- canCreateSampledTables(ConnectorSession) - Method in class com.facebook.presto.spi.classloader.ClassLoaderSafeConnectorMetadata
-
- canCreateSampledTables(ConnectorSession) - Method in class com.facebook.presto.spi.connector.classloader.ClassLoaderSafeConnectorMetadata
-
- canCreateSampledTables(ConnectorSession) - Method in interface com.facebook.presto.spi.connector.ConnectorMetadata
-
Returns true if this catalog supports creation of sampled tables
- canCreateSampledTables(ConnectorSession) - Method in interface com.facebook.presto.spi.ConnectorMetadata
-
Deprecated.
Returns true if this catalog supports creation of sampled tables
- checkCanAddColumn(ConnectorTransactionHandle, Identity, SchemaTableName) - Method in interface com.facebook.presto.spi.connector.ConnectorAccessControl
-
Check if identity is allowed to add columns to the specified table in this catalog.
- checkCanAddColumn(Identity, SchemaTableName) - Method in interface com.facebook.presto.spi.security.ConnectorAccessControl
-
Deprecated.
Check if identity is allowed to add columns to the specified table in this catalog.
- checkCanCreateTable(ConnectorTransactionHandle, Identity, SchemaTableName) - Method in interface com.facebook.presto.spi.connector.ConnectorAccessControl
-
Check if identity is allowed to create the specified table in this catalog.
- checkCanCreateTable(Identity, SchemaTableName) - Method in interface com.facebook.presto.spi.security.ConnectorAccessControl
-
Deprecated.
Check if identity is allowed to create the specified table in this catalog.
- checkCanCreateView(ConnectorTransactionHandle, Identity, SchemaTableName) - Method in interface com.facebook.presto.spi.connector.ConnectorAccessControl
-
Check if identity is allowed to create the specified view in this catalog.
- checkCanCreateView(Identity, SchemaTableName) - Method in interface com.facebook.presto.spi.security.ConnectorAccessControl
-
Deprecated.
Check if identity is allowed to create the specified view in this catalog.
- checkCanCreateViewWithSelectFromTable(ConnectorTransactionHandle, Identity, SchemaTableName) - Method in interface com.facebook.presto.spi.connector.ConnectorAccessControl
-
Check if identity is allowed to create a view that selects from the specified table in this catalog.
- checkCanCreateViewWithSelectFromTable(Identity, SchemaTableName) - Method in interface com.facebook.presto.spi.security.ConnectorAccessControl
-
Deprecated.
Check if identity is allowed to create a view that selects from the specified table in this catalog.
- checkCanCreateViewWithSelectFromView(ConnectorTransactionHandle, Identity, SchemaTableName) - Method in interface com.facebook.presto.spi.connector.ConnectorAccessControl
-
Check if identity is allowed to create a view that selects from the specified view in this catalog.
- checkCanCreateViewWithSelectFromView(Identity, SchemaTableName) - Method in interface com.facebook.presto.spi.security.ConnectorAccessControl
-
Deprecated.
Check if identity is allowed to create a view that selects from the specified view in this catalog.
- checkCanDeleteFromTable(ConnectorTransactionHandle, Identity, SchemaTableName) - Method in interface com.facebook.presto.spi.connector.ConnectorAccessControl
-
Check if identity is allowed to delete from the specified table in this catalog.
- checkCanDeleteFromTable(Identity, SchemaTableName) - Method in interface com.facebook.presto.spi.security.ConnectorAccessControl
-
Deprecated.
Check if identity is allowed to delete from the specified table in this catalog.
- checkCanDropTable(ConnectorTransactionHandle, Identity, SchemaTableName) - Method in interface com.facebook.presto.spi.connector.ConnectorAccessControl
-
Check if identity is allowed to drop the specified table in this catalog.
- checkCanDropTable(Identity, SchemaTableName) - Method in interface com.facebook.presto.spi.security.ConnectorAccessControl
-
Deprecated.
Check if identity is allowed to drop the specified table in this catalog.
- checkCanDropView(ConnectorTransactionHandle, Identity, SchemaTableName) - Method in interface com.facebook.presto.spi.connector.ConnectorAccessControl
-
Check if identity is allowed to drop the specified view in this catalog.
- checkCanDropView(Identity, SchemaTableName) - Method in interface com.facebook.presto.spi.security.ConnectorAccessControl
-
Deprecated.
Check if identity is allowed to drop the specified view in this catalog.
- checkCanGrantTablePrivilege(Identity, Privilege, SchemaTableName) - Method in interface com.facebook.presto.spi.connector.ConnectorAccessControl
-
Check if identity is allowed to grant to any other user the specified privilege on the specified table.
- checkCanGrantTablePrivilege(Identity, Privilege, SchemaTableName) - Method in interface com.facebook.presto.spi.security.ConnectorAccessControl
-
Deprecated.
Check if identity is allowed to grant to any other user the specified privilege on the specified table.
- checkCanInsertIntoTable(ConnectorTransactionHandle, Identity, SchemaTableName) - Method in interface com.facebook.presto.spi.connector.ConnectorAccessControl
-
Check if identity is allowed to insert into the specified table in this catalog.
- checkCanInsertIntoTable(Identity, SchemaTableName) - Method in interface com.facebook.presto.spi.security.ConnectorAccessControl
-
Deprecated.
Check if identity is allowed to insert into the specified table in this catalog.
- checkCanRenameColumn(ConnectorTransactionHandle, Identity, SchemaTableName) - Method in interface com.facebook.presto.spi.connector.ConnectorAccessControl
-
Check if identity is allowed to rename a column in the specified table in this catalog.
- checkCanRenameColumn(Identity, SchemaTableName) - Method in interface com.facebook.presto.spi.security.ConnectorAccessControl
-
Deprecated.
Check if identity is allowed to rename a column in the specified table in this catalog.
- checkCanRenameTable(ConnectorTransactionHandle, Identity, SchemaTableName, SchemaTableName) - Method in interface com.facebook.presto.spi.connector.ConnectorAccessControl
-
Check if identity is allowed to rename the specified table in this catalog.
- checkCanRenameTable(Identity, SchemaTableName, SchemaTableName) - Method in interface com.facebook.presto.spi.security.ConnectorAccessControl
-
Deprecated.
Check if identity is allowed to rename the specified table in this catalog.
- checkCanSelectFromTable(ConnectorTransactionHandle, Identity, SchemaTableName) - Method in interface com.facebook.presto.spi.connector.ConnectorAccessControl
-
Check if identity is allowed to select from the specified table in this catalog.
- checkCanSelectFromTable(Identity, SchemaTableName) - Method in interface com.facebook.presto.spi.security.ConnectorAccessControl
-
Deprecated.
Check if identity is allowed to select from the specified table in this catalog.
- checkCanSelectFromView(ConnectorTransactionHandle, Identity, SchemaTableName) - Method in interface com.facebook.presto.spi.connector.ConnectorAccessControl
-
Check if identity is allowed to select from the specified view in this catalog.
- checkCanSelectFromView(Identity, SchemaTableName) - Method in interface com.facebook.presto.spi.security.ConnectorAccessControl
-
Deprecated.
Check if identity is allowed to select from the specified view in this catalog.
- checkCanSetCatalogSessionProperty(Identity, String) - Method in interface com.facebook.presto.spi.connector.ConnectorAccessControl
-
Check if identity is allowed to set the specified property in this catalog.
- checkCanSetCatalogSessionProperty(Identity, String) - Method in interface com.facebook.presto.spi.security.ConnectorAccessControl
-
Deprecated.
Check if identity is allowed to set the specified property in this catalog.
- checkCanSetSystemSessionProperty(Identity, String) - Method in interface com.facebook.presto.spi.security.SystemAccessControl
-
Check if identity is allowed to set the specified system property.
- checkCanSetUser(Principal, String) - Method in interface com.facebook.presto.spi.security.SystemAccessControl
-
Check if the principal is allowed to be the specified user.
- checkConnectorSupports(IsolationLevel, IsolationLevel) - Static method in enum com.facebook.presto.spi.transaction.IsolationLevel
-
- checkOverflow(BigInteger) - Static method in class com.facebook.presto.spi.type.Decimals
-
- checkReadablePosition(int) - Method in class com.facebook.presto.spi.block.AbstractFixedWidthBlock
-
- ClassLoaderSafeConnectorIndexResolver - Class in com.facebook.presto.spi.classloader
-
- ClassLoaderSafeConnectorIndexResolver(ConnectorIndexResolver, ClassLoader) - Constructor for class com.facebook.presto.spi.classloader.ClassLoaderSafeConnectorIndexResolver
-
- ClassLoaderSafeConnectorMetadata - Class in com.facebook.presto.spi.classloader
-
- ClassLoaderSafeConnectorMetadata(ConnectorMetadata, ClassLoader) - Constructor for class com.facebook.presto.spi.classloader.ClassLoaderSafeConnectorMetadata
-
- ClassLoaderSafeConnectorMetadata - Class in com.facebook.presto.spi.connector.classloader
-
- ClassLoaderSafeConnectorMetadata(ConnectorMetadata, ClassLoader) - Constructor for class com.facebook.presto.spi.connector.classloader.ClassLoaderSafeConnectorMetadata
-
- ClassLoaderSafeConnectorPageSink - Class in com.facebook.presto.spi.classloader
-
- ClassLoaderSafeConnectorPageSink(ConnectorPageSink, ClassLoader) - Constructor for class com.facebook.presto.spi.classloader.ClassLoaderSafeConnectorPageSink
-
- ClassLoaderSafeConnectorPageSinkProvider - Class in com.facebook.presto.spi.classloader
-
- ClassLoaderSafeConnectorPageSinkProvider(ConnectorPageSinkProvider, ClassLoader) - Constructor for class com.facebook.presto.spi.classloader.ClassLoaderSafeConnectorPageSinkProvider
-
- ClassLoaderSafeConnectorPageSinkProvider - Class in com.facebook.presto.spi.connector.classloader
-
- ClassLoaderSafeConnectorPageSinkProvider(ConnectorPageSinkProvider, ClassLoader) - Constructor for class com.facebook.presto.spi.connector.classloader.ClassLoaderSafeConnectorPageSinkProvider
-
- ClassLoaderSafeConnectorPageSourceProvider - Class in com.facebook.presto.spi.classloader
-
- ClassLoaderSafeConnectorPageSourceProvider(ConnectorPageSourceProvider, ClassLoader) - Constructor for class com.facebook.presto.spi.classloader.ClassLoaderSafeConnectorPageSourceProvider
-
- ClassLoaderSafeConnectorPageSourceProvider - Class in com.facebook.presto.spi.connector.classloader
-
- ClassLoaderSafeConnectorPageSourceProvider(ConnectorPageSourceProvider, ClassLoader) - Constructor for class com.facebook.presto.spi.connector.classloader.ClassLoaderSafeConnectorPageSourceProvider
-
- ClassLoaderSafeConnectorRecordSetProvider - Class in com.facebook.presto.spi.classloader
-
- ClassLoaderSafeConnectorRecordSetProvider(ConnectorRecordSetProvider, ClassLoader) - Constructor for class com.facebook.presto.spi.classloader.ClassLoaderSafeConnectorRecordSetProvider
-
- ClassLoaderSafeConnectorRecordSinkProvider - Class in com.facebook.presto.spi.classloader
-
- ClassLoaderSafeConnectorRecordSinkProvider(ConnectorRecordSinkProvider, ClassLoader) - Constructor for class com.facebook.presto.spi.classloader.ClassLoaderSafeConnectorRecordSinkProvider
-
- ClassLoaderSafeConnectorSplitManager - Class in com.facebook.presto.spi.classloader
-
- ClassLoaderSafeConnectorSplitManager(ConnectorSplitManager, ClassLoader) - Constructor for class com.facebook.presto.spi.classloader.ClassLoaderSafeConnectorSplitManager
-
- ClassLoaderSafeConnectorSplitManager - Class in com.facebook.presto.spi.connector.classloader
-
- ClassLoaderSafeConnectorSplitManager(ConnectorSplitManager, ClassLoader) - Constructor for class com.facebook.presto.spi.connector.classloader.ClassLoaderSafeConnectorSplitManager
-
- ClassLoaderSafeNodePartitioningProvider - Class in com.facebook.presto.spi.connector.classloader
-
- ClassLoaderSafeNodePartitioningProvider(ConnectorNodePartitioningProvider, ClassLoader) - Constructor for class com.facebook.presto.spi.connector.classloader.ClassLoaderSafeNodePartitioningProvider
-
- ClassLoaderSafeRecordSet - Class in com.facebook.presto.spi.classloader
-
- ClassLoaderSafeRecordSet(RecordSet, ClassLoader) - Constructor for class com.facebook.presto.spi.classloader.ClassLoaderSafeRecordSet
-
- close() - Method in class com.facebook.presto.spi.classloader.ThreadContextClassLoader
-
- close() - Method in interface com.facebook.presto.spi.ConnectorPageSource
-
Immediately finishes this page source.
- close() - Method in interface com.facebook.presto.spi.ConnectorSplitSource
-
- close() - Method in class com.facebook.presto.spi.FixedPageSource
-
- close() - Method in class com.facebook.presto.spi.FixedSplitSource
-
- close() - Method in interface com.facebook.presto.spi.RecordCursor
-
- close() - Method in class com.facebook.presto.spi.RecordPageSource
-
- closeEntry() - Method in class com.facebook.presto.spi.block.ArrayBlockBuilder
-
- closeEntry() - Method in class com.facebook.presto.spi.block.ArrayElementBlockWriter
-
- closeEntry() - Method in interface com.facebook.presto.spi.block.BlockBuilder
-
Write a byte to the current entry;
- closeEntry() - Method in class com.facebook.presto.spi.block.FixedWidthBlockBuilder
-
- closeEntry() - Method in class com.facebook.presto.spi.block.InterleavedBlockBuilder
-
- closeEntry() - Method in class com.facebook.presto.spi.block.VariableWidthBlockBuilder
-
- ColumnDomain(C, Domain) - Constructor for class com.facebook.presto.spi.predicate.TupleDomain.ColumnDomain
-
- ColumnHandle - Interface in com.facebook.presto.spi
-
- ColumnMetadata - Class in com.facebook.presto.spi
-
- ColumnMetadata(String, Type) - Constructor for class com.facebook.presto.spi.ColumnMetadata
-
- ColumnMetadata(String, Type, String, boolean) - Constructor for class com.facebook.presto.spi.ColumnMetadata
-
- ColumnNotFoundException - Exception in com.facebook.presto.spi
-
- ColumnNotFoundException(SchemaTableName, String) - Constructor for exception com.facebook.presto.spi.ColumnNotFoundException
-
- ColumnNotFoundException(SchemaTableName, String, String) - Constructor for exception com.facebook.presto.spi.ColumnNotFoundException
-
- ColumnNotFoundException(SchemaTableName, String, Throwable) - Constructor for exception com.facebook.presto.spi.ColumnNotFoundException
-
- ColumnNotFoundException(SchemaTableName, String, String, Throwable) - Constructor for exception com.facebook.presto.spi.ColumnNotFoundException
-
- columnWiseUnion(TupleDomain<T>, TupleDomain<T>, TupleDomain<T>...) - Static method in class com.facebook.presto.spi.predicate.TupleDomain
-
- columnWiseUnion(List<TupleDomain<T>>) - Static method in class com.facebook.presto.spi.predicate.TupleDomain
-
Returns a TupleDomain in which corresponding column Domains are unioned together.
- com.facebook.presto.spi - package com.facebook.presto.spi
-
- com.facebook.presto.spi.block - package com.facebook.presto.spi.block
-
- com.facebook.presto.spi.classloader - package com.facebook.presto.spi.classloader
-
- com.facebook.presto.spi.connector - package com.facebook.presto.spi.connector
-
- com.facebook.presto.spi.connector.classloader - package com.facebook.presto.spi.connector.classloader
-
- com.facebook.presto.spi.predicate - package com.facebook.presto.spi.predicate
-
- com.facebook.presto.spi.procedure - package com.facebook.presto.spi.procedure
-
- com.facebook.presto.spi.security - package com.facebook.presto.spi.security
-
- com.facebook.presto.spi.session - package com.facebook.presto.spi.session
-
- com.facebook.presto.spi.transaction - package com.facebook.presto.spi.transaction
-
- com.facebook.presto.spi.type - package com.facebook.presto.spi.type
-
- commit(ConnectorTransactionHandle) - Method in interface com.facebook.presto.spi.connector.Connector
-
Commit the transaction.
- commit() - Method in interface com.facebook.presto.spi.RecordSink
-
- commitCreateTable(ConnectorSession, ConnectorOutputTableHandle, Collection<Slice>) - Method in class com.facebook.presto.spi.classloader.ClassLoaderSafeConnectorMetadata
-
- commitCreateTable(ConnectorSession, ConnectorOutputTableHandle, Collection<Slice>) - Method in interface com.facebook.presto.spi.ConnectorMetadata
-
Deprecated.
Commit a table creation with data after the data is written.
- commitDelete(ConnectorSession, ConnectorTableHandle, Collection<Slice>) - Method in interface com.facebook.presto.spi.ConnectorMetadata
-
Deprecated.
Commit delete query
- commitInsert(ConnectorSession, ConnectorInsertTableHandle, Collection<Slice>) - Method in class com.facebook.presto.spi.classloader.ClassLoaderSafeConnectorMetadata
-
- commitInsert(ConnectorSession, ConnectorInsertTableHandle, Collection<Slice>) - Method in interface com.facebook.presto.spi.ConnectorMetadata
-
Deprecated.
Commit insert query
- compact() - Method in class com.facebook.presto.spi.block.DictionaryBlock
-
- compact() - Method in class com.facebook.presto.spi.Page
-
- compactBlocks(List<Block>) - Static method in class com.facebook.presto.spi.block.DictionaryBlock
-
- compareBlockValue(Type, Block, int, Block, int) - Method in enum com.facebook.presto.spi.block.SortOrder
-
Compares the values at the specified positions.
- compareTo(int, int, int, Block, int, int, int) - Method in class com.facebook.presto.spi.block.AbstractArrayBlock
-
- compareTo(int, int, int, Block, int, int, int) - Method in class com.facebook.presto.spi.block.AbstractArrayElementBlock
-
- compareTo(int, int, int, Block, int, int, int) - Method in class com.facebook.presto.spi.block.AbstractFixedWidthBlock
-
- compareTo(int, int, int, Block, int, int, int) - Method in class com.facebook.presto.spi.block.AbstractInterleavedBlock
-
- compareTo(int, int, int, Block, int, int, int) - Method in class com.facebook.presto.spi.block.AbstractVariableWidthBlock
-
- compareTo(int, int, int, Block, int, int, int) - Method in interface com.facebook.presto.spi.block.Block
-
Compares the byte sequences at offset
in the value at position
to the byte sequence at otherOffset
in the value at otherPosition
in otherBlock
.
- compareTo(int, int, int, Block, int, int, int) - Method in class com.facebook.presto.spi.block.DictionaryBlock
-
- compareTo(int, int, int, Block, int, int, int) - Method in class com.facebook.presto.spi.block.LazyBlock
-
- compareTo(int, int, int, Block, int, int, int) - Method in class com.facebook.presto.spi.block.RunLengthEncodedBlock
-
- compareTo(Marker) - Method in class com.facebook.presto.spi.predicate.Marker
-
- compareTo(Block, int, Block, int) - Method in class com.facebook.presto.spi.type.AbstractType
-
- compareTo(Block, int, Block, int) - Method in class com.facebook.presto.spi.type.BigintType
-
- compareTo(Block, int, Block, int) - Method in class com.facebook.presto.spi.type.BooleanType
-
- compareTo(Block, int, Block, int) - Method in class com.facebook.presto.spi.type.DateType
-
- compareTo(Block, int, Block, int) - Method in class com.facebook.presto.spi.type.DoubleType
-
- compareTo(Block, int, Block, int) - Method in class com.facebook.presto.spi.type.IntegerType
-
- compareTo(Block, int, Block, int) - Method in class com.facebook.presto.spi.type.IntervalDayTimeType
-
- compareTo(Block, int, Block, int) - Method in class com.facebook.presto.spi.type.IntervalYearMonthType
-
- compareTo(SqlVarbinary) - Method in class com.facebook.presto.spi.type.SqlVarbinary
-
- compareTo(Block, int, Block, int) - Method in class com.facebook.presto.spi.type.TimestampType
-
- compareTo(Block, int, Block, int) - Method in class com.facebook.presto.spi.type.TimestampWithTimeZoneType
-
- compareTo(Block, int, Block, int) - Method in class com.facebook.presto.spi.type.TimeType
-
- compareTo(Block, int, Block, int) - Method in class com.facebook.presto.spi.type.TimeWithTimeZoneType
-
- compareTo(Block, int, Block, int) - Method in interface com.facebook.presto.spi.type.Type
-
Compare the values in the specified block at the specified positions equal.
- compareTo(Block, int, Block, int) - Method in class com.facebook.presto.spi.type.VarbinaryType
-
- compareTo(Block, int, Block, int) - Method in class com.facebook.presto.spi.type.VarcharType
-
- complement() - Method in class com.facebook.presto.spi.predicate.AllOrNoneValueSet
-
- complement() - Method in class com.facebook.presto.spi.predicate.Domain
-
- complement() - Method in class com.facebook.presto.spi.predicate.EquatableValueSet
-
- complement() - Method in class com.facebook.presto.spi.predicate.SortedRangeSet
-
- complement() - Method in interface com.facebook.presto.spi.predicate.ValueSet
-
- computeBlockEncoding() - Method in class com.facebook.presto.spi.block.AbstractInterleavedBlock
-
Can only be called after the child class is initialized enough that getBlock will return the right value
- Connector - Interface in com.facebook.presto.spi
-
Deprecated.
- Connector - Interface in com.facebook.presto.spi.connector
-
- ConnectorAccessControl - Interface in com.facebook.presto.spi.connector
-
- ConnectorAccessControl - Interface in com.facebook.presto.spi.security
-
Deprecated.
- ConnectorFactory - Interface in com.facebook.presto.spi.connector
-
- ConnectorFactory - Interface in com.facebook.presto.spi
-
Deprecated.
- ConnectorHandleResolver - Interface in com.facebook.presto.spi
-
- ConnectorIndex - Interface in com.facebook.presto.spi
-
- ConnectorIndexHandle - Interface in com.facebook.presto.spi
-
- ConnectorIndexProvider - Interface in com.facebook.presto.spi.connector
-
- ConnectorIndexResolver - Interface in com.facebook.presto.spi
-
Deprecated.
- ConnectorInsertTableHandle - Interface in com.facebook.presto.spi
-
- ConnectorMetadata - Interface in com.facebook.presto.spi.connector
-
- ConnectorMetadata - Interface in com.facebook.presto.spi
-
Deprecated.
- ConnectorNewTableLayout - Class in com.facebook.presto.spi
-
- ConnectorNewTableLayout(ConnectorPartitioningHandle, List<String>) - Constructor for class com.facebook.presto.spi.ConnectorNewTableLayout
-
- ConnectorNodePartitioning - Class in com.facebook.presto.spi
-
- ConnectorNodePartitioning(ConnectorPartitioningHandle, List<ColumnHandle>) - Constructor for class com.facebook.presto.spi.ConnectorNodePartitioning
-
- ConnectorNodePartitioningProvider - Interface in com.facebook.presto.spi.connector
-
- ConnectorOutputTableHandle - Interface in com.facebook.presto.spi
-
- ConnectorPageSink - Interface in com.facebook.presto.spi
-
- ConnectorPageSinkProvider - Interface in com.facebook.presto.spi.connector
-
- ConnectorPageSinkProvider - Interface in com.facebook.presto.spi
-
Deprecated.
- ConnectorPageSource - Interface in com.facebook.presto.spi
-
- ConnectorPageSourceProvider - Interface in com.facebook.presto.spi.connector
-
- ConnectorPageSourceProvider - Interface in com.facebook.presto.spi
-
Deprecated.
- ConnectorPartitioningHandle - Interface in com.facebook.presto.spi.connector
-
- ConnectorRecordSetProvider - Interface in com.facebook.presto.spi.connector
-
- ConnectorRecordSetProvider - Interface in com.facebook.presto.spi
-
Deprecated.
- ConnectorRecordSinkProvider - Interface in com.facebook.presto.spi.connector
-
- ConnectorRecordSinkProvider - Interface in com.facebook.presto.spi
-
Deprecated.
- ConnectorResolvedIndex - Class in com.facebook.presto.spi
-
- ConnectorResolvedIndex(ConnectorIndexHandle, TupleDomain<ColumnHandle>) - Constructor for class com.facebook.presto.spi.ConnectorResolvedIndex
-
- ConnectorSession - Interface in com.facebook.presto.spi
-
- ConnectorSplit - Interface in com.facebook.presto.spi
-
- ConnectorSplitManager - Interface in com.facebook.presto.spi.connector
-
- ConnectorSplitManager - Interface in com.facebook.presto.spi
-
Deprecated.
- ConnectorSplitSource - Interface in com.facebook.presto.spi
-
- ConnectorTableHandle - Interface in com.facebook.presto.spi
-
- ConnectorTableLayout - Class in com.facebook.presto.spi
-
- ConnectorTableLayout(ConnectorTableLayoutHandle) - Constructor for class com.facebook.presto.spi.ConnectorTableLayout
-
- ConnectorTableLayout(ConnectorTableLayoutHandle, Optional<List<ColumnHandle>>, TupleDomain<ColumnHandle>, Optional<ConnectorNodePartitioning>, Optional<Set<ColumnHandle>>, Optional<DiscretePredicates>, List<LocalProperty<ColumnHandle>>) - Constructor for class com.facebook.presto.spi.ConnectorTableLayout
-
- ConnectorTableLayoutHandle - Interface in com.facebook.presto.spi
-
- ConnectorTableLayoutResult - Class in com.facebook.presto.spi
-
- ConnectorTableLayoutResult(ConnectorTableLayout, TupleDomain<ColumnHandle>) - Constructor for class com.facebook.presto.spi.ConnectorTableLayoutResult
-
- ConnectorTableMetadata - Class in com.facebook.presto.spi
-
- ConnectorTableMetadata(SchemaTableName, List<ColumnMetadata>) - Constructor for class com.facebook.presto.spi.ConnectorTableMetadata
-
- ConnectorTableMetadata(SchemaTableName, List<ColumnMetadata>, Map<String, Object>) - Constructor for class com.facebook.presto.spi.ConnectorTableMetadata
-
- ConnectorTableMetadata(SchemaTableName, List<ColumnMetadata>, Map<String, Object>, String) - Constructor for class com.facebook.presto.spi.ConnectorTableMetadata
-
- ConnectorTableMetadata(SchemaTableName, List<ColumnMetadata>, Map<String, Object>, String, boolean) - Constructor for class com.facebook.presto.spi.ConnectorTableMetadata
-
- ConnectorTransactionHandle - Interface in com.facebook.presto.spi.connector
-
- ConnectorViewDefinition - Class in com.facebook.presto.spi
-
- ConnectorViewDefinition(SchemaTableName, Optional<String>, String) - Constructor for class com.facebook.presto.spi.ConnectorViewDefinition
-
- ConstantProperty<E> - Class in com.facebook.presto.spi
-
- ConstantProperty(E) - Constructor for class com.facebook.presto.spi.ConstantProperty
-
- constrain(Set<E>) - Method in class com.facebook.presto.spi.GroupingProperty
-
- constrain(Set<E>) - Method in interface com.facebook.presto.spi.LocalProperty
-
Return a new instance with the give (reduced) set of columns
- Constraint<T> - Class in com.facebook.presto.spi
-
- Constraint(TupleDomain<T>, Predicate<Map<T, NullableValue>>) - Constructor for class com.facebook.presto.spi.Constraint
-
- consume(Consumer<Ranges>, Consumer<DiscreteValues>, Consumer<AllOrNone>) - Method in interface com.facebook.presto.spi.predicate.ValuesProcessor
-
- contains(Domain) - Method in class com.facebook.presto.spi.predicate.Domain
-
- contains(Range) - Method in class com.facebook.presto.spi.predicate.Range
-
- contains(TupleDomain<T>) - Method in class com.facebook.presto.spi.predicate.TupleDomain
-
Returns true only if the this TupleDomain contains all possible tuples that would be allowable by
the other TupleDomain.
- contains(ValueSet) - Method in interface com.facebook.presto.spi.predicate.ValueSet
-
- containsValue(Object) - Method in class com.facebook.presto.spi.predicate.AllOrNoneValueSet
-
- containsValue(Object) - Method in class com.facebook.presto.spi.predicate.EquatableValueSet
-
- containsValue(Object) - Method in class com.facebook.presto.spi.predicate.SortedRangeSet
-
- containsValue(Object) - Method in interface com.facebook.presto.spi.predicate.ValueSet
-
- copyFromBlock(Block) - Method in class com.facebook.presto.spi.block.LazyArrayBlock
-
- copyOf(Type, List<Range>) - Static method in class com.facebook.presto.spi.predicate.SortedRangeSet
-
- copyOf(Type, Collection<Object>) - Static method in interface com.facebook.presto.spi.predicate.ValueSet
-
- copyOfRanges(Type, Collection<Range>) - Static method in interface com.facebook.presto.spi.predicate.ValueSet
-
- copyPositions(List<Integer>) - Method in class com.facebook.presto.spi.block.AbstractArrayBlock
-
- copyPositions(List<Integer>) - Method in class com.facebook.presto.spi.block.AbstractArrayElementBlock
-
- copyPositions(List<Integer>) - Method in class com.facebook.presto.spi.block.AbstractInterleavedBlock
-
- copyPositions(List<Integer>) - Method in interface com.facebook.presto.spi.block.Block
-
Returns a block containing the specified positions.
- copyPositions(List<Integer>) - Method in class com.facebook.presto.spi.block.DictionaryBlock
-
- copyPositions(List<Integer>) - Method in class com.facebook.presto.spi.block.FixedWidthBlock
-
- copyPositions(List<Integer>) - Method in class com.facebook.presto.spi.block.FixedWidthBlockBuilder
-
- copyPositions(List<Integer>) - Method in class com.facebook.presto.spi.block.LazyBlock
-
- copyPositions(List<Integer>) - Method in class com.facebook.presto.spi.block.LazyFixedWidthBlock
-
- copyPositions(List<Integer>) - Method in class com.facebook.presto.spi.block.LazySliceArrayBlock
-
- copyPositions(List<Integer>) - Method in class com.facebook.presto.spi.block.RunLengthEncodedBlock
-
- copyPositions(List<Integer>) - Method in class com.facebook.presto.spi.block.SliceArrayBlock
-
- copyPositions(List<Integer>) - Method in class com.facebook.presto.spi.block.VariableWidthBlock
-
- copyPositions(List<Integer>) - Method in class com.facebook.presto.spi.block.VariableWidthBlockBuilder
-
- copyRegion(int, int) - Method in class com.facebook.presto.spi.block.AbstractArrayBlock
-
- copyRegion(int, int) - Method in class com.facebook.presto.spi.block.AbstractArrayElementBlock
-
- copyRegion(int, int) - Method in class com.facebook.presto.spi.block.AbstractInterleavedBlock
-
- copyRegion(int, int) - Method in interface com.facebook.presto.spi.block.Block
-
Returns a block starting at the specified position and extends for the
specified length.
- copyRegion(int, int) - Method in class com.facebook.presto.spi.block.DictionaryBlock
-
- copyRegion(int, int) - Method in class com.facebook.presto.spi.block.FixedWidthBlock
-
- copyRegion(int, int) - Method in class com.facebook.presto.spi.block.FixedWidthBlockBuilder
-
- copyRegion(int, int) - Method in class com.facebook.presto.spi.block.LazyBlock
-
- copyRegion(int, int) - Method in class com.facebook.presto.spi.block.LazyFixedWidthBlock
-
- copyRegion(int, int) - Method in class com.facebook.presto.spi.block.LazySliceArrayBlock
-
- copyRegion(int, int) - Method in class com.facebook.presto.spi.block.RunLengthEncodedBlock
-
- copyRegion(int, int) - Method in class com.facebook.presto.spi.block.SliceArrayBlock
-
- copyRegion(int, int) - Method in class com.facebook.presto.spi.block.VariableWidthBlock
-
- copyRegion(int, int) - Method in class com.facebook.presto.spi.block.VariableWidthBlockBuilder
-
- create(Type, Object, int) - Static method in class com.facebook.presto.spi.block.RunLengthEncodedBlock
-
- create(String, Map<String, String>) - Method in interface com.facebook.presto.spi.connector.ConnectorFactory
-
- create(String, Map<String, String>) - Method in interface com.facebook.presto.spi.ConnectorFactory
-
Deprecated.
- create(ValueSet, boolean) - Static method in class com.facebook.presto.spi.predicate.Domain
-
- create(Type, Object) - Static method in class com.facebook.presto.spi.predicate.EquatableValueSet.ValueEntry
-
- create(Map<String, String>) - Method in interface com.facebook.presto.spi.security.SystemAccessControlFactory
-
- createBlockBuilder(BlockBuilderStatus, int, int) - Method in class com.facebook.presto.spi.type.AbstractFixedWidthType
-
- createBlockBuilder(BlockBuilderStatus, int) - Method in class com.facebook.presto.spi.type.AbstractFixedWidthType
-
- createBlockBuilder(BlockBuilderStatus, int, int) - Method in class com.facebook.presto.spi.type.AbstractVariableWidthType
-
- createBlockBuilder(BlockBuilderStatus, int) - Method in class com.facebook.presto.spi.type.AbstractVariableWidthType
-
- createBlockBuilder(BlockBuilderStatus, int, int) - Method in interface com.facebook.presto.spi.type.Type
-
Creates the preferred block builder for this type.
- createBlockBuilder(BlockBuilderStatus, int) - Method in interface com.facebook.presto.spi.type.Type
-
Creates the preferred block builder for this type.
- createBlockBuilderStatus() - Method in class com.facebook.presto.spi.block.PageBuilderStatus
-
- createDecimalType(int, int) - Static method in class com.facebook.presto.spi.type.DecimalType
-
- createDecimalType(int) - Static method in class com.facebook.presto.spi.type.DecimalType
-
- createDecimalType() - Static method in class com.facebook.presto.spi.type.DecimalType
-
- createDictionaryBlock() - Method in class com.facebook.presto.spi.block.LazySliceArrayBlock
-
- createFixedSizeBlockBuilder(int) - Method in class com.facebook.presto.spi.type.AbstractFixedWidthType
-
- createFixedSizeBlockBuilder(int) - Method in interface com.facebook.presto.spi.type.FixedWidthType
-
Creates a block builder for this type sized to hold the specified number
of positions.
- createNonLazyBlock() - Method in class com.facebook.presto.spi.block.LazySliceArrayBlock
-
- createPageIndexer(List<? extends Type>) - Method in interface com.facebook.presto.spi.PageIndexerFactory
-
Deprecated.
- createPageSink(ConnectorSession, ConnectorOutputTableHandle) - Method in class com.facebook.presto.spi.classloader.ClassLoaderSafeConnectorPageSinkProvider
-
- createPageSink(ConnectorSession, ConnectorInsertTableHandle) - Method in class com.facebook.presto.spi.classloader.ClassLoaderSafeConnectorPageSinkProvider
-
- createPageSink(ConnectorTransactionHandle, ConnectorSession, ConnectorOutputTableHandle) - Method in class com.facebook.presto.spi.connector.classloader.ClassLoaderSafeConnectorPageSinkProvider
-
- createPageSink(ConnectorTransactionHandle, ConnectorSession, ConnectorInsertTableHandle) - Method in class com.facebook.presto.spi.connector.classloader.ClassLoaderSafeConnectorPageSinkProvider
-
- createPageSink(ConnectorTransactionHandle, ConnectorSession, ConnectorOutputTableHandle) - Method in interface com.facebook.presto.spi.connector.ConnectorPageSinkProvider
-
- createPageSink(ConnectorTransactionHandle, ConnectorSession, ConnectorInsertTableHandle) - Method in interface com.facebook.presto.spi.connector.ConnectorPageSinkProvider
-
- createPageSink(ConnectorSession, ConnectorOutputTableHandle) - Method in interface com.facebook.presto.spi.ConnectorPageSinkProvider
-
Deprecated.
- createPageSink(ConnectorSession, ConnectorInsertTableHandle) - Method in interface com.facebook.presto.spi.ConnectorPageSinkProvider
-
Deprecated.
- createPageSource(ConnectorSession, ConnectorSplit, List<ColumnHandle>) - Method in class com.facebook.presto.spi.classloader.ClassLoaderSafeConnectorPageSourceProvider
-
- createPageSource(ConnectorTransactionHandle, ConnectorSession, ConnectorSplit, List<ColumnHandle>) - Method in class com.facebook.presto.spi.connector.classloader.ClassLoaderSafeConnectorPageSourceProvider
-
- createPageSource(ConnectorTransactionHandle, ConnectorSession, ConnectorSplit, List<ColumnHandle>) - Method in interface com.facebook.presto.spi.connector.ConnectorPageSourceProvider
-
- createPageSource(ConnectorSession, ConnectorSplit, List<ColumnHandle>) - Method in interface com.facebook.presto.spi.ConnectorPageSourceProvider
-
Deprecated.
- createTable(ConnectorSession, ConnectorTableMetadata) - Method in class com.facebook.presto.spi.classloader.ClassLoaderSafeConnectorMetadata
-
- createTable(ConnectorSession, ConnectorTableMetadata) - Method in class com.facebook.presto.spi.connector.classloader.ClassLoaderSafeConnectorMetadata
-
- createTable(ConnectorSession, ConnectorTableMetadata) - Method in interface com.facebook.presto.spi.connector.ConnectorMetadata
-
Creates a table using the specified table metadata.
- createTable(ConnectorSession, ConnectorTableMetadata) - Method in interface com.facebook.presto.spi.ConnectorMetadata
-
Deprecated.
Creates a table using the specified table metadata.
- createVarcharType(int) - Static method in class com.facebook.presto.spi.type.VarcharType
-
- createView(ConnectorSession, SchemaTableName, String, boolean) - Method in class com.facebook.presto.spi.classloader.ClassLoaderSafeConnectorMetadata
-
- createView(ConnectorSession, SchemaTableName, String, boolean) - Method in class com.facebook.presto.spi.connector.classloader.ClassLoaderSafeConnectorMetadata
-
- createView(ConnectorSession, SchemaTableName, String, boolean) - Method in interface com.facebook.presto.spi.connector.ConnectorMetadata
-
Create the specified view.
- createView(ConnectorSession, SchemaTableName, String, boolean) - Method in interface com.facebook.presto.spi.ConnectorMetadata
-
Deprecated.
Create the specified view.
- cursor() - Method in class com.facebook.presto.spi.classloader.ClassLoaderSafeRecordSet
-
- cursor() - Method in class com.facebook.presto.spi.InMemoryRecordSet
-
- cursor() - Method in interface com.facebook.presto.spi.RecordSet
-
- cursor(ConnectorTransactionHandle, ConnectorSession, TupleDomain<Integer>) - Method in interface com.facebook.presto.spi.SystemTable
-
Create a cursor for the data in this table.
- getAccessControl() - Method in interface com.facebook.presto.spi.connector.Connector
-
- getAccessControl() - Method in interface com.facebook.presto.spi.Connector
-
Deprecated.
- getActiveDatasourceNodes(String) - Method in interface com.facebook.presto.spi.NodeManager
-
- getAddresses() - Method in interface com.facebook.presto.spi.ConnectorSplit
-
- getAllOrNone() - Method in class com.facebook.presto.spi.predicate.AllOrNoneValueSet
-
- getArguments() - Method in class com.facebook.presto.spi.procedure.Procedure
-
- getBase() - Method in class com.facebook.presto.spi.type.TypeSignature
-
- getBlock() - Method in class com.facebook.presto.spi.block.AbstractArrayElementBlock
-
- getBlock(int) - Method in class com.facebook.presto.spi.block.AbstractInterleavedBlock
-
- getBlock() - Method in class com.facebook.presto.spi.block.ArrayElementBlockWriter
-
- getBlock(int) - Method in class com.facebook.presto.spi.block.InterleavedBlock
-
- getBlock(int) - Method in class com.facebook.presto.spi.block.InterleavedBlockBuilder
-
- getBlock() - Method in class com.facebook.presto.spi.block.LazyBlock
-
- getBlock(int) - Method in class com.facebook.presto.spi.Page
-
- getBlock() - Method in class com.facebook.presto.spi.predicate.EquatableValueSet.ValueEntry
-
- getBlock() - Method in class com.facebook.presto.spi.predicate.NullableValue.Serializable
-
- getBlockBuilder(int) - Method in class com.facebook.presto.spi.PageBuilder
-
- getBlocks() - Method in class com.facebook.presto.spi.Page
-
- getBoolean(int) - Method in interface com.facebook.presto.spi.RecordCursor
-
- getBoolean(Block, int) - Method in class com.facebook.presto.spi.type.AbstractType
-
- getBoolean(Block, int) - Method in class com.facebook.presto.spi.type.BooleanType
-
- getBoolean(Block, int) - Method in interface com.facebook.presto.spi.type.Type
-
Gets the value at the block
position
as a boolean.
- getBound() - Method in class com.facebook.presto.spi.predicate.Marker
-
- getBucket(Page, int) - Method in interface com.facebook.presto.spi.BucketFunction
-
Gets the bucket for the tuple at the specified position.
- getBucketFunction(ConnectorTransactionHandle, ConnectorSession, ConnectorPartitioningHandle, List<Type>, int) - Method in class com.facebook.presto.spi.connector.classloader.ClassLoaderSafeNodePartitioningProvider
-
- getBucketFunction(ConnectorTransactionHandle, ConnectorSession, ConnectorPartitioningHandle, List<Type>, int) - Method in interface com.facebook.presto.spi.connector.ConnectorNodePartitioningProvider
-
- getBucketToNode(ConnectorTransactionHandle, ConnectorSession, ConnectorPartitioningHandle) - Method in class com.facebook.presto.spi.connector.classloader.ClassLoaderSafeNodePartitioningProvider
-
- getBucketToNode(ConnectorTransactionHandle, ConnectorSession, ConnectorPartitioningHandle) - Method in interface com.facebook.presto.spi.connector.ConnectorNodePartitioningProvider
-
- getByte(int, int) - Method in class com.facebook.presto.spi.block.AbstractArrayBlock
-
- getByte(int, int) - Method in class com.facebook.presto.spi.block.AbstractArrayElementBlock
-
- getByte(int, int) - Method in class com.facebook.presto.spi.block.AbstractFixedWidthBlock
-
- getByte(int, int) - Method in class com.facebook.presto.spi.block.AbstractInterleavedBlock
-
- getByte(int, int) - Method in class com.facebook.presto.spi.block.AbstractVariableWidthBlock
-
- getByte(int, int) - Method in interface com.facebook.presto.spi.block.Block
-
Gets a byte at offset
in the value at position
.
- getByte(int, int) - Method in class com.facebook.presto.spi.block.DictionaryBlock
-
- getByte(int, int) - Method in class com.facebook.presto.spi.block.LazyBlock
-
- getByte(int, int) - Method in class com.facebook.presto.spi.block.RunLengthEncodedBlock
-
- getBytes() - Method in class com.facebook.presto.spi.type.SqlVarbinary
-
- getChannelCount() - Method in class com.facebook.presto.spi.Page
-
- getCode() - Method in class com.facebook.presto.spi.ErrorCode
-
- getColumn() - Method in class com.facebook.presto.spi.ConstantProperty
-
- getColumn() - Method in class com.facebook.presto.spi.predicate.TupleDomain.ColumnDomain
-
- getColumn() - Method in class com.facebook.presto.spi.SortingProperty
-
- getColumnDomains() - Method in class com.facebook.presto.spi.predicate.TupleDomain
-
- getColumnHandleClass() - Method in interface com.facebook.presto.spi.ConnectorHandleResolver
-
- getColumnHandles(ConnectorSession, ConnectorTableHandle) - Method in class com.facebook.presto.spi.classloader.ClassLoaderSafeConnectorMetadata
-
- getColumnHandles(ConnectorSession, ConnectorTableHandle) - Method in class com.facebook.presto.spi.connector.classloader.ClassLoaderSafeConnectorMetadata
-
- getColumnHandles(ConnectorSession, ConnectorTableHandle) - Method in interface com.facebook.presto.spi.connector.ConnectorMetadata
-
Gets all of the columns on the specified table, or an empty map if the columns can not be enumerated.
- getColumnHandles(ConnectorSession, ConnectorTableHandle) - Method in interface com.facebook.presto.spi.ConnectorMetadata
-
Deprecated.
Gets all of the columns on the specified table, or an empty map if the columns can not be enumerated.
- getColumnMetadata(ConnectorSession, ConnectorTableHandle, ColumnHandle) - Method in class com.facebook.presto.spi.classloader.ClassLoaderSafeConnectorMetadata
-
- getColumnMetadata(ConnectorSession, ConnectorTableHandle, ColumnHandle) - Method in class com.facebook.presto.spi.connector.classloader.ClassLoaderSafeConnectorMetadata
-
- getColumnMetadata(ConnectorSession, ConnectorTableHandle, ColumnHandle) - Method in interface com.facebook.presto.spi.connector.ConnectorMetadata
-
Gets the metadata for the specified table column.
- getColumnMetadata(ConnectorSession, ConnectorTableHandle, ColumnHandle) - Method in interface com.facebook.presto.spi.ConnectorMetadata
-
Deprecated.
Gets the metadata for the specified table column.
- getColumnName() - Method in exception com.facebook.presto.spi.ColumnNotFoundException
-
- getColumns() - Method in class com.facebook.presto.spi.ConnectorTableLayout
-
The columns from the original table provided by this layout.
- getColumns() - Method in class com.facebook.presto.spi.ConnectorTableMetadata
-
- getColumns() - Method in class com.facebook.presto.spi.ConstantProperty
-
- getColumns() - Method in class com.facebook.presto.spi.DiscretePredicates
-
- getColumns() - Method in class com.facebook.presto.spi.GroupingProperty
-
- getColumns() - Method in interface com.facebook.presto.spi.LocalProperty
-
- getColumns() - Method in class com.facebook.presto.spi.SortingProperty
-
- getColumnTypes() - Method in class com.facebook.presto.spi.classloader.ClassLoaderSafeRecordSet
-
- getColumnTypes() - Method in class com.facebook.presto.spi.InMemoryRecordSet
-
- getColumnTypes() - Method in interface com.facebook.presto.spi.RecordSet
-
- getColumnTypes() - Method in interface com.facebook.presto.spi.RecordSink
-
- getComment() - Method in class com.facebook.presto.spi.ColumnMetadata
-
- getCommonSuperType(List<? extends Type>) - Method in interface com.facebook.presto.spi.type.TypeManager
-
- getCommonSuperType(Type, Type) - Method in interface com.facebook.presto.spi.type.TypeManager
-
- getCompletedBytes() - Method in interface com.facebook.presto.spi.ConnectorPageSource
-
Gets the number of input bytes processed by this page source so far.
- getCompletedBytes() - Method in class com.facebook.presto.spi.FixedPageSource
-
- getCompletedBytes() - Method in interface com.facebook.presto.spi.RecordCursor
-
- getCompletedBytes() - Method in class com.facebook.presto.spi.RecordPageSource
-
- getCoordinators() - Method in interface com.facebook.presto.spi.NodeManager
-
- getCurrentNode() - Method in interface com.facebook.presto.spi.NodeManager
-
- getCursor() - Method in class com.facebook.presto.spi.RecordPageSource
-
- getDataSourceName() - Method in interface com.facebook.presto.spi.ConnectorSplitSource
-
- getDataSourceName() - Method in class com.facebook.presto.spi.FixedSplitSource
-
- getDays() - Method in class com.facebook.presto.spi.type.SqlDate
-
- getDefaultValue() - Method in class com.facebook.presto.spi.session.PropertyMetadata
-
Gets the default value for this property.
- getDescription() - Method in class com.facebook.presto.spi.session.PropertyMetadata
-
Description for the end user.
- getDictionary() - Method in class com.facebook.presto.spi.block.DictionaryBlock
-
- getDictionaryEncoding() - Method in class com.facebook.presto.spi.block.DictionaryBlockEncoding
-
- getDictionarySourceId() - Method in class com.facebook.presto.spi.block.DictionaryBlock
-
- getDiscretePredicates() - Method in class com.facebook.presto.spi.ConnectorTableLayout
-
A collection of discrete predicates describing the data in this layout.
- getDiscreteValues() - Method in class com.facebook.presto.spi.predicate.EquatableValueSet
-
- getDiscreteValues() - Method in interface com.facebook.presto.spi.predicate.ValueSet
-
- getDisplayName() - Method in class com.facebook.presto.spi.type.AbstractType
-
- getDisplayName() - Method in interface com.facebook.presto.spi.type.Type
-
Returns the name of this type that should be displayed to end-users.
- getDisplayName() - Method in class com.facebook.presto.spi.type.VarcharType
-
- getDistribution() - Method in interface com.facebook.presto.spi.SystemTable
-
- getDomain() - Method in class com.facebook.presto.spi.predicate.TupleDomain.ColumnDomain
-
- getDomains() - Method in class com.facebook.presto.spi.predicate.TupleDomain
-
Gets the TupleDomain as a map of each column to its respective Domain.
- getDouble(int, int) - Method in class com.facebook.presto.spi.block.AbstractArrayBlock
-
- getDouble(int, int) - Method in class com.facebook.presto.spi.block.AbstractArrayElementBlock
-
- getDouble(int, int) - Method in class com.facebook.presto.spi.block.AbstractFixedWidthBlock
-
- getDouble(int, int) - Method in class com.facebook.presto.spi.block.AbstractInterleavedBlock
-
- getDouble(int, int) - Method in class com.facebook.presto.spi.block.AbstractVariableWidthBlock
-
- getDouble(int, int) - Method in interface com.facebook.presto.spi.block.Block
-
Gets a little endian double at offset
in the value at position
.
- getDouble(int, int) - Method in class com.facebook.presto.spi.block.DictionaryBlock
-
- getDouble(int, int) - Method in class com.facebook.presto.spi.block.LazyBlock
-
- getDouble(int, int) - Method in class com.facebook.presto.spi.block.RunLengthEncodedBlock
-
- getDouble(int) - Method in interface com.facebook.presto.spi.RecordCursor
-
- getDouble(Block, int) - Method in class com.facebook.presto.spi.type.AbstractType
-
- getDouble(Block, int) - Method in class com.facebook.presto.spi.type.DoubleType
-
- getDouble(Block, int) - Method in interface com.facebook.presto.spi.type.Type
-
Gets the value at the block
position
as a double.
- getEncoding() - Method in class com.facebook.presto.spi.block.AbstractArrayBlock
-
- getEncoding() - Method in class com.facebook.presto.spi.block.AbstractArrayElementBlock
-
- getEncoding() - Method in class com.facebook.presto.spi.block.AbstractFixedWidthBlock
-
- getEncoding() - Method in class com.facebook.presto.spi.block.AbstractInterleavedBlock
-
- getEncoding() - Method in class com.facebook.presto.spi.block.AbstractVariableWidthBlock
-
- getEncoding() - Method in interface com.facebook.presto.spi.block.Block
-
Get the encoding for this block.
- getEncoding() - Method in class com.facebook.presto.spi.block.DictionaryBlock
-
- getEncoding() - Method in class com.facebook.presto.spi.block.InterleavedBlock
-
- getEncoding() - Method in class com.facebook.presto.spi.block.InterleavedBlockBuilder
-
- getEncoding() - Method in class com.facebook.presto.spi.block.LazyBlock
-
- getEncoding() - Method in class com.facebook.presto.spi.block.LazySliceArrayBlock
-
- getEncoding() - Method in class com.facebook.presto.spi.block.RunLengthEncodedBlock
-
- getEncoding() - Method in class com.facebook.presto.spi.block.SliceArrayBlock
-
- getEntries() - Method in class com.facebook.presto.spi.predicate.EquatableValueSet
-
- getErrorCode() - Method in exception com.facebook.presto.spi.PrestoException
-
- getEstimatedSize(Block) - Method in class com.facebook.presto.spi.block.ArrayBlockEncoding
-
- getEstimatedSize(Block) - Method in interface com.facebook.presto.spi.block.BlockEncoding
-
Estimated serialized block size
- getEstimatedSize(Block) - Method in class com.facebook.presto.spi.block.DictionaryBlockEncoding
-
- getEstimatedSize(Block) - Method in class com.facebook.presto.spi.block.FixedWidthBlockEncoding
-
- getEstimatedSize(Block) - Method in class com.facebook.presto.spi.block.InterleavedBlockEncoding
-
- getEstimatedSize(Block) - Method in class com.facebook.presto.spi.block.LazyBlockEncoding
-
- getEstimatedSize(Block) - Method in class com.facebook.presto.spi.block.LazySliceArrayBlockEncoding
-
- getEstimatedSize(Block) - Method in class com.facebook.presto.spi.block.RunLengthBlockEncoding
-
- getEstimatedSize(Block) - Method in class com.facebook.presto.spi.block.SliceArrayBlockEncoding
-
- getEstimatedSize(Block) - Method in class com.facebook.presto.spi.block.VariableWidthBlockEncoding
-
- getFactory() - Method in class com.facebook.presto.spi.block.ArrayBlockEncoding
-
- getFactory() - Method in interface com.facebook.presto.spi.block.BlockEncoding
-
Return associated factory
- getFactory() - Method in class com.facebook.presto.spi.block.DictionaryBlockEncoding
-
- getFactory() - Method in class com.facebook.presto.spi.block.FixedWidthBlockEncoding
-
- getFactory() - Method in class com.facebook.presto.spi.block.InterleavedBlockEncoding
-
- getFactory() - Method in class com.facebook.presto.spi.block.LazyBlockEncoding
-
- getFactory() - Method in class com.facebook.presto.spi.block.LazySliceArrayBlockEncoding
-
- getFactory() - Method in class com.facebook.presto.spi.block.RunLengthBlockEncoding
-
- getFactory() - Method in class com.facebook.presto.spi.block.SliceArrayBlockEncoding
-
- getFactory() - Method in class com.facebook.presto.spi.block.VariableWidthBlockEncoding
-
- getFixedSize() - Method in class com.facebook.presto.spi.block.AbstractFixedWidthBlock
-
- getFixedSize() - Method in class com.facebook.presto.spi.block.FixedWidthBlockEncoding
-
- getFixedSize() - Method in class com.facebook.presto.spi.type.AbstractFixedWidthType
-
- getFixedSize() - Method in interface com.facebook.presto.spi.type.FixedWidthType
-
Gets the size of a value of this type is bytes.
- getFloat(int, int) - Method in class com.facebook.presto.spi.block.AbstractArrayBlock
-
- getFloat(int, int) - Method in class com.facebook.presto.spi.block.AbstractArrayElementBlock
-
- getFloat(int, int) - Method in class com.facebook.presto.spi.block.AbstractFixedWidthBlock
-
- getFloat(int, int) - Method in class com.facebook.presto.spi.block.AbstractInterleavedBlock
-
- getFloat(int, int) - Method in class com.facebook.presto.spi.block.AbstractVariableWidthBlock
-
- getFloat(int, int) - Method in interface com.facebook.presto.spi.block.Block
-
Gets a little endian float at offset
in the value at position
.
- getFloat(int, int) - Method in class com.facebook.presto.spi.block.DictionaryBlock
-
- getFloat(int, int) - Method in class com.facebook.presto.spi.block.LazyBlock
-
- getFloat(int, int) - Method in class com.facebook.presto.spi.block.RunLengthEncodedBlock
-
- getHandle() - Method in class com.facebook.presto.spi.ConnectorTableLayout
-
- getHandleResolver() - Method in interface com.facebook.presto.spi.connector.ConnectorFactory
-
- getHandleResolver() - Method in interface com.facebook.presto.spi.ConnectorFactory
-
Deprecated.
- getHigh() - Method in class com.facebook.presto.spi.predicate.Range
-
- getHostAndPort() - Method in interface com.facebook.presto.spi.Node
-
- getHostText() - Method in class com.facebook.presto.spi.HostAddress
-
Returns the portion of this HostAddress
instance that should
represent the hostname or IPv4/IPv6 literal.
- getHttpUri() - Method in interface com.facebook.presto.spi.Node
-
- getId(int) - Method in class com.facebook.presto.spi.block.DictionaryBlock
-
- getId() - Method in class com.facebook.presto.spi.type.TimeZoneKey
-
- getIdentity() - Method in interface com.facebook.presto.spi.ConnectorSession
-
- getIds() - Method in class com.facebook.presto.spi.block.DictionaryBlock
-
- getIds() - Method in class com.facebook.presto.spi.block.LazySliceArrayBlock
-
- getIndex(ConnectorSession, ConnectorIndexHandle, List<ColumnHandle>, List<ColumnHandle>) - Method in class com.facebook.presto.spi.classloader.ClassLoaderSafeConnectorIndexResolver
-
- getIndex(ConnectorTransactionHandle, ConnectorSession, ConnectorIndexHandle, List<ColumnHandle>, List<ColumnHandle>) - Method in interface com.facebook.presto.spi.connector.ConnectorIndexProvider
-
- getIndex(ConnectorSession, ConnectorIndexHandle, List<ColumnHandle>, List<ColumnHandle>) - Method in interface com.facebook.presto.spi.ConnectorIndexResolver
-
Deprecated.
- getIndexHandle() - Method in class com.facebook.presto.spi.ConnectorResolvedIndex
-
- getIndexHandleClass() - Method in interface com.facebook.presto.spi.ConnectorHandleResolver
-
- getIndexProvider() - Method in interface com.facebook.presto.spi.connector.Connector
-
- getIndexResolver() - Method in interface com.facebook.presto.spi.Connector
-
Deprecated.
- getInfo() - Method in interface com.facebook.presto.spi.ConnectorSplit
-
- getInsertTableHandleClass() - Method in interface com.facebook.presto.spi.ConnectorHandleResolver
-
- getInt(int, int) - Method in class com.facebook.presto.spi.block.AbstractArrayBlock
-
- getInt(int, int) - Method in class com.facebook.presto.spi.block.AbstractArrayElementBlock
-
- getInt(int, int) - Method in class com.facebook.presto.spi.block.AbstractFixedWidthBlock
-
- getInt(int, int) - Method in class com.facebook.presto.spi.block.AbstractInterleavedBlock
-
- getInt(int, int) - Method in class com.facebook.presto.spi.block.AbstractVariableWidthBlock
-
- getInt(int, int) - Method in interface com.facebook.presto.spi.block.Block
-
Gets a little endian int at offset
in the value at position
.
- getInt(int, int) - Method in class com.facebook.presto.spi.block.DictionaryBlock
-
- getInt(int, int) - Method in class com.facebook.presto.spi.block.LazyBlock
-
- getInt(int, int) - Method in class com.facebook.presto.spi.block.RunLengthEncodedBlock
-
- getIsolationLevel() - Method in interface com.facebook.presto.spi.Connector
-
Deprecated.
Get the transaction read isolation level supported by this connector.
- getJavaType() - Method in class com.facebook.presto.spi.session.PropertyMetadata
-
Java type of this property.
- getJavaType() - Method in class com.facebook.presto.spi.type.AbstractType
-
- getJavaType() - Method in interface com.facebook.presto.spi.type.Type
-
Gets the Java class type used to represent this value on the stack during
expression execution.
- getKey() - Method in class com.facebook.presto.spi.type.TimeZoneKey
-
- getKind() - Method in class com.facebook.presto.spi.type.TypeParameter
-
- getKind() - Method in class com.facebook.presto.spi.type.TypeSignatureParameter
-
- getLeastSignificantBits() - Method in class com.facebook.presto.spi.block.DictionaryId
-
- getLength(int) - Method in class com.facebook.presto.spi.block.AbstractArrayBlock
-
- getLength(int) - Method in class com.facebook.presto.spi.block.AbstractArrayElementBlock
-
- getLength(int) - Method in class com.facebook.presto.spi.block.AbstractFixedWidthBlock
-
- getLength(int) - Method in class com.facebook.presto.spi.block.AbstractInterleavedBlock
-
- getLength(int) - Method in interface com.facebook.presto.spi.block.Block
-
Gets the length of the value at the position
.
- getLength(int) - Method in class com.facebook.presto.spi.block.DictionaryBlock
-
- getLength(int) - Method in class com.facebook.presto.spi.block.LazyBlock
-
- getLength(int) - Method in class com.facebook.presto.spi.block.LazySliceArrayBlock
-
- getLength(int) - Method in class com.facebook.presto.spi.block.RunLengthEncodedBlock
-
- getLength(int) - Method in class com.facebook.presto.spi.block.SliceArrayBlock
-
- getLength(int) - Method in class com.facebook.presto.spi.block.VariableWidthBlock
-
- getLength(int) - Method in class com.facebook.presto.spi.block.VariableWidthBlockBuilder
-
- getLength() - Method in class com.facebook.presto.spi.type.VarcharType
-
- getLocale() - Method in interface com.facebook.presto.spi.ConnectorSession
-
- getLocalProperties() - Method in class com.facebook.presto.spi.ConnectorTableLayout
-
Properties describing the layout of the data (grouping/sorting) within each partition
- getLong(int, int) - Method in class com.facebook.presto.spi.block.AbstractArrayBlock
-
- getLong(int, int) - Method in class com.facebook.presto.spi.block.AbstractArrayElementBlock
-
- getLong(int, int) - Method in class com.facebook.presto.spi.block.AbstractFixedWidthBlock
-
- getLong(int, int) - Method in class com.facebook.presto.spi.block.AbstractInterleavedBlock
-
- getLong(int, int) - Method in class com.facebook.presto.spi.block.AbstractVariableWidthBlock
-
- getLong(int, int) - Method in interface com.facebook.presto.spi.block.Block
-
Gets a little endian long at offset
in the value at position
.
- getLong(int, int) - Method in class com.facebook.presto.spi.block.DictionaryBlock
-
- getLong(int, int) - Method in class com.facebook.presto.spi.block.LazyBlock
-
- getLong(int, int) - Method in class com.facebook.presto.spi.block.RunLengthEncodedBlock
-
- getLong(int) - Method in interface com.facebook.presto.spi.RecordCursor
-
- getLong(Block, int) - Method in class com.facebook.presto.spi.type.AbstractType
-
- getLong(Block, int) - Method in class com.facebook.presto.spi.type.BigintType
-
- getLong(Block, int) - Method in class com.facebook.presto.spi.type.DateType
-
- getLong(Block, int) - Method in class com.facebook.presto.spi.type.IntegerType
-
- getLong(Block, int) - Method in class com.facebook.presto.spi.type.IntervalDayTimeType
-
- getLong(Block, int) - Method in class com.facebook.presto.spi.type.IntervalYearMonthType
-
- getLong(Block, int) - Method in class com.facebook.presto.spi.type.TimestampType
-
- getLong(Block, int) - Method in class com.facebook.presto.spi.type.TimestampWithTimeZoneType
-
- getLong(Block, int) - Method in class com.facebook.presto.spi.type.TimeType
-
- getLong(Block, int) - Method in class com.facebook.presto.spi.type.TimeWithTimeZoneType
-
- getLong(Block, int) - Method in interface com.facebook.presto.spi.type.Type
-
Gets the value at the block
position
as a long.
- getLongLiteral() - Method in class com.facebook.presto.spi.type.TypeParameter
-
- getLongLiteral() - Method in class com.facebook.presto.spi.type.TypeSignatureParameter
-
- getLow() - Method in class com.facebook.presto.spi.predicate.Range
-
- getMaxBlockSizeInBytes() - Method in class com.facebook.presto.spi.block.BlockBuilderStatus
-
- getMaxBlockSizeInBytes() - Method in class com.facebook.presto.spi.block.PageBuilderStatus
-
- getMaxIndex() - Method in interface com.facebook.presto.spi.PageIndexer
-
Deprecated.
Returns maximum index value returned.
- getMaxPageSizeInBytes() - Method in class com.facebook.presto.spi.block.PageBuilderStatus
-
- getMessage() - Method in exception com.facebook.presto.spi.PrestoException
-
- getMetadata(ConnectorTransactionHandle) - Method in interface com.facebook.presto.spi.connector.Connector
-
Guaranteed to be called at most once per transaction.
- getMetadata() - Method in interface com.facebook.presto.spi.Connector
-
Deprecated.
- getMethodHandle() - Method in class com.facebook.presto.spi.procedure.Procedure
-
- getMillisUtc() - Method in class com.facebook.presto.spi.type.SqlTime
-
- getMillisUtc() - Method in class com.facebook.presto.spi.type.SqlTimestamp
-
- getMillisUtc() - Method in class com.facebook.presto.spi.type.SqlTimestampWithTimeZone
-
- getMillisUtc() - Method in class com.facebook.presto.spi.type.SqlTimeWithTimeZone
-
- getMostSignificantBits() - Method in class com.facebook.presto.spi.block.DictionaryId
-
- getName() - Method in class com.facebook.presto.spi.block.ArrayBlockEncoding.ArrayBlockEncodingFactory
-
- getName() - Method in class com.facebook.presto.spi.block.ArrayBlockEncoding
-
- getName() - Method in interface com.facebook.presto.spi.block.BlockEncoding
-
Gets the unique name of this encoding.
- getName() - Method in interface com.facebook.presto.spi.block.BlockEncodingFactory
-
Gets the unique name of this encoding.
- getName() - Method in class com.facebook.presto.spi.block.DictionaryBlockEncoding.DictionaryBlockEncodingFactory
-
- getName() - Method in class com.facebook.presto.spi.block.DictionaryBlockEncoding
-
- getName() - Method in class com.facebook.presto.spi.block.FixedWidthBlockEncoding.FixedWidthBlockEncodingFactory
-
- getName() - Method in class com.facebook.presto.spi.block.FixedWidthBlockEncoding
-
- getName() - Method in class com.facebook.presto.spi.block.InterleavedBlockEncoding
-
- getName() - Method in class com.facebook.presto.spi.block.InterleavedBlockEncoding.InterleavedBlockEncodingFactory
-
- getName() - Method in class com.facebook.presto.spi.block.LazyBlockEncoding
-
- getName() - Method in class com.facebook.presto.spi.block.LazyBlockEncoding.LazyBlockEncodingFactory
-
- getName() - Method in class com.facebook.presto.spi.block.LazySliceArrayBlockEncoding
-
- getName() - Method in class com.facebook.presto.spi.block.LazySliceArrayBlockEncoding.LazySliceArrayBlockEncodingFactory
-
- getName() - Method in class com.facebook.presto.spi.block.RunLengthBlockEncoding
-
- getName() - Method in class com.facebook.presto.spi.block.SliceArrayBlockEncoding
-
- getName() - Method in class com.facebook.presto.spi.block.SliceArrayBlockEncoding.SliceArrayBlockEncodingFactory
-
- getName() - Method in class com.facebook.presto.spi.block.VariableWidthBlockEncoding
-
- getName() - Method in class com.facebook.presto.spi.block.VariableWidthBlockEncoding.VariableWidthBlockEncodingFactory
-
- getName() - Method in class com.facebook.presto.spi.ColumnMetadata
-
- getName() - Method in interface com.facebook.presto.spi.connector.ConnectorFactory
-
- getName() - Method in interface com.facebook.presto.spi.ConnectorFactory
-
Deprecated.
- getName() - Method in class com.facebook.presto.spi.ConnectorViewDefinition
-
- getName() - Method in class com.facebook.presto.spi.ErrorCode
-
- getName() - Method in class com.facebook.presto.spi.procedure.Procedure.Argument
-
- getName() - Method in class com.facebook.presto.spi.procedure.Procedure
-
- getName() - Method in interface com.facebook.presto.spi.security.SystemAccessControlFactory
-
- getName() - Method in class com.facebook.presto.spi.session.PropertyMetadata
-
Name of the session property.
- getName() - Method in class com.facebook.presto.spi.type.NamedType
-
- getName() - Method in class com.facebook.presto.spi.type.NamedTypeSignature
-
- getNamedType() - Method in class com.facebook.presto.spi.type.TypeParameter
-
- getNamedTypeSignature() - Method in class com.facebook.presto.spi.type.TypeSignatureParameter
-
- getNewTableLayout(ConnectorSession, ConnectorTableMetadata) - Method in class com.facebook.presto.spi.connector.classloader.ClassLoaderSafeConnectorMetadata
-
- getNewTableLayout(ConnectorSession, ConnectorTableMetadata) - Method in interface com.facebook.presto.spi.connector.ConnectorMetadata
-
Get the physical layout for a new table.
- getNextBatch(int) - Method in interface com.facebook.presto.spi.ConnectorSplitSource
-
- getNextBatch(int) - Method in class com.facebook.presto.spi.FixedSplitSource
-
- getNextPage() - Method in interface com.facebook.presto.spi.ConnectorPageSource
-
Gets the next page of data.
- getNextPage() - Method in class com.facebook.presto.spi.FixedPageSource
-
- getNextPage() - Method in class com.facebook.presto.spi.RecordPageSource
-
- getNodeIdentifier() - Method in interface com.facebook.presto.spi.Node
-
- getNodePartitioning() - Method in class com.facebook.presto.spi.ConnectorTableLayout
-
The partitioning of the table across the worker nodes.
- getNodePartitioningProvider() - Method in interface com.facebook.presto.spi.connector.Connector
-
- getNodes(NodeState) - Method in interface com.facebook.presto.spi.NodeManager
-
- getNullableSingleValue() - Method in class com.facebook.presto.spi.predicate.Domain
-
- getObject(int, Class<T>) - Method in class com.facebook.presto.spi.block.AbstractArrayBlock
-
- getObject(int, Class<T>) - Method in class com.facebook.presto.spi.block.AbstractArrayElementBlock
-
- getObject(int, Class<T>) - Method in class com.facebook.presto.spi.block.AbstractInterleavedBlock
-
- getObject(int, Class<T>) - Method in interface com.facebook.presto.spi.block.Block
-
Gets an object in the value at position
.
- getObject(int, Class<T>) - Method in class com.facebook.presto.spi.block.DictionaryBlock
-
- getObject(int, Class<T>) - Method in class com.facebook.presto.spi.block.LazyBlock
-
- getObject(int, Class<T>) - Method in class com.facebook.presto.spi.block.RunLengthEncodedBlock
-
- getObject(int) - Method in interface com.facebook.presto.spi.RecordCursor
-
- getObject(Block, int) - Method in class com.facebook.presto.spi.type.AbstractType
-
- getObject() - Method in class com.facebook.presto.spi.type.DecimalParseResult
-
- getObject(Block, int) - Method in interface com.facebook.presto.spi.type.Type
-
Gets the value at the block
position
as an Object.
- getObjectValue(ConnectorSession, Block, int) - Method in class com.facebook.presto.spi.type.BigintType
-
- getObjectValue(ConnectorSession, Block, int) - Method in class com.facebook.presto.spi.type.BooleanType
-
- getObjectValue(ConnectorSession, Block, int) - Method in class com.facebook.presto.spi.type.DateType
-
- getObjectValue(ConnectorSession, Block, int) - Method in class com.facebook.presto.spi.type.DoubleType
-
- getObjectValue(ConnectorSession, Block, int) - Method in class com.facebook.presto.spi.type.HyperLogLogType
-
- getObjectValue(ConnectorSession, Block, int) - Method in class com.facebook.presto.spi.type.IntegerType
-
- getObjectValue(ConnectorSession, Block, int) - Method in class com.facebook.presto.spi.type.IntervalDayTimeType
-
- getObjectValue(ConnectorSession, Block, int) - Method in class com.facebook.presto.spi.type.IntervalYearMonthType
-
- getObjectValue(ConnectorSession, Block, int) - Method in class com.facebook.presto.spi.type.P4HyperLogLogType
-
- getObjectValue(ConnectorSession, Block, int) - Method in class com.facebook.presto.spi.type.TimestampType
-
- getObjectValue(ConnectorSession, Block, int) - Method in class com.facebook.presto.spi.type.TimestampWithTimeZoneType
-
- getObjectValue(ConnectorSession, Block, int) - Method in class com.facebook.presto.spi.type.TimeType
-
- getObjectValue(ConnectorSession, Block, int) - Method in class com.facebook.presto.spi.type.TimeWithTimeZoneType
-
- getObjectValue(ConnectorSession, Block, int) - Method in interface com.facebook.presto.spi.type.Type
-
Gets an object representation of the type value in the block
position
.
- getObjectValue(ConnectorSession, Block, int) - Method in class com.facebook.presto.spi.type.VarbinaryType
-
- getObjectValue(ConnectorSession, Block, int) - Method in class com.facebook.presto.spi.type.VarcharType
-
- getOffsetBase() - Method in class com.facebook.presto.spi.block.AbstractArrayBlock
-
- getOffsetBase() - Method in class com.facebook.presto.spi.block.ArrayBlock
-
- getOffsetBase() - Method in class com.facebook.presto.spi.block.ArrayBlockBuilder
-
- getOffsetBase() - Method in class com.facebook.presto.spi.block.LazyArrayBlock
-
- getOffsets() - Method in class com.facebook.presto.spi.block.AbstractArrayBlock
-
- getOffsets() - Method in class com.facebook.presto.spi.block.ArrayBlock
-
- getOffsets() - Method in class com.facebook.presto.spi.block.ArrayBlockBuilder
-
- getOffsets() - Method in class com.facebook.presto.spi.block.LazyArrayBlock
-
- getOrder() - Method in class com.facebook.presto.spi.SortingProperty
-
- getOrderedRanges() - Method in interface com.facebook.presto.spi.predicate.Ranges
-
- getOrderedRanges() - Method in class com.facebook.presto.spi.predicate.SortedRangeSet
-
- getOutputTableHandleClass() - Method in interface com.facebook.presto.spi.ConnectorHandleResolver
-
- getOwner() - Method in class com.facebook.presto.spi.ConnectorTableMetadata
-
- getOwner() - Method in class com.facebook.presto.spi.ConnectorViewDefinition
-
- getPageSinkProvider() - Method in interface com.facebook.presto.spi.connector.Connector
-
- getPageSinkProvider() - Method in interface com.facebook.presto.spi.Connector
-
Deprecated.
- getPageSourceProvider() - Method in interface com.facebook.presto.spi.connector.Connector
-
- getPageSourceProvider() - Method in interface com.facebook.presto.spi.Connector
-
Deprecated.
- getParameterizedType(String, List<TypeSignatureParameter>) - Method in interface com.facebook.presto.spi.type.TypeManager
-
Gets the type with the specified base type, and the given parameters, or null if not found.
- getParameterizedType(String, List<TypeSignature>, List<String>) - Method in interface com.facebook.presto.spi.type.TypeManager
-
Deprecated.
- getParameters() - Method in class com.facebook.presto.spi.type.TypeSignature
-
- getPartitionColumns() - Method in class com.facebook.presto.spi.ConnectorNewTableLayout
-
- getPartitioning() - Method in class com.facebook.presto.spi.ConnectorNewTableLayout
-
- getPartitioningColumns() - Method in class com.facebook.presto.spi.ConnectorNodePartitioning
-
The columns used to partition the table across the worker nodes.
- getPartitioningHandle() - Method in class com.facebook.presto.spi.ConnectorNodePartitioning
-
A handle to the partitioning scheme used to divide the table across worker nodes.
- getPartitioningHandleClass() - Method in interface com.facebook.presto.spi.ConnectorHandleResolver
-
- getPort() - Method in class com.facebook.presto.spi.HostAddress
-
Get the current port number, failing if no port is defined.
- getPortOrDefault(int) - Method in class com.facebook.presto.spi.HostAddress
-
Returns the current port number, with a default if no port is defined.
- getPositionCount() - Method in class com.facebook.presto.spi.block.ArrayBlock
-
- getPositionCount() - Method in class com.facebook.presto.spi.block.ArrayBlockBuilder
-
- getPositionCount() - Method in class com.facebook.presto.spi.block.ArrayElementBlockWriter
-
- getPositionCount() - Method in interface com.facebook.presto.spi.block.Block
-
Returns the number of positions in this block.
- getPositionCount() - Method in class com.facebook.presto.spi.block.DictionaryBlock
-
- getPositionCount() - Method in class com.facebook.presto.spi.block.FixedWidthBlock
-
- getPositionCount() - Method in class com.facebook.presto.spi.block.FixedWidthBlockBuilder
-
- getPositionCount() - Method in class com.facebook.presto.spi.block.InterleavedBlock
-
- getPositionCount() - Method in class com.facebook.presto.spi.block.InterleavedBlockBuilder
-
- getPositionCount() - Method in class com.facebook.presto.spi.block.LazyArrayBlock
-
- getPositionCount() - Method in class com.facebook.presto.spi.block.LazyBlock
-
- getPositionCount() - Method in class com.facebook.presto.spi.block.LazyFixedWidthBlock
-
- getPositionCount() - Method in class com.facebook.presto.spi.block.LazySliceArrayBlock
-
- getPositionCount() - Method in class com.facebook.presto.spi.block.RunLengthEncodedBlock
-
- getPositionCount() - Method in class com.facebook.presto.spi.block.SliceArrayBlock
-
- getPositionCount() - Method in class com.facebook.presto.spi.block.VariableWidthBlock
-
- getPositionCount() - Method in class com.facebook.presto.spi.block.VariableWidthBlockBuilder
-
- getPositionCount() - Method in class com.facebook.presto.spi.Page
-
- getPositionCount() - Method in class com.facebook.presto.spi.PageBuilder
-
- getPositionOffset(int) - Method in class com.facebook.presto.spi.block.AbstractVariableWidthBlock
-
- getPositionOffset(int) - Method in class com.facebook.presto.spi.block.LazySliceArrayBlock
-
- getPositionOffset(int) - Method in class com.facebook.presto.spi.block.SliceArrayBlock
-
- getPositionOffset(int) - Method in class com.facebook.presto.spi.block.VariableWidthBlock
-
- getPositionOffset(int) - Method in class com.facebook.presto.spi.block.VariableWidthBlockBuilder
-
- getPrecision() - Method in class com.facebook.presto.spi.type.DecimalType
-
- getPrecision() - Method in class com.facebook.presto.spi.type.SqlDecimal
-
- getPredicate() - Method in class com.facebook.presto.spi.ConnectorTableLayout
-
A predicate that describes the universe of data in this layout.
- getPredicates() - Method in class com.facebook.presto.spi.DiscretePredicates
-
- getPrincipal() - Method in class com.facebook.presto.spi.security.Identity
-
- getPrintableValue(ConnectorSession) - Method in class com.facebook.presto.spi.predicate.Marker
-
- getProcedures() - Method in interface com.facebook.presto.spi.connector.Connector
-
- getProperties() - Method in class com.facebook.presto.spi.ConnectorTableMetadata
-
- getProperty(String, Class<T>) - Method in interface com.facebook.presto.spi.ConnectorSession
-
- getQueryId() - Method in interface com.facebook.presto.spi.ConnectorSession
-
- getRangeCount() - Method in interface com.facebook.presto.spi.predicate.Ranges
-
- getRangeCount() - Method in class com.facebook.presto.spi.predicate.SortedRangeSet
-
- getRanges() - Method in class com.facebook.presto.spi.predicate.SortedRangeSet
-
- getRanges() - Method in interface com.facebook.presto.spi.predicate.ValueSet
-
- getRawSlice() - Method in class com.facebook.presto.spi.block.AbstractFixedWidthBlock
-
- getRawSlice(int) - Method in class com.facebook.presto.spi.block.AbstractVariableWidthBlock
-
- getRawSlice() - Method in class com.facebook.presto.spi.block.FixedWidthBlock
-
- getRawSlice() - Method in class com.facebook.presto.spi.block.FixedWidthBlockBuilder
-
- getRawSlice() - Method in class com.facebook.presto.spi.block.LazyFixedWidthBlock
-
- getRawSlice(int) - Method in class com.facebook.presto.spi.block.LazySliceArrayBlock
-
- getRawSlice(int) - Method in class com.facebook.presto.spi.block.SliceArrayBlock
-
- getRawSlice(int) - Method in class com.facebook.presto.spi.block.VariableWidthBlock
-
- getRawSlice(int) - Method in class com.facebook.presto.spi.block.VariableWidthBlockBuilder
-
- getReadTimeNanos() - Method in interface com.facebook.presto.spi.ConnectorPageSource
-
Gets the wall time this page source spent reading data from the input.
- getReadTimeNanos() - Method in class com.facebook.presto.spi.FixedPageSource
-
- getReadTimeNanos() - Method in interface com.facebook.presto.spi.RecordCursor
-
- getReadTimeNanos() - Method in class com.facebook.presto.spi.RecordPageSource
-
- getRecordSet(ConnectorSession, ConnectorSplit, List<? extends ColumnHandle>) - Method in class com.facebook.presto.spi.classloader.ClassLoaderSafeConnectorRecordSetProvider
-
- getRecordSet(ConnectorTransactionHandle, ConnectorSession, ConnectorSplit, List<? extends ColumnHandle>) - Method in interface com.facebook.presto.spi.connector.ConnectorRecordSetProvider
-
- getRecordSet(ConnectorSession, ConnectorSplit, List<? extends ColumnHandle>) - Method in interface com.facebook.presto.spi.ConnectorRecordSetProvider
-
Deprecated.
- getRecordSetProvider() - Method in interface com.facebook.presto.spi.connector.Connector
-
- getRecordSetProvider() - Method in interface com.facebook.presto.spi.Connector
-
Deprecated.
- getRecordSink(ConnectorSession, ConnectorOutputTableHandle) - Method in class com.facebook.presto.spi.classloader.ClassLoaderSafeConnectorRecordSinkProvider
-
- getRecordSink(ConnectorSession, ConnectorInsertTableHandle) - Method in class com.facebook.presto.spi.classloader.ClassLoaderSafeConnectorRecordSinkProvider
-
- getRecordSink(ConnectorTransactionHandle, ConnectorSession, ConnectorOutputTableHandle) - Method in interface com.facebook.presto.spi.connector.ConnectorRecordSinkProvider
-
- getRecordSink(ConnectorTransactionHandle, ConnectorSession, ConnectorInsertTableHandle) - Method in interface com.facebook.presto.spi.connector.ConnectorRecordSinkProvider
-
- getRecordSink(ConnectorSession, ConnectorOutputTableHandle) - Method in interface com.facebook.presto.spi.ConnectorRecordSinkProvider
-
Deprecated.
- getRecordSink(ConnectorSession, ConnectorInsertTableHandle) - Method in interface com.facebook.presto.spi.ConnectorRecordSinkProvider
-
Deprecated.
- getRecordSinkProvider() - Method in interface com.facebook.presto.spi.connector.Connector
-
- getRecordSinkProvider() - Method in interface com.facebook.presto.spi.Connector
-
Deprecated.
- getRegion(int, int) - Method in class com.facebook.presto.spi.block.AbstractArrayBlock
-
- getRegion(int, int) - Method in class com.facebook.presto.spi.block.AbstractArrayElementBlock
-
- getRegion(int, int) - Method in class com.facebook.presto.spi.block.AbstractInterleavedBlock
-
- getRegion(int, int) - Method in interface com.facebook.presto.spi.block.Block
-
Returns a block starting at the specified position and extends for the
specified length.
- getRegion(int, int) - Method in class com.facebook.presto.spi.block.DictionaryBlock
-
- getRegion(int, int) - Method in class com.facebook.presto.spi.block.FixedWidthBlock
-
- getRegion(int, int) - Method in class com.facebook.presto.spi.block.FixedWidthBlockBuilder
-
- getRegion(int, int) - Method in class com.facebook.presto.spi.block.LazyBlock
-
- getRegion(int, int) - Method in class com.facebook.presto.spi.block.LazyFixedWidthBlock
-
- getRegion(int, int) - Method in class com.facebook.presto.spi.block.LazySliceArrayBlock
-
- getRegion(int, int) - Method in class com.facebook.presto.spi.block.RunLengthEncodedBlock
-
- getRegion(int, int) - Method in class com.facebook.presto.spi.block.SliceArrayBlock
-
- getRegion(int, int) - Method in class com.facebook.presto.spi.block.VariableWidthBlock
-
- getRegion(int, int) - Method in class com.facebook.presto.spi.block.VariableWidthBlockBuilder
-
- getRegion(int, int) - Method in class com.facebook.presto.spi.Page
-
- getRetainedSizeInBytes() - Method in class com.facebook.presto.spi.block.ArrayBlock
-
- getRetainedSizeInBytes() - Method in class com.facebook.presto.spi.block.ArrayBlockBuilder
-
- getRetainedSizeInBytes() - Method in class com.facebook.presto.spi.block.ArrayElementBlockWriter
-
- getRetainedSizeInBytes() - Method in interface com.facebook.presto.spi.block.Block
-
Returns the retained size of this block in memory.
- getRetainedSizeInBytes() - Method in class com.facebook.presto.spi.block.DictionaryBlock
-
- getRetainedSizeInBytes() - Method in class com.facebook.presto.spi.block.FixedWidthBlock
-
- getRetainedSizeInBytes() - Method in class com.facebook.presto.spi.block.FixedWidthBlockBuilder
-
- getRetainedSizeInBytes() - Method in class com.facebook.presto.spi.block.InterleavedBlock
-
- getRetainedSizeInBytes() - Method in class com.facebook.presto.spi.block.InterleavedBlockBuilder
-
- getRetainedSizeInBytes() - Method in class com.facebook.presto.spi.block.LazyArrayBlock
-
- getRetainedSizeInBytes() - Method in class com.facebook.presto.spi.block.LazyBlock
-
- getRetainedSizeInBytes() - Method in class com.facebook.presto.spi.block.LazyFixedWidthBlock
-
- getRetainedSizeInBytes() - Method in class com.facebook.presto.spi.block.LazySliceArrayBlock
-
- getRetainedSizeInBytes() - Method in class com.facebook.presto.spi.block.RunLengthEncodedBlock
-
- getRetainedSizeInBytes() - Method in class com.facebook.presto.spi.block.SliceArrayBlock
-
- getRetainedSizeInBytes() - Method in class com.facebook.presto.spi.block.VariableWidthBlock
-
- getRetainedSizeInBytes() - Method in class com.facebook.presto.spi.block.VariableWidthBlockBuilder
-
- getRetainedSizeInBytes() - Method in class com.facebook.presto.spi.Page
-
- getRetainedSizeInBytes() - Method in class com.facebook.presto.spi.PageBuilder
-
- getSampleWeightColumnHandle(ConnectorSession, ConnectorTableHandle) - Method in class com.facebook.presto.spi.classloader.ClassLoaderSafeConnectorMetadata
-
- getSampleWeightColumnHandle(ConnectorSession, ConnectorTableHandle) - Method in class com.facebook.presto.spi.connector.classloader.ClassLoaderSafeConnectorMetadata
-
- getSampleWeightColumnHandle(ConnectorSession, ConnectorTableHandle) - Method in interface com.facebook.presto.spi.connector.ConnectorMetadata
-
Returns the handle for the sample weight column, or null if the table does not contain sampled data.
- getSampleWeightColumnHandle(ConnectorSession, ConnectorTableHandle) - Method in interface com.facebook.presto.spi.ConnectorMetadata
-
Deprecated.
Returns the handle for the sample weight column, or null if the table does not contain sampled data.
- getScale() - Method in class com.facebook.presto.spi.type.DecimalType
-
- getScale() - Method in class com.facebook.presto.spi.type.SqlDecimal
-
- getSchema() - Method in class com.facebook.presto.spi.procedure.Procedure
-
- getSchemaName() - Method in exception com.facebook.presto.spi.SchemaNotFoundException
-
- getSchemaName() - Method in class com.facebook.presto.spi.SchemaTableName
-
- getSchemaName() - Method in class com.facebook.presto.spi.SchemaTablePrefix
-
- getSequenceId() - Method in class com.facebook.presto.spi.block.DictionaryId
-
- getSerializable() - Method in class com.facebook.presto.spi.predicate.NullableValue
-
- getServices(Class<T>) - Method in interface com.facebook.presto.spi.Plugin
-
- getSessionProperties() - Method in interface com.facebook.presto.spi.connector.Connector
-
- getSessionProperties() - Method in interface com.facebook.presto.spi.Connector
-
Deprecated.
- getSessionTimeZoneKey() - Method in class com.facebook.presto.spi.type.SqlTime
-
- getSessionTimeZoneKey() - Method in class com.facebook.presto.spi.type.SqlTimestamp
-
- getShort(int, int) - Method in class com.facebook.presto.spi.block.AbstractArrayBlock
-
- getShort(int, int) - Method in class com.facebook.presto.spi.block.AbstractArrayElementBlock
-
- getShort(int, int) - Method in class com.facebook.presto.spi.block.AbstractFixedWidthBlock
-
- getShort(int, int) - Method in class com.facebook.presto.spi.block.AbstractInterleavedBlock
-
- getShort(int, int) - Method in class com.facebook.presto.spi.block.AbstractVariableWidthBlock
-
- getShort(int, int) - Method in interface com.facebook.presto.spi.block.Block
-
Gets a little endian short at offset
in the value at position
.
- getShort(int, int) - Method in class com.facebook.presto.spi.block.DictionaryBlock
-
- getShort(int, int) - Method in class com.facebook.presto.spi.block.LazyBlock
-
- getShort(int, int) - Method in class com.facebook.presto.spi.block.RunLengthEncodedBlock
-
- getSingleValue() - Method in class com.facebook.presto.spi.predicate.AllOrNoneValueSet
-
- getSingleValue() - Method in class com.facebook.presto.spi.predicate.Domain
-
- getSingleValue() - Method in class com.facebook.presto.spi.predicate.EquatableValueSet
-
- getSingleValue() - Method in class com.facebook.presto.spi.predicate.Range
-
- getSingleValue() - Method in class com.facebook.presto.spi.predicate.SortedRangeSet
-
- getSingleValue() - Method in interface com.facebook.presto.spi.predicate.ValueSet
-
- getSingleValueBlock(int) - Method in class com.facebook.presto.spi.block.AbstractArrayBlock
-
- getSingleValueBlock(int) - Method in class com.facebook.presto.spi.block.AbstractArrayElementBlock
-
- getSingleValueBlock(int) - Method in class com.facebook.presto.spi.block.AbstractFixedWidthBlock
-
- getSingleValueBlock(int) - Method in class com.facebook.presto.spi.block.AbstractInterleavedBlock
-
- getSingleValueBlock(int) - Method in class com.facebook.presto.spi.block.AbstractVariableWidthBlock
-
- getSingleValueBlock(int) - Method in interface com.facebook.presto.spi.block.Block
-
Gets the value at the specified position as a single element block.
- getSingleValueBlock(int) - Method in class com.facebook.presto.spi.block.DictionaryBlock
-
- getSingleValueBlock(int) - Method in class com.facebook.presto.spi.block.LazyBlock
-
- getSingleValueBlock(int) - Method in class com.facebook.presto.spi.block.RunLengthEncodedBlock
-
- getSizeInBytes() - Method in class com.facebook.presto.spi.block.ArrayBlock
-
- getSizeInBytes() - Method in class com.facebook.presto.spi.block.ArrayBlockBuilder
-
- getSizeInBytes() - Method in class com.facebook.presto.spi.block.ArrayElementBlockWriter
-
- getSizeInBytes() - Method in interface com.facebook.presto.spi.block.Block
-
Returns the logical size of this block in memory.
- getSizeInBytes() - Method in class com.facebook.presto.spi.block.DictionaryBlock
-
- getSizeInBytes() - Method in class com.facebook.presto.spi.block.FixedWidthBlock
-
- getSizeInBytes() - Method in class com.facebook.presto.spi.block.FixedWidthBlockBuilder
-
- getSizeInBytes() - Method in class com.facebook.presto.spi.block.InterleavedBlock
-
- getSizeInBytes() - Method in class com.facebook.presto.spi.block.InterleavedBlockBuilder
-
- getSizeInBytes() - Method in class com.facebook.presto.spi.block.LazyArrayBlock
-
- getSizeInBytes() - Method in class com.facebook.presto.spi.block.LazyBlock
-
- getSizeInBytes() - Method in class com.facebook.presto.spi.block.LazyFixedWidthBlock
-
- getSizeInBytes() - Method in class com.facebook.presto.spi.block.LazySliceArrayBlock
-
- getSizeInBytes() - Method in class com.facebook.presto.spi.block.PageBuilderStatus
-
- getSizeInBytes() - Method in class com.facebook.presto.spi.block.RunLengthEncodedBlock
-
- getSizeInBytes() - Method in class com.facebook.presto.spi.block.SliceArrayBlock
-
- getSizeInBytes() - Method in class com.facebook.presto.spi.block.VariableWidthBlock
-
- getSizeInBytes() - Method in class com.facebook.presto.spi.block.VariableWidthBlockBuilder
-
- getSizeInBytes() - Method in class com.facebook.presto.spi.Page
-
- getSizeInBytes() - Method in class com.facebook.presto.spi.PageBuilder
-
- getSlice(int, int, int) - Method in class com.facebook.presto.spi.block.AbstractArrayBlock
-
- getSlice(int, int, int) - Method in class com.facebook.presto.spi.block.AbstractArrayElementBlock
-
- getSlice(int, int, int) - Method in class com.facebook.presto.spi.block.AbstractFixedWidthBlock
-
- getSlice(int, int, int) - Method in class com.facebook.presto.spi.block.AbstractInterleavedBlock
-
- getSlice(int, int, int) - Method in class com.facebook.presto.spi.block.AbstractVariableWidthBlock
-
- getSlice(int, int, int) - Method in interface com.facebook.presto.spi.block.Block
-
Gets a slice at offset
in the value at position
.
- getSlice(int, int, int) - Method in class com.facebook.presto.spi.block.DictionaryBlock
-
- getSlice(int, int, int) - Method in class com.facebook.presto.spi.block.LazyBlock
-
- getSlice(int, int, int) - Method in class com.facebook.presto.spi.block.RunLengthEncodedBlock
-
- getSlice(int) - Method in interface com.facebook.presto.spi.RecordCursor
-
- getSlice(Block, int) - Method in class com.facebook.presto.spi.type.AbstractFixedWidthType
-
- getSlice(Block, int) - Method in class com.facebook.presto.spi.type.AbstractType
-
- getSlice(Block, int) - Method in class com.facebook.presto.spi.type.HyperLogLogType
-
- getSlice(Block, int) - Method in class com.facebook.presto.spi.type.P4HyperLogLogType
-
- getSlice(Block, int) - Method in interface com.facebook.presto.spi.type.Type
-
Gets the value at the block
position
as a Slice.
- getSlice(Block, int) - Method in class com.facebook.presto.spi.type.VarbinaryType
-
- getSlice(Block, int) - Method in class com.facebook.presto.spi.type.VarcharType
-
- getSliceArraySizeInBytes(Slice[]) - Static method in class com.facebook.presto.spi.block.SliceArrayBlock
-
- getSpan() - Method in interface com.facebook.presto.spi.predicate.Ranges
-
- getSpan() - Method in class com.facebook.presto.spi.predicate.SortedRangeSet
-
- getSplitBucketFunction(ConnectorTransactionHandle, ConnectorSession, ConnectorPartitioningHandle) - Method in class com.facebook.presto.spi.connector.classloader.ClassLoaderSafeNodePartitioningProvider
-
- getSplitBucketFunction(ConnectorTransactionHandle, ConnectorSession, ConnectorPartitioningHandle) - Method in interface com.facebook.presto.spi.connector.ConnectorNodePartitioningProvider
-
- getSplitClass() - Method in interface com.facebook.presto.spi.ConnectorHandleResolver
-
- getSplitManager() - Method in interface com.facebook.presto.spi.connector.Connector
-
- getSplitManager() - Method in interface com.facebook.presto.spi.Connector
-
Deprecated.
- getSplits(ConnectorSession, ConnectorTableLayoutHandle) - Method in class com.facebook.presto.spi.classloader.ClassLoaderSafeConnectorSplitManager
-
- getSplits(ConnectorTransactionHandle, ConnectorSession, ConnectorTableLayoutHandle) - Method in class com.facebook.presto.spi.connector.classloader.ClassLoaderSafeConnectorSplitManager
-
- getSplits(ConnectorTransactionHandle, ConnectorSession, ConnectorTableLayoutHandle) - Method in interface com.facebook.presto.spi.connector.ConnectorSplitManager
-
- getSplits(ConnectorSession, ConnectorTableLayoutHandle) - Method in interface com.facebook.presto.spi.ConnectorSplitManager
-
Deprecated.
- getSqlType() - Method in class com.facebook.presto.spi.session.PropertyMetadata
-
SQL type of the property.
- getStartTime() - Method in interface com.facebook.presto.spi.ConnectorSession
-
- getStreamPartitioningColumns() - Method in class com.facebook.presto.spi.ConnectorTableLayout
-
The partitioning for the table streams.
- getSummary() - Method in class com.facebook.presto.spi.Constraint
-
- getSystemMemoryUsage() - Method in interface com.facebook.presto.spi.ConnectorPageSource
-
Get the total memory that needs to be reserved in the system memory pool.
- getSystemMemoryUsage() - Method in class com.facebook.presto.spi.FixedPageSource
-
- getSystemMemoryUsage() - Method in interface com.facebook.presto.spi.RecordCursor
-
- getSystemMemoryUsage() - Method in class com.facebook.presto.spi.RecordPageSource
-
- getSystemTables() - Method in interface com.facebook.presto.spi.connector.Connector
-
- getSystemTables() - Method in interface com.facebook.presto.spi.Connector
-
Deprecated.
- getTable() - Method in class com.facebook.presto.spi.ConnectorTableMetadata
-
- getTableHandle(ConnectorSession, SchemaTableName) - Method in class com.facebook.presto.spi.classloader.ClassLoaderSafeConnectorMetadata
-
- getTableHandle(ConnectorSession, SchemaTableName) - Method in class com.facebook.presto.spi.connector.classloader.ClassLoaderSafeConnectorMetadata
-
- getTableHandle(ConnectorSession, SchemaTableName) - Method in interface com.facebook.presto.spi.connector.ConnectorMetadata
-
Returns a table handle for the specified table name, or null if the connector does not contain the table.
- getTableHandle(ConnectorSession, SchemaTableName) - Method in interface com.facebook.presto.spi.ConnectorMetadata
-
Deprecated.
Returns a table handle for the specified table name, or null if the connector does not contain the table.
- getTableHandleClass() - Method in interface com.facebook.presto.spi.ConnectorHandleResolver
-
- getTableLayout(ConnectorSession, ConnectorTableLayoutHandle) - Method in class com.facebook.presto.spi.classloader.ClassLoaderSafeConnectorMetadata
-
- getTableLayout(ConnectorSession, ConnectorTableLayoutHandle) - Method in class com.facebook.presto.spi.connector.classloader.ClassLoaderSafeConnectorMetadata
-
- getTableLayout(ConnectorSession, ConnectorTableLayoutHandle) - Method in interface com.facebook.presto.spi.connector.ConnectorMetadata
-
- getTableLayout(ConnectorSession, ConnectorTableLayoutHandle) - Method in interface com.facebook.presto.spi.ConnectorMetadata
-
Deprecated.
- getTableLayout() - Method in class com.facebook.presto.spi.ConnectorTableLayoutResult
-
- getTableLayoutHandleClass() - Method in interface com.facebook.presto.spi.ConnectorHandleResolver
-
- getTableLayouts(ConnectorSession, ConnectorTableHandle, Constraint<ColumnHandle>, Optional<Set<ColumnHandle>>) - Method in class com.facebook.presto.spi.classloader.ClassLoaderSafeConnectorMetadata
-
- getTableLayouts(ConnectorSession, ConnectorTableHandle, Constraint<ColumnHandle>, Optional<Set<ColumnHandle>>) - Method in class com.facebook.presto.spi.connector.classloader.ClassLoaderSafeConnectorMetadata
-
- getTableLayouts(ConnectorSession, ConnectorTableHandle, Constraint<ColumnHandle>, Optional<Set<ColumnHandle>>) - Method in interface com.facebook.presto.spi.connector.ConnectorMetadata
-
Return a list of table layouts that satisfy the given constraint.
- getTableLayouts(ConnectorSession, ConnectorTableHandle, Constraint<ColumnHandle>, Optional<Set<ColumnHandle>>) - Method in interface com.facebook.presto.spi.ConnectorMetadata
-
Deprecated.
Return a list of table layouts that satisfy the given constraint.
- getTableMetadata(ConnectorSession, ConnectorTableHandle) - Method in class com.facebook.presto.spi.classloader.ClassLoaderSafeConnectorMetadata
-
- getTableMetadata(ConnectorSession, ConnectorTableHandle) - Method in class com.facebook.presto.spi.connector.classloader.ClassLoaderSafeConnectorMetadata
-
- getTableMetadata(ConnectorSession, ConnectorTableHandle) - Method in interface com.facebook.presto.spi.connector.ConnectorMetadata
-
Return the metadata for the specified table handle.
- getTableMetadata(ConnectorSession, ConnectorTableHandle) - Method in interface com.facebook.presto.spi.ConnectorMetadata
-
Deprecated.
Return the metadata for the specified table handle.
- getTableMetadata() - Method in interface com.facebook.presto.spi.SystemTable
-
- getTableName() - Method in exception com.facebook.presto.spi.ColumnNotFoundException
-
- getTableName() - Method in class com.facebook.presto.spi.SchemaTableName
-
- getTableName() - Method in class com.facebook.presto.spi.SchemaTablePrefix
-
- getTableName() - Method in exception com.facebook.presto.spi.TableNotFoundException
-
- getTableProperties() - Method in interface com.facebook.presto.spi.connector.Connector
-
- getTableProperties() - Method in interface com.facebook.presto.spi.Connector
-
Deprecated.
- getTimeZoneForKey(TimeZoneKey) - Static method in class com.facebook.presto.spi.type.TimeZoneIndex
-
- getTimeZoneKey() - Method in interface com.facebook.presto.spi.ConnectorSession
-
- getTimeZoneKey() - Method in class com.facebook.presto.spi.type.SqlTimestampWithTimeZone
-
- getTimeZoneKey() - Method in class com.facebook.presto.spi.type.SqlTimeWithTimeZone
-
- getTimeZoneKey(short) - Static method in class com.facebook.presto.spi.type.TimeZoneKey
-
- getTimeZoneKey(String) - Static method in class com.facebook.presto.spi.type.TimeZoneKey
-
- getTimeZoneKeyForOffset(long) - Static method in class com.facebook.presto.spi.type.TimeZoneKey
-
- getTimeZoneKeys() - Static method in class com.facebook.presto.spi.type.TimeZoneKey
-
- getTotalBytes() - Method in interface com.facebook.presto.spi.ConnectorPageSource
-
Gets the total input bytes that will be processed by this page source.
- getTotalBytes() - Method in class com.facebook.presto.spi.FixedPageSource
-
- getTotalBytes() - Method in interface com.facebook.presto.spi.RecordCursor
-
- getTotalBytes() - Method in class com.facebook.presto.spi.RecordPageSource
-
- getTransactionHandleClass() - Method in interface com.facebook.presto.spi.ConnectorHandleResolver
-
- getType() - Method in class com.facebook.presto.spi.ColumnMetadata
-
- getType(int) - Method in class com.facebook.presto.spi.PageBuilder
-
- getType() - Method in class com.facebook.presto.spi.predicate.AllOrNoneValueSet
-
- getType() - Method in class com.facebook.presto.spi.predicate.Domain
-
- getType() - Method in class com.facebook.presto.spi.predicate.EquatableValueSet
-
- getType() - Method in class com.facebook.presto.spi.predicate.EquatableValueSet.ValueEntry
-
- getType() - Method in class com.facebook.presto.spi.predicate.Marker
-
- getType() - Method in class com.facebook.presto.spi.predicate.NullableValue
-
- getType() - Method in class com.facebook.presto.spi.predicate.NullableValue.Serializable
-
- getType() - Method in class com.facebook.presto.spi.predicate.Range
-
- getType() - Method in class com.facebook.presto.spi.predicate.SortedRangeSet
-
- getType() - Method in interface com.facebook.presto.spi.predicate.ValueSet
-
- getType() - Method in class com.facebook.presto.spi.procedure.Procedure.Argument
-
- getType(int) - Method in interface com.facebook.presto.spi.RecordCursor
-
- getType() - Method in class com.facebook.presto.spi.type.DecimalParseResult
-
- getType() - Method in class com.facebook.presto.spi.type.NamedType
-
- getType(TypeSignature) - Method in interface com.facebook.presto.spi.type.TypeManager
-
Gets the type with the specified signature, or null if not found.
- getType() - Method in class com.facebook.presto.spi.type.TypeParameter
-
- getTypeParameters() - Method in class com.facebook.presto.spi.type.AbstractType
-
- getTypeParameters() - Method in interface com.facebook.presto.spi.type.Type
-
For parameterized types returns the list of parameters.
- getTypeParametersAsTypeSignatures() - Method in class com.facebook.presto.spi.type.TypeSignature
-
- getTypes() - Method in interface com.facebook.presto.spi.type.TypeManager
-
Gets a list of all registered types.
- getTypeSignature() - Method in class com.facebook.presto.spi.type.AbstractType
-
- getTypeSignature() - Method in class com.facebook.presto.spi.type.NamedTypeSignature
-
- getTypeSignature() - Method in interface com.facebook.presto.spi.type.Type
-
Gets the name of this type which must be case insensitive globally unique.
- getTypeSignature() - Method in class com.facebook.presto.spi.type.TypeSignatureParameter
-
- getTypeSignatureOrNamedTypeSignature() - Method in class com.facebook.presto.spi.type.TypeSignatureParameter
-
- getUnenforcedConstraint() - Method in class com.facebook.presto.spi.ConnectorTableLayoutResult
-
- getUnresolvedTupleDomain() - Method in class com.facebook.presto.spi.ConnectorResolvedIndex
-
- getUpdateRowIdColumnHandle(ConnectorSession, ConnectorTableHandle) - Method in class com.facebook.presto.spi.classloader.ClassLoaderSafeConnectorMetadata
-
- getUpdateRowIdColumnHandle(ConnectorSession, ConnectorTableHandle) - Method in class com.facebook.presto.spi.connector.classloader.ClassLoaderSafeConnectorMetadata
-
- getUpdateRowIdColumnHandle(ConnectorSession, ConnectorTableHandle) - Method in interface com.facebook.presto.spi.connector.ConnectorMetadata
-
Get the column handle that will generate row IDs for the delete operation.
- getUpdateRowIdColumnHandle(ConnectorSession, ConnectorTableHandle) - Method in interface com.facebook.presto.spi.ConnectorMetadata
-
Deprecated.
Get the column handle that will generate row IDs for the delete operation.
- getUser() - Method in interface com.facebook.presto.spi.ConnectorSession
-
- getUser() - Method in class com.facebook.presto.spi.security.Identity
-
- getValue() - Method in class com.facebook.presto.spi.block.RunLengthEncodedBlock
-
- getValue() - Method in class com.facebook.presto.spi.predicate.EquatableValueSet.ValueEntry
-
- getValue() - Method in class com.facebook.presto.spi.predicate.Marker
-
- getValue() - Method in class com.facebook.presto.spi.predicate.NullableValue
-
- getValue(ParameterKind, Class<A>) - Method in class com.facebook.presto.spi.type.TypeParameter
-
- getValueBlock() - Method in class com.facebook.presto.spi.predicate.Marker
-
- getValueBlockEncoding() - Method in class com.facebook.presto.spi.block.RunLengthBlockEncoding
-
- getValueIsNull() - Method in class com.facebook.presto.spi.block.AbstractArrayBlock
-
- getValueIsNull() - Method in class com.facebook.presto.spi.block.ArrayBlock
-
- getValueIsNull() - Method in class com.facebook.presto.spi.block.ArrayBlockBuilder
-
- getValueIsNull() - Method in class com.facebook.presto.spi.block.LazyArrayBlock
-
- getValues() - Method in class com.facebook.presto.spi.block.AbstractArrayBlock
-
- getValues() - Method in class com.facebook.presto.spi.block.ArrayBlock
-
- getValues() - Method in class com.facebook.presto.spi.block.ArrayBlockBuilder
-
- getValues() - Method in class com.facebook.presto.spi.block.LazyArrayBlock
-
- getValues() - Method in class com.facebook.presto.spi.block.LazySliceArrayBlock
-
- getValues() - Method in class com.facebook.presto.spi.block.SliceArrayBlock
-
- getValues() - Method in interface com.facebook.presto.spi.predicate.DiscreteValues
-
- getValues() - Method in class com.facebook.presto.spi.predicate.Domain
-
- getValues() - Method in class com.facebook.presto.spi.predicate.EquatableValueSet
-
- getValuesProcessor() - Method in class com.facebook.presto.spi.predicate.AllOrNoneValueSet
-
- getValuesProcessor() - Method in class com.facebook.presto.spi.predicate.EquatableValueSet
-
- getValuesProcessor() - Method in class com.facebook.presto.spi.predicate.SortedRangeSet
-
- getValuesProcessor() - Method in interface com.facebook.presto.spi.predicate.ValueSet
-
- getVariable() - Method in class com.facebook.presto.spi.type.TypeParameter
-
- getVariable() - Method in class com.facebook.presto.spi.type.TypeSignatureParameter
-
- getViewData() - Method in class com.facebook.presto.spi.ConnectorViewDefinition
-
- getViewName() - Method in exception com.facebook.presto.spi.ViewNotFoundException
-
- getViews(ConnectorSession, SchemaTablePrefix) - Method in class com.facebook.presto.spi.classloader.ClassLoaderSafeConnectorMetadata
-
- getViews(ConnectorSession, SchemaTablePrefix) - Method in class com.facebook.presto.spi.connector.classloader.ClassLoaderSafeConnectorMetadata
-
- getViews(ConnectorSession, SchemaTablePrefix) - Method in interface com.facebook.presto.spi.connector.ConnectorMetadata
-
Gets the view data for views that match the specified table prefix.
- getViews(ConnectorSession, SchemaTablePrefix) - Method in interface com.facebook.presto.spi.ConnectorMetadata
-
Deprecated.
Gets the view data for views that match the specified table prefix.
- getZoneId() - Method in exception com.facebook.presto.spi.type.TimeZoneNotSupportedException
-
- grantTablePrivileges(ConnectorSession, SchemaTableName, Set<Privilege>, String, boolean) - Method in class com.facebook.presto.spi.classloader.ClassLoaderSafeConnectorMetadata
-
- grantTablePrivileges(ConnectorSession, SchemaTableName, Set<Privilege>, String, boolean) - Method in class com.facebook.presto.spi.connector.classloader.ClassLoaderSafeConnectorMetadata
-
- grantTablePrivileges(ConnectorSession, SchemaTableName, Set<Privilege>, String, boolean) - Method in interface com.facebook.presto.spi.connector.ConnectorMetadata
-
Grants the specified privilege to the specified user on the specified table
- grantTablePrivileges(ConnectorSession, SchemaTableName, Set<Privilege>, String, boolean) - Method in interface com.facebook.presto.spi.ConnectorMetadata
-
Deprecated.
Grants the specified privilege to the specified user on the specified table
- greaterAdjacent() - Method in class com.facebook.presto.spi.predicate.Marker
-
- greaterThan(Type, Object) - Static method in class com.facebook.presto.spi.predicate.Range
-
- greaterThanOrEqual(Type, Object) - Static method in class com.facebook.presto.spi.predicate.Range
-
- GroupingProperty<E> - Class in com.facebook.presto.spi
-
- GroupingProperty(Collection<E>) - Constructor for class com.facebook.presto.spi.GroupingProperty
-
- ValueEntry(Type, Block) - Constructor for class com.facebook.presto.spi.predicate.EquatableValueSet.ValueEntry
-
- valueOf(String) - Static method in enum com.facebook.presto.spi.block.SortOrder
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.presto.spi.NodeState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.presto.spi.predicate.Marker.Bound
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in class com.facebook.presto.spi.SchemaTableName
-
- valueOf(String) - Static method in enum com.facebook.presto.spi.security.Privilege
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.presto.spi.StandardErrorCode.ErrorType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.presto.spi.StandardErrorCode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.presto.spi.SystemTable.Distribution
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.presto.spi.transaction.IsolationLevel
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.presto.spi.type.ParameterKind
-
Returns the enum constant of this type with the specified name.
- values() - Static method in enum com.facebook.presto.spi.block.SortOrder
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.presto.spi.NodeState
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.presto.spi.predicate.Marker.Bound
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.presto.spi.security.Privilege
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.presto.spi.StandardErrorCode.ErrorType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.presto.spi.StandardErrorCode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.presto.spi.SystemTable.Distribution
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.presto.spi.transaction.IsolationLevel
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.presto.spi.type.ParameterKind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- ValueSet - Interface in com.facebook.presto.spi.predicate
-
- ValuesProcessor - Interface in com.facebook.presto.spi.predicate
-
- VARBINARY - Static variable in class com.facebook.presto.spi.type.StandardTypes
-
- VARBINARY - Static variable in class com.facebook.presto.spi.type.VarbinaryType
-
- VarbinaryType - Class in com.facebook.presto.spi.type
-
- VARCHAR - Static variable in class com.facebook.presto.spi.type.StandardTypes
-
- VARCHAR - Static variable in class com.facebook.presto.spi.type.VarcharType
-
- VarcharType - Class in com.facebook.presto.spi.type
-
- VariableWidthBlock - Class in com.facebook.presto.spi.block
-
- VariableWidthBlock(int, Slice, Slice, Slice) - Constructor for class com.facebook.presto.spi.block.VariableWidthBlock
-
- VariableWidthBlockBuilder - Class in com.facebook.presto.spi.block
-
- VariableWidthBlockBuilder(BlockBuilderStatus, int, int) - Constructor for class com.facebook.presto.spi.block.VariableWidthBlockBuilder
-
- VariableWidthBlockEncoding - Class in com.facebook.presto.spi.block
-
- VariableWidthBlockEncoding() - Constructor for class com.facebook.presto.spi.block.VariableWidthBlockEncoding
-
- VariableWidthBlockEncoding.VariableWidthBlockEncodingFactory - Class in com.facebook.presto.spi.block
-
- VariableWidthBlockEncodingFactory() - Constructor for class com.facebook.presto.spi.block.VariableWidthBlockEncoding.VariableWidthBlockEncodingFactory
-
- VariableWidthType - Interface in com.facebook.presto.spi.type
-
VariableWidthType is a type that can have a different size for every value.
- ViewNotFoundException - Exception in com.facebook.presto.spi
-
- ViewNotFoundException(SchemaTableName) - Constructor for exception com.facebook.presto.spi.ViewNotFoundException
-
- ViewNotFoundException(SchemaTableName, String) - Constructor for exception com.facebook.presto.spi.ViewNotFoundException
-
- ViewNotFoundException(SchemaTableName, Throwable) - Constructor for exception com.facebook.presto.spi.ViewNotFoundException
-
- ViewNotFoundException(SchemaTableName, String, Throwable) - Constructor for exception com.facebook.presto.spi.ViewNotFoundException
-
- withColumnDomains(Map<T, Domain>) - Static method in class com.facebook.presto.spi.predicate.TupleDomain
-
- withConstants(Set<E>) - Method in interface com.facebook.presto.spi.LocalProperty
-
Simplfies this LocalProperty provided that the specified inputs are constants
- withDefaultPort(int) - Method in class com.facebook.presto.spi.HostAddress
-
Provide a default port if the parsed string contained only a host.
- withMaxPageSize(int, List<? extends Type>) - Static method in class com.facebook.presto.spi.PageBuilder
-
- writeBigDecimal(DecimalType, BlockBuilder, BigDecimal) - Static method in class com.facebook.presto.spi.type.Decimals
-
- writeBlock(SliceOutput, Block) - Method in class com.facebook.presto.spi.block.ArrayBlockEncoding
-
- writeBlock(SliceOutput, Block) - Method in interface com.facebook.presto.spi.block.BlockEncoding
-
Write the specified block to the specified output
- writeBlock(SliceOutput, Block) - Method in class com.facebook.presto.spi.block.DictionaryBlockEncoding
-
- writeBlock(SliceOutput, Block) - Method in class com.facebook.presto.spi.block.FixedWidthBlockEncoding
-
- writeBlock(SliceOutput, Block) - Method in class com.facebook.presto.spi.block.InterleavedBlockEncoding
-
- writeBlock(SliceOutput, Block) - Method in class com.facebook.presto.spi.block.LazyBlockEncoding
-
- writeBlock(SliceOutput, Block) - Method in class com.facebook.presto.spi.block.LazySliceArrayBlockEncoding
-
- writeBlock(SliceOutput, Block) - Method in class com.facebook.presto.spi.block.RunLengthBlockEncoding
-
- writeBlock(SliceOutput, Block) - Method in class com.facebook.presto.spi.block.SliceArrayBlockEncoding
-
- writeBlock(SliceOutput, Block) - Method in class com.facebook.presto.spi.block.VariableWidthBlockEncoding
-
- writeBlockEncoding(SliceOutput, BlockEncoding) - Method in interface com.facebook.presto.spi.block.BlockEncodingSerde
-
Write a blockEncoding to the output.
- writeBoolean(BlockBuilder, boolean) - Method in class com.facebook.presto.spi.type.AbstractType
-
- writeBoolean(BlockBuilder, boolean) - Method in class com.facebook.presto.spi.type.BooleanType
-
- writeBoolean(BlockBuilder, boolean) - Method in interface com.facebook.presto.spi.type.Type
-
Writes the boolean value into the BlockBuilder
.
- writeByte(int) - Method in class com.facebook.presto.spi.block.ArrayBlockBuilder
-
- writeByte(int) - Method in class com.facebook.presto.spi.block.ArrayElementBlockWriter
-
- writeByte(int) - Method in interface com.facebook.presto.spi.block.BlockBuilder
-
Write a byte to the current entry;
- writeByte(int) - Method in class com.facebook.presto.spi.block.FixedWidthBlockBuilder
-
- writeByte(int) - Method in class com.facebook.presto.spi.block.InterleavedBlockBuilder
-
- writeByte(int) - Method in class com.facebook.presto.spi.block.VariableWidthBlockBuilder
-
- writeBytes(Slice, int, int) - Method in class com.facebook.presto.spi.block.ArrayBlockBuilder
-
- writeBytes(Slice, int, int) - Method in class com.facebook.presto.spi.block.ArrayElementBlockWriter
-
- writeBytes(Slice, int, int) - Method in interface com.facebook.presto.spi.block.BlockBuilder
-
Write a byte sequences to the current entry;
- writeBytes(Slice, int, int) - Method in class com.facebook.presto.spi.block.FixedWidthBlockBuilder
-
- writeBytes(Slice, int, int) - Method in class com.facebook.presto.spi.block.InterleavedBlockBuilder
-
- writeBytes(Slice, int, int) - Method in class com.facebook.presto.spi.block.VariableWidthBlockBuilder
-
- writeBytesTo(int, int, int, BlockBuilder) - Method in class com.facebook.presto.spi.block.AbstractArrayBlock
-
- writeBytesTo(int, int, int, BlockBuilder) - Method in class com.facebook.presto.spi.block.AbstractArrayElementBlock
-
- writeBytesTo(int, int, int, BlockBuilder) - Method in class com.facebook.presto.spi.block.AbstractFixedWidthBlock
-
- writeBytesTo(int, int, int, BlockBuilder) - Method in class com.facebook.presto.spi.block.AbstractInterleavedBlock
-
- writeBytesTo(int, int, int, BlockBuilder) - Method in class com.facebook.presto.spi.block.AbstractVariableWidthBlock
-
- writeBytesTo(int, int, int, BlockBuilder) - Method in interface com.facebook.presto.spi.block.Block
-
Appends the byte sequences at offset
in the value at position
to blockBuilder
.
- writeBytesTo(int, int, int, BlockBuilder) - Method in class com.facebook.presto.spi.block.DictionaryBlock
-
- writeBytesTo(int, int, int, BlockBuilder) - Method in class com.facebook.presto.spi.block.LazyBlock
-
- writeBytesTo(int, int, int, BlockBuilder) - Method in class com.facebook.presto.spi.block.RunLengthEncodedBlock
-
- writeDouble(double) - Method in class com.facebook.presto.spi.block.ArrayBlockBuilder
-
- writeDouble(double) - Method in class com.facebook.presto.spi.block.ArrayElementBlockWriter
-
- writeDouble(double) - Method in interface com.facebook.presto.spi.block.BlockBuilder
-
Write a double to the current entry;
- writeDouble(double) - Method in class com.facebook.presto.spi.block.FixedWidthBlockBuilder
-
- writeDouble(double) - Method in class com.facebook.presto.spi.block.InterleavedBlockBuilder
-
- writeDouble(double) - Method in class com.facebook.presto.spi.block.VariableWidthBlockBuilder
-
- writeDouble(BlockBuilder, double) - Method in class com.facebook.presto.spi.type.AbstractType
-
- writeDouble(BlockBuilder, double) - Method in class com.facebook.presto.spi.type.DoubleType
-
- writeDouble(BlockBuilder, double) - Method in interface com.facebook.presto.spi.type.Type
-
Writes the double value into the BlockBuilder
.
- writeEncoding(BlockEncodingSerde, SliceOutput, ArrayBlockEncoding) - Method in class com.facebook.presto.spi.block.ArrayBlockEncoding.ArrayBlockEncodingFactory
-
- writeEncoding(BlockEncodingSerde, SliceOutput, T) - Method in interface com.facebook.presto.spi.block.BlockEncodingFactory
-
Writes this encoding to the output stream.
- writeEncoding(BlockEncodingSerde, SliceOutput, DictionaryBlockEncoding) - Method in class com.facebook.presto.spi.block.DictionaryBlockEncoding.DictionaryBlockEncodingFactory
-
- writeEncoding(BlockEncodingSerde, SliceOutput, FixedWidthBlockEncoding) - Method in class com.facebook.presto.spi.block.FixedWidthBlockEncoding.FixedWidthBlockEncodingFactory
-
- writeEncoding(BlockEncodingSerde, SliceOutput, InterleavedBlockEncoding) - Method in class com.facebook.presto.spi.block.InterleavedBlockEncoding.InterleavedBlockEncodingFactory
-
- writeEncoding(BlockEncodingSerde, SliceOutput, LazyBlockEncoding) - Method in class com.facebook.presto.spi.block.LazyBlockEncoding.LazyBlockEncodingFactory
-
- writeEncoding(BlockEncodingSerde, SliceOutput, LazySliceArrayBlockEncoding) - Method in class com.facebook.presto.spi.block.LazySliceArrayBlockEncoding.LazySliceArrayBlockEncodingFactory
-
- writeEncoding(BlockEncodingSerde, SliceOutput, SliceArrayBlockEncoding) - Method in class com.facebook.presto.spi.block.SliceArrayBlockEncoding.SliceArrayBlockEncodingFactory
-
- writeEncoding(BlockEncodingSerde, SliceOutput, VariableWidthBlockEncoding) - Method in class com.facebook.presto.spi.block.VariableWidthBlockEncoding.VariableWidthBlockEncodingFactory
-
- writeFloat(float) - Method in class com.facebook.presto.spi.block.ArrayBlockBuilder
-
- writeFloat(float) - Method in class com.facebook.presto.spi.block.ArrayElementBlockWriter
-
- writeFloat(float) - Method in interface com.facebook.presto.spi.block.BlockBuilder
-
Write a float to the current entry;
- writeFloat(float) - Method in class com.facebook.presto.spi.block.FixedWidthBlockBuilder
-
- writeFloat(float) - Method in class com.facebook.presto.spi.block.InterleavedBlockBuilder
-
- writeFloat(float) - Method in class com.facebook.presto.spi.block.VariableWidthBlockBuilder
-
- writeInt(int) - Method in class com.facebook.presto.spi.block.ArrayBlockBuilder
-
- writeInt(int) - Method in class com.facebook.presto.spi.block.ArrayElementBlockWriter
-
- writeInt(int) - Method in interface com.facebook.presto.spi.block.BlockBuilder
-
Write a int to the current entry;
- writeInt(int) - Method in class com.facebook.presto.spi.block.FixedWidthBlockBuilder
-
- writeInt(int) - Method in class com.facebook.presto.spi.block.InterleavedBlockBuilder
-
- writeInt(int) - Method in class com.facebook.presto.spi.block.VariableWidthBlockBuilder
-
- writeLong(long) - Method in class com.facebook.presto.spi.block.ArrayBlockBuilder
-
- writeLong(long) - Method in class com.facebook.presto.spi.block.ArrayElementBlockWriter
-
- writeLong(long) - Method in interface com.facebook.presto.spi.block.BlockBuilder
-
Write a long to the current entry;
- writeLong(long) - Method in class com.facebook.presto.spi.block.FixedWidthBlockBuilder
-
- writeLong(long) - Method in class com.facebook.presto.spi.block.InterleavedBlockBuilder
-
- writeLong(long) - Method in class com.facebook.presto.spi.block.VariableWidthBlockBuilder
-
- writeLong(BlockBuilder, long) - Method in class com.facebook.presto.spi.type.AbstractType
-
- writeLong(BlockBuilder, long) - Method in class com.facebook.presto.spi.type.BigintType
-
- writeLong(BlockBuilder, long) - Method in class com.facebook.presto.spi.type.DateType
-
- writeLong(BlockBuilder, long) - Method in class com.facebook.presto.spi.type.IntegerType
-
- writeLong(BlockBuilder, long) - Method in class com.facebook.presto.spi.type.IntervalDayTimeType
-
- writeLong(BlockBuilder, long) - Method in class com.facebook.presto.spi.type.IntervalYearMonthType
-
- writeLong(BlockBuilder, long) - Method in class com.facebook.presto.spi.type.TimestampType
-
- writeLong(BlockBuilder, long) - Method in class com.facebook.presto.spi.type.TimestampWithTimeZoneType
-
- writeLong(BlockBuilder, long) - Method in class com.facebook.presto.spi.type.TimeType
-
- writeLong(BlockBuilder, long) - Method in class com.facebook.presto.spi.type.TimeWithTimeZoneType
-
- writeLong(BlockBuilder, long) - Method in interface com.facebook.presto.spi.type.Type
-
Writes the long value into the BlockBuilder
.
- writeNativeValue(Type, BlockBuilder, Object) - Static method in class com.facebook.presto.spi.type.TypeUtils
-
Write a native value object to the current entry of blockBuilder
.
- writeObject(Object) - Method in class com.facebook.presto.spi.block.ArrayBlockBuilder
-
- writeObject(Object) - Method in class com.facebook.presto.spi.block.ArrayElementBlockWriter
-
- writeObject(Object) - Method in interface com.facebook.presto.spi.block.BlockBuilder
-
Write an object to the current entry;
- writeObject(Object) - Method in class com.facebook.presto.spi.block.InterleavedBlockBuilder
-
- writeObject(BlockBuilder, Object) - Method in class com.facebook.presto.spi.type.AbstractType
-
- writeObject(BlockBuilder, Object) - Method in interface com.facebook.presto.spi.type.Type
-
Writes the Object value into the BlockBuilder
.
- writePositionTo(int, BlockBuilder) - Method in class com.facebook.presto.spi.block.AbstractArrayBlock
-
- writePositionTo(int, BlockBuilder) - Method in class com.facebook.presto.spi.block.AbstractArrayElementBlock
-
- writePositionTo(int, BlockBuilder) - Method in class com.facebook.presto.spi.block.AbstractFixedWidthBlock
-
- writePositionTo(int, BlockBuilder) - Method in class com.facebook.presto.spi.block.AbstractInterleavedBlock
-
- writePositionTo(int, BlockBuilder) - Method in class com.facebook.presto.spi.block.AbstractVariableWidthBlock
-
- writePositionTo(int, BlockBuilder) - Method in interface com.facebook.presto.spi.block.Block
-
Appends the value at position
to blockBuilder
.
- writePositionTo(int, BlockBuilder) - Method in class com.facebook.presto.spi.block.DictionaryBlock
-
- writePositionTo(int, BlockBuilder) - Method in class com.facebook.presto.spi.block.LazyBlock
-
- writePositionTo(int, BlockBuilder) - Method in class com.facebook.presto.spi.block.RunLengthEncodedBlock
-
- writeShort(int) - Method in class com.facebook.presto.spi.block.ArrayBlockBuilder
-
- writeShort(int) - Method in class com.facebook.presto.spi.block.ArrayElementBlockWriter
-
- writeShort(int) - Method in interface com.facebook.presto.spi.block.BlockBuilder
-
Write a short to the current entry;
- writeShort(int) - Method in class com.facebook.presto.spi.block.FixedWidthBlockBuilder
-
- writeShort(int) - Method in class com.facebook.presto.spi.block.InterleavedBlockBuilder
-
- writeShort(int) - Method in class com.facebook.presto.spi.block.VariableWidthBlockBuilder
-
- writeSlice(BlockBuilder, Slice) - Method in class com.facebook.presto.spi.type.AbstractType
-
- writeSlice(BlockBuilder, Slice, int, int) - Method in class com.facebook.presto.spi.type.AbstractType
-
- writeSlice(BlockBuilder, Slice) - Method in class com.facebook.presto.spi.type.HyperLogLogType
-
- writeSlice(BlockBuilder, Slice, int, int) - Method in class com.facebook.presto.spi.type.HyperLogLogType
-
- writeSlice(BlockBuilder, Slice) - Method in class com.facebook.presto.spi.type.P4HyperLogLogType
-
- writeSlice(BlockBuilder, Slice, int, int) - Method in class com.facebook.presto.spi.type.P4HyperLogLogType
-
- writeSlice(BlockBuilder, Slice) - Method in interface com.facebook.presto.spi.type.Type
-
Writes the Slice value into the BlockBuilder
.
- writeSlice(BlockBuilder, Slice, int, int) - Method in interface com.facebook.presto.spi.type.Type
-
Writes the Slice value into the BlockBuilder
.
- writeSlice(BlockBuilder, Slice) - Method in class com.facebook.presto.spi.type.VarbinaryType
-
- writeSlice(BlockBuilder, Slice, int, int) - Method in class com.facebook.presto.spi.type.VarbinaryType
-
- writeSlice(BlockBuilder, Slice) - Method in class com.facebook.presto.spi.type.VarcharType
-
- writeSlice(BlockBuilder, Slice, int, int) - Method in class com.facebook.presto.spi.type.VarcharType
-
- writeString(BlockBuilder, String) - Method in class com.facebook.presto.spi.type.VarcharType
-
- writeType(SliceOutput, Type) - Static method in class com.facebook.presto.spi.type.TypeSerde
-