Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
A
- ABANDONED_QUERY - Enum constant in enum class io.trino.spi.StandardErrorCode
- ABANDONED_TASK - Enum constant in enum class io.trino.spi.StandardErrorCode
- abort() - Method in interface io.trino.spi.connector.ConnectorMergeSink
- abort() - Method in interface io.trino.spi.connector.ConnectorPageSink
- abort() - Method in interface io.trino.spi.exchange.ExchangeSink
-
Notifies the exchange that the write operation has been aborted.
- absExact(Int128) - Static method in class io.trino.spi.type.Int128Math
- AbstractConnectorTableFunction - Class in io.trino.spi.function.table
- AbstractConnectorTableFunction(String, String, List<ArgumentSpecification>, ReturnTypeSpecification) - Constructor for class io.trino.spi.function.table.AbstractConnectorTableFunction
- AbstractIntType - Class in io.trino.spi.type
- AbstractIntType(TypeSignature) - Constructor for class io.trino.spi.type.AbstractIntType
- AbstractLongType - Class in io.trino.spi.type
- AbstractLongType(TypeSignature) - Constructor for class io.trino.spi.type.AbstractLongType
- AbstractType - Class in io.trino.spi.type
- AbstractType(TypeSignature, Class<?>, Class<? extends ValueBlock>) - Constructor for class io.trino.spi.type.AbstractType
- AbstractVariableWidthType - Class in io.trino.spi.type
- AbstractVariableWidthType(TypeSignature, Class<?>) - Constructor for class io.trino.spi.type.AbstractVariableWidthType
- AccessDeniedException - Exception Class in io.trino.spi.security
- AccessDeniedException(String) - Constructor for exception class io.trino.spi.security.AccessDeniedException
- AccessDeniedException(String, AccessDeniedException) - Constructor for exception class io.trino.spi.security.AccessDeniedException
- accumulator() - Static method in class io.trino.spi.metrics.Metrics
- AccumulatorState - Interface in io.trino.spi.function
- accumulatorStateDescriptor(Class<T>, AccumulatorStateSerializer<T>, AccumulatorStateFactory<T>) - Method in class io.trino.spi.function.AggregationImplementation.Builder
- accumulatorStateDescriptors(List<AggregationImplementation.AccumulatorStateDescriptor<?>>) - Method in class io.trino.spi.function.AggregationImplementation.Builder
- AccumulatorStateFactory<T> - Interface in io.trino.spi.function
- AccumulatorStateMetadata - Annotation Interface in io.trino.spi.function
- AccumulatorStateSerializer<T> - Interface in io.trino.spi.function
- adapt(MethodHandle, Type, List<Type>, InvocationConvention, InvocationConvention) - Static method in class io.trino.spi.function.ScalarFunctionAdapter
-
Adapt the method handle from the actual calling convention of a method be converted to the expected calling convention?
- add(int, Slice) - Method in interface io.trino.spi.exchange.ExchangeSink
-
Appends arbitrary
data
to a partition specified bypartitionId
. - add(long, long, long, long, long[], int) - Static method in class io.trino.spi.type.Int128Math
- add(Metrics) - Method in class io.trino.spi.metrics.Metrics.Accumulator
- ADD - Enum constant in enum class io.trino.spi.function.OperatorType
- ADD_FUNCTION_NAME - Static variable in class io.trino.spi.expression.StandardFunctions
-
Arithmetic addition.
- addBytes(int) - Method in class io.trino.spi.block.BlockBuilderStatus
- addCast(Type, Type) - Method in class io.trino.spi.function.FunctionDependencyDeclaration.FunctionDependencyDeclarationBuilder
- addCastSignature(TypeSignature, TypeSignature) - Method in class io.trino.spi.function.FunctionDependencyDeclaration.FunctionDependencyDeclarationBuilder
- addChangeListener(Consumer<MemoryPoolInfo>) - Method in interface io.trino.spi.memory.ClusterMemoryPoolManager
- addColumn(ConnectorSession, ConnectorTableHandle, ColumnMetadata) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Add the specified column
- addColumnStatistic(ColumnStatisticMetadata, Block) - Method in class io.trino.spi.statistics.ComputedStatistics.Builder
- addComparisonUnorderedFirstOperator(OperatorMethodHandle) - Method in class io.trino.spi.type.TypeOperatorDeclaration.Builder
- addComparisonUnorderedFirstOperators(Collection<OperatorMethodHandle>) - Method in class io.trino.spi.type.TypeOperatorDeclaration.Builder
- addComparisonUnorderedLastOperator(OperatorMethodHandle) - Method in class io.trino.spi.type.TypeOperatorDeclaration.Builder
- addComparisonUnorderedLastOperators(Collection<OperatorMethodHandle>) - Method in class io.trino.spi.type.TypeOperatorDeclaration.Builder
- addEqualOperator(OperatorMethodHandle) - Method in class io.trino.spi.type.TypeOperatorDeclaration.Builder
- addEqualOperators(Collection<OperatorMethodHandle>) - Method in class io.trino.spi.type.TypeOperatorDeclaration.Builder
- addField(ConnectorSession, ConnectorTableHandle, List<String>, String, Type, boolean) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Add the specified field, potentially nested, to a row.
- addFunction(CatalogSchemaFunctionName, List<Type>) - Method in class io.trino.spi.function.FunctionDependencyDeclaration.FunctionDependencyDeclarationBuilder
- addFunctionSignature(CatalogSchemaFunctionName, List<TypeSignature>) - Method in class io.trino.spi.function.FunctionDependencyDeclaration.FunctionDependencyDeclarationBuilder
- addHashCodeOperator(OperatorMethodHandle) - Method in class io.trino.spi.type.TypeOperatorDeclaration.Builder
- addHashCodeOperators(Collection<OperatorMethodHandle>) - Method in class io.trino.spi.type.TypeOperatorDeclaration.Builder
- addIdenticalOperator(OperatorMethodHandle) - Method in class io.trino.spi.type.TypeOperatorDeclaration.Builder
- addIdenticalOperators(Collection<OperatorMethodHandle>) - Method in class io.trino.spi.type.TypeOperatorDeclaration.Builder
- addIndeterminateOperator(OperatorMethodHandle) - Method in class io.trino.spi.type.TypeOperatorDeclaration.Builder
- addIndeterminateOperators(Collection<OperatorMethodHandle>) - Method in class io.trino.spi.type.TypeOperatorDeclaration.Builder
- addInput(WindowIndex, int, int) - Method in interface io.trino.spi.function.WindowAccumulator
-
Add the specified positions to the accumulator.
- addLessThanOperator(OperatorMethodHandle) - Method in class io.trino.spi.type.TypeOperatorDeclaration.Builder
- addLessThanOperators(Collection<OperatorMethodHandle>) - Method in class io.trino.spi.type.TypeOperatorDeclaration.Builder
- addLessThanOrEqualOperator(OperatorMethodHandle) - Method in class io.trino.spi.type.TypeOperatorDeclaration.Builder
- addLessThanOrEqualOperators(Collection<OperatorMethodHandle>) - Method in class io.trino.spi.type.TypeOperatorDeclaration.Builder
- addOperator(OperatorType, List<Type>) - Method in class io.trino.spi.function.FunctionDependencyDeclaration.FunctionDependencyDeclarationBuilder
- addOperators(TypeOperatorDeclaration) - Method in class io.trino.spi.type.TypeOperatorDeclaration.Builder
- addOperators(Class<?>, MethodHandles.Lookup) - Method in class io.trino.spi.type.TypeOperatorDeclaration.Builder
- addOperatorSignature(OperatorType, List<TypeSignature>) - Method in class io.trino.spi.function.FunctionDependencyDeclaration.FunctionDependencyDeclarationBuilder
- addOptionalCast(Type, Type) - Method in class io.trino.spi.function.FunctionDependencyDeclaration.FunctionDependencyDeclarationBuilder
- addOptionalCastSignature(TypeSignature, TypeSignature) - Method in class io.trino.spi.function.FunctionDependencyDeclaration.FunctionDependencyDeclarationBuilder
- addOptionalFunction(CatalogSchemaFunctionName, List<Type>) - Method in class io.trino.spi.function.FunctionDependencyDeclaration.FunctionDependencyDeclarationBuilder
- addOptionalFunctionSignature(CatalogSchemaFunctionName, List<TypeSignature>) - Method in class io.trino.spi.function.FunctionDependencyDeclaration.FunctionDependencyDeclarationBuilder
- addOptionalOperator(OperatorType, List<Type>) - Method in class io.trino.spi.function.FunctionDependencyDeclaration.FunctionDependencyDeclarationBuilder
- addOptionalOperatorSignature(OperatorType, List<TypeSignature>) - Method in class io.trino.spi.function.FunctionDependencyDeclaration.FunctionDependencyDeclarationBuilder
- addOrReplaceCatalog(CatalogProperties) - Method in interface io.trino.spi.catalog.CatalogStore
-
Add or replace catalog properties.
- addRangeInclusive(Object, Object) - Method in class io.trino.spi.predicate.SortedRangeSet.Builder
- addReadValueOperator(OperatorMethodHandle) - Method in class io.trino.spi.type.TypeOperatorDeclaration.Builder
- addReadValueOperators(Collection<OperatorMethodHandle>) - Method in class io.trino.spi.type.TypeOperatorDeclaration.Builder
- addRow(Object...) - Method in class io.trino.spi.connector.InMemoryRecordSet.Builder
- addSink(int) - Method in interface io.trino.spi.exchange.Exchange
-
Registers a new sink
- addSourceHandles(List<ExchangeSourceHandle>) - Method in interface io.trino.spi.exchange.ExchangeSource
-
Add more
ExchangeSourceHandle
's to be read by theExchangeSource
. - addTableStatistic(TableStatisticType, Block) - Method in class io.trino.spi.statistics.ComputedStatistics.Builder
- addType(TypeSignature) - Method in class io.trino.spi.function.FunctionDependencyDeclaration.FunctionDependencyDeclarationBuilder
- addValue(Object) - Method in class io.trino.spi.predicate.SortedRangeSet.Builder
- addWithOverflow(long, long, long, long, long[], int) - Static method in class io.trino.spi.type.Int128Math
- addXxHash64Operator(OperatorMethodHandle) - Method in class io.trino.spi.type.TypeOperatorDeclaration.Builder
- addXxHash64Operators(Collection<OperatorMethodHandle>) - Method in class io.trino.spi.type.TypeOperatorDeclaration.Builder
- ADMINISTRATIVELY_KILLED - Enum constant in enum class io.trino.spi.StandardErrorCode
- ADMINISTRATIVELY_PREEMPTED - Enum constant in enum class io.trino.spi.StandardErrorCode
- advanceNextPosition() - Method in class io.trino.spi.connector.InMemoryRecordSet.InMemoryRecordCursor
- advanceNextPosition() - Method in interface io.trino.spi.connector.RecordCursor
- AGGREGATE - Enum constant in enum class io.trino.spi.function.FunctionKind
- aggregateBuilder(String) - Static method in class io.trino.spi.function.FunctionMetadata
- AggregateFunction - Class in io.trino.spi.connector
- AggregateFunction(String, Type, List<ConnectorExpression>, List<SortItem>, boolean, Optional<ConnectorExpression>) - Constructor for class io.trino.spi.connector.AggregateFunction
- AggregationApplicationResult<T> - Class in io.trino.spi.connector
- AggregationApplicationResult(T, List<ConnectorExpression>, List<Assignment>, Map<ColumnHandle, ColumnHandle>, boolean) - Constructor for class io.trino.spi.connector.AggregationApplicationResult
- AggregationFunction - Annotation Interface in io.trino.spi.function
- AggregationFunctionMetadata - Class in io.trino.spi.function
- AggregationFunctionMetadata.AggregationFunctionMetadataBuilder - Class in io.trino.spi.function
- AggregationImplementation - Class in io.trino.spi.function
- AggregationImplementation.AccumulatorStateDescriptor<T> - Class in io.trino.spi.function
- AggregationImplementation.AccumulatorStateDescriptor.Builder<T> - Class in io.trino.spi.function
- AggregationImplementation.Builder - Class in io.trino.spi.function
- AggregationState - Annotation Interface in io.trino.spi.function
- alias() - Element in annotation interface io.trino.spi.function.AggregationFunction
- alias() - Element in annotation interface io.trino.spi.function.ScalarFunction
- alias(String) - Method in class io.trino.spi.function.FunctionMetadata.Builder
- all() - Static method in class io.trino.spi.predicate.TupleDomain
- all(Type) - Static method in class io.trino.spi.predicate.Domain
- all(Type) - Static method in class io.trino.spi.predicate.Range
- all(Type) - Static method in interface io.trino.spi.predicate.ValueSet
- ALL - Enum constant in enum class io.trino.spi.security.SelectedRole.Type
- ALL_COORDINATORS - Enum constant in enum class io.trino.spi.connector.SystemTable.Distribution
- ALL_NODES - Enum constant in enum class io.trino.spi.connector.SystemTable.Distribution
- AllOrNone - Interface in io.trino.spi.predicate
- AllOrNoneValueSet - Class in io.trino.spi.predicate
-
Set that either includes all values, or excludes all values.
- AllOrNoneValueSet(Type, boolean) - Constructor for class io.trino.spi.predicate.AllOrNoneValueSet
- allowSplittingReadIntoMultipleSubQueries(ConnectorSession, ConnectorTableHandle) - Method in interface io.trino.spi.connector.ConnectorMetadata
- allRequiredSinksFinished() - Method in interface io.trino.spi.exchange.Exchange
-
Called by the engine when all required sinks finished successfully.
- ALREADY_EXISTS - Enum constant in enum class io.trino.spi.StandardErrorCode
- ALTER_TABLE_EXECUTE - Enum constant in enum class io.trino.spi.resourcegroups.QueryType
- alwaysFalse() - Static method in class io.trino.spi.connector.Constraint
- alwaysTrue() - Static method in class io.trino.spi.connector.Constraint
- AMBIGUOUS_FUNCTION_CALL - Enum constant in enum class io.trino.spi.StandardErrorCode
- AMBIGUOUS_FUNCTION_IMPLEMENTATION - Enum constant in enum class io.trino.spi.StandardErrorCode
- AMBIGUOUS_NAME - Enum constant in enum class io.trino.spi.StandardErrorCode
- AMBIGUOUS_RETURN_TYPE - Enum constant in enum class io.trino.spi.StandardErrorCode
- analyze(ConnectorSession, ConnectorTransactionHandle, Map<String, Argument>, ConnectorAccessControl) - Method in class io.trino.spi.function.table.AbstractConnectorTableFunction
- analyze(ConnectorSession, ConnectorTransactionHandle, Map<String, Argument>, ConnectorAccessControl) - Method in interface io.trino.spi.function.table.ConnectorTableFunction
-
This method is called by the Analyzer.
- ANALYZE - Enum constant in enum class io.trino.spi.resourcegroups.QueryType
- AND_FUNCTION_NAME - Static variable in class io.trino.spi.expression.StandardFunctions
-
$and is a vararg function accepting boolean arguments
- anonymous(List<Type>) - Static method in class io.trino.spi.type.RowType
- anonymousField(TypeSignature) - Static method in class io.trino.spi.type.TypeSignatureParameter
- anonymousRow(Type...) - Static method in class io.trino.spi.type.RowType
- append(ValueBlock, int) - Method in class io.trino.spi.block.ArrayBlockBuilder
- append(ValueBlock, int) - Method in interface io.trino.spi.block.BlockBuilder
-
Append the specified value.
- append(ValueBlock, int) - Method in class io.trino.spi.block.ByteArrayBlockBuilder
- append(ValueBlock, int) - Method in class io.trino.spi.block.Fixed12BlockBuilder
- append(ValueBlock, int) - Method in class io.trino.spi.block.Int128ArrayBlockBuilder
- append(ValueBlock, int) - Method in class io.trino.spi.block.IntArrayBlockBuilder
- append(ValueBlock, int) - Method in class io.trino.spi.block.LongArrayBlockBuilder
- append(ValueBlock, int) - Method in class io.trino.spi.block.MapBlockBuilder
- append(ValueBlock, int) - Method in class io.trino.spi.block.RowBlockBuilder
- append(ValueBlock, int) - Method in class io.trino.spi.block.ShortArrayBlockBuilder
- append(ValueBlock, int) - Method in class io.trino.spi.block.VariableWidthBlockBuilder
- appendColumn(Block) - Method in class io.trino.spi.Page
- appendNull() - Method in class io.trino.spi.block.ArrayBlockBuilder
- appendNull() - Method in interface io.trino.spi.block.BlockBuilder
-
Appends a null value to the block.
- appendNull() - Method in class io.trino.spi.block.ByteArrayBlockBuilder
- appendNull() - Method in class io.trino.spi.block.Fixed12BlockBuilder
- appendNull() - Method in class io.trino.spi.block.Int128ArrayBlockBuilder
- appendNull() - Method in class io.trino.spi.block.IntArrayBlockBuilder
- appendNull() - Method in class io.trino.spi.block.LongArrayBlockBuilder
- appendNull() - Method in class io.trino.spi.block.MapBlockBuilder
- appendNull() - Method in class io.trino.spi.block.RowBlockBuilder
- appendNull() - Method in class io.trino.spi.block.ShortArrayBlockBuilder
- appendNull() - Method in class io.trino.spi.block.VariableWidthBlockBuilder
- appendPage(Page) - Method in interface io.trino.spi.connector.ConnectorPageSink
-
Returns a future that will be completed when the page sink can accept more pages.
- appendPositions(ValueBlock, int[], int, int) - Method in class io.trino.spi.block.ArrayBlockBuilder
- appendPositions(ValueBlock, int[], int, int) - Method in interface io.trino.spi.block.BlockBuilder
-
Append the values at the specified positions.
- appendPositions(ValueBlock, int[], int, int) - Method in class io.trino.spi.block.ByteArrayBlockBuilder
- appendPositions(ValueBlock, int[], int, int) - Method in class io.trino.spi.block.Fixed12BlockBuilder
- appendPositions(ValueBlock, int[], int, int) - Method in class io.trino.spi.block.Int128ArrayBlockBuilder
- appendPositions(ValueBlock, int[], int, int) - Method in class io.trino.spi.block.IntArrayBlockBuilder
- appendPositions(ValueBlock, int[], int, int) - Method in class io.trino.spi.block.LongArrayBlockBuilder
- appendPositions(ValueBlock, int[], int, int) - Method in class io.trino.spi.block.MapBlockBuilder
- appendPositions(ValueBlock, int[], int, int) - Method in class io.trino.spi.block.RowBlockBuilder
- appendPositions(ValueBlock, int[], int, int) - Method in class io.trino.spi.block.ShortArrayBlockBuilder
- appendPositions(ValueBlock, int[], int, int) - Method in class io.trino.spi.block.VariableWidthBlockBuilder
- appendRange(ValueBlock, int, int) - Method in class io.trino.spi.block.ArrayBlockBuilder
- appendRange(ValueBlock, int, int) - Method in interface io.trino.spi.block.BlockBuilder
-
Append the values in the specified range.
- appendRange(ValueBlock, int, int) - Method in class io.trino.spi.block.ByteArrayBlockBuilder
- appendRange(ValueBlock, int, int) - Method in class io.trino.spi.block.Fixed12BlockBuilder
- appendRange(ValueBlock, int, int) - Method in class io.trino.spi.block.Int128ArrayBlockBuilder
- appendRange(ValueBlock, int, int) - Method in class io.trino.spi.block.IntArrayBlockBuilder
- appendRange(ValueBlock, int, int) - Method in class io.trino.spi.block.LongArrayBlockBuilder
- appendRange(ValueBlock, int, int) - Method in class io.trino.spi.block.MapBlockBuilder
- appendRange(ValueBlock, int, int) - Method in class io.trino.spi.block.RowBlockBuilder
- appendRange(ValueBlock, int, int) - Method in class io.trino.spi.block.ShortArrayBlockBuilder
- appendRange(ValueBlock, int, int) - Method in class io.trino.spi.block.VariableWidthBlockBuilder
- appendRepeated(ValueBlock, int, int) - Method in class io.trino.spi.block.ArrayBlockBuilder
- appendRepeated(ValueBlock, int, int) - Method in interface io.trino.spi.block.BlockBuilder
-
Append the specified value multiple times.
- appendRepeated(ValueBlock, int, int) - Method in class io.trino.spi.block.ByteArrayBlockBuilder
- appendRepeated(ValueBlock, int, int) - Method in class io.trino.spi.block.Fixed12BlockBuilder
- appendRepeated(ValueBlock, int, int) - Method in class io.trino.spi.block.Int128ArrayBlockBuilder
- appendRepeated(ValueBlock, int, int) - Method in class io.trino.spi.block.IntArrayBlockBuilder
- appendRepeated(ValueBlock, int, int) - Method in class io.trino.spi.block.LongArrayBlockBuilder
- appendRepeated(ValueBlock, int, int) - Method in class io.trino.spi.block.MapBlockBuilder
- appendRepeated(ValueBlock, int, int) - Method in class io.trino.spi.block.RowBlockBuilder
- appendRepeated(ValueBlock, int, int) - Method in class io.trino.spi.block.ShortArrayBlockBuilder
- appendRepeated(ValueBlock, int, int) - Method in class io.trino.spi.block.VariableWidthBlockBuilder
- appendTo(int, int, BlockBuilder) - Method in interface io.trino.spi.function.WindowIndex
-
Outputs a value from the index.
- appendTo(Block, int, BlockBuilder) - Method in class io.trino.spi.type.AbstractIntType
- appendTo(Block, int, BlockBuilder) - Method in class io.trino.spi.type.AbstractLongType
- appendTo(Block, int, BlockBuilder) - Method in class io.trino.spi.type.AbstractVariableWidthType
- appendTo(Block, int, BlockBuilder) - Method in class io.trino.spi.type.ArrayType
- appendTo(Block, int, BlockBuilder) - Method in class io.trino.spi.type.BooleanType
- appendTo(Block, int, BlockBuilder) - Method in class io.trino.spi.type.DoubleType
- appendTo(Block, int, BlockBuilder) - Method in class io.trino.spi.type.MapType
- appendTo(Block, int, BlockBuilder) - Method in class io.trino.spi.type.RowType
- appendTo(Block, int, BlockBuilder) - Method in class io.trino.spi.type.SmallintType
- appendTo(Block, int, BlockBuilder) - Method in class io.trino.spi.type.TinyintType
- appendTo(Block, int, BlockBuilder) - Method in interface io.trino.spi.type.Type
-
Append the value at
position
inblock
toblockBuilder
. - appendTo(Block, int, BlockBuilder) - Method in class io.trino.spi.type.UuidType
- applied() - Method in record class io.trino.spi.eventlistener.QueryPlanOptimizerStatistics
-
Returns the value of the
applied
record component. - apply(ArrayBlock.ArrayBlockFunction<T>, int) - Method in class io.trino.spi.block.ArrayBlock
- apply(Block, int, int) - Method in interface io.trino.spi.block.ArrayBlock.ArrayBlockFunction
- applyAggregation(ConnectorSession, ConnectorTableHandle, List<AggregateFunction>, Map<String, ColumnHandle>, List<List<ColumnHandle>>) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Attempt to push down the aggregates into the table.
- applyDelete(ConnectorSession, ConnectorTableHandle) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Attempt to push down a delete operation into the connector.
- applyFilter(ConnectorSession, ConnectorTableHandle, Constraint) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Attempt to push down the provided constraint into the table.
- applyJoin(ConnectorSession, JoinType, ConnectorTableHandle, ConnectorTableHandle, ConnectorExpression, Map<String, ColumnHandle>, Map<String, ColumnHandle>, JoinStatistics) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Attempt to push down the join operation.
- applyJoin(ConnectorSession, JoinType, ConnectorTableHandle, ConnectorTableHandle, List<JoinCondition>, Map<String, ColumnHandle>, Map<String, ColumnHandle>, JoinStatistics) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Deprecated.
- applyLimit(ConnectorSession, ConnectorTableHandle, long) - Method in interface io.trino.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.trino.spi.connector.ConnectorMetadata
-
Attempt to push down the provided projections into the table.
- applySample(ConnectorSession, ConnectorTableHandle, SampleType, double) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Attempt to push down the sampling into the table.
- applyTableFunction(ConnectorSession, ConnectorTableFunctionHandle) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Attempt to push down the table function invocation into the connector.
- applyTableScanRedirect(ConnectorSession, ConnectorTableHandle) - Method in interface io.trino.spi.connector.ConnectorMetadata
- applyTopN(ConnectorSession, ConnectorTableHandle, long, List<SortItem>, Map<String, ColumnHandle>) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Attempt to push down the TopN into the table scan.
- applyUpdate(ConnectorSession, ConnectorTableHandle, Map<ColumnHandle, Constant>) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Attempt to push down an update operation into the connector.
- Argument - Class in io.trino.spi.function.table
-
This class represents the three types of arguments passed to a Table Function: scalar arguments, descriptor arguments, and table arguments.
- Argument() - Constructor for class io.trino.spi.function.table.Argument
- argumentNullability(boolean...) - Method in class io.trino.spi.function.FunctionMetadata.Builder
- argumentNullability(List<Boolean>) - Method in class io.trino.spi.function.FunctionMetadata.Builder
- arguments() - Element in annotation interface io.trino.spi.function.Convention
- ArgumentSpecification - Class in io.trino.spi.function.table
-
Abstract class to capture the three supported argument types for a table function: - Table arguments - Descriptor arguments - SQL scalar arguments
- argumentType(Type) - Method in class io.trino.spi.function.Signature.Builder
- argumentType(TypeSignature) - Method in class io.trino.spi.function.Signature.Builder
- argumentTypes() - Element in annotation interface io.trino.spi.function.FunctionDependency
- argumentTypes() - Element in annotation interface io.trino.spi.function.OperatorDependency
- argumentTypes() - Element in annotation interface io.trino.spi.function.WindowFunctionSignature
- argumentTypes(List<TypeSignature>) - Method in class io.trino.spi.function.Signature.Builder
- ARRAY - Static variable in class io.trino.spi.type.StandardTypes
- ARRAY_CONSTRUCTOR_FUNCTION_NAME - Static variable in class io.trino.spi.expression.StandardFunctions
-
$array creates instance of
ArrayType
- ArrayBlock - Class in io.trino.spi.block
- ArrayBlock.ArrayBlockFunction<T> - Interface in io.trino.spi.block
- ArrayBlockBuilder - Class in io.trino.spi.block
- ArrayBlockBuilder(BlockBuilder, BlockBuilderStatus, int) - Constructor for class io.trino.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.trino.spi.block.ArrayBlockBuilder
- ArrayBlockBuilder(Type, BlockBuilderStatus, int, int) - Constructor for class io.trino.spi.block.ArrayBlockBuilder
- ArrayBlockEncoding - Class in io.trino.spi.block
- ArrayBlockEncoding() - Constructor for class io.trino.spi.block.ArrayBlockEncoding
- arrayType(TypeSignature) - Static method in class io.trino.spi.type.TypeSignature
- arrayType(TypeSignatureParameter) - Static method in class io.trino.spi.type.TypeSignature
- ArrayType - Class in io.trino.spi.type
- ArrayType(Type) - Constructor for class io.trino.spi.type.ArrayType
- ArrayValueBuilder<E> - Interface in io.trino.spi.block
- asBlock() - Method in class io.trino.spi.predicate.NullableValue
- ASC_NULLS_FIRST - Enum constant in enum class io.trino.spi.connector.SortOrder
- ASC_NULLS_LAST - Enum constant in enum class io.trino.spi.connector.SortOrder
- asNull(Type) - Static method in class io.trino.spi.predicate.NullableValue
- asPredicate() - Method in class io.trino.spi.predicate.TupleDomain
- Assignment - Class in io.trino.spi.connector
- Assignment(String, ColumnHandle, Type) - Constructor for class io.trino.spi.connector.Assignment
- authenticate(List<X509Certificate>) - Method in interface io.trino.spi.security.CertificateAuthenticator
-
Authenticate and extract principal from client certificate.
- AUTOCOMMIT_WRITE_CONFLICT - Enum constant in enum class io.trino.spi.StandardErrorCode
B
- BaseViewReferenceInfo - Interface in io.trino.spi.eventlistener
-
This class is JSON serializable for convenience and serialization compatibility is not guaranteed across versions.
- BasicPrincipal - Class in io.trino.spi.security
- BasicPrincipal(String) - Constructor for class io.trino.spi.security.BasicPrincipal
- BasicRelationStatistics - Class in io.trino.spi.connector
- BasicRelationStatistics(long, long) - Constructor for class io.trino.spi.connector.BasicRelationStatistics
- beginCreateTable(ConnectorSession, ConnectorTableMetadata, Optional<ConnectorTableLayout>, RetryMode, boolean) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Begin the atomic creation of a table with data.
- beginInsert(ConnectorSession, ConnectorTableHandle, List<ColumnHandle>, RetryMode) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Begin insert query.
- beginMerge(ConnectorSession, ConnectorTableHandle, RetryMode) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Do whatever is necessary to start an MERGE query, returning the
ConnectorMergeTableHandle
instance that will be passed to the PageSink, and to theConnectorMetadata.finishMerge(io.trino.spi.connector.ConnectorSession, io.trino.spi.connector.ConnectorMergeTableHandle, java.util.List<io.trino.spi.connector.ConnectorTableHandle>, java.util.Collection<io.airlift.slice.Slice>, java.util.Collection<io.trino.spi.statistics.ComputedStatistics>)
method. - beginQuery(ConnectorSession) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Start a query.
- beginRefreshMaterializedView(ConnectorSession, ConnectorTableHandle, List<ConnectorTableHandle>, RetryMode, RefreshType) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Begin materialized view query.
- beginStatisticsCollection(ConnectorSession, ConnectorTableHandle) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Begin statistics collection
- beginTableExecute(ConnectorSession, ConnectorTableExecuteHandle, ConnectorTableHandle) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Begin execution of table procedure
- BeginTableExecuteResult<E,
T> - Class in io.trino.spi.connector - BeginTableExecuteResult(E, T) - Constructor for class io.trino.spi.connector.BeginTableExecuteResult
- beginTransaction(IsolationLevel, boolean, boolean) - Method in interface io.trino.spi.connector.Connector
-
Start a new transaction and return a handle for it.
- BERNOULLI - Enum constant in enum class io.trino.spi.connector.SampleType
- BIGINT - Static variable in class io.trino.spi.type.BigintType
- BIGINT - Static variable in class io.trino.spi.type.StandardTypes
- bigIntegerTenToNth(int) - Static method in class io.trino.spi.type.Decimals
- BigintType - Class in io.trino.spi.type
- Block - Interface in io.trino.spi.block
- BLOCK_BUILDER - Enum constant in enum class io.trino.spi.function.InvocationConvention.InvocationReturnConvention
-
Return value is witten to a BlockBuilder passed as the last argument.
- BLOCK_POSITION - Enum constant in enum class io.trino.spi.function.InvocationConvention.InvocationArgumentConvention
-
Argument is passed a Block followed by the integer position in the block.
- BLOCK_POSITION_NOT_NULL - Enum constant in enum class io.trino.spi.function.InvocationConvention.InvocationArgumentConvention
-
Argument is passed a Block followed by the integer position in the block.
- BlockBuilder - Interface in io.trino.spi.block
- BlockBuilderStatus - Class in io.trino.spi.block
- blocked(CompletableFuture<Void>) - Static method in class io.trino.spi.function.table.TableFunctionProcessorState.Blocked
- BlockEncoding - Interface in io.trino.spi.block
- BlockEncodingSerde - Interface in io.trino.spi.block
- BlockIndex - Annotation Interface in io.trino.spi.function
- BlockPosition - Annotation Interface in io.trino.spi.function
- blockToNativeValue(Type, Block) - Static method in class io.trino.spi.predicate.Utils
- BOOLEAN - Static variable in class io.trino.spi.type.BooleanType
- BOOLEAN - Static variable in class io.trino.spi.type.StandardTypes
- booleanProperty(String, String, Boolean, boolean) - Static method in class io.trino.spi.session.PropertyMetadata
- booleanProperty(String, String, Boolean, Consumer<Boolean>, boolean) - Static method in class io.trino.spi.session.PropertyMetadata
- BooleanType - Class in io.trino.spi.type
- BoundSignature - Class in io.trino.spi.function
- BoundSignature(CatalogSchemaFunctionName, Type, List<Type>) - Constructor for class io.trino.spi.function.BoundSignature
- BOXED_NULLABLE - Enum constant in enum class io.trino.spi.function.InvocationConvention.InvocationArgumentConvention
-
Argument is always an object type.
- BucketFunction - Interface in io.trino.spi.connector
- BufferedArrayValueBuilder - Class in io.trino.spi.block
- BufferedMapValueBuilder - Class in io.trino.spi.block
- BufferedRowValueBuilder - Class in io.trino.spi.block
- build() - Method in class io.trino.spi.block.ArrayBlockBuilder
- build() - Method in interface io.trino.spi.block.BlockBuilder
-
Builds the block.
- build() - Method in class io.trino.spi.block.ByteArrayBlockBuilder
- build() - Method in class io.trino.spi.block.Fixed12BlockBuilder
- build() - Method in class io.trino.spi.block.Int128ArrayBlockBuilder
- build() - Method in class io.trino.spi.block.IntArrayBlockBuilder
- build() - Method in class io.trino.spi.block.LongArrayBlockBuilder
- build() - Method in class io.trino.spi.block.MapBlockBuilder
- build() - Method in class io.trino.spi.block.RowBlockBuilder
- build() - Method in class io.trino.spi.block.ShortArrayBlockBuilder
- build() - Method in class io.trino.spi.block.VariableWidthBlockBuilder
- build() - Method in class io.trino.spi.connector.ColumnMetadata.Builder
- build() - Method in class io.trino.spi.connector.ColumnSchema.Builder
- build() - Method in class io.trino.spi.connector.InMemoryRecordSet.Builder
- build() - Method in class io.trino.spi.exchange.ExchangeSourceOutputSelector.Builder
- build() - Method in class io.trino.spi.function.AggregationFunctionMetadata.AggregationFunctionMetadataBuilder
- build() - Method in class io.trino.spi.function.AggregationImplementation.AccumulatorStateDescriptor.Builder
- build() - Method in class io.trino.spi.function.AggregationImplementation.Builder
- build() - Method in class io.trino.spi.function.FunctionDependencyDeclaration.FunctionDependencyDeclarationBuilder
- build() - Method in class io.trino.spi.function.FunctionMetadata.Builder
- build() - Method in class io.trino.spi.function.ScalarFunctionImplementation.Builder
- build() - Method in class io.trino.spi.function.Signature.Builder
- build() - Method in class io.trino.spi.function.table.DescriptorArgument.Builder
- build() - Method in class io.trino.spi.function.table.DescriptorArgumentSpecification.Builder
- build() - Method in class io.trino.spi.function.table.ScalarArgument.Builder
- build() - Method in class io.trino.spi.function.table.ScalarArgumentSpecification.Builder
- build() - Method in class io.trino.spi.function.table.TableArgument.Builder
- build() - Method in class io.trino.spi.function.table.TableArgumentSpecification.Builder
- build() - Method in class io.trino.spi.function.table.TableFunctionAnalysis.Builder
- build() - Method in class io.trino.spi.function.TypeVariableConstraint.TypeVariableConstraintBuilder
- build() - Method in class io.trino.spi.PageBuilder
- build() - Method in class io.trino.spi.predicate.SortedRangeSet.Builder
- build() - Method in class io.trino.spi.security.ConnectorIdentity.Builder
- build() - Method in class io.trino.spi.security.Identity.Builder
- build() - Method in class io.trino.spi.security.ViewExpression.Builder
- build() - Method in class io.trino.spi.statistics.ColumnStatistics.Builder
- build() - Method in class io.trino.spi.statistics.ComputedStatistics.Builder
- build() - Method in class io.trino.spi.statistics.TableStatistics.Builder
- build() - Method in class io.trino.spi.type.TypeOperatorDeclaration.Builder
- build(int, ArrayValueBuilder<E>) - Method in class io.trino.spi.block.BufferedArrayValueBuilder
- build(int, MapValueBuilder<E>) - Method in class io.trino.spi.block.BufferedMapValueBuilder
- build(BlockBuilder) - Method in interface io.trino.spi.block.ArrayValueBuilder
- build(BlockBuilder, BlockBuilder) - Method in interface io.trino.spi.block.MapValueBuilder
- build(RowValueBuilder<E>) - Method in class io.trino.spi.block.BufferedRowValueBuilder
- build(List<BlockBuilder>) - Method in interface io.trino.spi.block.RowValueBuilder
- buildArrayValue(ArrayType, int, ArrayValueBuilder<E>) - Static method in interface io.trino.spi.block.ArrayValueBuilder
- buildEntry(ArrayValueBuilder<E>) - Method in class io.trino.spi.block.ArrayBlockBuilder
- buildEntry(MapValueBuilder<E>) - Method in class io.trino.spi.block.MapBlockBuilder
- buildEntry(RowValueBuilder<E>) - Method in class io.trino.spi.block.RowBlockBuilder
- builder() - Static method in class io.trino.spi.connector.ColumnMetadata
- builder() - Static method in class io.trino.spi.connector.ColumnSchema
- builder() - Static method in class io.trino.spi.function.AggregationFunctionMetadata
- builder() - Static method in class io.trino.spi.function.AggregationImplementation
- builder() - Static method in class io.trino.spi.function.FunctionDependencyDeclaration
- builder() - Static method in class io.trino.spi.function.ScalarFunctionImplementation
- builder() - Static method in class io.trino.spi.function.Signature
- builder() - Static method in class io.trino.spi.function.table.DescriptorArgument
- builder() - Static method in class io.trino.spi.function.table.DescriptorArgumentSpecification
- builder() - Static method in class io.trino.spi.function.table.ScalarArgument
- builder() - Static method in class io.trino.spi.function.table.ScalarArgumentSpecification
- builder() - Static method in class io.trino.spi.function.table.TableArgument
- builder() - Static method in class io.trino.spi.function.table.TableArgumentSpecification
- builder() - Static method in class io.trino.spi.function.table.TableFunctionAnalysis
- builder() - Static method in class io.trino.spi.security.ViewExpression
- builder() - Static method in class io.trino.spi.statistics.ColumnStatistics
- builder() - Static method in class io.trino.spi.statistics.TableStatistics
- builder(ColumnMetadata) - Static method in class io.trino.spi.connector.ColumnSchema
- builder(ConnectorTableMetadata) - Static method in class io.trino.spi.connector.InMemoryRecordSet
- builder(Type, int) - Static method in class io.trino.spi.predicate.SortedRangeSet
- builder(Class<?>) - Static method in class io.trino.spi.type.TypeOperatorDeclaration
- builder(Class<T>) - Static method in class io.trino.spi.function.AggregationImplementation.AccumulatorStateDescriptor
- builder(String) - Static method in class io.trino.spi.function.TypeVariableConstraint
- builder(String, FunctionKind) - Static method in class io.trino.spi.function.FunctionMetadata
- builder(Collection<Type>) - Static method in class io.trino.spi.connector.InMemoryRecordSet
- builder(List<ColumnMetadata>) - Static method in class io.trino.spi.connector.InMemoryRecordSet
- builder(List<String>, List<Block>) - Static method in class io.trino.spi.statistics.ComputedStatistics
- builder(Set<ExchangeId>) - Static method in class io.trino.spi.exchange.ExchangeSourceOutputSelector
- Builder() - Constructor for class io.trino.spi.statistics.ColumnStatistics.Builder
- Builder() - Constructor for class io.trino.spi.statistics.TableStatistics.Builder
- Builder(String) - Constructor for class io.trino.spi.security.Identity.Builder
- Builder(Set<ExchangeId>) - Constructor for class io.trino.spi.exchange.ExchangeSourceOutputSelector.Builder
- builderFrom(ColumnMetadata) - Static method in class io.trino.spi.connector.ColumnMetadata
- buildMapValue(MapType, int, MapValueBuilder<E>) - Static method in interface io.trino.spi.block.MapValueBuilder
- buildRowValue(RowType, RowValueBuilder<E>) - Static method in interface io.trino.spi.block.RowValueBuilder
- buildValueBlock() - Method in class io.trino.spi.block.ArrayBlockBuilder
- buildValueBlock() - Method in interface io.trino.spi.block.BlockBuilder
-
Builds a ValueBlock.
- buildValueBlock() - Method in class io.trino.spi.block.ByteArrayBlockBuilder
- buildValueBlock() - Method in class io.trino.spi.block.Fixed12BlockBuilder
- buildValueBlock() - Method in class io.trino.spi.block.Int128ArrayBlockBuilder
- buildValueBlock() - Method in class io.trino.spi.block.IntArrayBlockBuilder
- buildValueBlock() - Method in class io.trino.spi.block.LongArrayBlockBuilder
- buildValueBlock() - Method in class io.trino.spi.block.MapBlockBuilder
- buildValueBlock() - Method in class io.trino.spi.block.RowBlockBuilder
- buildValueBlock() - Method in class io.trino.spi.block.ShortArrayBlockBuilder
- buildValueBlock() - Method in class io.trino.spi.block.VariableWidthBlockBuilder
- ByteArrayBlock - Class in io.trino.spi.block
- ByteArrayBlock(int, Optional<boolean[]>, byte[]) - Constructor for class io.trino.spi.block.ByteArrayBlock
- ByteArrayBlockBuilder - Class in io.trino.spi.block
- ByteArrayBlockBuilder(BlockBuilderStatus, int) - Constructor for class io.trino.spi.block.ByteArrayBlockBuilder
- ByteArrayBlockEncoding - Class in io.trino.spi.block
- ByteArrayBlockEncoding() - Constructor for class io.trino.spi.block.ByteArrayBlockEncoding
- byteCount(Slice, int, int, int) - Static method in class io.trino.spi.type.Varchars
-
Get the byte count of a given
slice
with in range[offset, offset + length)
for at mostcodePointCount
many code points - byteCountWithoutTrailingSpace(Slice, int, int) - Static method in class io.trino.spi.type.Chars
- byteCountWithoutTrailingSpace(Slice, int, int, int) - Static method in class io.trino.spi.type.Chars
C
- Call - Class in io.trino.spi.expression
- Call(Type, FunctionName, List<ConnectorExpression>) - Constructor for class io.trino.spi.expression.Call
- CAN_QUEUE - Enum constant in enum class io.trino.spi.resourcegroups.ResourceGroupState
- CAN_RUN - Enum constant in enum class io.trino.spi.resourcegroups.ResourceGroupState
- canAccessCatalog(SystemSecurityContext, String) - Method in interface io.trino.spi.security.SystemAccessControl
-
Is identity allowed to access the specified catalog?
- canAdapt(InvocationConvention, InvocationConvention) - Static method in class io.trino.spi.function.ScalarFunctionAdapter
-
Can the actual calling convention of a method be converted to the expected calling convention?
- canCreateViewWithExecuteFunction(ConnectorSecurityContext, SchemaRoutineName) - Method in interface io.trino.spi.connector.ConnectorAccessControl
-
Is identity allowed to create a view that executes the specified function?
- canCreateViewWithExecuteFunction(SystemSecurityContext, CatalogSchemaRoutineName) - Method in interface io.trino.spi.security.SystemAccessControl
-
Is identity allowed to create a view that executes the specified function?
- canExecuteFunction(ConnectorSecurityContext, SchemaRoutineName) - Method in interface io.trino.spi.connector.ConnectorAccessControl
-
Is the identity allowed to execute the specified function?
- canExecuteFunction(SystemSecurityContext, CatalogSchemaRoutineName) - Method in interface io.trino.spi.security.SystemAccessControl
-
Is identity allowed to execute the specified function?
- CAST - Enum constant in enum class io.trino.spi.function.OperatorType
- CAST_FUNCTION_NAME - Static variable in class io.trino.spi.expression.StandardFunctions
-
$cast function result type is determined by the
ConnectorExpression.getType()
- castableFrom(Type) - Method in class io.trino.spi.function.TypeVariableConstraint.TypeVariableConstraintBuilder
- castableFrom(TypeSignature) - Method in class io.trino.spi.function.TypeVariableConstraint.TypeVariableConstraintBuilder
- castableFromTypeParameter(String, TypeSignature) - Method in class io.trino.spi.function.Signature.Builder
- castableTo(Type) - Method in class io.trino.spi.function.TypeVariableConstraint.TypeVariableConstraintBuilder
- castableTo(TypeSignature) - Method in class io.trino.spi.function.TypeVariableConstraint.TypeVariableConstraintBuilder
- castableToTypeParameter(String, TypeSignature) - Method in class io.trino.spi.function.Signature.Builder
- CastDependency - Annotation Interface in io.trino.spi.function
- catalog(String) - Method in class io.trino.spi.security.ViewExpression.Builder
- CATALOG_NOT_AVAILABLE - Enum constant in enum class io.trino.spi.StandardErrorCode
- CATALOG_NOT_FOUND - Enum constant in enum class io.trino.spi.StandardErrorCode
- CATALOG_STORE_ERROR - Enum constant in enum class io.trino.spi.StandardErrorCode
- CATALOG_UNAVAILABLE - Enum constant in enum class io.trino.spi.StandardErrorCode
- catalogHandle() - Method in record class io.trino.spi.catalog.CatalogProperties
-
Returns the value of the
catalogHandle
record component. - CatalogHandle - Class in io.trino.spi.connector
- CatalogHandle.CatalogHandleType - Enum Class in io.trino.spi.connector
- CatalogHandle.CatalogVersion - Class in io.trino.spi.connector
- catalogName() - Method in interface io.trino.spi.eventlistener.BaseViewReferenceInfo
- catalogName() - Method in record class io.trino.spi.eventlistener.MaterializedViewReferenceInfo
-
Returns the value of the
catalogName
record component. - catalogName() - Method in record class io.trino.spi.eventlistener.ViewReferenceInfo
-
Returns the value of the
catalogName
record component. - CatalogName - Class in io.trino.spi.catalog
- CatalogName(String) - Constructor for class io.trino.spi.catalog.CatalogName
- CatalogProperties - Record Class in io.trino.spi.catalog
- CatalogProperties(CatalogHandle, ConnectorName, Map<String, String>) - Constructor for record class io.trino.spi.catalog.CatalogProperties
-
Creates an instance of a
CatalogProperties
record class. - CatalogSchemaFunctionName - Class in io.trino.spi.function
- CatalogSchemaFunctionName(String, SchemaFunctionName) - Constructor for class io.trino.spi.function.CatalogSchemaFunctionName
- CatalogSchemaFunctionName(String, String, String) - Constructor for class io.trino.spi.function.CatalogSchemaFunctionName
- CatalogSchemaName - Class in io.trino.spi.connector
- CatalogSchemaName(String, String) - Constructor for class io.trino.spi.connector.CatalogSchemaName
- CatalogSchemaRoutineName - Class in io.trino.spi.connector
- CatalogSchemaRoutineName(String, SchemaRoutineName) - Constructor for class io.trino.spi.connector.CatalogSchemaRoutineName
- CatalogSchemaRoutineName(String, String, String) - Constructor for class io.trino.spi.connector.CatalogSchemaRoutineName
- CatalogSchemaTableName - Class in io.trino.spi.connector
- CatalogSchemaTableName(String, SchemaTableName) - Constructor for class io.trino.spi.connector.CatalogSchemaTableName
- CatalogSchemaTableName(String, String, String) - Constructor for class io.trino.spi.connector.CatalogSchemaTableName
- CatalogStore - Interface in io.trino.spi.catalog
- CatalogStore.StoredCatalog - Interface in io.trino.spi.catalog
- CatalogStoreFactory - Interface in io.trino.spi.catalog
- CatalogVersion(String) - Constructor for class io.trino.spi.connector.CatalogHandle.CatalogVersion
-
Version of a catalog.
- CertificateAuthenticator - Interface in io.trino.spi.security
- CertificateAuthenticatorFactory - Interface in io.trino.spi.security
- CHANGE_ONLY_UPDATED_COLUMNS - Enum constant in enum class io.trino.spi.connector.RowChangeParadigm
-
A storage paradigm in which the connector can update individual columns of rows identified by a rowId.
- CHAR - Static variable in class io.trino.spi.type.StandardTypes
- Chars - Class in io.trino.spi.type
- CharType - Class in io.trino.spi.type
- checkCanAddColumn(ConnectorSecurityContext, SchemaTableName) - Method in interface io.trino.spi.connector.ConnectorAccessControl
-
Check if identity is allowed to add columns to the specified table.
- checkCanAddColumn(SystemSecurityContext, CatalogSchemaTableName) - Method in interface io.trino.spi.security.SystemAccessControl
-
Check if identity is allowed to add columns to the specified table in a catalog.
- checkCanAlterColumn(ConnectorSecurityContext, SchemaTableName) - Method in interface io.trino.spi.connector.ConnectorAccessControl
-
Check if identity is allowed to alter columns for the specified table.
- checkCanAlterColumn(SystemSecurityContext, CatalogSchemaTableName) - Method in interface io.trino.spi.security.SystemAccessControl
-
Check if identity is allowed to alter columns for the specified table in a catalog.
- checkCanCreateCatalog(SystemSecurityContext, String) - Method in interface io.trino.spi.security.SystemAccessControl
-
Check if identity is allowed to create the specified catalog.
- checkCanCreateFunction(ConnectorSecurityContext, SchemaRoutineName) - Method in interface io.trino.spi.connector.ConnectorAccessControl
-
Check if identity is allowed to create the specified function.
- checkCanCreateFunction(SystemSecurityContext, CatalogSchemaRoutineName) - Method in interface io.trino.spi.security.SystemAccessControl
-
Check if identity is allowed to create the specified function in the catalog.
- checkCanCreateMaterializedView(ConnectorSecurityContext, SchemaTableName, Map<String, Object>) - Method in interface io.trino.spi.connector.ConnectorAccessControl
-
Check if identity is allowed to create the specified materialized view.
- checkCanCreateMaterializedView(SystemSecurityContext, CatalogSchemaTableName, Map<String, Object>) - Method in interface io.trino.spi.security.SystemAccessControl
-
Check if identity is allowed to create the specified materialized view in a catalog.
- checkCanCreateRole(ConnectorSecurityContext, String, Optional<TrinoPrincipal>) - Method in interface io.trino.spi.connector.ConnectorAccessControl
- checkCanCreateRole(SystemSecurityContext, String, Optional<TrinoPrincipal>) - Method in interface io.trino.spi.security.SystemAccessControl
-
Check if identity is allowed to create the specified role.
- checkCanCreateSchema(ConnectorSecurityContext, String, Map<String, Object>) - Method in interface io.trino.spi.connector.ConnectorAccessControl
-
Check if identity is allowed to create the specified schema with properties.
- checkCanCreateSchema(SystemSecurityContext, CatalogSchemaName, Map<String, Object>) - Method in interface io.trino.spi.security.SystemAccessControl
-
Check if identity is allowed to create the specified schema with properties in a catalog.
- checkCanCreateTable(ConnectorSecurityContext, SchemaTableName, Map<String, Object>) - Method in interface io.trino.spi.connector.ConnectorAccessControl
-
Check if identity is allowed to create the specified table with properties.
- checkCanCreateTable(SystemSecurityContext, CatalogSchemaTableName, Map<String, Object>) - Method in interface io.trino.spi.security.SystemAccessControl
-
Check if identity is allowed to create the specified table with properties in a catalog.
- checkCanCreateView(ConnectorSecurityContext, SchemaTableName) - Method in interface io.trino.spi.connector.ConnectorAccessControl
-
Check if identity is allowed to create the specified view.
- checkCanCreateView(SystemSecurityContext, CatalogSchemaTableName) - Method in interface io.trino.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.trino.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.trino.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.trino.spi.connector.ConnectorAccessControl
-
Check if identity is allowed to delete from the specified table.
- checkCanDeleteFromTable(SystemSecurityContext, CatalogSchemaTableName) - Method in interface io.trino.spi.security.SystemAccessControl
-
Check if identity is allowed to delete from the specified table in a catalog.
- checkCanDenyEntityPrivilege(SystemSecurityContext, EntityPrivilege, EntityKindAndName, TrinoPrincipal) - Method in interface io.trino.spi.security.SystemAccessControl
-
Check if identity is allowed to deny the specified privilege to the grantee on the specified entity.
- checkCanDenySchemaPrivilege(ConnectorSecurityContext, Privilege, String, TrinoPrincipal) - Method in interface io.trino.spi.connector.ConnectorAccessControl
-
Check if identity is allowed to deny to any other user the specified privilege on the specified schema.
- checkCanDenySchemaPrivilege(SystemSecurityContext, Privilege, CatalogSchemaName, TrinoPrincipal) - Method in interface io.trino.spi.security.SystemAccessControl
-
Check if identity is allowed to deny the specified privilege to the grantee on the specified schema.
- checkCanDenyTablePrivilege(ConnectorSecurityContext, Privilege, SchemaTableName, TrinoPrincipal) - Method in interface io.trino.spi.connector.ConnectorAccessControl
-
Check if identity is allowed to deny to any other user the specified privilege on the specified table.
- checkCanDenyTablePrivilege(SystemSecurityContext, Privilege, CatalogSchemaTableName, TrinoPrincipal) - Method in interface io.trino.spi.security.SystemAccessControl
-
Check if identity is allowed to deny the specified privilege to the grantee on the specified table.
- checkCanDropCatalog(SystemSecurityContext, String) - Method in interface io.trino.spi.security.SystemAccessControl
-
Check if identity is allowed to drop the specified catalog.
- checkCanDropColumn(ConnectorSecurityContext, SchemaTableName) - Method in interface io.trino.spi.connector.ConnectorAccessControl
-
Check if identity is allowed to drop columns from the specified table.
- checkCanDropColumn(SystemSecurityContext, CatalogSchemaTableName) - Method in interface io.trino.spi.security.SystemAccessControl
-
Check if identity is allowed to drop columns from the specified table in a catalog.
- checkCanDropFunction(ConnectorSecurityContext, SchemaRoutineName) - Method in interface io.trino.spi.connector.ConnectorAccessControl
-
Check if identity is allowed to drop the specified function.
- checkCanDropFunction(SystemSecurityContext, CatalogSchemaRoutineName) - Method in interface io.trino.spi.security.SystemAccessControl
-
Check if identity is allowed to drop the specified function in the catalog.
- checkCanDropMaterializedView(ConnectorSecurityContext, SchemaTableName) - Method in interface io.trino.spi.connector.ConnectorAccessControl
-
Check if identity is allowed to drop the specified materialized view.
- checkCanDropMaterializedView(SystemSecurityContext, CatalogSchemaTableName) - Method in interface io.trino.spi.security.SystemAccessControl
-
Check if identity is allowed to drop the specified materialized view in a catalog.
- checkCanDropRole(ConnectorSecurityContext, String) - Method in interface io.trino.spi.connector.ConnectorAccessControl
- checkCanDropRole(SystemSecurityContext, String) - Method in interface io.trino.spi.security.SystemAccessControl
-
Check if identity is allowed to drop the specified role.
- checkCanDropSchema(ConnectorSecurityContext, String) - Method in interface io.trino.spi.connector.ConnectorAccessControl
-
Check if identity is allowed to drop the specified schema.
- checkCanDropSchema(SystemSecurityContext, CatalogSchemaName) - Method in interface io.trino.spi.security.SystemAccessControl
-
Check if identity is allowed to drop the specified schema in a catalog.
- checkCanDropTable(ConnectorSecurityContext, SchemaTableName) - Method in interface io.trino.spi.connector.ConnectorAccessControl
-
Check if identity is allowed to drop the specified table.
- checkCanDropTable(SystemSecurityContext, CatalogSchemaTableName) - Method in interface io.trino.spi.security.SystemAccessControl
-
Check if identity is allowed to drop the specified table in a catalog.
- checkCanDropView(ConnectorSecurityContext, SchemaTableName) - Method in interface io.trino.spi.connector.ConnectorAccessControl
-
Check if identity is allowed to drop the specified view.
- checkCanDropView(SystemSecurityContext, CatalogSchemaTableName) - Method in interface io.trino.spi.security.SystemAccessControl
-
Check if identity is allowed to drop the specified view in a catalog.
- checkCanExecuteProcedure(ConnectorSecurityContext, SchemaRoutineName) - Method in interface io.trino.spi.connector.ConnectorAccessControl
- checkCanExecuteProcedure(SystemSecurityContext, CatalogSchemaRoutineName) - Method in interface io.trino.spi.security.SystemAccessControl
-
Check if identity is allowed to execute the specified procedure
- checkCanExecuteQuery(Identity, QueryId) - Method in interface io.trino.spi.security.SystemAccessControl
-
Checks if identity can execute a query.
- checkCanExecuteTableProcedure(ConnectorSecurityContext, SchemaTableName, String) - Method in interface io.trino.spi.connector.ConnectorAccessControl
- checkCanExecuteTableProcedure(SystemSecurityContext, CatalogSchemaTableName, String) - Method in interface io.trino.spi.security.SystemAccessControl
-
Check if identity is allowed to execute the specified table procedure on specified table
- checkCanGrantEntityPrivilege(SystemSecurityContext, EntityPrivilege, EntityKindAndName, TrinoPrincipal, boolean) - Method in interface io.trino.spi.security.SystemAccessControl
-
Check if identity is allowed to grant the specified privilege to the grantee on the specified entity.
- checkCanGrantRoles(ConnectorSecurityContext, Set<String>, Set<TrinoPrincipal>, boolean, Optional<TrinoPrincipal>) - Method in interface io.trino.spi.connector.ConnectorAccessControl
- checkCanGrantRoles(SystemSecurityContext, Set<String>, Set<TrinoPrincipal>, boolean, Optional<TrinoPrincipal>) - Method in interface io.trino.spi.security.SystemAccessControl
-
Check if identity is allowed to grant the specified roles to the specified principals.
- checkCanGrantSchemaPrivilege(ConnectorSecurityContext, Privilege, String, TrinoPrincipal, boolean) - Method in interface io.trino.spi.connector.ConnectorAccessControl
-
Check if identity is allowed to grant to any other user the specified privilege on the specified schema.
- checkCanGrantSchemaPrivilege(SystemSecurityContext, Privilege, CatalogSchemaName, TrinoPrincipal, boolean) - Method in interface io.trino.spi.security.SystemAccessControl
-
Check if identity is allowed to grant the specified privilege to the grantee on the specified schema.
- checkCanGrantTablePrivilege(ConnectorSecurityContext, Privilege, SchemaTableName, TrinoPrincipal, boolean) - Method in interface io.trino.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, TrinoPrincipal, boolean) - Method in interface io.trino.spi.security.SystemAccessControl
-
Check if identity is allowed to grant the specified privilege to the grantee on the specified table.
- checkCanImpersonateUser(Identity, String) - Method in interface io.trino.spi.security.SystemAccessControl
-
Check if the identity is allowed impersonate the specified user.
- checkCanInsertIntoTable(ConnectorSecurityContext, SchemaTableName) - Method in interface io.trino.spi.connector.ConnectorAccessControl
-
Check if identity is allowed to insert into the specified table.
- checkCanInsertIntoTable(SystemSecurityContext, CatalogSchemaTableName) - Method in interface io.trino.spi.security.SystemAccessControl
-
Check if identity is allowed to insert into the specified table in a catalog.
- checkCanKillQueryOwnedBy(Identity, Identity) - Method in interface io.trino.spi.security.SystemAccessControl
-
Checks if identity can kill a query owned by the specified user.
- checkCanReadSystemInformation(Identity) - Method in interface io.trino.spi.security.SystemAccessControl
-
Check if identity is allowed to read system information such as statistics, service registry, thread stacks, etc.
- checkCanRefreshMaterializedView(ConnectorSecurityContext, SchemaTableName) - Method in interface io.trino.spi.connector.ConnectorAccessControl
-
Check if identity is allowed to refresh the specified materialized view.
- checkCanRefreshMaterializedView(SystemSecurityContext, CatalogSchemaTableName) - Method in interface io.trino.spi.security.SystemAccessControl
-
Check if identity is allowed to refresh the specified materialized view in a catalog.
- checkCanRenameColumn(ConnectorSecurityContext, SchemaTableName) - Method in interface io.trino.spi.connector.ConnectorAccessControl
-
Check if identity is allowed to rename a column in the specified table.
- checkCanRenameColumn(SystemSecurityContext, CatalogSchemaTableName) - Method in interface io.trino.spi.security.SystemAccessControl
-
Check if identity is allowed to rename a column in the specified table in a catalog.
- checkCanRenameMaterializedView(ConnectorSecurityContext, SchemaTableName, SchemaTableName) - Method in interface io.trino.spi.connector.ConnectorAccessControl
-
Check if identity is allowed to rename the specified materialized view.
- checkCanRenameMaterializedView(SystemSecurityContext, CatalogSchemaTableName, CatalogSchemaTableName) - Method in interface io.trino.spi.security.SystemAccessControl
-
Check if identity is allowed to rename the specified materialized view in a catalog.
- checkCanRenameSchema(ConnectorSecurityContext, String, String) - Method in interface io.trino.spi.connector.ConnectorAccessControl
-
Check if identity is allowed to rename the specified schema.
- checkCanRenameSchema(SystemSecurityContext, CatalogSchemaName, String) - Method in interface io.trino.spi.security.SystemAccessControl
-
Check if identity is allowed to rename the specified schema in a catalog.
- checkCanRenameTable(ConnectorSecurityContext, SchemaTableName, SchemaTableName) - Method in interface io.trino.spi.connector.ConnectorAccessControl
-
Check if identity is allowed to rename the specified table.
- checkCanRenameTable(SystemSecurityContext, CatalogSchemaTableName, CatalogSchemaTableName) - Method in interface io.trino.spi.security.SystemAccessControl
-
Check if identity is allowed to rename the specified table in a catalog.
- checkCanRenameView(ConnectorSecurityContext, SchemaTableName, SchemaTableName) - Method in interface io.trino.spi.connector.ConnectorAccessControl
-
Check if identity is allowed to rename the specified view.
- checkCanRenameView(SystemSecurityContext, CatalogSchemaTableName, CatalogSchemaTableName) - Method in interface io.trino.spi.security.SystemAccessControl
-
Check if identity is allowed to rename the specified view in a catalog.
- checkCanRevokeEntityPrivilege(SystemSecurityContext, EntityPrivilege, EntityKindAndName, TrinoPrincipal, boolean) - Method in interface io.trino.spi.security.SystemAccessControl
-
Check if identity is allowed to revoke the specified privilege on the specified entity from the revokee.
- checkCanRevokeRoles(ConnectorSecurityContext, Set<String>, Set<TrinoPrincipal>, boolean, Optional<TrinoPrincipal>) - Method in interface io.trino.spi.connector.ConnectorAccessControl
- checkCanRevokeRoles(SystemSecurityContext, Set<String>, Set<TrinoPrincipal>, boolean, Optional<TrinoPrincipal>) - Method in interface io.trino.spi.security.SystemAccessControl
-
Check if identity is allowed to revoke the specified roles from the specified principals.
- checkCanRevokeSchemaPrivilege(ConnectorSecurityContext, Privilege, String, TrinoPrincipal, boolean) - Method in interface io.trino.spi.connector.ConnectorAccessControl
- checkCanRevokeSchemaPrivilege(SystemSecurityContext, Privilege, CatalogSchemaName, TrinoPrincipal, boolean) - Method in interface io.trino.spi.security.SystemAccessControl
-
Check if identity is allowed to revoke the specified privilege on the specified schema from the revokee.
- checkCanRevokeTablePrivilege(ConnectorSecurityContext, Privilege, SchemaTableName, TrinoPrincipal, boolean) - Method in interface io.trino.spi.connector.ConnectorAccessControl
-
Check if identity is allowed to revoke the specified privilege on the specified table from any user.
- checkCanRevokeTablePrivilege(SystemSecurityContext, Privilege, CatalogSchemaTableName, TrinoPrincipal, boolean) - Method in interface io.trino.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.trino.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.trino.spi.security.SystemAccessControl
-
Check if identity is allowed to select from the specified columns in a relation.
- checkCanSetCatalogSessionProperty(ConnectorSecurityContext, String) - Method in interface io.trino.spi.connector.ConnectorAccessControl
-
Check if identity is allowed to set the specified property.
- checkCanSetCatalogSessionProperty(SystemSecurityContext, String, String) - Method in interface io.trino.spi.security.SystemAccessControl
-
Check if identity is allowed to set the specified property in a catalog.
- checkCanSetColumnComment(ConnectorSecurityContext, SchemaTableName) - Method in interface io.trino.spi.connector.ConnectorAccessControl
-
Check if identity is allowed to comment the column in the specified table.
- checkCanSetColumnComment(SystemSecurityContext, CatalogSchemaTableName) - Method in interface io.trino.spi.security.SystemAccessControl
-
Check if identity is allowed to set comment to column in the specified table in a catalog.
- checkCanSetMaterializedViewProperties(ConnectorSecurityContext, SchemaTableName, Map<String, Optional<Object>>) - Method in interface io.trino.spi.connector.ConnectorAccessControl
-
Check if identity is allowed to set the properties of the specified materialized view.
- checkCanSetMaterializedViewProperties(SystemSecurityContext, CatalogSchemaTableName, Map<String, Optional<Object>>) - Method in interface io.trino.spi.security.SystemAccessControl
-
Check if identity is allowed to set the properties of the specified materialized view in a catalog.
- checkCanSetRole(ConnectorSecurityContext, String) - Method in interface io.trino.spi.connector.ConnectorAccessControl
- checkCanSetSchemaAuthorization(ConnectorSecurityContext, String, TrinoPrincipal) - Method in interface io.trino.spi.connector.ConnectorAccessControl
-
Check if identity is allowed to change the specified schema's user/role.
- checkCanSetSchemaAuthorization(SystemSecurityContext, CatalogSchemaName, TrinoPrincipal) - Method in interface io.trino.spi.security.SystemAccessControl
-
Check if identity is allowed to change the specified schema's user/role.
- checkCanSetSystemSessionProperty(Identity, QueryId, String) - Method in interface io.trino.spi.security.SystemAccessControl
-
Check if identity is allowed to set the specified system property.
- checkCanSetTableAuthorization(ConnectorSecurityContext, SchemaTableName, TrinoPrincipal) - Method in interface io.trino.spi.connector.ConnectorAccessControl
-
Check if identity is allowed to change the specified table's user/role.
- checkCanSetTableAuthorization(SystemSecurityContext, CatalogSchemaTableName, TrinoPrincipal) - Method in interface io.trino.spi.security.SystemAccessControl
-
Check if identity is allowed to change the specified table's user/role.
- checkCanSetTableComment(ConnectorSecurityContext, SchemaTableName) - Method in interface io.trino.spi.connector.ConnectorAccessControl
-
Check if identity is allowed to comment the specified table.
- checkCanSetTableComment(SystemSecurityContext, CatalogSchemaTableName) - Method in interface io.trino.spi.security.SystemAccessControl
-
Check if identity is allowed to comment the specified table in a catalog.
- checkCanSetTableProperties(ConnectorSecurityContext, SchemaTableName, Map<String, Optional<Object>>) - Method in interface io.trino.spi.connector.ConnectorAccessControl
-
Check if identity is allowed to set properties to the specified table.
- checkCanSetTableProperties(SystemSecurityContext, CatalogSchemaTableName, Map<String, Optional<Object>>) - Method in interface io.trino.spi.security.SystemAccessControl
-
Check if identity is allowed to alter properties to the specified table in a catalog.
- checkCanSetUser(Optional<Principal>, String) - Method in interface io.trino.spi.security.SystemAccessControl
-
Deprecated.
- checkCanSetViewAuthorization(ConnectorSecurityContext, SchemaTableName, TrinoPrincipal) - Method in interface io.trino.spi.connector.ConnectorAccessControl
-
Check if identity is allowed to change the specified view's user/role.
- checkCanSetViewAuthorization(SystemSecurityContext, CatalogSchemaTableName, TrinoPrincipal) - Method in interface io.trino.spi.security.SystemAccessControl
-
Check if identity is allowed to change the specified view's user/role.
- checkCanSetViewComment(ConnectorSecurityContext, SchemaTableName) - Method in interface io.trino.spi.connector.ConnectorAccessControl
-
Check if identity is allowed to comment the specified view.
- checkCanSetViewComment(SystemSecurityContext, CatalogSchemaTableName) - Method in interface io.trino.spi.security.SystemAccessControl
-
Check if identity is allowed to comment the specified view in a catalog.
- checkCanShowColumns(ConnectorSecurityContext, SchemaTableName) - Method in interface io.trino.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.trino.spi.security.SystemAccessControl
-
Check if identity is allowed to show columns of tables by executing SHOW COLUMNS, DESCRIBE etc.
- checkCanShowCreateFunction(ConnectorSecurityContext, SchemaRoutineName) - Method in interface io.trino.spi.connector.ConnectorAccessControl
-
Check if identity is allowed to execute SHOW CREATE FUNCTION.
- checkCanShowCreateFunction(SystemSecurityContext, CatalogSchemaRoutineName) - Method in interface io.trino.spi.security.SystemAccessControl
-
Check if identity is allowed to execute SHOW CREATE FUNCTION.
- checkCanShowCreateSchema(ConnectorSecurityContext, String) - Method in interface io.trino.spi.connector.ConnectorAccessControl
-
Check if identity is allowed to execute SHOW CREATE SCHEMA.
- checkCanShowCreateSchema(SystemSecurityContext, CatalogSchemaName) - Method in interface io.trino.spi.security.SystemAccessControl
-
Check if identity is allowed to execute SHOW CREATE SCHEMA.
- checkCanShowCreateTable(ConnectorSecurityContext, SchemaTableName) - Method in interface io.trino.spi.connector.ConnectorAccessControl
-
Check if identity is allowed to execute SHOW CREATE TABLE, SHOW CREATE VIEW or SHOW CREATE MATERIALIZED VIEW
- checkCanShowCreateTable(SystemSecurityContext, CatalogSchemaTableName) - Method in interface io.trino.spi.security.SystemAccessControl
-
Check if identity is allowed to execute SHOW CREATE TABLE, SHOW CREATE VIEW or SHOW CREATE MATERIALIZED VIEW
- checkCanShowCurrentRoles(ConnectorSecurityContext) - Method in interface io.trino.spi.connector.ConnectorAccessControl
-
Check if identity is allowed to show current roles.
- checkCanShowCurrentRoles(SystemSecurityContext) - Method in interface io.trino.spi.security.SystemAccessControl
-
Check if identity is allowed to show current roles.
- checkCanShowFunctions(ConnectorSecurityContext, String) - Method in interface io.trino.spi.connector.ConnectorAccessControl
-
Check if identity is allowed to show functions by executing SHOW FUNCTIONS.
- checkCanShowFunctions(SystemSecurityContext, CatalogSchemaName) - Method in interface io.trino.spi.security.SystemAccessControl
-
Check if identity is allowed to show functions by executing SHOW FUNCTIONS in a catalog schema.
- checkCanShowRoleGrants(ConnectorSecurityContext) - Method in interface io.trino.spi.connector.ConnectorAccessControl
-
Check if identity is allowed to show its own role grants.
- checkCanShowRoleGrants(SystemSecurityContext) - Method in interface io.trino.spi.security.SystemAccessControl
-
Check if identity is allowed to show its own role grants.
- checkCanShowRoles(ConnectorSecurityContext) - Method in interface io.trino.spi.connector.ConnectorAccessControl
-
Check if identity is allowed to show roles.
- checkCanShowRoles(SystemSecurityContext) - Method in interface io.trino.spi.security.SystemAccessControl
-
Check if identity is allowed to show roles.
- checkCanShowSchemas(ConnectorSecurityContext) - Method in interface io.trino.spi.connector.ConnectorAccessControl
-
Check if identity is allowed to execute SHOW SCHEMAS.
- checkCanShowSchemas(SystemSecurityContext, String) - Method in interface io.trino.spi.security.SystemAccessControl
-
Check if identity is allowed to execute SHOW SCHEMAS in a catalog.
- checkCanShowTables(ConnectorSecurityContext, String) - Method in interface io.trino.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.trino.spi.security.SystemAccessControl
-
Check if identity is allowed to show metadata of tables by executing SHOW TABLES, SHOW GRANTS etc. in a catalog.
- checkCanTruncateTable(ConnectorSecurityContext, SchemaTableName) - Method in interface io.trino.spi.connector.ConnectorAccessControl
-
Check if identity is allowed to truncate the specified table in this catalog.
- checkCanTruncateTable(SystemSecurityContext, CatalogSchemaTableName) - Method in interface io.trino.spi.security.SystemAccessControl
-
Check if identity is allowed to truncate the specified table in a catalog.
- checkCanUpdateTableColumns(ConnectorSecurityContext, SchemaTableName, Set<String>) - Method in interface io.trino.spi.connector.ConnectorAccessControl
-
Check if identity is allowed to update the supplied columns in the specified table in this catalog.
- checkCanUpdateTableColumns(SystemSecurityContext, CatalogSchemaTableName, Set<String>) - Method in interface io.trino.spi.security.SystemAccessControl
-
Check if identity is allowed to update the supplied columns in the specified table in a catalog.
- checkCanViewQueryOwnedBy(Identity, Identity) - Method in interface io.trino.spi.security.SystemAccessControl
-
Checks if identity can view a query owned by the specified user.
- checkCanWriteSystemInformation(Identity) - Method in interface io.trino.spi.security.SystemAccessControl
-
Check if identity is allowed to write system information such as marking nodes offline, or changing runtime flags.
- checkConnectorSupports(IsolationLevel, IsolationLevel) - Static method in enum class io.trino.spi.transaction.IsolationLevel
- checkValidTransition(ExchangeSourceOutputSelector) - Method in class io.trino.spi.exchange.ExchangeSourceOutputSelector
- checkValueValid(long) - Method in class io.trino.spi.type.AbstractIntType
- cleanupQuery(ConnectorSession) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Cleanup after a query.
- close() - Method in class io.trino.spi.classloader.ThreadContextClassLoader
- close() - Method in interface io.trino.spi.connector.ConnectorPageSource
-
Immediately finishes this page source.
- close() - Method in interface io.trino.spi.connector.ConnectorSplitSource
- close() - Method in class io.trino.spi.connector.EmptyPageSource
- close() - Method in class io.trino.spi.connector.FixedPageSource
- close() - Method in class io.trino.spi.connector.FixedSplitSource
- close() - Method in class io.trino.spi.connector.InMemoryRecordSet.InMemoryRecordCursor
- close() - Method in interface io.trino.spi.connector.RecordCursor
- close() - Method in class io.trino.spi.connector.RecordPageSource
- close() - Method in interface io.trino.spi.exchange.Exchange
- close() - Method in interface io.trino.spi.exchange.ExchangeSource
- close() - Method in interface io.trino.spi.exchange.ExchangeSourceHandleSource
- closeIdleWriters() - Method in interface io.trino.spi.connector.ConnectorPageSink
-
Closes the idle partition writers that have not received any data since the last time this method is called.
- CLUSTER_OUT_OF_MEMORY - Enum constant in enum class io.trino.spi.StandardErrorCode
- ClusterMemoryPoolManager - Interface in io.trino.spi.memory
- Column(String, TypeId, Optional<String>) - Constructor for class io.trino.spi.connector.ConnectorMaterializedViewDefinition.Column
- COLUMN_ALREADY_EXISTS - Enum constant in enum class io.trino.spi.StandardErrorCode
- COLUMN_NOT_FOUND - Enum constant in enum class io.trino.spi.StandardErrorCode
- COLUMN_TYPE_UNKNOWN - Enum constant in enum class io.trino.spi.StandardErrorCode
- ColumnarArray - Class in io.trino.spi.block
- ColumnarMap - Class in io.trino.spi.block
- ColumnDetail - Class in io.trino.spi.eventlistener
-
This class is JSON serializable for convenience and serialization compatibility is not guaranteed across versions.
- ColumnDetail(String, String, String, String) - Constructor for class io.trino.spi.eventlistener.ColumnDetail
- ColumnDomain(C, Domain) - Constructor for class io.trino.spi.predicate.TupleDomain.ColumnDomain
- ColumnHandle - Interface in io.trino.spi.connector
-
Represents a handle to a column within a
ConnectorTableHandle
returned from the connector to the engine. - ColumnInfo - Class in io.trino.spi.eventlistener
-
This class is JSON serializable for convenience and serialization compatibility is not guaranteed across versions.
- ColumnInfo(String, Optional<String>) - Constructor for class io.trino.spi.eventlistener.ColumnInfo
- ColumnMaskReferenceInfo - Record Class in io.trino.spi.eventlistener
-
This class is JSON serializable for convenience and serialization compatibility is not guaranteed across versions.
- ColumnMaskReferenceInfo(String, String, String, String, String) - Constructor for record class io.trino.spi.eventlistener.ColumnMaskReferenceInfo
-
Creates an instance of a
ColumnMaskReferenceInfo
record class. - ColumnMetadata - Class in io.trino.spi.connector
- ColumnMetadata(String, Type) - Constructor for class io.trino.spi.connector.ColumnMetadata
- ColumnMetadata.Builder - Class in io.trino.spi.connector
- ColumnNotFoundException - Exception Class in io.trino.spi.connector
- ColumnNotFoundException(SchemaTableName, String) - Constructor for exception class io.trino.spi.connector.ColumnNotFoundException
- ColumnNotFoundException(SchemaTableName, String, String) - Constructor for exception class io.trino.spi.connector.ColumnNotFoundException
- ColumnNotFoundException(SchemaTableName, String, String, Throwable) - Constructor for exception class io.trino.spi.connector.ColumnNotFoundException
- ColumnNotFoundException(SchemaTableName, String, Throwable) - Constructor for exception class io.trino.spi.connector.ColumnNotFoundException
- ColumnSchema - Class in io.trino.spi.connector
- ColumnSchema.Builder - Class in io.trino.spi.connector
- ColumnStatisticMetadata - Class in io.trino.spi.statistics
- ColumnStatisticMetadata(String, ColumnStatisticType) - Constructor for class io.trino.spi.statistics.ColumnStatisticMetadata
- ColumnStatisticMetadata(String, String, FunctionName) - Constructor for class io.trino.spi.statistics.ColumnStatisticMetadata
- ColumnStatisticMetadata(String, String, ColumnStatisticType) - Constructor for class io.trino.spi.statistics.ColumnStatisticMetadata
- ColumnStatistics - Class in io.trino.spi.statistics
- ColumnStatistics(Estimate, Estimate, Estimate, Optional<DoubleRange>) - Constructor for class io.trino.spi.statistics.ColumnStatistics
- ColumnStatistics.Builder - Class in io.trino.spi.statistics
-
If one of the estimates below is unspecified (i.e. left as "unknown"), the optimizer may not be able to derive the statistics needed for performing cost-based query plan optimizations.
- ColumnStatisticType - Enum Class in io.trino.spi.statistics
- columnWiseUnion(TupleDomain<T>, TupleDomain<T>, TupleDomain<T>...) - Static method in class io.trino.spi.predicate.TupleDomain
- columnWiseUnion(List<TupleDomain<T>>) - Static method in class io.trino.spi.predicate.TupleDomain
-
Returns a TupleDomain in which corresponding column Domains are unioned together.
- combineFunction(MethodHandle) - Method in class io.trino.spi.function.AggregationImplementation.Builder
- CombineFunction - Annotation Interface in io.trino.spi.function
-
A function annotated with @CombineFunction is one that will be used to combine two states into one in aggregation functions.
- comment() - Method in record class io.trino.spi.connector.RelationCommentMetadata
-
Returns the value of the
comment
record component. - commit(ConnectorTransactionHandle) - Method in interface io.trino.spi.connector.Connector
-
Commit the transaction.
- compact() - Method in class io.trino.spi.block.DictionaryBlock
- compact() - Method in class io.trino.spi.Page
- compactRelatedBlocks(List<DictionaryBlock>) - Static method in class io.trino.spi.block.DictionaryBlock
-
Compact the dictionary down to only the used positions for a set of blocks that have been projected from the same dictionary.
- comparableRequired() - Method in class io.trino.spi.function.TypeVariableConstraint.TypeVariableConstraintBuilder
- comparableTypeParameter(String) - Method in class io.trino.spi.function.Signature.Builder
- compare(long, long, long, long) - Static method in class io.trino.spi.type.Int128
- compareAbsolute(long, long, long, long) - Static method in class io.trino.spi.type.Int128Math
- compareAbsolute(Int128, Int128) - Static method in class io.trino.spi.type.Int128Math
- compareChars(Slice, Slice) - Static method in class io.trino.spi.type.Chars
- compareTo(Int128) - Method in class io.trino.spi.type.Int128
- compareTo(LongTimestamp) - Method in class io.trino.spi.type.LongTimestamp
- compareTo(LongTimestampWithTimeZone) - Method in class io.trino.spi.type.LongTimestampWithTimeZone
- compareTo(LongTimeWithTimeZone) - Method in class io.trino.spi.type.LongTimeWithTimeZone
- compareTo(SqlVarbinary) - Method in class io.trino.spi.type.SqlVarbinary
- COMPARISON_UNORDERED_FIRST - Enum constant in enum class io.trino.spi.function.OperatorType
-
Normal comparison operator, but unordered values such as NaN are placed before all normal values.
- COMPARISON_UNORDERED_LAST - Enum constant in enum class io.trino.spi.function.OperatorType
-
Normal comparison operator, but unordered values such as NaN are placed after all normal values.
- COMPILER_ERROR - Enum constant in enum class io.trino.spi.StandardErrorCode
- complement() - Method in class io.trino.spi.predicate.AllOrNoneValueSet
- complement() - Method in class io.trino.spi.predicate.Domain
- complement() - Method in class io.trino.spi.predicate.EquatableValueSet
- complement() - Method in class io.trino.spi.predicate.SortedRangeSet
- complement() - Method in interface io.trino.spi.predicate.ValueSet
- ComputedStatistics - Class in io.trino.spi.statistics
- ComputedStatistics.Builder - Class in io.trino.spi.statistics
- CONFIGURATION_INVALID - Enum constant in enum class io.trino.spi.StandardErrorCode
- CONFIGURATION_UNAVAILABLE - Enum constant in enum class io.trino.spi.StandardErrorCode
- configure(ResourceGroup, SelectionContext<C>) - Method in interface io.trino.spi.resourcegroups.ResourceGroupConfigurationManager
-
Implementations may retain a reference to the group, and re-configure it asynchronously.
- Connector - Interface in io.trino.spi.connector
- ConnectorAccessControl - Interface in io.trino.spi.connector
- ConnectorAnalyzeMetadata - Class in io.trino.spi.connector
- ConnectorAnalyzeMetadata(ConnectorTableHandle, TableStatisticsMetadata) - Constructor for class io.trino.spi.connector.ConnectorAnalyzeMetadata
- ConnectorBucketNodeMap - Class in io.trino.spi.connector
- ConnectorCapabilities - Enum Class in io.trino.spi.connector
- ConnectorContext - Interface in io.trino.spi.connector
- ConnectorExpression - Class in io.trino.spi.expression
- ConnectorExpression(Type) - Constructor for class io.trino.spi.expression.ConnectorExpression
- ConnectorFactory - Interface in io.trino.spi.connector
- ConnectorIdentity - Class in io.trino.spi.security
- ConnectorIdentity.Builder - Class in io.trino.spi.security
- ConnectorIndex - Interface in io.trino.spi.connector
- ConnectorIndexHandle - Interface in io.trino.spi.connector
- ConnectorIndexProvider - Interface in io.trino.spi.connector
- ConnectorInsertTableHandle - Interface in io.trino.spi.connector
- ConnectorMaterializedViewDefinition - Class in io.trino.spi.connector
- ConnectorMaterializedViewDefinition(String, Optional<CatalogSchemaTableName>, Optional<String>, Optional<String>, List<ConnectorMaterializedViewDefinition.Column>, Optional<Duration>, Optional<String>, Optional<String>, List<CatalogSchemaName>) - Constructor for class io.trino.spi.connector.ConnectorMaterializedViewDefinition
- ConnectorMaterializedViewDefinition.Column - Class in io.trino.spi.connector
- ConnectorMergeSink - Interface in io.trino.spi.connector
- ConnectorMergeTableHandle - Interface in io.trino.spi.connector
- ConnectorMetadata - Interface in io.trino.spi.connector
- connectorName() - Method in record class io.trino.spi.catalog.CatalogProperties
-
Returns the value of the
connectorName
record component. - ConnectorName - Class in io.trino.spi.connector
- ConnectorName(String) - Constructor for class io.trino.spi.connector.ConnectorName
- ConnectorNodePartitioningProvider - Interface in io.trino.spi.connector
- ConnectorOutputMetadata - Interface in io.trino.spi.connector
-
Connectors can choose to return ConnectorOutputMetadata from finishInsert or finishCreate.
- ConnectorOutputTableHandle - Interface in io.trino.spi.connector
- ConnectorPageSink - Interface in io.trino.spi.connector
- ConnectorPageSinkId - Interface in io.trino.spi.connector
-
Represents an identifier for the associated
ConnectorPageSink
which will be unique within a particular query. - ConnectorPageSinkProvider - Interface in io.trino.spi.connector
- ConnectorPageSource - Interface in io.trino.spi.connector
- ConnectorPageSourceProvider - Interface in io.trino.spi.connector
- ConnectorPageSourceProviderFactory - Interface in io.trino.spi.connector
- ConnectorPartitioningHandle - Interface in io.trino.spi.connector
- ConnectorRecordSetProvider - Interface in io.trino.spi.connector
- ConnectorResolvedIndex - Class in io.trino.spi.connector
- ConnectorResolvedIndex(ConnectorIndexHandle, TupleDomain<ColumnHandle>) - Constructor for class io.trino.spi.connector.ConnectorResolvedIndex
- ConnectorSecurityContext - Class in io.trino.spi.connector
- ConnectorSecurityContext(ConnectorTransactionHandle, ConnectorIdentity, QueryId) - Constructor for class io.trino.spi.connector.ConnectorSecurityContext
- ConnectorSession - Interface in io.trino.spi.connector
- ConnectorSplit - Interface in io.trino.spi.connector
- ConnectorSplitBatch(List<ConnectorSplit>, boolean) - Constructor for class io.trino.spi.connector.ConnectorSplitSource.ConnectorSplitBatch
- ConnectorSplitManager - Interface in io.trino.spi.connector
- ConnectorSplitSource - Interface in io.trino.spi.connector
-
Source of splits to be processed.
- ConnectorSplitSource.ConnectorSplitBatch - Class in io.trino.spi.connector
- ConnectorTableExecuteHandle - Interface in io.trino.spi.connector
-
ConnectorTableExecuteHandle identifies instance of executing a connector provided table procedure on a specific table.
- ConnectorTableFunction - Interface in io.trino.spi.function.table
- ConnectorTableFunctionHandle - Interface in io.trino.spi.function.table
-
An area to store all information necessary to execute the table function, gathered at analysis time
- ConnectorTableHandle - Interface in io.trino.spi.connector
-
Represents a handle to a relation returned from the connector to the engine.
- ConnectorTableLayout - Class in io.trino.spi.connector
- ConnectorTableLayout(ConnectorPartitioningHandle, List<String>, boolean) - Constructor for class io.trino.spi.connector.ConnectorTableLayout
- ConnectorTableLayout(List<String>) - Constructor for class io.trino.spi.connector.ConnectorTableLayout
-
Creates a preferred table layout that is evenly partitioned on given columns by the engine.
- ConnectorTableMetadata - Class in io.trino.spi.connector
- ConnectorTableMetadata(SchemaTableName, List<ColumnMetadata>) - Constructor for class io.trino.spi.connector.ConnectorTableMetadata
- ConnectorTableMetadata(SchemaTableName, List<ColumnMetadata>, Map<String, Object>) - Constructor for class io.trino.spi.connector.ConnectorTableMetadata
- ConnectorTableMetadata(SchemaTableName, List<ColumnMetadata>, Map<String, Object>, Optional<String>) - Constructor for class io.trino.spi.connector.ConnectorTableMetadata
- ConnectorTableMetadata(SchemaTableName, List<ColumnMetadata>, Map<String, Object>, Optional<String>, List<String>) - Constructor for class io.trino.spi.connector.ConnectorTableMetadata
- ConnectorTablePartitioning - Class in io.trino.spi.connector
-
The partitioning of split groups in a table.
- ConnectorTablePartitioning(ConnectorPartitioningHandle, List<ColumnHandle>) - Constructor for class io.trino.spi.connector.ConnectorTablePartitioning
- ConnectorTablePartitioning(ConnectorPartitioningHandle, List<ColumnHandle>, boolean) - Constructor for class io.trino.spi.connector.ConnectorTablePartitioning
- ConnectorTableProperties - Class in io.trino.spi.connector
- ConnectorTableProperties() - Constructor for class io.trino.spi.connector.ConnectorTableProperties
- ConnectorTableProperties(TupleDomain<ColumnHandle>, Optional<ConnectorTablePartitioning>, Optional<DiscretePredicates>, List<LocalProperty<ColumnHandle>>) - Constructor for class io.trino.spi.connector.ConnectorTableProperties
- ConnectorTableSchema - Class in io.trino.spi.connector
- ConnectorTableSchema(SchemaTableName, List<ColumnSchema>) - Constructor for class io.trino.spi.connector.ConnectorTableSchema
- ConnectorTableSchema(SchemaTableName, List<ColumnSchema>, List<String>) - Constructor for class io.trino.spi.connector.ConnectorTableSchema
- ConnectorTableVersion - Class in io.trino.spi.connector
- ConnectorTableVersion(PointerType, Type, Object) - Constructor for class io.trino.spi.connector.ConnectorTableVersion
- ConnectorTransactionHandle - Interface in io.trino.spi.connector
- ConnectorViewDefinition - Class in io.trino.spi.connector
- ConnectorViewDefinition(String, Optional<String>, Optional<String>, List<ConnectorViewDefinition.ViewColumn>, Optional<String>, Optional<String>, boolean, List<CatalogSchemaName>) - Constructor for class io.trino.spi.connector.ConnectorViewDefinition
- ConnectorViewDefinition.ViewColumn - Class in io.trino.spi.connector
- Constant - Class in io.trino.spi.expression
- Constant(Object, Type) - Constructor for class io.trino.spi.expression.Constant
- ConstantProperty<E> - Class in io.trino.spi.connector
- ConstantProperty(E) - Constructor for class io.trino.spi.connector.ConstantProperty
- constrain(Set<E>) - Method in class io.trino.spi.connector.GroupingProperty
- constrain(Set<E>) - Method in interface io.trino.spi.connector.LocalProperty
-
Return a new instance with the give (reduced) set of columns
- Constraint - Class in io.trino.spi.connector
- Constraint - Annotation Interface in io.trino.spi.function
- Constraint(TupleDomain<ColumnHandle>) - Constructor for class io.trino.spi.connector.Constraint
- Constraint(TupleDomain<ColumnHandle>, ConnectorExpression, Map<String, ColumnHandle>) - Constructor for class io.trino.spi.connector.Constraint
- Constraint(TupleDomain<ColumnHandle>, ConnectorExpression, Map<String, ColumnHandle>, Predicate<Map<ColumnHandle, NullableValue>>, Set<ColumnHandle>) - Constructor for class io.trino.spi.connector.Constraint
- Constraint(TupleDomain<ColumnHandle>, Predicate<Map<ColumnHandle, NullableValue>>, Set<ColumnHandle>) - Constructor for class io.trino.spi.connector.Constraint
- CONSTRAINT_VIOLATION - Enum constant in enum class io.trino.spi.StandardErrorCode
- ConstraintApplicationResult<T> - Class in io.trino.spi.connector
- ConstraintApplicationResult(T, TupleDomain<ColumnHandle>, ConnectorExpression, boolean) - Constructor for class io.trino.spi.connector.ConstraintApplicationResult
- Constraints - Annotation Interface in io.trino.spi.function
- consume(Consumer<Ranges>, Consumer<DiscreteValues>, Consumer<AllOrNone>) - Method in interface io.trino.spi.predicate.ValuesProcessor
- contains(Domain) - Method in class io.trino.spi.predicate.Domain
- contains(Range) - Method in class io.trino.spi.predicate.Range
- contains(TupleDomain<T>) - Method in class io.trino.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 class io.trino.spi.predicate.EquatableValueSet
- contains(ValueSet) - Method in class io.trino.spi.predicate.SortedRangeSet
- contains(ValueSet) - Method in interface io.trino.spi.predicate.ValueSet
- containsNull() - Method in class io.trino.spi.predicate.Domain.DiscreteSet
- containsValue(Object) - Method in class io.trino.spi.predicate.AllOrNoneValueSet
- containsValue(Object) - Method in class io.trino.spi.predicate.EquatableValueSet
- containsValue(Object) - Method in class io.trino.spi.predicate.SortedRangeSet
- containsValue(Object) - Method in interface io.trino.spi.predicate.ValueSet
- convention() - Element in annotation interface io.trino.spi.function.CastDependency
- convention() - Element in annotation interface io.trino.spi.function.FunctionDependency
- convention() - Element in annotation interface io.trino.spi.function.OperatorDependency
- Convention - Annotation Interface in io.trino.spi.function
- coordinatorOnly() - Static method in class io.trino.spi.connector.TableProcedureExecutionMode
-
Table procedure that does not read any table data and only executes on the coordinator.
- copy() - Method in interface io.trino.spi.function.AccumulatorState
- copy() - Method in interface io.trino.spi.function.WindowAccumulator
- copyOf(Type, Collection<?>) - Static method in interface io.trino.spi.predicate.ValueSet
- copyOf(Type, List<Range>) - Static method in class io.trino.spi.predicate.SortedRangeSet
-
Provided Ranges are unioned together to form the SortedRangeSet
- copyOfRanges(Type, Collection<Range>) - Static method in interface io.trino.spi.predicate.ValueSet
- copyPositions(int[], int, int) - Method in class io.trino.spi.block.ArrayBlock
- copyPositions(int[], int, int) - Method in interface io.trino.spi.block.Block
-
Returns a block containing the specified positions.
- copyPositions(int[], int, int) - Method in class io.trino.spi.block.ByteArrayBlock
- copyPositions(int[], int, int) - Method in class io.trino.spi.block.DictionaryBlock
- copyPositions(int[], int, int) - Method in class io.trino.spi.block.Fixed12Block
- copyPositions(int[], int, int) - Method in class io.trino.spi.block.Int128ArrayBlock
- copyPositions(int[], int, int) - Method in class io.trino.spi.block.IntArrayBlock
- copyPositions(int[], int, int) - Method in class io.trino.spi.block.LazyBlock
- copyPositions(int[], int, int) - Method in class io.trino.spi.block.LongArrayBlock
- copyPositions(int[], int, int) - Method in class io.trino.spi.block.MapBlock
- copyPositions(int[], int, int) - Method in class io.trino.spi.block.RowBlock
- copyPositions(int[], int, int) - Method in class io.trino.spi.block.RunLengthEncodedBlock
- copyPositions(int[], int, int) - Method in class io.trino.spi.block.ShortArrayBlock
- copyPositions(int[], int, int) - Method in interface io.trino.spi.block.ValueBlock
- copyPositions(int[], int, int) - Method in class io.trino.spi.block.VariableWidthBlock
- copyPositions(int[], int, int) - Method in class io.trino.spi.Page
- copyRegion(int, int) - Method in class io.trino.spi.block.ArrayBlock
- copyRegion(int, int) - Method in interface io.trino.spi.block.Block
-
Returns a block starting at the specified position and extends for the specified length.
- copyRegion(int, int) - Method in class io.trino.spi.block.ByteArrayBlock
- copyRegion(int, int) - Method in class io.trino.spi.block.DictionaryBlock
- copyRegion(int, int) - Method in class io.trino.spi.block.Fixed12Block
- copyRegion(int, int) - Method in class io.trino.spi.block.Int128ArrayBlock
- copyRegion(int, int) - Method in class io.trino.spi.block.IntArrayBlock
- copyRegion(int, int) - Method in class io.trino.spi.block.LazyBlock
- copyRegion(int, int) - Method in class io.trino.spi.block.LongArrayBlock
- copyRegion(int, int) - Method in class io.trino.spi.block.MapBlock
- copyRegion(int, int) - Method in class io.trino.spi.block.RowBlock
- copyRegion(int, int) - Method in class io.trino.spi.block.RunLengthEncodedBlock
- copyRegion(int, int) - Method in class io.trino.spi.block.ShortArrayBlock
- copyRegion(int, int) - Method in interface io.trino.spi.block.ValueBlock
- copyRegion(int, int) - Method in class io.trino.spi.block.VariableWidthBlock
- copyWithAppendedNull() - Method in class io.trino.spi.block.ArrayBlock
- copyWithAppendedNull() - Method in interface io.trino.spi.block.Block
-
Returns a block that contains a copy of the contents of the current block, and an appended null at the end.
- copyWithAppendedNull() - Method in class io.trino.spi.block.ByteArrayBlock
- copyWithAppendedNull() - Method in class io.trino.spi.block.DictionaryBlock
- copyWithAppendedNull() - Method in class io.trino.spi.block.Fixed12Block
- copyWithAppendedNull() - Method in class io.trino.spi.block.Int128ArrayBlock
- copyWithAppendedNull() - Method in class io.trino.spi.block.IntArrayBlock
- copyWithAppendedNull() - Method in class io.trino.spi.block.LazyBlock
- copyWithAppendedNull() - Method in class io.trino.spi.block.LongArrayBlock
- copyWithAppendedNull() - Method in class io.trino.spi.block.MapBlock
- copyWithAppendedNull() - Method in class io.trino.spi.block.RowBlock
- copyWithAppendedNull() - Method in class io.trino.spi.block.RunLengthEncodedBlock
- copyWithAppendedNull() - Method in class io.trino.spi.block.ShortArrayBlock
- copyWithAppendedNull() - Method in interface io.trino.spi.block.ValueBlock
- copyWithAppendedNull() - Method in class io.trino.spi.block.VariableWidthBlock
- CORRUPT_PAGE - Enum constant in enum class io.trino.spi.StandardErrorCode
- CORRUPT_SERIALIZED_IDENTITY - Enum constant in enum class io.trino.spi.StandardErrorCode
- Count<T> - Interface in io.trino.spi.metrics
- CPU_TIME - Static variable in class io.trino.spi.session.ResourceEstimates
- create(int, Block, int[]) - Static method in class io.trino.spi.block.DictionaryBlock
- create(Block, int) - Static method in class io.trino.spi.block.RunLengthEncodedBlock
- create(ValueSet, boolean) - Static method in class io.trino.spi.predicate.Domain
- create(Type, Object) - Static method in class io.trino.spi.predicate.EquatableValueSet.ValueEntry
- create(Type, Object, int) - Static method in class io.trino.spi.block.RunLengthEncodedBlock
- create(String, Map<String, String>, ConnectorContext) - Method in interface io.trino.spi.connector.ConnectorFactory
- create(Map<String, String>) - Method in interface io.trino.spi.catalog.CatalogStoreFactory
- create(Map<String, String>) - Method in interface io.trino.spi.eventlistener.EventListenerFactory
- create(Map<String, String>) - Method in interface io.trino.spi.security.CertificateAuthenticatorFactory
- create(Map<String, String>) - Method in interface io.trino.spi.security.GroupProviderFactory
- create(Map<String, String>) - Method in interface io.trino.spi.security.HeaderAuthenticatorFactory
- create(Map<String, String>) - Method in interface io.trino.spi.security.PasswordAuthenticatorFactory
- create(Map<String, String>) - Method in interface io.trino.spi.security.SystemAccessControlFactory
-
Deprecated.
- create(Map<String, String>, ExchangeManagerContext) - Method in interface io.trino.spi.exchange.ExchangeManagerFactory
- create(Map<String, String>, ResourceGroupConfigurationManagerContext) - Method in interface io.trino.spi.resourcegroups.ResourceGroupConfigurationManagerFactory
- create(Map<String, String>, SessionPropertyConfigurationManagerContext) - Method in interface io.trino.spi.session.SessionPropertyConfigurationManagerFactory
- create(Map<String, String>, SystemAccessControlFactory.SystemAccessControlContext) - Method in interface io.trino.spi.security.SystemAccessControlFactory
- CREATE - Enum constant in enum class io.trino.spi.security.Privilege
- createAuthenticatedPrincipal(HeaderAuthenticator.Headers) - Method in interface io.trino.spi.security.HeaderAuthenticator
-
Authenticate the provided headers.
- createAuthenticatedPrincipal(String, String) - Method in interface io.trino.spi.security.PasswordAuthenticator
-
Authenticate the provided user and password.
- createBlockBuilder(BlockBuilderStatus, int) - Method in class io.trino.spi.type.AbstractIntType
- createBlockBuilder(BlockBuilderStatus, int) - Method in class io.trino.spi.type.AbstractLongType
- createBlockBuilder(BlockBuilderStatus, int) - Method in class io.trino.spi.type.AbstractVariableWidthType
- createBlockBuilder(BlockBuilderStatus, int) - Method in class io.trino.spi.type.ArrayType
- createBlockBuilder(BlockBuilderStatus, int) - Method in class io.trino.spi.type.BooleanType
- createBlockBuilder(BlockBuilderStatus, int) - Method in class io.trino.spi.type.CharType
- createBlockBuilder(BlockBuilderStatus, int) - Method in class io.trino.spi.type.DoubleType
- createBlockBuilder(BlockBuilderStatus, int) - Method in class io.trino.spi.type.MapType
- createBlockBuilder(BlockBuilderStatus, int) - Method in class io.trino.spi.type.RowType
- createBlockBuilder(BlockBuilderStatus, int) - Method in class io.trino.spi.type.SmallintType
- createBlockBuilder(BlockBuilderStatus, int) - Method in class io.trino.spi.type.TinyintType
- createBlockBuilder(BlockBuilderStatus, int) - Method in interface io.trino.spi.type.Type
-
Creates the preferred block builder for this type.
- createBlockBuilder(BlockBuilderStatus, int) - Method in class io.trino.spi.type.UuidType
- createBlockBuilder(BlockBuilderStatus, int) - Method in class io.trino.spi.type.VarcharType
- createBlockBuilder(BlockBuilderStatus, int, int) - Method in class io.trino.spi.type.AbstractVariableWidthType
- createBlockBuilder(BlockBuilderStatus, int, int) - Method in class io.trino.spi.type.ArrayType
- createBlockBuilder(BlockBuilderStatus, int, int) - Method in interface io.trino.spi.type.FixedWidthType
- createBlockBuilder(BlockBuilderStatus, int, int) - Method in class io.trino.spi.type.MapType
- createBlockBuilder(BlockBuilderStatus, int, int) - Method in class io.trino.spi.type.RowType
- createBlockBuilder(BlockBuilderStatus, int, int) - Method in interface io.trino.spi.type.Type
-
Creates the preferred block builder for this type.
- createBlockBuilderStatus() - Method in class io.trino.spi.block.PageBuilderStatus
- createBlockForSingleNonNullValue(boolean) - Static method in class io.trino.spi.type.BooleanType
- createBlockFromKeyValue(Optional<boolean[]>, int[], Block, Block) - Method in class io.trino.spi.type.MapType
- createBucketNodeMap(int) - Static method in class io.trino.spi.connector.ConnectorBucketNodeMap
- createBucketNodeMap(List<Node>) - Static method in class io.trino.spi.connector.ConnectorBucketNodeMap
- createBuffered(ArrayType) - Static method in class io.trino.spi.block.BufferedArrayValueBuilder
- createBuffered(MapType) - Static method in class io.trino.spi.block.BufferedMapValueBuilder
- createBuffered(RowType) - Static method in class io.trino.spi.block.BufferedRowValueBuilder
- createBufferedDistinctStrict(MapType) - Static method in class io.trino.spi.block.BufferedMapValueBuilder
- createBufferedStrict(MapType) - Static method in class io.trino.spi.block.BufferedMapValueBuilder
- createCatalogProperties(CatalogName, ConnectorName, Map<String, String>) - Method in interface io.trino.spi.catalog.CatalogStore
-
Create a catalog properties from the raw properties.
- createCharType(int) - Static method in class io.trino.spi.type.CharType
- createDecimalType() - Static method in class io.trino.spi.type.DecimalType
- createDecimalType(int) - Static method in class io.trino.spi.type.DecimalType
- createDecimalType(int, int) - Static method in class io.trino.spi.type.DecimalType
- createDeleteAndInsertPages(Page, int) - Static method in class io.trino.spi.connector.MergePage
- createExchange(ExchangeContext, int, boolean) - Method in interface io.trino.spi.exchange.ExchangeManager
-
Called by the coordinator to initiate an external exchange between a pair of stages
- createFixedSizeBlockBuilder(int) - Method in class io.trino.spi.type.AbstractIntType
- createFixedSizeBlockBuilder(int) - Method in class io.trino.spi.type.AbstractLongType
- createFixedSizeBlockBuilder(int) - Method in class io.trino.spi.type.BooleanType
- createFixedSizeBlockBuilder(int) - Method in class io.trino.spi.type.DoubleType
- createFixedSizeBlockBuilder(int) - Method in interface io.trino.spi.type.FixedWidthType
-
Creates a block builder for this type sized to hold the specified number of positions.
- createFixedSizeBlockBuilder(int) - Method in class io.trino.spi.type.SmallintType
- createFixedSizeBlockBuilder(int) - Method in class io.trino.spi.type.TinyintType
- createFixedSizeBlockBuilder(int) - Method in class io.trino.spi.type.UuidType
- createGroupedState() - Method in interface io.trino.spi.function.AccumulatorStateFactory
-
Return value is also guaranteed to implement GroupedAccumulatorState
- createInformationSchemaCatalogHandle(CatalogHandle) - Static method in class io.trino.spi.connector.CatalogHandle
- createLanguageFunction(ConnectorSession, SchemaFunctionName, LanguageFunction, boolean) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Creates a language function with the specified name and signature token.
- createMapBlockInternal(MapType, int, int, Optional<boolean[]>, int[], Block, Block, MapHashTables) - Static method in class io.trino.spi.block.MapBlock
-
Create a map block directly without per element validations.
- createMaterializedView(ConnectorSession, SchemaTableName, ConnectorMaterializedViewDefinition, Map<String, Object>, boolean, boolean) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Create the specified materialized view.
- createMergeSink(ConnectorTransactionHandle, ConnectorSession, ConnectorMergeTableHandle, ConnectorPageSinkId) - Method in interface io.trino.spi.connector.ConnectorPageSinkProvider
- createNullBlock() - Method in interface io.trino.spi.type.Type
-
Creates a block containing as single null values.
- createPageIndexer(List<Type>) - Method in interface io.trino.spi.PageIndexerFactory
- createPageSink(ConnectorTransactionHandle, ConnectorSession, ConnectorInsertTableHandle, ConnectorPageSinkId) - Method in interface io.trino.spi.connector.ConnectorPageSinkProvider
- createPageSink(ConnectorTransactionHandle, ConnectorSession, ConnectorOutputTableHandle, ConnectorPageSinkId) - Method in interface io.trino.spi.connector.ConnectorPageSinkProvider
- createPageSink(ConnectorTransactionHandle, ConnectorSession, ConnectorTableExecuteHandle, ConnectorPageSinkId) - Method in interface io.trino.spi.connector.ConnectorPageSinkProvider
- createPageSource(ConnectorTransactionHandle, ConnectorSession, ConnectorSplit, ConnectorTableHandle, List<ColumnHandle>, DynamicFilter) - Method in interface io.trino.spi.connector.ConnectorPageSourceProvider
- createPageSourceProvider() - Method in interface io.trino.spi.connector.ConnectorPageSourceProviderFactory
- createProjectedDictionaryBlock(int, Block, int[], DictionaryId) - Static method in class io.trino.spi.block.DictionaryBlock
-
This should not only be used when creating a projection of another dictionary block.
- createProjection(Block) - Method in class io.trino.spi.block.DictionaryBlock
- createRandomExchangeId() - Static method in class io.trino.spi.exchange.ExchangeId
- createRole(ConnectorSession, String, Optional<TrinoPrincipal>) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Creates the specified role.
- createRootCatalogHandle(CatalogName, CatalogHandle.CatalogVersion) - Static method in class io.trino.spi.connector.CatalogHandle
- createSchema(ConnectorSession, String, Map<String, Object>, TrinoPrincipal) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Creates a schema.
- createSingleState() - Method in interface io.trino.spi.function.AccumulatorStateFactory
- createSink(ExchangeSinkInstanceHandle) - Method in interface io.trino.spi.exchange.ExchangeManager
-
Called by a worker to create an
ExchangeSink
for a specific sink instance. - createSource() - Method in interface io.trino.spi.exchange.ExchangeManager
-
Called by a worker to create an
ExchangeSource
to read exchange data. - createSystemTablesCatalogHandle(CatalogHandle) - Static method in class io.trino.spi.connector.CatalogHandle
- createTable(ConnectorSession, ConnectorTableMetadata, SaveMode) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Creates a table using the specified table metadata.
- createTableFunctionProcessorProvider() - Method in interface io.trino.spi.function.table.TableFunctionProcessorProviderFactory
- createTimestampType(int) - Static method in class io.trino.spi.type.TimestampType
- createTimestampWithTimeZoneType(int) - Static method in class io.trino.spi.type.TimestampWithTimeZoneType
- createTimeType(int) - Static method in class io.trino.spi.type.TimeType
- createTimeWithTimeZoneType(int) - Static method in class io.trino.spi.type.TimeWithTimeZoneType
- createType(TypeManager, List<TypeParameter>) - Method in interface io.trino.spi.type.ParametricType
- createType(TypeManager, List<TypeParameter>) - Method in class io.trino.spi.type.QuantileDigestParametricType
- createType(TypeManager, List<TypeParameter>) - Method in class io.trino.spi.type.TimeParametricType
- createType(TypeManager, List<TypeParameter>) - Method in class io.trino.spi.type.TimestampParametricType
- createType(TypeManager, List<TypeParameter>) - Method in class io.trino.spi.type.TimestampWithTimeZoneParametricType
- createType(TypeManager, List<TypeParameter>) - Method in class io.trino.spi.type.TimeWithTimeZoneParametricType
- createUnboundedVarcharType() - Static method in class io.trino.spi.type.VarcharType
- createVarcharType(int) - Static method in class io.trino.spi.type.VarcharType
- createView(ConnectorSession, SchemaTableName, ConnectorViewDefinition, Map<String, Object>, boolean) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Create the specified view.
- createWindowFunction(boolean, List<Supplier<Object>>) - Method in interface io.trino.spi.function.WindowFunctionSupplier
- createWithTypeSignature(TypeSignature, List<RowType.Field>) - Static method in class io.trino.spi.type.RowType
- cursor() - Method in class io.trino.spi.connector.InMemoryRecordSet
- cursor() - Method in interface io.trino.spi.connector.RecordSet
- cursor(ConnectorTransactionHandle, ConnectorSession, TupleDomain<Integer>) - Method in interface io.trino.spi.connector.SystemTable
-
Create a cursor for the data in this table.
- cursor(ConnectorTransactionHandle, ConnectorSession, TupleDomain<Integer>, Set<Integer>) - Method in interface io.trino.spi.connector.SystemTable
D
- DATA_DEFINITION - Enum constant in enum class io.trino.spi.resourcegroups.QueryType
- DATE - Static variable in class io.trino.spi.type.DateType
- DATE - Static variable in class io.trino.spi.type.StandardTypes
- DateTimeEncoding - Class in io.trino.spi.type
- DateType - Class in io.trino.spi.type
- decimal(String, DecimalType) - Static method in class io.trino.spi.type.SqlDecimal
- DECIMAL - Static variable in class io.trino.spi.type.StandardTypes
- DecimalConversions - Class in io.trino.spi.type
- DecimalParseResult - Class in io.trino.spi.type
- DecimalParseResult(Object, DecimalType) - Constructor for class io.trino.spi.type.DecimalParseResult
- Decimals - Class in io.trino.spi.type
- DecimalType - Class in io.trino.spi.type
- declarePosition() - Method in class io.trino.spi.PageBuilder
- declarePositions(int) - Method in class io.trino.spi.PageBuilder
- decode(Object) - Method in class io.trino.spi.session.PropertyMetadata
-
Decodes the SQL type object value to the Java type of the property.
- decodeFixed12First(int[], int) - Static method in class io.trino.spi.block.Fixed12Block
-
At position * 3 in the values, read a little endian long.
- decodeFixed12Second(int[], int) - Static method in class io.trino.spi.block.Fixed12Block
-
At position * 3 + 8 in the values, read a little endian int.
- decodePageIndex(long) - Method in interface io.trino.spi.PageSorter
- decodePositionIndex(long) - Method in interface io.trino.spi.PageSorter
- decomposable() - Element in annotation interface io.trino.spi.function.AggregationFunction
- DEFAULT_COMPACTION_THRESHOLD - Static variable in class io.trino.spi.predicate.Domain
- DEFAULT_COMPARABLE_OPERATORS - Static variable in class io.trino.spi.type.AbstractVariableWidthType
- DEFAULT_MAX_PAGE_SIZE_IN_BYTES - Static variable in class io.trino.spi.block.PageBuilderStatus
- DEFAULT_ON_NULL - Enum constant in enum class io.trino.spi.function.InvocationConvention.InvocationReturnConvention
-
When a null is passed to a never null argument, the function will not be invoked, and the Java default value for the return type will be returned.
- DEFAULT_ORDERING_OPERATORS - Static variable in class io.trino.spi.type.AbstractVariableWidthType
- DEFAULT_PRECISION - Static variable in class io.trino.spi.type.DecimalType
- DEFAULT_PRECISION - Static variable in class io.trino.spi.type.TimestampType
- DEFAULT_PRECISION - Static variable in class io.trino.spi.type.TimestampWithTimeZoneType
- DEFAULT_PRECISION - Static variable in class io.trino.spi.type.TimeType
- DEFAULT_PRECISION - Static variable in class io.trino.spi.type.TimeWithTimeZoneType
- DEFAULT_READ_OPERATORS - Static variable in class io.trino.spi.type.AbstractVariableWidthType
- DEFAULT_SCALE - Static variable in class io.trino.spi.type.DecimalType
- defaultValue(Descriptor) - Method in class io.trino.spi.function.table.DescriptorArgumentSpecification.Builder
- defaultValue(Object) - Method in class io.trino.spi.function.table.ScalarArgumentSpecification.Builder
- delegateMaterializedViewRefreshToConnector(ConnectorSession, SchemaTableName) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Returns true if materialized view refresh should be delegated to connector using
ConnectorMetadata.refreshMaterializedView(io.trino.spi.connector.ConnectorSession, io.trino.spi.connector.SchemaTableName)
- DELETE - Enum constant in enum class io.trino.spi.resourcegroups.QueryType
- DELETE - Enum constant in enum class io.trino.spi.security.Privilege
- DELETE_OPERATION_NUMBER - Static variable in interface io.trino.spi.connector.ConnectorMergeSink
-
Represents a deleted row.
- DELETE_ROW_AND_INSERT_ROW - Enum constant in enum class io.trino.spi.connector.RowChangeParadigm
-
A paradigm that translates a changed row into a delete by rowId, and an insert of a new record, which will get a new rowId when the connector writes it out.
- denyAddColumn(String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyAddColumn(String, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyAlterColumn(String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyAlterColumn(String, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyCatalogAccess(String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyCatalogAccess(String, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyCommentColumn(String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyCommentColumn(String, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyCommentTable(String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyCommentTable(String, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyCommentView(String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyCommentView(String, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyCreateCatalog(String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyCreateCatalog(String, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyCreateFunction(String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyCreateFunction(String, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyCreateMaterializedView(String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyCreateMaterializedView(String, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyCreateRole(String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyCreateSchema(String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyCreateSchema(String, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyCreateTable(String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyCreateTable(String, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyCreateView(String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyCreateView(String, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyCreateViewWithSelect(String, ConnectorIdentity) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyCreateViewWithSelect(String, ConnectorIdentity, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyCreateViewWithSelect(String, Identity) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyDeleteTable(String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyDeleteTable(String, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyDenyEntityPrivilege(String, EntityKindAndName) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyDenyEntityPrivilege(String, EntityKindAndName, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyDenySchemaPrivilege(String, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyDenySchemaPrivilege(String, String, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyDenyTablePrivilege(String, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyDenyTablePrivilege(String, String, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyDropCatalog(String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyDropCatalog(String, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyDropColumn(String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyDropColumn(String, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyDropFunction(String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyDropFunction(String, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyDropMaterializedView(String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyDropMaterializedView(String, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyDropRole(String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyDropSchema(String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyDropSchema(String, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyDropTable(String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyDropTable(String, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyDropView(String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyDropView(String, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyExecuteFunction(String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyExecuteFunction(String, FunctionKind, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyExecuteProcedure(String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyExecuteProcedure(String, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyExecuteQuery() - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyExecuteQuery(String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyExecuteTableProcedure(String, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyGrantEntityPrivilege(String, EntityKindAndName) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyGrantEntityPrivilege(String, EntityKindAndName, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyGrantRoles(Set<String>, Set<TrinoPrincipal>) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyGrantSchemaPrivilege(String, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyGrantSchemaPrivilege(String, String, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyGrantTablePrivilege(String, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyGrantTablePrivilege(String, String, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyImpersonateUser(String, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyImpersonateUser(String, String, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyInsertTable(String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyInsertTable(String, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyKillQuery() - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyKillQuery(String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyReadSystemInformationAccess() - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyReadSystemInformationAccess(String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyRefreshMaterializedView(String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyRefreshMaterializedView(String, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyRenameColumn(String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyRenameColumn(String, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyRenameMaterializedView(String, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyRenameMaterializedView(String, String, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyRenameSchema(String, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyRenameSchema(String, String, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyRenameTable(String, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyRenameTable(String, String, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyRenameView(String, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyRenameView(String, String, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyRevokeEntityPrivilege(String, EntityKindAndName) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyRevokeEntityPrivilege(String, EntityKindAndName, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyRevokeRoles(Set<String>, Set<TrinoPrincipal>) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyRevokeSchemaPrivilege(String, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyRevokeSchemaPrivilege(String, String, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyRevokeTablePrivilege(String, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyRevokeTablePrivilege(String, String, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denySchemaPrivileges(ConnectorSession, String, Set<Privilege>, TrinoPrincipal) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Denys the specified privilege to the specified user on the specified schema
- denySelectColumns(String, Collection<String>) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denySelectColumns(String, Collection<String>, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denySelectTable(String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denySelectTable(String, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denySetCatalogSessionProperty(String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denySetCatalogSessionProperty(String, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denySetCatalogSessionProperty(String, String, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denySetMaterializedViewProperties(String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denySetMaterializedViewProperties(String, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denySetRole(String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denySetSchemaAuthorization(String, TrinoPrincipal) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denySetSchemaAuthorization(String, TrinoPrincipal, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denySetSystemSessionProperty(String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denySetSystemSessionProperty(String, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denySetTableAuthorization(String, TrinoPrincipal) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denySetTableAuthorization(String, TrinoPrincipal, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denySetTableProperties(String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denySetTableProperties(String, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denySetUser(Optional<Principal>, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denySetUser(Optional<Principal>, String, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denySetViewAuthorization(String, TrinoPrincipal) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denySetViewAuthorization(String, TrinoPrincipal, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyShowColumns(String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyShowColumns(String, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyShowCreateFunction(String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyShowCreateFunction(String, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyShowCreateSchema(String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyShowCreateSchema(String, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyShowCreateTable(String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyShowCreateTable(String, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyShowCurrentRoles() - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyShowFunctions(String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyShowFunctions(String, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyShowRoleGrants() - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyShowRoles() - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyShowSchemas() - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyShowSchemas(String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyShowTables(String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyShowTables(String, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyTablePrivileges(ConnectorSession, SchemaTableName, Set<Privilege>, TrinoPrincipal) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Denys the specified privilege to the specified user on the specified table
- denyTruncateTable(String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyTruncateTable(String, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyUpdateTableColumns(String, Set<String>) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyUpdateTableColumns(String, Set<String>, String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyViewQuery() - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyViewQuery(String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyWriteSystemInformationAccess() - Static method in exception class io.trino.spi.security.AccessDeniedException
- denyWriteSystemInformationAccess(String) - Static method in exception class io.trino.spi.security.AccessDeniedException
- deprecated() - Method in class io.trino.spi.function.FunctionMetadata.Builder
- DEPRECATED_FUNCTION - Enum constant in enum class io.trino.spi.connector.StandardWarningCode
- DESC_NULLS_FIRST - Enum constant in enum class io.trino.spi.connector.SortOrder
- DESC_NULLS_LAST - Enum constant in enum class io.trino.spi.connector.SortOrder
- DESCRIBE - Enum constant in enum class io.trino.spi.resourcegroups.QueryType
- DescribedTable(Descriptor) - Constructor for class io.trino.spi.function.table.ReturnTypeSpecification.DescribedTable
- description(String) - Method in class io.trino.spi.function.FunctionMetadata.Builder
- Description - Annotation Interface in io.trino.spi.function
- descriptor(Descriptor) - Method in class io.trino.spi.function.table.DescriptorArgument.Builder
- descriptor(String...) - Static method in class io.trino.spi.function.table.Descriptor
- descriptor(List<String>, List<Type>) - Static method in class io.trino.spi.function.table.Descriptor
- Descriptor - Class in io.trino.spi.function.table
- Descriptor(List<Descriptor.Field>) - Constructor for class io.trino.spi.function.table.Descriptor
- Descriptor.Field - Class in io.trino.spi.function.table
- DescriptorArgument - Class in io.trino.spi.function.table
-
This class represents the descriptor argument passed to a Table Function.
- DescriptorArgument(Optional<Descriptor>) - Constructor for class io.trino.spi.function.table.DescriptorArgument
- DescriptorArgument.Builder - Class in io.trino.spi.function.table
- DescriptorArgumentSpecification - Class in io.trino.spi.function.table
- DescriptorArgumentSpecification.Builder - Class in io.trino.spi.function.table
- deserialize(Block, int, T) - Method in interface io.trino.spi.function.AccumulatorStateSerializer
-
Deserialize
index
-th position inblock
intostate
. - destroy() - Method in class io.trino.spi.security.Identity
- deterministic() - Element in annotation interface io.trino.spi.function.ScalarFunction
- DictionaryBlock - Class in io.trino.spi.block
- DictionaryBlockEncoding - Class in io.trino.spi.block
- DictionaryBlockEncoding() - Constructor for class io.trino.spi.block.DictionaryBlockEncoding
- DictionaryId - Class in io.trino.spi.block
- DictionaryId(long, long, long) - Constructor for class io.trino.spi.block.DictionaryId
- DISABLED - Static variable in record class io.trino.spi.connector.WriterScalingOptions
- DISCRETE - Enum constant in enum class io.trino.spi.predicate.SortedRangeSet.DiscreteSetMarker
- DiscretePredicates - Class in io.trino.spi.connector
- DiscretePredicates(List<ColumnHandle>, Iterable<TupleDomain<ColumnHandle>>) - Constructor for class io.trino.spi.connector.DiscretePredicates
- DiscreteValues - Interface in io.trino.spi.predicate
- distributedWithFilteringAndRepartitioning() - Static method in class io.trino.spi.connector.TableProcedureExecutionMode
- Distribution<T> - Interface in io.trino.spi.metrics
- DIVIDE - Enum constant in enum class io.trino.spi.function.OperatorType
- DIVIDE_FUNCTION_NAME - Static variable in class io.trino.spi.expression.StandardFunctions
-
Arithmetic division.
- divideRoundUp(long, long, int, long, long, int) - Static method in class io.trino.spi.type.Int128Math
- DIVISION_BY_ZERO - Enum constant in enum class io.trino.spi.StandardErrorCode
- Domain - Class in io.trino.spi.predicate
-
Defines the possible values of a single variable in terms of its valid scalar values and nullability.
- Domain.DiscreteSet - Class in io.trino.spi.predicate
- DOUBLE - Static variable in class io.trino.spi.type.DoubleType
- DOUBLE - Static variable in class io.trino.spi.type.StandardTypes
- doubleProperty(String, String, Double, boolean) - Static method in class io.trino.spi.session.PropertyMetadata
- doubleProperty(String, String, Double, Consumer<Double>, boolean) - Static method in class io.trino.spi.session.PropertyMetadata
- DoubleRange - Class in io.trino.spi.statistics
- DoubleRange(double, double) - Constructor for class io.trino.spi.statistics.DoubleRange
- DoubleSymmetricDistribution - Class in io.trino.spi.eventlistener
- DoubleSymmetricDistribution(double, double, double, double, double, double, double, double, double, double, double, double, double) - Constructor for class io.trino.spi.eventlistener.DoubleSymmetricDistribution
- doubleToLongDecimal(double, long, long) - Static method in class io.trino.spi.type.DecimalConversions
- doubleToShortDecimal(double, long, long) - Static method in class io.trino.spi.type.DecimalConversions
- DoubleType - Class in io.trino.spi.type
- dropColumn(ConnectorSession, ConnectorTableHandle, ColumnHandle) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Drop the specified column
- dropField(ConnectorSession, ConnectorTableHandle, ColumnHandle, List<String>) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Drop the specified field, potentially nested, from a row.
- dropLanguageFunction(ConnectorSession, SchemaFunctionName, String) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Drops a language function with the specified name and signature token.
- dropMaterializedView(ConnectorSession, SchemaTableName) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Drop the specified materialized view.
- dropNotNullConstraint(ConnectorSession, ConnectorTableHandle, ColumnHandle) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Drop a not null constraint on the specified column
- dropRole(ConnectorSession, String) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Drops the specified role.
- dropSchema(ConnectorSession, String, boolean) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Drops the specified schema.
- dropTable(ConnectorSession, ConnectorTableHandle) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Drops the specified table
- dropView(ConnectorSession, SchemaTableName) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Drop the specified view.
- DUPLICATE_COLUMN_NAME - Enum constant in enum class io.trino.spi.StandardErrorCode
- DUPLICATE_COLUMN_OR_PATH_NAME - Enum constant in enum class io.trino.spi.StandardErrorCode
- DUPLICATE_NAMED_QUERY - Enum constant in enum class io.trino.spi.StandardErrorCode
- DUPLICATE_NOT_CHECKED - Enum constant in enum class io.trino.spi.block.MapHashTables.HashBuildMode
- DUPLICATE_PARAMETER_NAME - Enum constant in enum class io.trino.spi.StandardErrorCode
- DUPLICATE_PROPERTY - Enum constant in enum class io.trino.spi.StandardErrorCode
- DUPLICATE_RANGE_VARIABLE - Enum constant in enum class io.trino.spi.StandardErrorCode
- DUPLICATE_WINDOW_NAME - Enum constant in enum class io.trino.spi.StandardErrorCode
- DuplicateMapKeyException - Exception Class in io.trino.spi.block
- DuplicateMapKeyException(Block, int) - Constructor for exception class io.trino.spi.block.DuplicateMapKeyException
- DynamicFilter - Interface in io.trino.spi.connector
E
- EAGER - Enum constant in enum class io.trino.spi.exchange.Exchange.SourceHandlesDeliveryMode
- embedVersion(Runnable) - Method in interface io.trino.spi.VersionEmbedder
-
Encodes Trino server version information in the stack
- embedVersion(Callable<T>) - Method in interface io.trino.spi.VersionEmbedder
- embedVersion(Executor) - Method in interface io.trino.spi.VersionEmbedder
- empty() - Static method in class io.trino.spi.statistics.ColumnStatistics
- empty() - Static method in class io.trino.spi.statistics.TableStatistics
- empty() - Static method in class io.trino.spi.statistics.TableStatisticsMetadata
- EMPTY - Static variable in interface io.trino.spi.connector.DynamicFilter
- EMPTY - Static variable in class io.trino.spi.metrics.Metrics
- EmptyPageSource - Class in io.trino.spi.connector
- EmptyPageSource() - Constructor for class io.trino.spi.connector.EmptyPageSource
- emptySplitSource() - Static method in class io.trino.spi.connector.FixedSplitSource
- ENABLED - Static variable in record class io.trino.spi.connector.WriterScalingOptions
- encode(T) - Method in class io.trino.spi.session.PropertyMetadata
-
Encodes the Java type value to SQL type object value
- encodeFixed12(long, int, int[], int) - Static method in class io.trino.spi.block.Fixed12Block
-
At position * 3 in the values, write a little endian long followed by a little endian int.
- encodeScaledValue(BigDecimal, int) - Static method in class io.trino.spi.type.Decimals
- encodeScaledValue(BigDecimal, int, RoundingMode) - Static method in class io.trino.spi.type.Decimals
- encodeShortScaledValue(BigDecimal, int) - Static method in class io.trino.spi.type.Decimals
- encodeShortScaledValue(BigDecimal, int, RoundingMode) - Static method in class io.trino.spi.type.Decimals
- ensureCapacity(int) - Method in interface io.trino.spi.function.GroupedAccumulatorState
- entityKind() - Method in record class io.trino.spi.connector.EntityKindAndName
-
Returns the value of the
entityKind
record component. - EntityKindAndName - Record Class in io.trino.spi.connector
- EntityKindAndName(String, List<String>) - Constructor for record class io.trino.spi.connector.EntityKindAndName
-
Creates an instance of a
EntityKindAndName
record class. - EntityPrivilege - Record Class in io.trino.spi.connector
- EntityPrivilege(String) - Constructor for record class io.trino.spi.connector.EntityPrivilege
-
Creates an instance of a
EntityPrivilege
record class. - enumProperty(String, String, Class<T>, T, boolean) - Static method in class io.trino.spi.session.PropertyMetadata
- enumProperty(String, String, Class<T>, T, Consumer<T>, boolean) - Static method in class io.trino.spi.session.PropertyMetadata
- epochMicrosToMillisWithRounding(long) - Static method in class io.trino.spi.type.Timestamps
- equal(Type, Object) - Static method in class io.trino.spi.predicate.Range
- EQUAL - Enum constant in enum class io.trino.spi.connector.JoinCondition.Operator
-
Deprecated.
- EQUAL - Enum constant in enum class io.trino.spi.function.OperatorType
- EQUAL_OPERATOR_FUNCTION_NAME - Static variable in class io.trino.spi.expression.StandardFunctions
- equalOperator(long, long) - Static method in class io.trino.spi.type.TimeType
- equals(Object) - Method in class io.trino.spi.block.DictionaryId
- equals(Object) - Method in class io.trino.spi.catalog.CatalogName
- equals(Object) - Method in record class io.trino.spi.catalog.CatalogProperties
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in class io.trino.spi.connector.AggregateFunction
- equals(Object) - Method in class io.trino.spi.connector.CatalogHandle.CatalogVersion
- equals(Object) - Method in class io.trino.spi.connector.CatalogHandle
- equals(Object) - Method in class io.trino.spi.connector.CatalogSchemaName
- equals(Object) - Method in class io.trino.spi.connector.CatalogSchemaRoutineName
- equals(Object) - Method in class io.trino.spi.connector.CatalogSchemaTableName
- equals(Object) - Method in interface io.trino.spi.connector.ColumnHandle
- equals(Object) - Method in class io.trino.spi.connector.ColumnMetadata
- equals(Object) - Method in class io.trino.spi.connector.ColumnSchema
- equals(Object) - Method in class io.trino.spi.connector.ConnectorMaterializedViewDefinition.Column
- equals(Object) - Method in class io.trino.spi.connector.ConnectorMaterializedViewDefinition
- equals(Object) - Method in class io.trino.spi.connector.ConnectorName
- equals(Object) - Method in class io.trino.spi.connector.ConnectorTablePartitioning
- equals(Object) - Method in class io.trino.spi.connector.ConnectorTableProperties
- equals(Object) - Method in class io.trino.spi.connector.ConstantProperty
- equals(Object) - Method in record class io.trino.spi.connector.EntityKindAndName
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class io.trino.spi.connector.EntityPrivilege
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in class io.trino.spi.connector.GroupingProperty
- equals(Object) - Method in class io.trino.spi.connector.JoinCondition
-
Deprecated.
- equals(Object) - Method in class io.trino.spi.connector.MaterializedViewFreshness
- equals(Object) - Method in record class io.trino.spi.connector.RelationColumnsMetadata
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class io.trino.spi.connector.RelationCommentMetadata
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in class io.trino.spi.connector.SchemaRoutineName
- equals(Object) - Method in class io.trino.spi.connector.SchemaTableName
- equals(Object) - Method in class io.trino.spi.connector.SchemaTablePrefix
- equals(Object) - Method in class io.trino.spi.connector.SortingProperty
- equals(Object) - Method in class io.trino.spi.connector.SortItem
- equals(Object) - Method in record class io.trino.spi.connector.WriterScalingOptions
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in class io.trino.spi.ErrorCode
- equals(Object) - Method in class io.trino.spi.eventlistener.ColumnDetail
- equals(Object) - Method in record class io.trino.spi.eventlistener.ColumnMaskReferenceInfo
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class io.trino.spi.eventlistener.MaterializedViewReferenceInfo
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in class io.trino.spi.eventlistener.OutputColumnMetadata
- equals(Object) - Method in record class io.trino.spi.eventlistener.QueryPlanOptimizerStatistics
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class io.trino.spi.eventlistener.RowFilterReferenceInfo
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class io.trino.spi.eventlistener.ViewReferenceInfo
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in class io.trino.spi.exchange.ExchangeId
- equals(Object) - Method in record class io.trino.spi.exchange.ExchangeSourceHandleSource.ExchangeSourceHandleBatch
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in class io.trino.spi.expression.Call
- equals(Object) - Method in class io.trino.spi.expression.ConnectorExpression
- equals(Object) - Method in class io.trino.spi.expression.Constant
- equals(Object) - Method in class io.trino.spi.expression.FieldDereference
- equals(Object) - Method in class io.trino.spi.expression.FunctionName
- equals(Object) - Method in class io.trino.spi.expression.Variable
- equals(Object) - Method in class io.trino.spi.function.BoundSignature
- equals(Object) - Method in class io.trino.spi.function.CatalogSchemaFunctionName
- equals(Object) - Method in class io.trino.spi.function.FunctionDependencyDeclaration.CastDependency
- equals(Object) - Method in class io.trino.spi.function.FunctionDependencyDeclaration.FunctionDependency
- equals(Object) - Method in class io.trino.spi.function.FunctionDependencyDeclaration.OperatorDependency
- equals(Object) - Method in class io.trino.spi.function.FunctionId
- equals(Object) - Method in class io.trino.spi.function.FunctionNullability
- equals(Object) - Method in class io.trino.spi.function.InvocationConvention
- equals(Object) - Method in record class io.trino.spi.function.LanguageFunction
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in class io.trino.spi.function.LongVariableConstraint
- equals(Object) - Method in class io.trino.spi.function.SchemaFunctionName
- equals(Object) - Method in class io.trino.spi.function.Signature
- equals(Object) - Method in class io.trino.spi.function.table.Descriptor
- equals(Object) - Method in class io.trino.spi.function.table.Descriptor.Field
- equals(Object) - Method in class io.trino.spi.function.table.DescriptorArgument
- equals(Object) - Method in class io.trino.spi.function.table.NameAndPosition
- equals(Object) - Method in class io.trino.spi.function.TypeVariableConstraint
- equals(Object) - Method in class io.trino.spi.HostAddress
- equals(Object) - Method in class io.trino.spi.Location
- equals(Object) - Method in class io.trino.spi.metrics.Metrics
- equals(Object) - Method in class io.trino.spi.predicate.AllOrNoneValueSet
- equals(Object) - Method in class io.trino.spi.predicate.Domain
- equals(Object) - Method in class io.trino.spi.predicate.EquatableValueSet
- equals(Object) - Method in class io.trino.spi.predicate.EquatableValueSet.ValueEntry
- equals(Object) - Method in class io.trino.spi.predicate.NullableValue
- equals(Object) - Method in class io.trino.spi.predicate.Range
- equals(Object) - Method in class io.trino.spi.predicate.SortedRangeSet
- equals(Object) - Method in class io.trino.spi.predicate.TupleDomain
- equals(Object) - Method in class io.trino.spi.QueryId
- equals(Object) - Method in class io.trino.spi.resourcegroups.ResourceGroupId
- equals(Object) - Method in class io.trino.spi.security.BasicPrincipal
- equals(Object) - Method in class io.trino.spi.security.GrantInfo
- equals(Object) - Method in class io.trino.spi.security.Identity
- equals(Object) - Method in class io.trino.spi.security.PrivilegeInfo
- equals(Object) - Method in class io.trino.spi.security.RoleGrant
- equals(Object) - Method in class io.trino.spi.security.SelectedRole
- equals(Object) - Method in class io.trino.spi.security.TrinoPrincipal
- equals(Object) - Method in class io.trino.spi.SplitWeight
- equals(Object) - Method in class io.trino.spi.statistics.ColumnStatisticMetadata
- equals(Object) - Method in class io.trino.spi.statistics.ColumnStatistics
- equals(Object) - Method in class io.trino.spi.statistics.DoubleRange
- equals(Object) - Method in class io.trino.spi.statistics.Estimate
- equals(Object) - Method in class io.trino.spi.statistics.TableStatistics
- equals(Object) - Method in class io.trino.spi.TrinoWarning
- equals(Object) - Method in class io.trino.spi.type.AbstractType
- equals(Object) - Method in class io.trino.spi.type.BigintType
- equals(Object) - Method in class io.trino.spi.type.BooleanType
- equals(Object) - Method in class io.trino.spi.type.CharType
- equals(Object) - Method in class io.trino.spi.type.DateType
- equals(Object) - Method in class io.trino.spi.type.DecimalParseResult
- equals(Object) - Method in class io.trino.spi.type.DoubleType
- equals(Object) - Method in class io.trino.spi.type.Int128
- equals(Object) - Method in class io.trino.spi.type.IntegerType
- equals(Object) - Method in class io.trino.spi.type.LongTimestamp
- equals(Object) - Method in class io.trino.spi.type.LongTimestampWithTimeZone
- equals(Object) - Method in class io.trino.spi.type.LongTimeWithTimeZone
- equals(Object) - Method in class io.trino.spi.type.NamedType
- equals(Object) - Method in class io.trino.spi.type.NamedTypeSignature
- equals(Object) - Method in class io.trino.spi.type.RealType
- equals(Object) - Method in class io.trino.spi.type.RowFieldName
- equals(Object) - Method in class io.trino.spi.type.SmallintType
- equals(Object) - Method in class io.trino.spi.type.SqlDate
- equals(Object) - Method in class io.trino.spi.type.SqlDecimal
- equals(Object) - Method in class io.trino.spi.type.SqlTime
- equals(Object) - Method in class io.trino.spi.type.SqlTimestamp
- equals(Object) - Method in class io.trino.spi.type.SqlTimestampWithTimeZone
- equals(Object) - Method in class io.trino.spi.type.SqlTimeWithTimeZone
- equals(Object) - Method in class io.trino.spi.type.SqlVarbinary
- equals(Object) - Method in class io.trino.spi.type.TimeZoneKey
- equals(Object) - Method in class io.trino.spi.type.TinyintType
- equals(Object) - Method in class io.trino.spi.type.TypeId
- equals(Object) - Method in class io.trino.spi.type.TypeParameter
- equals(Object) - Method in class io.trino.spi.type.TypeSignature
- equals(Object) - Method in class io.trino.spi.type.TypeSignatureParameter
- equals(Object) - Method in class io.trino.spi.type.VarbinaryType
- equals(Object) - Method in class io.trino.spi.type.VarcharType
- equals(Object) - Method in class io.trino.spi.WarningCode
- EquatableValueSet - Class in io.trino.spi.predicate
-
A set containing values that are uniquely identifiable.
- EquatableValueSet(Type, boolean, Set<EquatableValueSet.ValueEntry>) - Constructor for class io.trino.spi.predicate.EquatableValueSet
- EquatableValueSet.ValueEntry - Class in io.trino.spi.predicate
- ErrorCode - Class in io.trino.spi
- ErrorCode(int, String, ErrorType) - Constructor for class io.trino.spi.ErrorCode
- ErrorCode(int, String, ErrorType, boolean) - Constructor for class io.trino.spi.ErrorCode
- ErrorCodeSupplier - Interface in io.trino.spi
- ErrorType - Enum Class in io.trino.spi
- Estimate - Class in io.trino.spi.statistics
- eta() - Element in annotation interface io.trino.spi.Experimental
-
When the community expects the SPI will be finalized, but this date may be extended.
- EventListener - Interface in io.trino.spi.eventlistener
- EventListenerFactory - Interface in io.trino.spi.eventlistener
- EXCEEDED_CPU_LIMIT - Enum constant in enum class io.trino.spi.StandardErrorCode
- EXCEEDED_FUNCTION_MEMORY_LIMIT - Enum constant in enum class io.trino.spi.StandardErrorCode
- EXCEEDED_GLOBAL_MEMORY_LIMIT - Enum constant in enum class io.trino.spi.StandardErrorCode
- EXCEEDED_LOCAL_MEMORY_LIMIT - Enum constant in enum class io.trino.spi.StandardErrorCode
- EXCEEDED_SCAN_LIMIT - Enum constant in enum class io.trino.spi.StandardErrorCode
- EXCEEDED_SPILL_LIMIT - Enum constant in enum class io.trino.spi.StandardErrorCode
- EXCEEDED_TASK_DESCRIPTOR_STORAGE_CAPACITY - Enum constant in enum class io.trino.spi.StandardErrorCode
- EXCEEDED_TIME_LIMIT - Enum constant in enum class io.trino.spi.StandardErrorCode
- Exchange - Interface in io.trino.spi.exchange
- EXCHANGE_MANAGER_NOT_CONFIGURED - Enum constant in enum class io.trino.spi.StandardErrorCode
- Exchange.SourceHandlesDeliveryMode - Enum Class in io.trino.spi.exchange
- ExchangeContext - Interface in io.trino.spi.exchange
- ExchangeId - Class in io.trino.spi.exchange
- ExchangeId(String) - Constructor for class io.trino.spi.exchange.ExchangeId
- ExchangeManager - Interface in io.trino.spi.exchange
-
Service provider interface for an external exchange
- ExchangeManagerContext - Interface in io.trino.spi.exchange
- ExchangeManagerFactory - Interface in io.trino.spi.exchange
- ExchangeSink - Interface in io.trino.spi.exchange
- ExchangeSinkHandle - Interface in io.trino.spi.exchange
- ExchangeSinkInstanceHandle - Interface in io.trino.spi.exchange
- ExchangeSource - Interface in io.trino.spi.exchange
- ExchangeSourceHandle - Interface in io.trino.spi.exchange
- ExchangeSourceHandleBatch(List<ExchangeSourceHandle>, boolean) - Constructor for record class io.trino.spi.exchange.ExchangeSourceHandleSource.ExchangeSourceHandleBatch
-
Creates an instance of a
ExchangeSourceHandleBatch
record class. - ExchangeSourceHandleSource - Interface in io.trino.spi.exchange
- ExchangeSourceHandleSource.ExchangeSourceHandleBatch - Record Class in io.trino.spi.exchange
- ExchangeSourceOutputSelector - Class in io.trino.spi.exchange
- ExchangeSourceOutputSelector(int, Map<ExchangeId, Slice>, boolean) - Constructor for class io.trino.spi.exchange.ExchangeSourceOutputSelector
- ExchangeSourceOutputSelector.Builder - Class in io.trino.spi.exchange
- ExchangeSourceOutputSelector.Selection - Enum Class in io.trino.spi.exchange
- ExchangeSourceStatistics - Class in io.trino.spi.exchange
- ExchangeSourceStatistics(long) - Constructor for class io.trino.spi.exchange.ExchangeSourceStatistics
- exclude(ExchangeId, int) - Method in class io.trino.spi.exchange.ExchangeSourceOutputSelector.Builder
- EXCLUDED - Enum constant in enum class io.trino.spi.exchange.ExchangeSourceOutputSelector.Selection
- executeDelete(ConnectorSession, ConnectorTableHandle) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Execute the delete operation on the handle returned from
ConnectorMetadata.applyDelete(io.trino.spi.connector.ConnectorSession, io.trino.spi.connector.ConnectorTableHandle)
. - executeTableExecute(ConnectorSession, ConnectorTableExecuteHandle) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Execute a
coordinator-only
table procedure. - executeUpdate(ConnectorSession, ConnectorTableHandle) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Execute the update operation on the handle returned from
ConnectorMetadata.applyUpdate(io.trino.spi.connector.ConnectorSession, io.trino.spi.connector.ConnectorTableHandle, java.util.Map<io.trino.spi.connector.ColumnHandle, io.trino.spi.expression.Constant>)
. - EXECUTION_TIME - Static variable in class io.trino.spi.session.ResourceEstimates
- EXPECTED_BYTES_PER_ENTRY - Static variable in class io.trino.spi.type.AbstractVariableWidthType
- Experimental - Annotation Interface in io.trino.spi
-
Signifies that a public API (public class, method or field) is subject to incompatible changes, or even removal, in a future release.
- EXPLAIN - Enum constant in enum class io.trino.spi.resourcegroups.QueryType
- expression() - Method in record class io.trino.spi.eventlistener.ColumnMaskReferenceInfo
-
Returns the value of the
expression
record component. - expression() - Method in interface io.trino.spi.eventlistener.FilterMaskReferenceInfo
- expression() - Method in record class io.trino.spi.eventlistener.RowFilterReferenceInfo
-
Returns the value of the
expression
record component. - expression() - Element in annotation interface io.trino.spi.function.Constraint
- expression(String) - Method in class io.trino.spi.security.ViewExpression.Builder
- EXPRESSION_NOT_AGGREGATE - Enum constant in enum class io.trino.spi.StandardErrorCode
- EXPRESSION_NOT_CONSTANT - Enum constant in enum class io.trino.spi.StandardErrorCode
- EXPRESSION_NOT_IN_DISTINCT - Enum constant in enum class io.trino.spi.StandardErrorCode
- EXPRESSION_NOT_SCALAR - Enum constant in enum class io.trino.spi.StandardErrorCode
- EXTERNAL - Enum constant in enum class io.trino.spi.ErrorType
- extractDiscreteValues(TupleDomain<T>) - Static method in class io.trino.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.trino.spi.predicate.TupleDomain
-
Extract all column constraints that require exactly one value or only null in their respective Domains.
- extractOperatorDeclaration(Class<?>, MethodHandles.Lookup, Class<?>) - Static method in class io.trino.spi.type.TypeOperatorDeclaration
F
- factory(AccumulatorStateFactory<T>) - Method in class io.trino.spi.function.AggregationImplementation.AccumulatorStateDescriptor.Builder
- FAIL - Enum constant in enum class io.trino.spi.connector.SaveMode
- FAIL_ON_NULL - Enum constant in enum class io.trino.spi.function.InvocationConvention.InvocationReturnConvention
-
The function will never return a null value.
- failures() - Method in record class io.trino.spi.eventlistener.QueryPlanOptimizerStatistics
-
Returns the value of the
failures
record component. - FAIR - Enum constant in enum class io.trino.spi.resourcegroups.SchedulingPolicy
- FALSE - Static variable in class io.trino.spi.expression.Constant
- field(Type) - Static method in class io.trino.spi.type.RowType
- field(String, Type) - Static method in class io.trino.spi.type.RowType
- Field(String, Optional<Type>) - Constructor for class io.trino.spi.function.table.Descriptor.Field
- Field(Optional<String>, Type) - Constructor for class io.trino.spi.type.RowType.Field
- Field(Optional<String>, Optional<Type>) - Constructor for class io.trino.spi.function.table.Descriptor.Field
- FieldDereference - Class in io.trino.spi.expression
- FieldDereference(Type, ConnectorExpression, int) - Constructor for class io.trino.spi.expression.FieldDereference
- filter(BiPredicate<T, Domain>) - Method in class io.trino.spi.predicate.TupleDomain
- filterCatalogs(SystemSecurityContext, Set<String>) - Method in interface io.trino.spi.security.SystemAccessControl
-
Filter the list of catalogs to those visible to the identity.
- filterColumns(ConnectorSecurityContext, Map<SchemaTableName, Set<String>>) - Method in interface io.trino.spi.connector.ConnectorAccessControl
-
Filter lists of columns of multiple tables to those visible to the identity.
- filterColumns(SystemSecurityContext, CatalogSchemaTableName, Set<String>) - Method in interface io.trino.spi.security.SystemAccessControl
- filterColumns(SystemSecurityContext, String, Map<SchemaTableName, Set<String>>) - Method in interface io.trino.spi.security.SystemAccessControl
-
Filter lists of columns of multiple tables to those visible to the identity.
- filterFunctions(ConnectorSecurityContext, Set<SchemaFunctionName>) - Method in interface io.trino.spi.connector.ConnectorAccessControl
-
Filter the list of functions to those visible to the identity.
- filterFunctions(SystemSecurityContext, String, Set<SchemaFunctionName>) - Method in interface io.trino.spi.security.SystemAccessControl
-
Filter the list of functions to those visible to the identity.
- FilterMaskReferenceInfo - Interface in io.trino.spi.eventlistener
-
This class is JSON serializable for convenience and serialization compatibility is not guaranteed across versions.
- filterSchemas(ConnectorSecurityContext, Set<String>) - Method in interface io.trino.spi.connector.ConnectorAccessControl
-
Filter the list of schemas to those visible to the identity.
- filterSchemas(SystemSecurityContext, String, Set<String>) - Method in interface io.trino.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.trino.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.trino.spi.security.SystemAccessControl
-
Filter the list of tables and views to those visible to the identity.
- filterViewQueryOwnedBy(Identity, Collection<Identity>) - Method in interface io.trino.spi.security.SystemAccessControl
-
Filter the list of users to those the identity view query owned by the user.
- finish() - Method in interface io.trino.spi.connector.ConnectorMergeSink
- finish() - Method in interface io.trino.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 interface io.trino.spi.exchange.ExchangeSink
-
Notifies the exchange sink that no more data will be appended.
- finishCreateTable(ConnectorSession, ConnectorOutputTableHandle, Collection<Slice>, Collection<ComputedStatistics>) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Finish a table creation with data after the data is written.
- FINISHED - Static variable in class io.trino.spi.function.table.TableFunctionProcessorState.Finished
- finishInsert(ConnectorSession, ConnectorInsertTableHandle, List<ConnectorTableHandle>, Collection<Slice>, Collection<ComputedStatistics>) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Finish insert query
- finishMerge(ConnectorSession, ConnectorMergeTableHandle, List<ConnectorTableHandle>, Collection<Slice>, Collection<ComputedStatistics>) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Finish a merge query
- finishRefreshMaterializedView(ConnectorSession, ConnectorTableHandle, ConnectorInsertTableHandle, Collection<Slice>, Collection<ComputedStatistics>, List<ConnectorTableHandle>, List<String>) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Finish materialized view query
- finishStatisticsCollection(ConnectorSession, ConnectorTableHandle, Collection<ComputedStatistics>) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Finish statistics collection
- finishTableExecute(ConnectorSession, ConnectorTableExecuteHandle, Collection<Slice>, List<Object>) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Finish table execute
- FIXED12_BYTES - Static variable in class io.trino.spi.block.Fixed12Block
- Fixed12Block - Class in io.trino.spi.block
- Fixed12Block(int, Optional<boolean[]>, int[]) - Constructor for class io.trino.spi.block.Fixed12Block
- Fixed12BlockBuilder - Class in io.trino.spi.block
- Fixed12BlockBuilder(BlockBuilderStatus, int) - Constructor for class io.trino.spi.block.Fixed12BlockBuilder
- Fixed12BlockEncoding - Class in io.trino.spi.block
- Fixed12BlockEncoding() - Constructor for class io.trino.spi.block.Fixed12BlockEncoding
- FixedPageSource - Class in io.trino.spi.connector
- FixedPageSource(Iterator<Page>, long) - Constructor for class io.trino.spi.connector.FixedPageSource
- FixedPageSource(List<Page>) - Constructor for class io.trino.spi.connector.FixedPageSource
- fixedSizeInBytesPerPosition() - Method in class io.trino.spi.block.ArrayBlock
- fixedSizeInBytesPerPosition() - Method in interface io.trino.spi.block.Block
-
Returns the number of bytes (in terms of
Block.getSizeInBytes()
) required per position that this block contains, assuming that the number of bytes required is a known static quantity and not dependent on any particular specific position. - fixedSizeInBytesPerPosition() - Method in class io.trino.spi.block.ByteArrayBlock
- fixedSizeInBytesPerPosition() - Method in class io.trino.spi.block.DictionaryBlock
- fixedSizeInBytesPerPosition() - Method in class io.trino.spi.block.Fixed12Block
- fixedSizeInBytesPerPosition() - Method in class io.trino.spi.block.Int128ArrayBlock
- fixedSizeInBytesPerPosition() - Method in class io.trino.spi.block.IntArrayBlock
- fixedSizeInBytesPerPosition() - Method in class io.trino.spi.block.LazyBlock
- fixedSizeInBytesPerPosition() - Method in class io.trino.spi.block.LongArrayBlock
- fixedSizeInBytesPerPosition() - Method in class io.trino.spi.block.MapBlock
- fixedSizeInBytesPerPosition() - Method in class io.trino.spi.block.RowBlock
- fixedSizeInBytesPerPosition() - Method in class io.trino.spi.block.RunLengthEncodedBlock
- fixedSizeInBytesPerPosition() - Method in class io.trino.spi.block.ShortArrayBlock
- fixedSizeInBytesPerPosition() - Method in class io.trino.spi.block.VariableWidthBlock
- FixedSplitSource - Class in io.trino.spi.connector
- FixedSplitSource(ConnectorSplit) - Constructor for class io.trino.spi.connector.FixedSplitSource
- FixedSplitSource(Iterable<? extends ConnectorSplit>) - Constructor for class io.trino.spi.connector.FixedSplitSource
- FixedSplitSource(Iterable<? extends ConnectorSplit>, List<Object>) - Constructor for class io.trino.spi.connector.FixedSplitSource
- FixedWidthType - Interface in io.trino.spi.type
-
FixedWidthType is a type that has a fixed size for every value.
- FLAT - Enum constant in enum class io.trino.spi.function.InvocationConvention.InvocationArgumentConvention
-
Argument is passed as a flat slice.
- FLAT_RETURN - Enum constant in enum class io.trino.spi.function.InvocationConvention.InvocationReturnConvention
-
Return value is written to flat memory passed as the last 5 arguments to the function.
- FlatFixed - Annotation Interface in io.trino.spi.function
- FlatFixedOffset - Annotation Interface in io.trino.spi.function
- FlatVariableWidth - Annotation Interface in io.trino.spi.function
- flip() - Method in enum class io.trino.spi.connector.JoinCondition.Operator
-
Deprecated.
- floorDiv(Int128, Int128) - Static method in class io.trino.spi.type.Int128Math
- forMaterializedView(SchemaTableName, List<ConnectorMaterializedViewDefinition.Column>) - Static method in record class io.trino.spi.connector.RelationColumnsMetadata
- forRedirectedTable(SchemaTableName) - Static method in record class io.trino.spi.connector.RelationColumnsMetadata
- forRedirectedTable(SchemaTableName) - Static method in record class io.trino.spi.connector.RelationCommentMetadata
- forRedirectedTable(SchemaTableName) - Static method in class io.trino.spi.connector.TableColumnsMetadata
- forRelation(SchemaTableName, Optional<String>) - Static method in record class io.trino.spi.connector.RelationCommentMetadata
- forTable(SchemaTableName, List<ColumnMetadata>) - Static method in record class io.trino.spi.connector.RelationColumnsMetadata
- forTable(SchemaTableName, List<ColumnMetadata>) - Static method in class io.trino.spi.connector.TableColumnsMetadata
- forUser(String) - Static method in class io.trino.spi.security.ConnectorIdentity
- forUser(String) - Static method in class io.trino.spi.security.Identity
- forView(SchemaTableName, List<ConnectorViewDefinition.ViewColumn>) - Static method in record class io.trino.spi.connector.RelationColumnsMetadata
- FRESH - Enum constant in enum class io.trino.spi.connector.MaterializedViewFreshness.Freshness
- from(ConnectorExpression, Set<String>, Set<String>) - Static method in class io.trino.spi.connector.JoinCondition
-
Deprecated.
- from(Identity) - Static method in class io.trino.spi.security.Identity
- from(Type, Object, Object) - Static method in class io.trino.spi.statistics.DoubleRange
-
Creates DoubleRange from Trino native representation.
- from(List<RowType.Field>) - Static method in class io.trino.spi.type.RowType
- fromBigEndian(byte[]) - Static method in class io.trino.spi.type.Int128
-
Decode an Int128 from the two's complement big-endian representation.
- fromColumnDomains(Optional<List<TupleDomain.ColumnDomain<T>>>) - Static method in class io.trino.spi.predicate.TupleDomain
-
Deprecated.
- fromElementBlock(int, Optional<boolean[]>, int[], Block) - Static method in class io.trino.spi.block.ArrayBlock
-
Create an array block directly from columnar nulls, values, and offsets into the values.
- fromEpochMillisAndFraction(long, int, short) - Static method in class io.trino.spi.type.LongTimestampWithTimeZone
- fromEpochMillisAndFraction(long, int, TimeZoneKey) - Static method in class io.trino.spi.type.LongTimestampWithTimeZone
- fromEpochSecondsAndFraction(long, long, TimeZoneKey) - Static method in class io.trino.spi.type.LongTimestampWithTimeZone
- fromFieldBlocks(int, Block[]) - Static method in class io.trino.spi.block.RowBlock
-
Create a row block directly from field blocks.
- fromFixedValues(Map<T, NullableValue>) - Static method in class io.trino.spi.predicate.TupleDomain
-
Convert a map of columns to values into the TupleDomain which requires those columns to be fixed to those values.
- fromId(String) - Static method in class io.trino.spi.connector.CatalogHandle
- fromInstant(int, Instant, ZoneId) - Static method in class io.trino.spi.type.SqlTimestampWithTimeZone
- fromJson(CatalogSchemaFunctionName, List<TypeSignature>, boolean) - Static method in class io.trino.spi.function.FunctionDependencyDeclaration.FunctionDependency
- fromJson(FunctionId, Signature, String, Set<String>, FunctionNullability, boolean, boolean, String, FunctionKind, boolean) - Static method in class io.trino.spi.function.FunctionMetadata
- fromJson(OperatorType, List<TypeSignature>, boolean) - Static method in class io.trino.spi.function.FunctionDependencyDeclaration.OperatorDependency
- fromJson(Type, boolean[], Block, SortedRangeSet.DiscreteSetMarker) - Static method in class io.trino.spi.predicate.SortedRangeSet
-
Deprecated.
- fromJson(TypeSignature, TypeSignature, boolean) - Static method in class io.trino.spi.function.FunctionDependencyDeclaration.CastDependency
- fromJson(String, boolean, boolean, Optional<String>, Set<TypeSignature>, Set<TypeSignature>) - Static method in class io.trino.spi.function.TypeVariableConstraint
-
Deprecated.
- fromJson(String, String) - Static method in class io.trino.spi.function.LongVariableConstraint
-
Deprecated.
- fromJson(String, String, Optional<ColumnStatisticType>, Optional<FunctionName>) - Static method in class io.trino.spi.statistics.ColumnStatisticMetadata
- fromJson(List<TypeVariableConstraint>, List<LongVariableConstraint>, TypeSignature, List<TypeSignature>, boolean) - Static method in class io.trino.spi.function.Signature
-
Deprecated.
- fromJson(Set<TypeSignature>, Set<FunctionDependencyDeclaration.FunctionDependency>, Set<FunctionDependencyDeclaration.OperatorDependency>, Set<FunctionDependencyDeclaration.CastDependency>) - Static method in class io.trino.spi.function.FunctionDependencyDeclaration
- fromKeyValueBlock(Optional<boolean[]>, int[], int, Block, Block, MapType) - Static method in class io.trino.spi.block.MapBlock
- fromKeyValueBlock(Optional<boolean[]>, int[], Block, Block, MapType) - Static method in class io.trino.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.trino.spi.type.SqlTimestamp
- fromNotNullSuppressedFieldBlocks(int, Optional<boolean[]>, Block[]) - Static method in class io.trino.spi.block.RowBlock
-
Create a row block directly from field blocks that are not null-suppressed.
- fromNullableValue(NullableValue) - Static method in class io.trino.spi.function.table.ScalarArgument
- fromParts(String, int) - Static method in class io.trino.spi.HostAddress
-
Build a HostAddress instance from separate host and port values.
- fromProportion(double) - Static method in class io.trino.spi.SplitWeight
-
Produces a
SplitWeight
that corresponds to theSplitWeight.standard()
weight proportionally, i.e., a parameter of1.0
will be equivalent to the standard weight and a value of0.5
will be 1/2 of the standard split weight. - fromRawValue(long) - Static method in class io.trino.spi.SplitWeight
-
Produces a
SplitWeight
from the raw internal value representation. - fromSeconds(int, long, long) - Static method in class io.trino.spi.type.SqlTimestamp
- fromSerializable(NullableValue.Serializable) - Static method in class io.trino.spi.predicate.NullableValue
- fromSqlType(String) - Method in interface io.trino.spi.type.TypeManager
-
Gets a type given it's SQL representation
- fromString(String) - Static method in class io.trino.spi.HostAddress
-
Split a freeform string into a host and port, without strict validation.
- fromType() - Element in annotation interface io.trino.spi.function.CastDependency
- fromUri(URI) - Static method in class io.trino.spi.HostAddress
- FULL - Enum constant in enum class io.trino.spi.RefreshType
- FULL - Enum constant in enum class io.trino.spi.resourcegroups.ResourceGroupState
- FULL_OUTER - Enum constant in enum class io.trino.spi.connector.JoinType
- FUNCTION - Enum constant in enum class io.trino.spi.function.InvocationConvention.InvocationArgumentConvention
-
Argument is a lambda function.
- FUNCTION_IMPLEMENTATION_ERROR - Enum constant in enum class io.trino.spi.StandardErrorCode
- FUNCTION_IMPLEMENTATION_MISSING - Enum constant in enum class io.trino.spi.StandardErrorCode
- FUNCTION_NOT_AGGREGATE - Enum constant in enum class io.trino.spi.StandardErrorCode
- FUNCTION_NOT_FOUND - Enum constant in enum class io.trino.spi.StandardErrorCode
- FUNCTION_NOT_WINDOW - Enum constant in enum class io.trino.spi.StandardErrorCode
- FunctionDependencies - Interface in io.trino.spi.function
- FunctionDependency - Annotation Interface in io.trino.spi.function
- FunctionDependencyDeclaration - Class in io.trino.spi.function
- FunctionDependencyDeclaration.CastDependency - Class in io.trino.spi.function
- FunctionDependencyDeclaration.FunctionDependency - Class in io.trino.spi.function
- FunctionDependencyDeclaration.FunctionDependencyDeclarationBuilder - Class in io.trino.spi.function
- FunctionDependencyDeclaration.OperatorDependency - Class in io.trino.spi.function
- functionId(FunctionId) - Method in class io.trino.spi.function.FunctionMetadata.Builder
- FunctionId - Class in io.trino.spi.function
- FunctionId(String) - Constructor for class io.trino.spi.function.FunctionId
- FunctionKind - Enum Class in io.trino.spi.function
- FunctionMetadata - Class in io.trino.spi.function
- FunctionMetadata.Builder - Class in io.trino.spi.function
- FunctionName - Class in io.trino.spi.expression
- FunctionName(String) - Constructor for class io.trino.spi.expression.FunctionName
- FunctionName(Optional<CatalogSchemaName>, String) - Constructor for class io.trino.spi.expression.FunctionName
- FunctionNullability - Class in io.trino.spi.function
- FunctionNullability(boolean, List<Boolean>) - Constructor for class io.trino.spi.function.FunctionNullability
- FunctionProvider - Interface in io.trino.spi.function
- functionType(TypeSignature, TypeSignature...) - Static method in class io.trino.spi.type.TypeSignature
G
- GENERIC_INSUFFICIENT_RESOURCES - Enum constant in enum class io.trino.spi.StandardErrorCode
- GENERIC_INTERNAL_ERROR - Enum constant in enum class io.trino.spi.StandardErrorCode
- GENERIC_TABLE - Static variable in class io.trino.spi.function.table.ReturnTypeSpecification.GenericTable
- GENERIC_USER_ERROR - Enum constant in enum class io.trino.spi.StandardErrorCode
- GEOMETRY - Static variable in class io.trino.spi.type.StandardTypes
- get() - Method in class io.trino.spi.metrics.Metrics.Accumulator
- get(BlockBuilder) - Method in interface io.trino.spi.function.InOut
- getAccessControl() - Method in interface io.trino.spi.connector.Connector
- getAccumulatorStateDescriptors() - Method in class io.trino.spi.function.AggregationImplementation
- getAddresses() - Method in interface io.trino.spi.connector.ConnectorSplit
- getAggregation() - Method in class io.trino.spi.statistics.ColumnStatisticMetadata
- getAggregationFunctionMetadata(ConnectorSession, FunctionId) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Returns the aggregation metadata for the aggregation function with the specified id.
- getAggregationIfPresent() - Method in class io.trino.spi.statistics.ColumnStatisticMetadata
- getAggregationImplementation(FunctionId, BoundSignature, FunctionDependencies) - Method in interface io.trino.spi.function.FunctionProvider
- getAllInetAddresses() - Method in class io.trino.spi.HostAddress
- getAllNodes() - Method in interface io.trino.spi.NodeManager
- getAllocation() - Method in class io.trino.spi.memory.MemoryAllocation
- getAllOrNone() - Method in class io.trino.spi.predicate.AllOrNoneValueSet
- getAnalysisTime() - Method in class io.trino.spi.eventlistener.QueryStatistics
- getAnalyzeProperties() - Method in interface io.trino.spi.connector.Connector
- getArgumentConvention(int) - Method in class io.trino.spi.function.InvocationConvention
- getArgumentConventions() - Method in class io.trino.spi.function.InvocationConvention
- getArgumentCount() - Method in enum class io.trino.spi.function.OperatorType
- getArgumentNullable() - Method in class io.trino.spi.function.FunctionNullability
- getArguments() - Method in class io.trino.spi.connector.AggregateFunction
- getArguments() - Method in class io.trino.spi.expression.Call
- getArguments() - Method in class io.trino.spi.function.table.AbstractConnectorTableFunction
- getArguments() - Method in interface io.trino.spi.function.table.ConnectorTableFunction
- getArgumentType(int) - Method in class io.trino.spi.function.BoundSignature
- getArgumentTypes() - Method in class io.trino.spi.function.BoundSignature
- getArgumentTypes() - Method in class io.trino.spi.function.FunctionDependencyDeclaration.FunctionDependency
- getArgumentTypes() - Method in class io.trino.spi.function.FunctionDependencyDeclaration.OperatorDependency
- getArgumentTypes() - Method in class io.trino.spi.function.Signature
- getArity() - Method in class io.trino.spi.function.BoundSignature
- getArray(int) - Method in class io.trino.spi.block.ArrayBlock
- getAssignments() - Method in class io.trino.spi.connector.AggregationApplicationResult
- getAssignments() - Method in class io.trino.spi.connector.Constraint
- getAssignments() - Method in class io.trino.spi.connector.ProjectionApplicationResult
- getAuthorization() - Method in class io.trino.spi.eventlistener.RoutineInfo
- getAuthorization() - Method in class io.trino.spi.eventlistener.TableInfo
- getAverage() - Method in class io.trino.spi.eventlistener.DoubleSymmetricDistribution
- getAverage() - Method in class io.trino.spi.eventlistener.LongDistribution
- getAverage() - Method in class io.trino.spi.eventlistener.LongSymmetricDistribution
- getAverage() - Method in class io.trino.spi.eventlistener.StageCpuDistribution
- getAverageFullGcSec() - Method in class io.trino.spi.eventlistener.StageGcStatistics
- getBase() - Method in class io.trino.spi.type.TypeSignature
- getBaseName() - Method in interface io.trino.spi.type.Type
-
Returns the base name of this type.
- getBlock() - Method in class io.trino.spi.block.LazyBlock
- getBlock() - Method in class io.trino.spi.predicate.EquatableValueSet.ValueEntry
- getBlock() - Method in class io.trino.spi.predicate.NullableValue.Serializable
- getBlock(int) - Method in class io.trino.spi.Page
- getBlockBuilder(int) - Method in class io.trino.spi.PageBuilder
- getBlockEncodings() - Method in interface io.trino.spi.Plugin
- getBoolean(int) - Method in class io.trino.spi.connector.InMemoryRecordSet.InMemoryRecordCursor
- getBoolean(int) - Method in interface io.trino.spi.connector.RecordCursor
- getBoolean(int, int) - Method in interface io.trino.spi.function.WindowIndex
-
Gets a value as a
boolean
. - getBoolean(Block, int) - Method in class io.trino.spi.type.AbstractType
- getBoolean(Block, int) - Method in class io.trino.spi.type.BooleanType
- getBoolean(Block, int) - Method in interface io.trino.spi.type.Type
-
Gets the value at the
block
position
as a boolean. - getBooleanValue() - Method in interface io.trino.spi.function.InternalDataAccessor
- getBoundedLength() - Method in class io.trino.spi.type.VarcharType
- getBucket(Page, int) - Method in interface io.trino.spi.connector.BucketFunction
-
Gets the bucket for the tuple at the specified position.
- getBucketCount() - Method in class io.trino.spi.connector.ConnectorBucketNodeMap
- getBucketFunction(ConnectorTransactionHandle, ConnectorSession, ConnectorPartitioningHandle, List<Type>, int) - Method in interface io.trino.spi.connector.ConnectorNodePartitioningProvider
- getBucketNodeMapping(ConnectorTransactionHandle, ConnectorSession, ConnectorPartitioningHandle) - Method in interface io.trino.spi.connector.ConnectorNodePartitioningProvider
- getByte(int) - Method in class io.trino.spi.block.ByteArrayBlock
- getByte(Block, int) - Method in class io.trino.spi.type.TinyintType
- getBytes() - Method in class io.trino.spi.type.SqlVarbinary
- getCallingConvention() - Method in class io.trino.spi.function.OperatorMethodHandle
- getCanonicalName() - Method in class io.trino.spi.function.FunctionMetadata
-
The canonical name of the function.
- getCapabilities() - Method in interface io.trino.spi.connector.Connector
- getCastableFrom() - Method in class io.trino.spi.function.TypeVariableConstraint
- getCastableTo() - Method in class io.trino.spi.function.TypeVariableConstraint
- getCastDependencies() - Method in class io.trino.spi.function.FunctionDependencyDeclaration
- getCastImplementation(Type, Type, InvocationConvention) - Method in interface io.trino.spi.function.FunctionDependencies
- getCastImplementationSignature(TypeSignature, TypeSignature, InvocationConvention) - Method in interface io.trino.spi.function.FunctionDependencies
- getCastNullability(Type, Type) - Method in interface io.trino.spi.function.FunctionDependencies
- getCatalog() - Method in class io.trino.spi.connector.ConnectorMaterializedViewDefinition
- getCatalog() - Method in class io.trino.spi.connector.ConnectorViewDefinition
- getCatalog() - Method in class io.trino.spi.eventlistener.ColumnDetail
- getCatalog() - Method in class io.trino.spi.eventlistener.QueryContext
- getCatalog() - Method in class io.trino.spi.eventlistener.TableInfo
- getCatalog() - Method in class io.trino.spi.security.ViewExpression
- getCatalogHandle() - Method in interface io.trino.spi.connector.ConnectorContext
- getCatalogName() - Method in class io.trino.spi.connector.CatalogHandle
-
Gets the actual raw catalog name for this handle.
- getCatalogName() - Method in class io.trino.spi.connector.CatalogSchemaName
- getCatalogName() - Method in class io.trino.spi.connector.CatalogSchemaRoutineName
- getCatalogName() - Method in class io.trino.spi.connector.CatalogSchemaTableName
- getCatalogName() - Method in class io.trino.spi.eventlistener.QueryInputMetadata
- getCatalogName() - Method in class io.trino.spi.eventlistener.QueryOutputMetadata
- getCatalogName() - Method in class io.trino.spi.eventlistener.SplitCompletedEvent
- getCatalogName() - Method in class io.trino.spi.function.CatalogSchemaFunctionName
- getCatalogRoles() - Method in class io.trino.spi.security.Identity
- getCatalogs() - Method in interface io.trino.spi.catalog.CatalogStore
-
Get all catalogs.
- getCatalogSchema() - Method in class io.trino.spi.expression.FunctionName
- getCatalogSessionProperties(SessionConfigurationContext) - Method in interface io.trino.spi.session.SessionPropertyConfigurationManager
- getCatalogStoreFactories() - Method in interface io.trino.spi.Plugin
- getCatalogVersion() - Method in class io.trino.spi.eventlistener.QueryInputMetadata
- getCatalogVersion() - Method in class io.trino.spi.eventlistener.QueryOutputMetadata
- getCertificateAuthenticatorFactories() - Method in interface io.trino.spi.Plugin
- getChannelCount() - Method in class io.trino.spi.Page
- getCheckConstraints() - Method in class io.trino.spi.connector.ConnectorTableMetadata
-
List of constraints data in a table is expected to satisfy.
- getCheckConstraints() - Method in class io.trino.spi.connector.ConnectorTableSchema
-
List of constraints data in a table is expected to satisfy.
- getChildren() - Method in class io.trino.spi.expression.Call
- getChildren() - Method in class io.trino.spi.expression.ConnectorExpression
- getChildren() - Method in class io.trino.spi.expression.Constant
- getChildren() - Method in class io.trino.spi.expression.FieldDereference
- getChildren() - Method in class io.trino.spi.expression.Variable
- getClientCapabilities() - Method in class io.trino.spi.eventlistener.QueryContext
- getClientInfo() - Method in class io.trino.spi.eventlistener.QueryContext
- getClientTags() - Method in class io.trino.spi.eventlistener.QueryContext
- getClientTags() - Method in class io.trino.spi.session.SessionConfigurationContext
- getCode() - Method in class io.trino.spi.ErrorCode
- getCode() - Method in class io.trino.spi.WarningCode
- getColumn() - Method in class io.trino.spi.connector.Assignment
- getColumn() - Method in class io.trino.spi.connector.ConstantProperty
- getColumn() - Method in class io.trino.spi.connector.SortingProperty
- getColumn() - Method in class io.trino.spi.eventlistener.ColumnInfo
- getColumn() - Method in class io.trino.spi.predicate.TupleDomain.ColumnDomain
- getColumnDomains() - Method in class io.trino.spi.predicate.TupleDomain
-
Deprecated.
- getColumnHandles() - Method in class io.trino.spi.connector.TableFunctionApplicationResult
- getColumnHandles(ConnectorSession, ConnectorTableHandle) - Method in interface io.trino.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.trino.spi.connector.ConnectorAccessControl
- getColumnMask(SystemSecurityContext, CatalogSchemaTableName, String, Type) - Method in interface io.trino.spi.security.SystemAccessControl
- getColumnMasks(ConnectorSecurityContext, SchemaTableName, List<ColumnSchema>) - Method in interface io.trino.spi.connector.ConnectorAccessControl
-
Bulk method for getting column masks for a subset of columns in a table.
- getColumnMasks(SystemSecurityContext, CatalogSchemaTableName, List<ColumnSchema>) - Method in interface io.trino.spi.security.SystemAccessControl
-
Bulk method for getting column masks for a subset of columns in a table.
- getColumnMetadata(ConnectorSession, ConnectorTableHandle, ColumnHandle) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Gets the metadata for the specified table column.
- getColumnName() - Method in exception class io.trino.spi.connector.ColumnNotFoundException
- getColumnName() - Method in class io.trino.spi.eventlistener.ColumnDetail
- getColumnName() - Method in class io.trino.spi.eventlistener.OutputColumnMetadata
- getColumnName() - Method in class io.trino.spi.statistics.ColumnStatisticMetadata
- getColumnNumber() - Method in class io.trino.spi.Location
- getColumnProperties() - Method in interface io.trino.spi.connector.Connector
- getColumns() - Method in class io.trino.spi.connector.ConnectorMaterializedViewDefinition
- getColumns() - Method in class io.trino.spi.connector.ConnectorTableMetadata
- getColumns() - Method in class io.trino.spi.connector.ConnectorTableSchema
- getColumns() - Method in class io.trino.spi.connector.ConnectorViewDefinition
- getColumns() - Method in class io.trino.spi.connector.ConstantProperty
- getColumns() - Method in class io.trino.spi.connector.DiscretePredicates
- getColumns() - Method in class io.trino.spi.connector.GroupingProperty
- getColumns() - Method in interface io.trino.spi.connector.LocalProperty
- getColumns() - Method in class io.trino.spi.connector.SortingProperty
- getColumns() - Method in class io.trino.spi.connector.TableColumnsMetadata
- getColumns() - Method in class io.trino.spi.eventlistener.QueryInputMetadata
- getColumns() - Method in class io.trino.spi.eventlistener.QueryOutputMetadata
- getColumns() - Method in class io.trino.spi.eventlistener.TableInfo
- getColumns(int) - Method in class io.trino.spi.Page
- getColumns(int...) - Method in class io.trino.spi.Page
- getColumnSchema() - Method in class io.trino.spi.connector.ColumnMetadata
- getColumnsCovered() - Method in interface io.trino.spi.connector.DynamicFilter
-
Set of keys of a
TupleDomain
to be returned fromDynamicFilter.getCurrentPredicate()
or a superset thereof. - getColumnStatistics() - Method in class io.trino.spi.statistics.ComputedStatistics
- getColumnStatistics() - Method in class io.trino.spi.statistics.TableStatistics
- getColumnStatistics() - Method in class io.trino.spi.statistics.TableStatisticsMetadata
- getColumnType() - Method in class io.trino.spi.eventlistener.OutputColumnMetadata
- getColumnTypes() - Method in class io.trino.spi.connector.InMemoryRecordSet
- getColumnTypes() - Method in interface io.trino.spi.connector.RecordSet
- getCombineFunction() - Method in class io.trino.spi.function.AggregationImplementation
- getComment() - Method in class io.trino.spi.connector.ColumnMetadata
- getComment() - Method in class io.trino.spi.connector.ConnectorMaterializedViewDefinition.Column
- getComment() - Method in class io.trino.spi.connector.ConnectorMaterializedViewDefinition
- getComment() - Method in class io.trino.spi.connector.ConnectorTableMetadata
- getComment() - Method in class io.trino.spi.connector.ConnectorViewDefinition
- getComment() - Method in class io.trino.spi.connector.ConnectorViewDefinition.ViewColumn
- getCommonPartitioningHandle(ConnectorSession, ConnectorPartitioningHandle, ConnectorPartitioningHandle) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Return a partitioning handle which the connector can transparently convert both
left
andright
into. - getComparisonUnorderedFirstOperator(Type, InvocationConvention) - Method in class io.trino.spi.type.TypeOperators
- getComparisonUnorderedFirstOperators() - Method in class io.trino.spi.type.TypeOperatorDeclaration
- getComparisonUnorderedLastOperator(Type, InvocationConvention) - Method in class io.trino.spi.type.TypeOperators
- getComparisonUnorderedLastOperators() - Method in class io.trino.spi.type.TypeOperatorDeclaration
- getCompletedBytes() - Method in interface io.trino.spi.connector.ConnectorPageSink
-
Gets the number of output bytes written by this page source so far.
- getCompletedBytes() - Method in interface io.trino.spi.connector.ConnectorPageSource
-
Gets the number of input bytes processed by this page source so far.
- getCompletedBytes() - Method in class io.trino.spi.connector.EmptyPageSource
- getCompletedBytes() - Method in class io.trino.spi.connector.FixedPageSource
- getCompletedBytes() - Method in class io.trino.spi.connector.InMemoryRecordSet.InMemoryRecordCursor
- getCompletedBytes() - Method in interface io.trino.spi.connector.RecordCursor
-
Gets the number of input bytes processed by this record cursor so far.
- getCompletedBytes() - Method in class io.trino.spi.connector.RecordPageSource
- getCompletedDataSizeBytes() - Method in class io.trino.spi.eventlistener.SplitStatistics
- getCompletedPositions() - Method in interface io.trino.spi.connector.ConnectorPageSource
-
Gets the number of input rows processed by this page source so far.
- getCompletedPositions() - Method in class io.trino.spi.eventlistener.SplitStatistics
- getCompletedReadTime() - Method in class io.trino.spi.eventlistener.SplitStatistics
- getCompletedSplits() - Method in class io.trino.spi.eventlistener.QueryStatistics
- getConnectorAggregationId() - Method in class io.trino.spi.statistics.ColumnStatisticMetadata
- getConnectorFactories() - Method in interface io.trino.spi.Plugin
- getConnectorInfo() - Method in class io.trino.spi.eventlistener.QueryInputMetadata
- getConnectorMetrics() - Method in class io.trino.spi.eventlistener.QueryInputMetadata
- getConnectorOutputMetadata() - Method in class io.trino.spi.eventlistener.QueryOutputMetadata
- getConnectorRole() - Method in class io.trino.spi.security.ConnectorIdentity
- getContext() - Method in class io.trino.spi.eventlistener.QueryCompletedEvent
- getContext() - Method in class io.trino.spi.eventlistener.QueryCreatedEvent
- getContext() - Method in class io.trino.spi.resourcegroups.SelectionContext
- getCpuQuotaGenerationMillisPerSecond() - Method in interface io.trino.spi.resourcegroups.ResourceGroup
- getCpuTime() - Method in class io.trino.spi.eventlistener.QueryStatistics
- getCpuTime() - Method in class io.trino.spi.eventlistener.SplitStatistics
- getCpuTime() - Method in class io.trino.spi.session.ResourceEstimates
- getCpuTimeDistribution() - Method in class io.trino.spi.eventlistener.QueryStatistics
- getCpuTimeDistribution() - Method in class io.trino.spi.eventlistener.StageTaskStatistics
- getCreateTime() - Method in class io.trino.spi.eventlistener.QueryCompletedEvent
- getCreateTime() - Method in class io.trino.spi.eventlistener.QueryCreatedEvent
- getCreateTime() - Method in class io.trino.spi.eventlistener.SplitCompletedEvent
- getCreateTimeMillisDistribution() - Method in class io.trino.spi.eventlistener.StageTaskStatistics
- getCreateTimeScaledDistribution() - Method in class io.trino.spi.eventlistener.StageTaskStatistics
- getCumulativeMemory() - Method in class io.trino.spi.eventlistener.QueryStatistics
- getCurrentNode() - Method in interface io.trino.spi.NodeManager
- getCurrentPredicate() - Method in interface io.trino.spi.connector.DynamicFilter
- getCursor() - Method in class io.trino.spi.connector.RecordPageSource
- getDataProcessor(ConnectorSession, ConnectorTableFunctionHandle) - Method in interface io.trino.spi.function.table.TableFunctionProcessorProvider
-
This method returns a
TableFunctionDataProcessor
. - getDataSize() - Method in class io.trino.spi.connector.BasicRelationStatistics
-
Returns estimated data size.
- getDataSize() - Method in class io.trino.spi.statistics.ColumnStatistics
- getDataSizeInBytes() - Method in interface io.trino.spi.exchange.ExchangeSourceHandle
- getDays() - Method in class io.trino.spi.type.SqlDate
- getDefaultValue() - Method in class io.trino.spi.function.table.ArgumentSpecification
- getDefaultValue() - Method in class io.trino.spi.session.PropertyMetadata
-
Gets the default value for this property.
- getDeletionsPage() - Method in class io.trino.spi.connector.MergePage
- getDescription() - Method in class io.trino.spi.function.FunctionMetadata
- getDescription() - Method in class io.trino.spi.session.PropertyMetadata
-
Description for the end user.
- getDescriptor() - Method in class io.trino.spi.function.table.DescriptorArgument
- getDescriptor() - Method in class io.trino.spi.function.table.ReturnTypeSpecification.DescribedTable
- getDestinationColumns() - Method in class io.trino.spi.connector.TableScanRedirectApplicationResult
- getDestinationTable() - Method in class io.trino.spi.connector.TableScanRedirectApplicationResult
- getDictionary() - Method in class io.trino.spi.block.DictionaryBlock
- getDictionarySourceId() - Method in class io.trino.spi.block.DictionaryBlock
- getDiscretePredicates() - Method in class io.trino.spi.connector.ConnectorTableProperties
-
A collection of discrete predicates describing the data in this layout.
- getDiscreteSet() - Method in class io.trino.spi.predicate.AllOrNoneValueSet
- getDiscreteSet() - Method in class io.trino.spi.predicate.EquatableValueSet
- getDiscreteSet() - Method in class io.trino.spi.predicate.SortedRangeSet
- getDiscreteSet() - Method in interface io.trino.spi.predicate.ValueSet
- getDiscreteSetMarker() - Method in class io.trino.spi.predicate.SortedRangeSet
- getDiscreteValues() - Method in class io.trino.spi.predicate.EquatableValueSet
- getDiscreteValues() - Method in interface io.trino.spi.predicate.ValueSet
- getDiscreteValues(Type.Range) - Method in class io.trino.spi.type.BigintType
- getDiscreteValues(Type.Range) - Method in class io.trino.spi.type.IntegerType
- getDiscreteValues(Type.Range) - Method in class io.trino.spi.type.SmallintType
- getDiscreteValues(Type.Range) - Method in class io.trino.spi.type.TinyintType
- getDiscreteValues(Type.Range) - Method in interface io.trino.spi.type.Type
-
Returns a stream of discrete values inside the specified range (if supported by this type).
- getDisplayName() - Method in class io.trino.spi.type.AbstractType
- getDisplayName() - Method in class io.trino.spi.type.ArrayType
- getDisplayName() - Method in class io.trino.spi.type.MapType
- getDisplayName() - Method in class io.trino.spi.type.RowType
- getDisplayName() - Method in interface io.trino.spi.type.Type
-
Returns the name of this type that should be displayed to end-users.
- getDistinctValuesCount() - Method in class io.trino.spi.statistics.ColumnStatistics
- getDistribution() - Method in interface io.trino.spi.connector.SystemTable
- getDomain() - Method in class io.trino.spi.predicate.TupleDomain.ColumnDomain
- getDomain(T, Type) - Method in class io.trino.spi.predicate.TupleDomain
- getDomains() - Method in class io.trino.spi.predicate.TupleDomain
-
Gets the TupleDomain as a map of each column to its respective Domain
- getDouble(int) - Method in class io.trino.spi.connector.InMemoryRecordSet.InMemoryRecordCursor
- getDouble(int) - Method in interface io.trino.spi.connector.RecordCursor
- getDouble(int, int) - Method in interface io.trino.spi.function.WindowIndex
-
Gets a value as a
double
. - getDouble(Block, int) - Method in class io.trino.spi.type.AbstractType
- getDouble(Block, int) - Method in class io.trino.spi.type.DoubleType
- getDouble(Block, int) - Method in interface io.trino.spi.type.Type
-
Gets the value at the
block
position
as a double. - getDoubleValue() - Method in interface io.trino.spi.function.InternalDataAccessor
- getDuration() - Method in class io.trino.spi.eventlistener.StageOutputBufferUtilization
- getDuration() - Method in interface io.trino.spi.metrics.Timing
- getElementsBlock() - Method in class io.trino.spi.block.ArrayBlock
- getElementsBlock() - Method in class io.trino.spi.block.ColumnarArray
- getElementType() - Method in class io.trino.spi.type.ArrayType
- getEnabledRoles() - Method in class io.trino.spi.eventlistener.QueryContext
- getEnabledRoles() - Method in class io.trino.spi.security.Identity
- getEnabledSystemRoles() - Method in class io.trino.spi.security.ConnectorIdentity
- getEncoding() - Method in class io.trino.spi.eventlistener.QueryMetadata
- getEncodingName() - Method in class io.trino.spi.block.ArrayBlock
- getEncodingName() - Method in interface io.trino.spi.block.Block
-
Get the encoding for this block.
- getEncodingName() - Method in class io.trino.spi.block.ByteArrayBlock
- getEncodingName() - Method in class io.trino.spi.block.DictionaryBlock
- getEncodingName() - Method in class io.trino.spi.block.Fixed12Block
- getEncodingName() - Method in class io.trino.spi.block.Int128ArrayBlock
- getEncodingName() - Method in class io.trino.spi.block.IntArrayBlock
- getEncodingName() - Method in class io.trino.spi.block.LazyBlock
- getEncodingName() - Method in class io.trino.spi.block.LongArrayBlock
- getEncodingName() - Method in class io.trino.spi.block.MapBlock
- getEncodingName() - Method in class io.trino.spi.block.RowBlock
- getEncodingName() - Method in class io.trino.spi.block.RunLengthEncodedBlock
- getEncodingName() - Method in class io.trino.spi.block.ShortArrayBlock
- getEncodingName() - Method in class io.trino.spi.block.VariableWidthBlock
- getEndTime() - Method in class io.trino.spi.eventlistener.QueryCompletedEvent
- getEndTime() - Method in class io.trino.spi.eventlistener.SplitCompletedEvent
- getEndTimeMillisDistribution() - Method in class io.trino.spi.eventlistener.StageTaskStatistics
- getEndTimeScaledDistribution() - Method in class io.trino.spi.eventlistener.StageTaskStatistics
- getEntries() - Method in class io.trino.spi.predicate.EquatableValueSet
- getEntryCount(int) - Method in class io.trino.spi.block.ColumnarMap
- getEnvironment() - Method in class io.trino.spi.eventlistener.QueryContext
- getEnvironment() - Method in interface io.trino.spi.NodeManager
- getEnvironment() - Method in interface io.trino.spi.resourcegroups.ResourceGroupConfigurationManagerContext
- getEnvironment() - Method in interface io.trino.spi.resourcegroups.SessionPropertyConfigurationManagerContext
- getEpochMicros() - Method in class io.trino.spi.type.LongTimestamp
- getEpochMicros() - Method in class io.trino.spi.type.SqlTimestamp
- getEpochMillis() - Method in class io.trino.spi.type.LongTimestampWithTimeZone
- getEpochMillis() - Method in class io.trino.spi.type.SqlTimestampWithTimeZone
- getEqualOperator(Type, InvocationConvention) - Method in class io.trino.spi.type.TypeOperators
- getEqualOperators() - Method in class io.trino.spi.type.TypeOperatorDeclaration
- getErrorCode() - Method in class io.trino.spi.eventlistener.QueryFailureInfo
- getErrorCode() - Method in exception class io.trino.spi.TrinoException
- getEstimatedDataSizeForStats(int) - Method in class io.trino.spi.block.ArrayBlock
- getEstimatedDataSizeForStats(int) - Method in interface io.trino.spi.block.Block
-
Returns the estimated in memory data size for stats of position.
- getEstimatedDataSizeForStats(int) - Method in class io.trino.spi.block.ByteArrayBlock
- getEstimatedDataSizeForStats(int) - Method in class io.trino.spi.block.DictionaryBlock
- getEstimatedDataSizeForStats(int) - Method in class io.trino.spi.block.Fixed12Block
- getEstimatedDataSizeForStats(int) - Method in class io.trino.spi.block.Int128ArrayBlock
- getEstimatedDataSizeForStats(int) - Method in class io.trino.spi.block.IntArrayBlock
- getEstimatedDataSizeForStats(int) - Method in class io.trino.spi.block.LazyBlock
- getEstimatedDataSizeForStats(int) - Method in class io.trino.spi.block.LongArrayBlock
- getEstimatedDataSizeForStats(int) - Method in class io.trino.spi.block.MapBlock
- getEstimatedDataSizeForStats(int) - Method in class io.trino.spi.block.RowBlock
- getEstimatedDataSizeForStats(int) - Method in class io.trino.spi.block.RunLengthEncodedBlock
- getEstimatedDataSizeForStats(int) - Method in class io.trino.spi.block.ShortArrayBlock
- getEstimatedDataSizeForStats(int) - Method in class io.trino.spi.block.VariableWidthBlock
- getEstimatedMemoryReservationDistribution() - Method in class io.trino.spi.eventlistener.StageTaskStatistics
- getEstimatedSize() - Method in interface io.trino.spi.function.AccumulatorState
- getEstimatedSize() - Method in interface io.trino.spi.function.WindowAccumulator
- getEventListenerFactories() - Method in interface io.trino.spi.Plugin
- getEventListeners() - Method in interface io.trino.spi.connector.Connector
- getEventListeners() - Method in interface io.trino.spi.security.SystemAccessControl
- getExchangeId() - Method in interface io.trino.spi.exchange.ExchangeContext
- getExchangeManagerFactories() - Method in interface io.trino.spi.Plugin
- getExecutionMode() - Method in class io.trino.spi.connector.TableProcedureMetadata
- getExecutionStartTime() - Method in class io.trino.spi.eventlistener.QueryCompletedEvent
- getExecutionTime() - Method in class io.trino.spi.eventlistener.QueryStatistics
- getExecutionTime() - Method in class io.trino.spi.session.ResourceEstimates
- getExpression() - Method in class io.trino.spi.connector.Constraint
- getExpression() - Method in class io.trino.spi.function.LongVariableConstraint
- getExpression() - Method in class io.trino.spi.security.ViewExpression
- getExtraCredentials() - Method in class io.trino.spi.security.ConnectorIdentity
- getExtraCredentials() - Method in class io.trino.spi.security.Identity
- getExtraInfo() - Method in class io.trino.spi.connector.ColumnMetadata
- getFactory() - Method in class io.trino.spi.function.AggregationImplementation.AccumulatorStateDescriptor
- getFailedCpuTime() - Method in class io.trino.spi.eventlistener.QueryStatistics
- getFailedCumulativeMemory() - Method in class io.trino.spi.eventlistener.QueryStatistics
- getFailedInputBlockedTime() - Method in class io.trino.spi.eventlistener.QueryStatistics
- getFailedOutputBlockedTime() - Method in class io.trino.spi.eventlistener.QueryStatistics
- getFailedScheduledTime() - Method in class io.trino.spi.eventlistener.QueryStatistics
- getFailureHost() - Method in class io.trino.spi.eventlistener.QueryFailureInfo
- getFailureInfo() - Method in class io.trino.spi.eventlistener.QueryCompletedEvent
- getFailureInfo() - Method in class io.trino.spi.eventlistener.SplitCompletedEvent
- getFailureMessage() - Method in class io.trino.spi.eventlistener.QueryFailureInfo
- getFailureMessage() - Method in class io.trino.spi.eventlistener.SplitFailureInfo
- getFailuresJson() - Method in class io.trino.spi.eventlistener.QueryFailureInfo
- getFailureTask() - Method in class io.trino.spi.eventlistener.QueryFailureInfo
- getFailureType() - Method in class io.trino.spi.eventlistener.QueryFailureInfo
- getFailureType() - Method in class io.trino.spi.eventlistener.SplitFailureInfo
- getField() - Method in class io.trino.spi.expression.FieldDereference
- getFieldBlock(int) - Method in class io.trino.spi.block.RowBlock
- getFieldBlocks() - Method in class io.trino.spi.block.RowBlock
- getFieldCount() - Method in class io.trino.spi.block.SqlRow
- getFieldName() - Method in class io.trino.spi.type.NamedTypeSignature
- getFields() - Method in class io.trino.spi.function.table.Descriptor
- getFields() - Method in class io.trino.spi.type.RowType
- getFilter() - Method in class io.trino.spi.connector.AggregateFunction
- getFilter() - Method in class io.trino.spi.connector.TableScanRedirectApplicationResult
- getFilters() - Method in class io.trino.spi.eventlistener.TableInfo
- getFirstStartTimeMillisDistribution() - Method in class io.trino.spi.eventlistener.StageTaskStatistics
- getFirstStartTimeScaledDistribution() - Method in class io.trino.spi.eventlistener.StageTaskStatistics
- getFixed12First(int) - Method in class io.trino.spi.block.Fixed12Block
- getFixed12Second(int) - Method in class io.trino.spi.block.Fixed12Block
- getFixedMapping() - Method in class io.trino.spi.connector.ConnectorBucketNodeMap
- getFixedSize() - Method in class io.trino.spi.type.AbstractIntType
- getFixedSize() - Method in class io.trino.spi.type.AbstractLongType
- getFixedSize() - Method in class io.trino.spi.type.BooleanType
- getFixedSize() - Method in class io.trino.spi.type.DoubleType
- getFixedSize() - Method in interface io.trino.spi.type.FixedWidthType
-
Gets the size of a value of this type in bytes.
- getFixedSize() - Method in class io.trino.spi.type.SmallintType
- getFixedSize() - Method in class io.trino.spi.type.TinyintType
- getFixedSize() - Method in class io.trino.spi.type.UuidType
- getFlatFixedSize() - Method in class io.trino.spi.type.AbstractIntType
- getFlatFixedSize() - Method in class io.trino.spi.type.AbstractLongType
- getFlatFixedSize() - Method in class io.trino.spi.type.AbstractVariableWidthType
- getFlatFixedSize() - Method in class io.trino.spi.type.ArrayType
- getFlatFixedSize() - Method in class io.trino.spi.type.BooleanType
- getFlatFixedSize() - Method in class io.trino.spi.type.DoubleType
- getFlatFixedSize() - Method in class io.trino.spi.type.MapType
- getFlatFixedSize() - Method in class io.trino.spi.type.RowType
- getFlatFixedSize() - Method in class io.trino.spi.type.SmallintType
- getFlatFixedSize() - Method in class io.trino.spi.type.TinyintType
- getFlatFixedSize() - Method in interface io.trino.spi.type.Type
-
Returns the fixed size of this type when written to a flat buffer.
- getFlatFixedSize() - Method in class io.trino.spi.type.UuidType
- getFlatVariableWidthSize(Block, int) - Method in class io.trino.spi.type.AbstractVariableWidthType
- getFlatVariableWidthSize(Block, int) - Method in class io.trino.spi.type.ArrayType
- getFlatVariableWidthSize(Block, int) - Method in interface io.trino.spi.type.FixedWidthType
- getFlatVariableWidthSize(Block, int) - Method in class io.trino.spi.type.MapType
- getFlatVariableWidthSize(Block, int) - Method in class io.trino.spi.type.RowType
- getFlatVariableWidthSize(Block, int) - Method in interface io.trino.spi.type.Type
-
Returns the variable width size of the value at the specified position when written to a flat buffer.
- getFloat(Block, int) - Method in class io.trino.spi.type.RealType
- getFreeBytes() - Method in class io.trino.spi.memory.MemoryPoolInfo
- getFreshness() - Method in class io.trino.spi.connector.MaterializedViewFreshness
- getFromType() - Method in class io.trino.spi.function.FunctionDependencyDeclaration.CastDependency
- getFullGcTasks() - Method in class io.trino.spi.eventlistener.StageGcStatistics
- getFunctionDependencies() - Method in class io.trino.spi.function.FunctionDependencyDeclaration
- getFunctionDependencies(ConnectorSession, FunctionId, BoundSignature) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Returns the dependencies of the function with the specified id.
- getFunctionId() - Method in class io.trino.spi.function.FunctionMetadata
-
Unique id of this function.
- getFunctionMetadata(ConnectorSession, FunctionId) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Return the function with the specified id.
- getFunctionName() - Method in class io.trino.spi.connector.AggregateFunction
- getFunctionName() - Method in class io.trino.spi.expression.Call
- getFunctionName() - Method in class io.trino.spi.function.CatalogSchemaFunctionName
- getFunctionName() - Method in class io.trino.spi.function.SchemaFunctionName
- getFunctionNullability() - Method in class io.trino.spi.function.FunctionMetadata
- getFunctionNullability(CatalogSchemaFunctionName, List<Type>) - Method in interface io.trino.spi.function.FunctionDependencies
- getFunctionProvider() - Method in interface io.trino.spi.connector.Connector
- getFunctions() - Method in interface io.trino.spi.Plugin
- getFunctions(ConnectorSession, SchemaFunctionName) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Get all functions with specified name.
- getFuture() - Method in class io.trino.spi.function.table.TableFunctionProcessorState.Blocked
- getGetSplitDistribution() - Method in class io.trino.spi.eventlistener.StageTaskStatistics
- getGracePeriod() - Method in class io.trino.spi.connector.ConnectorMaterializedViewDefinition
- getGrantee() - Method in class io.trino.spi.security.GrantInfo
- getGrantee() - Method in class io.trino.spi.security.RoleGrant
- getGrantor() - Method in class io.trino.spi.security.GrantInfo
- getGroupingColumnMapping() - Method in class io.trino.spi.connector.AggregationApplicationResult
- getGroupingColumns() - Method in class io.trino.spi.statistics.ComputedStatistics
- getGroupingColumns() - Method in class io.trino.spi.statistics.TableStatisticsMetadata
- getGroupingValues() - Method in class io.trino.spi.statistics.ComputedStatistics
- getGroupProviderFactories() - Method in interface io.trino.spi.Plugin
- getGroups() - Method in class io.trino.spi.eventlistener.QueryContext
- getGroups() - Method in class io.trino.spi.security.ConnectorIdentity
- getGroups() - Method in class io.trino.spi.security.Identity
- getGroups(String) - Method in interface io.trino.spi.security.GroupProvider
- getHandle() - Method in class io.trino.spi.connector.AggregationApplicationResult
- getHandle() - Method in class io.trino.spi.connector.ConstraintApplicationResult
- getHandle() - Method in class io.trino.spi.connector.LimitApplicationResult
- getHandle() - Method in class io.trino.spi.connector.ProjectionApplicationResult
- getHandle() - Method in class io.trino.spi.connector.SampleApplicationResult
- getHandle() - Method in class io.trino.spi.connector.TopNApplicationResult
- getHandle() - Method in class io.trino.spi.function.table.TableFunctionAnalysis
- getHardConcurrencyLimit() - Method in interface io.trino.spi.resourcegroups.ResourceGroup
- getHardCpuLimit() - Method in interface io.trino.spi.resourcegroups.ResourceGroup
- getHashCodeOperator(Type, InvocationConvention) - Method in class io.trino.spi.type.TypeOperators
- getHashCodeOperators() - Method in class io.trino.spi.type.TypeOperatorDeclaration
- getHeader(String) - Method in interface io.trino.spi.security.HeaderAuthenticator.Headers
- getHeaderAuthenticatorFactories() - Method in interface io.trino.spi.Plugin
- getHigh() - Method in class io.trino.spi.type.Int128
- getHighBoundedValue() - Method in class io.trino.spi.predicate.Range
- getHighValue() - Method in class io.trino.spi.predicate.Range
- getHost() - Method in interface io.trino.spi.Node
- getHostAndPort() - Method in interface io.trino.spi.Node
- getHostText() - Method in class io.trino.spi.HostAddress
-
Returns the portion of this
HostAddress
instance that should represent the hostname or IPv4/IPv6 literal. - getId() - Method in class io.trino.spi.connector.CatalogHandle
-
Gets the unique identifier of this catalog.
- getId() - Method in interface io.trino.spi.connector.ConnectorPageSinkId
- getId() - Method in interface io.trino.spi.exchange.Exchange
-
Get id of this exchange
- getId() - Method in class io.trino.spi.exchange.ExchangeId
- getId() - Method in class io.trino.spi.QueryId
- getId() - Method in interface io.trino.spi.resourcegroups.ResourceGroup
- getId() - Method in class io.trino.spi.type.TimeZoneKey
- getId() - Method in class io.trino.spi.type.TypeId
- getId(int) - Method in class io.trino.spi.block.DictionaryBlock
- getIdenticalOperator(Type, InvocationConvention) - Method in class io.trino.spi.type.TypeOperators
- getIdenticalOperators() - Method in class io.trino.spi.type.TypeOperatorDeclaration
- getIdentity() - Method in class io.trino.spi.connector.ConnectorSecurityContext
- getIdentity() - Method in interface io.trino.spi.connector.ConnectorSession
- getIdentity() - Method in class io.trino.spi.security.SystemSecurityContext
- getInclusive() - Method in class io.trino.spi.predicate.SortedRangeSet
- getIndeterminateOperator(Type, InvocationConvention) - Method in class io.trino.spi.type.TypeOperators
- getIndeterminateOperators() - Method in class io.trino.spi.type.TypeOperatorDeclaration
- getIndex(ConnectorTransactionHandle, ConnectorSession, ConnectorIndexHandle, List<ColumnHandle>, List<ColumnHandle>) - Method in interface io.trino.spi.connector.ConnectorIndexProvider
- getIndexHandle() - Method in class io.trino.spi.connector.ConnectorResolvedIndex
- getIndexProvider() - Method in interface io.trino.spi.connector.Connector
- getInfo() - Method in interface io.trino.spi.connector.ConnectorOutputMetadata
- getInfo(ConnectorTableHandle) - Method in interface io.trino.spi.connector.ConnectorMetadata
- getInitialMemoryRequirement() - Method in interface io.trino.spi.connector.Connector
-
Retrieves the initial memory requirement for the connector.
- getInputBlockedTime() - Method in class io.trino.spi.eventlistener.QueryStatistics
- getInputFunction() - Method in class io.trino.spi.function.AggregationImplementation
- getInputs() - Method in class io.trino.spi.eventlistener.QueryIOMetadata
- getInsertionsPage() - Method in class io.trino.spi.connector.MergePage
- getInsertLayout(ConnectorSession, ConnectorTableHandle) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Get the physical layout for inserting into an existing table.
- getInsertWriterScalingOptions(ConnectorSession, ConnectorTableHandle) - Method in interface io.trino.spi.connector.ConnectorMetadata
- getInstanceFactory() - Method in class io.trino.spi.function.ScalarFunctionImplementation
- getInstanceSizeInBytes(int) - Static method in class io.trino.spi.Page
- getInt(int) - Method in class io.trino.spi.block.IntArrayBlock
- getInt(int, int) - Method in class io.trino.spi.block.Fixed12Block
- getInt(Block, int) - Method in class io.trino.spi.type.AbstractIntType
- getInt128(int) - Method in class io.trino.spi.block.Int128ArrayBlock
- getInt128High(int) - Method in class io.trino.spi.block.Int128ArrayBlock
- getInt128Low(int) - Method in class io.trino.spi.block.Int128ArrayBlock
- getIntermediateTypes() - Method in class io.trino.spi.function.AggregationFunctionMetadata
- getInternalNetworkBytes() - Method in class io.trino.spi.eventlistener.QueryStatistics
- getInternalNetworkRows() - Method in class io.trino.spi.eventlistener.QueryStatistics
- getIoMetadata() - Method in class io.trino.spi.eventlistener.QueryCompletedEvent
- getJavaType() - Method in class io.trino.spi.session.PropertyMetadata
-
Java type of this property.
- getJavaType() - Method in class io.trino.spi.type.AbstractType
- getJavaType() - Method in interface io.trino.spi.type.Type
-
Gets the Java class type used to represent this value on the stack during expression execution.
- getJmxExport() - Method in interface io.trino.spi.resourcegroups.ResourceGroup
- getJoinStatistics() - Method in interface io.trino.spi.connector.JoinStatistics
-
Estimated statistics for join result.
- getJsonLengthLimitExceeded() - Method in class io.trino.spi.eventlistener.QueryOutputMetadata
- getJsonPlan() - Method in class io.trino.spi.eventlistener.QueryMetadata
- getKey() - Method in class io.trino.spi.type.TimeZoneKey
- getKeyBlock() - Method in class io.trino.spi.block.MapBlock
- getKeyBlockEqual() - Method in class io.trino.spi.type.MapType
-
Internal use by this package and io.trino.spi.block only.
- getKeyBlockHashCode() - Method in class io.trino.spi.type.MapType
-
Internal use by this package and io.trino.spi.block only.
- getKeyBlockIdentical() - Method in class io.trino.spi.type.MapType
-
Internal use by this package and io.trino.spi.block only.
- getKeyBlockNativeEqual() - Method in class io.trino.spi.type.MapType
-
Internal use by this package and io.trino.spi.block only.
- getKeyBlockNativeIdentical() - Method in class io.trino.spi.type.MapType
-
Internal use by this package and io.trino.spi.block only.
- getKeyNativeHashCode() - Method in class io.trino.spi.type.MapType
-
Internal use by this package and io.trino.spi.block only.
- getKeysBlock() - Method in class io.trino.spi.block.ColumnarMap
- getKeyType() - Method in class io.trino.spi.type.MapType
- getKind() - Method in class io.trino.spi.function.FunctionMetadata
- getKind() - Method in class io.trino.spi.type.TypeParameter
- getKind() - Method in class io.trino.spi.type.TypeSignatureParameter
- getLambdaInterfaces() - Method in class io.trino.spi.function.AggregationImplementation
- getLambdaInterfaces() - Method in class io.trino.spi.function.ScalarFunctionImplementation
- getLambdaInterfaces() - Method in interface io.trino.spi.function.WindowFunctionSupplier
- getLanguageFunctions(ConnectorSession, SchemaFunctionName) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Get all language functions with the specified name.
- getLastEndTimeMillisDistribution() - Method in class io.trino.spi.eventlistener.StageTaskStatistics
- getLastEndTimeScaledDistribution() - Method in class io.trino.spi.eventlistener.StageTaskStatistics
- getLastFreshTime() - Method in class io.trino.spi.connector.MaterializedViewFreshness
-
Last time when the materialized view was known to be fresh.
- getLastSegment() - Method in class io.trino.spi.resourcegroups.ResourceGroupId
- getLastStartTimeMillisDistribution() - Method in class io.trino.spi.eventlistener.StageTaskStatistics
- getLastStartTimeScaledDistribution() - Method in class io.trino.spi.eventlistener.StageTaskStatistics
- getLayoutForTableExecute(ConnectorSession, ConnectorTableExecuteHandle) - Method in interface io.trino.spi.connector.ConnectorMetadata
- getLeastSignificantBits() - Method in class io.trino.spi.block.DictionaryId
- getLeftColumnHandles() - Method in class io.trino.spi.connector.JoinApplicationResult
- getLeftExpression() - Method in class io.trino.spi.connector.JoinCondition
-
Deprecated.
- getLeftStatistics() - Method in interface io.trino.spi.connector.JoinStatistics
-
Estimated statistics for left join table.
- getLength() - Method in class io.trino.spi.type.CharType
- getLength() - Method in class io.trino.spi.type.VarcharType
- getLength(int) - Method in class io.trino.spi.block.ColumnarArray
- getLessThanOperator(Type, InvocationConvention) - Method in class io.trino.spi.type.TypeOperators
- getLessThanOperators() - Method in class io.trino.spi.type.TypeOperatorDeclaration
- getLessThanOrEqualOperator(Type, InvocationConvention) - Method in class io.trino.spi.type.TypeOperators
- getLessThanOrEqualOperators() - Method in class io.trino.spi.type.TypeOperatorDeclaration
- getLineNumber() - Method in class io.trino.spi.Location
- getLoadedBlock() - Method in class io.trino.spi.block.ArrayBlock
- getLoadedBlock() - Method in interface io.trino.spi.block.Block
-
Returns a fully loaded block that assures all data is in memory.
- getLoadedBlock() - Method in class io.trino.spi.block.DictionaryBlock
- getLoadedBlock() - Method in class io.trino.spi.block.LazyBlock
- getLoadedBlock() - Method in class io.trino.spi.block.MapBlock
- getLoadedBlock() - Method in class io.trino.spi.block.RowBlock
- getLoadedBlock() - Method in class io.trino.spi.block.RunLengthEncodedBlock
- getLoadedPage() - Method in class io.trino.spi.Page
-
Returns a page that assures all data is in memory.
- getLoadedPage(int) - Method in class io.trino.spi.Page
- getLoadedPage(int...) - Method in class io.trino.spi.Page
- getLoadedPage(int[], int[]) - Method in class io.trino.spi.Page
- getLocale() - Method in interface io.trino.spi.connector.ConnectorSession
- getLocalProperties() - Method in class io.trino.spi.connector.ConnectorTableProperties
-
Properties describing the layout of the data (grouping/sorting) within each partition
- getLocation() - Method in exception class io.trino.spi.TrinoException
- getLong(int) - Method in class io.trino.spi.block.LongArrayBlock
- getLong(int) - Method in class io.trino.spi.connector.InMemoryRecordSet.InMemoryRecordCursor
- getLong(int) - Method in interface io.trino.spi.connector.RecordCursor
- getLong(int, int) - Method in interface io.trino.spi.function.WindowIndex
-
Gets a value as a
long
. - getLong(Block, int) - Method in class io.trino.spi.type.AbstractIntType
- getLong(Block, int) - Method in class io.trino.spi.type.AbstractLongType
- getLong(Block, int) - Method in class io.trino.spi.type.AbstractType
- getLong(Block, int) - Method in class io.trino.spi.type.SmallintType
- getLong(Block, int) - Method in class io.trino.spi.type.TinyintType
- getLong(Block, int) - Method in interface io.trino.spi.type.Type
-
Gets the value at the
block
position
as a long. - getLongLiteral() - Method in class io.trino.spi.type.TypeParameter
- getLongLiteral() - Method in class io.trino.spi.type.TypeSignatureParameter
- getLongValue() - Method in interface io.trino.spi.function.InternalDataAccessor
- getLongVariableConstraints() - Method in class io.trino.spi.function.Signature
- getLow() - Method in class io.trino.spi.type.Int128
- getLowBoundedValue() - Method in class io.trino.spi.predicate.Range
- getLowValue() - Method in class io.trino.spi.predicate.Range
- getMap(int) - Method in class io.trino.spi.block.MapBlock
- getMapType() - Method in class io.trino.spi.block.SqlMap
- getMask() - Method in class io.trino.spi.eventlistener.ColumnInfo
- getMaterializedView(ConnectorSession, SchemaTableName) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Gets the materialized view data for the specified materialized view name.
- getMaterializedViewFreshness(ConnectorSession, SchemaTableName) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
The method is used by the engine to determine if a materialized view is current with respect to the tables it depends on.
- getMaterializedViewName() - Method in exception class io.trino.spi.connector.MaterializedViewNotFoundException
- getMaterializedViewProperties() - Method in interface io.trino.spi.connector.Connector
- getMaterializedViewProperties(ConnectorSession, SchemaTableName, ConnectorMaterializedViewDefinition) - Method in interface io.trino.spi.connector.ConnectorMetadata
- getMaterializedViews(ConnectorSession, Optional<String>) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Gets the definitions of materialized views, possibly filtered by schema.
- getMax() - Method in class io.trino.spi.eventlistener.DoubleSymmetricDistribution
- getMax() - Method in class io.trino.spi.eventlistener.LongDistribution
- getMax() - Method in class io.trino.spi.eventlistener.LongSymmetricDistribution
- getMax() - Method in class io.trino.spi.eventlistener.StageCpuDistribution
- getMax() - Method in class io.trino.spi.eventlistener.StageOutputBufferUtilization
- getMax() - Method in interface io.trino.spi.metrics.Distribution
- getMax() - Method in class io.trino.spi.statistics.DoubleRange
- getMax() - Method in class io.trino.spi.type.Type.Range
- getMaxBytes() - Method in class io.trino.spi.memory.MemoryPoolInfo
- getMaxFullGcSec() - Method in class io.trino.spi.eventlistener.StageGcStatistics
- getMaxIndex() - Method in interface io.trino.spi.PageIndexer
-
Returns maximum index value returned.
- getMaxPageSizeInBytes() - Method in class io.trino.spi.block.BlockBuilderStatus
- getMaxPageSizeInBytes() - Method in class io.trino.spi.block.PageBuilderStatus
- getMaxQueuedQueries() - Method in interface io.trino.spi.resourcegroups.ResourceGroup
- getMaxWriterTasks(ConnectorSession) - Method in interface io.trino.spi.connector.ConnectorMetadata
- getMemoryPoolManager() - Method in interface io.trino.spi.resourcegroups.ResourceGroupConfigurationManagerContext
- getMemoryUsage() - Method in interface io.trino.spi.connector.ConnectorPageSink
-
Get the total memory that needs to be reserved in the memory pool.
- getMemoryUsage() - Method in interface io.trino.spi.connector.ConnectorPageSource
-
Get the total memory that needs to be reserved in the memory pool.
- getMemoryUsage() - Method in class io.trino.spi.connector.EmptyPageSource
- getMemoryUsage() - Method in class io.trino.spi.connector.FixedPageSource
- getMemoryUsage() - Method in interface io.trino.spi.connector.RecordCursor
- getMemoryUsage() - Method in class io.trino.spi.connector.RecordPageSource
- getMemoryUsage() - Method in interface io.trino.spi.exchange.ExchangeSink
-
Get the total memory that needs to be reserved in the memory pool.
- getMemoryUsage() - Method in interface io.trino.spi.exchange.ExchangeSource
-
Get the total memory that needs to be reserved in the memory pool.
- getMergeRowIdColumnHandle(ConnectorSession, ConnectorTableHandle) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Get the column handle that will generate row IDs for the merge operation.
- getMessage() - Method in exception class io.trino.spi.TrinoException
- getMessage() - Method in class io.trino.spi.TrinoWarning
- getMetadata() - Method in class io.trino.spi.eventlistener.QueryCompletedEvent
- getMetadata() - Method in class io.trino.spi.eventlistener.QueryCreatedEvent
- getMetadata(ConnectorSession, ConnectorTransactionHandle) - Method in interface io.trino.spi.connector.Connector
-
Guaranteed to be called at most once per transaction.
- getMetadataProvider() - Method in interface io.trino.spi.connector.ConnectorContext
- getMethodHandle() - Method in class io.trino.spi.function.OperatorMethodHandle
- getMethodHandle() - Method in class io.trino.spi.function.ScalarFunctionImplementation
- getMetrics() - Method in interface io.trino.spi.connector.ConnectorPageSource
-
Returns the connector's metrics, mapping a metric ID to its latest value.
- getMetrics() - Method in interface io.trino.spi.exchange.ExchangeSource
-
Get metrics describing ExchangeSource.
- getMetrics() - Method in class io.trino.spi.metrics.Metrics
- getMillis() - Method in class io.trino.spi.type.SqlTimestamp
- getMillisUtc() - Method in class io.trino.spi.type.SqlTimestampWithTimeZone
- getMin() - Method in class io.trino.spi.eventlistener.DoubleSymmetricDistribution
- getMin() - Method in class io.trino.spi.eventlistener.LongDistribution
- getMin() - Method in class io.trino.spi.eventlistener.LongSymmetricDistribution
- getMin() - Method in class io.trino.spi.eventlistener.StageCpuDistribution
- getMin() - Method in class io.trino.spi.eventlistener.StageOutputBufferUtilization
- getMin() - Method in interface io.trino.spi.metrics.Distribution
- getMin() - Method in class io.trino.spi.statistics.DoubleRange
- getMin() - Method in class io.trino.spi.type.Type.Range
- getMinFullGcSec() - Method in class io.trino.spi.eventlistener.StageGcStatistics
- getMostSignificantBits() - Method in class io.trino.spi.block.DictionaryId
- getName() - Method in class io.trino.spi.block.ArrayBlockEncoding
- getName() - Method in interface io.trino.spi.block.BlockEncoding
-
Gets the unique name of this encoding.
- getName() - Method in class io.trino.spi.block.ByteArrayBlockEncoding
- getName() - Method in class io.trino.spi.block.DictionaryBlockEncoding
- getName() - Method in class io.trino.spi.block.Fixed12BlockEncoding
- getName() - Method in class io.trino.spi.block.Int128ArrayBlockEncoding
- getName() - Method in class io.trino.spi.block.IntArrayBlockEncoding
- getName() - Method in class io.trino.spi.block.LazyBlockEncoding
- getName() - Method in class io.trino.spi.block.LongArrayBlockEncoding
- getName() - Method in class io.trino.spi.block.MapBlockEncoding
- getName() - Method in class io.trino.spi.block.RowBlockEncoding
- getName() - Method in class io.trino.spi.block.RunLengthBlockEncoding
- getName() - Method in class io.trino.spi.block.ShortArrayBlockEncoding
- getName() - Method in class io.trino.spi.block.VariableWidthBlockEncoding
- getName() - Method in interface io.trino.spi.catalog.CatalogStoreFactory
- getName() - Method in class io.trino.spi.connector.ColumnMetadata
- getName() - Method in class io.trino.spi.connector.ColumnSchema
- getName() - Method in interface io.trino.spi.connector.ConnectorFactory
- getName() - Method in class io.trino.spi.connector.ConnectorMaterializedViewDefinition.Column
- getName() - Method in class io.trino.spi.connector.ConnectorViewDefinition.ViewColumn
- getName() - Method in class io.trino.spi.connector.SortItem
- getName() - Method in class io.trino.spi.connector.TableProcedureMetadata
- getName() - Method in class io.trino.spi.ErrorCode
- getName() - Method in interface io.trino.spi.eventlistener.EventListenerFactory
- getName() - Method in interface io.trino.spi.exchange.ExchangeManagerFactory
- getName() - Method in class io.trino.spi.expression.FunctionName
- getName() - Method in class io.trino.spi.expression.Variable
- getName() - Method in class io.trino.spi.function.BoundSignature
-
The absolute canonical name of the function.
- getName() - Method in class io.trino.spi.function.FunctionDependencyDeclaration.FunctionDependency
- getName() - Method in class io.trino.spi.function.LongVariableConstraint
- getName() - Method in class io.trino.spi.function.table.AbstractConnectorTableFunction
- getName() - Method in class io.trino.spi.function.table.ArgumentSpecification
- getName() - Method in interface io.trino.spi.function.table.ConnectorTableFunction
- getName() - Method in class io.trino.spi.function.table.Descriptor.Field
- getName() - Method in class io.trino.spi.function.table.NameAndPosition
- getName() - Method in class io.trino.spi.function.TypeVariableConstraint
- getName() - Method in interface io.trino.spi.resourcegroups.ResourceGroupConfigurationManagerFactory
- getName() - Method in class io.trino.spi.security.BasicPrincipal
- getName() - Method in interface io.trino.spi.security.CertificateAuthenticatorFactory
- getName() - Method in interface io.trino.spi.security.GroupProviderFactory
- getName() - Method in interface io.trino.spi.security.HeaderAuthenticatorFactory
- getName() - Method in interface io.trino.spi.security.PasswordAuthenticatorFactory
- getName() - Method in interface io.trino.spi.security.SystemAccessControlFactory
- getName() - Method in class io.trino.spi.security.TrinoPrincipal
- getName() - Method in class io.trino.spi.session.PropertyMetadata
-
Name of the property.
- getName() - Method in interface io.trino.spi.session.SessionPropertyConfigurationManagerFactory
- getName() - Method in class io.trino.spi.type.NamedType
- getName() - Method in class io.trino.spi.type.NamedTypeSignature
- getName() - Method in interface io.trino.spi.type.ParametricType
- getName() - Method in class io.trino.spi.type.QuantileDigestParametricType
- getName() - Method in class io.trino.spi.type.RowFieldName
- getName() - Method in class io.trino.spi.type.RowType.Field
- getName() - Method in class io.trino.spi.type.TimeParametricType
- getName() - Method in class io.trino.spi.type.TimestampParametricType
- getName() - Method in class io.trino.spi.type.TimestampWithTimeZoneParametricType
- getName() - Method in class io.trino.spi.type.TimeWithTimeZoneParametricType
- getName() - Method in class io.trino.spi.WarningCode
- getNamedType() - Method in class io.trino.spi.type.TypeParameter
- getNamedTypeSignature() - Method in class io.trino.spi.type.TypeSignatureParameter
- getNames() - Method in class io.trino.spi.function.FunctionMetadata
-
Canonical name and any aliases.
- getNewTableLayout(ConnectorSession, ConnectorTableMetadata) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Get the physical layout for a new table.
- getNewTableWriterScalingOptions(ConnectorSession, SchemaTableName, Map<String, Object>) - Method in interface io.trino.spi.connector.ConnectorMetadata
- getNextBatch() - Method in interface io.trino.spi.exchange.ExchangeSourceHandleSource
-
Returns a next batch of
ExchangeSourceHandle
s. - getNextBatch(int) - Method in interface io.trino.spi.connector.ConnectorSplitSource
- getNextBatch(int) - Method in class io.trino.spi.connector.FixedSplitSource
- getNextPage() - Method in interface io.trino.spi.connector.ConnectorPageSource
-
Gets the next page of data.
- getNextPage() - Method in class io.trino.spi.connector.EmptyPageSource
- getNextPage() - Method in class io.trino.spi.connector.FixedPageSource
- getNextPage() - Method in class io.trino.spi.connector.RecordPageSource
- getNextValue(Object) - Method in class io.trino.spi.type.BigintType
- getNextValue(Object) - Method in class io.trino.spi.type.DateType
- getNextValue(Object) - Method in class io.trino.spi.type.IntegerType
- getNextValue(Object) - Method in class io.trino.spi.type.SmallintType
- getNextValue(Object) - Method in class io.trino.spi.type.TimeType
- getNextValue(Object) - Method in class io.trino.spi.type.TinyintType
- getNextValue(Object) - Method in interface io.trino.spi.type.Type
-
Returns the minimum value that compares greater than
value
. - getNodeIdentifier() - Method in interface io.trino.spi.Node
- getNodeManager() - Method in interface io.trino.spi.connector.ConnectorContext
- getNodePartitioningProvider() - Method in interface io.trino.spi.connector.Connector
- getNonNullValues() - Method in class io.trino.spi.predicate.Domain.DiscreteSet
- getNullableDiscreteSet() - Method in class io.trino.spi.predicate.Domain
- getNullableSingleValue() - Method in class io.trino.spi.predicate.Domain
- getNullableValue() - Method in class io.trino.spi.function.table.ScalarArgument
- getNulls() - Method in class io.trino.spi.block.ArrayBlock
- getNulls() - Method in class io.trino.spi.block.ByteArrayBlock
- getNulls() - Method in class io.trino.spi.block.Fixed12Block
- getNulls() - Method in class io.trino.spi.block.Int128ArrayBlock
- getNulls() - Method in class io.trino.spi.block.IntArrayBlock
- getNulls() - Method in class io.trino.spi.block.LongArrayBlock
- getNulls() - Method in class io.trino.spi.block.MapBlock
- getNulls() - Method in class io.trino.spi.block.RowBlock
- getNulls() - Method in class io.trino.spi.block.ShortArrayBlock
- getNulls() - Method in interface io.trino.spi.block.ValueBlock
-
Returns a ByteArrayBlock specifying whether the current positions in the Block contain a NULL.
- getNulls() - Method in class io.trino.spi.block.VariableWidthBlock
- getNullsFraction() - Method in class io.trino.spi.statistics.ColumnStatistics
- getNullSuppressedRowFieldsFromBlock(Block) - Static method in class io.trino.spi.block.RowBlock
-
Returns the row fields from the specified block with null rows suppressed.
- getObject() - Method in class io.trino.spi.type.DecimalParseResult
- getObject(int) - Method in class io.trino.spi.connector.InMemoryRecordSet.InMemoryRecordCursor
- getObject(int) - Method in interface io.trino.spi.connector.RecordCursor
- getObject(int, int) - Method in interface io.trino.spi.function.WindowIndex
-
Gets an object value.
- getObject(Block, int) - Method in class io.trino.spi.type.AbstractType
- getObject(Block, int) - Method in class io.trino.spi.type.ArrayType
- getObject(Block, int) - Method in class io.trino.spi.type.MapType
- getObject(Block, int) - Method in class io.trino.spi.type.RowType
- getObject(Block, int) - Method in interface io.trino.spi.type.Type
-
Gets the value at the
block
position
as an Object. - getObjectValue() - Method in interface io.trino.spi.function.InternalDataAccessor
- getObjectValue(ConnectorSession, Block, int) - Method in class io.trino.spi.type.ArrayType
- getObjectValue(ConnectorSession, Block, int) - Method in class io.trino.spi.type.BigintType
- getObjectValue(ConnectorSession, Block, int) - Method in class io.trino.spi.type.BooleanType
- getObjectValue(ConnectorSession, Block, int) - Method in class io.trino.spi.type.CharType
- getObjectValue(ConnectorSession, Block, int) - Method in class io.trino.spi.type.DateType
- getObjectValue(ConnectorSession, Block, int) - Method in class io.trino.spi.type.DoubleType
- getObjectValue(ConnectorSession, Block, int) - Method in class io.trino.spi.type.HyperLogLogType
- getObjectValue(ConnectorSession, Block, int) - Method in class io.trino.spi.type.IntegerType
- getObjectValue(ConnectorSession, Block, int) - Method in class io.trino.spi.type.MapType
- getObjectValue(ConnectorSession, Block, int) - Method in class io.trino.spi.type.P4HyperLogLogType
- getObjectValue(ConnectorSession, Block, int) - Method in class io.trino.spi.type.QuantileDigestType
- getObjectValue(ConnectorSession, Block, int) - Method in class io.trino.spi.type.RealType
- getObjectValue(ConnectorSession, Block, int) - Method in class io.trino.spi.type.RowType
- getObjectValue(ConnectorSession, Block, int) - Method in class io.trino.spi.type.SmallintType
- getObjectValue(ConnectorSession, Block, int) - Method in class io.trino.spi.type.TimeType
- getObjectValue(ConnectorSession, Block, int) - Method in class io.trino.spi.type.TinyintType
- getObjectValue(ConnectorSession, Block, int) - Method in interface io.trino.spi.type.Type
-
Gets an object representation of the type value in the
block
position
. - getObjectValue(ConnectorSession, Block, int) - Method in class io.trino.spi.type.UuidType
- getObjectValue(ConnectorSession, Block, int) - Method in class io.trino.spi.type.VarbinaryType
- getObjectValue(ConnectorSession, Block, int) - Method in class io.trino.spi.type.VarcharType
- getOffset(int) - Method in class io.trino.spi.block.ColumnarArray
- getOffset(int) - Method in class io.trino.spi.block.ColumnarMap
- getOffsetMinutes() - Method in class io.trino.spi.type.LongTimeWithTimeZone
- getOffsetMinutes() - Method in class io.trino.spi.type.SqlTimeWithTimeZone
- getOpenTelemetry() - Method in interface io.trino.spi.connector.ConnectorContext
- getOpenTelemetry() - Method in interface io.trino.spi.exchange.ExchangeManagerContext
- getOpenTelemetry() - Method in interface io.trino.spi.security.SystemAccessControlFactory.SystemAccessControlContext
- getOperator() - Method in class io.trino.spi.connector.JoinCondition
-
Deprecated.
- getOperator() - Method in enum class io.trino.spi.function.OperatorType
- getOperatorDependencies() - Method in class io.trino.spi.function.FunctionDependencyDeclaration
- getOperatorImplementation(OperatorType, List<Type>, InvocationConvention) - Method in interface io.trino.spi.function.FunctionDependencies
- getOperatorImplementationSignature(OperatorType, List<TypeSignature>, InvocationConvention) - Method in interface io.trino.spi.function.FunctionDependencies
- getOperatorNullability(OperatorType, List<Type>) - Method in interface io.trino.spi.function.FunctionDependencies
- getOperatorSummaries() - Method in class io.trino.spi.eventlistener.QueryStatistics
- getOperatorType() - Method in class io.trino.spi.function.FunctionDependencyDeclaration.OperatorDependency
- getOptimizerRulesSummaries() - Method in class io.trino.spi.eventlistener.QueryStatistics
- getOrder() - Method in class io.trino.spi.connector.SortingProperty
- getOrderBy() - Method in class io.trino.spi.function.table.TableArgument
- getOrderedRanges() - Method in interface io.trino.spi.predicate.Ranges
- getOrderedRanges() - Method in class io.trino.spi.predicate.SortedRangeSet
- getOrderingOperator(Type, SortOrder, InvocationConvention) - Method in class io.trino.spi.type.TypeOperators
- getOriginalSql() - Method in class io.trino.spi.connector.ConnectorMaterializedViewDefinition
- getOriginalSql() - Method in class io.trino.spi.connector.ConnectorViewDefinition
- getOriginalUser() - Method in class io.trino.spi.eventlistener.QueryContext
- getOutput() - Method in class io.trino.spi.eventlistener.QueryIOMetadata
- getOutputBlockedTime() - Method in class io.trino.spi.eventlistener.QueryStatistics
- getOutputBufferUtilization() - Method in class io.trino.spi.eventlistener.QueryStatistics
- getOutputBytes() - Method in class io.trino.spi.eventlistener.QueryStatistics
- getOutputDataSizeDistribution() - Method in class io.trino.spi.eventlistener.StageTaskStatistics
- getOutputFunction() - Method in class io.trino.spi.function.AggregationImplementation
- getOutputPositionsDistribution() - Method in class io.trino.spi.eventlistener.StageTaskStatistics
- getOutputRows() - Method in class io.trino.spi.eventlistener.QueryStatistics
- getOutputType() - Method in class io.trino.spi.connector.AggregateFunction
- getOwner() - Method in class io.trino.spi.connector.ConnectorMaterializedViewDefinition
- getOwner() - Method in class io.trino.spi.connector.ConnectorViewDefinition
- getP01() - Method in class io.trino.spi.eventlistener.DoubleSymmetricDistribution
- getP01() - Method in class io.trino.spi.eventlistener.LongSymmetricDistribution
- getP01() - Method in class io.trino.spi.eventlistener.StageOutputBufferUtilization
- getP05() - Method in class io.trino.spi.eventlistener.DoubleSymmetricDistribution
- getP05() - Method in class io.trino.spi.eventlistener.LongSymmetricDistribution
- getP05() - Method in class io.trino.spi.eventlistener.StageOutputBufferUtilization
- getP10() - Method in class io.trino.spi.eventlistener.DoubleSymmetricDistribution
- getP10() - Method in class io.trino.spi.eventlistener.LongSymmetricDistribution
- getP10() - Method in class io.trino.spi.eventlistener.StageOutputBufferUtilization
- getP25() - Method in class io.trino.spi.eventlistener.DoubleSymmetricDistribution
- getP25() - Method in class io.trino.spi.eventlistener.LongDistribution
- getP25() - Method in class io.trino.spi.eventlistener.LongSymmetricDistribution
- getP25() - Method in class io.trino.spi.eventlistener.StageCpuDistribution
- getP25() - Method in class io.trino.spi.eventlistener.StageOutputBufferUtilization
- getP50() - Method in class io.trino.spi.eventlistener.DoubleSymmetricDistribution
- getP50() - Method in class io.trino.spi.eventlistener.LongDistribution
- getP50() - Method in class io.trino.spi.eventlistener.LongSymmetricDistribution
- getP50() - Method in class io.trino.spi.eventlistener.StageCpuDistribution
- getP50() - Method in class io.trino.spi.eventlistener.StageOutputBufferUtilization
- getP75() - Method in class io.trino.spi.eventlistener.DoubleSymmetricDistribution
- getP75() - Method in class io.trino.spi.eventlistener.LongDistribution
- getP75() - Method in class io.trino.spi.eventlistener.LongSymmetricDistribution
- getP75() - Method in class io.trino.spi.eventlistener.StageCpuDistribution
- getP75() - Method in class io.trino.spi.eventlistener.StageOutputBufferUtilization
- getP90() - Method in class io.trino.spi.eventlistener.DoubleSymmetricDistribution
- getP90() - Method in class io.trino.spi.eventlistener.LongDistribution
- getP90() - Method in class io.trino.spi.eventlistener.LongSymmetricDistribution
- getP90() - Method in class io.trino.spi.eventlistener.StageCpuDistribution
- getP90() - Method in class io.trino.spi.eventlistener.StageOutputBufferUtilization
- getP95() - Method in class io.trino.spi.eventlistener.DoubleSymmetricDistribution
- getP95() - Method in class io.trino.spi.eventlistener.LongDistribution
- getP95() - Method in class io.trino.spi.eventlistener.LongSymmetricDistribution
- getP95() - Method in class io.trino.spi.eventlistener.StageCpuDistribution
- getP95() - Method in class io.trino.spi.eventlistener.StageOutputBufferUtilization
- getP99() - Method in class io.trino.spi.eventlistener.DoubleSymmetricDistribution
- getP99() - Method in class io.trino.spi.eventlistener.LongDistribution
- getP99() - Method in class io.trino.spi.eventlistener.LongSymmetricDistribution
- getP99() - Method in class io.trino.spi.eventlistener.StageCpuDistribution
- getP99() - Method in class io.trino.spi.eventlistener.StageOutputBufferUtilization
- getPageIndexerFactory() - Method in interface io.trino.spi.connector.ConnectorContext
- getPageSinkProvider() - Method in interface io.trino.spi.connector.Connector
- getPageSorter() - Method in interface io.trino.spi.connector.ConnectorContext
- getPageSourceProvider() - Method in interface io.trino.spi.connector.Connector
- getPageSourceProviderFactory() - Method in interface io.trino.spi.connector.Connector
-
Provide a pageSourceProviderFactory to create stateful instances of PageSourceProvider per query.
- getParameterCount() - Method in enum class io.trino.spi.function.InvocationConvention.InvocationArgumentConvention
- getParameterCount() - Method in enum class io.trino.spi.function.InvocationConvention.InvocationReturnConvention
- getParameterizedType(String, List<TypeSignatureParameter>) - Method in interface io.trino.spi.type.TypeManager
-
Gets the type with the specified base type and the given parameters.
- getParameters() - Method in class io.trino.spi.type.TypeSignature
- getParametricTypes() - Method in interface io.trino.spi.Plugin
- getParent() - Method in class io.trino.spi.resourcegroups.ResourceGroupId
- getParentSpan() - Method in interface io.trino.spi.exchange.ExchangeContext
- getPartitionBy() - Method in class io.trino.spi.function.table.TableArgument
- getPartitionColumns() - Method in class io.trino.spi.connector.ConnectorTableLayout
- getPartitionId() - Method in interface io.trino.spi.exchange.ExchangeSourceHandle
- getPartitioning() - Method in class io.trino.spi.connector.ConnectorTableLayout
- getPartitioningColumns() - Method in class io.trino.spi.connector.ConnectorTablePartitioning
-
The columns used to partition the table across the worker nodes.
- getPartitioningHandle() - Method in class io.trino.spi.connector.ConnectorTablePartitioning
-
A handle to the partitioning scheme used to divide the table across worker nodes.
- getPasswordAuthenticatorFactories() - Method in interface io.trino.spi.Plugin
- getPath() - Method in class io.trino.spi.connector.ConnectorMaterializedViewDefinition
- getPath() - Method in class io.trino.spi.connector.ConnectorViewDefinition
- getPath() - Method in class io.trino.spi.security.ViewExpression
- getPayload() - Method in class io.trino.spi.eventlistener.QueryMetadata
- getPayload() - Method in class io.trino.spi.eventlistener.SplitCompletedEvent
- getPeakMemoryBytes() - Method in class io.trino.spi.session.ResourceEstimates
- getPeakMemoryReservationDistribution() - Method in class io.trino.spi.eventlistener.StageTaskStatistics
- getPeakTaskTotalMemory() - Method in class io.trino.spi.eventlistener.QueryStatistics
- getPeakTaskUserMemory() - Method in class io.trino.spi.eventlistener.QueryStatistics
- getPeakUserMemoryBytes() - Method in class io.trino.spi.eventlistener.QueryStatistics
- getPercentile(double) - Method in interface io.trino.spi.metrics.Distribution
- getPhysicalInputBytes() - Method in class io.trino.spi.eventlistener.QueryInputMetadata
- getPhysicalInputBytes() - Method in class io.trino.spi.eventlistener.QueryStatistics
- getPhysicalInputReadTime() - Method in class io.trino.spi.eventlistener.QueryStatistics
- getPhysicalInputRows() - Method in class io.trino.spi.eventlistener.QueryInputMetadata
- getPhysicalInputRows() - Method in class io.trino.spi.eventlistener.QueryStatistics
- getPicos() - Method in class io.trino.spi.type.SqlTime
- getPicos() - Method in class io.trino.spi.type.SqlTimeWithTimeZone
- getPicoseconds() - Method in class io.trino.spi.type.LongTimeWithTimeZone
- getPicosOfMicro() - Method in class io.trino.spi.type.LongTimestamp
- getPicosOfMicros() - Method in class io.trino.spi.type.SqlTimestamp
- getPicosOfMilli() - Method in class io.trino.spi.type.LongTimestampWithTimeZone
- getPicosOfMilli() - Method in class io.trino.spi.type.SqlTimestampWithTimeZone
- getPlan() - Method in class io.trino.spi.eventlistener.QueryMetadata
- getPlanningCpuTime() - Method in class io.trino.spi.eventlistener.QueryStatistics
- getPlanningTime() - Method in class io.trino.spi.eventlistener.QueryStatistics
- getPlanNodeStatsAndCosts() - Method in class io.trino.spi.eventlistener.QueryStatistics
- getPointerType() - Method in class io.trino.spi.connector.ConnectorTableVersion
- getPort() - Method in class io.trino.spi.HostAddress
-
Get the current port number, failing if no port is defined.
- getPortOrDefault(int) - Method in class io.trino.spi.HostAddress
-
Returns the current port number, with a default if no port is defined.
- getPosition() - Method in class io.trino.spi.function.table.NameAndPosition
- getPositionCount() - Method in class io.trino.spi.block.ArrayBlock
- getPositionCount() - Method in class io.trino.spi.block.ArrayBlockBuilder
- getPositionCount() - Method in interface io.trino.spi.block.Block
-
Returns the number of positions in this block.
- getPositionCount() - Method in interface io.trino.spi.block.BlockBuilder
-
Returns the number of positions in this block builder.
- getPositionCount() - Method in class io.trino.spi.block.ByteArrayBlock
- getPositionCount() - Method in class io.trino.spi.block.ByteArrayBlockBuilder
- getPositionCount() - Method in class io.trino.spi.block.ColumnarArray
- getPositionCount() - Method in class io.trino.spi.block.ColumnarMap
- getPositionCount() - Method in class io.trino.spi.block.DictionaryBlock
- getPositionCount() - Method in class io.trino.spi.block.Fixed12Block
- getPositionCount() - Method in class io.trino.spi.block.Fixed12BlockBuilder
- getPositionCount() - Method in class io.trino.spi.block.Int128ArrayBlock
- getPositionCount() - Method in class io.trino.spi.block.Int128ArrayBlockBuilder
- getPositionCount() - Method in class io.trino.spi.block.IntArrayBlock
- getPositionCount() - Method in class io.trino.spi.block.IntArrayBlockBuilder
- getPositionCount() - Method in class io.trino.spi.block.LazyBlock
- getPositionCount() - Method in class io.trino.spi.block.LongArrayBlock
- getPositionCount() - Method in class io.trino.spi.block.LongArrayBlockBuilder
- getPositionCount() - Method in class io.trino.spi.block.MapBlock
- getPositionCount() - Method in class io.trino.spi.block.MapBlockBuilder
- getPositionCount() - Method in class io.trino.spi.block.RowBlock
- getPositionCount() - Method in class io.trino.spi.block.RowBlockBuilder
- getPositionCount() - Method in class io.trino.spi.block.RunLengthEncodedBlock
-
Position count will always be at least 2
- getPositionCount() - Method in class io.trino.spi.block.ShortArrayBlock
- getPositionCount() - Method in class io.trino.spi.block.ShortArrayBlockBuilder
- getPositionCount() - Method in class io.trino.spi.block.VariableWidthBlock
- getPositionCount() - Method in class io.trino.spi.block.VariableWidthBlockBuilder
- getPositionCount() - Method in class io.trino.spi.Page
- getPositionCount() - Method in class io.trino.spi.PageBuilder
- getPositions(int[], int, int) - Method in interface io.trino.spi.block.Block
-
Create a new block from the current block by keeping the same elements only with respect to
positions
that starts atoffset
and has length oflength
. - getPositions(int[], int, int) - Method in class io.trino.spi.block.DictionaryBlock
- getPositions(int[], int, int) - Method in class io.trino.spi.block.LazyBlock
- getPositions(int[], int, int) - Method in class io.trino.spi.block.RunLengthEncodedBlock
- getPositions(int[], int, int) - Method in class io.trino.spi.Page
- getPositionsSizeInBytes(boolean[], int) - Method in class io.trino.spi.block.ArrayBlock
- getPositionsSizeInBytes(boolean[], int) - Method in interface io.trino.spi.block.Block
-
Returns the size of all positions marked true in the positions array.
- getPositionsSizeInBytes(boolean[], int) - Method in class io.trino.spi.block.ByteArrayBlock
- getPositionsSizeInBytes(boolean[], int) - Method in class io.trino.spi.block.DictionaryBlock
- getPositionsSizeInBytes(boolean[], int) - Method in class io.trino.spi.block.Fixed12Block
- getPositionsSizeInBytes(boolean[], int) - Method in class io.trino.spi.block.Int128ArrayBlock
- getPositionsSizeInBytes(boolean[], int) - Method in class io.trino.spi.block.IntArrayBlock
- getPositionsSizeInBytes(boolean[], int) - Method in class io.trino.spi.block.LazyBlock
- getPositionsSizeInBytes(boolean[], int) - Method in class io.trino.spi.block.LongArrayBlock
- getPositionsSizeInBytes(boolean[], int) - Method in class io.trino.spi.block.MapBlock
- getPositionsSizeInBytes(boolean[], int) - Method in class io.trino.spi.block.RowBlock
- getPositionsSizeInBytes(boolean[], int) - Method in class io.trino.spi.block.RunLengthEncodedBlock
- getPositionsSizeInBytes(boolean[], int) - Method in class io.trino.spi.block.ShortArrayBlock
- getPositionsSizeInBytes(boolean[], int) - Method in class io.trino.spi.block.VariableWidthBlock
- getPrecision() - Method in class io.trino.spi.type.DecimalType
- getPrecision() - Method in class io.trino.spi.type.SqlDecimal
- getPrecision() - Method in class io.trino.spi.type.SqlTimestamp
- getPrecision() - Method in class io.trino.spi.type.SqlTimestampWithTimeZone
- getPrecision() - Method in class io.trino.spi.type.TimestampType
- getPrecision() - Method in class io.trino.spi.type.TimestampWithTimeZoneType
- getPrecision() - Method in class io.trino.spi.type.TimeType
- getPrecision() - Method in class io.trino.spi.type.TimeWithTimeZoneType
- getPredicate() - Method in class io.trino.spi.connector.ConnectorTableProperties
-
A TupleDomain that represents a predicate that every row in this table satisfies.
- getPredicateColumns() - Method in class io.trino.spi.connector.Constraint
-
Set of columns the
Constraint.predicate()
result depends on. - getPredicates() - Method in class io.trino.spi.connector.DiscretePredicates
- getPreparedQuery() - Method in class io.trino.spi.eventlistener.QueryMetadata
- getPreviousValue(Object) - Method in class io.trino.spi.type.BigintType
- getPreviousValue(Object) - Method in class io.trino.spi.type.DateType
- getPreviousValue(Object) - Method in class io.trino.spi.type.IntegerType
- getPreviousValue(Object) - Method in class io.trino.spi.type.SmallintType
- getPreviousValue(Object) - Method in class io.trino.spi.type.TimeType
- getPreviousValue(Object) - Method in class io.trino.spi.type.TinyintType
- getPreviousValue(Object) - Method in interface io.trino.spi.type.Type
-
Returns the maximum value that compares less than
value
. - getPrincipal() - Method in class io.trino.spi.eventlistener.QueryContext
- getPrincipal() - Method in class io.trino.spi.security.ConnectorIdentity
- getPrincipal() - Method in class io.trino.spi.security.Identity
- getPrivilege() - Method in class io.trino.spi.security.PrivilegeInfo
- getPrivilegeInfo() - Method in class io.trino.spi.security.GrantInfo
- getProcedures() - Method in interface io.trino.spi.connector.Connector
- getProcessedInputBytes() - Method in class io.trino.spi.eventlistener.QueryStatistics
- getProcessedInputDataSizeDistribution() - Method in class io.trino.spi.eventlistener.StageTaskStatistics
- getProcessedInputPositionsDistribution() - Method in class io.trino.spi.eventlistener.StageTaskStatistics
- getProcessedInputRows() - Method in class io.trino.spi.eventlistener.QueryStatistics
- getProjections() - Method in class io.trino.spi.connector.AggregationApplicationResult
- getProjections() - Method in class io.trino.spi.connector.ProjectionApplicationResult
- getProperties() - Method in class io.trino.spi.connector.ColumnMetadata
- getProperties() - Method in class io.trino.spi.connector.ConnectorTableMetadata
- getProperties() - Method in class io.trino.spi.connector.TableProcedureMetadata
- getProperty(String, Class<T>) - Method in interface io.trino.spi.connector.ConnectorSession
- getQuery() - Method in class io.trino.spi.eventlistener.QueryMetadata
- getQueryId() - Method in class io.trino.spi.connector.ConnectorSecurityContext
- getQueryId() - Method in interface io.trino.spi.connector.ConnectorSession
- getQueryId() - Method in class io.trino.spi.eventlistener.QueryMetadata
- getQueryId() - Method in class io.trino.spi.eventlistener.SplitCompletedEvent
- getQueryId() - Method in interface io.trino.spi.exchange.ExchangeContext
- getQueryId() - Method in class io.trino.spi.security.SystemSecurityContext
- getQueryMemoryAllocations() - Method in class io.trino.spi.memory.MemoryPoolInfo
- getQueryMemoryReservations() - Method in class io.trino.spi.memory.MemoryPoolInfo
- getQueryMemoryRevocableReservations() - Method in class io.trino.spi.memory.MemoryPoolInfo
- getQueryStart() - Method in class io.trino.spi.security.SystemSecurityContext
- getQueryState() - Method in class io.trino.spi.eventlistener.QueryMetadata
- getQueryType() - Method in class io.trino.spi.eventlistener.QueryContext
- getQueryType() - Method in class io.trino.spi.resourcegroups.SelectionCriteria
- getQueryType() - Method in class io.trino.spi.session.SessionConfigurationContext
- getQueuedTime() - Method in class io.trino.spi.eventlistener.QueryStatistics
- getQueuedTime() - Method in class io.trino.spi.eventlistener.SplitStatistics
- getRange() - Method in class io.trino.spi.statistics.ColumnStatistics
- getRange() - Method in class io.trino.spi.type.BigintType
- getRange() - Method in class io.trino.spi.type.CharType
- getRange() - Method in class io.trino.spi.type.DateType
- getRange() - Method in class io.trino.spi.type.DoubleType
- getRange() - Method in class io.trino.spi.type.IntegerType
- getRange() - Method in class io.trino.spi.type.RealType
- getRange() - Method in class io.trino.spi.type.SmallintType
- getRange() - Method in class io.trino.spi.type.TimeType
- getRange() - Method in class io.trino.spi.type.TinyintType
- getRange() - Method in interface io.trino.spi.type.Type
-
Return the range of possible values for this type, if available.
- getRange() - Method in class io.trino.spi.type.VarcharType
- getRangeCount() - Method in interface io.trino.spi.predicate.Ranges
- getRangeCount() - Method in class io.trino.spi.predicate.SortedRangeSet
- getRanges() - Method in class io.trino.spi.predicate.SortedRangeSet
- getRanges() - Method in interface io.trino.spi.predicate.ValueSet
- getRawFieldBlock(int) - Method in class io.trino.spi.block.SqlRow
- getRawFieldBlocks() - Method in class io.trino.spi.block.SqlRow
- getRawIds() - Method in class io.trino.spi.block.DictionaryBlock
- getRawIdsOffset() - Method in class io.trino.spi.block.DictionaryBlock
- getRawIndex() - Method in class io.trino.spi.block.SqlRow
- getRawInputDataSizeDistribution() - Method in class io.trino.spi.eventlistener.StageTaskStatistics
- getRawInputPositionsDistribution() - Method in class io.trino.spi.eventlistener.StageTaskStatistics
- getRawKeyBlock() - Method in class io.trino.spi.block.SqlMap
- getRawMessage() - Method in exception class io.trino.spi.TrinoException
- getRawOffset() - Method in class io.trino.spi.block.SqlMap
- getRawSlice() - Method in class io.trino.spi.block.VariableWidthBlock
-
Gets the raw
Slice
that keeps the actual data bytes. - getRawSliceOffset(int) - Method in class io.trino.spi.block.VariableWidthBlock
-
Gets the offset of the value at the
position
in theSlice
returned byVariableWidthBlock.getRawSlice()
. - getRawValue() - Method in class io.trino.spi.SplitWeight
- getRawValueBlock() - Method in class io.trino.spi.block.SqlMap
- getRawValues() - Method in class io.trino.spi.block.ByteArrayBlock
-
Gets the raw byte array that keeps the actual data values.
- getRawValues() - Method in class io.trino.spi.block.IntArrayBlock
- getRawValuesOffset() - Method in class io.trino.spi.block.ByteArrayBlock
-
Gets the offset into raw byte array where the data values start.
- getRawValuesOffset() - Method in class io.trino.spi.block.IntArrayBlock
- getReadTimeNanos() - Method in interface io.trino.spi.connector.ConnectorPageSource
-
Gets the wall time this page source spent reading data from the input.
- getReadTimeNanos() - Method in class io.trino.spi.connector.EmptyPageSource
- getReadTimeNanos() - Method in class io.trino.spi.connector.FixedPageSource
- getReadTimeNanos() - Method in class io.trino.spi.connector.InMemoryRecordSet.InMemoryRecordCursor
- getReadTimeNanos() - Method in interface io.trino.spi.connector.RecordCursor
-
Gets the wall time spent reading data.
- getReadTimeNanos() - Method in class io.trino.spi.connector.RecordPageSource
- getReadValueOperator(Type, InvocationConvention) - Method in class io.trino.spi.type.TypeOperators
- getReadValueOperators() - Method in class io.trino.spi.type.TypeOperatorDeclaration
- getRecordSet(ConnectorTransactionHandle, ConnectorSession, ConnectorSplit, ConnectorTableHandle, List<? extends ColumnHandle>) - Method in interface io.trino.spi.connector.ConnectorRecordSetProvider
- getRecordSetProvider() - Method in interface io.trino.spi.connector.Connector
- getReferenceChain() - Method in class io.trino.spi.eventlistener.TableInfo
-
Get the reference chain for this table.
- getRegion(int, int) - Method in class io.trino.spi.block.ArrayBlock
- getRegion(int, int) - Method in interface io.trino.spi.block.Block
-
Returns a block starting at the specified position and extends for the specified length.
- getRegion(int, int) - Method in class io.trino.spi.block.ByteArrayBlock
- getRegion(int, int) - Method in class io.trino.spi.block.DictionaryBlock
- getRegion(int, int) - Method in class io.trino.spi.block.Fixed12Block
- getRegion(int, int) - Method in class io.trino.spi.block.Int128ArrayBlock
- getRegion(int, int) - Method in class io.trino.spi.block.IntArrayBlock
- getRegion(int, int) - Method in class io.trino.spi.block.LazyBlock
- getRegion(int, int) - Method in class io.trino.spi.block.LongArrayBlock
- getRegion(int, int) - Method in class io.trino.spi.block.MapBlock
- getRegion(int, int) - Method in class io.trino.spi.block.RowBlock
- getRegion(int, int) - Method in class io.trino.spi.block.RunLengthEncodedBlock
- getRegion(int, int) - Method in class io.trino.spi.block.ShortArrayBlock
- getRegion(int, int) - Method in interface io.trino.spi.block.ValueBlock
- getRegion(int, int) - Method in class io.trino.spi.block.VariableWidthBlock
- getRegion(int, int) - Method in class io.trino.spi.Page
- getRegionSizeInBytes(int, int) - Method in class io.trino.spi.block.ArrayBlock
- getRegionSizeInBytes(int, int) - Method in interface io.trino.spi.block.Block
-
Returns the size of
block.getRegion(position, length)
. - getRegionSizeInBytes(int, int) - Method in class io.trino.spi.block.ByteArrayBlock
- getRegionSizeInBytes(int, int) - Method in class io.trino.spi.block.DictionaryBlock
- getRegionSizeInBytes(int, int) - Method in class io.trino.spi.block.Fixed12Block
- getRegionSizeInBytes(int, int) - Method in class io.trino.spi.block.Int128ArrayBlock
- getRegionSizeInBytes(int, int) - Method in class io.trino.spi.block.IntArrayBlock
- getRegionSizeInBytes(int, int) - Method in class io.trino.spi.block.LazyBlock
- getRegionSizeInBytes(int, int) - Method in class io.trino.spi.block.LongArrayBlock
- getRegionSizeInBytes(int, int) - Method in class io.trino.spi.block.MapBlock
- getRegionSizeInBytes(int, int) - Method in class io.trino.spi.block.RowBlock
- getRegionSizeInBytes(int, int) - Method in class io.trino.spi.block.RunLengthEncodedBlock
- getRegionSizeInBytes(int, int) - Method in class io.trino.spi.block.ShortArrayBlock
- getRegionSizeInBytes(int, int) - Method in class io.trino.spi.block.VariableWidthBlock
- getRelationMetadata(ConnectorSession, CatalogSchemaTableName) - Method in interface io.trino.spi.connector.MetadataProvider
-
Return relation schema or empty if relation does not exist.
- getRelationTypes(ConnectorSession, Optional<String>) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
List table, view and materialized view names, possibly filtered by schema.
- getRemainingExpression() - Method in class io.trino.spi.connector.ConstraintApplicationResult
- getRemainingFilter() - Method in class io.trino.spi.connector.ConstraintApplicationResult
- getRemoteClientAddress() - Method in class io.trino.spi.eventlistener.QueryContext
- getRemoteHost() - Method in exception class io.trino.spi.TrinoTransportException
- getRequiredColumns() - Method in class io.trino.spi.function.table.TableFunctionAnalysis
- getRequiredWorkerNodes() - Method in interface io.trino.spi.NodeManager
- getReservedBytes() - Method in class io.trino.spi.memory.MemoryPoolInfo
- getReservedRevocableBytes() - Method in class io.trino.spi.memory.MemoryPoolInfo
- getResourceEstimates() - Method in class io.trino.spi.eventlistener.QueryContext
- getResourceEstimates() - Method in class io.trino.spi.resourcegroups.SelectionCriteria
- getResourceGroupConfigurationManagerFactories() - Method in interface io.trino.spi.Plugin
- getResourceGroupId() - Method in class io.trino.spi.eventlistener.QueryContext
- getResourceGroupId() - Method in class io.trino.spi.resourcegroups.SelectionContext
- getResourceGroupId() - Method in class io.trino.spi.session.SessionConfigurationContext
- getResourceWaitingTime() - Method in class io.trino.spi.eventlistener.QueryStatistics
- getResult() - Method in class io.trino.spi.function.table.TableFunctionProcessorState.Processed
- getRetainedSizeInBytes() - Method in class io.trino.spi.block.ArrayBlock
- getRetainedSizeInBytes() - Method in class io.trino.spi.block.ArrayBlockBuilder
- getRetainedSizeInBytes() - Method in interface io.trino.spi.block.Block
-
Returns the retained size of this block in memory, including over-allocations.
- getRetainedSizeInBytes() - Method in interface io.trino.spi.block.BlockBuilder
-
Returns the retained size of this block in memory, including over-allocations.
- getRetainedSizeInBytes() - Method in class io.trino.spi.block.BufferedArrayValueBuilder
- getRetainedSizeInBytes() - Method in class io.trino.spi.block.BufferedMapValueBuilder
- getRetainedSizeInBytes() - Method in class io.trino.spi.block.BufferedRowValueBuilder
- getRetainedSizeInBytes() - Method in class io.trino.spi.block.ByteArrayBlock
- getRetainedSizeInBytes() - Method in class io.trino.spi.block.ByteArrayBlockBuilder
- getRetainedSizeInBytes() - Method in class io.trino.spi.block.DictionaryBlock
- getRetainedSizeInBytes() - Method in class io.trino.spi.block.Fixed12Block
- getRetainedSizeInBytes() - Method in class io.trino.spi.block.Fixed12BlockBuilder
- getRetainedSizeInBytes() - Method in class io.trino.spi.block.Int128ArrayBlock
- getRetainedSizeInBytes() - Method in class io.trino.spi.block.Int128ArrayBlockBuilder
- getRetainedSizeInBytes() - Method in class io.trino.spi.block.IntArrayBlock
- getRetainedSizeInBytes() - Method in class io.trino.spi.block.IntArrayBlockBuilder
- getRetainedSizeInBytes() - Method in class io.trino.spi.block.LazyBlock
- getRetainedSizeInBytes() - Method in class io.trino.spi.block.LongArrayBlock
- getRetainedSizeInBytes() - Method in class io.trino.spi.block.LongArrayBlockBuilder
- getRetainedSizeInBytes() - Method in class io.trino.spi.block.MapBlock
- getRetainedSizeInBytes() - Method in class io.trino.spi.block.MapBlockBuilder
- getRetainedSizeInBytes() - Method in class io.trino.spi.block.MapHashTables
- getRetainedSizeInBytes() - Method in class io.trino.spi.block.RowBlock
- getRetainedSizeInBytes() - Method in class io.trino.spi.block.RowBlockBuilder
- getRetainedSizeInBytes() - Method in class io.trino.spi.block.RunLengthEncodedBlock
- getRetainedSizeInBytes() - Method in class io.trino.spi.block.ShortArrayBlock
- getRetainedSizeInBytes() - Method in class io.trino.spi.block.ShortArrayBlockBuilder
- getRetainedSizeInBytes() - Method in class io.trino.spi.block.SqlMap
- getRetainedSizeInBytes() - Method in class io.trino.spi.block.SqlRow
- getRetainedSizeInBytes() - Method in class io.trino.spi.block.VariableWidthBlock
- getRetainedSizeInBytes() - Method in class io.trino.spi.block.VariableWidthBlockBuilder
- getRetainedSizeInBytes() - Method in class io.trino.spi.catalog.CatalogName
- getRetainedSizeInBytes() - Method in class io.trino.spi.connector.CatalogHandle.CatalogVersion
- getRetainedSizeInBytes() - Method in class io.trino.spi.connector.CatalogHandle
- getRetainedSizeInBytes() - Method in interface io.trino.spi.connector.ConnectorSplit
- getRetainedSizeInBytes() - Method in class io.trino.spi.connector.SchemaTableName
- getRetainedSizeInBytes() - Method in class io.trino.spi.exchange.ExchangeId
- getRetainedSizeInBytes() - Method in interface io.trino.spi.exchange.ExchangeSourceHandle
- getRetainedSizeInBytes() - Method in class io.trino.spi.exchange.ExchangeSourceOutputSelector
- getRetainedSizeInBytes() - Method in class io.trino.spi.HostAddress
- getRetainedSizeInBytes() - Method in class io.trino.spi.Page
- getRetainedSizeInBytes() - Method in class io.trino.spi.PageBuilder
- getRetainedSizeInBytes() - Method in class io.trino.spi.predicate.AllOrNoneValueSet
- getRetainedSizeInBytes() - Method in class io.trino.spi.predicate.Domain
- getRetainedSizeInBytes() - Method in class io.trino.spi.predicate.EquatableValueSet
- getRetainedSizeInBytes() - Method in class io.trino.spi.predicate.EquatableValueSet.ValueEntry
- getRetainedSizeInBytes() - Method in class io.trino.spi.predicate.SortedRangeSet
- getRetainedSizeInBytes() - Method in interface io.trino.spi.predicate.ValueSet
- getRetainedSizeInBytes() - Method in class io.trino.spi.SplitWeight
- getRetainedSizeInBytes(ToLongFunction<T>) - Method in class io.trino.spi.predicate.TupleDomain
- getRetryPolicy() - Method in class io.trino.spi.eventlistener.QueryContext
- getReturnConvention() - Method in class io.trino.spi.function.InvocationConvention
- getReturnedType() - Method in class io.trino.spi.function.table.TableFunctionAnalysis
- getReturnType() - Method in class io.trino.spi.function.BoundSignature
- getReturnType() - Method in class io.trino.spi.function.Signature
- getReturnTypeSpecification() - Method in class io.trino.spi.function.table.AbstractConnectorTableFunction
- getReturnTypeSpecification() - Method in interface io.trino.spi.function.table.ConnectorTableFunction
- getRightColumnHandles() - Method in class io.trino.spi.connector.JoinApplicationResult
- getRightExpression() - Method in class io.trino.spi.connector.JoinCondition
-
Deprecated.
- getRightStatistics() - Method in interface io.trino.spi.connector.JoinStatistics
-
Estimated statistics for right join table.
- getRole() - Method in class io.trino.spi.security.SelectedRole
- getRoleName() - Method in class io.trino.spi.security.RoleGrant
- getRoles() - Method in class io.trino.spi.security.Identity
-
Deprecated.Use getConnectorRoles
- getRoot() - Method in class io.trino.spi.resourcegroups.ResourceGroupId
- getRootCatalogHandle() - Method in class io.trino.spi.connector.CatalogHandle
- getRoutine() - Method in class io.trino.spi.eventlistener.RoutineInfo
- getRoutineName() - Method in class io.trino.spi.connector.CatalogSchemaRoutineName
- getRoutineName() - Method in class io.trino.spi.connector.SchemaRoutineName
- getRoutines() - Method in class io.trino.spi.eventlistener.QueryMetadata
- getRow(int) - Method in class io.trino.spi.block.RowBlock
- getRowChangeParadigm(ConnectorSession, ConnectorTableHandle) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Return the row change paradigm supported by the connector on the table.
- getRowCount() - Method in class io.trino.spi.connector.BasicRelationStatistics
-
Returns estimated row count.
- getRowCount() - Method in class io.trino.spi.statistics.TableStatistics
- getRowFieldsFromBlock(Block) - Static method in class io.trino.spi.block.RowBlock
-
Returns the row fields from the specified block.
- getRowFilters(ConnectorSecurityContext, SchemaTableName) - Method in interface io.trino.spi.connector.ConnectorAccessControl
-
Get row filters associated with the given table and identity.
- getRowFilters(SystemSecurityContext, CatalogSchemaTableName) - Method in interface io.trino.spi.security.SystemAccessControl
-
Get row filters associated with the given table and identity.
- getRowType() - Method in class io.trino.spi.function.table.TableArgument
- getScalarFunctionImplementation(CatalogSchemaFunctionName, List<Type>, InvocationConvention) - Method in interface io.trino.spi.function.FunctionDependencies
- getScalarFunctionImplementation(FunctionId, BoundSignature, FunctionDependencies, InvocationConvention) - Method in interface io.trino.spi.function.FunctionProvider
- getScalarFunctionImplementationSignature(CatalogSchemaFunctionName, List<TypeSignature>, InvocationConvention) - Method in interface io.trino.spi.function.FunctionDependencies
- getScale() - Method in class io.trino.spi.type.DecimalType
- getScale() - Method in class io.trino.spi.type.SqlDecimal
- getScheduledTime() - Method in class io.trino.spi.eventlistener.QueryStatistics
- getScheduledTimeDistribution() - Method in class io.trino.spi.eventlistener.StageTaskStatistics
- getSchedulingPolicy() - Method in interface io.trino.spi.resourcegroups.ResourceGroup
- getSchedulingWeight() - Method in interface io.trino.spi.resourcegroups.ResourceGroup
- getSchema() - Method in class io.trino.spi.connector.ConnectorMaterializedViewDefinition
- getSchema() - Method in class io.trino.spi.connector.ConnectorViewDefinition
- getSchema() - Method in class io.trino.spi.connector.SchemaTablePrefix
- getSchema() - Method in class io.trino.spi.eventlistener.ColumnDetail
- getSchema() - Method in class io.trino.spi.eventlistener.QueryContext
- getSchema() - Method in class io.trino.spi.eventlistener.QueryInputMetadata
- getSchema() - Method in class io.trino.spi.eventlistener.QueryOutputMetadata
- getSchema() - Method in class io.trino.spi.eventlistener.TableInfo
- getSchema() - Method in class io.trino.spi.function.table.AbstractConnectorTableFunction
- getSchema() - Method in interface io.trino.spi.function.table.ConnectorTableFunction
- getSchema() - Method in class io.trino.spi.security.ViewExpression
- getSchemaFunctionName() - Method in class io.trino.spi.function.CatalogSchemaFunctionName
- getSchemaName() - Method in class io.trino.spi.connector.CatalogSchemaName
- getSchemaName() - Method in class io.trino.spi.connector.CatalogSchemaRoutineName
- getSchemaName() - Method in exception class io.trino.spi.connector.SchemaNotFoundException
- getSchemaName() - Method in class io.trino.spi.connector.SchemaRoutineName
- getSchemaName() - Method in class io.trino.spi.connector.SchemaTableName
- getSchemaName() - Method in class io.trino.spi.function.CatalogSchemaFunctionName
- getSchemaName() - Method in class io.trino.spi.function.SchemaFunctionName
- getSchemaOwner(ConnectorSession, String) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Get the schema properties for the specified schema.
- getSchemaProperties() - Method in interface io.trino.spi.connector.Connector
- getSchemaProperties(ConnectorSession, String) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Gets the schema properties for the specified schema.
- getSchemaRoutineName() - Method in class io.trino.spi.connector.CatalogSchemaRoutineName
- getSchemaTableName() - Method in class io.trino.spi.connector.CatalogSchemaTableName
- getSchemaTableName() - Method in class io.trino.spi.security.GrantInfo
- getSecurityIdentity() - Method in class io.trino.spi.security.ViewExpression
- getSegments() - Method in class io.trino.spi.resourcegroups.ResourceGroupId
- getSelection(ExchangeId, int, int) - Method in class io.trino.spi.exchange.ExchangeSourceOutputSelector
- getSequenceId() - Method in class io.trino.spi.block.DictionaryId
- getSerializable() - Method in class io.trino.spi.predicate.NullableValue
- getSerializedType() - Method in interface io.trino.spi.function.AccumulatorStateSerializer
- getSerializer() - Method in class io.trino.spi.function.AggregationImplementation.AccumulatorStateDescriptor
- getServerAddress() - Method in class io.trino.spi.eventlistener.QueryContext
- getServerVersion() - Method in class io.trino.spi.eventlistener.QueryContext
- getSessionProperties() - Method in interface io.trino.spi.connector.Connector
- getSessionProperties() - Method in class io.trino.spi.eventlistener.QueryContext
- getSessionPropertyConfigurationManagerFactories() - Method in interface io.trino.spi.Plugin
- getShort(int) - Method in class io.trino.spi.block.ShortArrayBlock
- getShort(Block, int) - Method in class io.trino.spi.type.SmallintType
- getSignature() - Method in class io.trino.spi.function.FunctionMetadata
-
Signature of a matching call site.
- getSingleValue() - Method in class io.trino.spi.predicate.AllOrNoneValueSet
- getSingleValue() - Method in class io.trino.spi.predicate.Domain
- getSingleValue() - Method in class io.trino.spi.predicate.EquatableValueSet
- getSingleValue() - Method in class io.trino.spi.predicate.Range
- getSingleValue() - Method in class io.trino.spi.predicate.SortedRangeSet
- getSingleValue() - Method in interface io.trino.spi.predicate.ValueSet
- getSingleValueBlock(int) - Method in class io.trino.spi.block.ArrayBlock
- getSingleValueBlock(int) - Method in interface io.trino.spi.block.Block
-
Gets the value at the specified position as a single element block.
- getSingleValueBlock(int) - Method in class io.trino.spi.block.ByteArrayBlock
- getSingleValueBlock(int) - Method in class io.trino.spi.block.DictionaryBlock
- getSingleValueBlock(int) - Method in class io.trino.spi.block.Fixed12Block
- getSingleValueBlock(int) - Method in class io.trino.spi.block.Int128ArrayBlock
- getSingleValueBlock(int) - Method in class io.trino.spi.block.IntArrayBlock
- getSingleValueBlock(int) - Method in class io.trino.spi.block.LazyBlock
- getSingleValueBlock(int) - Method in class io.trino.spi.block.LongArrayBlock
- getSingleValueBlock(int) - Method in class io.trino.spi.block.MapBlock
- getSingleValueBlock(int) - Method in class io.trino.spi.block.RowBlock
- getSingleValueBlock(int) - Method in class io.trino.spi.block.RunLengthEncodedBlock
- getSingleValueBlock(int) - Method in class io.trino.spi.block.ShortArrayBlock
- getSingleValueBlock(int) - Method in class io.trino.spi.block.VariableWidthBlock
- getSingleValueBlock(int, int) - Method in interface io.trino.spi.function.WindowIndex
-
Gets a value stored as a
Block
. - getSingleValuePage(int) - Method in class io.trino.spi.Page
-
Gets the values at the specified position as a single element page.
- getSize() - Method in class io.trino.spi.block.SqlMap
- getSizeInBytes() - Method in class io.trino.spi.block.ArrayBlock
- getSizeInBytes() - Method in class io.trino.spi.block.ArrayBlockBuilder
- getSizeInBytes() - Method in interface io.trino.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 interface io.trino.spi.block.BlockBuilder
-
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.trino.spi.block.ByteArrayBlock
- getSizeInBytes() - Method in class io.trino.spi.block.ByteArrayBlockBuilder
- getSizeInBytes() - Method in class io.trino.spi.block.DictionaryBlock
- getSizeInBytes() - Method in class io.trino.spi.block.Fixed12Block
- getSizeInBytes() - Method in class io.trino.spi.block.Fixed12BlockBuilder
- getSizeInBytes() - Method in class io.trino.spi.block.Int128ArrayBlock
- getSizeInBytes() - Method in class io.trino.spi.block.Int128ArrayBlockBuilder
- getSizeInBytes() - Method in class io.trino.spi.block.IntArrayBlock
- getSizeInBytes() - Method in class io.trino.spi.block.IntArrayBlockBuilder
- getSizeInBytes() - Method in class io.trino.spi.block.LazyBlock
- getSizeInBytes() - Method in class io.trino.spi.block.LongArrayBlock
- getSizeInBytes() - Method in class io.trino.spi.block.LongArrayBlockBuilder
- getSizeInBytes() - Method in class io.trino.spi.block.MapBlock
- getSizeInBytes() - Method in class io.trino.spi.block.MapBlockBuilder
- getSizeInBytes() - Method in class io.trino.spi.block.PageBuilderStatus
- getSizeInBytes() - Method in class io.trino.spi.block.RowBlock
- getSizeInBytes() - Method in class io.trino.spi.block.RowBlockBuilder
- getSizeInBytes() - Method in class io.trino.spi.block.RunLengthEncodedBlock
- getSizeInBytes() - Method in class io.trino.spi.block.ShortArrayBlock
- getSizeInBytes() - Method in class io.trino.spi.block.ShortArrayBlockBuilder
- getSizeInBytes() - Method in class io.trino.spi.block.SqlMap
- getSizeInBytes() - Method in class io.trino.spi.block.SqlRow
- getSizeInBytes() - Method in class io.trino.spi.block.VariableWidthBlock
- getSizeInBytes() - Method in class io.trino.spi.block.VariableWidthBlockBuilder
- getSizeInBytes() - Method in class io.trino.spi.exchange.ExchangeSourceStatistics
- getSizeInBytes() - Method in class io.trino.spi.Page
- getSizeInBytes() - Method in class io.trino.spi.PageBuilder
- getSlice(int) - Method in class io.trino.spi.block.VariableWidthBlock
- getSlice(int) - Method in class io.trino.spi.connector.InMemoryRecordSet.InMemoryRecordCursor
- getSlice(int) - Method in interface io.trino.spi.connector.RecordCursor
- getSlice(int, int) - Method in interface io.trino.spi.function.WindowIndex
-
Gets a value as a
Slice
. - getSlice(Block, int) - Method in class io.trino.spi.type.AbstractType
- getSlice(Block, int) - Method in class io.trino.spi.type.CharType
- getSlice(Block, int) - Method in class io.trino.spi.type.HyperLogLogType
- getSlice(Block, int) - Method in class io.trino.spi.type.P4HyperLogLogType
- getSlice(Block, int) - Method in class io.trino.spi.type.QuantileDigestType
- getSlice(Block, int) - Method in interface io.trino.spi.type.Type
-
Gets the value at the
block
position
as a Slice. - getSlice(Block, int) - Method in class io.trino.spi.type.UuidType
- getSlice(Block, int) - Method in class io.trino.spi.type.VarbinaryType
- getSlice(Block, int) - Method in class io.trino.spi.type.VarcharType
- getSliceLength(int) - Method in class io.trino.spi.block.VariableWidthBlock
- getSoftConcurrencyLimit() - Method in interface io.trino.spi.resourcegroups.ResourceGroup
- getSoftCpuLimit() - Method in interface io.trino.spi.resourcegroups.ResourceGroup
- getSoftMemoryLimitBytes() - Method in interface io.trino.spi.resourcegroups.ResourceGroup
- getSortedRanges() - Method in class io.trino.spi.predicate.SortedRangeSet
- getSortItems() - Method in class io.trino.spi.connector.AggregateFunction
- getSortOrder() - Method in class io.trino.spi.connector.SortItem
- getSource() - Method in interface io.trino.spi.connector.ConnectorSession
- getSource() - Method in class io.trino.spi.eventlistener.QueryContext
- getSource() - Method in class io.trino.spi.resourcegroups.SelectionCriteria
- getSource() - Method in class io.trino.spi.session.SessionConfigurationContext
- getSourceColumns() - Method in class io.trino.spi.eventlistener.OutputColumnMetadata
- getSourceHandle() - Method in class io.trino.spi.connector.BeginTableExecuteResult
- getSourceHandles() - Method in interface io.trino.spi.exchange.Exchange
-
Returns an
ExchangeSourceHandleSource
instance to be used to enumerateExchangeSourceHandle
s. - getSpan() - Method in interface io.trino.spi.predicate.Ranges
- getSpan() - Method in class io.trino.spi.predicate.SortedRangeSet
- getSpilledBytes() - Method in class io.trino.spi.eventlistener.QueryStatistics
- getSpiVersion() - Method in interface io.trino.spi.connector.ConnectorContext
-
Version of the SPI.
- getSplitBucketFunction(ConnectorTransactionHandle, ConnectorSession, ConnectorPartitioningHandle) - Method in interface io.trino.spi.connector.ConnectorNodePartitioningProvider
- getSplitInfo() - Method in interface io.trino.spi.connector.ConnectorSplit
- getSplitManager() - Method in interface io.trino.spi.connector.Connector
- getSplitProcessor(ConnectorSession, ConnectorTableFunctionHandle, ConnectorSplit) - Method in interface io.trino.spi.function.table.TableFunctionProcessorProvider
-
This method returns a
TableFunctionSplitProcessor
. - getSplits() - Method in class io.trino.spi.connector.ConnectorSplitSource.ConnectorSplitBatch
- getSplits(ConnectorTransactionHandle, ConnectorSession, ConnectorTableHandle, DynamicFilter, Constraint) - Method in interface io.trino.spi.connector.ConnectorSplitManager
- getSplits(ConnectorTransactionHandle, ConnectorSession, ConnectorTableFunctionHandle) - Method in interface io.trino.spi.connector.ConnectorSplitManager
- getSplitWeight() - Method in interface io.trino.spi.connector.ConnectorSplit
- getSpoolingManagerFactories() - Method in interface io.trino.spi.Plugin
- getSqlType() - Method in class io.trino.spi.session.PropertyMetadata
-
SQL type of the property.
- getStageGcStatistics() - Method in class io.trino.spi.eventlistener.QueryStatistics
- getStageId() - Method in class io.trino.spi.eventlistener.SplitCompletedEvent
- getStageId() - Method in class io.trino.spi.eventlistener.StageCpuDistribution
- getStageId() - Method in class io.trino.spi.eventlistener.StageGcStatistics
- getStageId() - Method in class io.trino.spi.eventlistener.StageOutputBufferUtilization
- getStageId() - Method in class io.trino.spi.eventlistener.StageTaskStatistics
- getStart() - Method in interface io.trino.spi.connector.ConnectorSession
- getStartingTime() - Method in class io.trino.spi.eventlistener.QueryStatistics
- getStartTime() - Method in class io.trino.spi.eventlistener.SplitCompletedEvent
- getStateInterface() - Method in class io.trino.spi.function.AggregationImplementation.AccumulatorStateDescriptor
- getStatistics() - Method in class io.trino.spi.eventlistener.QueryCompletedEvent
- getStatistics() - Method in class io.trino.spi.eventlistener.SplitCompletedEvent
- getStatisticsCollectionMetadata(ConnectorSession, ConnectorTableHandle, Map<String, Object>) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Describe statistics that must be collected during a statistics collection
- getStatisticsCollectionMetadataForWrite(ConnectorSession, ConnectorTableMetadata) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Describes statistics that must be collected during a write.
- getStatisticsMetadata() - Method in class io.trino.spi.connector.ConnectorAnalyzeMetadata
- getStatisticType() - Method in class io.trino.spi.statistics.ColumnStatisticMetadata
- getStatisticTypeIfPresent() - Method in class io.trino.spi.statistics.ColumnStatisticMetadata
- getStorageTable() - Method in class io.trino.spi.connector.ConnectorMaterializedViewDefinition
- getSummary() - Method in class io.trino.spi.connector.Constraint
- getSupportedType(ConnectorSession, Map<String, Object>, Type) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Return the effective
Type
that is supported by the connector for the given type. - getSystemAccessControlFactories() - Method in interface io.trino.spi.Plugin
- getSystemSessionProperties(SessionConfigurationContext) - Method in interface io.trino.spi.session.SessionPropertyConfigurationManager
- getSystemTable(ConnectorSession, SchemaTableName) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Returns the system table for the specified table name, if one exists.
- getSystemTables() - Method in interface io.trino.spi.connector.Connector
- getTable() - Method in class io.trino.spi.connector.ConnectorTableMetadata
- getTable() - Method in class io.trino.spi.connector.ConnectorTableSchema
- getTable() - Method in class io.trino.spi.connector.SchemaTablePrefix
- getTable() - Method in class io.trino.spi.connector.TableColumnsMetadata
- getTable() - Method in class io.trino.spi.eventlistener.ColumnDetail
- getTable() - Method in class io.trino.spi.eventlistener.QueryInputMetadata
- getTable() - Method in class io.trino.spi.eventlistener.QueryOutputMetadata
- getTable() - Method in class io.trino.spi.eventlistener.TableInfo
- getTableExecuteHandle() - Method in class io.trino.spi.connector.BeginTableExecuteResult
- getTableExecuteSplitsInfo() - Method in interface io.trino.spi.connector.ConnectorSplitSource
- getTableExecuteSplitsInfo() - Method in class io.trino.spi.connector.FixedSplitSource
- getTableFunctionProcessorProvider(ConnectorTableFunctionHandle) - Method in interface io.trino.spi.function.FunctionProvider
- getTableFunctionProcessorProviderFactory(ConnectorTableFunctionHandle) - Method in interface io.trino.spi.function.FunctionProvider
- getTableFunctions() - Method in interface io.trino.spi.connector.Connector
- getTableHandle() - Method in class io.trino.spi.connector.ConnectorAnalyzeMetadata
- getTableHandle() - Method in interface io.trino.spi.connector.ConnectorMergeTableHandle
-
This method is required because the
ConnectorTableHandle
returned byConnectorMetadata.beginMerge(io.trino.spi.connector.ConnectorSession, io.trino.spi.connector.ConnectorTableHandle, io.trino.spi.connector.RetryMode)
is in general different than the one passed to that method, but the updated handle must be made available toConnectorMetadata.finishMerge(io.trino.spi.connector.ConnectorSession, io.trino.spi.connector.ConnectorMergeTableHandle, java.util.List<io.trino.spi.connector.ConnectorTableHandle>, java.util.Collection<io.airlift.slice.Slice>, java.util.Collection<io.trino.spi.statistics.ComputedStatistics>)
- getTableHandle() - Method in class io.trino.spi.connector.JoinApplicationResult
- getTableHandle() - Method in class io.trino.spi.connector.TableFunctionApplicationResult
- getTableHandle(ConnectorSession, SchemaTableName, Optional<ConnectorTableVersion>, Optional<ConnectorTableVersion>) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Returns a table handle for the specified table name and version, or
null
iftableName
relation does not exist or is not a table (e.g. is a view, or a materialized view). - getTableHandleForExecute(ConnectorSession, ConnectorAccessControl, ConnectorTableHandle, String, Map<String, Object>, RetryMode) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Create initial handle for execution of table procedure.
- getTableHandleForExecute(ConnectorSession, ConnectorTableHandle, String, Map<String, Object>, RetryMode) - Method in interface io.trino.spi.connector.ConnectorMetadata
- getTableMetadata() - Method in interface io.trino.spi.connector.SystemTable
- getTableMetadata(ConnectorSession, ConnectorTableHandle) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Return the metadata for the specified table handle.
- getTableName() - Method in exception class io.trino.spi.connector.ColumnNotFoundException
- getTableName() - Method in class io.trino.spi.connector.SchemaTableName
- getTableName() - Method in exception class io.trino.spi.connector.TableNotFoundException
- getTableName(ConnectorSession, ConnectorTableHandle) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Return schema table name for the specified table handle.
- getTablePartitioning() - Method in class io.trino.spi.connector.ConnectorTableProperties
-
The partitioning of the table across the worker nodes.
- getTableProcedures() - Method in interface io.trino.spi.connector.Connector
- getTableProperties() - Method in interface io.trino.spi.connector.Connector
- getTableProperties(ConnectorSession, ConnectorTableHandle) - Method in interface io.trino.spi.connector.ConnectorMetadata
- getTables() - Method in class io.trino.spi.eventlistener.QueryMetadata
- getTableSchema() - Method in class io.trino.spi.connector.ConnectorTableMetadata
- getTableSchema(ConnectorSession, ConnectorTableHandle) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Return table schema definition for the specified table handle.
- getTableStatistics() - Method in class io.trino.spi.statistics.ComputedStatistics
- getTableStatistics() - Method in class io.trino.spi.statistics.TableStatisticsMetadata
- getTableStatistics(ConnectorSession, ConnectorTableHandle) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Get statistics for table.
- getTag() - Method in class io.trino.spi.memory.MemoryAllocation
- getTags() - Method in class io.trino.spi.resourcegroups.SelectionCriteria
- getTarget() - Method in class io.trino.spi.expression.FieldDereference
- getTaskId() - Method in class io.trino.spi.eventlistener.SplitCompletedEvent
- getTaskMemoryReservations() - Method in class io.trino.spi.memory.MemoryPoolInfo
- getTaskMemoryRevocableReservations() - Method in class io.trino.spi.memory.MemoryPoolInfo
- getTasks() - Method in class io.trino.spi.eventlistener.StageCpuDistribution
- getTasks() - Method in class io.trino.spi.eventlistener.StageGcStatistics
- getTasks() - Method in class io.trino.spi.eventlistener.StageOutputBufferUtilization
- getTasks() - Method in class io.trino.spi.eventlistener.StageTaskStatistics
- getTaskStatistics() - Method in class io.trino.spi.eventlistener.QueryStatistics
- getTerminatingStartTimeMillisDistribution() - Method in class io.trino.spi.eventlistener.StageTaskStatistics
- getTerminatingStartTimeScaledDistribution() - Method in class io.trino.spi.eventlistener.StageTaskStatistics
- getTimeToFirstByte() - Method in class io.trino.spi.eventlistener.SplitStatistics
-
Deprecated.
- getTimeToLastByte() - Method in class io.trino.spi.eventlistener.SplitStatistics
-
Deprecated.
- getTimezone() - Method in class io.trino.spi.eventlistener.QueryContext
- getTimeZoneKey() - Method in interface io.trino.spi.connector.ConnectorSession
- getTimeZoneKey() - Method in class io.trino.spi.type.LongTimestampWithTimeZone
- getTimeZoneKey() - Method in class io.trino.spi.type.SqlTimestampWithTimeZone
- getTimeZoneKey(short) - Static method in class io.trino.spi.type.TimeZoneKey
- getTimeZoneKey(String) - Static method in class io.trino.spi.type.TimeZoneKey
- getTimeZoneKeyForOffset(long) - Static method in class io.trino.spi.type.TimeZoneKey
- getTimeZoneKeys() - Static method in class io.trino.spi.type.TimeZoneKey
- getTotal() - Method in class io.trino.spi.eventlistener.DoubleSymmetricDistribution
- getTotal() - Method in class io.trino.spi.eventlistener.LongDistribution
- getTotal() - Method in class io.trino.spi.eventlistener.LongSymmetricDistribution
- getTotal() - Method in class io.trino.spi.eventlistener.StageCpuDistribution
- getTotal() - Method in interface io.trino.spi.metrics.Count
- getTotal() - Method in interface io.trino.spi.metrics.Distribution
- getTotalBytes() - Method in class io.trino.spi.eventlistener.QueryStatistics
- getTotalDriversDistribution() - Method in class io.trino.spi.eventlistener.StageTaskStatistics
- getTotalFullGcSec() - Method in class io.trino.spi.eventlistener.StageGcStatistics
- getTotalRows() - Method in class io.trino.spi.eventlistener.QueryStatistics
- getToType() - Method in class io.trino.spi.function.FunctionDependencyDeclaration.CastDependency
- getTracer() - Method in interface io.trino.spi.connector.ConnectorContext
- getTracer() - Method in interface io.trino.spi.exchange.ExchangeManagerContext
- getTracer() - Method in interface io.trino.spi.security.SystemAccessControlFactory.SystemAccessControlContext
- getTraceToken() - Method in interface io.trino.spi.connector.ConnectorSession
- getTraceToken() - Method in class io.trino.spi.eventlistener.QueryContext
- getTransactionHandle() - Method in class io.trino.spi.connector.ConnectorSecurityContext
- getTransactionId() - Method in class io.trino.spi.eventlistener.QueryMetadata
- getType() - Method in class io.trino.spi.connector.Assignment
- getType() - Method in class io.trino.spi.connector.CatalogHandle
- getType() - Method in class io.trino.spi.connector.ColumnMetadata
- getType() - Method in class io.trino.spi.connector.ColumnSchema
- getType() - Method in class io.trino.spi.connector.ConnectorMaterializedViewDefinition.Column
- getType() - Method in class io.trino.spi.connector.ConnectorViewDefinition.ViewColumn
- getType() - Method in class io.trino.spi.ErrorCode
- getType() - Method in class io.trino.spi.expression.ConnectorExpression
- getType() - Method in interface io.trino.spi.function.InOut
- getType() - Method in class io.trino.spi.function.table.Descriptor.Field
- getType() - Method in class io.trino.spi.function.table.ScalarArgument
- getType() - Method in class io.trino.spi.function.table.ScalarArgumentSpecification
- getType() - Method in class io.trino.spi.predicate.AllOrNoneValueSet
- getType() - Method in class io.trino.spi.predicate.Domain
- getType() - Method in class io.trino.spi.predicate.EquatableValueSet
- getType() - Method in class io.trino.spi.predicate.EquatableValueSet.ValueEntry
- getType() - Method in class io.trino.spi.predicate.NullableValue
- getType() - Method in class io.trino.spi.predicate.NullableValue.Serializable
- getType() - Method in class io.trino.spi.predicate.Range
- getType() - Method in class io.trino.spi.predicate.SortedRangeSet
- getType() - Method in interface io.trino.spi.predicate.ValueSet
- getType() - Method in class io.trino.spi.security.SelectedRole
- getType() - Method in class io.trino.spi.security.TrinoPrincipal
- getType() - Method in class io.trino.spi.type.DecimalParseResult
- getType() - Method in class io.trino.spi.type.NamedType
- getType() - Method in class io.trino.spi.type.RowType.Field
- getType() - Method in class io.trino.spi.type.TypeParameter
- getType(int) - Method in class io.trino.spi.connector.InMemoryRecordSet.InMemoryRecordCursor
- getType(int) - Method in interface io.trino.spi.connector.RecordCursor
- getType(TypeId) - Method in interface io.trino.spi.type.TypeManager
-
Gets the type with the give (opaque) id
- getType(TypeSignature) - Method in interface io.trino.spi.function.FunctionDependencies
- getType(TypeSignature) - Method in interface io.trino.spi.type.TypeManager
-
Gets the type with the specified signature.
- getTypeDependencies() - Method in class io.trino.spi.function.FunctionDependencyDeclaration
- getTypeId() - Method in interface io.trino.spi.type.Type
- getTypeManager() - Method in interface io.trino.spi.connector.ConnectorContext
- getTypeOperatorDeclaration(TypeOperators) - Method in class io.trino.spi.type.AbstractIntType
- getTypeOperatorDeclaration(TypeOperators) - Method in class io.trino.spi.type.AbstractLongType
- getTypeOperatorDeclaration(TypeOperators) - Method in class io.trino.spi.type.AbstractVariableWidthType
- getTypeOperatorDeclaration(TypeOperators) - Method in class io.trino.spi.type.ArrayType
- getTypeOperatorDeclaration(TypeOperators) - Method in class io.trino.spi.type.BooleanType
- getTypeOperatorDeclaration(TypeOperators) - Method in class io.trino.spi.type.CharType
- getTypeOperatorDeclaration(TypeOperators) - Method in class io.trino.spi.type.DoubleType
- getTypeOperatorDeclaration(TypeOperators) - Method in class io.trino.spi.type.MapType
- getTypeOperatorDeclaration(TypeOperators) - Method in class io.trino.spi.type.RealType
- getTypeOperatorDeclaration(TypeOperators) - Method in class io.trino.spi.type.RowType
- getTypeOperatorDeclaration(TypeOperators) - Method in class io.trino.spi.type.SmallintType
- getTypeOperatorDeclaration(TypeOperators) - Method in class io.trino.spi.type.TimeType
- getTypeOperatorDeclaration(TypeOperators) - Method in class io.trino.spi.type.TinyintType
- getTypeOperatorDeclaration(TypeOperators) - Method in interface io.trino.spi.type.Type
-
Gets the declared type specific operators for this type.
- getTypeOperatorDeclaration(TypeOperators) - Method in class io.trino.spi.type.UuidType
- getTypeOperatorDeclaration(TypeOperators) - Method in class io.trino.spi.type.VarbinaryType
- getTypeOperatorDeclaration(TypeOperators) - Method in class io.trino.spi.type.VarcharType
- getTypeOperators() - Method in interface io.trino.spi.type.TypeManager
-
Gets the cache for type operators.
- getTypeParameters() - Method in class io.trino.spi.type.AbstractType
- getTypeParameters() - Method in class io.trino.spi.type.ArrayType
- getTypeParameters() - Method in class io.trino.spi.type.MapType
- getTypeParameters() - Method in class io.trino.spi.type.QuantileDigestType
- getTypeParameters() - Method in class io.trino.spi.type.RowType
- getTypeParameters() - Method in interface io.trino.spi.type.Type
-
For parameterized types returns the list of parameters.
- getTypeParametersAsTypeSignatures() - Method in class io.trino.spi.type.TypeSignature
- getTypes() - Method in interface io.trino.spi.Plugin
- getTypeSignature() - Method in class io.trino.spi.type.AbstractType
- getTypeSignature() - Method in class io.trino.spi.type.NamedTypeSignature
- getTypeSignature() - Method in interface io.trino.spi.type.Type
-
Gets the name of this type which must be case insensitive globally unique.
- getTypeSignature() - Method in class io.trino.spi.type.TypeSignatureParameter
- getTypeSignatureOrNamedTypeSignature() - Method in class io.trino.spi.type.TypeSignatureParameter
- getTypeVariableConstraints() - Method in class io.trino.spi.function.Signature
- getUnderlyingFieldBlock(int) - Method in class io.trino.spi.block.SqlRow
- getUnderlyingFieldPosition(int) - Method in class io.trino.spi.block.SqlRow
- getUnderlyingKeyBlock() - Method in class io.trino.spi.block.SqlMap
- getUnderlyingKeyPosition(int) - Method in class io.trino.spi.block.SqlMap
- getUnderlyingValueBlock() - Method in class io.trino.spi.block.ArrayBlock
- getUnderlyingValueBlock() - Method in interface io.trino.spi.block.Block
-
Returns the underlying value block underlying this block.
- getUnderlyingValueBlock() - Method in class io.trino.spi.block.ByteArrayBlock
- getUnderlyingValueBlock() - Method in class io.trino.spi.block.DictionaryBlock
- getUnderlyingValueBlock() - Method in class io.trino.spi.block.Fixed12Block
- getUnderlyingValueBlock() - Method in class io.trino.spi.block.Int128ArrayBlock
- getUnderlyingValueBlock() - Method in class io.trino.spi.block.IntArrayBlock
- getUnderlyingValueBlock() - Method in class io.trino.spi.block.LazyBlock
- getUnderlyingValueBlock() - Method in class io.trino.spi.block.LongArrayBlock
- getUnderlyingValueBlock() - Method in class io.trino.spi.block.MapBlock
- getUnderlyingValueBlock() - Method in class io.trino.spi.block.RowBlock
- getUnderlyingValueBlock() - Method in class io.trino.spi.block.RunLengthEncodedBlock
- getUnderlyingValueBlock() - Method in class io.trino.spi.block.ShortArrayBlock
- getUnderlyingValueBlock() - Method in class io.trino.spi.block.SqlMap
- getUnderlyingValueBlock() - Method in interface io.trino.spi.block.ValueBlock
- getUnderlyingValueBlock() - Method in class io.trino.spi.block.VariableWidthBlock
- getUnderlyingValuePosition(int) - Method in interface io.trino.spi.block.Block
-
Returns the position in the underlying value block corresponding to the specified position in this block.
- getUnderlyingValuePosition(int) - Method in class io.trino.spi.block.DictionaryBlock
- getUnderlyingValuePosition(int) - Method in class io.trino.spi.block.LazyBlock
- getUnderlyingValuePosition(int) - Method in class io.trino.spi.block.RunLengthEncodedBlock
- getUnderlyingValuePosition(int) - Method in class io.trino.spi.block.SqlMap
- getUnderlyingValuePosition(int) - Method in interface io.trino.spi.block.ValueBlock
- getUnresolvedTupleDomain() - Method in class io.trino.spi.connector.ConnectorResolvedIndex
- getUnscaledValue() - Method in class io.trino.spi.type.SqlDecimal
- getUpdateLayout(ConnectorSession, ConnectorTableHandle) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Get the physical layout for updated or deleted rows of a MERGE operation.
- getUpdateType() - Method in class io.trino.spi.eventlistener.QueryMetadata
- getUri() - Method in class io.trino.spi.eventlistener.QueryMetadata
- getUser() - Method in interface io.trino.spi.connector.ConnectorSession
- getUser() - Method in class io.trino.spi.eventlistener.QueryContext
- getUser() - Method in class io.trino.spi.resourcegroups.SelectionCriteria
- getUser() - Method in class io.trino.spi.security.ConnectorIdentity
- getUser() - Method in class io.trino.spi.security.Identity
- getUser() - Method in class io.trino.spi.session.SessionConfigurationContext
- getUserAgent() - Method in class io.trino.spi.eventlistener.QueryContext
- getUserGroups() - Method in class io.trino.spi.resourcegroups.SelectionCriteria
- getValidationCpuNanos() - Method in interface io.trino.spi.connector.ConnectorPageSink
-
ConnectorPageSink can provide optional validation to check the data is correctly consumed by connector (e.g. output table has the correct data).
- getValue() - Method in class io.trino.spi.block.RunLengthEncodedBlock
- getValue() - Method in enum class io.trino.spi.connector.JoinCondition.Operator
-
Deprecated.
- getValue() - Method in enum class io.trino.spi.exchange.ExchangeSourceOutputSelector.Selection
- getValue() - Method in class io.trino.spi.expression.Constant
- getValue() - Method in class io.trino.spi.function.table.ScalarArgument
- getValue() - Method in class io.trino.spi.predicate.EquatableValueSet.ValueEntry
- getValue() - Method in class io.trino.spi.predicate.NullableValue
- getValue() - Method in class io.trino.spi.statistics.Estimate
- getValue(ParameterKind, Class<A>) - Method in class io.trino.spi.type.TypeParameter
- getValueBlock() - Method in class io.trino.spi.block.MapBlock
- getValueBlockType() - Method in class io.trino.spi.type.AbstractType
- getValueBlockType() - Method in interface io.trino.spi.type.Type
-
Gets the ValueBlock type used to store values of this type.
- getValues() - Method in class io.trino.spi.exchange.ExchangeSourceOutputSelector
- getValues() - Method in interface io.trino.spi.predicate.DiscreteValues
- getValues() - Method in class io.trino.spi.predicate.Domain
- getValues() - Method in class io.trino.spi.predicate.EquatableValueSet
- getValuesBlock() - Method in class io.trino.spi.block.ColumnarMap
- getValuesCount() - Method in interface io.trino.spi.predicate.DiscreteValues
- getValuesCount() - Method in class io.trino.spi.predicate.EquatableValueSet
- getValuesProcessor() - Method in class io.trino.spi.predicate.AllOrNoneValueSet
- getValuesProcessor() - Method in class io.trino.spi.predicate.EquatableValueSet
- getValuesProcessor() - Method in class io.trino.spi.predicate.SortedRangeSet
- getValuesProcessor() - Method in interface io.trino.spi.predicate.ValueSet
- getValueType() - Method in class io.trino.spi.type.MapType
- getValueType() - Method in class io.trino.spi.type.QuantileDigestType
- getVariable() - Method in class io.trino.spi.connector.Assignment
- getVariable() - Method in class io.trino.spi.type.TypeParameter
- getVariable() - Method in class io.trino.spi.type.TypeSignatureParameter
- getVariadicBound() - Method in class io.trino.spi.function.TypeVariableConstraint
- getVersion() - Method in class io.trino.spi.connector.CatalogHandle
- getVersion() - Method in class io.trino.spi.connector.ConnectorTableVersion
- getVersion() - Method in class io.trino.spi.exchange.ExchangeSourceOutputSelector
- getVersion() - Method in interface io.trino.spi.Node
- getVersion() - Method in interface io.trino.spi.security.SystemAccessControlFactory.SystemAccessControlContext
- getVersionEmbedder() - Method in interface io.trino.spi.connector.ConnectorContext
- getVersionType() - Method in class io.trino.spi.connector.ConnectorTableVersion
- getView(ConnectorSession, SchemaTableName) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Gets the view data for the specified view name.
- getViewName() - Method in exception class io.trino.spi.connector.ViewNotFoundException
- getViewProperties() - Method in interface io.trino.spi.connector.Connector
- getViewProperties(ConnectorSession, SchemaTableName) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Gets the view properties for the specified view.
- getViews(ConnectorSession, Optional<String>) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Gets the definitions of views (but not materialized views), possibly filtered by schema.
- getViewText() - Method in class io.trino.spi.eventlistener.TableInfo
-
If this object refers to a view or materialized view, return the SQL text of the view.
- getWallTime() - Method in class io.trino.spi.eventlistener.QueryStatistics
- getWallTime() - Method in class io.trino.spi.eventlistener.SplitStatistics
- getWarningCode() - Method in class io.trino.spi.TrinoWarning
- getWarnings() - Method in class io.trino.spi.eventlistener.QueryCompletedEvent
- getWindowAccumulator() - Method in class io.trino.spi.function.AggregationImplementation
- getWindowFunctionSupplier(FunctionId, BoundSignature, FunctionDependencies) - Method in interface io.trino.spi.function.FunctionProvider
- getWithHierarchy() - Method in class io.trino.spi.security.GrantInfo
- getWorkerNodes() - Method in interface io.trino.spi.NodeManager
- getWrittenBytes() - Method in class io.trino.spi.eventlistener.QueryStatistics
- getWrittenRows() - Method in class io.trino.spi.eventlistener.QueryStatistics
- getXxHash64Operator(Type, InvocationConvention) - Method in class io.trino.spi.type.TypeOperators
- getXxHash64Operators() - Method in class io.trino.spi.type.TypeOperatorDeclaration
- getZoneId() - Method in class io.trino.spi.type.TimeZoneKey
- getZoneId() - Method in exception class io.trino.spi.type.TimeZoneNotSupportedException
- GrantInfo - Class in io.trino.spi.security
- GrantInfo(PrivilegeInfo, TrinoPrincipal, SchemaTableName, Optional<TrinoPrincipal>, Optional<Boolean>) - Constructor for class io.trino.spi.security.GrantInfo
- grantRoles(ConnectorSession, Set<String>, Set<TrinoPrincipal>, boolean, Optional<TrinoPrincipal>) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Grants the specified roles to the specified grantees
- grantSchemaPrivileges(ConnectorSession, String, Set<Privilege>, TrinoPrincipal, boolean) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Grants the specified privilege to the specified user on the specified schema
- grantTablePrivileges(ConnectorSession, SchemaTableName, Set<Privilege>, TrinoPrincipal, boolean) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Grants the specified privilege to the specified user on the specified table
- GREATER_THAN - Enum constant in enum class io.trino.spi.connector.JoinCondition.Operator
-
Deprecated.
- GREATER_THAN_OPERATOR_FUNCTION_NAME - Static variable in class io.trino.spi.expression.StandardFunctions
- GREATER_THAN_OR_EQUAL - Enum constant in enum class io.trino.spi.connector.JoinCondition.Operator
-
Deprecated.
- GREATER_THAN_OR_EQUAL_OPERATOR_FUNCTION_NAME - Static variable in class io.trino.spi.expression.StandardFunctions
- greaterThan(Type, Object) - Static method in class io.trino.spi.predicate.Range
- greaterThanOrEqual(Type, Object) - Static method in class io.trino.spi.predicate.Range
- GroupedAccumulatorState - Interface in io.trino.spi.function
- GroupingProperty<E> - Class in io.trino.spi.connector
- GroupingProperty(Collection<E>) - Constructor for class io.trino.spi.connector.GroupingProperty
- GroupProvider - Interface in io.trino.spi.security
- GroupProviderFactory - Interface in io.trino.spi.security
H
- handle(ConnectorTableFunctionHandle) - Method in class io.trino.spi.function.table.TableFunctionAnalysis.Builder
- handles() - Method in record class io.trino.spi.exchange.ExchangeSourceHandleSource.ExchangeSourceHandleBatch
-
Returns the value of the
handles
record component. - hasFixedMapping() - Method in class io.trino.spi.connector.ConnectorBucketNodeMap
- hash(long) - Static method in class io.trino.spi.type.AbstractLongType
- HASH_CODE - Enum constant in enum class io.trino.spi.function.OperatorType
- hashCode() - Method in class io.trino.spi.block.DictionaryId
- hashCode() - Method in class io.trino.spi.catalog.CatalogName
- hashCode() - Method in record class io.trino.spi.catalog.CatalogProperties
-
Returns a hash code value for this object.
- hashCode() - Method in class io.trino.spi.connector.AggregateFunction
- hashCode() - Method in class io.trino.spi.connector.CatalogHandle.CatalogVersion
- hashCode() - Method in class io.trino.spi.connector.CatalogHandle
- hashCode() - Method in class io.trino.spi.connector.CatalogSchemaName
- hashCode() - Method in class io.trino.spi.connector.CatalogSchemaRoutineName
- hashCode() - Method in class io.trino.spi.connector.CatalogSchemaTableName
- hashCode() - Method in interface io.trino.spi.connector.ColumnHandle
- hashCode() - Method in class io.trino.spi.connector.ColumnMetadata
- hashCode() - Method in class io.trino.spi.connector.ColumnSchema
- hashCode() - Method in class io.trino.spi.connector.ConnectorMaterializedViewDefinition.Column
- hashCode() - Method in class io.trino.spi.connector.ConnectorMaterializedViewDefinition
- hashCode() - Method in class io.trino.spi.connector.ConnectorName
- hashCode() - Method in class io.trino.spi.connector.ConnectorTablePartitioning
- hashCode() - Method in class io.trino.spi.connector.ConnectorTableProperties
- hashCode() - Method in class io.trino.spi.connector.ConstantProperty
- hashCode() - Method in record class io.trino.spi.connector.EntityKindAndName
-
Returns a hash code value for this object.
- hashCode() - Method in record class io.trino.spi.connector.EntityPrivilege
-
Returns a hash code value for this object.
- hashCode() - Method in class io.trino.spi.connector.GroupingProperty
- hashCode() - Method in class io.trino.spi.connector.JoinCondition
-
Deprecated.
- hashCode() - Method in class io.trino.spi.connector.MaterializedViewFreshness
- hashCode() - Method in record class io.trino.spi.connector.RelationColumnsMetadata
-
Returns a hash code value for this object.
- hashCode() - Method in record class io.trino.spi.connector.RelationCommentMetadata
-
Returns a hash code value for this object.
- hashCode() - Method in class io.trino.spi.connector.SchemaRoutineName
- hashCode() - Method in class io.trino.spi.connector.SchemaTableName
- hashCode() - Method in class io.trino.spi.connector.SchemaTablePrefix
- hashCode() - Method in class io.trino.spi.connector.SortingProperty
- hashCode() - Method in class io.trino.spi.connector.SortItem
- hashCode() - Method in record class io.trino.spi.connector.WriterScalingOptions
-
Returns a hash code value for this object.
- hashCode() - Method in class io.trino.spi.ErrorCode
- hashCode() - Method in class io.trino.spi.eventlistener.ColumnDetail
- hashCode() - Method in record class io.trino.spi.eventlistener.ColumnMaskReferenceInfo
-
Returns a hash code value for this object.
- hashCode() - Method in record class io.trino.spi.eventlistener.MaterializedViewReferenceInfo
-
Returns a hash code value for this object.
- hashCode() - Method in class io.trino.spi.eventlistener.OutputColumnMetadata
- hashCode() - Method in record class io.trino.spi.eventlistener.QueryPlanOptimizerStatistics
-
Returns a hash code value for this object.
- hashCode() - Method in record class io.trino.spi.eventlistener.RowFilterReferenceInfo
-
Returns a hash code value for this object.
- hashCode() - Method in record class io.trino.spi.eventlistener.ViewReferenceInfo
-
Returns a hash code value for this object.
- hashCode() - Method in class io.trino.spi.exchange.ExchangeId
- hashCode() - Method in record class io.trino.spi.exchange.ExchangeSourceHandleSource.ExchangeSourceHandleBatch
-
Returns a hash code value for this object.
- hashCode() - Method in class io.trino.spi.expression.Call
- hashCode() - Method in class io.trino.spi.expression.ConnectorExpression
- hashCode() - Method in class io.trino.spi.expression.Constant
- hashCode() - Method in class io.trino.spi.expression.FieldDereference
- hashCode() - Method in class io.trino.spi.expression.FunctionName
- hashCode() - Method in class io.trino.spi.expression.Variable
- hashCode() - Method in class io.trino.spi.function.BoundSignature
- hashCode() - Method in class io.trino.spi.function.CatalogSchemaFunctionName
- hashCode() - Method in class io.trino.spi.function.FunctionDependencyDeclaration.CastDependency
- hashCode() - Method in class io.trino.spi.function.FunctionDependencyDeclaration.FunctionDependency
- hashCode() - Method in class io.trino.spi.function.FunctionDependencyDeclaration.OperatorDependency
- hashCode() - Method in class io.trino.spi.function.FunctionId
- hashCode() - Method in class io.trino.spi.function.FunctionNullability
- hashCode() - Method in class io.trino.spi.function.InvocationConvention
- hashCode() - Method in record class io.trino.spi.function.LanguageFunction
-
Returns a hash code value for this object.
- hashCode() - Method in class io.trino.spi.function.LongVariableConstraint
- hashCode() - Method in class io.trino.spi.function.SchemaFunctionName
- hashCode() - Method in class io.trino.spi.function.Signature
- hashCode() - Method in class io.trino.spi.function.table.Descriptor.Field
- hashCode() - Method in class io.trino.spi.function.table.Descriptor
- hashCode() - Method in class io.trino.spi.function.table.DescriptorArgument
- hashCode() - Method in class io.trino.spi.function.table.NameAndPosition
- hashCode() - Method in class io.trino.spi.function.TypeVariableConstraint
- hashCode() - Method in class io.trino.spi.HostAddress
- hashCode() - Method in class io.trino.spi.Location
- hashCode() - Method in class io.trino.spi.metrics.Metrics
- hashCode() - Method in class io.trino.spi.predicate.AllOrNoneValueSet
- hashCode() - Method in class io.trino.spi.predicate.Domain
- hashCode() - Method in class io.trino.spi.predicate.EquatableValueSet
- hashCode() - Method in class io.trino.spi.predicate.EquatableValueSet.ValueEntry
- hashCode() - Method in class io.trino.spi.predicate.NullableValue
- hashCode() - Method in class io.trino.spi.predicate.Range
- hashCode() - Method in class io.trino.spi.predicate.SortedRangeSet
- hashCode() - Method in class io.trino.spi.predicate.TupleDomain
- hashCode() - Method in class io.trino.spi.QueryId
- hashCode() - Method in class io.trino.spi.resourcegroups.ResourceGroupId
- hashCode() - Method in class io.trino.spi.security.BasicPrincipal
- hashCode() - Method in class io.trino.spi.security.GrantInfo
- hashCode() - Method in class io.trino.spi.security.Identity
- hashCode() - Method in class io.trino.spi.security.PrivilegeInfo
- hashCode() - Method in class io.trino.spi.security.RoleGrant
- hashCode() - Method in class io.trino.spi.security.SelectedRole
- hashCode() - Method in class io.trino.spi.security.TrinoPrincipal
- hashCode() - Method in class io.trino.spi.SplitWeight
- hashCode() - Method in class io.trino.spi.statistics.ColumnStatisticMetadata
- hashCode() - Method in class io.trino.spi.statistics.ColumnStatistics
- hashCode() - Method in class io.trino.spi.statistics.DoubleRange
- hashCode() - Method in class io.trino.spi.statistics.Estimate
- hashCode() - Method in class io.trino.spi.statistics.TableStatistics
- hashCode() - Method in class io.trino.spi.TrinoWarning
- hashCode() - Method in class io.trino.spi.type.AbstractType
- hashCode() - Method in class io.trino.spi.type.BigintType
- hashCode() - Method in class io.trino.spi.type.BooleanType
- hashCode() - Method in class io.trino.spi.type.CharType
- hashCode() - Method in class io.trino.spi.type.DateType
- hashCode() - Method in class io.trino.spi.type.DecimalParseResult
- hashCode() - Method in class io.trino.spi.type.DoubleType
- hashCode() - Method in class io.trino.spi.type.Int128
- hashCode() - Method in class io.trino.spi.type.IntegerType
- hashCode() - Method in class io.trino.spi.type.LongTimestamp
- hashCode() - Method in class io.trino.spi.type.LongTimestampWithTimeZone
- hashCode() - Method in class io.trino.spi.type.LongTimeWithTimeZone
- hashCode() - Method in class io.trino.spi.type.NamedType
- hashCode() - Method in class io.trino.spi.type.NamedTypeSignature
- hashCode() - Method in class io.trino.spi.type.RealType
- hashCode() - Method in class io.trino.spi.type.RowFieldName
- hashCode() - Method in class io.trino.spi.type.SmallintType
- hashCode() - Method in class io.trino.spi.type.SqlDate
- hashCode() - Method in class io.trino.spi.type.SqlDecimal
- hashCode() - Method in class io.trino.spi.type.SqlTime
- hashCode() - Method in class io.trino.spi.type.SqlTimestamp
- hashCode() - Method in class io.trino.spi.type.SqlTimestampWithTimeZone
- hashCode() - Method in class io.trino.spi.type.SqlTimeWithTimeZone
- hashCode() - Method in class io.trino.spi.type.SqlVarbinary
- hashCode() - Method in class io.trino.spi.type.TimeZoneKey
- hashCode() - Method in class io.trino.spi.type.TinyintType
- hashCode() - Method in class io.trino.spi.type.TypeId
- hashCode() - Method in class io.trino.spi.type.TypeParameter
- hashCode() - Method in class io.trino.spi.type.TypeSignature
- hashCode() - Method in class io.trino.spi.type.TypeSignatureParameter
- hashCode() - Method in class io.trino.spi.type.VarbinaryType
- hashCode() - Method in class io.trino.spi.type.VarcharType
- hashCode() - Method in class io.trino.spi.WarningCode
- hashCodeOperator(long) - Static method in class io.trino.spi.type.TimeType
- hasPort() - Method in class io.trino.spi.HostAddress
-
Return true if this instance has a defined port.
- HeaderAuthenticator - Interface in io.trino.spi.security
- HeaderAuthenticator.Headers - Interface in io.trino.spi.security
- HeaderAuthenticatorFactory - Interface in io.trino.spi.security
- hidden() - Element in annotation interface io.trino.spi.function.AggregationFunction
- hidden() - Method in class io.trino.spi.function.FunctionMetadata.Builder
- hidden() - Element in annotation interface io.trino.spi.function.ScalarFunction
- HostAddress - Class in io.trino.spi
-
An immutable representation of a host and port.
- HYPER_LOG_LOG - Static variable in class io.trino.spi.type.HyperLogLogType
- HYPER_LOG_LOG - Static variable in class io.trino.spi.type.StandardTypes
- HyperLogLogType - Class in io.trino.spi.type
- HyperLogLogType() - Constructor for class io.trino.spi.type.HyperLogLogType
I
- IDENTICAL - Enum constant in enum class io.trino.spi.connector.JoinCondition.Operator
-
Deprecated.
- IDENTICAL - Enum constant in enum class io.trino.spi.function.OperatorType
- IDENTICAL_OPERATOR_FUNCTION_NAME - Static variable in class io.trino.spi.expression.StandardFunctions
- identity(String) - Method in class io.trino.spi.security.ViewExpression.Builder
- Identity - Class in io.trino.spi.security
- Identity.Builder - Class in io.trino.spi.security
- IGNORE - Enum constant in enum class io.trino.spi.connector.SaveMode
- IN_OUT - Enum constant in enum class io.trino.spi.function.InvocationConvention.InvocationArgumentConvention
-
Argument is passed in an InOut.
- IN_PREDICATE_FUNCTION_NAME - Static variable in class io.trino.spi.expression.StandardFunctions
-
$in(value, array)
returnstrue
when value is equal to an element of the array, otherwise returnsNULL
when comparing value to an element of the array returns an indeterminate result, otherwise returnsfalse
- include(ExchangeId, int, int) - Method in class io.trino.spi.exchange.ExchangeSourceOutputSelector.Builder
- INCLUDED - Enum constant in enum class io.trino.spi.exchange.ExchangeSourceOutputSelector.Selection
- includesNullableValue(Object) - Method in class io.trino.spi.predicate.Domain
- inclusive() - Method in class io.trino.spi.predicate.EquatableValueSet
- INCOMPATIBLE_CLIENT - Enum constant in enum class io.trino.spi.StandardErrorCode
- INCREMENTAL - Enum constant in enum class io.trino.spi.RefreshType
- INDETERMINATE - Enum constant in enum class io.trino.spi.function.OperatorType
- indexPage(Page) - Method in interface io.trino.spi.PageIndexer
-
Returns the unique index of each position value.
- INFORMATION_SCHEMA - Enum constant in enum class io.trino.spi.connector.CatalogHandle.CatalogHandleType
- InMemoryRecordCursor(List<Type>, Iterator<? extends List<?>>) - Constructor for class io.trino.spi.connector.InMemoryRecordSet.InMemoryRecordCursor
- InMemoryRecordSet - Class in io.trino.spi.connector
- InMemoryRecordSet(Collection<? extends Type>, Iterable<? extends List<?>>) - Constructor for class io.trino.spi.connector.InMemoryRecordSet
- InMemoryRecordSet.Builder - Class in io.trino.spi.connector
- InMemoryRecordSet.InMemoryRecordCursor - Class in io.trino.spi.connector
- INNER - Enum constant in enum class io.trino.spi.connector.JoinType
- InOut - Interface in io.trino.spi.function
- inputFunction(MethodHandle) - Method in class io.trino.spi.function.AggregationImplementation.Builder
- InputFunction - Annotation Interface in io.trino.spi.function
- INSERT - Enum constant in enum class io.trino.spi.resourcegroups.QueryType
- INSERT - Enum constant in enum class io.trino.spi.security.Privilege
- INSERT_OPERATION_NUMBER - Static variable in interface io.trino.spi.connector.ConnectorMergeSink
-
Represents an inserted row.
- INSTANCE_SIZE - Static variable in class io.trino.spi.block.BlockBuilderStatus
- INSTANCE_SIZE - Static variable in class io.trino.spi.block.MapHashTables
- INSTANCE_SIZE - Static variable in class io.trino.spi.block.PageBuilderStatus
- INSTANCE_SIZE - Static variable in class io.trino.spi.Page
- INSTANCE_SIZE - Static variable in class io.trino.spi.type.Int128
- INSTANCE_SIZE - Static variable in class io.trino.spi.type.LongTimestamp
- INSTANCE_SIZE - Static variable in class io.trino.spi.type.LongTimestampWithTimeZone
- INSTANCE_SIZE - Static variable in class io.trino.spi.type.LongTimeWithTimeZone
- instanceFactory(MethodHandle) - Method in class io.trino.spi.function.ScalarFunctionImplementation.Builder
- instantiateSink(ExchangeSinkHandle, int) - Method in interface io.trino.spi.exchange.Exchange
-
Registers a sink instance for an attempt.
- INSUFFICIENT_RESOURCES - Enum constant in enum class io.trino.spi.ErrorType
- Int128 - Class in io.trino.spi.type
- INT128_BYTES - Static variable in class io.trino.spi.block.Int128ArrayBlock
- Int128ArrayBlock - Class in io.trino.spi.block
- Int128ArrayBlock(int, Optional<boolean[]>, long[]) - Constructor for class io.trino.spi.block.Int128ArrayBlock
- Int128ArrayBlockBuilder - Class in io.trino.spi.block
- Int128ArrayBlockBuilder(BlockBuilderStatus, int) - Constructor for class io.trino.spi.block.Int128ArrayBlockBuilder
- Int128ArrayBlockEncoding - Class in io.trino.spi.block
- Int128ArrayBlockEncoding() - Constructor for class io.trino.spi.block.Int128ArrayBlockEncoding
- Int128Math - Class in io.trino.spi.type
-
128 bit int arithmetic using two's complement representation
- IntArrayBlock - Class in io.trino.spi.block
- IntArrayBlock(int, Optional<boolean[]>, int[]) - Constructor for class io.trino.spi.block.IntArrayBlock
- IntArrayBlockBuilder - Class in io.trino.spi.block
- IntArrayBlockBuilder(BlockBuilderStatus, int) - Constructor for class io.trino.spi.block.IntArrayBlockBuilder
- IntArrayBlockEncoding - Class in io.trino.spi.block
- IntArrayBlockEncoding() - Constructor for class io.trino.spi.block.IntArrayBlockEncoding
- INTEGER - Static variable in class io.trino.spi.type.IntegerType
- INTEGER - Static variable in class io.trino.spi.type.StandardTypes
- integerProperty(String, String, Integer, boolean) - Static method in class io.trino.spi.session.PropertyMetadata
- integerProperty(String, String, Integer, Consumer<Integer>, boolean) - Static method in class io.trino.spi.session.PropertyMetadata
- IntegerType - Class in io.trino.spi.type
- intermediateType(Type) - Method in class io.trino.spi.function.AggregationFunctionMetadata.AggregationFunctionMetadataBuilder
- intermediateType(TypeSignature) - Method in class io.trino.spi.function.AggregationFunctionMetadata.AggregationFunctionMetadataBuilder
- INTERNAL_ERROR - Enum constant in enum class io.trino.spi.ErrorType
- InternalDataAccessor - Interface in io.trino.spi.function
-
This interface is an internal detail of the SPI and should never be used.
- intersect(Domain) - Method in class io.trino.spi.predicate.Domain
- intersect(Range) - Method in class io.trino.spi.predicate.Range
- intersect(TupleDomain<U>) - Method in class io.trino.spi.predicate.TupleDomain
-
Returns the strict intersection of the TupleDomains.
- intersect(ValueSet) - Method in class io.trino.spi.predicate.AllOrNoneValueSet
- intersect(ValueSet) - Method in class io.trino.spi.predicate.EquatableValueSet
- intersect(ValueSet) - Method in class io.trino.spi.predicate.SortedRangeSet
- intersect(ValueSet) - Method in interface io.trino.spi.predicate.ValueSet
- intersect(List<? extends TupleDomain<? extends T>>) - Static method in class io.trino.spi.predicate.TupleDomain
- INTERVAL_DAY_TO_SECOND - Static variable in class io.trino.spi.type.StandardTypes
- INTERVAL_YEAR_TO_MONTH - Static variable in class io.trino.spi.type.StandardTypes
- intScale(long) - Static method in class io.trino.spi.type.DecimalConversions
- INVALID_ANALYZE_PROPERTY - Enum constant in enum class io.trino.spi.StandardErrorCode
- INVALID_ARGUMENTS - Enum constant in enum class io.trino.spi.StandardErrorCode
- INVALID_CAST_ARGUMENT - Enum constant in enum class io.trino.spi.StandardErrorCode
- INVALID_CATALOG_PROPERTY - Enum constant in enum class io.trino.spi.StandardErrorCode
- INVALID_CHECK_CONSTRAINT - Enum constant in enum class io.trino.spi.StandardErrorCode
- INVALID_COLUMN_MASK - Enum constant in enum class io.trino.spi.StandardErrorCode
- INVALID_COLUMN_PROPERTY - Enum constant in enum class io.trino.spi.StandardErrorCode
- INVALID_COLUMN_REFERENCE - Enum constant in enum class io.trino.spi.StandardErrorCode
- INVALID_COPARTITIONING - Enum constant in enum class io.trino.spi.StandardErrorCode
- INVALID_ENTITY_KIND - Enum constant in enum class io.trino.spi.StandardErrorCode
- INVALID_FUNCTION_ARGUMENT - Enum constant in enum class io.trino.spi.StandardErrorCode
- INVALID_JSON_LITERAL - Enum constant in enum class io.trino.spi.StandardErrorCode
- INVALID_LABEL - Enum constant in enum class io.trino.spi.StandardErrorCode
- INVALID_LIMIT_CLAUSE - Enum constant in enum class io.trino.spi.StandardErrorCode
- INVALID_LITERAL - Enum constant in enum class io.trino.spi.StandardErrorCode
- INVALID_MATERIALIZED_VIEW_PROPERTY - Enum constant in enum class io.trino.spi.StandardErrorCode
- INVALID_NAVIGATION_NESTING - Enum constant in enum class io.trino.spi.StandardErrorCode
- INVALID_ORDER_BY - Enum constant in enum class io.trino.spi.StandardErrorCode
- INVALID_PARAMETER_USAGE - Enum constant in enum class io.trino.spi.StandardErrorCode
- INVALID_PARTITION_BY - Enum constant in enum class io.trino.spi.StandardErrorCode
- INVALID_PATH - Enum constant in enum class io.trino.spi.StandardErrorCode
- INVALID_PATTERN_RECOGNITION_FUNCTION - Enum constant in enum class io.trino.spi.StandardErrorCode
- INVALID_PLAN - Enum constant in enum class io.trino.spi.StandardErrorCode
- INVALID_PRIVILEGE - Enum constant in enum class io.trino.spi.StandardErrorCode
- INVALID_PROCEDURE_ARGUMENT - Enum constant in enum class io.trino.spi.StandardErrorCode
- INVALID_PROCEDURE_DEFINITION - Enum constant in enum class io.trino.spi.StandardErrorCode
- INVALID_PROCESSING_MODE - Enum constant in enum class io.trino.spi.StandardErrorCode
- INVALID_RANGE - Enum constant in enum class io.trino.spi.StandardErrorCode
- INVALID_RECURSIVE_REFERENCE - Enum constant in enum class io.trino.spi.StandardErrorCode
- INVALID_RESOURCE_GROUP - Enum constant in enum class io.trino.spi.StandardErrorCode
- INVALID_ROW_FILTER - Enum constant in enum class io.trino.spi.StandardErrorCode
- INVALID_ROW_PATTERN - Enum constant in enum class io.trino.spi.StandardErrorCode
- INVALID_SCHEMA_PROPERTY - Enum constant in enum class io.trino.spi.StandardErrorCode
- INVALID_SESSION_PROPERTY - Enum constant in enum class io.trino.spi.StandardErrorCode
- INVALID_SPATIAL_PARTITIONING - Enum constant in enum class io.trino.spi.StandardErrorCode
- INVALID_TABLE_FUNCTION_INVOCATION - Enum constant in enum class io.trino.spi.StandardErrorCode
- INVALID_TABLE_PROPERTY - Enum constant in enum class io.trino.spi.StandardErrorCode
- INVALID_VIEW - Enum constant in enum class io.trino.spi.StandardErrorCode
- INVALID_VIEW_PROPERTY - Enum constant in enum class io.trino.spi.StandardErrorCode
- INVALID_WINDOW_FRAME - Enum constant in enum class io.trino.spi.StandardErrorCode
- INVALID_WINDOW_MEASURE - Enum constant in enum class io.trino.spi.StandardErrorCode
- INVALID_WINDOW_REFERENCE - Enum constant in enum class io.trino.spi.StandardErrorCode
- InvocationConvention - Class in io.trino.spi.function
- InvocationConvention(List<InvocationConvention.InvocationArgumentConvention>, InvocationConvention.InvocationReturnConvention, boolean, boolean) - Constructor for class io.trino.spi.function.InvocationConvention
- InvocationConvention.InvocationArgumentConvention - Enum Class in io.trino.spi.function
- InvocationConvention.InvocationReturnConvention - Enum Class in io.trino.spi.function
- invocations() - Method in record class io.trino.spi.eventlistener.QueryPlanOptimizerStatistics
-
Returns the value of the
invocations
record component. - io.trino.spi - package io.trino.spi
- io.trino.spi.block - package io.trino.spi.block
- io.trino.spi.catalog - package io.trino.spi.catalog
- io.trino.spi.classloader - package io.trino.spi.classloader
- io.trino.spi.connector - package io.trino.spi.connector
- io.trino.spi.eventlistener - package io.trino.spi.eventlistener
- io.trino.spi.exchange - package io.trino.spi.exchange
- io.trino.spi.expression - package io.trino.spi.expression
- io.trino.spi.function - package io.trino.spi.function
- io.trino.spi.function.table - package io.trino.spi.function.table
- io.trino.spi.memory - package io.trino.spi.memory
- io.trino.spi.metrics - package io.trino.spi.metrics
- io.trino.spi.predicate - package io.trino.spi.predicate
- io.trino.spi.resourcegroups - package io.trino.spi.resourcegroups
- io.trino.spi.security - package io.trino.spi.security
- io.trino.spi.session - package io.trino.spi.session
- io.trino.spi.statistics - package io.trino.spi.statistics
- io.trino.spi.transaction - package io.trino.spi.transaction
- io.trino.spi.type - package io.trino.spi.type
- IPADDRESS - Static variable in class io.trino.spi.type.StandardTypes
- IS_NULL_FUNCTION_NAME - Static variable in class io.trino.spi.expression.StandardFunctions
- isAll() - Method in interface io.trino.spi.predicate.AllOrNone
- isAll() - Method in class io.trino.spi.predicate.AllOrNoneValueSet
- isAll() - Method in class io.trino.spi.predicate.Domain
- isAll() - Method in class io.trino.spi.predicate.EquatableValueSet
- isAll() - Method in class io.trino.spi.predicate.Range
- isAll() - Method in class io.trino.spi.predicate.SortedRangeSet
- isAll() - Method in class io.trino.spi.predicate.TupleDomain
-
Returns true if any tuples would satisfy this TupleDomain
- isAll() - Method in interface io.trino.spi.predicate.ValueSet
- isAncestorOf(ResourceGroupId) - Method in class io.trino.spi.resourcegroups.ResourceGroupId
- isArgumentNullable(int) - Method in class io.trino.spi.function.FunctionNullability
- isAscending() - Method in enum class io.trino.spi.connector.SortOrder
- isAuthenticated() - Method in class io.trino.spi.resourcegroups.SelectionCriteria
- isAwaitable() - Method in interface io.trino.spi.connector.DynamicFilter
-
Returns true if dynamic filter can be narrowed down more and
DynamicFilter.isBlocked()
method can be used to wait for narrowed filter. - isBlocked() - Method in interface io.trino.spi.connector.ConnectorPageSource
-
Returns a future that will be completed when the page source becomes unblocked.
- isBlocked() - Method in interface io.trino.spi.connector.DynamicFilter
-
Returned a future, which blocks until dynamic filter is narrowed down.
- isBlocked() - Method in interface io.trino.spi.exchange.ExchangeSink
-
Returns a future that will be completed when the exchange sink becomes unblocked.
- isBlocked() - Method in interface io.trino.spi.exchange.ExchangeSource
-
Returns a future that will be completed when the exchange source becomes unblocked.
- isCalculated() - Method in class io.trino.spi.type.TypeSignature
- isCalculated() - Method in class io.trino.spi.type.TypeSignatureParameter
- isCompact() - Method in class io.trino.spi.block.DictionaryBlock
- isComparable() - Method in class io.trino.spi.type.AbstractIntType
- isComparable() - Method in class io.trino.spi.type.AbstractLongType
- isComparable() - Method in class io.trino.spi.type.AbstractType
- isComparable() - Method in class io.trino.spi.type.ArrayType
- isComparable() - Method in class io.trino.spi.type.BooleanType
- isComparable() - Method in class io.trino.spi.type.CharType
- isComparable() - Method in class io.trino.spi.type.DecimalType
- isComparable() - Method in class io.trino.spi.type.DoubleType
- isComparable() - Method in class io.trino.spi.type.MapType
- isComparable() - Method in class io.trino.spi.type.RowType
- isComparable() - Method in class io.trino.spi.type.SmallintType
- isComparable() - Method in class io.trino.spi.type.TimestampType
- isComparable() - Method in class io.trino.spi.type.TimestampWithTimeZoneType
- isComparable() - Method in class io.trino.spi.type.TimeWithTimeZoneType
- isComparable() - Method in class io.trino.spi.type.TinyintType
- isComparable() - Method in interface io.trino.spi.type.Type
-
True if the type supports equalTo and hash.
- isComparable() - Method in class io.trino.spi.type.TypeOperatorDeclaration
- isComparable() - Method in class io.trino.spi.type.UuidType
- isComparable() - Method in class io.trino.spi.type.VarbinaryType
- isComparable() - Method in class io.trino.spi.type.VarcharType
- isComparableRequired() - Method in class io.trino.spi.function.TypeVariableConstraint
- isComplete() - Method in interface io.trino.spi.connector.DynamicFilter
-
Returns true it dynamic filter cannot be narrowed more.
- isComplete() - Method in class io.trino.spi.eventlistener.QueryStatistics
- isCoordinator() - Method in interface io.trino.spi.Node
- isCoordinatorOnly() - Method in interface io.trino.spi.connector.ConnectorPartitioningHandle
- isDecomposable() - Method in class io.trino.spi.function.AggregationFunctionMetadata
- isDeprecated() - Method in class io.trino.spi.function.FunctionMetadata
- isDeterministic() - Method in class io.trino.spi.function.FunctionMetadata
- isDirectlyReferenced() - Method in class io.trino.spi.eventlistener.TableInfo
- isDisabled() - Method in interface io.trino.spi.resourcegroups.ResourceGroup
- isDiscreteSet() - Method in class io.trino.spi.predicate.AllOrNoneValueSet
- isDiscreteSet() - Method in class io.trino.spi.predicate.EquatableValueSet
- isDiscreteSet() - Method in class io.trino.spi.predicate.SortedRangeSet
- isDiscreteSet() - Method in interface io.trino.spi.predicate.ValueSet
- isDistinct() - Method in class io.trino.spi.connector.AggregateFunction
- isEmpty() - Method in class io.trino.spi.block.PageBuilderStatus
- isEmpty() - Method in class io.trino.spi.connector.SchemaTablePrefix
- isEmpty() - Method in class io.trino.spi.PageBuilder
- isEmpty() - Method in class io.trino.spi.statistics.TableStatistics
- isEmpty() - Method in class io.trino.spi.statistics.TableStatisticsMetadata
- isFatal() - Method in class io.trino.spi.ErrorCode
- isFinal() - Method in class io.trino.spi.exchange.ExchangeSourceOutputSelector
- isFinished() - Method in interface io.trino.spi.connector.ConnectorPageSource
-
Will this page source product more pages?
- isFinished() - Method in interface io.trino.spi.connector.ConnectorSplitSource
-
Returns whether any more
ConnectorSplit
may be produced. - isFinished() - Method in class io.trino.spi.connector.EmptyPageSource
- isFinished() - Method in class io.trino.spi.connector.FixedPageSource
- isFinished() - Method in class io.trino.spi.connector.FixedSplitSource
- isFinished() - Method in class io.trino.spi.connector.RecordPageSource
- isFinished() - Method in interface io.trino.spi.exchange.ExchangeSource
-
Once isFinished returns true,
ExchangeSource.read()
will never return a non-null result - isFlatVariableWidth() - Method in class io.trino.spi.type.AbstractVariableWidthType
- isFlatVariableWidth() - Method in class io.trino.spi.type.ArrayType
- isFlatVariableWidth() - Method in interface io.trino.spi.type.FixedWidthType
- isFlatVariableWidth() - Method in class io.trino.spi.type.MapType
- isFlatVariableWidth() - Method in class io.trino.spi.type.RowType
- isFlatVariableWidth() - Method in interface io.trino.spi.type.Type
-
Returns true if this type is variable width when written to a flat buffer.
- isFloatingPointNaN(Type, Object) - Static method in class io.trino.spi.type.TypeUtils
- isFull() - Method in class io.trino.spi.block.PageBuilderStatus
- isFull() - Method in class io.trino.spi.PageBuilder
- isGrantable() - Method in class io.trino.spi.security.RoleGrant
- isGrantOption() - Method in class io.trino.spi.security.PrivilegeInfo
- isHandleUpdateRequired() - Method in interface io.trino.spi.exchange.ExchangeSink
-
Returns
true
whenExchangeSinkInstanceHandle
needs to be updated throughExchangeSink.updateHandle(ExchangeSinkInstanceHandle)
to make further progress - isHashTablesPresent() - Method in class io.trino.spi.block.MapBlock
- isHidden() - Method in class io.trino.spi.connector.ColumnMetadata
- isHidden() - Method in class io.trino.spi.connector.ColumnSchema
- isHidden() - Method in class io.trino.spi.function.FunctionMetadata
- isHidden() - Method in class io.trino.spi.session.PropertyMetadata
-
Is this property hidden from users?
- isHighInclusive() - Method in class io.trino.spi.predicate.Range
- isHighUnbounded() - Method in class io.trino.spi.predicate.Range
- isInclusive() - Method in interface io.trino.spi.predicate.DiscreteValues
- isInternal() - Method in enum class io.trino.spi.connector.CatalogHandle.CatalogHandleType
- isLimitGuaranteed() - Method in class io.trino.spi.connector.LimitApplicationResult
- isLoaded() - Method in class io.trino.spi.block.ArrayBlock
- isLoaded() - Method in interface io.trino.spi.block.Block
-
Returns true if block data is fully loaded into memory.
- isLoaded() - Method in class io.trino.spi.block.DictionaryBlock
- isLoaded() - Method in class io.trino.spi.block.LazyBlock
- isLoaded() - Method in class io.trino.spi.block.MapBlock
- isLoaded() - Method in class io.trino.spi.block.RowBlock
- isLoaded() - Method in class io.trino.spi.block.RunLengthEncodedBlock
- isLongLiteral() - Method in class io.trino.spi.type.TypeParameter
- isLongLiteral() - Method in class io.trino.spi.type.TypeSignatureParameter
- isLowInclusive() - Method in class io.trino.spi.predicate.Range
- isLowUnbounded() - Method in class io.trino.spi.predicate.Range
- isNamedTypeSignature() - Method in class io.trino.spi.type.TypeSignatureParameter
- isNegative() - Method in class io.trino.spi.type.Int128
- isNoMoreSplits() - Method in class io.trino.spi.connector.ConnectorSplitSource.ConnectorSplitBatch
- isNone() - Method in class io.trino.spi.predicate.AllOrNoneValueSet
- isNone() - Method in class io.trino.spi.predicate.Domain
- isNone() - Method in class io.trino.spi.predicate.EquatableValueSet
- isNone() - Method in class io.trino.spi.predicate.SortedRangeSet
- isNone() - Method in class io.trino.spi.predicate.TupleDomain
-
Returns true if no tuple could ever satisfy this TupleDomain
- isNone() - Method in interface io.trino.spi.predicate.ValueSet
- isNull() - Method in interface io.trino.spi.function.InOut
- isNull() - Method in class io.trino.spi.predicate.NullableValue
- isNull(int) - Method in class io.trino.spi.block.ArrayBlock
- isNull(int) - Method in interface io.trino.spi.block.Block
-
Is the specified position null?
- isNull(int) - Method in class io.trino.spi.block.ByteArrayBlock
- isNull(int) - Method in class io.trino.spi.block.ColumnarArray
- isNull(int) - Method in class io.trino.spi.block.ColumnarMap
- isNull(int) - Method in class io.trino.spi.block.DictionaryBlock
- isNull(int) - Method in class io.trino.spi.block.Fixed12Block
- isNull(int) - Method in class io.trino.spi.block.Int128ArrayBlock
- isNull(int) - Method in class io.trino.spi.block.IntArrayBlock
- isNull(int) - Method in class io.trino.spi.block.LazyBlock
- isNull(int) - Method in class io.trino.spi.block.LongArrayBlock
- isNull(int) - Method in class io.trino.spi.block.MapBlock
- isNull(int) - Method in class io.trino.spi.block.RowBlock
- isNull(int) - Method in class io.trino.spi.block.RunLengthEncodedBlock
- isNull(int) - Method in class io.trino.spi.block.ShortArrayBlock
- isNull(int) - Method in class io.trino.spi.block.VariableWidthBlock
- isNull(int) - Method in class io.trino.spi.connector.InMemoryRecordSet.InMemoryRecordCursor
- isNull(int) - Method in interface io.trino.spi.connector.RecordCursor
- isNull(int, int) - Method in interface io.trino.spi.function.WindowIndex
-
Check if a value is null.
- IsNull - Annotation Interface in io.trino.spi.function
- isNullable() - Method in class io.trino.spi.connector.ColumnMetadata
- isNullable() - Method in enum class io.trino.spi.function.InvocationConvention.InvocationArgumentConvention
- isNullable() - Method in enum class io.trino.spi.function.InvocationConvention.InvocationReturnConvention
- isNullableDiscreteSet() - Method in class io.trino.spi.predicate.Domain
- isNullableSingleValue() - Method in class io.trino.spi.predicate.Domain
- isNullAllowed() - Method in class io.trino.spi.predicate.Domain
- isNullsFirst() - Method in enum class io.trino.spi.connector.SortOrder
- IsolationLevel - Enum Class in io.trino.spi.transaction
- isOnlyNull() - Method in class io.trino.spi.predicate.Domain
- isOptional() - Method in class io.trino.spi.function.FunctionDependencyDeclaration.CastDependency
- isOptional() - Method in class io.trino.spi.function.FunctionDependencyDeclaration.FunctionDependency
- isOptional() - Method in class io.trino.spi.function.FunctionDependencyDeclaration.OperatorDependency
- isOrderable() - Method in class io.trino.spi.type.AbstractIntType
- isOrderable() - Method in class io.trino.spi.type.AbstractLongType
- isOrderable() - Method in class io.trino.spi.type.AbstractType
- isOrderable() - Method in class io.trino.spi.type.ArrayType
- isOrderable() - Method in class io.trino.spi.type.BooleanType
- isOrderable() - Method in class io.trino.spi.type.CharType
- isOrderable() - Method in class io.trino.spi.type.DecimalType
- isOrderable() - Method in class io.trino.spi.type.DoubleType
- isOrderable() - Method in class io.trino.spi.type.RowType
- isOrderable() - Method in class io.trino.spi.type.SmallintType
- isOrderable() - Method in class io.trino.spi.type.TimestampType
- isOrderable() - Method in class io.trino.spi.type.TimestampWithTimeZoneType
- isOrderable() - Method in class io.trino.spi.type.TimeWithTimeZoneType
- isOrderable() - Method in class io.trino.spi.type.TinyintType
- isOrderable() - Method in interface io.trino.spi.type.Type
-
True if the type supports compareTo.
- isOrderable() - Method in class io.trino.spi.type.TypeOperatorDeclaration
- isOrderable() - Method in class io.trino.spi.type.UuidType
- isOrderable() - Method in class io.trino.spi.type.VarbinaryType
- isOrderable() - Method in class io.trino.spi.type.VarcharType
- isOrderableRequired() - Method in class io.trino.spi.function.TypeVariableConstraint
- isOrderSensitive() - Method in class io.trino.spi.connector.ConstantProperty
- isOrderSensitive() - Method in class io.trino.spi.connector.GroupingProperty
- isOrderSensitive() - Method in interface io.trino.spi.connector.LocalProperty
-
Returns true if reordering breaks this LocalProperty
- isOrderSensitive() - Method in class io.trino.spi.connector.SortingProperty
- isOrderSensitive() - Element in annotation interface io.trino.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
- isOrderSensitive() - Method in class io.trino.spi.function.AggregationFunctionMetadata
- isPassThroughColumns() - Method in class io.trino.spi.function.table.TableArgumentSpecification
- isPerTaskWriterScalingEnabled() - Method in record class io.trino.spi.connector.WriterScalingOptions
-
Returns the value of the
isPerTaskWriterScalingEnabled
record component. - isPrecalculateStatistics() - Method in class io.trino.spi.connector.AggregationApplicationResult
- isPrecalculateStatistics() - Method in class io.trino.spi.connector.ConstraintApplicationResult
- isPrecalculateStatistics() - Method in class io.trino.spi.connector.JoinApplicationResult
- isPrecalculateStatistics() - Method in class io.trino.spi.connector.LimitApplicationResult
- isPrecalculateStatistics() - Method in class io.trino.spi.connector.ProjectionApplicationResult
- isPrecalculateStatistics() - Method in class io.trino.spi.connector.SampleApplicationResult
- isPrecalculateStatistics() - Method in class io.trino.spi.connector.TopNApplicationResult
- isPruneWhenEmpty() - Method in class io.trino.spi.function.table.TableArgumentSpecification
- isReadsData() - Method in class io.trino.spi.connector.TableProcedureExecutionMode
- isRemotelyAccessible() - Method in interface io.trino.spi.connector.ConnectorSplit
-
Returns true when this ConnectorSplit can be scheduled on any node.
- isRequired() - Method in class io.trino.spi.function.table.ArgumentSpecification
- isReturnNullable() - Method in class io.trino.spi.function.FunctionNullability
- isRowSemantics() - Method in class io.trino.spi.function.table.TableArgumentSpecification
- isRunAsInvoker() - Method in class io.trino.spi.connector.ConnectorViewDefinition
- isShort() - Method in class io.trino.spi.type.DecimalType
- isShort() - Method in class io.trino.spi.type.TimestampType
- isShort() - Method in class io.trino.spi.type.TimestampWithTimeZoneType
- isShort() - Method in class io.trino.spi.type.TimeWithTimeZoneType
- isSimplifiedBy(LocalProperty<E>) - Method in class io.trino.spi.connector.ConstantProperty
- isSimplifiedBy(LocalProperty<E>) - Method in class io.trino.spi.connector.GroupingProperty
- isSimplifiedBy(LocalProperty<E>) - Method in interface io.trino.spi.connector.LocalProperty
-
Return true if the actual LocalProperty can be used to simplify this LocalProperty
- isSimplifiedBy(LocalProperty<E>) - Method in class io.trino.spi.connector.SortingProperty
- isSingleNode() - Method in interface io.trino.spi.connector.ConnectorPartitioningHandle
- isSingleSplitPerPartition() - Method in class io.trino.spi.connector.ConnectorTablePartitioning
- isSingleStatementWritesOnly() - Method in interface io.trino.spi.connector.Connector
-
True if the connector only supports write statements in independent transactions.
- isSingleValue() - Method in class io.trino.spi.predicate.AllOrNoneValueSet
- isSingleValue() - Method in class io.trino.spi.predicate.Domain
- isSingleValue() - Method in class io.trino.spi.predicate.EquatableValueSet
- isSingleValue() - Method in class io.trino.spi.predicate.Range
- isSingleValue() - Method in class io.trino.spi.predicate.SortedRangeSet
- isSingleValue() - Method in interface io.trino.spi.predicate.ValueSet
- isTopNGuaranteed() - Method in class io.trino.spi.connector.TopNApplicationResult
- isTyped() - Method in class io.trino.spi.function.table.Descriptor
- isTypeSignature() - Method in class io.trino.spi.type.TypeSignatureParameter
- isUnbounded() - Method in class io.trino.spi.type.VarcharType
- isUnknown() - Method in class io.trino.spi.statistics.Estimate
- isUsedInput() - Method in class io.trino.spi.function.table.TableFunctionProcessorState.Processed
- isUtcZoneId(String) - Static method in class io.trino.spi.type.TimeZoneKey
- isVariable() - Method in class io.trino.spi.type.TypeSignatureParameter
- isVariableArity() - Method in class io.trino.spi.function.Signature
- isView(ConnectorSession, SchemaTableName) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Is the specified table a view.
- isWriterTasksScalingEnabled() - Method in record class io.trino.spi.connector.WriterScalingOptions
-
Returns the value of the
isWriterTasksScalingEnabled
record component. - isZero() - Method in class io.trino.spi.type.Int128
J
- javaUuidToTrinoUuid(UUID) - Static method in class io.trino.spi.type.UuidType
- JoinApplicationResult<T> - Class in io.trino.spi.connector
- JoinApplicationResult(T, Map<ColumnHandle, ColumnHandle>, Map<ColumnHandle, ColumnHandle>, boolean) - Constructor for class io.trino.spi.connector.JoinApplicationResult
- JoinCondition - Class in io.trino.spi.connector
-
Deprecated.
- JoinCondition(JoinCondition.Operator, ConnectorExpression, ConnectorExpression) - Constructor for class io.trino.spi.connector.JoinCondition
-
Deprecated.
- JoinCondition.Operator - Enum Class in io.trino.spi.connector
-
Deprecated.
- JoinStatistics - Interface in io.trino.spi.connector
-
Represents estimated statistics for join node and left and right table passed to
ConnectorMetadata.applyJoin(ConnectorSession, JoinType, ConnectorTableHandle, ConnectorTableHandle, List, Map, Map, JoinStatistics)
- JoinType - Enum Class in io.trino.spi.connector
- JSON - Static variable in class io.trino.spi.type.StandardTypes
- JSON_2016 - Static variable in class io.trino.spi.type.StandardTypes
- JSON_INPUT_CONVERSION_ERROR - Enum constant in enum class io.trino.spi.StandardErrorCode
- JSON_OUTPUT_CONVERSION_ERROR - Enum constant in enum class io.trino.spi.StandardErrorCode
- JSON_VALUE_RESULT_ERROR - Enum constant in enum class io.trino.spi.StandardErrorCode
- jsonValue() - Method in class io.trino.spi.type.TypeSignature
- jsonValue() - Method in class io.trino.spi.type.TypeSignatureParameter
K
- keepWhenEmpty() - Method in class io.trino.spi.function.table.TableArgumentSpecification.Builder
L
- lambdaInterfaces(Class<?>...) - Method in class io.trino.spi.function.AggregationImplementation.Builder
- lambdaInterfaces(List<Class<?>>) - Method in class io.trino.spi.function.AggregationImplementation.Builder
- lambdaInterfaces(List<Class<?>>) - Method in class io.trino.spi.function.ScalarFunctionImplementation.Builder
- LanguageFunction - Record Class in io.trino.spi.function
- LanguageFunction(String, String, List<CatalogSchemaName>, Optional<String>) - Constructor for record class io.trino.spi.function.LanguageFunction
-
Creates an instance of a
LanguageFunction
record class. - languageFunctionExists(ConnectorSession, SchemaFunctionName, String) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Check if a language function exists.
- lastBatch() - Method in record class io.trino.spi.exchange.ExchangeSourceHandleSource.ExchangeSourceHandleBatch
-
Returns the value of the
lastBatch
record component. - LazyBlock - Class in io.trino.spi.block
- LazyBlock(int, LazyBlockLoader) - Constructor for class io.trino.spi.block.LazyBlock
- LazyBlockEncoding - Class in io.trino.spi.block
- LazyBlockEncoding() - Constructor for class io.trino.spi.block.LazyBlockEncoding
- LazyBlockLoader - Interface in io.trino.spi.block
- LEFT_OUTER - Enum constant in enum class io.trino.spi.connector.JoinType
- LESS_THAN - Enum constant in enum class io.trino.spi.connector.JoinCondition.Operator
-
Deprecated.
- LESS_THAN - Enum constant in enum class io.trino.spi.function.OperatorType
- LESS_THAN_OPERATOR_FUNCTION_NAME - Static variable in class io.trino.spi.expression.StandardFunctions
- LESS_THAN_OR_EQUAL - Enum constant in enum class io.trino.spi.connector.JoinCondition.Operator
-
Deprecated.
- LESS_THAN_OR_EQUAL - Enum constant in enum class io.trino.spi.function.OperatorType
- LESS_THAN_OR_EQUAL_OPERATOR_FUNCTION_NAME - Static variable in class io.trino.spi.expression.StandardFunctions
- lessThan(long, long) - Static method in class io.trino.spi.type.TimeType
- lessThan(Type, Object) - Static method in class io.trino.spi.predicate.Range
- lessThanOrEqual(long, long) - Static method in class io.trino.spi.type.TimeType
- lessThanOrEqual(Type, Object) - Static method in class io.trino.spi.predicate.Range
- LIKE_FUNCTION_NAME - Static variable in class io.trino.spi.expression.StandardFunctions
- LimitApplicationResult<T> - Class in io.trino.spi.connector
- LimitApplicationResult(T, boolean, boolean) - Constructor for class io.trino.spi.connector.LimitApplicationResult
- listApplicableRoles(ConnectorSession, TrinoPrincipal) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
List applicable roles, including the transitive grants, for the specified principal
- listEnabledRoles(ConnectorSession) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
List applicable roles, including the transitive grants, in given session
- listenForLoads(Block, Consumer<Block>) - Static method in class io.trino.spi.block.LazyBlock
- listFunctions(ConnectorSession, String) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
List available functions.
- listLanguageFunctions(ConnectorSession, String) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
List available language functions.
- listMaterializedViews(ConnectorSession, Optional<String>) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
List materialized view names, possibly filtered by schema.
- listRoleGrants(ConnectorSession, TrinoPrincipal) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
List role grants for a given principal, not recursively.
- listRoles(ConnectorSession) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
List available roles.
- listSchemaNames(ConnectorSession) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Returns the schemas provided by this connector.
- listTableColumns(ConnectorSession, SchemaTablePrefix) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Deprecated.use
ConnectorMetadata.streamTableColumns(io.trino.spi.connector.ConnectorSession, io.trino.spi.connector.SchemaTablePrefix)
which handles redirected tables - listTablePrivileges(ConnectorSession, SchemaTablePrefix) - Method in interface io.trino.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.trino.spi.connector.ConnectorMetadata
-
List table, view and materialized view names, possibly filtered by schema.
- listViews(ConnectorSession, Optional<String>) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
List view names (but not materialized views), possibly filtered by schema.
- LiteralParameter - Annotation Interface in io.trino.spi.function
- LiteralParameters - Annotation Interface in io.trino.spi.function
- load() - Method in interface io.trino.spi.block.LazyBlockLoader
-
Loads a lazy block.
- loadProperties() - Method in interface io.trino.spi.catalog.CatalogStore.StoredCatalog
- LocalProperty<E> - Interface in io.trino.spi.connector
- Location - Class in io.trino.spi
- Location(int, int) - Constructor for class io.trino.spi.Location
- LONG - Enum constant in enum class io.trino.spi.type.ParameterKind
- LongArrayBlock - Class in io.trino.spi.block
- LongArrayBlock(int, Optional<boolean[]>, long[]) - Constructor for class io.trino.spi.block.LongArrayBlock
- LongArrayBlockBuilder - Class in io.trino.spi.block
- LongArrayBlockBuilder(BlockBuilderStatus, int) - Constructor for class io.trino.spi.block.LongArrayBlockBuilder
- LongArrayBlockEncoding - Class in io.trino.spi.block
- LongArrayBlockEncoding() - Constructor for class io.trino.spi.block.LongArrayBlockEncoding
- longDecimalToDouble(Int128, long) - Static method in class io.trino.spi.type.DecimalConversions
- longDecimalToReal(Int128, long) - Static method in class io.trino.spi.type.DecimalConversions
- LongDistribution - Class in io.trino.spi.eventlistener
- LongDistribution(long, long, long, long, long, long, long, long, long, double) - Constructor for class io.trino.spi.eventlistener.LongDistribution
- longProperty(String, String, Long, boolean) - Static method in class io.trino.spi.session.PropertyMetadata
- longProperty(String, String, Long, Consumer<Long>, boolean) - Static method in class io.trino.spi.session.PropertyMetadata
- LongSymmetricDistribution - Class in io.trino.spi.eventlistener
- LongSymmetricDistribution(long, long, long, long, long, long, long, long, long, long, long, long, double) - Constructor for class io.trino.spi.eventlistener.LongSymmetricDistribution
- longTenToNth(int) - Static method in class io.trino.spi.type.Decimals
- LongTimestamp - Class in io.trino.spi.type
- LongTimestamp(long, int) - Constructor for class io.trino.spi.type.LongTimestamp
- LongTimestampWithTimeZone - Class in io.trino.spi.type
- LongTimeWithTimeZone - Class in io.trino.spi.type
- LongTimeWithTimeZone(long, int) - Constructor for class io.trino.spi.type.LongTimeWithTimeZone
- longToLongCast(Int128, long, long, long, long) - Static method in class io.trino.spi.type.DecimalConversions
- longToShortCast(Int128, long, long, long, long) - Static method in class io.trino.spi.type.DecimalConversions
- longVariable(String) - Method in class io.trino.spi.function.Signature.Builder
- longVariable(String, String) - Method in class io.trino.spi.function.Signature.Builder
- LongVariableConstraint - Class in io.trino.spi.function
- lookup(RecordSet) - Method in interface io.trino.spi.connector.ConnectorIndex
M
- makeCompatiblePartitioning(ConnectorSession, ConnectorTableHandle, ConnectorPartitioningHandle) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Return a table handle whose partitioning is converted to the provided partitioning handle, but otherwise identical to the provided table handle.
- MAP - Static variable in class io.trino.spi.type.StandardTypes
- MapBlock - Class in io.trino.spi.block
- MapBlockBuilder - Class in io.trino.spi.block
- MapBlockBuilder(MapType, BlockBuilderStatus, int) - Constructor for class io.trino.spi.block.MapBlockBuilder
- MapBlockEncoding - Class in io.trino.spi.block
- MapBlockEncoding() - Constructor for class io.trino.spi.block.MapBlockEncoding
- MapHashTables - Class in io.trino.spi.block
- MapHashTables.HashBuildMode - Enum Class in io.trino.spi.block
- mapType(TypeSignature, TypeSignature) - Static method in class io.trino.spi.type.TypeSignature
- MapType - Class in io.trino.spi.type
- MapType(Type, Type, TypeOperators) - Constructor for class io.trino.spi.type.MapType
- MapValueBuilder<E> - Interface in io.trino.spi.block
- match(SelectionCriteria) - Method in interface io.trino.spi.resourcegroups.ResourceGroupConfigurationManager
-
This method is called for every query that is submitted, so it should be fast.
- matches(SchemaTableName) - Method in class io.trino.spi.connector.SchemaTablePrefix
- MATERIALIZED_VIEW - Enum constant in enum class io.trino.spi.connector.RelationType
- MATERIALIZED_VIEW_GRACE_PERIOD - Enum constant in enum class io.trino.spi.connector.ConnectorCapabilities
- materializedViewColumns() - Method in record class io.trino.spi.connector.RelationColumnsMetadata
-
Returns the value of the
materializedViewColumns
record component. - MaterializedViewFreshness - Class in io.trino.spi.connector
- MaterializedViewFreshness(MaterializedViewFreshness.Freshness, Optional<Instant>) - Constructor for class io.trino.spi.connector.MaterializedViewFreshness
- MaterializedViewFreshness.Freshness - Enum Class in io.trino.spi.connector
- MaterializedViewNotFoundException - Exception Class in io.trino.spi.connector
- MaterializedViewNotFoundException(SchemaTableName) - Constructor for exception class io.trino.spi.connector.MaterializedViewNotFoundException
- MaterializedViewNotFoundException(SchemaTableName, String) - Constructor for exception class io.trino.spi.connector.MaterializedViewNotFoundException
- MaterializedViewNotFoundException(SchemaTableName, String, Throwable) - Constructor for exception class io.trino.spi.connector.MaterializedViewNotFoundException
- MaterializedViewNotFoundException(SchemaTableName, Throwable) - Constructor for exception class io.trino.spi.connector.MaterializedViewNotFoundException
- MaterializedViewReferenceInfo - Record Class in io.trino.spi.eventlistener
-
This class is JSON serializable for convenience and serialization compatibility is not guaranteed across versions.
- MaterializedViewReferenceInfo(String, String, String) - Constructor for record class io.trino.spi.eventlistener.MaterializedViewReferenceInfo
-
Creates an instance of a
MaterializedViewReferenceInfo
record class. - MAX_LENGTH - Static variable in class io.trino.spi.type.CharType
- MAX_LENGTH - Static variable in class io.trino.spi.type.VarcharType
- MAX_PRECISION - Static variable in class io.trino.spi.type.Decimals
- MAX_PRECISION - Static variable in class io.trino.spi.type.TimestampType
- MAX_PRECISION - Static variable in class io.trino.spi.type.TimestampWithTimeZoneType
- MAX_PRECISION - Static variable in class io.trino.spi.type.TimeType
- MAX_PRECISION - Static variable in class io.trino.spi.type.TimeWithTimeZoneType
- MAX_SHORT_PRECISION - Static variable in class io.trino.spi.type.Decimals
- MAX_SHORT_PRECISION - Static variable in class io.trino.spi.type.TimestampType
- MAX_SHORT_PRECISION - Static variable in class io.trino.spi.type.TimestampWithTimeZoneType
- MAX_SHORT_PRECISION - Static variable in class io.trino.spi.type.TimeWithTimeZoneType
- MAX_TIME_ZONE_KEY - Static variable in class io.trino.spi.type.TimeZoneKey
- MAX_UNSCALED_DECIMAL - Static variable in class io.trino.spi.type.Decimals
- MAX_VALUE - Enum constant in enum class io.trino.spi.statistics.ColumnStatisticType
- MAX_VALUE - Static variable in class io.trino.spi.type.Int128
- MAX_VALUE_SIZE_IN_BYTES - Enum constant in enum class io.trino.spi.statistics.ColumnStatisticType
- maximal(List<TupleDomain<T>>) - Static method in class io.trino.spi.predicate.TupleDomain
-
Returns the tuple domain that contains all other tuple domains, or
Optional.empty()
if they are not supersets of each other. - mayHaveNull() - Method in class io.trino.spi.block.ArrayBlock
- mayHaveNull() - Method in interface io.trino.spi.block.Block
-
Is it possible the block may have a null value?
- mayHaveNull() - Method in class io.trino.spi.block.ByteArrayBlock
- mayHaveNull() - Method in class io.trino.spi.block.ColumnarArray
- mayHaveNull() - Method in class io.trino.spi.block.ColumnarMap
- mayHaveNull() - Method in class io.trino.spi.block.DictionaryBlock
- mayHaveNull() - Method in class io.trino.spi.block.Fixed12Block
- mayHaveNull() - Method in class io.trino.spi.block.Int128ArrayBlock
- mayHaveNull() - Method in class io.trino.spi.block.IntArrayBlock
- mayHaveNull() - Method in class io.trino.spi.block.LazyBlock
- mayHaveNull() - Method in class io.trino.spi.block.LongArrayBlock
- mayHaveNull() - Method in class io.trino.spi.block.MapBlock
- mayHaveNull() - Method in class io.trino.spi.block.RowBlock
- mayHaveNull() - Method in class io.trino.spi.block.RunLengthEncodedBlock
- mayHaveNull() - Method in class io.trino.spi.block.ShortArrayBlock
- mayHaveNull() - Method in class io.trino.spi.block.VariableWidthBlock
- meetsRequirementOf(IsolationLevel) - Method in enum class io.trino.spi.transaction.IsolationLevel
- MemoryAllocation - Class in io.trino.spi.memory
- MemoryAllocation(String, long) - Constructor for class io.trino.spi.memory.MemoryAllocation
- MemoryPoolInfo - Class in io.trino.spi.memory
- MemoryPoolInfo(long, long, long, Map<QueryId, Long>, Map<QueryId, List<MemoryAllocation>>, Map<QueryId, Long>, Map<String, Long>, Map<String, Long>) - Constructor for class io.trino.spi.memory.MemoryPoolInfo
- merge(ExchangeSourceOutputSelector) - Method in class io.trino.spi.exchange.ExchangeSourceOutputSelector
- MERGE - Enum constant in enum class io.trino.spi.resourcegroups.QueryType
- MERGE_TARGET_ROW_MULTIPLE_MATCHES - Enum constant in enum class io.trino.spi.StandardErrorCode
- Mergeable<T> - Interface in io.trino.spi
- MergePage - Class in io.trino.spi.connector
-
Separate deletions and insertions pages from a merge using
RowChangeParadigm.DELETE_ROW_AND_INSERT_ROW
. - mergeWith(Metrics) - Method in class io.trino.spi.metrics.Metrics
- mergeWith(List<T>) - Method in interface io.trino.spi.Mergeable
- mergeWith(T) - Method in interface io.trino.spi.Mergeable
-
Merges the current state with the state of the other instance, and returns the merged state.
- MetadataProvider - Interface in io.trino.spi.connector
- methodHandle(MethodHandle) - Method in class io.trino.spi.function.ScalarFunctionImplementation.Builder
- Metric<T> - Interface in io.trino.spi.metrics
- Metrics - Class in io.trino.spi.metrics
- Metrics(Map<String, Metric<?>>) - Constructor for class io.trino.spi.metrics.Metrics
- Metrics.Accumulator - Class in io.trino.spi.metrics
- MICROSECONDS_PER_DAY - Static variable in class io.trino.spi.type.Timestamps
- MICROSECONDS_PER_MILLISECOND - Static variable in class io.trino.spi.type.Timestamps
- MICROSECONDS_PER_SECOND - Static variable in class io.trino.spi.type.Timestamps
- MILLISECONDS_PER_DAY - Static variable in class io.trino.spi.type.Timestamps
- MILLISECONDS_PER_HOUR - Static variable in class io.trino.spi.type.Timestamps
- MILLISECONDS_PER_MINUTE - Static variable in class io.trino.spi.type.Timestamps
- MILLISECONDS_PER_SECOND - Static variable in class io.trino.spi.type.Timestamps
- MIN_UNSCALED_DECIMAL - Static variable in class io.trino.spi.type.Decimals
- MIN_VALUE - Enum constant in enum class io.trino.spi.statistics.ColumnStatisticType
-
Deprecated.
- MIN_VALUE - Static variable in class io.trino.spi.type.Int128
- MINUTES_PER_HOUR - Static variable in class io.trino.spi.type.Timestamps
- MISMATCHED_COLUMN_ALIASES - Enum constant in enum class io.trino.spi.StandardErrorCode
- MISSING_ARGUMENT - Enum constant in enum class io.trino.spi.StandardErrorCode
- MISSING_CATALOG_NAME - Enum constant in enum class io.trino.spi.StandardErrorCode
- MISSING_COLUMN_ALIASES - Enum constant in enum class io.trino.spi.StandardErrorCode
- MISSING_COLUMN_NAME - Enum constant in enum class io.trino.spi.StandardErrorCode
- MISSING_GROUP_BY - Enum constant in enum class io.trino.spi.StandardErrorCode
- MISSING_ORDER_BY - Enum constant in enum class io.trino.spi.StandardErrorCode
- MISSING_OVER - Enum constant in enum class io.trino.spi.StandardErrorCode
- MISSING_PATH_NAME - Enum constant in enum class io.trino.spi.StandardErrorCode
- MISSING_RETURN - Enum constant in enum class io.trino.spi.StandardErrorCode
- MISSING_RETURN_TYPE - Enum constant in enum class io.trino.spi.StandardErrorCode
- MISSING_ROW_PATTERN - Enum constant in enum class io.trino.spi.StandardErrorCode
- MISSING_SCHEMA_NAME - Enum constant in enum class io.trino.spi.StandardErrorCode
- MISSING_TABLE - Enum constant in enum class io.trino.spi.StandardErrorCode
- MISSING_VARIABLE_DEFINITIONS - Enum constant in enum class io.trino.spi.StandardErrorCode
- MODIFYING_ROWS_MESSAGE - Static variable in interface io.trino.spi.connector.ConnectorMetadata
- MODULUS - Enum constant in enum class io.trino.spi.function.OperatorType
- MODULUS_FUNCTION_NAME - Static variable in class io.trino.spi.expression.StandardFunctions
-
Arithmetic modulus.
- MULTI_CATALOG_WRITE_CONFLICT - Enum constant in enum class io.trino.spi.StandardErrorCode
- multipleValues(Type, List<?>) - Static method in class io.trino.spi.predicate.Domain
- multipleValues(Type, List<?>, boolean) - Static method in class io.trino.spi.predicate.Domain
- multiply(long, long) - Static method in class io.trino.spi.type.Int128Math
- multiply(long, long, long, long) - Static method in class io.trino.spi.type.Int128Math
- multiply(Int128, long) - Static method in class io.trino.spi.type.Int128Math
- multiply(Int128, Int128) - Static method in class io.trino.spi.type.Int128Math
- MULTIPLY - Enum constant in enum class io.trino.spi.function.OperatorType
- MULTIPLY_FUNCTION_NAME - Static variable in class io.trino.spi.expression.StandardFunctions
-
Arithmetic multiplication.
N
- name() - Method in interface io.trino.spi.catalog.CatalogStore.StoredCatalog
- name() - Method in record class io.trino.spi.connector.EntityKindAndName
-
Returns the value of the
name
record component. - name() - Method in record class io.trino.spi.connector.EntityPrivilege
-
Returns the value of the
name
record component. - name() - Method in record class io.trino.spi.connector.RelationColumnsMetadata
-
Returns the value of the
name
record component. - name() - Method in record class io.trino.spi.connector.RelationCommentMetadata
-
Returns the value of the
name
record component. - name() - Element in annotation interface io.trino.spi.function.FunctionDependency
- name() - Element in annotation interface io.trino.spi.function.TypeParameterSpecialization
- name() - Element in annotation interface io.trino.spi.function.WindowFunctionSignature
- name(String) - Method in class io.trino.spi.function.table.DescriptorArgumentSpecification.Builder
- name(String) - Method in class io.trino.spi.function.table.ScalarArgumentSpecification.Builder
- name(String) - Method in class io.trino.spi.function.table.TableArgumentSpecification.Builder
- NAME - Static variable in class io.trino.spi.block.ArrayBlockEncoding
- NAME - Static variable in class io.trino.spi.block.ByteArrayBlockEncoding
- NAME - Static variable in class io.trino.spi.block.DictionaryBlockEncoding
- NAME - Static variable in class io.trino.spi.block.Fixed12BlockEncoding
- NAME - Static variable in class io.trino.spi.block.Int128ArrayBlockEncoding
- NAME - Static variable in class io.trino.spi.block.IntArrayBlockEncoding
- NAME - Static variable in class io.trino.spi.block.LazyBlockEncoding
- NAME - Static variable in class io.trino.spi.block.LongArrayBlockEncoding
- NAME - Static variable in class io.trino.spi.block.MapBlockEncoding
- NAME - Static variable in class io.trino.spi.block.RowBlockEncoding
- NAME - Static variable in class io.trino.spi.block.RunLengthBlockEncoding
- NAME - Static variable in class io.trino.spi.block.ShortArrayBlockEncoding
- NAME - Static variable in class io.trino.spi.block.VariableWidthBlockEncoding
- NameAndPosition - Class in io.trino.spi.function.table
-
This class represents a descriptor field reference.
- NameAndPosition(String, int) - Constructor for class io.trino.spi.function.table.NameAndPosition
- NAMED_TYPE - Enum constant in enum class io.trino.spi.type.ParameterKind
- namedField(String, TypeSignature) - Static method in class io.trino.spi.type.TypeSignatureParameter
- NamedType - Class in io.trino.spi.type
- NamedType(Optional<RowFieldName>, Type) - Constructor for class io.trino.spi.type.NamedType
- namedTypeParameter(NamedTypeSignature) - Static method in class io.trino.spi.type.TypeSignatureParameter
- NamedTypeSignature - Class in io.trino.spi.type
- NamedTypeSignature(Optional<RowFieldName>, TypeSignature) - Constructor for class io.trino.spi.type.NamedTypeSignature
- NANOSECONDS_PER_DAY - Static variable in class io.trino.spi.type.Timestamps
- NANOSECONDS_PER_MICROSECOND - Static variable in class io.trino.spi.type.Timestamps
- NANOSECONDS_PER_MILLISECOND - Static variable in class io.trino.spi.type.Timestamps
- NANOSECONDS_PER_MINUTE - Static variable in class io.trino.spi.type.Timestamps
- NANOSECONDS_PER_SECOND - Static variable in class io.trino.spi.type.Timestamps
- nativeContainerType() - Element in annotation interface io.trino.spi.function.SqlType
- nativeContainerType() - Element in annotation interface io.trino.spi.function.TypeParameterSpecialization
- nativeValueToBlock(Type, Object) - Static method in class io.trino.spi.predicate.Utils
- negate(Int128) - Static method in class io.trino.spi.type.Int128Math
- NEGATE_FUNCTION_NAME - Static variable in class io.trino.spi.expression.StandardFunctions
-
Arithmetic unary minus.
- negateExact(Int128) - Static method in class io.trino.spi.type.Int128Math
- NEGATION - Enum constant in enum class io.trino.spi.function.OperatorType
- NESTED_AGGREGATION - Enum constant in enum class io.trino.spi.StandardErrorCode
- NESTED_RECURSIVE - Enum constant in enum class io.trino.spi.StandardErrorCode
- NESTED_ROW_PATTERN_RECOGNITION - Enum constant in enum class io.trino.spi.StandardErrorCode
- NESTED_WINDOW - Enum constant in enum class io.trino.spi.StandardErrorCode
- NEVER_NULL - Enum constant in enum class io.trino.spi.function.InvocationConvention.InvocationArgumentConvention
-
Argument must not be a boxed type.
- newBlockBuilderLike(int, BlockBuilderStatus) - Method in class io.trino.spi.block.ArrayBlockBuilder
- newBlockBuilderLike(int, BlockBuilderStatus) - Method in interface io.trino.spi.block.BlockBuilder
-
Creates a new block builder of the same type based on the current usage statistics of this block builder.
- newBlockBuilderLike(int, BlockBuilderStatus) - Method in class io.trino.spi.block.ByteArrayBlockBuilder
- newBlockBuilderLike(int, BlockBuilderStatus) - Method in class io.trino.spi.block.Fixed12BlockBuilder
- newBlockBuilderLike(int, BlockBuilderStatus) - Method in class io.trino.spi.block.Int128ArrayBlockBuilder
- newBlockBuilderLike(int, BlockBuilderStatus) - Method in class io.trino.spi.block.IntArrayBlockBuilder
- newBlockBuilderLike(int, BlockBuilderStatus) - Method in class io.trino.spi.block.LongArrayBlockBuilder
- newBlockBuilderLike(int, BlockBuilderStatus) - Method in class io.trino.spi.block.MapBlockBuilder
- newBlockBuilderLike(int, BlockBuilderStatus) - Method in class io.trino.spi.block.RowBlockBuilder
- newBlockBuilderLike(int, BlockBuilderStatus) - Method in class io.trino.spi.block.ShortArrayBlockBuilder
- newBlockBuilderLike(int, BlockBuilderStatus) - Method in class io.trino.spi.block.VariableWidthBlockBuilder
- newBlockBuilderLike(BlockBuilderStatus) - Method in interface io.trino.spi.block.BlockBuilder
- newInstance(int, long) - Static method in class io.trino.spi.type.SqlTime
- newInstance(int, long, int) - Static method in class io.trino.spi.type.SqlTimestamp
- newInstance(int, long, int) - Static method in class io.trino.spi.type.SqlTimeWithTimeZone
- newInstance(int, long, int, TimeZoneKey) - Static method in class io.trino.spi.type.SqlTimestampWithTimeZone
- NO_DEPENDENCIES - Static variable in class io.trino.spi.function.FunctionDependencyDeclaration
- NO_NODES_AVAILABLE - Enum constant in enum class io.trino.spi.StandardErrorCode
- NO_RETRIES - Enum constant in enum class io.trino.spi.connector.RetryMode
- NO_TYPE_OPERATOR_DECLARATION - Static variable in class io.trino.spi.type.TypeOperatorDeclaration
- Node - Interface in io.trino.spi
- NodeManager - Interface in io.trino.spi
- noDescription() - Method in class io.trino.spi.function.FunctionMetadata.Builder
- noMoreSinks() - Method in interface io.trino.spi.exchange.Exchange
-
Called when no more sinks will be added with
Exchange.addSink(int)
. - noMoreSourceHandles() - Method in interface io.trino.spi.exchange.ExchangeSource
-
Notify
ExchangeSource
that no moreExchangeSourceHandle
's will be added with theExchangeSource.addSourceHandles(List)
method. - NON_DISCRETE - Enum constant in enum class io.trino.spi.predicate.SortedRangeSet.DiscreteSetMarker
- nondeterministic() - Method in class io.trino.spi.function.FunctionMetadata.Builder
- none() - Static method in class io.trino.spi.predicate.TupleDomain
- none(Type) - Static method in class io.trino.spi.predicate.Domain
- none(Type) - Static method in interface io.trino.spi.predicate.ValueSet
- NONE - Enum constant in enum class io.trino.spi.security.SelectedRole.Type
- NOOP_METADATA_PROVIDER - Static variable in interface io.trino.spi.connector.MetadataProvider
- NORMAL - Enum constant in enum class io.trino.spi.connector.CatalogHandle.CatalogHandleType
- NOT_BLOCKED - Static variable in interface io.trino.spi.connector.ConnectorPageSink
- NOT_BLOCKED - Static variable in interface io.trino.spi.connector.ConnectorPageSource
- NOT_BLOCKED - Static variable in interface io.trino.spi.connector.DynamicFilter
- NOT_BLOCKED - Static variable in interface io.trino.spi.exchange.ExchangeSink
- NOT_BLOCKED - Static variable in interface io.trino.spi.exchange.ExchangeSource
- NOT_EQUAL - Enum constant in enum class io.trino.spi.connector.JoinCondition.Operator
-
Deprecated.
- NOT_EQUAL_OPERATOR_FUNCTION_NAME - Static variable in class io.trino.spi.expression.StandardFunctions
- NOT_FOUND - Enum constant in enum class io.trino.spi.StandardErrorCode
- NOT_FUNCTION_NAME - Static variable in class io.trino.spi.expression.StandardFunctions
-
$not is a function accepting boolean argument
- NOT_IN_TRANSACTION - Enum constant in enum class io.trino.spi.StandardErrorCode
- NOT_NULL_COLUMN_CONSTRAINT - Enum constant in enum class io.trino.spi.connector.ConnectorCapabilities
- NOT_SUPPORTED - Enum constant in enum class io.trino.spi.StandardErrorCode
- NotFoundException - Exception Class in io.trino.spi.connector
- NotFoundException() - Constructor for exception class io.trino.spi.connector.NotFoundException
- NotFoundException(String) - Constructor for exception class io.trino.spi.connector.NotFoundException
- NotFoundException(String, Throwable) - Constructor for exception class io.trino.spi.connector.NotFoundException
- NotFoundException(Throwable) - Constructor for exception class io.trino.spi.connector.NotFoundException
- notNull(Type) - Static method in class io.trino.spi.predicate.Domain
- NULL_DESCRIPTOR - Static variable in class io.trino.spi.function.table.DescriptorArgument
- NULL_FLAG - Enum constant in enum class io.trino.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.trino.spi.type.TypeUtils
- NULL_TREATMENT_NOT_ALLOWED - Enum constant in enum class io.trino.spi.StandardErrorCode
- nullable() - Method in class io.trino.spi.function.FunctionMetadata.Builder
- NULLABLE_RETURN - Enum constant in enum class io.trino.spi.function.InvocationConvention.InvocationReturnConvention
-
The function may return a null value.
- NullableValue - Class in io.trino.spi.predicate
- NullableValue(Type, Object) - Constructor for class io.trino.spi.predicate.NullableValue
- NullableValue.Serializable - Class in io.trino.spi.predicate
- NULLIF_FUNCTION_NAME - Static variable in class io.trino.spi.expression.StandardFunctions
-
$nullif is a function accepting two arguments.
- NUMBER_OF_DISTINCT_VALUES - Enum constant in enum class io.trino.spi.statistics.ColumnStatisticType
-
Deprecated.
- NUMBER_OF_DISTINCT_VALUES_SUMMARY - Enum constant in enum class io.trino.spi.statistics.ColumnStatisticType
- NUMBER_OF_NON_NULL_VALUES - Enum constant in enum class io.trino.spi.statistics.ColumnStatisticType
-
Deprecated.
- NUMBER_OF_TRUE_VALUES - Enum constant in enum class io.trino.spi.statistics.ColumnStatisticType
-
Deprecated.
- NUMERIC_VALUE_OUT_OF_RANGE - Enum constant in enum class io.trino.spi.StandardErrorCode
- numericParameter(long) - Static method in class io.trino.spi.type.TypeSignatureParameter
O
- of(double) - Static method in class io.trino.spi.statistics.Estimate
- of(long) - Static method in class io.trino.spi.type.TypeParameter
- of(long, int, int) - Static method in class io.trino.spi.type.SqlDecimal
- of(NamedType) - Static method in class io.trino.spi.type.TypeParameter
- of(Type) - Static method in class io.trino.spi.type.TypeParameter
- of(Type, Object) - Static method in class io.trino.spi.predicate.NullableValue
- of(Type, Object, Object...) - Static method in interface io.trino.spi.predicate.ValueSet
- of(TypeSignatureParameter, TypeManager) - Static method in class io.trino.spi.type.TypeParameter
- of(String) - Static method in class io.trino.spi.type.TypeId
- of(String) - Static method in class io.trino.spi.type.TypeParameter
- ofRanges(Range, Range...) - Static method in interface io.trino.spi.predicate.ValueSet
- ofRanges(List<Range>) - Static method in interface io.trino.spi.predicate.ValueSet
- ofUser(String) - Static method in class io.trino.spi.security.ConnectorIdentity
- ofUser(String) - Static method in class io.trino.spi.security.Identity
- ONE - Static variable in class io.trino.spi.type.Int128
- ONLY_PASS_THROUGH - Static variable in class io.trino.spi.function.table.ReturnTypeSpecification.OnlyPassThrough
- onlyNull(Type) - Static method in class io.trino.spi.predicate.Domain
- operator() - Element in annotation interface io.trino.spi.function.OperatorDependency
- OPERATOR_NOT_FOUND - Enum constant in enum class io.trino.spi.StandardErrorCode
- operatorBuilder(OperatorType) - Static method in class io.trino.spi.function.FunctionMetadata
- OperatorDependency - Annotation Interface in io.trino.spi.function
- OperatorMethodHandle - Class in io.trino.spi.function
- OperatorMethodHandle(InvocationConvention, MethodHandle) - Constructor for class io.trino.spi.function.OperatorMethodHandle
- OperatorType - Enum Class in io.trino.spi.function
- OPTIMIZER_TIMEOUT - Enum constant in enum class io.trino.spi.StandardErrorCode
- OR_FUNCTION_NAME - Static variable in class io.trino.spi.expression.StandardFunctions
-
$or is a vararg function accepting boolean arguments
- orderableRequired() - Method in class io.trino.spi.function.TypeVariableConstraint.TypeVariableConstraintBuilder
- orderableTypeParameter(String) - Method in class io.trino.spi.function.Signature.Builder
- orderBy(List<String>) - Method in class io.trino.spi.function.table.TableArgument.Builder
- orderSensitive() - Method in class io.trino.spi.function.AggregationFunctionMetadata.AggregationFunctionMetadataBuilder
- OUT_OF_SPILL_SPACE - Enum constant in enum class io.trino.spi.StandardErrorCode
- output(BlockBuilder) - Method in interface io.trino.spi.function.WindowAccumulator
-
Get the value of the accumulator.
- OutputColumnMetadata - Class in io.trino.spi.eventlistener
-
This class is JSON serializable for convenience and serialization compatibility is not guaranteed across versions.
- OutputColumnMetadata(String, String, Set<ColumnDetail>) - Constructor for class io.trino.spi.eventlistener.OutputColumnMetadata
- outputFunction(MethodHandle) - Method in class io.trino.spi.function.AggregationImplementation.Builder
- OutputFunction - Annotation Interface in io.trino.spi.function
- overflows(long, int) - Static method in class io.trino.spi.type.Decimals
- overflows(long, long) - Static method in class io.trino.spi.type.Decimals
- overflows(Int128) - Static method in class io.trino.spi.type.Decimals
- overflows(Int128, int) - Static method in class io.trino.spi.type.Decimals
- overflows(BigDecimal, long) - Static method in class io.trino.spi.type.Decimals
- overflows(BigInteger, int) - Static method in class io.trino.spi.type.Decimals
- overlaps(Domain) - Method in class io.trino.spi.predicate.Domain
- overlaps(Range) - Method in class io.trino.spi.predicate.Range
- overlaps(TupleDomain<T>) - Method in class io.trino.spi.predicate.TupleDomain
-
Returns true only if there exists a strict intersection between the TupleDomains.
- overlaps(ValueSet) - Method in class io.trino.spi.predicate.EquatableValueSet
- overlaps(ValueSet) - Method in class io.trino.spi.predicate.SortedRangeSet
- overlaps(ValueSet) - Method in interface io.trino.spi.predicate.ValueSet
- owner() - Method in record class io.trino.spi.function.LanguageFunction
-
Returns the value of the
owner
record component.
P
- P4_HYPER_LOG_LOG - Static variable in class io.trino.spi.type.P4HyperLogLogType
- P4_HYPER_LOG_LOG - Static variable in class io.trino.spi.type.StandardTypes
- P4HyperLogLogType - Class in io.trino.spi.type
- P4HyperLogLogType() - Constructor for class io.trino.spi.type.P4HyperLogLogType
- packDateTimeWithZone(long, int) - Static method in class io.trino.spi.type.DateTimeEncoding
- packDateTimeWithZone(long, short) - Static method in class io.trino.spi.type.DateTimeEncoding
- packDateTimeWithZone(long, TimeZoneKey) - Static method in class io.trino.spi.type.DateTimeEncoding
- packDateTimeWithZone(long, String) - Static method in class io.trino.spi.type.DateTimeEncoding
- packTimeWithTimeZone(long, int) - Static method in class io.trino.spi.type.DateTimeEncoding
- padSpaces(Slice, int) - Static method in class io.trino.spi.type.Chars
- padSpaces(Slice, CharType) - Static method in class io.trino.spi.type.Chars
- padSpaces(String, CharType) - Static method in class io.trino.spi.type.Chars
-
Pads String with spaces to given
CharType
's length in code points. - Page - Class in io.trino.spi
- Page(int) - Constructor for class io.trino.spi.Page
- Page(int, Block...) - Constructor for class io.trino.spi.Page
- Page(Block...) - Constructor for class io.trino.spi.Page
- PAGE_TOO_LARGE - Enum constant in enum class io.trino.spi.StandardErrorCode
- PAGE_TRANSPORT_ERROR - Enum constant in enum class io.trino.spi.StandardErrorCode
- PAGE_TRANSPORT_TIMEOUT - Enum constant in enum class io.trino.spi.StandardErrorCode
- PageBuilder - Class in io.trino.spi
- PageBuilder(int, List<? extends Type>) - Constructor for class io.trino.spi.PageBuilder
- PageBuilder(List<? extends Type>) - Constructor for class io.trino.spi.PageBuilder
-
Create a PageBuilder with given types.
- PageBuilderStatus - Class in io.trino.spi.block
- PageBuilderStatus() - Constructor for class io.trino.spi.block.PageBuilderStatus
- PageBuilderStatus(int) - Constructor for class io.trino.spi.block.PageBuilderStatus
- PageIndexer - Interface in io.trino.spi
- PageIndexerFactory - Interface in io.trino.spi
- PageSorter - Interface in io.trino.spi
- pageSource(ConnectorTransactionHandle, ConnectorSession, TupleDomain<Integer>) - Method in interface io.trino.spi.connector.SystemTable
-
Create a page source for the data in this table.
- ParameterKind - Enum Class in io.trino.spi.type
- parametricType(String, TypeSignature...) - Static method in class io.trino.spi.type.TypeSignature
- ParametricType - Interface in io.trino.spi.type
- parentGroupContext(SelectionContext<C>) - Method in interface io.trino.spi.resourcegroups.ResourceGroupConfigurationManager
-
This method is called when parent group of the one specified by
ResourceGroupConfigurationManager.match(SelectionCriteria)
'sSelectionContext.getResourceGroupId()
does not exist yet. - parse(String) - Static method in class io.trino.spi.type.Decimals
- parseDottedId(String, int, String) - Static method in class io.trino.spi.QueryId
- partitionBy(List<String>) - Method in class io.trino.spi.function.table.TableArgument.Builder
- passThroughColumns() - Method in class io.trino.spi.function.table.TableArgumentSpecification.Builder
- PasswordAuthenticator - Interface in io.trino.spi.security
- PasswordAuthenticatorFactory - Interface in io.trino.spi.security
- path() - Method in record class io.trino.spi.function.LanguageFunction
-
Returns the value of the
path
record component. - PATH_EVALUATION_ERROR - Enum constant in enum class io.trino.spi.StandardErrorCode
- PEAK_MEMORY - Static variable in class io.trino.spi.session.ResourceEstimates
- PERMISSION_DENIED - Enum constant in enum class io.trino.spi.StandardErrorCode
- perTaskMaxScaledWriterCount() - Method in record class io.trino.spi.connector.WriterScalingOptions
-
Returns the value of the
perTaskMaxScaledWriterCount
record component. - PICOSECONDS_PER_DAY - Static variable in class io.trino.spi.type.Timestamps
- PICOSECONDS_PER_HOUR - Static variable in class io.trino.spi.type.Timestamps
- PICOSECONDS_PER_MICROSECOND - Static variable in class io.trino.spi.type.Timestamps
- PICOSECONDS_PER_MILLISECOND - Static variable in class io.trino.spi.type.Timestamps
- PICOSECONDS_PER_MINUTE - Static variable in class io.trino.spi.type.Timestamps
- PICOSECONDS_PER_NANOSECOND - Static variable in class io.trino.spi.type.Timestamps
- PICOSECONDS_PER_SECOND - Static variable in class io.trino.spi.type.Timestamps
- Plugin - Interface in io.trino.spi
- PointerType - Enum Class in io.trino.spi.connector
-
This enum represents the type of pointer used in TableVersion.
- powerOfTen(int) - Static method in class io.trino.spi.type.Int128Math
- predicate() - Method in class io.trino.spi.connector.Constraint
-
A predicate that can be used to filter data.
- PREFIX - Static variable in exception class io.trino.spi.security.AccessDeniedException
- prependColumn(Block) - Method in class io.trino.spi.Page
- PrincipalType - Enum Class in io.trino.spi.security
- Privilege - Enum Class in io.trino.spi.security
- PrivilegeInfo - Class in io.trino.spi.security
- PrivilegeInfo(Privilege, boolean) - Constructor for class io.trino.spi.security.PrivilegeInfo
- PROCEDURE_CALL_FAILED - Enum constant in enum class io.trino.spi.StandardErrorCode
- PROCEDURE_NOT_FOUND - Enum constant in enum class io.trino.spi.StandardErrorCode
- process() - Method in interface io.trino.spi.function.table.TableFunctionSplitProcessor
-
This method processes a split.
- process(List<Optional<Page>>) - Method in interface io.trino.spi.function.table.TableFunctionDataProcessor
-
This method processes a portion of data.
- processRow(BlockBuilder, boolean, int, int) - Method in class io.trino.spi.function.RankingWindowFunction
-
Process a row by outputting the result of the window function.
- processRow(BlockBuilder, int, int, int) - Method in class io.trino.spi.function.ValueWindowFunction
-
Process a row by outputting the result of the window function.
- processRow(BlockBuilder, int, int, int, int) - Method in class io.trino.spi.function.RankingWindowFunction
- processRow(BlockBuilder, int, int, int, int) - Method in class io.trino.spi.function.ValueWindowFunction
- processRow(BlockBuilder, int, int, int, int) - Method in interface io.trino.spi.function.WindowFunction
-
Process a row by outputting the result of the window function.
- produced(Page) - Static method in class io.trino.spi.function.table.TableFunctionProcessorState.Processed
- ProjectionApplicationResult<T> - Class in io.trino.spi.connector
- ProjectionApplicationResult(T, List<ConnectorExpression>, List<Assignment>, boolean) - Constructor for class io.trino.spi.connector.ProjectionApplicationResult
- properties() - Method in record class io.trino.spi.catalog.CatalogProperties
-
Returns the value of the
properties
record component. - PropertyMetadata<T> - Class in io.trino.spi.session
- PropertyMetadata(String, String, Type, Class<T>, T, boolean, Function<Object, T>, Function<T, Object>) - Constructor for class io.trino.spi.session.PropertyMetadata
- pruneWhenEmpty() - Method in class io.trino.spi.function.table.TableArgumentSpecification.Builder
Q
- QDIGEST - Static variable in class io.trino.spi.type.QuantileDigestParametricType
- QDIGEST - Static variable in class io.trino.spi.type.StandardTypes
- QuantileDigestParametricType - Class in io.trino.spi.type
- QuantileDigestParametricType() - Constructor for class io.trino.spi.type.QuantileDigestParametricType
- QuantileDigestType - Class in io.trino.spi.type
- QuantileDigestType(Type) - Constructor for class io.trino.spi.type.QuantileDigestType
- QUERY_EXCEEDED_COMPILER_LIMIT - Enum constant in enum class io.trino.spi.StandardErrorCode
- QUERY_HAS_TOO_MANY_STAGES - Enum constant in enum class io.trino.spi.StandardErrorCode
- QUERY_PRIORITY - Enum constant in enum class io.trino.spi.resourcegroups.SchedulingPolicy
- QUERY_QUEUE_FULL - Enum constant in enum class io.trino.spi.StandardErrorCode
- QUERY_REJECTED - Enum constant in enum class io.trino.spi.StandardErrorCode
- QUERY_TEXT_TOO_LARGE - Enum constant in enum class io.trino.spi.StandardErrorCode
- queryCompleted(QueryCompletedEvent) - Method in interface io.trino.spi.eventlistener.EventListener
- QueryCompletedEvent - Class in io.trino.spi.eventlistener
-
This class is JSON serializable for convenience and serialization compatibility is not guaranteed across versions.
- QueryCompletedEvent(QueryMetadata, QueryStatistics, QueryContext, QueryIOMetadata, Optional<QueryFailureInfo>, List<TrinoWarning>, Instant, Instant, Instant) - Constructor for class io.trino.spi.eventlistener.QueryCompletedEvent
- QueryContext - Class in io.trino.spi.eventlistener
-
This class is JSON serializable for convenience and serialization compatibility is not guaranteed across versions.
- QueryContext(String, String, Optional<String>, Set<String>, Set<String>, Optional<String>, Optional<String>, Optional<String>, Optional<String>, Set<String>, Set<String>, Optional<String>, String, Optional<String>, Optional<String>, Optional<ResourceGroupId>, Map<String, String>, ResourceEstimates, String, String, String, Optional<QueryType>, String) - Constructor for class io.trino.spi.eventlistener.QueryContext
- queryCreated(QueryCreatedEvent) - Method in interface io.trino.spi.eventlistener.EventListener
- QueryCreatedEvent - Class in io.trino.spi.eventlistener
-
This class is JSON serializable for convenience and serialization compatibility is not guaranteed across versions.
- QueryCreatedEvent(Instant, QueryContext, QueryMetadata) - Constructor for class io.trino.spi.eventlistener.QueryCreatedEvent
- QueryFailureInfo - Class in io.trino.spi.eventlistener
-
This class is JSON serializable for convenience and serialization compatibility is not guaranteed across versions.
- QueryFailureInfo(ErrorCode, Optional<String>, Optional<String>, Optional<String>, Optional<String>, String) - Constructor for class io.trino.spi.eventlistener.QueryFailureInfo
- QueryId - Class in io.trino.spi
- QueryId(String) - Constructor for class io.trino.spi.QueryId
- QueryInputMetadata - Class in io.trino.spi.eventlistener
-
This class is JSON serializable for convenience and serialization compatibility is not guaranteed across versions.
- QueryInputMetadata(String, CatalogHandle.CatalogVersion, String, String, List<String>, Optional<Object>, Metrics, OptionalLong, OptionalLong) - Constructor for class io.trino.spi.eventlistener.QueryInputMetadata
- QueryIOMetadata - Class in io.trino.spi.eventlistener
-
This class is JSON serializable for convenience and serialization compatibility is not guaranteed across versions.
- QueryIOMetadata(List<QueryInputMetadata>, Optional<QueryOutputMetadata>) - Constructor for class io.trino.spi.eventlistener.QueryIOMetadata
- QueryMetadata - Class in io.trino.spi.eventlistener
-
This class is JSON serializable for convenience and serialization compatibility is not guaranteed across versions.
- QueryMetadata(String, Optional<String>, Optional<String>, String, Optional<String>, Optional<String>, String, List<TableInfo>, List<RoutineInfo>, URI, Optional<String>, Optional<String>, Supplier<Optional<String>>) - Constructor for class io.trino.spi.eventlistener.QueryMetadata
- QueryMetadata(String, Optional<String>, Optional<String>, String, Optional<String>, Optional<String>, String, List<TableInfo>, List<RoutineInfo>, URI, Optional<String>, Optional<String>, Optional<String>) - Constructor for class io.trino.spi.eventlistener.QueryMetadata
- QueryOutputMetadata - Class in io.trino.spi.eventlistener
-
This class is JSON serializable for convenience and serialization compatibility is not guaranteed across versions.
- QueryOutputMetadata(String, CatalogHandle.CatalogVersion, String, String, Optional<List<OutputColumnMetadata>>, Optional<String>, Optional<Boolean>) - Constructor for class io.trino.spi.eventlistener.QueryOutputMetadata
- QueryPlanOptimizerStatistics - Record Class in io.trino.spi.eventlistener
-
This class is JSON serializable for convenience and serialization compatibility is not guaranteed across versions.
- QueryPlanOptimizerStatistics(String, long, long, long, long) - Constructor for record class io.trino.spi.eventlistener.QueryPlanOptimizerStatistics
-
Creates an instance of a
QueryPlanOptimizerStatistics
record class. - QueryStatistics - Class in io.trino.spi.eventlistener
-
This class is JSON serializable for convenience and serialization compatibility is not guaranteed across versions.
- QueryStatistics(Duration, Duration, Duration, Duration, Optional<Duration>, Optional<Duration>, Optional<Duration>, Optional<Duration>, Optional<Duration>, Optional<Duration>, Optional<Duration>, Optional<Duration>, Optional<Duration>, Optional<Duration>, Optional<Duration>, Optional<Duration>, Optional<Duration>, long, long, long, long, long, long, long, long, long, long, long, long, long, long, long, long, double, double, List<StageGcStatistics>, int, boolean, List<StageCpuDistribution>, List<StageOutputBufferUtilization>, List<StageTaskStatistics>, Supplier<List<String>>, List<QueryPlanOptimizerStatistics>, Optional<String>) - Constructor for class io.trino.spi.eventlistener.QueryStatistics
- QueryStatistics(Duration, Duration, Duration, Duration, Optional<Duration>, Optional<Duration>, Optional<Duration>, Optional<Duration>, Optional<Duration>, Optional<Duration>, Optional<Duration>, Optional<Duration>, Optional<Duration>, Optional<Duration>, Optional<Duration>, Optional<Duration>, Optional<Duration>, long, long, long, long, long, long, long, long, long, long, long, long, long, long, long, long, double, double, List<StageGcStatistics>, int, boolean, List<StageCpuDistribution>, List<StageOutputBufferUtilization>, List<StageTaskStatistics>, List<String>, List<QueryPlanOptimizerStatistics>, Optional<String>) - Constructor for class io.trino.spi.eventlistener.QueryStatistics
- QueryType - Enum Class in io.trino.spi.resourcegroups
R
- randomDictionaryId() - Static method in class io.trino.spi.block.DictionaryId
- range(Type, Object, boolean, Object, boolean) - Static method in class io.trino.spi.predicate.Range
- Range - Class in io.trino.spi.predicate
-
A Range of values across the continuous space defined by the types of the Markers
- Range(Object, Object) - Constructor for class io.trino.spi.type.Type.Range
- Ranges - Interface in io.trino.spi.predicate
- RankingWindowFunction - Class in io.trino.spi.function
- RankingWindowFunction() - Constructor for class io.trino.spi.function.RankingWindowFunction
- rawValueForStandardSplitCount(int) - Static method in class io.trino.spi.SplitWeight
- rawValueSum(Collection<T>, Function<T, SplitWeight>) - Static method in class io.trino.spi.SplitWeight
- read() - Method in interface io.trino.spi.exchange.ExchangeSource
-
Gets the next chunk of data.
- READ_COMMITTED - Enum constant in enum class io.trino.spi.transaction.IsolationLevel
- READ_ONLY_VIOLATION - Enum constant in enum class io.trino.spi.StandardErrorCode
- READ_UNCOMMITTED - Enum constant in enum class io.trino.spi.transaction.IsolationLevel
- READ_VALUE - Enum constant in enum class io.trino.spi.function.OperatorType
- readBigDecimal(DecimalType, Block, int) - Static method in class io.trino.spi.type.Decimals
- readBlock(SliceInput) - Method in interface io.trino.spi.block.BlockEncodingSerde
-
Read a block encoding from the input.
- readBlock(BlockEncodingSerde, SliceInput) - Method in class io.trino.spi.block.ArrayBlockEncoding
- readBlock(BlockEncodingSerde, SliceInput) - Method in interface io.trino.spi.block.BlockEncoding
-
Read a block from the specified input.
- readBlock(BlockEncodingSerde, SliceInput) - Method in class io.trino.spi.block.ByteArrayBlockEncoding
- readBlock(BlockEncodingSerde, SliceInput) - Method in class io.trino.spi.block.DictionaryBlockEncoding
- readBlock(BlockEncodingSerde, SliceInput) - Method in class io.trino.spi.block.Fixed12BlockEncoding
- readBlock(BlockEncodingSerde, SliceInput) - Method in class io.trino.spi.block.Int128ArrayBlockEncoding
- readBlock(BlockEncodingSerde, SliceInput) - Method in class io.trino.spi.block.IntArrayBlockEncoding
- readBlock(BlockEncodingSerde, SliceInput) - Method in class io.trino.spi.block.LazyBlockEncoding
- readBlock(BlockEncodingSerde, SliceInput) - Method in class io.trino.spi.block.LongArrayBlockEncoding
- readBlock(BlockEncodingSerde, SliceInput) - Method in class io.trino.spi.block.MapBlockEncoding
- readBlock(BlockEncodingSerde, SliceInput) - Method in class io.trino.spi.block.RowBlockEncoding
- readBlock(BlockEncodingSerde, SliceInput) - Method in class io.trino.spi.block.RunLengthBlockEncoding
- readBlock(BlockEncodingSerde, SliceInput) - Method in class io.trino.spi.block.ShortArrayBlockEncoding
- readBlock(BlockEncodingSerde, SliceInput) - Method in class io.trino.spi.block.VariableWidthBlockEncoding
- readNativeValue(Type, Block, int) - Static method in class io.trino.spi.type.TypeUtils
-
Get the native value as an object in the value at
position
ofblock
. - readType(SliceInput) - Method in interface io.trino.spi.block.BlockEncodingSerde
-
Reads a type from the input.
- REAL - Static variable in class io.trino.spi.type.RealType
- REAL - Static variable in class io.trino.spi.type.StandardTypes
- realToLongDecimal(float, long, long) - Static method in class io.trino.spi.type.DecimalConversions
- realToShortDecimal(float, long, long) - Static method in class io.trino.spi.type.DecimalConversions
- RealType - Class in io.trino.spi.type
- RecordCursor - Interface in io.trino.spi.connector
- RecordPageSource - Class in io.trino.spi.connector
- RecordPageSource(RecordSet) - Constructor for class io.trino.spi.connector.RecordPageSource
- RecordPageSource(List<Type>, RecordCursor) - Constructor for class io.trino.spi.connector.RecordPageSource
- RecordSet - Interface in io.trino.spi.connector
- redirected() - Method in record class io.trino.spi.connector.RelationColumnsMetadata
-
Returns the value of the
redirected
record component. - redirectTable(ConnectorSession, SchemaTableName) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Redirects table to other table which may or may not be in the same catalog.
- REDUNDANT_ORDER_BY - Enum constant in enum class io.trino.spi.connector.StandardWarningCode
- refreshMaterializedView(ConnectorSession, SchemaTableName) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Refresh materialized view
- RefreshType - Enum Class in io.trino.spi
-
Signifies whether a Materialized View refresh operation could be done incrementally or only fully.
- RelationColumnsMetadata - Record Class in io.trino.spi.connector
- RelationColumnsMetadata(SchemaTableName, Optional<List<ConnectorMaterializedViewDefinition.Column>>, Optional<List<ConnectorViewDefinition.ViewColumn>>, Optional<List<ColumnMetadata>>, boolean) - Constructor for record class io.trino.spi.connector.RelationColumnsMetadata
-
Creates an instance of a
RelationColumnsMetadata
record class. - RelationCommentMetadata - Record Class in io.trino.spi.connector
- RelationCommentMetadata(SchemaTableName, boolean, Optional<String>) - Constructor for record class io.trino.spi.connector.RelationCommentMetadata
-
Creates an instance of a
RelationCommentMetadata
record class. - RelationType - Enum Class in io.trino.spi.connector
- relocateFlatVariableWidthOffsets(byte[], int, byte[], int) - Method in class io.trino.spi.type.AbstractVariableWidthType
- relocateFlatVariableWidthOffsets(byte[], int, byte[], int) - Method in class io.trino.spi.type.ArrayType
- relocateFlatVariableWidthOffsets(byte[], int, byte[], int) - Method in interface io.trino.spi.type.FixedWidthType
- relocateFlatVariableWidthOffsets(byte[], int, byte[], int) - Method in class io.trino.spi.type.MapType
- relocateFlatVariableWidthOffsets(byte[], int, byte[], int) - Method in class io.trino.spi.type.RowType
- relocateFlatVariableWidthOffsets(byte[], int, byte[], int) - Method in interface io.trino.spi.type.Type
-
Update the variable width offsets recorded in the value.
- remainder(long, long, int, long, long, int) - Static method in class io.trino.spi.type.Int128Math
- REMOTE_BUFFER_CLOSE_FAILED - Enum constant in enum class io.trino.spi.StandardErrorCode
- REMOTE_HOST_GONE - Enum constant in enum class io.trino.spi.StandardErrorCode
- REMOTE_TASK_ERROR - Enum constant in enum class io.trino.spi.StandardErrorCode
- REMOTE_TASK_FAILED - Enum constant in enum class io.trino.spi.StandardErrorCode
- REMOTE_TASK_MISMATCH - Enum constant in enum class io.trino.spi.StandardErrorCode
- removeCatalog(CatalogName) - Method in interface io.trino.spi.catalog.CatalogStore
-
Remove a catalog if present.
- removeInput(WindowIndex, int, int) - Method in interface io.trino.spi.function.WindowAccumulator
-
Remove the specified positions from the accumulator.
- renameColumn(ConnectorSession, ConnectorTableHandle, ColumnHandle, String) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Rename the specified column
- renameField(ConnectorSession, ConnectorTableHandle, List<String>, String) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Rename the specified field, potentially nested, to a row.
- renameMaterializedView(ConnectorSession, SchemaTableName, SchemaTableName) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Rename the specified materialized view
- renameSchema(ConnectorSession, String, String) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Renames the specified schema.
- renameTable(ConnectorSession, ConnectorTableHandle, SchemaTableName) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Rename the specified table
- renameView(ConnectorSession, SchemaTableName, SchemaTableName) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Rename the specified view
- REPEATABLE_READ - Enum constant in enum class io.trino.spi.transaction.IsolationLevel
- REPLACE - Enum constant in enum class io.trino.spi.connector.SaveMode
- replacementBlockForWrite(Block) - Method in interface io.trino.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.trino.spi.block.DictionaryBlockEncoding
- replacementBlockForWrite(Block) - Method in class io.trino.spi.block.LazyBlockEncoding
- requiredColumns(String, List<Integer>) - Method in class io.trino.spi.function.table.TableFunctionAnalysis.Builder
- requiresAnonymizedPlan() - Method in interface io.trino.spi.eventlistener.EventListener
-
Specify whether the plan included in QueryCompletedEvent should be anonymized or not
- rescale(long, int, int) - Static method in class io.trino.spi.type.Decimals
- rescale(long, long, int, long[], int) - Static method in class io.trino.spi.type.Int128Math
- rescale(Int128, int) - Static method in class io.trino.spi.type.Int128Math
- rescale(BigDecimal, DecimalType) - Static method in class io.trino.spi.type.Decimals
- rescale(BigInteger, int, int) - Static method in class io.trino.spi.type.Decimals
- rescaleTruncate(long, long, int, long[], int) - Static method in class io.trino.spi.type.Int128Math
- rescaleTruncate(Int128, int) - Static method in class io.trino.spi.type.Int128Math
- reset() - Method in class io.trino.spi.function.RankingWindowFunction
-
Reset state for a new partition (including the first one).
- reset() - Method in class io.trino.spi.function.ValueWindowFunction
-
Reset state for a new partition (including the first one).
- reset() - Method in class io.trino.spi.PageBuilder
- reset(WindowIndex) - Method in class io.trino.spi.function.RankingWindowFunction
- reset(WindowIndex) - Method in class io.trino.spi.function.ValueWindowFunction
- reset(WindowIndex) - Method in interface io.trino.spi.function.WindowFunction
-
Reset state for a new partition (including the first one).
- resetTo(int) - Method in class io.trino.spi.block.ArrayBlockBuilder
- resetTo(int) - Method in interface io.trino.spi.block.BlockBuilder
-
Rolls back added data to the specified position.
- resetTo(int) - Method in class io.trino.spi.block.ByteArrayBlockBuilder
- resetTo(int) - Method in class io.trino.spi.block.Fixed12BlockBuilder
- resetTo(int) - Method in class io.trino.spi.block.Int128ArrayBlockBuilder
- resetTo(int) - Method in class io.trino.spi.block.IntArrayBlockBuilder
- resetTo(int) - Method in class io.trino.spi.block.LongArrayBlockBuilder
- resetTo(int) - Method in class io.trino.spi.block.MapBlockBuilder
- resetTo(int) - Method in class io.trino.spi.block.RowBlockBuilder
- resetTo(int) - Method in class io.trino.spi.block.ShortArrayBlockBuilder
- resetTo(int) - Method in class io.trino.spi.block.VariableWidthBlockBuilder
- resolveIndex(ConnectorSession, ConnectorTableHandle, Set<ColumnHandle>, Set<ColumnHandle>, TupleDomain<ColumnHandle>) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Try to locate a table index that can lookup results by indexableColumns and provide the requested outputColumns.
- ResourceEstimates - Class in io.trino.spi.session
-
Estimated resource usage for a query.
- ResourceEstimates(Optional<Duration>, Optional<Duration>, Optional<Long>) - Constructor for class io.trino.spi.session.ResourceEstimates
- ResourceGroup - Interface in io.trino.spi.resourcegroups
- ResourceGroupConfigurationManager<C> - Interface in io.trino.spi.resourcegroups
-
The engine calls the
ResourceGroupConfigurationManager.match(SelectionCriteria)
method whenever a query is submitted, and receives aSelectionContext
in return which contains a fully-qualifiedResourceGroupId
, and a manager-specific data structure of typeC
. - ResourceGroupConfigurationManagerContext - Interface in io.trino.spi.resourcegroups
- ResourceGroupConfigurationManagerFactory - Interface in io.trino.spi.resourcegroups
- ResourceGroupId - Class in io.trino.spi.resourcegroups
- ResourceGroupId(ResourceGroupId, String) - Constructor for class io.trino.spi.resourcegroups.ResourceGroupId
- ResourceGroupId(String) - Constructor for class io.trino.spi.resourcegroups.ResourceGroupId
- ResourceGroupId(List<String>) - Constructor for class io.trino.spi.resourcegroups.ResourceGroupId
- ResourceGroupState - Enum Class in io.trino.spi.resourcegroups
- result() - Element in annotation interface io.trino.spi.function.Convention
- retainedBytesForEachPart(ObjLongConsumer<Object>) - Method in class io.trino.spi.block.ArrayBlock
- retainedBytesForEachPart(ObjLongConsumer<Object>) - Method in interface io.trino.spi.block.Block
-
consumer
visits each of the internal data container and accepts the size for it. - retainedBytesForEachPart(ObjLongConsumer<Object>) - Method in class io.trino.spi.block.ByteArrayBlock
- retainedBytesForEachPart(ObjLongConsumer<Object>) - Method in class io.trino.spi.block.DictionaryBlock
- retainedBytesForEachPart(ObjLongConsumer<Object>) - Method in class io.trino.spi.block.Fixed12Block
- retainedBytesForEachPart(ObjLongConsumer<Object>) - Method in class io.trino.spi.block.Int128ArrayBlock
- retainedBytesForEachPart(ObjLongConsumer<Object>) - Method in class io.trino.spi.block.IntArrayBlock
- retainedBytesForEachPart(ObjLongConsumer<Object>) - Method in class io.trino.spi.block.LazyBlock
- retainedBytesForEachPart(ObjLongConsumer<Object>) - Method in class io.trino.spi.block.LongArrayBlock
- retainedBytesForEachPart(ObjLongConsumer<Object>) - Method in class io.trino.spi.block.MapBlock
- retainedBytesForEachPart(ObjLongConsumer<Object>) - Method in class io.trino.spi.block.RowBlock
- retainedBytesForEachPart(ObjLongConsumer<Object>) - Method in class io.trino.spi.block.RunLengthEncodedBlock
- retainedBytesForEachPart(ObjLongConsumer<Object>) - Method in class io.trino.spi.block.ShortArrayBlock
- retainedBytesForEachPart(ObjLongConsumer<Object>) - Method in class io.trino.spi.block.SqlMap
- retainedBytesForEachPart(ObjLongConsumer<Object>) - Method in class io.trino.spi.block.SqlRow
- retainedBytesForEachPart(ObjLongConsumer<Object>) - Method in class io.trino.spi.block.VariableWidthBlock
- RETRIES_ENABLED - Enum constant in enum class io.trino.spi.connector.RetryMode
- RetryMode - Enum Class in io.trino.spi.connector
- returnedType(Descriptor) - Method in class io.trino.spi.function.table.TableFunctionAnalysis.Builder
- returnType() - Element in annotation interface io.trino.spi.function.WindowFunctionSignature
- returnType(Type) - Method in class io.trino.spi.function.Signature.Builder
- returnType(TypeSignature) - Method in class io.trino.spi.function.Signature.Builder
- ReturnTypeSpecification - Class in io.trino.spi.function.table
-
The return type declaration refers to the proper columns of the table function.
- ReturnTypeSpecification() - Constructor for class io.trino.spi.function.table.ReturnTypeSpecification
- ReturnTypeSpecification.DescribedTable - Class in io.trino.spi.function.table
-
The proper columns of the table function are known at function declaration time.
- ReturnTypeSpecification.GenericTable - Class in io.trino.spi.function.table
-
The proper columns of the table function are not known at function declaration time.
- ReturnTypeSpecification.OnlyPassThrough - Class in io.trino.spi.function.table
-
The table function has no proper columns.
- revokeRoles(ConnectorSession, Set<String>, Set<TrinoPrincipal>, boolean, Optional<TrinoPrincipal>) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Revokes the specified roles from the specified grantees
- revokeSchemaPrivileges(ConnectorSession, String, Set<Privilege>, TrinoPrincipal, boolean) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Revokes the specified privilege on the specified schema from the specified user
- revokeTablePrivileges(ConnectorSession, SchemaTableName, Set<Privilege>, TrinoPrincipal, boolean) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Revokes the specified privilege on the specified table from the specified user
- RIGHT_OUTER - Enum constant in enum class io.trino.spi.connector.JoinType
- ROLE - Enum constant in enum class io.trino.spi.security.PrincipalType
- ROLE - Enum constant in enum class io.trino.spi.security.SelectedRole.Type
- ROLE_ALREADY_EXISTS - Enum constant in enum class io.trino.spi.StandardErrorCode
- ROLE_NOT_FOUND - Enum constant in enum class io.trino.spi.StandardErrorCode
- roleExists(ConnectorSession, String) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Does the specified role exist.
- RoleGrant - Class in io.trino.spi.security
- RoleGrant(TrinoPrincipal, String, boolean) - Constructor for class io.trino.spi.security.RoleGrant
- rollback(ConnectorTransactionHandle) - Method in interface io.trino.spi.connector.Connector
-
Rollback the transaction.
- round(long, int) - Static method in class io.trino.spi.type.Timestamps
- roundDiv(int, long) - Static method in class io.trino.spi.type.Timestamps
- roundDiv(long, long) - Static method in class io.trino.spi.type.Timestamps
- roundTo(int) - Method in class io.trino.spi.type.SqlTime
- roundTo(int) - Method in class io.trino.spi.type.SqlTimestamp
- roundTo(int) - Method in class io.trino.spi.type.SqlTimestampWithTimeZone
- roundTo(int) - Method in class io.trino.spi.type.SqlTimeWithTimeZone
- RoutineInfo - Class in io.trino.spi.eventlistener
-
This class is JSON serializable for convenience and serialization compatibility is not guaranteed across versions.
- RoutineInfo(String, String) - Constructor for class io.trino.spi.eventlistener.RoutineInfo
- ROW - Static variable in class io.trino.spi.type.StandardTypes
- ROW_COUNT - Enum constant in enum class io.trino.spi.statistics.TableStatisticType
- RowBlock - Class in io.trino.spi.block
- RowBlockBuilder - Class in io.trino.spi.block
- RowBlockBuilder(List<Type>, BlockBuilderStatus, int) - Constructor for class io.trino.spi.block.RowBlockBuilder
- RowBlockEncoding - Class in io.trino.spi.block
- RowBlockEncoding() - Constructor for class io.trino.spi.block.RowBlockEncoding
- RowChangeParadigm - Enum Class in io.trino.spi.connector
-
Different connectors have different ways of representing row updates, imposed by the underlying storage systems.
- RowFieldName - Class in io.trino.spi.type
- RowFieldName(String) - Constructor for class io.trino.spi.type.RowFieldName
- RowFilterReferenceInfo - Record Class in io.trino.spi.eventlistener
-
This class is JSON serializable for convenience and serialization compatibility is not guaranteed across versions.
- RowFilterReferenceInfo(String, String, String, String) - Constructor for record class io.trino.spi.eventlistener.RowFilterReferenceInfo
-
Creates an instance of a
RowFilterReferenceInfo
record class. - rowSemantics() - Method in class io.trino.spi.function.table.TableArgumentSpecification.Builder
- rowType(RowType) - Method in class io.trino.spi.function.table.TableArgument.Builder
- rowType(RowType.Field...) - Static method in class io.trino.spi.type.RowType
- rowType(TypeSignatureParameter...) - Static method in class io.trino.spi.type.TypeSignature
- rowType(List<TypeSignatureParameter>) - Static method in class io.trino.spi.type.TypeSignature
- RowType - Class in io.trino.spi.type
-
As defined in ISO/IEC FCD 9075-2 (SQL 2011), section 4.8
- RowType.Field - Class in io.trino.spi.type
- RowValueBuilder<E> - Interface in io.trino.spi.block
- rule() - Method in record class io.trino.spi.eventlistener.QueryPlanOptimizerStatistics
-
Returns the value of the
rule
record component. - RunLengthBlockEncoding - Class in io.trino.spi.block
- RunLengthBlockEncoding() - Constructor for class io.trino.spi.block.RunLengthBlockEncoding
- RunLengthEncodedBlock - Class in io.trino.spi.block
S
- SampleApplicationResult<T> - Class in io.trino.spi.connector
- SampleApplicationResult(T, boolean) - Constructor for class io.trino.spi.connector.SampleApplicationResult
- SampleType - Enum Class in io.trino.spi.connector
- SATURATED_FLOOR_CAST - Enum constant in enum class io.trino.spi.function.OperatorType
- SaveMode - Enum Class in io.trino.spi.connector
- SCALAR - Enum constant in enum class io.trino.spi.function.FunctionKind
- ScalarArgument - Class in io.trino.spi.function.table
-
This class represents the scalar argument passed to a Table Function.
- ScalarArgument(Type, Object) - Constructor for class io.trino.spi.function.table.ScalarArgument
- ScalarArgument.Builder - Class in io.trino.spi.function.table
- ScalarArgumentSpecification - Class in io.trino.spi.function.table
- ScalarArgumentSpecification.Builder - Class in io.trino.spi.function.table
- scalarBuilder(String) - Static method in class io.trino.spi.function.FunctionMetadata
- ScalarFunction - Annotation Interface in io.trino.spi.function
- ScalarFunctionAdapter - Class in io.trino.spi.function
- ScalarFunctionImplementation - Class in io.trino.spi.function
- ScalarFunctionImplementation.Builder - Class in io.trino.spi.function
- ScalarOperator - Annotation Interface in io.trino.spi.function
- SchedulingPolicy - Enum Class in io.trino.spi.resourcegroups
- schema(String) - Method in class io.trino.spi.security.ViewExpression.Builder
- SCHEMA_ALREADY_EXISTS - Enum constant in enum class io.trino.spi.StandardErrorCode
- SCHEMA_NOT_EMPTY - Enum constant in enum class io.trino.spi.StandardErrorCode
- SCHEMA_NOT_FOUND - Enum constant in enum class io.trino.spi.StandardErrorCode
- schemaExists(ConnectorSession, String) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Checks if a schema exists.
- SchemaFunctionName - Class in io.trino.spi.function
- SchemaFunctionName(String, String) - Constructor for class io.trino.spi.function.SchemaFunctionName
- schemaName() - Method in interface io.trino.spi.eventlistener.BaseViewReferenceInfo
- schemaName() - Method in record class io.trino.spi.eventlistener.MaterializedViewReferenceInfo
-
Returns the value of the
schemaName
record component. - schemaName() - Method in record class io.trino.spi.eventlistener.ViewReferenceInfo
-
Returns the value of the
schemaName
record component. - SchemaNotFoundException - Exception Class in io.trino.spi.connector
- SchemaNotFoundException(String) - Constructor for exception class io.trino.spi.connector.SchemaNotFoundException
- SchemaNotFoundException(String, String) - Constructor for exception class io.trino.spi.connector.SchemaNotFoundException
- SchemaNotFoundException(String, String, Throwable) - Constructor for exception class io.trino.spi.connector.SchemaNotFoundException
- SchemaNotFoundException(String, Throwable) - Constructor for exception class io.trino.spi.connector.SchemaNotFoundException
- SchemaRoutineName - Class in io.trino.spi.connector
- SchemaRoutineName(String, String) - Constructor for class io.trino.spi.connector.SchemaRoutineName
- schemaTableName(String, String) - Static method in class io.trino.spi.connector.SchemaTableName
- SchemaTableName - Class in io.trino.spi.connector
- SchemaTableName(String, String) - Constructor for class io.trino.spi.connector.SchemaTableName
- SchemaTablePrefix - Class in io.trino.spi.connector
- SchemaTablePrefix() - Constructor for class io.trino.spi.connector.SchemaTablePrefix
- SchemaTablePrefix(String) - Constructor for class io.trino.spi.connector.SchemaTablePrefix
- SchemaTablePrefix(String, String) - Constructor for class io.trino.spi.connector.SchemaTablePrefix
- SECONDS_PER_DAY - Static variable in class io.trino.spi.type.Timestamps
- SECONDS_PER_MINUTE - Static variable in class io.trino.spi.type.Timestamps
- seekKey(MethodHandle, MethodHandle, Block, int) - Method in class io.trino.spi.block.SqlMap
- seekKey(Object) - Method in class io.trino.spi.block.SqlMap
- seekKeyExact(boolean) - Method in class io.trino.spi.block.SqlMap
- seekKeyExact(double) - Method in class io.trino.spi.block.SqlMap
- seekKeyExact(long) - Method in class io.trino.spi.block.SqlMap
- seekKeyExact(Object) - Method in class io.trino.spi.block.SqlMap
- SELECT - Enum constant in enum class io.trino.spi.resourcegroups.QueryType
- SELECT - Enum constant in enum class io.trino.spi.security.Privilege
- SelectedRole - Class in io.trino.spi.security
- SelectedRole(SelectedRole.Type, Optional<String>) - Constructor for class io.trino.spi.security.SelectedRole
- SelectedRole.Type - Enum Class in io.trino.spi.security
- SelectionContext<T> - Class in io.trino.spi.resourcegroups
- SelectionContext(ResourceGroupId, T) - Constructor for class io.trino.spi.resourcegroups.SelectionContext
- SelectionCriteria - Class in io.trino.spi.resourcegroups
- SelectionCriteria(boolean, String, Set<String>, Optional<String>, Set<String>, ResourceEstimates, Optional<String>) - Constructor for class io.trino.spi.resourcegroups.SelectionCriteria
- Serializable(Type, Block) - Constructor for class io.trino.spi.predicate.NullableValue.Serializable
- SERIALIZABLE - Enum constant in enum class io.trino.spi.transaction.IsolationLevel
- SERIALIZATION_ERROR - Enum constant in enum class io.trino.spi.StandardErrorCode
- serialize(T, BlockBuilder) - Method in interface io.trino.spi.function.AccumulatorStateSerializer
- serializedType() - Element in annotation interface io.trino.spi.function.AccumulatorStateMetadata
- serializer(AccumulatorStateSerializer<T>) - Method in class io.trino.spi.function.AggregationImplementation.AccumulatorStateDescriptor.Builder
- SERVER_SHUTTING_DOWN - Enum constant in enum class io.trino.spi.StandardErrorCode
- SERVER_STARTING_UP - Enum constant in enum class io.trino.spi.StandardErrorCode
- session() - Element in annotation interface io.trino.spi.function.Convention
- SessionConfigurationContext - Class in io.trino.spi.session
- SessionConfigurationContext(String, Optional<String>, Set<String>, Optional<String>, ResourceGroupId) - Constructor for class io.trino.spi.session.SessionConfigurationContext
- SessionPropertyConfigurationManager - Interface in io.trino.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.trino.spi.resourcegroups
- SessionPropertyConfigurationManagerFactory - Interface in io.trino.spi.session
- set(Block, int) - Method in interface io.trino.spi.function.InOut
- set(InOut) - Method in interface io.trino.spi.function.InOut
- setColumnComment(ConnectorSession, ConnectorTableHandle, ColumnHandle, Optional<String>) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Comments to the specified column
- setColumnStatistics(ColumnHandle, ColumnStatistics) - Method in class io.trino.spi.statistics.TableStatistics.Builder
- setColumnType(ConnectorSession, ConnectorTableHandle, ColumnHandle, Type) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Set the specified column type
- setComment(Optional<String>) - Method in class io.trino.spi.connector.ColumnMetadata.Builder
- setCpuQuotaGenerationMillisPerSecond(long) - Method in interface io.trino.spi.resourcegroups.ResourceGroup
-
Rate at which distributed CPU usage quota regenerates.
- setDataSize(Estimate) - Method in class io.trino.spi.statistics.ColumnStatistics.Builder
- setDisabled(boolean) - Method in interface io.trino.spi.resourcegroups.ResourceGroup
-
Marks the group as disabled.
- setDistinctValuesCount(Estimate) - Method in class io.trino.spi.statistics.ColumnStatistics.Builder
- setExtraInfo(Optional<String>) - Method in class io.trino.spi.connector.ColumnMetadata.Builder
- setFieldType(ConnectorSession, ConnectorTableHandle, List<String>, Type) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Set the specified field type
- setFinal() - Method in class io.trino.spi.exchange.ExchangeSourceOutputSelector.Builder
- setGroupId(int) - Method in interface io.trino.spi.function.GroupedAccumulatorState
- setHardConcurrencyLimit(int) - Method in interface io.trino.spi.resourcegroups.ResourceGroup
-
Maximum number of concurrently running queries, after which new queries will queue instead of starting.
- setHardCpuLimit(Duration) - Method in interface io.trino.spi.resourcegroups.ResourceGroup
-
Threshold on total distributed CPU usage after which new queries will queue instead of starting.
- setHidden(boolean) - Method in class io.trino.spi.connector.ColumnMetadata.Builder
- setHidden(boolean) - Method in class io.trino.spi.connector.ColumnSchema.Builder
- setJmxExport(boolean) - Method in interface io.trino.spi.resourcegroups.ResourceGroup
-
Whether to export statistics about this group and allow configuration via JMX.
- setMaterializedViewColumnComment(ConnectorSession, SchemaTableName, String, Optional<String>) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Comments to the specified materialized view column.
- setMaterializedViewProperties(ConnectorSession, SchemaTableName, Map<String, Optional<Object>>) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Sets the properties of the specified materialized view
- setMaxQueuedQueries(int) - Method in interface io.trino.spi.resourcegroups.ResourceGroup
-
Maximum number of queued queries after which submitted queries will be rejected.
- setName(String) - Method in class io.trino.spi.connector.ColumnMetadata.Builder
- setName(String) - Method in class io.trino.spi.connector.ColumnSchema.Builder
- setNullable(boolean) - Method in class io.trino.spi.connector.ColumnMetadata.Builder
- setNullsFraction(Estimate) - Method in class io.trino.spi.statistics.ColumnStatistics.Builder
- setOutputSelector(ExchangeSourceOutputSelector) - Method in interface io.trino.spi.exchange.ExchangeSource
-
Called by the engine to provide information about what source task output must be included and what must be skipped.
- setPartitionCount(ExchangeId, int) - Method in class io.trino.spi.exchange.ExchangeSourceOutputSelector.Builder
- setPath(List<CatalogSchemaName>) - Method in class io.trino.spi.security.ViewExpression.Builder
- setProperties(Map<String, Object>) - Method in class io.trino.spi.connector.ColumnMetadata.Builder
- setRange(DoubleRange) - Method in class io.trino.spi.statistics.ColumnStatistics.Builder
- setRange(Optional<DoubleRange>) - Method in class io.trino.spi.statistics.ColumnStatistics.Builder
- setRowCount(Estimate) - Method in class io.trino.spi.statistics.TableStatistics.Builder
- setSchedulingPolicy(SchedulingPolicy) - Method in interface io.trino.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.trino.spi.resourcegroups.ResourceGroup
-
Scheduling weight of this group in its parent group.
- setSchemaAuthorization(ConnectorSession, String, TrinoPrincipal) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Sets the user/role on the specified schema.
- setSoftConcurrencyLimit(int) - Method in interface io.trino.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.trino.spi.resourcegroups.ResourceGroup
-
Threshold on total distributed CPU usage after which max running queries will be reduced.
- setSoftMemoryLimitBytes(long) - Method in interface io.trino.spi.resourcegroups.ResourceGroup
-
Threshold on total distributed memory usage after which new queries will queue instead of starting.
- setSourceHandlesDeliveryMode(Exchange.SourceHandlesDeliveryMode) - Method in interface io.trino.spi.exchange.Exchange
-
Change
ExchangeSourceHandleSource
delivery mode. - setTableAuthorization(ConnectorSession, SchemaTableName, TrinoPrincipal) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Sets the user/role on the specified table.
- setTableComment(ConnectorSession, ConnectorTableHandle, Optional<String>) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Comments to the specified table
- setTableProperties(ConnectorSession, ConnectorTableHandle, Map<String, Optional<Object>>) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Set properties to the specified table
- setType(Type) - Method in class io.trino.spi.connector.ColumnMetadata.Builder
- setType(Type) - Method in class io.trino.spi.connector.ColumnSchema.Builder
- setViewAuthorization(ConnectorSession, SchemaTableName, TrinoPrincipal) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Sets the user/role on the specified view.
- setViewColumnComment(ConnectorSession, SchemaTableName, String, Optional<String>) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Comments to the specified view column.
- setViewComment(ConnectorSession, SchemaTableName, Optional<String>) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Comments to the specified view
- shiftLeft(long[], int) - Static method in class io.trino.spi.type.Int128Math
- ShortArrayBlock - Class in io.trino.spi.block
- ShortArrayBlock(int, Optional<boolean[]>, short[]) - Constructor for class io.trino.spi.block.ShortArrayBlock
- ShortArrayBlockBuilder - Class in io.trino.spi.block
- ShortArrayBlockBuilder(BlockBuilderStatus, int) - Constructor for class io.trino.spi.block.ShortArrayBlockBuilder
- ShortArrayBlockEncoding - Class in io.trino.spi.block
- ShortArrayBlockEncoding() - Constructor for class io.trino.spi.block.ShortArrayBlockEncoding
- shortDecimalToDouble(long, long) - Static method in class io.trino.spi.type.DecimalConversions
- shortDecimalToReal(long, long) - Static method in class io.trino.spi.type.DecimalConversions
- shortToLongCast(long, long, long, long, long) - Static method in class io.trino.spi.type.DecimalConversions
- shortToShortCast(long, long, long, long, long, long, long) - Static method in class io.trino.spi.type.DecimalConversions
- shutdown() - Method in interface io.trino.spi.connector.Connector
-
Shutdown the connector by releasing any held resources such as threads, sockets, etc.
- shutdown() - Method in interface io.trino.spi.eventlistener.EventListener
-
Shutdown the event listener by releasing any held resources such as threads, sockets, etc.
- shutdown() - Method in interface io.trino.spi.exchange.ExchangeManager
-
Shutdown the exchange manager by releasing any held resources such as threads, sockets, etc.
- shutdown() - Method in interface io.trino.spi.resourcegroups.ResourceGroupConfigurationManager
- shutdown() - Method in interface io.trino.spi.security.SystemAccessControl
- signature(Signature) - Method in class io.trino.spi.function.FunctionMetadata.Builder
- Signature - Class in io.trino.spi.function
- Signature.Builder - Class in io.trino.spi.function
- signatureToken() - Method in record class io.trino.spi.function.LanguageFunction
-
Returns the value of the
signatureToken
record component. - simpleConvention(InvocationConvention.InvocationReturnConvention, InvocationConvention.InvocationArgumentConvention...) - Static method in class io.trino.spi.function.InvocationConvention
- simplify() - Method in class io.trino.spi.predicate.Domain
-
Reduces the number of discrete components in the Domain if there are too many.
- simplify() - Method in class io.trino.spi.predicate.TupleDomain
- simplify(int) - Method in class io.trino.spi.predicate.Domain
- simplify(int) - Method in class io.trino.spi.predicate.TupleDomain
- SINGLE_COORDINATOR - Enum constant in enum class io.trino.spi.connector.SystemTable.Distribution
- singleValue(Type, Object) - Static method in class io.trino.spi.predicate.Domain
- singleValue(Type, Object, boolean) - Static method in class io.trino.spi.predicate.Domain
- sinkFinished(ExchangeSinkHandle, int) - Method in interface io.trino.spi.exchange.Exchange
-
Called by the engine when an attempt finishes successfully.
- size() - Method in interface io.trino.spi.function.WindowIndex
-
Gets the number of rows in the partition
- SIZE - Static variable in class io.trino.spi.type.Int128
- SIZE_IN_BYTES_PER_POSITION - Static variable in class io.trino.spi.block.ByteArrayBlock
- SIZE_IN_BYTES_PER_POSITION - Static variable in class io.trino.spi.block.Fixed12Block
- SIZE_IN_BYTES_PER_POSITION - Static variable in class io.trino.spi.block.Int128ArrayBlock
- SIZE_IN_BYTES_PER_POSITION - Static variable in class io.trino.spi.block.IntArrayBlock
- SIZE_IN_BYTES_PER_POSITION - Static variable in class io.trino.spi.block.LongArrayBlock
- SIZE_IN_BYTES_PER_POSITION - Static variable in class io.trino.spi.block.ShortArrayBlock
- SMALLINT - Static variable in class io.trino.spi.type.SmallintType
- SMALLINT - Static variable in class io.trino.spi.type.StandardTypes
- SmallintType - Class in io.trino.spi.type
- sort(List<Type>, List<Page>, List<Integer>, List<SortOrder>, int) - Method in interface io.trino.spi.PageSorter
- SortedRangeSet - Class in io.trino.spi.predicate
-
A set containing zero or more Ranges of the same type over a continuous space of possible values.
- SortedRangeSet.Builder - Class in io.trino.spi.predicate
- SortedRangeSet.DiscreteSetMarker - Enum Class in io.trino.spi.predicate
- SortingProperty<E> - Class in io.trino.spi.connector
- SortingProperty(E, SortOrder) - Constructor for class io.trino.spi.connector.SortingProperty
- SortItem - Class in io.trino.spi.connector
- SortItem(String, SortOrder) - Constructor for class io.trino.spi.connector.SortItem
- SortOrder - Enum Class in io.trino.spi.connector
- span(Range) - Method in class io.trino.spi.predicate.Range
- splitCompleted(SplitCompletedEvent) - Method in interface io.trino.spi.eventlistener.EventListener
- SplitCompletedEvent - Class in io.trino.spi.eventlistener
-
This class is JSON serializable for convenience and serialization compatibility is not guaranteed across versions.
- SplitCompletedEvent(String, String, String, Optional<String>, Instant, Optional<Instant>, Optional<Instant>, SplitStatistics, Optional<SplitFailureInfo>, String) - Constructor for class io.trino.spi.eventlistener.SplitCompletedEvent
- SplitFailureInfo - Class in io.trino.spi.eventlistener
-
This class is JSON serializable for convenience and serialization compatibility is not guaranteed across versions.
- SplitFailureInfo(String, String) - Constructor for class io.trino.spi.eventlistener.SplitFailureInfo
- SplitStatistics - Class in io.trino.spi.eventlistener
-
This class is JSON serializable for convenience and serialization compatibility is not guaranteed across versions.
- SplitStatistics(Duration, Duration, Duration, Duration, long, long, Optional<Duration>, Optional<Duration>) - Constructor for class io.trino.spi.eventlistener.SplitStatistics
- SplitWeight - Class in io.trino.spi
- sql() - Method in record class io.trino.spi.function.LanguageFunction
-
Returns the value of the
sql
record component. - SqlDate - Class in io.trino.spi.type
- SqlDate(int) - Constructor for class io.trino.spi.type.SqlDate
- SqlDecimal - Class in io.trino.spi.type
- SqlDecimal(BigInteger, int, int) - Constructor for class io.trino.spi.type.SqlDecimal
- SqlMap - Class in io.trino.spi.block
- SqlMap(MapType, MapHashTables.HashBuildMode, Block, Block) - Constructor for class io.trino.spi.block.SqlMap
- SqlNullable - Annotation Interface in io.trino.spi.function
-
Indicates a parameter or return value can be NULL.
- SqlRow - Class in io.trino.spi.block
- SqlRow(int, Block[]) - Constructor for class io.trino.spi.block.SqlRow
- SqlTime - Class in io.trino.spi.type
- SqlTimestamp - Class in io.trino.spi.type
- SqlTimestampWithTimeZone - Class in io.trino.spi.type
- SqlTimeWithTimeZone - Class in io.trino.spi.type
- SqlType - Annotation Interface in io.trino.spi.function
- SqlVarbinary - Class in io.trino.spi.type
- SqlVarbinary(byte[]) - Constructor for class io.trino.spi.type.SqlVarbinary
- STACK_OVERFLOW - Enum constant in enum class io.trino.spi.StandardErrorCode
- StageCpuDistribution - Class in io.trino.spi.eventlistener
-
This class is JSON serializable for convenience and serialization compatibility is not guaranteed across versions.
- StageCpuDistribution(int, int, long, long, long, long, long, long, long, long, long, double) - Constructor for class io.trino.spi.eventlistener.StageCpuDistribution
- StageGcStatistics - Class in io.trino.spi.eventlistener
-
This class is JSON serializable for convenience and serialization compatibility is not guaranteed across versions.
- StageGcStatistics(int, int, int, int, int, int, int) - Constructor for class io.trino.spi.eventlistener.StageGcStatistics
- StageOutputBufferUtilization - Class in io.trino.spi.eventlistener
-
This class is JSON serializable for convenience and serialization compatibility is not guaranteed across versions.
- StageOutputBufferUtilization(int, int, double, double, double, double, double, double, double, double, double, double, double, Duration) - Constructor for class io.trino.spi.eventlistener.StageOutputBufferUtilization
- StageTaskStatistics - Class in io.trino.spi.eventlistener
-
This class is JSON serializable for convenience and serialization compatibility is not guaranteed across versions.
- StageTaskStatistics(int, int, LongDistribution, LongDistribution, LongDistribution, LongDistribution, LongDistribution, LongDistribution, LongDistribution, LongDistribution, LongDistribution, LongDistribution, LongDistribution, LongSymmetricDistribution, LongSymmetricDistribution, LongSymmetricDistribution, LongSymmetricDistribution, LongSymmetricDistribution, LongSymmetricDistribution, DoubleSymmetricDistribution, DoubleSymmetricDistribution, DoubleSymmetricDistribution, DoubleSymmetricDistribution, DoubleSymmetricDistribution, DoubleSymmetricDistribution, DoubleSymmetricDistribution) - Constructor for class io.trino.spi.eventlistener.StageTaskStatistics
- STALE - Enum constant in enum class io.trino.spi.connector.MaterializedViewFreshness.Freshness
- standard() - Static method in class io.trino.spi.SplitWeight
- STANDARD - Enum constant in enum class io.trino.spi.exchange.Exchange.SourceHandlesDeliveryMode
- StandardErrorCode - Enum Class in io.trino.spi
- StandardFunctions - Class in io.trino.spi.expression
- StandardTypes - Class in io.trino.spi.type
- StandardWarningCode - Enum Class in io.trino.spi.connector
- stateFactoryClass() - Element in annotation interface io.trino.spi.function.AccumulatorStateMetadata
- stateSerializerClass() - Element in annotation interface io.trino.spi.function.AccumulatorStateMetadata
- StatsUtil - Class in io.trino.spi.statistics
- storeMergedRows(Page) - Method in interface io.trino.spi.connector.ConnectorMergeSink
-
Store the page resulting from a merge.
- streamRelationColumns(ConnectorSession, Optional<String>, UnaryOperator<Set<SchemaTableName>>) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Gets columns for all relations (tables, views, materialized views), possibly filtered by schemaName.
- streamRelationComments(ConnectorSession, Optional<String>, UnaryOperator<Set<SchemaTableName>>) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Gets comments for all relations (tables, views, materialized views), possibly filtered by schemaName.
- streamTableColumns(ConnectorSession, SchemaTablePrefix) - Method in interface io.trino.spi.connector.ConnectorMetadata
- strict() - Method in class io.trino.spi.block.MapBlockBuilder
- STRICT_EQUALS - Enum constant in enum class io.trino.spi.block.MapHashTables.HashBuildMode
- STRICT_NOT_DISTINCT_FROM - Enum constant in enum class io.trino.spi.block.MapHashTables.HashBuildMode
- strictNotDistinctFrom() - Method in class io.trino.spi.block.MapBlockBuilder
- stringProperty(String, String, String, boolean) - Static method in class io.trino.spi.session.PropertyMetadata
- stringProperty(String, String, String, Consumer<String>, boolean) - Static method in class io.trino.spi.session.PropertyMetadata
- SUBQUERY_MULTIPLE_ROWS - Enum constant in enum class io.trino.spi.StandardErrorCode
- SUBSCRIPT - Enum constant in enum class io.trino.spi.function.OperatorType
- subtract(long, long, long, long, long[], int) - Static method in class io.trino.spi.type.Int128Math
- subtract(Domain) - Method in class io.trino.spi.predicate.Domain
- subtract(ValueSet) - Method in interface io.trino.spi.predicate.ValueSet
- subtract(Int128, Int128) - Static method in class io.trino.spi.type.Int128Math
- SUBTRACT - Enum constant in enum class io.trino.spi.function.OperatorType
- SUBTRACT_FUNCTION_NAME - Static variable in class io.trino.spi.expression.StandardFunctions
-
Arithmetic subtraction.
- supportsConcurrentReadAndWrite() - Method in interface io.trino.spi.exchange.ExchangeManager
-
Provides information if Exchange implementation provided with this plugin supports concurrent reading and writing.
- supportsFilter() - Method in class io.trino.spi.connector.TableProcedureExecutionMode
- supportsInstanceFactory() - Method in class io.trino.spi.function.InvocationConvention
- supportsMissingColumnsOnInsert() - Method in interface io.trino.spi.connector.ConnectorMetadata
- supportsMultipleWritersPerPartition() - Method in class io.trino.spi.connector.ConnectorTableLayout
- supportsSession() - Method in class io.trino.spi.function.InvocationConvention
- SYNTAX_ERROR - Enum constant in enum class io.trino.spi.StandardErrorCode
- SYSTEM - Enum constant in enum class io.trino.spi.connector.CatalogHandle.CatalogHandleType
- SYSTEM - Enum constant in enum class io.trino.spi.connector.SampleType
- SystemAccessControl - Interface in io.trino.spi.security
- SystemAccessControlFactory - Interface in io.trino.spi.security
- SystemAccessControlFactory.SystemAccessControlContext - Interface in io.trino.spi.security
- SystemSecurityContext - Class in io.trino.spi.security
- SystemSecurityContext(Identity, QueryId, Instant) - Constructor for class io.trino.spi.security.SystemSecurityContext
- SystemTable - Interface in io.trino.spi.connector
-
Exactly one of
SystemTable.cursor(io.trino.spi.connector.ConnectorTransactionHandle, io.trino.spi.connector.ConnectorSession, io.trino.spi.predicate.TupleDomain<java.lang.Integer>)
orSystemTable.pageSource(io.trino.spi.connector.ConnectorTransactionHandle, io.trino.spi.connector.ConnectorSession, io.trino.spi.predicate.TupleDomain<java.lang.Integer>)
must be implemented. - SystemTable.Distribution - Enum Class in io.trino.spi.connector
T
- TABLE - Enum constant in enum class io.trino.spi.connector.RelationType
- TABLE - Enum constant in enum class io.trino.spi.function.FunctionKind
- TABLE_ALREADY_EXISTS - Enum constant in enum class io.trino.spi.StandardErrorCode
- TABLE_HAS_NO_COLUMNS - Enum constant in enum class io.trino.spi.StandardErrorCode
- TABLE_NOT_FOUND - Enum constant in enum class io.trino.spi.StandardErrorCode
- TABLE_REDIRECTION_ERROR - Enum constant in enum class io.trino.spi.StandardErrorCode
- TableArgument - Class in io.trino.spi.function.table
-
This class represents the table argument passed to a Table Function.
- TableArgument(RowType, List<String>, List<String>) - Constructor for class io.trino.spi.function.table.TableArgument
- TableArgument.Builder - Class in io.trino.spi.function.table
- TableArgumentSpecification - Class in io.trino.spi.function.table
- TableArgumentSpecification.Builder - Class in io.trino.spi.function.table
- tableBuilder(String) - Static method in class io.trino.spi.function.FunctionMetadata
- tableColumns() - Method in record class io.trino.spi.connector.RelationColumnsMetadata
-
Returns the value of the
tableColumns
record component. - TableColumnsMetadata - Class in io.trino.spi.connector
- TableColumnsMetadata(SchemaTableName, Optional<List<ColumnMetadata>>) - Constructor for class io.trino.spi.connector.TableColumnsMetadata
- TableFunctionAnalysis - Class in io.trino.spi.function.table
-
An object of this class is produced by the `analyze()` method of a `ConnectorTableFunction` implementation.
- TableFunctionAnalysis.Builder - Class in io.trino.spi.function.table
- TableFunctionApplicationResult<T> - Class in io.trino.spi.connector
- TableFunctionApplicationResult(T, List<ColumnHandle>) - Constructor for class io.trino.spi.connector.TableFunctionApplicationResult
- TableFunctionDataProcessor - Interface in io.trino.spi.function.table
- TableFunctionProcessorProvider - Interface in io.trino.spi.function.table
- TableFunctionProcessorProviderFactory - Interface in io.trino.spi.function.table
- TableFunctionProcessorState - Interface in io.trino.spi.function.table
-
The result of processing input by
TableFunctionDataProcessor
orTableFunctionSplitProcessor
. - TableFunctionProcessorState.Blocked - Class in io.trino.spi.function.table
- TableFunctionProcessorState.Finished - Class in io.trino.spi.function.table
- TableFunctionProcessorState.Processed - Class in io.trino.spi.function.table
- TableFunctionSplitProcessor - Interface in io.trino.spi.function.table
-
Processes table functions splits, as returned from
ConnectorSplitManager
for aConnectorTableFunctionHandle
. - TableInfo - Class in io.trino.spi.eventlistener
-
This class is JSON serializable for convenience and serialization compatibility is not guaranteed across versions.
- TableInfo(String, String, String, String, List<String>, List<ColumnInfo>, boolean, Optional<String>, List<TableReferenceInfo>) - Constructor for class io.trino.spi.eventlistener.TableInfo
- TableNotFoundException - Exception Class in io.trino.spi.connector
- TableNotFoundException(SchemaTableName) - Constructor for exception class io.trino.spi.connector.TableNotFoundException
- TableNotFoundException(SchemaTableName, String) - Constructor for exception class io.trino.spi.connector.TableNotFoundException
- TableNotFoundException(SchemaTableName, String, Throwable) - Constructor for exception class io.trino.spi.connector.TableNotFoundException
- TableNotFoundException(SchemaTableName, Throwable) - Constructor for exception class io.trino.spi.connector.TableNotFoundException
- TableProcedureExecutionMode - Class in io.trino.spi.connector
- TableProcedureMetadata - Class in io.trino.spi.connector
- TableProcedureMetadata(String, TableProcedureExecutionMode, List<PropertyMetadata<?>>) - Constructor for class io.trino.spi.connector.TableProcedureMetadata
- tableRedirected() - Method in record class io.trino.spi.connector.RelationCommentMetadata
-
Returns the value of the
tableRedirected
record component. - TableReferenceInfo - Interface in io.trino.spi.eventlistener
-
This class is JSON serializable for convenience and serialization compatibility is not guaranteed across versions.
- TableScanRedirectApplicationResult - Class in io.trino.spi.connector
- TableScanRedirectApplicationResult(CatalogSchemaTableName, Map<ColumnHandle, String>, TupleDomain<String>) - Constructor for class io.trino.spi.connector.TableScanRedirectApplicationResult
- TableStatistics - Class in io.trino.spi.statistics
- TableStatistics(Estimate, Map<ColumnHandle, ColumnStatistics>) - Constructor for class io.trino.spi.statistics.TableStatistics
- TableStatistics.Builder - Class in io.trino.spi.statistics
- TableStatisticsMetadata - Class in io.trino.spi.statistics
- TableStatisticsMetadata(Set<ColumnStatisticMetadata>, Set<TableStatisticType>, List<String>) - Constructor for class io.trino.spi.statistics.TableStatisticsMetadata
- TableStatisticType - Enum Class in io.trino.spi.statistics
- TARGET_ID - Enum constant in enum class io.trino.spi.connector.PointerType
- targetCatalogName() - Method in record class io.trino.spi.eventlistener.ColumnMaskReferenceInfo
-
Returns the value of the
targetCatalogName
record component. - targetCatalogName() - Method in interface io.trino.spi.eventlistener.FilterMaskReferenceInfo
- targetCatalogName() - Method in record class io.trino.spi.eventlistener.RowFilterReferenceInfo
-
Returns the value of the
targetCatalogName
record component. - targetColumnName() - Method in record class io.trino.spi.eventlistener.ColumnMaskReferenceInfo
-
Returns the value of the
targetColumnName
record component. - targetSchemaName() - Method in record class io.trino.spi.eventlistener.ColumnMaskReferenceInfo
-
Returns the value of the
targetSchemaName
record component. - targetSchemaName() - Method in interface io.trino.spi.eventlistener.FilterMaskReferenceInfo
- targetSchemaName() - Method in record class io.trino.spi.eventlistener.RowFilterReferenceInfo
-
Returns the value of the
targetSchemaName
record component. - targetTableName() - Method in record class io.trino.spi.eventlistener.ColumnMaskReferenceInfo
-
Returns the value of the
targetTableName
record component. - targetTableName() - Method in interface io.trino.spi.eventlistener.FilterMaskReferenceInfo
- targetTableName() - Method in record class io.trino.spi.eventlistener.RowFilterReferenceInfo
-
Returns the value of the
targetTableName
record component. - TDIGEST - Static variable in class io.trino.spi.type.StandardTypes
- TEMPORAL - Enum constant in enum class io.trino.spi.connector.PointerType
- ThreadContextClassLoader - Class in io.trino.spi.classloader
- ThreadContextClassLoader(ClassLoader) - Constructor for class io.trino.spi.classloader.ThreadContextClassLoader
- TIME - Static variable in class io.trino.spi.type.StandardTypes
- TIME - Static variable in class io.trino.spi.type.TimeParametricType
- TIME_MICROS - Static variable in class io.trino.spi.type.TimeType
- TIME_MILLIS - Static variable in class io.trino.spi.type.TimeType
- TIME_NANOS - Static variable in class io.trino.spi.type.TimeType
- TIME_PICOS - Static variable in class io.trino.spi.type.TimeType
- TIME_SECONDS - Static variable in class io.trino.spi.type.TimeType
- TIME_TZ_MICROS - Static variable in class io.trino.spi.type.TimeWithTimeZoneType
- TIME_TZ_MILLIS - Static variable in class io.trino.spi.type.TimeWithTimeZoneType
- TIME_TZ_NANOS - Static variable in class io.trino.spi.type.TimeWithTimeZoneType
- TIME_TZ_PICOS - Static variable in class io.trino.spi.type.TimeWithTimeZoneType
- TIME_TZ_SECONDS - Static variable in class io.trino.spi.type.TimeWithTimeZoneType
- TIME_WITH_TIME_ZONE - Static variable in class io.trino.spi.type.StandardTypes
- TIME_WITH_TIME_ZONE - Static variable in class io.trino.spi.type.TimeWithTimeZoneParametricType
- TimeParametricType - Class in io.trino.spi.type
- TimeParametricType() - Constructor for class io.trino.spi.type.TimeParametricType
- TIMESTAMP - Static variable in class io.trino.spi.type.StandardTypes
- TIMESTAMP - Static variable in class io.trino.spi.type.TimestampParametricType
- TIMESTAMP_MICROS - Static variable in class io.trino.spi.type.TimestampType
- TIMESTAMP_MILLIS - Static variable in class io.trino.spi.type.TimestampType
- TIMESTAMP_NANOS - Static variable in class io.trino.spi.type.TimestampType
- TIMESTAMP_PICOS - Static variable in class io.trino.spi.type.TimestampType
- TIMESTAMP_SECONDS - Static variable in class io.trino.spi.type.TimestampType
- TIMESTAMP_TZ_MICROS - Static variable in class io.trino.spi.type.TimestampWithTimeZoneType
- TIMESTAMP_TZ_MILLIS - Static variable in class io.trino.spi.type.TimestampWithTimeZoneType
- TIMESTAMP_TZ_NANOS - Static variable in class io.trino.spi.type.TimestampWithTimeZoneType
- TIMESTAMP_TZ_PICOS - Static variable in class io.trino.spi.type.TimestampWithTimeZoneType
- TIMESTAMP_TZ_SECONDS - Static variable in class io.trino.spi.type.TimestampWithTimeZoneType
- TIMESTAMP_WITH_TIME_ZONE - Static variable in class io.trino.spi.type.StandardTypes
- TIMESTAMP_WITH_TIME_ZONE - Static variable in class io.trino.spi.type.TimestampWithTimeZoneParametricType
- TimestampParametricType - Class in io.trino.spi.type
- TimestampParametricType() - Constructor for class io.trino.spi.type.TimestampParametricType
- Timestamps - Class in io.trino.spi.type
- TimestampType - Class in io.trino.spi.type
-
A timestamp is to be interpreted as local date time without regards to any time zone.
- TimestampTypes - Class in io.trino.spi.type
- TimestampWithTimeZoneParametricType - Class in io.trino.spi.type
- TimestampWithTimeZoneParametricType() - Constructor for class io.trino.spi.type.TimestampWithTimeZoneParametricType
- TimestampWithTimeZoneType - Class in io.trino.spi.type
- TimeType - Class in io.trino.spi.type
-
A time is stored as picoseconds from midnight.
- TimeWithTimeZoneParametricType - Class in io.trino.spi.type
- TimeWithTimeZoneParametricType() - Constructor for class io.trino.spi.type.TimeWithTimeZoneParametricType
- TimeWithTimeZoneType - Class in io.trino.spi.type
- TimeWithTimeZoneType(int, Class<?>, Class<? extends ValueBlock>) - Constructor for class io.trino.spi.type.TimeWithTimeZoneType
- TimeWithTimeZoneTypes - Class in io.trino.spi.type
- TimeZoneKey - Class in io.trino.spi.type
- TimeZoneNotSupportedException - Exception Class in io.trino.spi.type
- TimeZoneNotSupportedException(String) - Constructor for exception class io.trino.spi.type.TimeZoneNotSupportedException
- Timing<T> - Interface in io.trino.spi.metrics
- TINYINT - Static variable in class io.trino.spi.type.StandardTypes
- TINYINT - Static variable in class io.trino.spi.type.TinyintType
- TinyintType - Class in io.trino.spi.type
- toBigDecimal() - Method in class io.trino.spi.type.SqlDecimal
- toBigEndianBytes() - Method in class io.trino.spi.type.Int128
- toBigEndianBytes(byte[], int) - Method in class io.trino.spi.type.Int128
- toBigInteger() - Method in class io.trino.spi.type.Int128
- toColumnarArray(Block) - Static method in class io.trino.spi.block.ColumnarArray
- toColumnarMap(Block) - Static method in class io.trino.spi.block.ColumnarMap
- toConnectorIdentity() - Method in class io.trino.spi.security.Identity
- toConnectorIdentity(String) - Method in class io.trino.spi.security.Identity
- toErrorCode() - Method in interface io.trino.spi.ErrorCodeSupplier
- toErrorCode() - Method in enum class io.trino.spi.StandardErrorCode
- toFunctionId(String, Signature) - Static method in class io.trino.spi.function.FunctionId
- toInetAddress() - Method in class io.trino.spi.HostAddress
- toLocalDateTime() - Method in class io.trino.spi.type.SqlTimestamp
- toLong() - Method in class io.trino.spi.type.Int128
- toLongArray() - Method in class io.trino.spi.type.Int128
- toLongExact() - Method in class io.trino.spi.type.Int128
- TOO_MANY_ARGUMENTS - Enum constant in enum class io.trino.spi.StandardErrorCode
- TOO_MANY_GROUPING_SETS - Enum constant in enum class io.trino.spi.StandardErrorCode
- TOO_MANY_REQUESTS_FAILED - Enum constant in enum class io.trino.spi.StandardErrorCode
- TOO_MANY_STAGES - Enum constant in enum class io.trino.spi.connector.StandardWarningCode
- toOptionalSchemaTableName() - Method in class io.trino.spi.connector.SchemaTablePrefix
- TopNApplicationResult<T> - Class in io.trino.spi.connector
- TopNApplicationResult(T, boolean, boolean) - Constructor for class io.trino.spi.connector.TopNApplicationResult
- toSchemaTableName() - Method in class io.trino.spi.connector.SchemaTablePrefix
- toSchemaTablePrefix() - Method in class io.trino.spi.connector.SchemaTableName
- toSignature() - Method in class io.trino.spi.function.BoundSignature
- toStatsRepresentation(Type, Object) - Static method in class io.trino.spi.statistics.StatsUtil
- toString() - Method in class io.trino.spi.block.ArrayBlock
- toString() - Method in class io.trino.spi.block.ArrayBlockBuilder
- toString() - Method in class io.trino.spi.block.BlockBuilderStatus
- toString() - Method in class io.trino.spi.block.ByteArrayBlock
- toString() - Method in class io.trino.spi.block.ByteArrayBlockBuilder
- toString() - Method in class io.trino.spi.block.DictionaryBlock
- toString() - Method in class io.trino.spi.block.Fixed12Block
- toString() - Method in class io.trino.spi.block.Fixed12BlockBuilder
- toString() - Method in class io.trino.spi.block.Int128ArrayBlock
- toString() - Method in class io.trino.spi.block.Int128ArrayBlockBuilder
- toString() - Method in class io.trino.spi.block.IntArrayBlock
- toString() - Method in class io.trino.spi.block.IntArrayBlockBuilder
- toString() - Method in class io.trino.spi.block.LongArrayBlock
- toString() - Method in class io.trino.spi.block.LongArrayBlockBuilder
- toString() - Method in class io.trino.spi.block.MapBlock
- toString() - Method in class io.trino.spi.block.MapBlockBuilder
- toString() - Method in class io.trino.spi.block.PageBuilderStatus
- toString() - Method in class io.trino.spi.block.RowBlock
- toString() - Method in class io.trino.spi.block.RowBlockBuilder
- toString() - Method in class io.trino.spi.block.RunLengthEncodedBlock
- toString() - Method in class io.trino.spi.block.ShortArrayBlock
- toString() - Method in class io.trino.spi.block.ShortArrayBlockBuilder
- toString() - Method in class io.trino.spi.block.SqlMap
- toString() - Method in class io.trino.spi.block.SqlRow
- toString() - Method in class io.trino.spi.block.VariableWidthBlock
- toString() - Method in class io.trino.spi.block.VariableWidthBlockBuilder
- toString() - Method in class io.trino.spi.catalog.CatalogName
- toString() - Method in record class io.trino.spi.catalog.CatalogProperties
-
Returns a string representation of this record class.
- toString() - Method in class io.trino.spi.connector.AggregateFunction
- toString() - Method in class io.trino.spi.connector.Assignment
- toString() - Method in class io.trino.spi.connector.BeginTableExecuteResult
- toString() - Method in class io.trino.spi.connector.CatalogHandle.CatalogVersion
- toString() - Method in class io.trino.spi.connector.CatalogHandle
- toString() - Method in class io.trino.spi.connector.CatalogSchemaName
- toString() - Method in class io.trino.spi.connector.CatalogSchemaRoutineName
- toString() - Method in class io.trino.spi.connector.CatalogSchemaTableName
- toString() - Method in class io.trino.spi.connector.ColumnMetadata
- toString() - Method in class io.trino.spi.connector.ColumnSchema
- toString() - Method in class io.trino.spi.connector.ConnectorMaterializedViewDefinition.Column
- toString() - Method in class io.trino.spi.connector.ConnectorMaterializedViewDefinition
- toString() - Method in class io.trino.spi.connector.ConnectorName
- toString() - Method in class io.trino.spi.connector.ConnectorTableMetadata
- toString() - Method in class io.trino.spi.connector.ConnectorTableSchema
- toString() - Method in class io.trino.spi.connector.ConnectorTableVersion
- toString() - Method in class io.trino.spi.connector.ConnectorViewDefinition
- toString() - Method in class io.trino.spi.connector.ConnectorViewDefinition.ViewColumn
- toString() - Method in class io.trino.spi.connector.ConstantProperty
- toString() - Method in class io.trino.spi.connector.Constraint
- toString() - Method in record class io.trino.spi.connector.EntityKindAndName
-
Returns a string representation of this record class.
- toString() - Method in record class io.trino.spi.connector.EntityPrivilege
-
Returns a string representation of this record class.
- toString() - Method in class io.trino.spi.connector.GroupingProperty
- toString() - Method in class io.trino.spi.connector.JoinCondition
-
Deprecated.
- toString() - Method in class io.trino.spi.connector.MaterializedViewFreshness
- toString() - Method in record class io.trino.spi.connector.RelationColumnsMetadata
-
Returns a string representation of this record class.
- toString() - Method in record class io.trino.spi.connector.RelationCommentMetadata
-
Returns a string representation of this record class.
- toString() - Method in class io.trino.spi.connector.SchemaRoutineName
- toString() - Method in class io.trino.spi.connector.SchemaTableName
- toString() - Method in class io.trino.spi.connector.SchemaTablePrefix
- toString() - Method in class io.trino.spi.connector.SortingProperty
- toString() - Method in class io.trino.spi.connector.SortItem
- toString() - Method in enum class io.trino.spi.connector.SortOrder
- toString() - Method in record class io.trino.spi.connector.WriterScalingOptions
-
Returns a string representation of this record class.
- toString() - Method in class io.trino.spi.ErrorCode
- toString() - Method in record class io.trino.spi.eventlistener.ColumnMaskReferenceInfo
-
Returns a string representation of this record class.
- toString() - Method in record class io.trino.spi.eventlistener.MaterializedViewReferenceInfo
-
Returns a string representation of this record class.
- toString() - Method in class io.trino.spi.eventlistener.QueryCompletedEvent
- toString() - Method in class io.trino.spi.eventlistener.QueryCreatedEvent
- toString() - Method in record class io.trino.spi.eventlistener.QueryPlanOptimizerStatistics
-
Returns a string representation of this record class.
- toString() - Method in record class io.trino.spi.eventlistener.RowFilterReferenceInfo
-
Returns a string representation of this record class.
- toString() - Method in class io.trino.spi.eventlistener.SplitCompletedEvent
- toString() - Method in record class io.trino.spi.eventlistener.ViewReferenceInfo
-
Returns a string representation of this record class.
- toString() - Method in class io.trino.spi.exchange.ExchangeId
- toString() - Method in record class io.trino.spi.exchange.ExchangeSourceHandleSource.ExchangeSourceHandleBatch
-
Returns a string representation of this record class.
- toString() - Method in class io.trino.spi.exchange.ExchangeSourceOutputSelector
- toString() - Method in class io.trino.spi.expression.Call
- toString() - Method in class io.trino.spi.expression.ConnectorExpression
- toString() - Method in class io.trino.spi.expression.Constant
- toString() - Method in class io.trino.spi.expression.FieldDereference
- toString() - Method in class io.trino.spi.expression.FunctionName
- toString() - Method in class io.trino.spi.expression.Variable
- toString() - Method in class io.trino.spi.function.AggregationFunctionMetadata
- toString() - Method in class io.trino.spi.function.BoundSignature
- toString() - Method in class io.trino.spi.function.CatalogSchemaFunctionName
- toString() - Method in class io.trino.spi.function.FunctionDependencyDeclaration.CastDependency
- toString() - Method in class io.trino.spi.function.FunctionDependencyDeclaration.FunctionDependency
- toString() - Method in class io.trino.spi.function.FunctionDependencyDeclaration.OperatorDependency
- toString() - Method in class io.trino.spi.function.FunctionId
- toString() - Method in class io.trino.spi.function.FunctionMetadata
- toString() - Method in class io.trino.spi.function.FunctionNullability
- toString() - Method in class io.trino.spi.function.InvocationConvention
- toString() - Method in record class io.trino.spi.function.LanguageFunction
-
Returns a string representation of this record class.
- toString() - Method in class io.trino.spi.function.LongVariableConstraint
- toString() - Method in class io.trino.spi.function.SchemaFunctionName
- toString() - Method in class io.trino.spi.function.Signature
- toString() - Method in class io.trino.spi.function.TypeVariableConstraint
- toString() - Method in class io.trino.spi.HostAddress
-
Rebuild the host:port string, including brackets if necessary.
- toString() - Method in class io.trino.spi.Location
- toString() - Method in class io.trino.spi.memory.MemoryPoolInfo
- toString() - Method in class io.trino.spi.metrics.Metrics
- toString() - Method in class io.trino.spi.Page
- toString() - Method in class io.trino.spi.predicate.AllOrNoneValueSet
- toString() - Method in class io.trino.spi.predicate.Domain
- toString() - Method in class io.trino.spi.predicate.EquatableValueSet
- toString() - Method in class io.trino.spi.predicate.NullableValue
- toString() - Method in class io.trino.spi.predicate.Range
- toString() - Method in class io.trino.spi.predicate.SortedRangeSet
- toString() - Method in class io.trino.spi.predicate.TupleDomain
- toString() - Method in interface io.trino.spi.predicate.ValueSet
- toString() - Method in class io.trino.spi.QueryId
- toString() - Method in class io.trino.spi.resourcegroups.ResourceGroupId
- toString() - Method in class io.trino.spi.resourcegroups.SelectionCriteria
- toString() - Method in class io.trino.spi.security.BasicPrincipal
- toString() - Method in class io.trino.spi.security.ConnectorIdentity
- toString() - Method in class io.trino.spi.security.Identity
- toString() - Method in class io.trino.spi.security.RoleGrant
- toString() - Method in class io.trino.spi.security.SelectedRole
- toString() - Method in class io.trino.spi.security.TrinoPrincipal
- toString() - Method in class io.trino.spi.session.PropertyMetadata
- toString() - Method in class io.trino.spi.session.ResourceEstimates
- toString() - Method in class io.trino.spi.SplitWeight
- toString() - Method in class io.trino.spi.statistics.ColumnStatisticMetadata
- toString() - Method in class io.trino.spi.statistics.ColumnStatistics
- toString() - Method in class io.trino.spi.statistics.DoubleRange
- toString() - Method in class io.trino.spi.statistics.Estimate
- toString() - Method in class io.trino.spi.statistics.TableStatistics
- toString() - Method in enum class io.trino.spi.transaction.IsolationLevel
- toString() - Method in class io.trino.spi.TrinoWarning
- toString() - Method in class io.trino.spi.type.AbstractType
- toString() - Method in class io.trino.spi.type.DecimalParseResult
- toString() - Method in class io.trino.spi.type.Int128
- toString() - Method in class io.trino.spi.type.LongTimestamp
- toString() - Method in class io.trino.spi.type.LongTimestampWithTimeZone
- toString() - Method in class io.trino.spi.type.NamedTypeSignature
- toString() - Method in class io.trino.spi.type.RowFieldName
- toString() - Method in class io.trino.spi.type.SqlDate
- toString() - Method in class io.trino.spi.type.SqlDecimal
- toString() - Method in class io.trino.spi.type.SqlTime
- toString() - Method in class io.trino.spi.type.SqlTimestamp
- toString() - Method in class io.trino.spi.type.SqlTimestampWithTimeZone
- toString() - Method in class io.trino.spi.type.SqlTimeWithTimeZone
- toString() - Method in class io.trino.spi.type.SqlVarbinary
- toString() - Method in class io.trino.spi.type.TimeZoneKey
- toString() - Method in class io.trino.spi.type.TypeId
- toString() - Method in class io.trino.spi.type.TypeParameter
- toString() - Method in class io.trino.spi.type.TypeSignature
- toString() - Method in class io.trino.spi.type.TypeSignatureParameter
- toString() - Method in class io.trino.spi.WarningCode
- toString(long, int) - Static method in class io.trino.spi.type.Decimals
- toString(ConnectorSession) - Method in class io.trino.spi.predicate.AllOrNoneValueSet
- toString(ConnectorSession) - Method in class io.trino.spi.predicate.Domain
- toString(ConnectorSession) - Method in class io.trino.spi.predicate.EquatableValueSet
- toString(ConnectorSession) - Method in class io.trino.spi.predicate.Range
- toString(ConnectorSession) - Method in class io.trino.spi.predicate.SortedRangeSet
- toString(ConnectorSession) - Method in class io.trino.spi.predicate.TupleDomain
- toString(ConnectorSession) - Method in interface io.trino.spi.predicate.ValueSet
- toString(ConnectorSession, int) - Method in class io.trino.spi.predicate.AllOrNoneValueSet
- toString(ConnectorSession, int) - Method in class io.trino.spi.predicate.Domain
- toString(ConnectorSession, int) - Method in class io.trino.spi.predicate.EquatableValueSet
- toString(ConnectorSession, int) - Method in class io.trino.spi.predicate.SortedRangeSet
- toString(ConnectorSession, int) - Method in interface io.trino.spi.predicate.ValueSet
- toString(Int128, int) - Static method in class io.trino.spi.type.Decimals
- toString(BigInteger, int) - Static method in class io.trino.spi.type.Decimals
- TOTAL_SIZE_IN_BYTES - Enum constant in enum class io.trino.spi.statistics.ColumnStatisticType
- totalTime() - Method in record class io.trino.spi.eventlistener.QueryPlanOptimizerStatistics
-
Returns the value of the
totalTime
record component. - toType() - Element in annotation interface io.trino.spi.function.CastDependency
- toWarningCode() - Method in enum class io.trino.spi.connector.StandardWarningCode
- toWarningCode() - Method in interface io.trino.spi.WarningCodeSupplier
- toZonedDateTime() - Method in class io.trino.spi.type.SqlTimestampWithTimeZone
- TRANSACTION_ALREADY_ABORTED - Enum constant in enum class io.trino.spi.StandardErrorCode
- TRANSACTION_CONFLICT - Enum constant in enum class io.trino.spi.StandardErrorCode
- transform(Function<Ranges, T>, Function<DiscreteValues, T>, Function<AllOrNone, T>) - Method in interface io.trino.spi.predicate.ValuesProcessor
- transform(Function<T, U>) - Method in class io.trino.spi.connector.ConstraintApplicationResult
- transformDomains(BiFunction<T, Domain, Domain>) - Method in class io.trino.spi.predicate.TupleDomain
- transformKeys(Function<T, U>) - Method in class io.trino.spi.predicate.TupleDomain
- translate(Function<E, Optional<T>>) - Method in class io.trino.spi.connector.ConstantProperty
- translate(Function<E, Optional<T>>) - Method in class io.trino.spi.connector.GroupingProperty
- translate(Function<E, Optional<T>>) - Method in interface io.trino.spi.connector.LocalProperty
- translate(Function<E, Optional<T>>) - Method in class io.trino.spi.connector.SortingProperty
-
Returns Optional.empty() if the column could not be translated
- trimTrailingSpaces(Slice) - Static method in class io.trino.spi.type.Chars
- trino.spi - module trino.spi
- TrinoException - Exception Class in io.trino.spi
- TrinoException(ErrorCodeSupplier, String) - Constructor for exception class io.trino.spi.TrinoException
- TrinoException(ErrorCodeSupplier, String, Throwable) - Constructor for exception class io.trino.spi.TrinoException
- TrinoException(ErrorCodeSupplier, Throwable) - Constructor for exception class io.trino.spi.TrinoException
- TrinoException(ErrorCodeSupplier, Optional<Location>, String, Throwable) - Constructor for exception class io.trino.spi.TrinoException
- TrinoPrincipal - Class in io.trino.spi.security
- TrinoPrincipal(PrincipalType, String) - Constructor for class io.trino.spi.security.TrinoPrincipal
- TrinoTransportException - Exception Class in io.trino.spi
- TrinoTransportException(ErrorCodeSupplier, HostAddress, String) - Constructor for exception class io.trino.spi.TrinoTransportException
- TrinoTransportException(ErrorCodeSupplier, HostAddress, String, Throwable) - Constructor for exception class io.trino.spi.TrinoTransportException
- trinoUuidToJavaUuid(Slice) - Static method in class io.trino.spi.type.UuidType
- TrinoWarning - Class in io.trino.spi
- TrinoWarning(WarningCode, String) - Constructor for class io.trino.spi.TrinoWarning
- TrinoWarning(WarningCodeSupplier, String) - Constructor for class io.trino.spi.TrinoWarning
- TRUE - Static variable in class io.trino.spi.expression.Constant
- truncateEpochMicrosToMillis(long) - Static method in class io.trino.spi.type.Timestamps
- truncateTable(ConnectorSession, ConnectorTableHandle) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Truncates the specified table
- truncateToLength(Slice, int) - Static method in class io.trino.spi.type.Varchars
- truncateToLength(Slice, Type) - Static method in class io.trino.spi.type.Varchars
- truncateToLength(Slice, VarcharType) - Static method in class io.trino.spi.type.Varchars
- truncateToLengthAndTrimSpaces(Slice, int) - Static method in class io.trino.spi.type.Chars
- truncateToLengthAndTrimSpaces(Slice, CharType) - Static method in class io.trino.spi.type.Chars
- truncateToLengthAndTrimSpaces(Slice, Type) - Static method in class io.trino.spi.type.Chars
- TRY_CAST_FUNCTION_NAME - Static variable in class io.trino.spi.expression.StandardFunctions
- tryExpandRanges(int) - Method in class io.trino.spi.predicate.AllOrNoneValueSet
- tryExpandRanges(int) - Method in class io.trino.spi.predicate.EquatableValueSet
- tryExpandRanges(int) - Method in class io.trino.spi.predicate.SortedRangeSet
- tryExpandRanges(int) - Method in interface io.trino.spi.predicate.ValueSet
-
Try to expand
valueSet
into a discrete set of (at mostlimit
) objects. - TupleDomain<T> - Class in io.trino.spi.predicate
-
Defines a set of valid tuples according to the constraints on each of its constituent columns
- TupleDomain.ColumnDomain<C> - Class in io.trino.spi.predicate
- type(Type) - Method in class io.trino.spi.function.table.ScalarArgument.Builder
- type(Type) - Method in class io.trino.spi.function.table.ScalarArgumentSpecification.Builder
- Type - Interface in io.trino.spi.type
- TYPE - Enum constant in enum class io.trino.spi.type.ParameterKind
- TYPE_MISMATCH - Enum constant in enum class io.trino.spi.StandardErrorCode
- TYPE_NOT_FOUND - Enum constant in enum class io.trino.spi.StandardErrorCode
- Type.Range - Class in io.trino.spi.type
- TypeId - Class in io.trino.spi.type
-
Represents an opaque identifier for a Type than can be used for serialization or storage in external systems.
- TypeManager - Interface in io.trino.spi.type
- TypeNotFoundException - Exception Class in io.trino.spi.type
- TypeNotFoundException(TypeSignature) - Constructor for exception class io.trino.spi.type.TypeNotFoundException
- TypeNotFoundException(TypeSignature, Throwable) - Constructor for exception class io.trino.spi.type.TypeNotFoundException
- TypeNotFoundException(String, Throwable) - Constructor for exception class io.trino.spi.type.TypeNotFoundException
- TypeOperatorDeclaration - Class in io.trino.spi.type
- TypeOperatorDeclaration.Builder - Class in io.trino.spi.type
- TypeOperators - Class in io.trino.spi.type
- TypeOperators() - Constructor for class io.trino.spi.type.TypeOperators
- TypeOperators(BiFunction<Object, Supplier<Object>, Object>) - Constructor for class io.trino.spi.type.TypeOperators
- typeParameter(TypeSignature) - Static method in class io.trino.spi.type.TypeSignatureParameter
- TypeParameter - Class in io.trino.spi.type
- TypeParameter - Annotation Interface in io.trino.spi.function
- typeParameters() - Element in annotation interface io.trino.spi.function.AccumulatorStateMetadata
- TypeParameters - Annotation Interface in io.trino.spi.function
- TypeParameterSpecialization - Annotation Interface in io.trino.spi.function
- TypeSignature - Class in io.trino.spi.type
- TypeSignature(String, TypeSignatureParameter...) - Constructor for class io.trino.spi.type.TypeSignature
- TypeSignature(String, List<TypeSignatureParameter>) - Constructor for class io.trino.spi.type.TypeSignature
- TypeSignatureParameter - Class in io.trino.spi.type
- TypeUtils - Class in io.trino.spi.type
- typeVariable() - Element in annotation interface io.trino.spi.function.WindowFunctionSignature
- typeVariable(String) - Method in class io.trino.spi.function.Signature.Builder
- typeVariable(String) - Static method in class io.trino.spi.function.TypeVariableConstraint
- typeVariable(String) - Static method in class io.trino.spi.type.TypeSignatureParameter
- typeVariableConstraint(TypeVariableConstraint) - Method in class io.trino.spi.function.Signature.Builder
- TypeVariableConstraint - Class in io.trino.spi.function
- TypeVariableConstraint.TypeVariableConstraintBuilder - Class in io.trino.spi.function
- typeVariableConstraints(List<TypeVariableConstraint>) - Method in class io.trino.spi.function.Signature.Builder
U
- UNBOUNDED_LENGTH - Static variable in class io.trino.spi.type.VarcharType
- union(Domain) - Method in class io.trino.spi.predicate.Domain
- union(ValueSet) - Method in class io.trino.spi.predicate.AllOrNoneValueSet
- union(ValueSet) - Method in class io.trino.spi.predicate.EquatableValueSet
- union(ValueSet) - Method in class io.trino.spi.predicate.SortedRangeSet
- union(ValueSet) - Method in interface io.trino.spi.predicate.ValueSet
- union(DoubleRange, DoubleRange) - Static method in class io.trino.spi.statistics.DoubleRange
- union(Collection<ValueSet>) - Method in class io.trino.spi.predicate.SortedRangeSet
- union(Collection<ValueSet>) - Method in interface io.trino.spi.predicate.ValueSet
- union(List<Domain>) - Static method in class io.trino.spi.predicate.Domain
- unknown() - Static method in class io.trino.spi.statistics.Estimate
- UNKNOWN - Enum constant in enum class io.trino.spi.connector.MaterializedViewFreshness.Freshness
- UNKNOWN - Enum constant in enum class io.trino.spi.exchange.ExchangeSourceOutputSelector.Selection
- UNKNOWN - Enum constant in enum class io.trino.spi.predicate.SortedRangeSet.DiscreteSetMarker
- UNKNOWN_TRANSACTION - Enum constant in enum class io.trino.spi.StandardErrorCode
- unpackMillisUtc(long) - Static method in class io.trino.spi.type.DateTimeEncoding
- unpackOffsetMinutes(long) - Static method in class io.trino.spi.type.DateTimeEncoding
- unpackTimeNanos(long) - Static method in class io.trino.spi.type.DateTimeEncoding
- unpackZoneKey(long) - Static method in class io.trino.spi.type.DateTimeEncoding
- Unstable - Annotation Interface in io.trino.spi
-
Signifies that a public API (public class, method or field) is permanently subject to incompatible changes, or even removal, in any future release, without prior notice.
- UNSUPPORTED_ISOLATION_LEVEL - Enum constant in enum class io.trino.spi.StandardErrorCode
- UNSUPPORTED_SUBQUERY - Enum constant in enum class io.trino.spi.StandardErrorCode
- UNSUPPORTED_TABLE_TYPE - Enum constant in enum class io.trino.spi.StandardErrorCode
- UPDATE - Enum constant in enum class io.trino.spi.resourcegroups.QueryType
- UPDATE - Enum constant in enum class io.trino.spi.security.Privilege
- UPDATE_DELETE_OPERATION_NUMBER - Static variable in interface io.trino.spi.connector.ConnectorMergeSink
-
Represents an old version of an updated row, to be deleted, when using
RowChangeParadigm.DELETE_ROW_AND_INSERT_ROW
. - UPDATE_INSERT_OPERATION_NUMBER - Static variable in interface io.trino.spi.connector.ConnectorMergeSink
-
Represents a new version of an updated row, to be inserted, when using
RowChangeParadigm.DELETE_ROW_AND_INSERT_ROW
. - UPDATE_OPERATION_NUMBER - Static variable in interface io.trino.spi.connector.ConnectorMergeSink
-
Represents an updated row when using
RowChangeParadigm.CHANGE_ONLY_UPDATED_COLUMNS
. - updateHandle(ExchangeSinkInstanceHandle) - Method in interface io.trino.spi.exchange.ExchangeSink
-
Update
ExchangeSinkInstanceHandle
. - updateMillisUtc(long, long) - Static method in class io.trino.spi.type.DateTimeEncoding
- updateSinkInstanceHandle(ExchangeSinkHandle, int) - Method in interface io.trino.spi.exchange.Exchange
-
Update
ExchangeSinkInstanceHandle
. - usedInput() - Static method in class io.trino.spi.function.table.TableFunctionProcessorState.Processed
- usedInputAndProduced(Page) - Static method in class io.trino.spi.function.table.TableFunctionProcessorState.Processed
- USER - Enum constant in enum class io.trino.spi.security.PrincipalType
- USER_CANCELED - Enum constant in enum class io.trino.spi.StandardErrorCode
- USER_ERROR - Enum constant in enum class io.trino.spi.ErrorType
- UTC_KEY - Static variable in class io.trino.spi.type.TimeZoneKey
- Utils - Class in io.trino.spi.predicate
- UUID - Static variable in class io.trino.spi.type.StandardTypes
- UUID - Static variable in class io.trino.spi.type.UuidType
- UuidType - Class in io.trino.spi.type
-
UUIDs are encoded in big-endian representation (the bytes are stored in the same order as they appear when a UUID is printed in hexadecimal).
V
- validateId(String) - Static method in class io.trino.spi.QueryId
- validateScan(ConnectorSession, ConnectorTableHandle) - Method in interface io.trino.spi.connector.ConnectorMetadata
-
Allows the connector to reject the table scan produced by the planner.
- value() - Element in annotation interface io.trino.spi.function.AggregationFunction
- value() - Element in annotation interface io.trino.spi.function.AggregationState
- value() - Element in annotation interface io.trino.spi.function.Constraints
- value() - Element in annotation interface io.trino.spi.function.Description
- value() - Element in annotation interface io.trino.spi.function.LiteralParameter
- value() - Element in annotation interface io.trino.spi.function.LiteralParameters
- value() - Element in annotation interface io.trino.spi.function.OutputFunction
- value() - Element in annotation interface io.trino.spi.function.ScalarFunction
- value() - Element in annotation interface io.trino.spi.function.ScalarOperator
- value() - Element in annotation interface io.trino.spi.function.SqlNullable
- value() - Element in annotation interface io.trino.spi.function.SqlType
- value() - Element in annotation interface io.trino.spi.function.TypeParameter
- value() - Element in annotation interface io.trino.spi.function.TypeParameters
- value() - Element in annotation interface io.trino.spi.function.WindowFunctionSignatures
- value(Object) - Method in class io.trino.spi.function.table.ScalarArgument.Builder
- VALUE_BLOCK_POSITION - Enum constant in enum class io.trino.spi.function.InvocationConvention.InvocationArgumentConvention
-
Argument is passed a ValueBlock followed by the integer position in the block.
- VALUE_BLOCK_POSITION_NOT_NULL - Enum constant in enum class io.trino.spi.function.InvocationConvention.InvocationArgumentConvention
-
Argument is passed a ValueBlock followed by the integer position in the block.
- ValueBlock - Interface in io.trino.spi.block
- ValueEntry(Type, Block) - Constructor for class io.trino.spi.predicate.EquatableValueSet.ValueEntry
- valueOf(long) - Static method in class io.trino.spi.type.Decimals
- valueOf(long) - Static method in class io.trino.spi.type.Int128
- valueOf(long[]) - Static method in class io.trino.spi.type.Int128
- valueOf(long, long) - Static method in class io.trino.spi.type.Int128
- valueOf(String) - Static method in enum class io.trino.spi.block.MapHashTables.HashBuildMode
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class io.trino.spi.connector.CatalogHandle.CatalogHandleType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class io.trino.spi.connector.ConnectorCapabilities
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class io.trino.spi.connector.JoinCondition.Operator
-
Deprecated.Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class io.trino.spi.connector.JoinType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class io.trino.spi.connector.MaterializedViewFreshness.Freshness
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class io.trino.spi.connector.PointerType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class io.trino.spi.connector.RelationType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class io.trino.spi.connector.RetryMode
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class io.trino.spi.connector.RowChangeParadigm
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class io.trino.spi.connector.SampleType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class io.trino.spi.connector.SaveMode
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class io.trino.spi.connector.SortOrder
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class io.trino.spi.connector.StandardWarningCode
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class io.trino.spi.connector.SystemTable.Distribution
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class io.trino.spi.ErrorType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class io.trino.spi.exchange.Exchange.SourceHandlesDeliveryMode
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class io.trino.spi.exchange.ExchangeSourceOutputSelector.Selection
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class io.trino.spi.function.FunctionKind
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class io.trino.spi.function.InvocationConvention.InvocationArgumentConvention
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class io.trino.spi.function.InvocationConvention.InvocationReturnConvention
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class io.trino.spi.function.OperatorType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class io.trino.spi.predicate.SortedRangeSet.DiscreteSetMarker
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in class io.trino.spi.QueryId
- valueOf(String) - Static method in enum class io.trino.spi.RefreshType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class io.trino.spi.resourcegroups.QueryType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class io.trino.spi.resourcegroups.ResourceGroupState
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class io.trino.spi.resourcegroups.SchedulingPolicy
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class io.trino.spi.security.PrincipalType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class io.trino.spi.security.Privilege
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class io.trino.spi.security.SelectedRole.Type
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in class io.trino.spi.security.SelectedRole
- valueOf(String) - Static method in enum class io.trino.spi.StandardErrorCode
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class io.trino.spi.statistics.ColumnStatisticType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class io.trino.spi.statistics.TableStatisticType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class io.trino.spi.transaction.IsolationLevel
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in class io.trino.spi.type.Int128
- valueOf(String) - Static method in enum class io.trino.spi.type.ParameterKind
-
Returns the enum constant of this class with the specified name.
- valueOf(BigDecimal) - Static method in class io.trino.spi.type.Decimals
- valueOf(BigInteger) - Static method in class io.trino.spi.type.Decimals
- valueOf(BigInteger) - Static method in class io.trino.spi.type.Int128
- valueOfShort(BigDecimal) - Static method in class io.trino.spi.type.Decimals
- values() - Static method in enum class io.trino.spi.block.MapHashTables.HashBuildMode
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class io.trino.spi.connector.CatalogHandle.CatalogHandleType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class io.trino.spi.connector.ConnectorCapabilities
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class io.trino.spi.connector.JoinCondition.Operator
-
Deprecated.Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class io.trino.spi.connector.JoinType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class io.trino.spi.connector.MaterializedViewFreshness.Freshness
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class io.trino.spi.connector.PointerType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class io.trino.spi.connector.RelationType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class io.trino.spi.connector.RetryMode
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class io.trino.spi.connector.RowChangeParadigm
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class io.trino.spi.connector.SampleType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class io.trino.spi.connector.SaveMode
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class io.trino.spi.connector.SortOrder
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class io.trino.spi.connector.StandardWarningCode
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class io.trino.spi.connector.SystemTable.Distribution
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class io.trino.spi.ErrorType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class io.trino.spi.exchange.Exchange.SourceHandlesDeliveryMode
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class io.trino.spi.exchange.ExchangeSourceOutputSelector.Selection
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class io.trino.spi.function.FunctionKind
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class io.trino.spi.function.InvocationConvention.InvocationArgumentConvention
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class io.trino.spi.function.InvocationConvention.InvocationReturnConvention
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class io.trino.spi.function.OperatorType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class io.trino.spi.predicate.SortedRangeSet.DiscreteSetMarker
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class io.trino.spi.RefreshType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class io.trino.spi.resourcegroups.QueryType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class io.trino.spi.resourcegroups.ResourceGroupState
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class io.trino.spi.resourcegroups.SchedulingPolicy
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class io.trino.spi.security.PrincipalType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class io.trino.spi.security.Privilege
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class io.trino.spi.security.SelectedRole.Type
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class io.trino.spi.StandardErrorCode
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class io.trino.spi.statistics.ColumnStatisticType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class io.trino.spi.statistics.TableStatisticType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class io.trino.spi.transaction.IsolationLevel
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class io.trino.spi.type.ParameterKind
-
Returns an array containing the constants of this enum class, in the order they are declared.
- ValueSet - Interface in io.trino.spi.predicate
- ValuesProcessor - Interface in io.trino.spi.predicate
- ValueWindowFunction - Class in io.trino.spi.function
- ValueWindowFunction() - Constructor for class io.trino.spi.function.ValueWindowFunction
- VARBINARY - Static variable in class io.trino.spi.type.StandardTypes
- VARBINARY - Static variable in class io.trino.spi.type.VarbinaryType
- VarbinaryType - Class in io.trino.spi.type
- VARCHAR - Static variable in class io.trino.spi.type.StandardTypes
- VARCHAR - Static variable in class io.trino.spi.type.VarcharType
- Varchars - Class in io.trino.spi.type
- VarcharType - Class in io.trino.spi.type
- variable() - Element in annotation interface io.trino.spi.function.Constraint
- Variable - Class in io.trino.spi.expression
- Variable(String, Type) - Constructor for class io.trino.spi.expression.Variable
- VARIABLE - Enum constant in enum class io.trino.spi.type.ParameterKind
- variableArity() - Method in class io.trino.spi.function.Signature.Builder
- VariableWidthBlock - Class in io.trino.spi.block
- VariableWidthBlock(int, Slice, int[], Optional<boolean[]>) - Constructor for class io.trino.spi.block.VariableWidthBlock
- VariableWidthBlockBuilder - Class in io.trino.spi.block
- VariableWidthBlockBuilder(BlockBuilderStatus, int, int) - Constructor for class io.trino.spi.block.VariableWidthBlockBuilder
- VariableWidthBlockEncoding - Class in io.trino.spi.block
- VariableWidthBlockEncoding() - Constructor for class io.trino.spi.block.VariableWidthBlockEncoding
- VariableWidthType - Interface in io.trino.spi.type
-
VariableWidthType is a type that can have a different size for every value.
- variadicBound(String) - Method in class io.trino.spi.function.TypeVariableConstraint.TypeVariableConstraintBuilder
- variadicTypeParameter(String, String) - Method in class io.trino.spi.function.Signature.Builder
- VersionEmbedder - Interface in io.trino.spi
- VIEW - Enum constant in enum class io.trino.spi.connector.RelationType
- VIEW_IS_RECURSIVE - Enum constant in enum class io.trino.spi.StandardErrorCode
- VIEW_IS_STALE - Enum constant in enum class io.trino.spi.StandardErrorCode
- ViewColumn(String, TypeId, Optional<String>) - Constructor for class io.trino.spi.connector.ConnectorViewDefinition.ViewColumn
- viewColumns() - Method in record class io.trino.spi.connector.RelationColumnsMetadata
-
Returns the value of the
viewColumns
record component. - ViewExpression - Class in io.trino.spi.security
- ViewExpression.Builder - Class in io.trino.spi.security
- viewName() - Method in interface io.trino.spi.eventlistener.BaseViewReferenceInfo
- viewName() - Method in record class io.trino.spi.eventlistener.MaterializedViewReferenceInfo
-
Returns the value of the
viewName
record component. - viewName() - Method in record class io.trino.spi.eventlistener.ViewReferenceInfo
-
Returns the value of the
viewName
record component. - ViewNotFoundException - Exception Class in io.trino.spi.connector
- ViewNotFoundException(SchemaTableName) - Constructor for exception class io.trino.spi.connector.ViewNotFoundException
- ViewNotFoundException(SchemaTableName, String) - Constructor for exception class io.trino.spi.connector.ViewNotFoundException
- ViewNotFoundException(SchemaTableName, String, Throwable) - Constructor for exception class io.trino.spi.connector.ViewNotFoundException
- ViewNotFoundException(SchemaTableName, Throwable) - Constructor for exception class io.trino.spi.connector.ViewNotFoundException
- ViewReferenceInfo - Record Class in io.trino.spi.eventlistener
-
This class is JSON serializable for convenience and serialization compatibility is not guaranteed across versions.
- ViewReferenceInfo(String, String, String) - Constructor for record class io.trino.spi.eventlistener.ViewReferenceInfo
-
Creates an instance of a
ViewReferenceInfo
record class.
W
- WarningCode - Class in io.trino.spi
- WarningCode(int, String) - Constructor for class io.trino.spi.WarningCode
- WarningCodeSupplier - Interface in io.trino.spi
- WEIGHTED - Enum constant in enum class io.trino.spi.resourcegroups.SchedulingPolicy
- WEIGHTED_FAIR - Enum constant in enum class io.trino.spi.resourcegroups.SchedulingPolicy
- WINDOW - Enum constant in enum class io.trino.spi.function.FunctionKind
- windowAccumulator() - Element in annotation interface io.trino.spi.function.AggregationFunction
- windowAccumulator(Class<? extends WindowAccumulator>) - Method in class io.trino.spi.function.AggregationImplementation.Builder
- WindowAccumulator - Interface in io.trino.spi.function
- windowBuilder(String) - Static method in class io.trino.spi.function.FunctionMetadata
- WindowFunction - Interface in io.trino.spi.function
- WindowFunctionSignature - Annotation Interface in io.trino.spi.function
- WindowFunctionSignatures - Annotation Interface in io.trino.spi.function
- WindowFunctionSupplier - Interface in io.trino.spi.function
- windowIndex - Variable in class io.trino.spi.function.RankingWindowFunction
- windowIndex - Variable in class io.trino.spi.function.ValueWindowFunction
- WindowIndex - Interface in io.trino.spi.function
-
A window index contains the sorted values for a window partition.
- withAdditionalConnectorRoles(Map<String, SelectedRole>) - Method in class io.trino.spi.security.Identity.Builder
- withAdditionalExtraCredentials(Map<String, String>) - Method in class io.trino.spi.security.Identity.Builder
- withAdditionalGroups(Set<String>) - Method in class io.trino.spi.security.Identity.Builder
- withAdditionalRoles(Map<String, SelectedRole>) - Method in class io.trino.spi.security.Identity.Builder
-
Deprecated.Use withAdditionalConnectorRoles
- withColumnDomains(Map<T, Domain>) - Static method in class io.trino.spi.predicate.TupleDomain
- withConnectorRole(SelectedRole) - Method in class io.trino.spi.security.ConnectorIdentity.Builder
- withConnectorRole(String, SelectedRole) - Method in class io.trino.spi.security.Identity.Builder
- withConnectorRole(Optional<SelectedRole>) - Method in class io.trino.spi.security.ConnectorIdentity.Builder
- withConnectorRoles(Map<String, SelectedRole>) - Method in class io.trino.spi.security.Identity.Builder
- withConstants(Set<E>) - Method in interface io.trino.spi.connector.LocalProperty
-
Simplfies this LocalProperty provided that the specified inputs are constants
- withDefaultPort(int) - Method in class io.trino.spi.HostAddress
-
Provide a default port if the parsed string contained only a host.
- withDetailedMessage(Type, ConnectorSession) - Method in exception class io.trino.spi.block.DuplicateMapKeyException
- withEnabledRoles(Set<String>) - Method in class io.trino.spi.security.Identity.Builder
- withEnabledSystemRoles(Set<String>) - Method in class io.trino.spi.security.ConnectorIdentity.Builder
- withExtraCredentials(Map<String, String>) - Method in class io.trino.spi.security.ConnectorIdentity.Builder
- withExtraCredentials(Map<String, String>) - Method in class io.trino.spi.security.Identity.Builder
- withGroups(Set<String>) - Method in class io.trino.spi.security.ConnectorIdentity.Builder
- withGroups(Set<String>) - Method in class io.trino.spi.security.Identity.Builder
- withMaxPageSize(int, List<? extends Type>) - Static method in class io.trino.spi.PageBuilder
- withOnDestroy(Runnable) - Method in class io.trino.spi.security.Identity.Builder
- withoutOwner() - Method in class io.trino.spi.connector.ConnectorViewDefinition
- withPrincipal(Principal) - Method in class io.trino.spi.security.ConnectorIdentity.Builder
- withPrincipal(Principal) - Method in class io.trino.spi.security.Identity.Builder
- withPrincipal(Optional<Principal>) - Method in class io.trino.spi.security.ConnectorIdentity.Builder
- withPrincipal(Optional<Principal>) - Method in class io.trino.spi.security.Identity.Builder
- withRole(String, SelectedRole) - Method in class io.trino.spi.security.Identity.Builder
-
Deprecated.Use withConnectorRole
- withRoles(Map<String, SelectedRole>) - Method in class io.trino.spi.security.Identity.Builder
-
Deprecated.Use withConnectorRoles
- withUser(String) - Method in class io.trino.spi.security.Identity.Builder
- wrapByteArrayAsBooleanBlockWithoutNulls(byte[]) - Static method in class io.trino.spi.type.BooleanType
-
This method signifies a contract to callers that as an optimization, they can encode BooleanType blocks as a byte[] directly and potentially bypass the BlockBuilder / BooleanType abstraction in the name of efficiency.
- writeBigDecimal(DecimalType, BlockBuilder, BigDecimal) - Static method in class io.trino.spi.type.Decimals
- writeBlock(SliceOutput, Block) - Method in interface io.trino.spi.block.BlockEncodingSerde
-
Write a blockEncoding to the output.
- writeBlock(BlockEncodingSerde, SliceOutput, Block) - Method in class io.trino.spi.block.ArrayBlockEncoding
- writeBlock(BlockEncodingSerde, SliceOutput, Block) - Method in interface io.trino.spi.block.BlockEncoding
-
Write the specified block to the specified output
- writeBlock(BlockEncodingSerde, SliceOutput, Block) - Method in class io.trino.spi.block.ByteArrayBlockEncoding
- writeBlock(BlockEncodingSerde, SliceOutput, Block) - Method in class io.trino.spi.block.DictionaryBlockEncoding
- writeBlock(BlockEncodingSerde, SliceOutput, Block) - Method in class io.trino.spi.block.Fixed12BlockEncoding
- writeBlock(BlockEncodingSerde, SliceOutput, Block) - Method in class io.trino.spi.block.Int128ArrayBlockEncoding
- writeBlock(BlockEncodingSerde, SliceOutput, Block) - Method in class io.trino.spi.block.IntArrayBlockEncoding
- writeBlock(BlockEncodingSerde, SliceOutput, Block) - Method in class io.trino.spi.block.LazyBlockEncoding
- writeBlock(BlockEncodingSerde, SliceOutput, Block) - Method in class io.trino.spi.block.LongArrayBlockEncoding
- writeBlock(BlockEncodingSerde, SliceOutput, Block) - Method in class io.trino.spi.block.MapBlockEncoding
- writeBlock(BlockEncodingSerde, SliceOutput, Block) - Method in class io.trino.spi.block.RowBlockEncoding
- writeBlock(BlockEncodingSerde, SliceOutput, Block) - Method in class io.trino.spi.block.RunLengthBlockEncoding
- writeBlock(BlockEncodingSerde, SliceOutput, Block) - Method in class io.trino.spi.block.ShortArrayBlockEncoding
- writeBlock(BlockEncodingSerde, SliceOutput, Block) - Method in class io.trino.spi.block.VariableWidthBlockEncoding
- writeBoolean(BlockBuilder, boolean) - Method in class io.trino.spi.type.AbstractType
- writeBoolean(BlockBuilder, boolean) - Method in class io.trino.spi.type.BooleanType
- writeBoolean(BlockBuilder, boolean) - Method in interface io.trino.spi.type.Type
-
Writes the boolean value into the
BlockBuilder
. - writeByte(byte) - Method in class io.trino.spi.block.ByteArrayBlockBuilder
- writeByte(BlockBuilder, byte) - Method in class io.trino.spi.type.TinyintType
- writeDouble(BlockBuilder, double) - Method in class io.trino.spi.type.AbstractType
- writeDouble(BlockBuilder, double) - Method in class io.trino.spi.type.DoubleType
- writeDouble(BlockBuilder, double) - Method in interface io.trino.spi.type.Type
-
Writes the double value into the
BlockBuilder
. - writeEntry(byte[], int, int) - Method in class io.trino.spi.block.VariableWidthBlockBuilder
- writeEntry(Slice) - Method in class io.trino.spi.block.VariableWidthBlockBuilder
- writeEntry(Slice, int, int) - Method in class io.trino.spi.block.VariableWidthBlockBuilder
- writeFixed12(long, int) - Method in class io.trino.spi.block.Fixed12BlockBuilder
- writeFloat(BlockBuilder, float) - Method in class io.trino.spi.type.RealType
- writeInt(int) - Method in class io.trino.spi.block.IntArrayBlockBuilder
- writeInt(BlockBuilder, int) - Method in class io.trino.spi.type.AbstractIntType
- writeInt128(long, long) - Method in class io.trino.spi.block.Int128ArrayBlockBuilder
- writeLong(long) - Method in class io.trino.spi.block.LongArrayBlockBuilder
- writeLong(BlockBuilder, long) - Method in class io.trino.spi.type.AbstractIntType
- writeLong(BlockBuilder, long) - Method in class io.trino.spi.type.AbstractLongType
- writeLong(BlockBuilder, long) - Method in class io.trino.spi.type.AbstractType
- writeLong(BlockBuilder, long) - Method in class io.trino.spi.type.RealType
- writeLong(BlockBuilder, long) - Method in class io.trino.spi.type.SmallintType
- writeLong(BlockBuilder, long) - Method in class io.trino.spi.type.TinyintType
- writeLong(BlockBuilder, long) - Method in interface io.trino.spi.type.Type
-
Writes the long value into the
BlockBuilder
. - writeLongTimestamp(BlockBuilder, long, int) - Static method in class io.trino.spi.type.TimestampTypes
- writeLongTimestamp(BlockBuilder, LongTimestamp) - Static method in class io.trino.spi.type.TimestampTypes
- writeNativeValue(Type, BlockBuilder, Object) - Static method in class io.trino.spi.type.TypeUtils
-
Write a native value object to the current entry of
blockBuilder
. - writeNativeValue(Type, Object) - Static method in class io.trino.spi.type.TypeUtils
- writeObject(BlockBuilder, Object) - Method in class io.trino.spi.type.AbstractType
- writeObject(BlockBuilder, Object) - Method in class io.trino.spi.type.ArrayType
- writeObject(BlockBuilder, Object) - Method in class io.trino.spi.type.MapType
- writeObject(BlockBuilder, Object) - Method in class io.trino.spi.type.RowType
- writeObject(BlockBuilder, Object) - Method in interface io.trino.spi.type.Type
-
Writes the Object value into the
BlockBuilder
. - WriterScalingOptions - Record Class in io.trino.spi.connector
- WriterScalingOptions(boolean, boolean) - Constructor for record class io.trino.spi.connector.WriterScalingOptions
- WriterScalingOptions(boolean, boolean, Optional<Integer>) - Constructor for record class io.trino.spi.connector.WriterScalingOptions
-
Creates an instance of a
WriterScalingOptions
record class. - writeShort(short) - Method in class io.trino.spi.block.ShortArrayBlockBuilder
- writeShort(BlockBuilder, short) - Method in class io.trino.spi.type.SmallintType
- writeShortDecimal(BlockBuilder, long) - Static method in class io.trino.spi.type.Decimals
- writeSlice(BlockBuilder, Slice) - Method in class io.trino.spi.type.AbstractType
- writeSlice(BlockBuilder, Slice) - Method in class io.trino.spi.type.CharType
- writeSlice(BlockBuilder, Slice) - Method in class io.trino.spi.type.HyperLogLogType
- writeSlice(BlockBuilder, Slice) - Method in class io.trino.spi.type.P4HyperLogLogType
- writeSlice(BlockBuilder, Slice) - Method in class io.trino.spi.type.QuantileDigestType
- writeSlice(BlockBuilder, Slice) - Method in interface io.trino.spi.type.Type
-
Writes the Slice value into the
BlockBuilder
. - writeSlice(BlockBuilder, Slice) - Method in class io.trino.spi.type.UuidType
- writeSlice(BlockBuilder, Slice) - Method in class io.trino.spi.type.VarbinaryType
- writeSlice(BlockBuilder, Slice) - Method in class io.trino.spi.type.VarcharType
- writeSlice(BlockBuilder, Slice, int, int) - Method in class io.trino.spi.type.AbstractType
- writeSlice(BlockBuilder, Slice, int, int) - Method in class io.trino.spi.type.CharType
- writeSlice(BlockBuilder, Slice, int, int) - Method in class io.trino.spi.type.HyperLogLogType
- writeSlice(BlockBuilder, Slice, int, int) - Method in class io.trino.spi.type.P4HyperLogLogType
- writeSlice(BlockBuilder, Slice, int, int) - Method in class io.trino.spi.type.QuantileDigestType
- writeSlice(BlockBuilder, Slice, int, int) - Method in interface io.trino.spi.type.Type
-
Writes the Slice value into the
BlockBuilder
. - writeSlice(BlockBuilder, Slice, int, int) - Method in class io.trino.spi.type.UuidType
- writeSlice(BlockBuilder, Slice, int, int) - Method in class io.trino.spi.type.VarbinaryType
- writeSlice(BlockBuilder, Slice, int, int) - Method in class io.trino.spi.type.VarcharType
- writeString(BlockBuilder, String) - Method in class io.trino.spi.type.CharType
- writeString(BlockBuilder, String) - Method in class io.trino.spi.type.VarcharType
- writeType(SliceOutput, Type) - Method in interface io.trino.spi.block.BlockEncodingSerde
-
Write a type to the output.
X
- XX_HASH_64 - Enum constant in enum class io.trino.spi.function.OperatorType
- xxHash64(double) - Static method in class io.trino.spi.type.DoubleType
- xxHash64Operator(long) - Static method in class io.trino.spi.type.TimeType
Z
- zero() - Static method in class io.trino.spi.statistics.Estimate
- ZERO - Static variable in class io.trino.spi.eventlistener.DoubleSymmetricDistribution
- ZERO - Static variable in class io.trino.spi.type.Int128
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
SystemAccessControl.checkCanImpersonateUser(io.trino.spi.security.Identity, java.lang.String)
instead