Skip navigation links
A B C D E F G H I J K L M N O P R S T U V W Y 

A

abort(long, WriterCommitMessage[]) - Method in class org.apache.iceberg.spark.source.StreamingWriter
 
abortWith(Tasks.Task<I, ?>) - Method in class org.apache.iceberg.util.Tasks.Builder
 
accept(Path) - Method in class org.apache.iceberg.hadoop.HiddenPathFilter
 
Accessor<T> - Interface in org.apache.iceberg
 
accessor() - Method in class org.apache.iceberg.expressions.BoundReference
 
accessorForField(int) - Method in class org.apache.iceberg.Schema
Returns an accessor for retrieving the data from StructLike.
Accessors - Class in org.apache.iceberg
 
Action<R> - Interface in org.apache.iceberg.actions
An action performed on a table.
Actions - Class in org.apache.iceberg.actions
 
add(D) - Method in interface org.apache.iceberg.io.FileAppender
 
add(DataFile) - Method in class org.apache.iceberg.ManifestWriter
Add an added entry for a data file.
add(D) - Method in class org.apache.iceberg.parquet.ParquetWriteAdapter
 
add(CharSequence) - Method in class org.apache.iceberg.util.CharSequenceSet
 
addAll(Iterator<D>) - Method in interface org.apache.iceberg.io.FileAppender
 
addAll(Iterable<D>) - Method in interface org.apache.iceberg.io.FileAppender
 
addAll(Collection<? extends CharSequence>) - Method in class org.apache.iceberg.util.CharSequenceSet
 
addCloseable(Closeable) - Method in class org.apache.iceberg.io.CloseableGroup
 
addColumn(String, Type) - Method in interface org.apache.iceberg.UpdateSchema
Add a new top-level column.
addColumn(String, Type, String) - Method in interface org.apache.iceberg.UpdateSchema
Add a new top-level column.
addColumn(String, String, Type) - Method in interface org.apache.iceberg.UpdateSchema
Add a new column to a nested struct.
addColumn(String, String, Type, String) - Method in interface org.apache.iceberg.UpdateSchema
Add a new column to a nested struct.
ADDED_FILES_COUNT - Static variable in interface org.apache.iceberg.ManifestFile
 
ADDED_FILES_PROP - Static variable in class org.apache.iceberg.SnapshotSummary
 
ADDED_RECORDS_PROP - Static variable in class org.apache.iceberg.SnapshotSummary
 
ADDED_ROWS_COUNT - Static variable in interface org.apache.iceberg.ManifestFile
 
addedFile(PartitionSpec, DataFile) - Method in class org.apache.iceberg.SnapshotSummary.Builder
 
addedFiles() - Method in class org.apache.iceberg.ManifestReader
 
addedFiles() - Method in interface org.apache.iceberg.Snapshot
Return all files added to the table in this snapshot.
addedFilesCount() - Method in class org.apache.iceberg.GenericManifestFile
 
addedFilesCount() - Method in interface org.apache.iceberg.ManifestFile
 
addedManifest(ManifestFile) - Method in class org.apache.iceberg.SnapshotSummary.Builder
 
addedManifests() - Method in class org.apache.iceberg.actions.RewriteManifestsActionResult
 
addedRowsCount() - Method in class org.apache.iceberg.GenericManifestFile
 
addedRowsCount() - Method in interface org.apache.iceberg.ManifestFile
 
addElement(List<E>, E) - Method in class org.apache.iceberg.parquet.ParquetValueReaders.ListReader
 
addElement(I, E) - Method in class org.apache.iceberg.parquet.ParquetValueReaders.RepeatedReader
 
addExtension(String) - Method in enum org.apache.iceberg.FileFormat
Returns filename with this format's extension added, if necessary.
addFallbackIds(MessageType) - Static method in class org.apache.iceberg.parquet.ParquetSchemaUtil
 
addFile(DataFile) - Method in class org.apache.iceberg.BaseOverwriteFiles
 
addFile(DataFile) - Method in class org.apache.iceberg.BaseReplacePartitions
 
addFile(DataFile) - Method in interface org.apache.iceberg.OverwriteFiles
Add a DataFile to the table.
addFile(DataFile) - Method in interface org.apache.iceberg.ReplacePartitions
Add a DataFile to the table.
addManifest(ManifestFile) - Method in class org.apache.iceberg.BaseRewriteManifests
 
addManifest(ManifestFile) - Method in interface org.apache.iceberg.RewriteManifests
Adds a manifest file to the table.
addPair(Map<K, V>, K, V) - Method in class org.apache.iceberg.parquet.ParquetValueReaders.MapReader
 
addPair(I, K, V) - Method in class org.apache.iceberg.parquet.ParquetValueReaders.RepeatedKeyValueReader
 
addRequiredColumn(String, Type) - Method in interface org.apache.iceberg.UpdateSchema
Add a new required top-level column.
addRequiredColumn(String, Type, String) - Method in interface org.apache.iceberg.UpdateSchema
Add a new required top-level column.
addRequiredColumn(String, String, Type) - Method in interface org.apache.iceberg.UpdateSchema
Add a new required top-level column.
addRequiredColumn(String, String, Type, String) - Method in interface org.apache.iceberg.UpdateSchema
Add a new required top-level column.
addSchema(Schema) - Method in class org.apache.iceberg.data.avro.IcebergDecoder
Adds an Iceberg schema that can be used to decode buffers.
addStagedSnapshot(Snapshot) - Method in class org.apache.iceberg.TableMetadata
 
ADJUST_TO_UTC_PROP - Static variable in class org.apache.iceberg.avro.AvroSchemaUtil
 
advance() - Method in class org.apache.iceberg.parquet.BaseColumnIterator
 
advanceNextPageCount - Variable in class org.apache.iceberg.parquet.BaseColumnIterator
 
after(String) - Method in class org.apache.iceberg.FileHistory.Builder
 
after(long) - Method in class org.apache.iceberg.FileHistory.Builder
 
after(String) - Method in class org.apache.iceberg.ScanSummary.Builder
 
after(long) - Method in class org.apache.iceberg.ScanSummary.Builder
 
afterField(Types.NestedField) - Method in class org.apache.iceberg.types.TypeUtil.SchemaVisitor
 
aliasToId(String) - Method in class org.apache.iceberg.Schema
Returns the column id for the given column alias.
AllDataFilesTable - Class in org.apache.iceberg
A Table implementation that exposes a table's valid data files as rows.
AllDataFilesTable(TableOperations, Table) - Constructor for class org.apache.iceberg.AllDataFilesTable
 
AllDataFilesTable.AllDataFilesTableScan - Class in org.apache.iceberg
 
AllEntriesTable - Class in org.apache.iceberg
A Table implementation that exposes a table's manifest entries as rows.
AllEntriesTable(TableOperations, Table) - Constructor for class org.apache.iceberg.AllEntriesTable
 
AllManifestsTable - Class in org.apache.iceberg
A Table implementation that exposes a table's valid manifest files as rows.
AllManifestsTable(TableOperations, Table) - Constructor for class org.apache.iceberg.AllManifestsTable
 
AllManifestsTable.AllManifestsTableScan - Class in org.apache.iceberg
 
allowIncompatibleChanges() - Method in interface org.apache.iceberg.UpdateSchema
Allow incompatible changes to the schema.
AlreadyExistsException - Exception in org.apache.iceberg.exceptions
Exception raised when attempting to create a table that already exists.
AlreadyExistsException(String, Object...) - Constructor for exception org.apache.iceberg.exceptions.AlreadyExistsException
 
AlreadyExistsException(Throwable, String, Object...) - Constructor for exception org.apache.iceberg.exceptions.AlreadyExistsException
 
alwaysFalse() - Static method in class org.apache.iceberg.expressions.Expressions
 
alwaysFalse() - Method in class org.apache.iceberg.expressions.ExpressionVisitors.ExpressionVisitor
 
alwaysNull(String, String) - Method in class org.apache.iceberg.PartitionSpec.Builder
 
alwaysNull(String) - Method in class org.apache.iceberg.PartitionSpec.Builder
 
alwaysNull() - Static method in class org.apache.iceberg.transforms.Transforms
Returns a Transform that always produces null.
alwaysTrue() - Static method in class org.apache.iceberg.expressions.Expressions
 
alwaysTrue() - Method in class org.apache.iceberg.expressions.ExpressionVisitors.ExpressionVisitor
 
ancestorIds(Snapshot, Function<Long, Snapshot>) - Static method in class org.apache.iceberg.util.SnapshotUtil
 
ancestorOf(Table, long, long) - Static method in class org.apache.iceberg.util.SnapshotUtil
 
And - Class in org.apache.iceberg.expressions
 
and(Expression, Expression) - Static method in class org.apache.iceberg.expressions.Expressions
 
and(Expression, Expression, Expression...) - Static method in class org.apache.iceberg.expressions.Expressions
 
and(R, R) - Method in class org.apache.iceberg.expressions.ExpressionVisitors.ExpressionVisitor
 
APPEND - Static variable in class org.apache.iceberg.DataOperations
New data is appended to the table and no data is removed or deleted.
appendFile(DataFile) - Method in interface org.apache.iceberg.AppendFiles
Append a DataFile to the table.
AppendFiles - Interface in org.apache.iceberg
API for appending new files in a table.
appendManifest(ManifestFile) - Method in interface org.apache.iceberg.AppendFiles
Append a ManifestFile to the table.
appendsAfter(long) - Method in class org.apache.iceberg.DataTableScan
 
appendsAfter(long) - Method in interface org.apache.iceberg.TableScan
Create a new TableScan to read appended data from fromSnapshotId exclusive to the current snapshot inclusive.
appendsBetween(long, long) - Method in class org.apache.iceberg.DataTableScan
 
appendsBetween(long, long) - Method in interface org.apache.iceberg.TableScan
Create a new TableScan to read appended data from fromSnapshotId exclusive to toSnapshotId inclusive.
apply(TableMetadata) - Method in class org.apache.iceberg.BaseOverwriteFiles
 
apply(TableMetadata) - Method in class org.apache.iceberg.BaseReplacePartitions
 
apply(TableMetadata) - Method in class org.apache.iceberg.BaseRewriteManifests
 
apply() - Method in interface org.apache.iceberg.PendingUpdate
Apply the pending changes and return the uncommitted changes for validation.
apply() - Method in class org.apache.iceberg.SetLocation
 
apply(TableMetadata) - Method in class org.apache.iceberg.SnapshotManager
 
apply() - Method in class org.apache.iceberg.SnapshotManager
 
apply(S) - Method in interface org.apache.iceberg.transforms.Transform
Transforms a value to its corresponding partition value.
apply(S) - Method in class org.apache.iceberg.transforms.UnknownTransform
 
array(Schema, T) - Method in class org.apache.iceberg.avro.AvroSchemaVisitor
 
array(Types.ListType, Schema, T) - Method in class org.apache.iceberg.avro.AvroSchemaWithTypeVisitor
 
array(ValueReader<T>) - Static method in class org.apache.iceberg.avro.ValueReaders
 
array(ValueWriter<T>) - Static method in class org.apache.iceberg.avro.ValueWriters
 
arrayMap(ValueReader<K>, ValueReader<V>) - Static method in class org.apache.iceberg.avro.ValueReaders
 
arrayMap(ValueWriter<K>, ValueWriter<V>) - Static method in class org.apache.iceberg.avro.ValueWriters
 
ArrowSchemaUtil - Class in org.apache.iceberg.arrow
 
asCombinedScanTask() - Method in interface org.apache.iceberg.CombinedScanTask
 
asCombinedScanTask() - Method in interface org.apache.iceberg.ScanTask
 
asDataTask() - Method in interface org.apache.iceberg.DataTask
 
asDataTask() - Method in interface org.apache.iceberg.ScanTask
 
asFileScanTask() - Method in interface org.apache.iceberg.FileScanTask
 
asFileScanTask() - Method in interface org.apache.iceberg.ScanTask
 
asListType() - Method in interface org.apache.iceberg.types.Type
 
asListType() - Method in class org.apache.iceberg.types.Types.ListType
 
asLiteralPredicate() - Method in class org.apache.iceberg.expressions.BoundLiteralPredicate
 
asLiteralPredicate() - Method in class org.apache.iceberg.expressions.BoundPredicate
 
asMappedFields() - Method in class org.apache.iceberg.mapping.NameMapping
 
asMapType() - Method in interface org.apache.iceberg.types.Type
 
asMapType() - Method in class org.apache.iceberg.types.Types.MapType
 
asNestedType() - Method in interface org.apache.iceberg.types.Type
 
asNestedType() - Method in class org.apache.iceberg.types.Type.NestedType
 
asOfTime(long) - Method in class org.apache.iceberg.AllDataFilesTable.AllDataFilesTableScan
 
asOfTime(long) - Method in class org.apache.iceberg.AllManifestsTable.AllManifestsTableScan
 
asOfTime(long) - Method in class org.apache.iceberg.data.IcebergGenerics.ScanBuilder
 
asOfTime(long) - Method in class org.apache.iceberg.FindFiles.Builder
Base results on files in the snapshot that was current as of a timestamp.
asOfTime(long) - Method in class org.apache.iceberg.mr.mapreduce.IcebergInputFormat.ConfigBuilder
 
asOfTime(long) - Method in interface org.apache.iceberg.TableScan
Create a new TableScan from this scan's configuration that will use the most recent snapshot as of the given time in milliseconds.
asPrimitiveType() - Method in interface org.apache.iceberg.types.Type
 
asPrimitiveType() - Method in class org.apache.iceberg.types.Type.PrimitiveType
 
asSetPredicate() - Method in class org.apache.iceberg.expressions.BoundPredicate
 
asSetPredicate() - Method in class org.apache.iceberg.expressions.BoundSetPredicate
 
assignFreshIds(Type, TypeUtil.NextID) - Static method in class org.apache.iceberg.types.TypeUtil
Assigns fresh ids from the nextId function for all fields in a type.
assignFreshIds(Schema, TypeUtil.NextID) - Static method in class org.apache.iceberg.types.TypeUtil
Assigns fresh ids from the nextId function for all fields in a schema.
assignIncreasingFreshIds(Schema) - Static method in class org.apache.iceberg.types.TypeUtil
Assigns strictly increasing fresh ids for all fields in a schema, starting from 1.
asStatic() - Method in class org.apache.iceberg.common.DynFields.UnboundField
Returns this field as a StaticField.
asStatic() - Method in class org.apache.iceberg.common.DynMethods.UnboundMethod
Returns this method as a StaticMethod.
asStruct() - Method in class org.apache.iceberg.Schema
Returns the underlying struct type for this schema.
asStructType() - Method in interface org.apache.iceberg.types.Type
 
asStructType() - Method in class org.apache.iceberg.types.Types.StructType
 
asUnaryPredicate() - Method in class org.apache.iceberg.expressions.BoundPredicate
 
asUnaryPredicate() - Method in class org.apache.iceberg.expressions.BoundUnaryPredicate
 
Avro - Class in org.apache.iceberg.avro
 
Avro.ReadBuilder - Class in org.apache.iceberg.avro
 
Avro.WriteBuilder - Class in org.apache.iceberg.avro
 
AVRO_COMPRESSION - Static variable in class org.apache.iceberg.TableProperties
 
AVRO_COMPRESSION_DEFAULT - Static variable in class org.apache.iceberg.TableProperties
 
AvroIterable<D> - Class in org.apache.iceberg.avro
 
AvroSchemaUtil - Class in org.apache.iceberg.avro
 
AvroSchemaVisitor<T> - Class in org.apache.iceberg.avro
 
AvroSchemaVisitor() - Constructor for class org.apache.iceberg.avro.AvroSchemaVisitor
 
AvroSchemaWithTypeVisitor<T> - Class in org.apache.iceberg.avro
 
AvroSchemaWithTypeVisitor() - Constructor for class org.apache.iceberg.avro.AvroSchemaWithTypeVisitor
 

B

BaseColumnIterator - Class in org.apache.iceberg.parquet
 
BaseColumnIterator(ColumnDescriptor) - Constructor for class org.apache.iceberg.parquet.BaseColumnIterator
 
BaseCombinedScanTask - Class in org.apache.iceberg
 
BaseCombinedScanTask(FileScanTask...) - Constructor for class org.apache.iceberg.BaseCombinedScanTask
 
BaseCombinedScanTask(List<FileScanTask>) - Constructor for class org.apache.iceberg.BaseCombinedScanTask
 
BaseMetastoreCatalog - Class in org.apache.iceberg
 
BaseMetastoreCatalog() - Constructor for class org.apache.iceberg.BaseMetastoreCatalog
 
BaseMetastoreTableOperations - Class in org.apache.iceberg
 
BaseMetastoreTableOperations() - Constructor for class org.apache.iceberg.BaseMetastoreTableOperations
 
BaseOverwriteFiles - Class in org.apache.iceberg
 
BaseOverwriteFiles(TableOperations) - Constructor for class org.apache.iceberg.BaseOverwriteFiles
 
BasePageIterator - Class in org.apache.iceberg.parquet
 
BasePageIterator(ColumnDescriptor, String) - Constructor for class org.apache.iceberg.parquet.BasePageIterator
 
BasePageIterator.IntIterator - Class in org.apache.iceberg.parquet
 
BaseReplacePartitions - Class in org.apache.iceberg
 
BaseRewriteManifests - Class in org.apache.iceberg
 
BaseTable - Class in org.apache.iceberg
Base Table implementation.
BaseTable(TableOperations, String) - Constructor for class org.apache.iceberg.BaseTable
 
BaseVectorizedParquetValuesReader - Class in org.apache.iceberg.arrow.vectorized.parquet
A values reader for Parquet's run-length encoded data that reads column data in batches instead of one value at a time.
BaseVectorizedParquetValuesReader(int, boolean) - Constructor for class org.apache.iceberg.arrow.vectorized.parquet.BaseVectorizedParquetValuesReader
 
BaseVectorizedParquetValuesReader(int, int, boolean) - Constructor for class org.apache.iceberg.arrow.vectorized.parquet.BaseVectorizedParquetValuesReader
 
before(String) - Method in class org.apache.iceberg.FileHistory.Builder
 
before(long) - Method in class org.apache.iceberg.FileHistory.Builder
 
before(String) - Method in class org.apache.iceberg.ScanSummary.Builder
 
before(long) - Method in class org.apache.iceberg.ScanSummary.Builder
 
beforeField(Types.NestedField) - Method in class org.apache.iceberg.types.TypeUtil.SchemaVisitor
 
BinaryAsDecimalReader(ColumnDescriptor, int) - Constructor for class org.apache.iceberg.parquet.ParquetValueReaders.BinaryAsDecimalReader
 
BinaryType() - Constructor for class org.apache.iceberg.types.Types.BinaryType
 
BinaryUtil - Class in org.apache.iceberg.util
 
bind(Object) - Method in class org.apache.iceberg.common.DynConstructors.Ctor
 
bind(Object) - Method in class org.apache.iceberg.common.DynFields.UnboundField
Returns this method as a BoundMethod for the given receiver.
bind(Object) - Method in class org.apache.iceberg.common.DynMethods.UnboundMethod
Returns this method as a BoundMethod for the given receiver.
bind(Types.StructType, Expression, boolean) - Static method in class org.apache.iceberg.expressions.Binder
Replaces all unbound/named references with bound references to fields in the given struct.
bind(Types.StructType, boolean) - Method in class org.apache.iceberg.expressions.NamedReference
 
bind(Types.StructType, boolean) - Method in interface org.apache.iceberg.expressions.Unbound
Bind this value expression to concrete types.
bind(Types.StructType, boolean) - Method in class org.apache.iceberg.expressions.UnboundPredicate
Bind this UnboundPredicate.
bind(Types.StructType, boolean) - Method in class org.apache.iceberg.expressions.UnboundTransform
 
Binder - Class in org.apache.iceberg.expressions
Rewrites expressions by replacing unbound named references with references to fields in a struct schema.
BinPacking - Class in org.apache.iceberg.util
 
BinPacking() - Constructor for class org.apache.iceberg.util.BinPacking
 
BinPacking.ListPacker<T> - Class in org.apache.iceberg.util
 
BinPacking.PackingIterable<T> - Class in org.apache.iceberg.util
 
blockLocations(CombinedScanTask, Configuration) - Static method in class org.apache.iceberg.hadoop.Util
 
booleans() - Static method in class org.apache.iceberg.avro.ValueReaders
 
booleans() - Static method in class org.apache.iceberg.avro.ValueWriters
 
BooleanType() - Constructor for class org.apache.iceberg.types.Types.BooleanType
 
Bound<T> - Interface in org.apache.iceberg.expressions
Represents a bound value expression.
BoundExpressionVisitor() - Constructor for class org.apache.iceberg.expressions.ExpressionVisitors.BoundExpressionVisitor
Deprecated.
 
BoundLiteralPredicate<T> - Class in org.apache.iceberg.expressions
 
BoundPredicate<T> - Class in org.apache.iceberg.expressions
 
BoundPredicate(Expression.Operation, BoundTerm<T>) - Constructor for class org.apache.iceberg.expressions.BoundPredicate
 
BoundReference<T> - Class in org.apache.iceberg.expressions
 
boundReferences(Types.StructType, List<Expression>, boolean) - Static method in class org.apache.iceberg.expressions.Binder
 
BoundSetPredicate<T> - Class in org.apache.iceberg.expressions
 
BoundTerm<T> - Interface in org.apache.iceberg.expressions
Represents a bound term.
BoundTransform<S,T> - Class in org.apache.iceberg.expressions
A transform expression.
BoundUnaryPredicate<T> - Class in org.apache.iceberg.expressions
 
BoundVisitor() - Constructor for class org.apache.iceberg.expressions.ExpressionVisitors.BoundVisitor
 
bucket(String, int) - Static method in class org.apache.iceberg.expressions.Expressions
 
bucket(String, int, String) - Method in class org.apache.iceberg.PartitionSpec.Builder
 
bucket(String, int) - Method in class org.apache.iceberg.PartitionSpec.Builder
 
bucket(String, int, int) - Method in interface org.apache.iceberg.transforms.PartitionSpecVisitor
 
bucket(Type, int) - Static method in class org.apache.iceberg.transforms.Transforms
Returns a bucket Transform for the given type and number of buckets.
buffer() - Method in interface org.apache.iceberg.encryption.EncryptionKeyMetadata
Opaque blob representing metadata about a file's encryption key.
build() - Method in class org.apache.iceberg.avro.Avro.ReadBuilder
 
build() - Method in class org.apache.iceberg.avro.Avro.WriteBuilder
 
build() - Method in class org.apache.iceberg.common.DynClasses.Builder
Returns the first implementation or throws RuntimeException if one was not found.
build() - Method in class org.apache.iceberg.common.DynConstructors.Builder
 
build() - Method in class org.apache.iceberg.common.DynFields.Builder
Returns the first valid implementation as a UnboundField or throws a NoSuchFieldException if there is none.
build(Object) - Method in class org.apache.iceberg.common.DynFields.Builder
Returns the first valid implementation as a BoundMethod or throws a RuntimeException if there is none.
build() - Method in class org.apache.iceberg.common.DynMethods.Builder
Returns the first valid implementation as a UnboundMethod or throws a RuntimeError if there is none.
build(Object) - Method in class org.apache.iceberg.common.DynMethods.Builder
Returns the first valid implementation as a BoundMethod or throws a RuntimeError if there is none.
build() - Method in class org.apache.iceberg.data.IcebergGenerics.ScanBuilder
 
build() - Method in class org.apache.iceberg.DataFiles.Builder
 
build() - Method in class org.apache.iceberg.FileHistory.Builder
 
build() - Method in class org.apache.iceberg.GenericManifestFile.CopyBuilder
 
build() - Method in class org.apache.iceberg.orc.ORC.ReadBuilder
 
build() - Method in class org.apache.iceberg.orc.ORC.WriteBuilder
 
build() - Method in class org.apache.iceberg.parquet.Parquet.ReadBuilder
 
build() - Method in class org.apache.iceberg.parquet.Parquet.WriteBuilder
 
build() - Method in class org.apache.iceberg.PartitionSpec.Builder
 
build() - Method in class org.apache.iceberg.ScanSummary.Builder
Summarizes a table scan as a map of partition key to metrics for that partition.
build() - Method in class org.apache.iceberg.SnapshotSummary.Builder
 
buildAvroProjection(Schema, Schema, Map<String, String>) - Static method in class org.apache.iceberg.avro.AvroSchemaUtil
 
buildChecked() - Method in class org.apache.iceberg.common.DynClasses.Builder
Returns the first implementation or throws ClassNotFoundException if one was not found.
buildChecked() - Method in class org.apache.iceberg.common.DynConstructors.Builder
 
buildChecked() - Method in class org.apache.iceberg.common.DynFields.Builder
Returns the first valid implementation as a UnboundField or throws a NoSuchFieldException if there is none.
buildChecked(Object) - Method in class org.apache.iceberg.common.DynFields.Builder
Returns the first valid implementation as a BoundMethod or throws a NoSuchMethodException if there is none.
buildChecked() - Method in class org.apache.iceberg.common.DynMethods.Builder
Returns the first valid implementation as a UnboundMethod or throws a NoSuchMethodException if there is none.
buildChecked(Object) - Method in class org.apache.iceberg.common.DynMethods.Builder
Returns the first valid implementation as a BoundMethod or throws a NoSuchMethodException if there is none.
builder() - Static method in class org.apache.iceberg.common.DynClasses
 
Builder() - Constructor for class org.apache.iceberg.common.DynClasses.Builder
 
builder() - Static method in class org.apache.iceberg.common.DynConstructors
 
builder(Class<?>) - Static method in class org.apache.iceberg.common.DynConstructors
 
Builder(Class<?>) - Constructor for class org.apache.iceberg.common.DynConstructors.Builder
 
Builder() - Constructor for class org.apache.iceberg.common.DynConstructors.Builder
 
builder() - Static method in class org.apache.iceberg.common.DynFields
 
Builder() - Constructor for class org.apache.iceberg.common.DynFields.Builder
 
builder(String) - Static method in class org.apache.iceberg.common.DynMethods
Constructs a new builder for calling methods dynamically.
Builder(String) - Constructor for class org.apache.iceberg.common.DynMethods.Builder
 
builder(PartitionSpec) - Static method in class org.apache.iceberg.DataFiles
 
Builder() - Constructor for class org.apache.iceberg.DataFiles.Builder
 
Builder(PartitionSpec) - Constructor for class org.apache.iceberg.DataFiles.Builder
 
Builder(Table) - Constructor for class org.apache.iceberg.FileHistory.Builder
 
Builder(Table) - Constructor for class org.apache.iceberg.FindFiles.Builder
 
Builder(TableScan) - Constructor for class org.apache.iceberg.ScanSummary.Builder
 
builder() - Static method in class org.apache.iceberg.SnapshotSummary
 
Builder() - Constructor for class org.apache.iceberg.SnapshotSummary.Builder
 
Builder(Iterable<I>) - Constructor for class org.apache.iceberg.util.Tasks.Builder
 
builderFor(Schema) - Static method in class org.apache.iceberg.PartitionSpec
Creates a new partition spec builder for the given Schema.
buildList(List<E>) - Method in class org.apache.iceberg.parquet.ParquetValueReaders.ListReader
 
buildList(I) - Method in class org.apache.iceberg.parquet.ParquetValueReaders.RepeatedReader
 
buildMap(Map<K, V>) - Method in class org.apache.iceberg.parquet.ParquetValueReaders.MapReader
 
buildMap(I) - Method in class org.apache.iceberg.parquet.ParquetValueReaders.RepeatedKeyValueReader
 
buildOrcProjection(Schema, TypeDescription) - Static method in class org.apache.iceberg.orc.ORCSchemaUtil
Converts an Iceberg schema to a corresponding ORC schema within the context of an existing ORC file schema.
buildReader(Schema, TypeDescription) - Static method in class org.apache.iceberg.data.orc.GenericOrcReader
 
buildReader(Schema, MessageType) - Static method in class org.apache.iceberg.data.parquet.GenericParquetReaders
 
buildReader(Schema, MessageType, Map<Integer, ?>) - Static method in class org.apache.iceberg.data.parquet.GenericParquetReaders
 
buildReader(Schema, MessageType) - Static method in class org.apache.iceberg.parquet.ParquetAvroValueReaders
 
buildReader(MessageType, Schema, Map<Integer, Object>) - Static method in class org.apache.iceberg.pig.PigParquetReader
 
buildReader(Schema, MessageType) - Static method in class org.apache.iceberg.spark.data.SparkParquetReaders
 
buildReader(Schema, MessageType, Map<Integer, ?>) - Static method in class org.apache.iceberg.spark.data.SparkParquetReaders
 
buildReplacement(Schema, PartitionSpec, Map<String, String>) - Method in class org.apache.iceberg.TableMetadata
 
buildStatic() - Method in class org.apache.iceberg.common.DynFields.Builder
Returns the first valid implementation as a StaticField or throws a RuntimeException if there is none.
buildStatic() - Method in class org.apache.iceberg.common.DynMethods.Builder
Returns the first valid implementation as a StaticMethod or throws a RuntimeException if there is none.
buildStaticChecked() - Method in class org.apache.iceberg.common.DynFields.Builder
Returns the first valid implementation as a StaticField or throws a NoSuchFieldException if there is none.
buildStaticChecked() - Method in class org.apache.iceberg.common.DynMethods.Builder
Returns the first valid implementation as a StaticMethod or throws a NoSuchMethodException if there is none.
buildStruct(I) - Method in class org.apache.iceberg.parquet.ParquetValueReaders.StructReader
 
buildWriter(TypeDescription) - Static method in class org.apache.iceberg.data.orc.GenericOrcWriter
 
buildWriter(MessageType) - Static method in class org.apache.iceberg.data.parquet.GenericParquetWriter
 
buildWriter(MessageType) - Static method in class org.apache.iceberg.parquet.ParquetAvroWriter
 
buildWriter(Schema, MessageType) - Static method in class org.apache.iceberg.spark.data.SparkParquetWriters
 
byteBuffers() - Static method in class org.apache.iceberg.avro.ValueReaders
 
byteBuffers() - Static method in class org.apache.iceberg.avro.ValueWriters
 
byteBuffers(ColumnDescriptor) - Static method in class org.apache.iceberg.parquet.ParquetValueWriters
 
ByteBuffers - Class in org.apache.iceberg.util
 
bytes() - Static method in class org.apache.iceberg.avro.ValueReaders
 
bytes() - Static method in class org.apache.iceberg.avro.ValueWriters
 
BytesReader(ColumnDescriptor) - Constructor for class org.apache.iceberg.parquet.ParquetValueReaders.BytesReader
 

C

CachingCatalog - Class in org.apache.iceberg
 
callInit() - Method in class org.apache.iceberg.parquet.Parquet.ReadBuilder
 
canContainAny(ManifestFile, Iterable<StructLike>, Function<Integer, PartitionSpec>) - Static method in class org.apache.iceberg.util.ManifestFileUtil
 
canTransform(Type) - Method in interface org.apache.iceberg.transforms.Transform
Checks whether this function can be applied to the given Type.
canTransform(Type) - Method in class org.apache.iceberg.transforms.UnknownTransform
 
caseInsensitive() - Method in class org.apache.iceberg.data.IcebergGenerics.ScanBuilder
 
caseInsensitive() - Method in interface org.apache.iceberg.Filterable
Sets case insensitive binding and projection.
caseInsensitive() - Method in class org.apache.iceberg.FindFiles.Builder
 
caseInsensitive() - Method in class org.apache.iceberg.parquet.Parquet.ReadBuilder
 
caseInsensitiveField(String) - Method in class org.apache.iceberg.types.Types.StructType
 
caseInsensitiveFindField(String) - Method in class org.apache.iceberg.Schema
Returns a sub-field by name as a Types.NestedField.
caseInsensitiveSelect(String...) - Method in class org.apache.iceberg.Schema
Creates a projection schema for a subset of columns, selected by case insensitive names
caseInsensitiveSelect(Collection<String>) - Method in class org.apache.iceberg.Schema
Creates a projection schema for a subset of columns, selected by case insensitive names
caseSensitive(boolean) - Method in interface org.apache.iceberg.Filterable
Sets case sensitivity.
caseSensitive() - Method in interface org.apache.iceberg.Filterable
Sets case sensitive binding and projection.
caseSensitive(boolean) - Method in class org.apache.iceberg.FilteredManifest
 
caseSensitive(boolean) - Method in class org.apache.iceberg.FindFiles.Builder
 
caseSensitive(boolean) - Method in class org.apache.iceberg.ManifestReader
 
caseSensitive(boolean) - Method in class org.apache.iceberg.mr.mapreduce.IcebergInputFormat.ConfigBuilder
 
caseSensitive(boolean) - Method in class org.apache.iceberg.orc.ORC.ReadBuilder
 
caseSensitive(boolean) - Method in class org.apache.iceberg.parquet.Parquet.ReadBuilder
 
caseSensitive(boolean) - Method in interface org.apache.iceberg.TableScan
Create a new TableScan from this that, if data columns where selected via TableScan.select(java.util.Collection), controls whether the match to the schema will be done with case sensitivity.
Catalog - Interface in org.apache.iceberg.catalog
A Catalog API for table create, drop, and load operations.
catalogFunc(Class<? extends Function<Configuration, Catalog>>) - Method in class org.apache.iceberg.mr.mapreduce.IcebergInputFormat.ConfigBuilder
 
CHANGED_PARTITION_COUNT_PROP - Static variable in class org.apache.iceberg.SnapshotSummary
 
charAt(int) - Method in class org.apache.iceberg.util.CharSequenceWrapper
 
charSequences() - Static method in class org.apache.iceberg.types.Comparators
 
CharSequenceSet - Class in org.apache.iceberg.util
 
CharSequenceWrapper - Class in org.apache.iceberg.util
Wrapper class to adapt CharSequence for use in maps and sets.
check(boolean, String, Object...) - Static method in exception org.apache.iceberg.exceptions.ValidationException
 
CheckCompatibility - Class in org.apache.iceberg.types
 
cherrypick(long) - Method in interface org.apache.iceberg.ManageSnapshots
Apply supported changes in given snapshot and create a new snapshot which will be set as the current snapshot on commit.
cherrypick(long) - Method in class org.apache.iceberg.SnapshotManager
 
CherrypickAncestorCommitException - Exception in org.apache.iceberg.exceptions
This exception occurs when one cherrypicks an ancestor or when the picked snapshot is already linked to a published ancestor.
CherrypickAncestorCommitException(long) - Constructor for exception org.apache.iceberg.exceptions.CherrypickAncestorCommitException
 
CherrypickAncestorCommitException(long, long) - Constructor for exception org.apache.iceberg.exceptions.CherrypickAncestorCommitException
 
child() - Method in class org.apache.iceberg.expressions.Not
 
classLoader(ClassLoader) - Method in class org.apache.iceberg.avro.Avro.ReadBuilder
 
cleanUncommitted(Set<ManifestFile>) - Method in class org.apache.iceberg.BaseRewriteManifests
 
clear() - Method in class org.apache.iceberg.DataFiles.Builder
 
clear() - Method in class org.apache.iceberg.SnapshotSummary.Builder
 
clear() - Method in class org.apache.iceberg.util.CharSequenceSet
 
ClientPool<C,E extends java.lang.Exception> - Class in org.apache.iceberg.hive
 
ClientPool.Action<R,C,E extends java.lang.Exception> - Interface in org.apache.iceberg.hive
 
close() - Method in class org.apache.iceberg.arrow.vectorized.VectorizedArrowReader
 
close() - Method in class org.apache.iceberg.FilteredManifest
 
close() - Method in class org.apache.iceberg.hadoop.HadoopCatalog
 
close(C) - Method in class org.apache.iceberg.hive.ClientPool
 
close() - Method in class org.apache.iceberg.hive.ClientPool
 
close() - Method in class org.apache.iceberg.hive.HiveCatalog
 
close(HiveMetaStoreClient) - Method in class org.apache.iceberg.hive.HiveClientPool
 
close() - Method in class org.apache.iceberg.io.CloseableGroup
 
close() - Method in class org.apache.iceberg.ManifestWriter
 
close() - Method in class org.apache.iceberg.orc.VectorizedRowBatchIterator
 
close() - Method in class org.apache.iceberg.parquet.ParquetWriteAdapter
 
close() - Method in interface org.apache.iceberg.parquet.VectorizedReader
Release any resources allocated
close() - Method in class org.apache.iceberg.pig.IcebergPigInputFormat.IcebergRecordReader
 
CloseableGroup - Class in org.apache.iceberg.io
 
CloseableGroup() - Constructor for class org.apache.iceberg.io.CloseableGroup
 
CloseableIterable<T> - Interface in org.apache.iceberg.io
 
CloseableIterable.ConcatCloseableIterable<E> - Class in org.apache.iceberg.io
 
clusterBy(Function<DataFile, Object>) - Method in class org.apache.iceberg.BaseRewriteManifests
 
clusterBy(Function<DataFile, Object>) - Method in interface org.apache.iceberg.RewriteManifests
Groups an existing DataFile by a cluster key produced by a function.
collect() - Method in class org.apache.iceberg.FindFiles.Builder
 
collections(int, int, ParquetValueWriter<E>) - Static method in class org.apache.iceberg.parquet.ParquetValueWriters
 
column() - Method in interface org.apache.iceberg.parquet.ParquetValueReader
 
column - Variable in class org.apache.iceberg.parquet.ParquetValueReaders.PrimitiveReader
 
column() - Method in class org.apache.iceberg.parquet.ParquetValueReaders.PrimitiveReader
 
column() - Method in class org.apache.iceberg.parquet.ParquetValueReaders.RepeatedKeyValueReader
 
column() - Method in class org.apache.iceberg.parquet.ParquetValueReaders.RepeatedReader
 
column() - Method in class org.apache.iceberg.parquet.ParquetValueReaders.StructReader
 
column - Variable in class org.apache.iceberg.parquet.ParquetValueWriters.PrimitiveWriter
 
ColumnIterator<T> - Class in org.apache.iceberg.parquet
 
columnMode(String) - Method in class org.apache.iceberg.MetricsConfig
 
columns() - Method in interface org.apache.iceberg.parquet.ParquetValueReader
 
columns() - Method in class org.apache.iceberg.parquet.ParquetValueReaders.PrimitiveReader
 
columns() - Method in class org.apache.iceberg.parquet.ParquetValueReaders.RepeatedKeyValueReader
 
columns() - Method in class org.apache.iceberg.parquet.ParquetValueReaders.RepeatedReader
 
columns() - Method in class org.apache.iceberg.parquet.ParquetValueReaders.StructReader
 
columns() - Method in interface org.apache.iceberg.parquet.ParquetValueWriter
 
columns() - Method in class org.apache.iceberg.parquet.ParquetValueWriters.PrimitiveWriter
 
columns() - Method in class org.apache.iceberg.parquet.ParquetValueWriters.RepeatedKeyValueWriter
 
columns() - Method in class org.apache.iceberg.parquet.ParquetValueWriters.RepeatedWriter
 
columns() - Method in class org.apache.iceberg.parquet.ParquetValueWriters.StructWriter
 
columns() - Method in class org.apache.iceberg.Schema
 
columnSizes() - Method in interface org.apache.iceberg.DataFile
 
columnSizes() - Method in class org.apache.iceberg.Metrics
Get the number of bytes for all fields in a file.
columnSizes() - Method in class org.apache.iceberg.spark.SparkDataFile
 
ColumnWriter<T> - Class in org.apache.iceberg.parquet
 
combine(Iterable<E>, Closeable) - Static method in interface org.apache.iceberg.io.CloseableIterable
 
CombinedScanTask - Interface in org.apache.iceberg
A scan task made of several ranges from files.
commit(TableMetadata, TableMetadata) - Method in class org.apache.iceberg.BaseMetastoreTableOperations
 
commit(TableMetadata, TableMetadata) - Method in class org.apache.iceberg.hadoop.HadoopTableOperations
 
commit() - Method in interface org.apache.iceberg.PendingUpdate
Apply the pending changes and commit.
commit() - Method in class org.apache.iceberg.SetLocation
 
commit(long, WriterCommitMessage[]) - Method in class org.apache.iceberg.spark.source.StreamingWriter
 
commit(TableMetadata, TableMetadata) - Method in interface org.apache.iceberg.TableOperations
Replace the base table metadata with a new version.
COMMIT_MAX_RETRY_WAIT_MS - Static variable in class org.apache.iceberg.TableProperties
 
COMMIT_MAX_RETRY_WAIT_MS_DEFAULT - Static variable in class org.apache.iceberg.TableProperties
 
COMMIT_MIN_RETRY_WAIT_MS - Static variable in class org.apache.iceberg.TableProperties
 
COMMIT_MIN_RETRY_WAIT_MS_DEFAULT - Static variable in class org.apache.iceberg.TableProperties
 
COMMIT_NUM_RETRIES - Static variable in class org.apache.iceberg.TableProperties
 
COMMIT_NUM_RETRIES_DEFAULT - Static variable in class org.apache.iceberg.TableProperties
 
COMMIT_TOTAL_RETRY_TIME_MS - Static variable in class org.apache.iceberg.TableProperties
 
COMMIT_TOTAL_RETRY_TIME_MS_DEFAULT - Static variable in class org.apache.iceberg.TableProperties
 
CommitFailedException - Exception in org.apache.iceberg.exceptions
Exception raised when a commit fails because of out of date metadata.
CommitFailedException(String, Object...) - Constructor for exception org.apache.iceberg.exceptions.CommitFailedException
 
CommitFailedException(Throwable, String, Object...) - Constructor for exception org.apache.iceberg.exceptions.CommitFailedException
 
commitTransaction() - Method in interface org.apache.iceberg.Transaction
Apply the pending changes from all actions and commit.
comparator() - Method in interface org.apache.iceberg.expressions.BoundTerm
 
comparator() - Method in interface org.apache.iceberg.expressions.Literal
Return a Comparator for values.
Comparators - Class in org.apache.iceberg.types
 
compatibleWith(PartitionSpec) - Method in class org.apache.iceberg.PartitionSpec
Returns true if this spec is equivalent to the other, with field names and partition field ids ignored.
concat(Iterable<CloseableIterable<E>>) - Static method in interface org.apache.iceberg.io.CloseableIterable
 
conf() - Method in class org.apache.iceberg.hadoop.HadoopFileIO
 
config(String, String) - Method in class org.apache.iceberg.orc.ORC.ReadBuilder
 
config(String, String) - Method in class org.apache.iceberg.orc.ORC.WriteBuilder
 
ConfigBuilder(Configuration) - Constructor for class org.apache.iceberg.mr.mapreduce.IcebergInputFormat.ConfigBuilder
 
configure(Job) - Static method in class org.apache.iceberg.mr.mapreduce.IcebergInputFormat
Configures the Job to use the IcebergInputFormat and returns a helper to add further configuration.
constant(C) - Static method in class org.apache.iceberg.parquet.ParquetValueReaders
 
constantsMap(FileScanTask) - Static method in class org.apache.iceberg.util.PartitionUtil
 
constantsMap(FileScanTask, BiFunction<Type, Object, Object>) - Static method in class org.apache.iceberg.util.PartitionUtil
 
contains(Object) - Method in class org.apache.iceberg.util.CharSequenceSet
 
containsAll(Collection<?>) - Method in class org.apache.iceberg.util.CharSequenceSet
 
containsNull() - Method in class org.apache.iceberg.GenericPartitionFieldSummary
 
containsNull() - Method in interface org.apache.iceberg.ManifestFile.PartitionFieldSummary
 
Conversions - Class in org.apache.iceberg.types
 
convert(Schema) - Static method in class org.apache.iceberg.arrow.ArrowSchemaUtil
Convert Iceberg schema to Arrow Schema.
convert(Types.NestedField) - Static method in class org.apache.iceberg.arrow.ArrowSchemaUtil
 
convert(Schema, String) - Static method in class org.apache.iceberg.avro.AvroSchemaUtil
 
convert(Schema, Map<Types.StructType, String>) - Static method in class org.apache.iceberg.avro.AvroSchemaUtil
 
convert(Type) - Static method in class org.apache.iceberg.avro.AvroSchemaUtil
 
convert(Types.StructType, String) - Static method in class org.apache.iceberg.avro.AvroSchemaUtil
 
convert(Type, Map<Types.StructType, String>) - Static method in class org.apache.iceberg.avro.AvroSchemaUtil
 
convert(Schema) - Static method in class org.apache.iceberg.avro.AvroSchemaUtil
 
convert(Type) - Static method in class org.apache.iceberg.hive.HiveTypeConverter
 
convert(Schema) - Static method in class org.apache.iceberg.orc.ORCSchemaUtil
 
convert(TypeDescription) - Static method in class org.apache.iceberg.orc.ORCSchemaUtil
Convert an ORC schema to an Iceberg schema.
convert(Schema, String) - Static method in class org.apache.iceberg.parquet.ParquetSchemaUtil
 
convert(MessageType) - Static method in class org.apache.iceberg.parquet.ParquetSchemaUtil
 
convert(Schema, String) - Method in class org.apache.iceberg.parquet.TypeToMessageType
 
convert(Schema) - Static method in class org.apache.iceberg.pig.SchemaUtil
 
convert(Filter) - Static method in class org.apache.iceberg.spark.SparkFilters
 
convert(Schema) - Static method in class org.apache.iceberg.spark.SparkSchemaUtil
Convert a Schema to a Spark type.
convert(Type) - Static method in class org.apache.iceberg.spark.SparkSchemaUtil
Convert a Type to a Spark type.
convert(StructType) - Static method in class org.apache.iceberg.spark.SparkSchemaUtil
Convert a Spark struct to a Schema with new field ids.
convert(DataType) - Static method in class org.apache.iceberg.spark.SparkSchemaUtil
Convert a Spark struct to a Type with new field ids.
convert(Schema, StructType) - Static method in class org.apache.iceberg.spark.SparkSchemaUtil
Convert a Spark struct to a Schema based on the given schema.
convert(Schema, Row) - Static method in class org.apache.iceberg.spark.SparkValueConverter
 
convert(Type, Object) - Static method in class org.apache.iceberg.spark.SparkValueConverter
 
convertTypes(Types.StructType, String) - Static method in class org.apache.iceberg.avro.AvroSchemaUtil
 
copy() - Method in class org.apache.iceberg.data.GenericRecord
 
copy(Map<String, Object>) - Method in class org.apache.iceberg.data.GenericRecord
 
copy() - Method in interface org.apache.iceberg.data.Record
 
copy(Map<String, Object>) - Method in interface org.apache.iceberg.data.Record
 
copy() - Method in interface org.apache.iceberg.DataFile
Copies this data file.
copy(DataFile) - Method in class org.apache.iceberg.DataFiles.Builder
 
copy(PartitionSpec, StructLike) - Static method in class org.apache.iceberg.DataFiles
 
copy() - Method in interface org.apache.iceberg.encryption.EncryptionKeyMetadata
 
copy() - Method in class org.apache.iceberg.GenericManifestFile
 
copy() - Method in class org.apache.iceberg.GenericPartitionFieldSummary
 
copy() - Method in interface org.apache.iceberg.ManifestFile
Copies this manifest file.
copy() - Method in interface org.apache.iceberg.ManifestFile.PartitionFieldSummary
Copies this summary.
copy() - Method in class org.apache.iceberg.spark.SparkDataFile
 
copy(ByteBuffer) - Static method in class org.apache.iceberg.util.ByteBuffers
 
copyOf(ManifestFile) - Static method in class org.apache.iceberg.GenericManifestFile
 
copyWithoutStats() - Method in interface org.apache.iceberg.DataFile
Copies this data file without file stats.
copyWithoutStats() - Method in class org.apache.iceberg.spark.SparkDataFile
 
Counts() - Constructor for class org.apache.iceberg.MetricsModes.Counts
 
create(Schema, Schema) - Static method in class org.apache.iceberg.data.avro.DataReader
 
create(Schema, Schema, Map<Integer, ?>) - Static method in class org.apache.iceberg.data.avro.DataReader
 
create(Schema) - Static method in class org.apache.iceberg.data.avro.DataWriter
 
create(Schema) - Static method in class org.apache.iceberg.data.GenericRecord
 
create(Types.StructType) - Static method in class org.apache.iceberg.data.GenericRecord
 
create() - Method in class org.apache.iceberg.hadoop.HadoopOutputFile
 
create(Schema, PartitionSpec, Map<String, String>, String) - Method in class org.apache.iceberg.hadoop.HadoopTables
Create a table using the FileSystem implementation resolve from location.
create() - Method in interface org.apache.iceberg.io.OutputFile
Create a new file and return a PositionOutputStream to it.
create(Schema) - Static method in class org.apache.iceberg.mapping.MappingUtil
Create a name-based mapping for a schema.
create(Schema, String) - Method in interface org.apache.iceberg.Tables
 
create(Schema, PartitionSpec, String) - Method in interface org.apache.iceberg.Tables
 
create(Schema, PartitionSpec, Map<String, String>, String) - Method in interface org.apache.iceberg.Tables
 
createBatchedReaderFunc(Function<MessageType, VectorizedReader<?>>) - Method in class org.apache.iceberg.parquet.Parquet.ReadBuilder
 
createNamespace(Namespace) - Method in interface org.apache.iceberg.catalog.SupportsNamespaces
Create a namespace in the catalog.
createNamespace(Namespace, Map<String, String>) - Method in interface org.apache.iceberg.catalog.SupportsNamespaces
Create a namespace in the catalog.
createNamespace(Namespace, Map<String, String>) - Method in class org.apache.iceberg.hadoop.HadoopCatalog
 
createNamespace(Namespace, Map<String, String>) - Method in class org.apache.iceberg.hive.HiveCatalog
 
createOrOverwrite() - Method in class org.apache.iceberg.hadoop.HadoopOutputFile
 
createOrOverwrite() - Method in interface org.apache.iceberg.io.OutputFile
Create a new file and return a PositionOutputStream to it.
createOrReplaceTableTransaction(TableOperations, TableMetadata) - Static method in class org.apache.iceberg.Transactions
 
createReader(DataSourceOptions) - Method in class org.apache.iceberg.spark.source.IcebergSource
 
createReader(StructType, DataSourceOptions) - Method in class org.apache.iceberg.spark.source.IcebergSource
 
createReaderFunc(Function<Schema, DatumReader<?>>) - Method in class org.apache.iceberg.avro.Avro.ReadBuilder
 
createReaderFunc(BiFunction<Schema, Schema, DatumReader<?>>) - Method in class org.apache.iceberg.avro.Avro.ReadBuilder
 
createReaderFunc(Function<TypeDescription, OrcValueReader<?>>) - Method in class org.apache.iceberg.orc.ORC.ReadBuilder
 
createReaderFunc(Function<MessageType, ParquetValueReader<?>>) - Method in class org.apache.iceberg.parquet.Parquet.ReadBuilder
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.iceberg.mr.mapreduce.IcebergInputFormat
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.iceberg.pig.IcebergPigInputFormat
 
createStreamWriter(String, StructType, OutputMode, DataSourceOptions) - Method in class org.apache.iceberg.spark.source.IcebergSource
 
createTable(TableIdentifier, Schema, PartitionSpec, String, Map<String, String>) - Method in class org.apache.iceberg.BaseMetastoreCatalog
 
createTable(TableIdentifier, Schema, PartitionSpec, String, Map<String, String>) - Method in class org.apache.iceberg.CachingCatalog
 
createTable(TableIdentifier, Schema, PartitionSpec, String, Map<String, String>) - Method in interface org.apache.iceberg.catalog.Catalog
Create a table.
createTable(TableIdentifier, Schema, PartitionSpec, Map<String, String>) - Method in interface org.apache.iceberg.catalog.Catalog
Create a table.
createTable(TableIdentifier, Schema, PartitionSpec) - Method in interface org.apache.iceberg.catalog.Catalog
Create a table.
createTable(TableIdentifier, Schema) - Method in interface org.apache.iceberg.catalog.Catalog
Create an unpartitioned table.
createTable(TableIdentifier, Schema, PartitionSpec, String, Map<String, String>) - Method in class org.apache.iceberg.hadoop.HadoopCatalog
 
createTableTransaction(TableOperations, TableMetadata) - Static method in class org.apache.iceberg.Transactions
 
createWriter(String, StructType, SaveMode, DataSourceOptions) - Method in class org.apache.iceberg.spark.source.IcebergSource
 
createWriterFunc(Function<Schema, DatumWriter<?>>) - Method in class org.apache.iceberg.avro.Avro.WriteBuilder
 
createWriterFunc(Function<TypeDescription, OrcValueWriter<?>>) - Method in class org.apache.iceberg.orc.ORC.WriteBuilder
 
createWriterFunc(Function<MessageType, ParquetValueWriter<?>>) - Method in class org.apache.iceberg.parquet.Parquet.WriteBuilder
 
ctorImpl(Class<?>, Class<?>...) - Method in class org.apache.iceberg.common.DynMethods.Builder
 
ctorImpl(String, Class<?>...) - Method in class org.apache.iceberg.common.DynMethods.Builder
 
current() - Method in class org.apache.iceberg.BaseMetastoreTableOperations
 
current() - Method in class org.apache.iceberg.hadoop.HadoopTableOperations
 
current() - Method in interface org.apache.iceberg.TableOperations
Return the currently loaded table metadata, without checking for updates.
currentAncestors(Table) - Static method in class org.apache.iceberg.util.SnapshotUtil
Return the snapshot IDs for the ancestors of the current table state.
currentDefinitionLevel() - Method in class org.apache.iceberg.parquet.ColumnIterator
 
currentDL - Variable in class org.apache.iceberg.parquet.BasePageIterator
 
currentMetadataLocation() - Method in class org.apache.iceberg.BaseMetastoreTableOperations
 
currentPageCount() - Method in class org.apache.iceberg.parquet.BasePageIterator
 
currentPath() - Method in class org.apache.iceberg.parquet.ParquetTypeVisitor
 
currentPath() - Method in class org.apache.iceberg.parquet.TypeWithSchemaVisitor
 
currentRepetitionLevel() - Method in class org.apache.iceberg.parquet.ColumnIterator
 
currentRL - Variable in class org.apache.iceberg.parquet.BasePageIterator
 
currentSnapshot() - Method in class org.apache.iceberg.BaseTable
 
currentSnapshot() - Method in interface org.apache.iceberg.Table
Get the current snapshot for this table, or null if there are no snapshots.
currentSnapshot() - Method in class org.apache.iceberg.TableMetadata
 
currentVersion() - Method in class org.apache.iceberg.BaseMetastoreTableOperations
 
CustomOrderSchemaVisitor() - Constructor for class org.apache.iceberg.types.TypeUtil.CustomOrderSchemaVisitor
 

D

data(PartitionSpec, String) - Static method in class org.apache.iceberg.DataFiles
 
DataFile - Interface in org.apache.iceberg
Interface for files listed in a table manifest.
DataFiles - Class in org.apache.iceberg
 
DataFiles.Builder - Class in org.apache.iceberg
 
DataFilesTable - Class in org.apache.iceberg
A Table implementation that exposes a table's data files as rows.
DataFilesTable(TableOperations, Table) - Constructor for class org.apache.iceberg.DataFilesTable
 
DataFilesTable.FilesTableScan - Class in org.apache.iceberg
 
DataOperations - Class in org.apache.iceberg
Data operations that produce snapshots.
DataReader<T> - Class in org.apache.iceberg.data.avro
 
DataTableScan - Class in org.apache.iceberg
 
DataTableScan(TableOperations, Table) - Constructor for class org.apache.iceberg.DataTableScan
 
DataTableScan(TableOperations, Table, Long, Schema, Expression, boolean, boolean, Collection<String>, ImmutableMap<String, String>) - Constructor for class org.apache.iceberg.DataTableScan
 
DataTask - Interface in org.apache.iceberg
A task that returns data as rows instead of where to read data.
dataTimestampMillis() - Method in class org.apache.iceberg.ScanSummary.PartitionMetrics
 
DataWriter<T> - Class in org.apache.iceberg.data.avro
 
dateFromDays(int) - Static method in class org.apache.iceberg.data.DateTimeUtil
 
DateTimeUtil - Class in org.apache.iceberg.data
 
DateType() - Constructor for class org.apache.iceberg.types.Types.DateType
 
day(String) - Static method in class org.apache.iceberg.expressions.Expressions
 
day(String, String) - Method in class org.apache.iceberg.PartitionSpec.Builder
 
day(String) - Method in class org.apache.iceberg.PartitionSpec.Builder
 
day(String, int) - Method in interface org.apache.iceberg.transforms.PartitionSpecVisitor
 
day(Type) - Static method in class org.apache.iceberg.transforms.Transforms
Returns a day Transform for date or timestamp types.
decimal(ValueReader<byte[]>, int) - Static method in class org.apache.iceberg.avro.ValueReaders
 
decimal(int, int) - Static method in class org.apache.iceberg.avro.ValueWriters
 
DECIMAL_INT32_MAX_DIGITS - Static variable in class org.apache.iceberg.parquet.TypeToMessageType
 
DECIMAL_INT64_MAX_DIGITS - Static variable in class org.apache.iceberg.parquet.TypeToMessageType
 
DecimalArrowVector(String, BufferAllocator, int, int) - Constructor for class org.apache.iceberg.arrow.vectorized.IcebergArrowVectors.DecimalArrowVector
 
decimalAsFixed(ColumnDescriptor, int, int) - Static method in class org.apache.iceberg.parquet.ParquetValueWriters
 
decimalAsInteger(ColumnDescriptor, int, int) - Static method in class org.apache.iceberg.parquet.ParquetValueWriters
 
decimalAsLong(ColumnDescriptor, int, int) - Static method in class org.apache.iceberg.parquet.ParquetValueWriters
 
decimalRequiredBytes(int) - Static method in class org.apache.iceberg.types.TypeUtil
 
decode(InputStream, D) - Method in class org.apache.iceberg.data.avro.IcebergDecoder
 
decrypt(EncryptedInputFile) - Method in interface org.apache.iceberg.encryption.EncryptionManager
Given an EncryptedInputFile.encryptedInputFile() representing the raw encrypted bytes from the underlying file system, and given metadata about how the file was encrypted via EncryptedInputFile.keyMetadata(), return an InputFile that returns decrypted input streams.
decrypt(Iterable<EncryptedInputFile>) - Method in interface org.apache.iceberg.encryption.EncryptionManager
Variant of EncryptionManager.decrypt(EncryptedInputFile) that provides a sequence of files that all need to be decrypted in a single context.
decrypt(EncryptedInputFile) - Method in class org.apache.iceberg.encryption.PlaintextEncryptionManager
 
DEFAULT_BATCH_SIZE - Static variable in class org.apache.iceberg.arrow.vectorized.VectorizedArrowReader
 
DEFAULT_FILE_FORMAT - Static variable in class org.apache.iceberg.TableProperties
 
DEFAULT_FILE_FORMAT_DEFAULT - Static variable in class org.apache.iceberg.TableProperties
 
DEFAULT_NAME_MAPPING - Static variable in class org.apache.iceberg.TableProperties
 
DEFAULT_WRITE_METRICS_MODE - Static variable in class org.apache.iceberg.TableProperties
 
DEFAULT_WRITE_METRICS_MODE_DEFAULT - Static variable in class org.apache.iceberg.TableProperties
 
defaultAlwaysNull() - Method in class org.apache.iceberg.common.DynFields.Builder
Instructs this builder to return AlwaysNull if no implementation is found.
defaultFormat(FileFormat) - Method in interface org.apache.iceberg.UpdateProperties
Set the default file format for the table.
defaultSpecId() - Method in class org.apache.iceberg.TableMetadata
 
defaultWarehouseLocation(TableIdentifier) - Method in class org.apache.iceberg.BaseMetastoreCatalog
 
defaultWarehouseLocation(TableIdentifier) - Method in class org.apache.iceberg.hadoop.HadoopCatalog
 
defaultWarehouseLocation(TableIdentifier) - Method in class org.apache.iceberg.hive.HiveCatalog
 
definitionLevels - Variable in class org.apache.iceberg.parquet.BasePageIterator
 
DelegatingInputStream - Interface in org.apache.iceberg.io
 
DelegatingOutputStream - Interface in org.apache.iceberg.io
 
DELETE - Static variable in class org.apache.iceberg.DataOperations
Data is deleted from the table and no data is added.
delete(DataFile) - Method in class org.apache.iceberg.ManifestWriter
Add a delete entry for a data file.
deleteColumn(String) - Method in interface org.apache.iceberg.UpdateSchema
Delete a column in the schema.
DELETED_DUPLICATE_FILES - Static variable in class org.apache.iceberg.SnapshotSummary
 
DELETED_FILES_COUNT - Static variable in interface org.apache.iceberg.ManifestFile
 
DELETED_FILES_PROP - Static variable in class org.apache.iceberg.SnapshotSummary
 
DELETED_RECORDS_PROP - Static variable in class org.apache.iceberg.SnapshotSummary
 
DELETED_ROWS_COUNT - Static variable in interface org.apache.iceberg.ManifestFile
 
deletedFile(PartitionSpec, DataFile) - Method in class org.apache.iceberg.SnapshotSummary.Builder
 
deletedFiles() - Method in class org.apache.iceberg.ManifestReader
 
deletedFiles() - Method in interface org.apache.iceberg.Snapshot
Return all files deleted from the table in this snapshot.
deletedFilesCount() - Method in class org.apache.iceberg.GenericManifestFile
 
deletedFilesCount() - Method in interface org.apache.iceberg.ManifestFile
 
deletedManifest(ManifestFile) - Method in class org.apache.iceberg.SnapshotSummary.Builder
 
deletedManifests() - Method in class org.apache.iceberg.actions.RewriteManifestsActionResult
 
deletedRowsCount() - Method in class org.apache.iceberg.GenericManifestFile
 
deletedRowsCount() - Method in interface org.apache.iceberg.ManifestFile
 
deleteFile(DataFile) - Method in class org.apache.iceberg.BaseOverwriteFiles
 
deleteFile(CharSequence) - Method in interface org.apache.iceberg.DeleteFiles
Delete a file path from the underlying table.
deleteFile(DataFile) - Method in interface org.apache.iceberg.DeleteFiles
Delete a file tracked by a DataFile from the underlying table.
deleteFile(String) - Method in class org.apache.iceberg.hadoop.HadoopFileIO
 
deleteFile(String) - Method in interface org.apache.iceberg.io.FileIO
Delete the file at the given path.
deleteFile(InputFile) - Method in interface org.apache.iceberg.io.FileIO
Convenience method to delete an InputFile.
deleteFile(OutputFile) - Method in interface org.apache.iceberg.io.FileIO
Convenience method to delete an OutputFile.
deleteFile(DataFile) - Method in interface org.apache.iceberg.OverwriteFiles
Delete a DataFile from the table.
DeleteFiles - Interface in org.apache.iceberg
API for deleting files from a table.
deleteFromRowFilter(Expression) - Method in interface org.apache.iceberg.DeleteFiles
Delete files that match an Expression on data rows from the table.
deleteManifest(ManifestFile) - Method in class org.apache.iceberg.BaseRewriteManifests
 
deleteManifest(ManifestFile) - Method in interface org.apache.iceberg.RewriteManifests
Deletes a manifest file from the table.
deleteWith(Consumer<String>) - Method in class org.apache.iceberg.actions.RemoveOrphanFilesAction
Passes an alternative delete implementation that will be used to delete orphan files.
deleteWith(Consumer<String>) - Method in interface org.apache.iceberg.ExpireSnapshots
Passes an alternative delete implementation that will be used for manifests and data files.
deleteWith(Consumer<String>) - Method in interface org.apache.iceberg.SnapshotUpdate
Set a callback to delete files instead of the table's default.
desc - Variable in class org.apache.iceberg.parquet.BaseColumnIterator
 
desc - Variable in class org.apache.iceberg.parquet.BasePageIterator
 
descriptor() - Method in class org.apache.iceberg.arrow.vectorized.VectorHolder
 
deserializeFromBase64(String) - Static method in class org.apache.iceberg.mr.SerializationUtil
 
deserializeFromBytes(byte[]) - Static method in class org.apache.iceberg.mr.SerializationUtil
 
dictionary() - Method in class org.apache.iceberg.arrow.vectorized.VectorHolder
 
dictionary - Variable in class org.apache.iceberg.parquet.BaseColumnIterator
 
dictionary - Variable in class org.apache.iceberg.parquet.BasePageIterator
 
doc() - Method in class org.apache.iceberg.types.Types.NestedField
 
doCommit(TableMetadata, TableMetadata) - Method in class org.apache.iceberg.BaseMetastoreTableOperations
 
doCommit(TableMetadata, TableMetadata) - Method in class org.apache.iceberg.hive.HiveTableOperations
 
doRefresh() - Method in class org.apache.iceberg.BaseMetastoreTableOperations
 
doRefresh() - Method in class org.apache.iceberg.hive.HiveTableOperations
 
doubles() - Static method in class org.apache.iceberg.avro.ValueReaders
 
doubles() - Static method in class org.apache.iceberg.avro.ValueWriters
 
DoubleType() - Constructor for class org.apache.iceberg.types.Types.DoubleType
 
doUnlock(long) - Method in class org.apache.iceberg.hive.HiveTableOperations
 
dropNamespace(Namespace) - Method in interface org.apache.iceberg.catalog.SupportsNamespaces
Drop a namespace.
dropNamespace(Namespace) - Method in class org.apache.iceberg.hadoop.HadoopCatalog
 
dropNamespace(Namespace) - Method in class org.apache.iceberg.hive.HiveCatalog
 
dropTable(TableIdentifier, boolean) - Method in class org.apache.iceberg.CachingCatalog
 
dropTable(TableIdentifier) - Method in interface org.apache.iceberg.catalog.Catalog
Drop a table and delete all data and metadata files.
dropTable(TableIdentifier, boolean) - Method in interface org.apache.iceberg.catalog.Catalog
Drop a table; optionally delete data and metadata files.
dropTable(TableIdentifier, boolean) - Method in class org.apache.iceberg.hadoop.HadoopCatalog
 
dropTable(TableIdentifier, boolean) - Method in class org.apache.iceberg.hive.HiveCatalog
 
dropTableData(FileIO, TableMetadata) - Static method in class org.apache.iceberg.BaseMetastoreCatalog
Drops all data and metadata files referenced by TableMetadata.
DuplicateWAPCommitException - Exception in org.apache.iceberg.exceptions
This exception occurs when the WAP workflow detects a duplicate wap commit.
DuplicateWAPCommitException(String) - Constructor for exception org.apache.iceberg.exceptions.DuplicateWAPCommitException
 
DynClasses - Class in org.apache.iceberg.common
 
DynClasses.Builder - Class in org.apache.iceberg.common
 
DynConstructors - Class in org.apache.iceberg.common
Copied from parquet-common
DynConstructors.Builder - Class in org.apache.iceberg.common
 
DynConstructors.Ctor<C> - Class in org.apache.iceberg.common
 
DynFields - Class in org.apache.iceberg.common
 
DynFields.BoundField<T> - Class in org.apache.iceberg.common
 
DynFields.Builder - Class in org.apache.iceberg.common
 
DynFields.StaticField<T> - Class in org.apache.iceberg.common
 
DynFields.UnboundField<T> - Class in org.apache.iceberg.common
Convenience wrapper class around Field.
DynMethods - Class in org.apache.iceberg.common
Copied from parquet-common
DynMethods.BoundMethod - Class in org.apache.iceberg.common
 
DynMethods.Builder - Class in org.apache.iceberg.common
 
DynMethods.StaticMethod - Class in org.apache.iceberg.common
 
DynMethods.UnboundMethod - Class in org.apache.iceberg.common
Convenience wrapper class around Method.

E

ELEMENT_ID_PROP - Static variable in class org.apache.iceberg.avro.AvroSchemaUtil
 
elementId() - Method in class org.apache.iceberg.types.Types.ListType
 
elements(L) - Method in class org.apache.iceberg.parquet.ParquetValueWriters.RepeatedWriter
 
elementType() - Method in class org.apache.iceberg.types.Types.ListType
 
empty() - Static method in class org.apache.iceberg.catalog.Namespace
 
EMPTY - Static variable in interface org.apache.iceberg.encryption.EncryptionKeyMetadata
 
empty() - Static method in interface org.apache.iceberg.encryption.EncryptionKeyMetadata
 
empty() - Static method in interface org.apache.iceberg.io.CloseableIterable
 
encode(D) - Method in class org.apache.iceberg.data.avro.IcebergEncoder
 
encode(D, OutputStream) - Method in class org.apache.iceberg.data.avro.IcebergEncoder
 
encrypt(OutputFile) - Method in interface org.apache.iceberg.encryption.EncryptionManager
Given a handle on an OutputFile that writes raw bytes to the underlying file system, return a bundle of an EncryptedOutputFile.encryptingOutputFile() that writes encrypted bytes to the underlying file system, and the EncryptedOutputFile.keyMetadata() that points to the encryption key that is being used to encrypt this file.
encrypt(Iterable<OutputFile>) - Method in interface org.apache.iceberg.encryption.EncryptionManager
Variant of EncryptionManager.encrypt(OutputFile) that provides a sequence of files that all need to be encrypted in a single context.
encrypt(OutputFile) - Method in class org.apache.iceberg.encryption.PlaintextEncryptionManager
 
EncryptedFiles - Class in org.apache.iceberg.encryption
 
encryptedInput(InputFile, EncryptionKeyMetadata) - Static method in class org.apache.iceberg.encryption.EncryptedFiles
 
encryptedInput(InputFile, ByteBuffer) - Static method in class org.apache.iceberg.encryption.EncryptedFiles
 
encryptedInput(InputFile, byte[]) - Static method in class org.apache.iceberg.encryption.EncryptedFiles
 
EncryptedInputFile - Interface in org.apache.iceberg.encryption
Thin wrapper around an InputFile instance that is encrypted.
encryptedInputFile() - Method in interface org.apache.iceberg.encryption.EncryptedInputFile
The InputFile that is reading raw encrypted bytes from the underlying file system.
encryptedOutput(OutputFile, EncryptionKeyMetadata) - Static method in class org.apache.iceberg.encryption.EncryptedFiles
 
encryptedOutput(OutputFile, ByteBuffer) - Static method in class org.apache.iceberg.encryption.EncryptedFiles
 
encryptedOutput(OutputFile, byte[]) - Static method in class org.apache.iceberg.encryption.EncryptedFiles
 
EncryptedOutputFile - Interface in org.apache.iceberg.encryption
Thin wrapper around a OutputFile that is encrypting bytes written to the underlying file system, via an encryption key that is symbolized by the enclosed EncryptionKeyMetadata.
encryptingOutputFile() - Method in interface org.apache.iceberg.encryption.EncryptedOutputFile
An OutputFile instance that encrypts the bytes that are written to its output streams.
encryption() - Method in class org.apache.iceberg.BaseTable
 
encryption() - Method in interface org.apache.iceberg.Table
 
encryption() - Method in interface org.apache.iceberg.TableOperations
 
EncryptionKeyMetadata - Interface in org.apache.iceberg.encryption
Light typedef over a ByteBuffer that indicates that the given bytes represent metadata about an encrypted data file's encryption key.
EncryptionKeyMetadatas - Class in org.apache.iceberg.encryption
 
EncryptionManager - Interface in org.apache.iceberg.encryption
Module for encrypting and decrypting table data files.
enums(List<String>) - Static method in class org.apache.iceberg.avro.ValueReaders
 
eq(BoundReference<T>, Literal<T>) - Method in class org.apache.iceberg.expressions.ExpressionVisitors.BoundExpressionVisitor
Deprecated.
 
eq(Bound<T>, Literal<T>) - Method in class org.apache.iceberg.expressions.ExpressionVisitors.BoundVisitor
 
equal(String, T) - Static method in class org.apache.iceberg.expressions.Expressions
 
equal(UnboundTerm<T>, T) - Static method in class org.apache.iceberg.expressions.Expressions
 
equals(Object) - Method in class org.apache.iceberg.catalog.Namespace
 
equals(Object) - Method in class org.apache.iceberg.catalog.TableIdentifier
 
equals(Object) - Method in class org.apache.iceberg.data.GenericRecord
 
equals(Object) - Method in class org.apache.iceberg.GenericManifestFile
 
equals(Object) - Method in class org.apache.iceberg.mapping.MappedField
 
equals(Object) - Method in class org.apache.iceberg.mapping.MappedFields
 
equals(Object) - Method in class org.apache.iceberg.MetricsModes.Truncate
 
equals(Object) - Method in class org.apache.iceberg.PartitionField
 
equals(Object) - Method in class org.apache.iceberg.PartitionSpec
 
equals(Object) - Method in class org.apache.iceberg.TableMetadata.MetadataLogEntry
 
equals(Object) - Method in class org.apache.iceberg.TableMetadata.SnapshotLogEntry
 
equals(Object) - Method in class org.apache.iceberg.transforms.UnknownTransform
 
equals(Object) - Method in class org.apache.iceberg.types.Types.DecimalType
 
equals(Object) - Method in class org.apache.iceberg.types.Types.FixedType
 
equals(Object) - Method in class org.apache.iceberg.types.Types.ListType
 
equals(Object) - Method in class org.apache.iceberg.types.Types.MapType
 
equals(Object) - Method in class org.apache.iceberg.types.Types.NestedField
 
equals(Object) - Method in class org.apache.iceberg.types.Types.StructType
 
equals(Object) - Method in class org.apache.iceberg.types.Types.TimestampType
 
equals(Object) - Method in class org.apache.iceberg.util.CharSequenceWrapper
 
equals(Object) - Method in class org.apache.iceberg.util.Pair
 
equals(Object) - Method in class org.apache.iceberg.util.StructLikeWrapper
 
eval(StructLike) - Method in interface org.apache.iceberg.expressions.Bound
Produce a value from the struct for this expression.
eval(StructLike) - Method in class org.apache.iceberg.expressions.BoundPredicate
 
eval(StructLike) - Method in class org.apache.iceberg.expressions.BoundReference
 
eval(StructLike) - Method in class org.apache.iceberg.expressions.BoundTransform
 
eval(StructLike) - Method in class org.apache.iceberg.expressions.Evaluator
 
eval(DataFile) - Method in class org.apache.iceberg.expressions.InclusiveMetricsEvaluator
Test whether the file may contain records that match the expression.
eval(ManifestFile) - Method in class org.apache.iceberg.expressions.ManifestEvaluator
Test whether the file may contain records that match the expression.
eval(DataFile) - Method in class org.apache.iceberg.expressions.StrictMetricsEvaluator
Test whether the file may contain records that match the expression.
Evaluator - Class in org.apache.iceberg.expressions
Evaluates an Expression for data described by a Types.StructType.
Evaluator(Types.StructType, Expression) - Constructor for class org.apache.iceberg.expressions.Evaluator
 
Evaluator(Types.StructType, Expression, boolean) - Constructor for class org.apache.iceberg.expressions.Evaluator
 
Exceptions - Class in org.apache.iceberg.util
 
ExceptionUtil - Class in org.apache.iceberg.util
 
execute() - Method in interface org.apache.iceberg.actions.Action
Executes this action.
execute() - Method in class org.apache.iceberg.actions.RemoveOrphanFilesAction
 
execute() - Method in class org.apache.iceberg.actions.RewriteManifestsAction
 
executeWith(ExecutorService) - Method in class org.apache.iceberg.util.Tasks.Builder
 
existing(DataFile, long, long) - Method in class org.apache.iceberg.ManifestWriter
Add an existing entry for a data file.
EXISTING_FILES_COUNT - Static variable in interface org.apache.iceberg.ManifestFile
 
EXISTING_ROWS_COUNT - Static variable in interface org.apache.iceberg.ManifestFile
 
existingFilesCount() - Method in class org.apache.iceberg.GenericManifestFile
 
existingFilesCount() - Method in interface org.apache.iceberg.ManifestFile
 
existingRowsCount() - Method in class org.apache.iceberg.GenericManifestFile
 
existingRowsCount() - Method in interface org.apache.iceberg.ManifestFile
 
exists() - Method in class org.apache.iceberg.hadoop.HadoopInputFile
 
exists() - Method in interface org.apache.iceberg.io.InputFile
Checks whether the file exists.
expireOlderThan(long) - Method in interface org.apache.iceberg.ExpireSnapshots
Expires all snapshots older than the given timestamp.
expireSnapshotId(long) - Method in interface org.apache.iceberg.ExpireSnapshots
Expires a specific Snapshot identified by id.
expireSnapshots() - Method in class org.apache.iceberg.BaseTable
 
ExpireSnapshots - Interface in org.apache.iceberg
API for removing old snapshots from a table.
expireSnapshots() - Method in interface org.apache.iceberg.Table
Create a new expire API to manage snapshots in this table and commit.
expireSnapshots() - Method in interface org.apache.iceberg.Transaction
Create a new expire API to manage snapshots in this table.
exponentialBackoff(long, long, long, double) - Method in class org.apache.iceberg.util.Tasks.Builder
 
Expression - Interface in org.apache.iceberg.expressions
Represents a boolean expression tree.
Expression.Operation - Enum in org.apache.iceberg.expressions
 
Expressions - Class in org.apache.iceberg.expressions
Factory methods for creating expressions.
ExpressionVisitor() - Constructor for class org.apache.iceberg.expressions.ExpressionVisitors.ExpressionVisitor
 
ExpressionVisitors - Class in org.apache.iceberg.expressions
Utils for traversing expressions.
ExpressionVisitors.BoundExpressionVisitor<R> - Class in org.apache.iceberg.expressions
Deprecated.
ExpressionVisitors.BoundVisitor<R> - Class in org.apache.iceberg.expressions
 
ExpressionVisitors.ExpressionVisitor<R> - Class in org.apache.iceberg.expressions
 

F

factory() - Static method in class org.apache.iceberg.util.JsonUtil
 
False - Class in org.apache.iceberg.expressions
An expression that is always false.
field() - Method in class org.apache.iceberg.expressions.BoundReference
 
field(int) - Method in class org.apache.iceberg.mapping.MappedFields
 
field(Types.NestedField) - Method in class org.apache.iceberg.parquet.TypeToMessageType
 
field(Types.NestedField, Supplier<Type>) - Method in class org.apache.iceberg.spark.PruneColumnsWithoutReordering
 
field(Types.NestedField, Supplier<Type>) - Method in class org.apache.iceberg.spark.PruneColumnsWithReordering
 
field(Types.NestedField, Supplier<List<String>>) - Method in class org.apache.iceberg.types.CheckCompatibility
 
field(Types.NestedField, Supplier<Map<String, Integer>>) - Method in class org.apache.iceberg.types.IndexByName
 
field(int) - Method in class org.apache.iceberg.types.Type.NestedType
 
field(int) - Method in class org.apache.iceberg.types.Types.ListType
 
field(int) - Method in class org.apache.iceberg.types.Types.MapType
 
field(String) - Method in class org.apache.iceberg.types.Types.StructType
 
field(int) - Method in class org.apache.iceberg.types.Types.StructType
 
field(Types.NestedField, Supplier<T>) - Method in class org.apache.iceberg.types.TypeUtil.CustomOrderSchemaVisitor
 
field(Types.NestedField, T) - Method in class org.apache.iceberg.types.TypeUtil.SchemaVisitor
 
FIELD_ID_PROP - Static variable in class org.apache.iceberg.avro.AvroSchemaUtil
 
fieldId() - Method in class org.apache.iceberg.expressions.BoundReference
 
fieldId() - Method in class org.apache.iceberg.PartitionField
 
fieldId() - Method in class org.apache.iceberg.types.Types.NestedField
 
fieldNames() - Method in class org.apache.iceberg.avro.AvroSchemaVisitor
 
fieldNames - Variable in class org.apache.iceberg.parquet.ParquetTypeVisitor
 
fieldNames - Variable in class org.apache.iceberg.parquet.TypeWithSchemaVisitor
 
fields() - Method in class org.apache.iceberg.mapping.MappedFields
 
fields() - Method in class org.apache.iceberg.PartitionSpec
 
fields() - Method in class org.apache.iceberg.types.Type.NestedType
 
fields() - Method in class org.apache.iceberg.types.Types.ListType
 
fields() - Method in class org.apache.iceberg.types.Types.MapType
 
fields() - Method in class org.apache.iceberg.types.Types.StructType
 
fieldType(String) - Method in class org.apache.iceberg.types.Type.NestedType
 
fieldType(String) - Method in class org.apache.iceberg.types.Types.ListType
 
fieldType(String) - Method in class org.apache.iceberg.types.Types.MapType
 
fieldType(String) - Method in class org.apache.iceberg.types.Types.StructType
 
file() - Method in interface org.apache.iceberg.FileScanTask
The file to scan.
file() - Method in class org.apache.iceberg.ManifestReader
 
file() - Method in class org.apache.iceberg.TableMetadata
 
file() - Method in class org.apache.iceberg.TableMetadata.MetadataLogEntry
 
FileAppender<D> - Interface in org.apache.iceberg.io
 
fileCount() - Method in class org.apache.iceberg.ScanSummary.PartitionMetrics
 
FileFormat - Enum in org.apache.iceberg
Enum of supported file formats.
FileHistory - Class in org.apache.iceberg
 
FileHistory.Builder - Class in org.apache.iceberg
 
FileIO - Interface in org.apache.iceberg.io
Pluggable module for reading, writing, and deleting files.
fileMetrics(InputFile, MetricsConfig) - Static method in class org.apache.iceberg.parquet.ParquetUtil
 
files() - Method in class org.apache.iceberg.BaseCombinedScanTask
 
files() - Method in interface org.apache.iceberg.CombinedScanTask
Return the tasks in this combined task.
Files - Class in org.apache.iceberg
 
FileScanTask - Interface in org.apache.iceberg
A scan task over a range of a single file.
fileSizeInBytes() - Method in interface org.apache.iceberg.DataFile
 
fileSizeInBytes() - Method in class org.apache.iceberg.spark.SparkDataFile
 
filter() - Method in class org.apache.iceberg.events.ScanEvent
 
filter(CloseableIterable<E>, Predicate<E>) - Static method in interface org.apache.iceberg.io.CloseableIterable
 
filter(Expression) - Method in class org.apache.iceberg.mr.mapreduce.IcebergInputFormat.ConfigBuilder
 
filter(Expression) - Method in class org.apache.iceberg.parquet.Parquet.ReadBuilder
 
filter(Expression) - Method in interface org.apache.iceberg.TableScan
Create a new TableScan from the results of this filtered by the Expression.
filter() - Method in interface org.apache.iceberg.TableScan
Returns this scan's filter Expression.
Filterable<T extends Filterable<T>> - Interface in org.apache.iceberg
Methods to filter files in a snapshot or manifest when reading.
FilteredManifest - Class in org.apache.iceberg
 
filterPartitions(Expression) - Method in interface org.apache.iceberg.Filterable
Adds a filter expression on partition data for matching files.
filterPartitions(Expression) - Method in class org.apache.iceberg.FilteredManifest
 
filterPartitions(Expression) - Method in class org.apache.iceberg.ManifestReader
 
filterRecords(boolean) - Method in class org.apache.iceberg.parquet.Parquet.ReadBuilder
 
filterRows(Expression) - Method in interface org.apache.iceberg.Filterable
Adds a filter expression on data rows for matching files.
filterRows(Expression) - Method in class org.apache.iceberg.FilteredManifest
 
filterRows(Expression) - Method in class org.apache.iceberg.ManifestReader
 
finalize() - Method in class org.apache.iceberg.hive.HiveCatalog
 
find(int) - Method in class org.apache.iceberg.mapping.NameMapping
 
find(String...) - Method in class org.apache.iceberg.mapping.NameMapping
 
find(List<String>) - Method in class org.apache.iceberg.mapping.NameMapping
 
find(Schema, Predicate<Type>) - Static method in class org.apache.iceberg.types.TypeUtil
 
findColumnName(int) - Method in class org.apache.iceberg.Schema
Returns the full column name for the given id.
findField(int) - Method in class org.apache.iceberg.Schema
Returns the sub-field identified by the field id as a Types.NestedField.
findField(String) - Method in class org.apache.iceberg.Schema
Returns a sub-field by name as a Types.NestedField.
FindFiles - Class in org.apache.iceberg
 
FindFiles.Builder - Class in org.apache.iceberg
 
findTable(DataSourceOptions, Configuration) - Method in class org.apache.iceberg.spark.source.IcebergSource
 
findType(String) - Method in class org.apache.iceberg.Schema
 
findType(int) - Method in class org.apache.iceberg.Schema
Returns the Type of a sub-field identified by the field id.
first() - Method in class org.apache.iceberg.util.Pair
 
fixed(int) - Static method in class org.apache.iceberg.avro.ValueReaders
 
fixed(Schema) - Static method in class org.apache.iceberg.avro.ValueReaders
 
fixed(int) - Static method in class org.apache.iceberg.avro.ValueWriters
 
flipLR() - Method in enum org.apache.iceberg.expressions.Expression.Operation
 
FloatAsDoubleReader(ColumnDescriptor) - Constructor for class org.apache.iceberg.parquet.ParquetValueReaders.FloatAsDoubleReader
 
floats() - Static method in class org.apache.iceberg.avro.ValueReaders
 
floats() - Static method in class org.apache.iceberg.avro.ValueWriters
 
FloatType() - Constructor for class org.apache.iceberg.types.Types.FloatType
 
footerMetrics(ParquetMetadata, MetricsConfig) - Static method in class org.apache.iceberg.parquet.ParquetUtil
 
foreach(Iterable<I>) - Static method in class org.apache.iceberg.util.Tasks
 
foreach(I...) - Static method in class org.apache.iceberg.util.Tasks
 
format() - Method in interface org.apache.iceberg.DataFile
 
format() - Method in class org.apache.iceberg.spark.SparkDataFile
 
formatVersion() - Method in class org.apache.iceberg.TableMetadata
 
forPartitionFilter(Expression, PartitionSpec, boolean) - Static method in class org.apache.iceberg.expressions.ManifestEvaluator
 
forRowFilter(Expression, PartitionSpec, boolean) - Static method in class org.apache.iceberg.expressions.ManifestEvaluator
 
forTable(SparkSession, Table) - Static method in class org.apache.iceberg.actions.Actions
 
forTable(Table) - Static method in class org.apache.iceberg.actions.Actions
 
forTable(Table) - Method in class org.apache.iceberg.avro.Avro.WriteBuilder
 
forTable(Table) - Method in class org.apache.iceberg.parquet.Parquet.WriteBuilder
 
forType(Type.PrimitiveType) - Static method in class org.apache.iceberg.types.Comparators
 
from(String) - Static method in enum org.apache.iceberg.MetadataTableType
 
fromByteBuffer(Type, ByteBuffer) - Static method in class org.apache.iceberg.types.Conversions
 
fromEncryptedOutputFile(EncryptedOutputFile, PartitionData, Metrics, List<Long>) - Static method in class org.apache.iceberg.DataFiles
 
fromFileName(CharSequence) - Static method in enum org.apache.iceberg.FileFormat
 
fromFileName(String) - Static method in enum org.apache.iceberg.TableMetadataParser.Codec
 
fromFixed(GenericFixed, Schema, LogicalType) - Method in class org.apache.iceberg.avro.UUIDConversion
 
fromInputFile(InputFile, PartitionData, long) - Static method in class org.apache.iceberg.DataFiles
 
fromInputFile(InputFile, long) - Static method in class org.apache.iceberg.DataFiles
 
fromInputFile(InputFile) - Static method in class org.apache.iceberg.orc.OrcMetrics
 
fromInputFile(InputFile, Configuration) - Static method in class org.apache.iceberg.orc.OrcMetrics
 
fromJson(String) - Static method in class org.apache.iceberg.mapping.NameMappingParser
 
fromJson(Schema, JsonNode) - Static method in class org.apache.iceberg.PartitionSpecParser
 
fromJson(Schema, String) - Static method in class org.apache.iceberg.PartitionSpecParser
 
fromJson(JsonNode) - Static method in class org.apache.iceberg.SchemaParser
 
fromJson(String) - Static method in class org.apache.iceberg.SchemaParser
 
fromJson(FileIO, String) - Static method in class org.apache.iceberg.SnapshotParser
 
fromLocation(CharSequence, Configuration) - Static method in class org.apache.iceberg.hadoop.HadoopInputFile
 
fromLocation(CharSequence, long, Configuration) - Static method in class org.apache.iceberg.hadoop.HadoopInputFile
 
fromLocation(CharSequence, FileSystem) - Static method in class org.apache.iceberg.hadoop.HadoopInputFile
 
fromLocation(CharSequence, long, FileSystem) - Static method in class org.apache.iceberg.hadoop.HadoopInputFile
 
fromLocation(CharSequence, Configuration) - Static method in class org.apache.iceberg.hadoop.HadoopOutputFile
 
fromLocation(CharSequence, FileSystem) - Static method in class org.apache.iceberg.hadoop.HadoopOutputFile
 
fromManifest(ManifestFile) - Static method in class org.apache.iceberg.DataFiles
 
fromManifestList(InputFile) - Static method in class org.apache.iceberg.DataFiles
 
fromName(String) - Static method in enum org.apache.iceberg.TableMetadataParser.Codec
 
fromPartitionString(Type, String) - Static method in class org.apache.iceberg.types.Conversions
 
fromPath(Path, Configuration) - Static method in class org.apache.iceberg.hadoop.HadoopInputFile
 
fromPath(Path, long, Configuration) - Static method in class org.apache.iceberg.hadoop.HadoopInputFile
 
fromPath(Path, FileSystem) - Static method in class org.apache.iceberg.hadoop.HadoopInputFile
 
fromPath(Path, long, FileSystem) - Static method in class org.apache.iceberg.hadoop.HadoopInputFile
 
fromPath(Path, FileSystem, Configuration) - Static method in class org.apache.iceberg.hadoop.HadoopInputFile
 
fromPath(Path, long, FileSystem, Configuration) - Static method in class org.apache.iceberg.hadoop.HadoopInputFile
 
fromPath(Path, Configuration) - Static method in class org.apache.iceberg.hadoop.HadoopOutputFile
 
fromPath(Path, FileSystem) - Static method in class org.apache.iceberg.hadoop.HadoopOutputFile
 
fromPath(Path, FileSystem, Configuration) - Static method in class org.apache.iceberg.hadoop.HadoopOutputFile
 
fromPrimitiveString(String) - Static method in class org.apache.iceberg.types.Types
 
fromProperties(Map<String, String>) - Static method in class org.apache.iceberg.MetricsConfig
 
fromStat(FileStatus, long) - Static method in class org.apache.iceberg.DataFiles
 
fromStat(FileStatus, PartitionData, long) - Static method in class org.apache.iceberg.DataFiles
 
fromStat(FileStatus, PartitionData, Metrics, EncryptionKeyMetadata, List<Long>) - Static method in class org.apache.iceberg.DataFiles
 
fromStatus(FileStatus, Configuration) - Static method in class org.apache.iceberg.hadoop.HadoopInputFile
 
fromStatus(FileStatus, FileSystem) - Static method in class org.apache.iceberg.hadoop.HadoopInputFile
 
fromStatus(FileStatus, FileSystem, Configuration) - Static method in class org.apache.iceberg.hadoop.HadoopInputFile
 
fromString(String) - Static method in class org.apache.iceberg.MetricsModes
 
fromString(Type, String) - Static method in class org.apache.iceberg.transforms.Transforms
 
Full() - Constructor for class org.apache.iceberg.MetricsModes.Full
 

G

genericFixed(int) - Static method in class org.apache.iceberg.avro.ValueWriters
 
GenericManifestFile - Class in org.apache.iceberg
 
GenericManifestFile(Schema) - Constructor for class org.apache.iceberg.GenericManifestFile
Used by Avro reflection to instantiate this class when reading manifest files.
GenericManifestFile(String, long, int, long, long, Long, int, long, int, long, int, long, List<ManifestFile.PartitionFieldSummary>) - Constructor for class org.apache.iceberg.GenericManifestFile
 
GenericManifestFile.CopyBuilder - Class in org.apache.iceberg
 
GenericOrcReader - Class in org.apache.iceberg.data.orc
ORC reader for Generic Record.
GenericOrcWriter - Class in org.apache.iceberg.data.orc
 
GenericParquetReaders - Class in org.apache.iceberg.data.parquet
 
GenericParquetWriter - Class in org.apache.iceberg.data.parquet
 
GenericPartitionFieldSummary - Class in org.apache.iceberg
 
GenericPartitionFieldSummary(Schema) - Constructor for class org.apache.iceberg.GenericPartitionFieldSummary
Used by Avro reflection to instantiate this class when reading manifest files.
GenericPartitionFieldSummary(boolean, ByteBuffer, ByteBuffer) - Constructor for class org.apache.iceberg.GenericPartitionFieldSummary
 
GenericRecord - Class in org.apache.iceberg.data
 
get(T) - Method in interface org.apache.iceberg.Accessor
 
get(S, int) - Method in class org.apache.iceberg.avro.ValueReaders.StructReader
 
get(S, int) - Method in class org.apache.iceberg.avro.ValueWriters.StructWriter
 
get() - Method in class org.apache.iceberg.common.DynFields.BoundField
 
get() - Method in class org.apache.iceberg.common.DynFields.StaticField
 
get(Object) - Method in class org.apache.iceberg.common.DynFields.UnboundField
 
get(int) - Method in class org.apache.iceberg.data.GenericRecord
 
get(int, Class<T>) - Method in class org.apache.iceberg.data.GenericRecord
 
get(int) - Method in interface org.apache.iceberg.data.Record
 
get(int, Class<T>) - Method in class org.apache.iceberg.GenericManifestFile
 
get(int) - Method in class org.apache.iceberg.GenericManifestFile
 
get(int, Class<T>) - Method in class org.apache.iceberg.GenericPartitionFieldSummary
 
get(int) - Method in class org.apache.iceberg.GenericPartitionFieldSummary
 
get() - Static method in class org.apache.iceberg.hadoop.HiddenPathFilter
 
get() - Method in class org.apache.iceberg.hadoop.SerializableConfiguration
 
get() - Static method in class org.apache.iceberg.MetricsModes.Counts
 
get() - Static method in class org.apache.iceberg.MetricsModes.Full
 
get() - Static method in class org.apache.iceberg.MetricsModes.None
 
get(S, int) - Method in class org.apache.iceberg.parquet.ParquetValueWriters.StructWriter
 
get(int, Class<T>) - Method in class org.apache.iceberg.spark.SparkStructLike
 
get(int, Class<T>) - Method in interface org.apache.iceberg.StructLike
 
get() - Static method in class org.apache.iceberg.types.Types.BinaryType
 
get() - Static method in class org.apache.iceberg.types.Types.BooleanType
 
get() - Static method in class org.apache.iceberg.types.Types.DateType
 
get() - Static method in class org.apache.iceberg.types.Types.DoubleType
 
get() - Static method in class org.apache.iceberg.types.Types.FloatType
 
get() - Static method in class org.apache.iceberg.types.Types.IntegerType
 
get() - Static method in class org.apache.iceberg.types.Types.LongType
 
get() - Static method in class org.apache.iceberg.types.Types.StringType
 
get() - Static method in class org.apache.iceberg.types.Types.TimeType
 
get() - Static method in class org.apache.iceberg.types.Types.UUIDType
 
get() - Method in interface org.apache.iceberg.types.TypeUtil.NextID
 
get() - Method in class org.apache.iceberg.util.CharSequenceWrapper
 
get(int) - Method in class org.apache.iceberg.util.Pair
 
get() - Method in class org.apache.iceberg.util.StructLikeWrapper
 
getAliases() - Method in class org.apache.iceberg.Schema
Returns an alias map for this schema, if set.
getBool(String, JsonNode) - Static method in class org.apache.iceberg.util.JsonUtil
 
getBuffer(int) - Method in class org.apache.iceberg.parquet.ValuesAsBytesReader
 
getConf() - Method in class org.apache.iceberg.hadoop.HadoopInputFile
 
getConf() - Method in class org.apache.iceberg.hadoop.HadoopOutputFile
 
getConf() - Method in class org.apache.iceberg.hadoop.HadoopTables
 
getConstructedClass() - Method in class org.apache.iceberg.common.DynConstructors.Ctor
 
getConvertedType() - Method in class org.apache.iceberg.avro.UUIDConversion
 
getCurrentKey() - Method in class org.apache.iceberg.pig.IcebergPigInputFormat.IcebergRecordReader
 
getCurrentValue() - Method in class org.apache.iceberg.pig.IcebergPigInputFormat.IcebergRecordReader
 
getDefault() - Static method in class org.apache.iceberg.MetricsConfig
 
getDelegate() - Method in interface org.apache.iceberg.io.DelegatingInputStream
 
getDelegate() - Method in interface org.apache.iceberg.io.DelegatingOutputStream
 
getElement(List<E>) - Method in class org.apache.iceberg.parquet.ParquetValueReaders.ListReader
 
getElement(I) - Method in class org.apache.iceberg.parquet.ParquetValueReaders.RepeatedReader
 
getElementId(Schema) - Static method in class org.apache.iceberg.avro.AvroSchemaUtil
 
getFeatures() - Method in class org.apache.iceberg.pig.IcebergStorage
 
getField(String) - Method in class org.apache.iceberg.data.GenericRecord
 
getField(String) - Method in interface org.apache.iceberg.data.Record
 
getField(I, int) - Method in class org.apache.iceberg.parquet.ParquetValueReaders.StructReader
 
getFieldId(Schema.Field) - Static method in class org.apache.iceberg.avro.AvroSchemaUtil
 
getFieldsBySourceId(int) - Method in class org.apache.iceberg.PartitionSpec
 
getFileExtension(String) - Static method in class org.apache.iceberg.TableMetadataParser
 
getFileExtension(TableMetadataParser.Codec) - Static method in class org.apache.iceberg.TableMetadataParser
 
getFileSystem() - Method in class org.apache.iceberg.hadoop.HadoopInputFile
 
getFileSystem() - Method in class org.apache.iceberg.hadoop.HadoopOutputFile
 
getFileSystem(Path, Configuration) - Method in class org.apache.iceberg.hadoop.HadoopTableOperations
 
getFs(Path, Configuration) - Static method in class org.apache.iceberg.hadoop.Util
 
getInputFormat() - Method in class org.apache.iceberg.pig.IcebergStorage
 
getInt(String, JsonNode) - Static method in class org.apache.iceberg.util.JsonUtil
 
getIntOrNull(String, JsonNode) - Static method in class org.apache.iceberg.util.JsonUtil
 
getKey() - Method in class org.apache.iceberg.parquet.ParquetValueReaders.ReusableEntry
 
getKeyId(Schema) - Static method in class org.apache.iceberg.avro.AvroSchemaUtil
 
getLength() - Method in class org.apache.iceberg.hadoop.HadoopInputFile
 
getLength() - Method in interface org.apache.iceberg.io.InputFile
 
getLogicalTypeName() - Method in class org.apache.iceberg.avro.UUIDConversion
 
getLong(String, JsonNode) - Static method in class org.apache.iceberg.util.JsonUtil
 
getMetadata() - Method in class org.apache.iceberg.avro.AvroIterable
 
getNext() - Method in class org.apache.iceberg.pig.IcebergStorage
 
getOldFileExtension(TableMetadataParser.Codec) - Static method in class org.apache.iceberg.TableMetadataParser
 
getPair(Map<K, V>) - Method in class org.apache.iceberg.parquet.ParquetValueReaders.MapReader
 
getPair(I) - Method in class org.apache.iceberg.parquet.ParquetValueReaders.RepeatedKeyValueReader
 
getPartitionKeys(String, Job) - Method in class org.apache.iceberg.pig.IcebergStorage
 
getPath() - Method in class org.apache.iceberg.hadoop.HadoopOutputFile
 
getPos() - Method in class org.apache.iceberg.io.PositionOutputStream
Return the current position in the OutputStream.
getPos() - Method in class org.apache.iceberg.io.SeekableInputStream
Return the current position in the InputStream.
getPredicateFields(String, Job) - Method in class org.apache.iceberg.pig.IcebergStorage
 
getProgress() - Method in class org.apache.iceberg.pig.IcebergPigInputFormat.IcebergRecordReader
 
getProjectedIds(Schema) - Static method in class org.apache.iceberg.types.TypeUtil
 
getProjectedIds(Type) - Static method in class org.apache.iceberg.types.TypeUtil
 
getResultType(Type) - Method in interface org.apache.iceberg.transforms.Transform
Returns the Type produced by this transform given a source type.
getResultType(Type) - Method in class org.apache.iceberg.transforms.UnknownTransform
 
getSchema() - Method in class org.apache.iceberg.GenericManifestFile
 
getSchema() - Method in class org.apache.iceberg.GenericPartitionFieldSummary
 
getSchema(String, Job) - Method in class org.apache.iceberg.pig.IcebergStorage
 
getSchema() - Method in class org.apache.iceberg.util.Pair
 
getSplitOffsets(ParquetMetadata) - Static method in class org.apache.iceberg.parquet.ParquetUtil
 
getSplits(JobContext) - Method in class org.apache.iceberg.mr.mapreduce.IcebergInputFormat
 
getSplits(JobContext) - Method in class org.apache.iceberg.pig.IcebergPigInputFormat
 
getStat() - Method in class org.apache.iceberg.hadoop.HadoopInputFile
 
getStatistics(String, Job) - Method in class org.apache.iceberg.pig.IcebergStorage
 
getString(String, JsonNode) - Static method in class org.apache.iceberg.util.JsonUtil
 
getStringList(String, JsonNode) - Static method in class org.apache.iceberg.util.JsonUtil
 
getStringMap(String, JsonNode) - Static method in class org.apache.iceberg.util.JsonUtil
 
getStringOrNull(String, JsonNode) - Static method in class org.apache.iceberg.util.JsonUtil
 
getSupportedExpressionTypes() - Method in class org.apache.iceberg.pig.IcebergStorage
 
getType(Types.StructType) - Static method in interface org.apache.iceberg.DataFile
 
getType() - Static method in interface org.apache.iceberg.ManifestFile.PartitionFieldSummary
 
getValue() - Method in class org.apache.iceberg.parquet.ParquetValueReaders.ReusableEntry
 
getValueId(Schema) - Static method in class org.apache.iceberg.avro.AvroSchemaUtil
 
getWorkerPool() - Static method in class org.apache.iceberg.util.ThreadPools
Return an ExecutorService that uses the "worker" thread-pool.
greaterThan(String, T) - Static method in class org.apache.iceberg.expressions.Expressions
 
greaterThan(UnboundTerm<T>, T) - Static method in class org.apache.iceberg.expressions.Expressions
 
greaterThanOrEqual(String, T) - Static method in class org.apache.iceberg.expressions.Expressions
 
greaterThanOrEqual(UnboundTerm<T>, T) - Static method in class org.apache.iceberg.expressions.Expressions
 
gt(BoundReference<T>, Literal<T>) - Method in class org.apache.iceberg.expressions.ExpressionVisitors.BoundExpressionVisitor
Deprecated.
 
gt(Bound<T>, Literal<T>) - Method in class org.apache.iceberg.expressions.ExpressionVisitors.BoundVisitor
 
gtEq(BoundReference<T>, Literal<T>) - Method in class org.apache.iceberg.expressions.ExpressionVisitors.BoundExpressionVisitor
Deprecated.
 
gtEq(Bound<T>, Literal<T>) - Method in class org.apache.iceberg.expressions.ExpressionVisitors.BoundVisitor
 

H

HadoopCatalog - Class in org.apache.iceberg.hadoop
HadoopCatalog provides a way to use table names like db.table to work with path-based tables under a common location.
HadoopCatalog(Configuration, String) - Constructor for class org.apache.iceberg.hadoop.HadoopCatalog
The constructor of the HadoopCatalog.
HadoopCatalog(Configuration) - Constructor for class org.apache.iceberg.hadoop.HadoopCatalog
The constructor of the HadoopCatalog.
HadoopFileIO - Class in org.apache.iceberg.hadoop
 
HadoopFileIO(Configuration) - Constructor for class org.apache.iceberg.hadoop.HadoopFileIO
 
HadoopFileIO(SerializableSupplier<Configuration>) - Constructor for class org.apache.iceberg.hadoop.HadoopFileIO
 
HadoopInputFile - Class in org.apache.iceberg.hadoop
InputFile implementation using the Hadoop FileSystem API.
HadoopOutputFile - Class in org.apache.iceberg.hadoop
OutputFile implementation using the Hadoop FileSystem API.
HadoopTableOperations - Class in org.apache.iceberg.hadoop
TableOperations implementation for file systems that support atomic rename.
HadoopTableOperations(Path, Configuration) - Constructor for class org.apache.iceberg.hadoop.HadoopTableOperations
 
HadoopTables - Class in org.apache.iceberg.hadoop
Implementation of Iceberg tables that uses the Hadoop FileSystem to store metadata and manifests.
HadoopTables() - Constructor for class org.apache.iceberg.hadoop.HadoopTables
 
HadoopTables(Configuration) - Constructor for class org.apache.iceberg.hadoop.HadoopTables
 
hasAddedFiles() - Method in interface org.apache.iceberg.ManifestFile
Returns true if the manifest contains ADDED entries or if the count is not known.
hasDeletedFiles() - Method in interface org.apache.iceberg.ManifestFile
Returns true if the manifest contains DELETED entries or if the count is not known.
hasExistingFiles() - Method in interface org.apache.iceberg.ManifestFile
Returns true if the manifest contains EXISTING entries or if the count is not known.
hasFieldId(Schema.Field) - Static method in class org.apache.iceberg.avro.AvroSchemaUtil
 
hashCode() - Method in class org.apache.iceberg.catalog.Namespace
 
hashCode() - Method in class org.apache.iceberg.catalog.TableIdentifier
 
hashCode() - Method in class org.apache.iceberg.data.GenericRecord
 
hashCode() - Method in class org.apache.iceberg.GenericManifestFile
 
hashCode() - Method in class org.apache.iceberg.mapping.MappedField
 
hashCode() - Method in class org.apache.iceberg.mapping.MappedFields
 
hashCode() - Method in class org.apache.iceberg.MetricsModes.Truncate
 
hashCode() - Method in class org.apache.iceberg.PartitionField
 
hashCode() - Method in class org.apache.iceberg.PartitionSpec
 
hashCode() - Method in class org.apache.iceberg.TableMetadata.MetadataLogEntry
 
hashCode() - Method in class org.apache.iceberg.TableMetadata.SnapshotLogEntry
 
hashCode() - Method in class org.apache.iceberg.transforms.UnknownTransform
 
hashCode() - Method in class org.apache.iceberg.types.Types.DecimalType
 
hashCode() - Method in class org.apache.iceberg.types.Types.FixedType
 
hashCode() - Method in class org.apache.iceberg.types.Types.ListType
 
hashCode() - Method in class org.apache.iceberg.types.Types.MapType
 
hashCode() - Method in class org.apache.iceberg.types.Types.NestedField
 
hashCode() - Method in class org.apache.iceberg.types.Types.StructType
 
hashCode() - Method in class org.apache.iceberg.types.Types.TimestampType
 
hashCode() - Method in class org.apache.iceberg.util.CharSequenceWrapper
 
hashCode() - Method in class org.apache.iceberg.util.Pair
 
hashCode() - Method in class org.apache.iceberg.util.StructLikeWrapper
 
hasIds(MessageType) - Static method in class org.apache.iceberg.parquet.ParquetSchemaUtil
 
hasNamespace() - Method in class org.apache.iceberg.catalog.TableIdentifier
Whether the namespace is empty.
hasNext() - Method in class org.apache.iceberg.orc.VectorizedRowBatchIterator
 
hasNext() - Method in class org.apache.iceberg.parquet.BaseColumnIterator
 
hasNext - Variable in class org.apache.iceberg.parquet.BasePageIterator
 
hasNext() - Method in class org.apache.iceberg.parquet.BasePageIterator
 
hasNonDictionaryPages(ColumnChunkMetaData) - Static method in class org.apache.iceberg.parquet.ParquetUtil
 
hasNulls() - Method in class org.apache.iceberg.arrow.vectorized.NullabilityHolder
 
HasTableOperations - Interface in org.apache.iceberg
Used to expose a table's TableOperations.
hiddenImpl(Class<?>...) - Method in class org.apache.iceberg.common.DynConstructors.Builder
 
hiddenImpl(String, Class<?>...) - Method in class org.apache.iceberg.common.DynConstructors.Builder
 
hiddenImpl(Class<T>, Class<?>...) - Method in class org.apache.iceberg.common.DynConstructors.Builder
 
hiddenImpl(String, String) - Method in class org.apache.iceberg.common.DynFields.Builder
Checks for a hidden implementation, first finding the class by name.
hiddenImpl(Class<?>, String) - Method in class org.apache.iceberg.common.DynFields.Builder
Checks for a hidden implementation.
hiddenImpl(String, String, Class<?>...) - Method in class org.apache.iceberg.common.DynMethods.Builder
Checks for an implementation, first finding the given class by name.
hiddenImpl(String, Class<?>...) - Method in class org.apache.iceberg.common.DynMethods.Builder
Checks for an implementation, first finding the given class by name.
hiddenImpl(Class<?>, String, Class<?>...) - Method in class org.apache.iceberg.common.DynMethods.Builder
Checks for a method implementation.
hiddenImpl(Class<?>, Class<?>...) - Method in class org.apache.iceberg.common.DynMethods.Builder
Checks for a method implementation.
HiddenPathFilter - Class in org.apache.iceberg.hadoop
A PathFilter that filters out hidden paths.
history() - Method in class org.apache.iceberg.BaseTable
 
history() - Method in interface org.apache.iceberg.Table
Get the snapshot history of this table.
HistoryEntry - Interface in org.apache.iceberg
Table history entry.
HistoryTable - Class in org.apache.iceberg
A Table implementation that exposes a table's history as rows.
HistoryTable(TableOperations, Table) - Constructor for class org.apache.iceberg.HistoryTable
 
HiveCatalog - Class in org.apache.iceberg.hive
 
HiveCatalog(Configuration) - Constructor for class org.apache.iceberg.hive.HiveCatalog
 
HiveCatalogs - Class in org.apache.iceberg.hive
 
HiveClientPool - Class in org.apache.iceberg.hive
 
HiveClientPool(int, Configuration) - Constructor for class org.apache.iceberg.hive.HiveClientPool
 
HiveTableOperations - Class in org.apache.iceberg.hive
TODO we should be able to extract some more commonalities to BaseMetastoreTableOperations to avoid code duplication between this class and Metacat Tables.
HiveTableOperations(Configuration, HiveClientPool, String, String) - Constructor for class org.apache.iceberg.hive.HiveTableOperations
 
HiveTypeConverter - Class in org.apache.iceberg.hive
 
hour(String) - Static method in class org.apache.iceberg.expressions.Expressions
 
hour(String, String) - Method in class org.apache.iceberg.PartitionSpec.Builder
 
hour(String) - Method in class org.apache.iceberg.PartitionSpec.Builder
 
hour(String, int) - Method in interface org.apache.iceberg.transforms.PartitionSpecVisitor
 
hour(Type) - Static method in class org.apache.iceberg.transforms.Transforms
Returns a hour Transform for timestamps.

I

ICEBERG_BINARY_TYPE_ATTRIBUTE - Static variable in class org.apache.iceberg.orc.ORCSchemaUtil
The name of the ORC TypeDescription attribute indicating the Iceberg type corresponding to an ORC binary type.
ICEBERG_FIELD_NAME_PROP - Static variable in class org.apache.iceberg.avro.AvroSchemaUtil
 
ICEBERG_LONG_TYPE_ATTRIBUTE - Static variable in class org.apache.iceberg.orc.ORCSchemaUtil
The name of the ORC TypeDescription attribute indicating the Iceberg type corresponding to an ORC long type.
ICEBERG_TABLE_TYPE_VALUE - Static variable in class org.apache.iceberg.BaseMetastoreTableOperations
 
IcebergArrowVectors - Class in org.apache.iceberg.arrow.vectorized
The general way of getting a value at an index in the Arrow vector is by calling get(index).
IcebergArrowVectors() - Constructor for class org.apache.iceberg.arrow.vectorized.IcebergArrowVectors
 
IcebergArrowVectors.DecimalArrowVector - Class in org.apache.iceberg.arrow.vectorized
Extension of Arrow's @DecimalVector.
IcebergArrowVectors.VarBinaryArrowVector - Class in org.apache.iceberg.arrow.vectorized
Extension of Arrow's @VarBinaryVector.
IcebergArrowVectors.VarcharArrowVector - Class in org.apache.iceberg.arrow.vectorized
Extension of Arrow's @VarCharVector.
IcebergDecoder<D> - Class in org.apache.iceberg.data.avro
 
IcebergDecoder(Schema) - Constructor for class org.apache.iceberg.data.avro.IcebergDecoder
Creates a new decoder that constructs datum instances described by an Iceberg schema.
IcebergDecoder(Schema, SchemaStore) - Constructor for class org.apache.iceberg.data.avro.IcebergDecoder
Creates a new decoder that constructs datum instances described by an Iceberg schema.
IcebergEncoder<D> - Class in org.apache.iceberg.data.avro
 
IcebergEncoder(Schema) - Constructor for class org.apache.iceberg.data.avro.IcebergEncoder
Creates a new MessageEncoder that will deconstruct datum instances described by the schema.
IcebergEncoder(Schema, boolean) - Constructor for class org.apache.iceberg.data.avro.IcebergEncoder
Creates a new MessageEncoder that will deconstruct datum instances described by the schema.
IcebergGenerics - Class in org.apache.iceberg.data
 
IcebergGenerics.ScanBuilder - Class in org.apache.iceberg.data
 
IcebergInputFormat<T> - Class in org.apache.iceberg.mr.mapreduce
Generic Mrv2 InputFormat API for Iceberg.
IcebergInputFormat() - Constructor for class org.apache.iceberg.mr.mapreduce.IcebergInputFormat
 
IcebergInputFormat.ConfigBuilder - Class in org.apache.iceberg.mr.mapreduce
 
IcebergPigInputFormat<T> - Class in org.apache.iceberg.pig
 
IcebergPigInputFormat.IcebergRecordReader<T> - Class in org.apache.iceberg.pig
 
IcebergRecordReader() - Constructor for class org.apache.iceberg.pig.IcebergPigInputFormat.IcebergRecordReader
 
IcebergSource - Class in org.apache.iceberg.spark.source
 
IcebergSource() - Constructor for class org.apache.iceberg.spark.source.IcebergSource
 
IcebergStorage - Class in org.apache.iceberg.pig
 
IcebergStorage() - Constructor for class org.apache.iceberg.pig.IcebergStorage
 
id() - Method in class org.apache.iceberg.mapping.MappedField
 
id(String) - Method in class org.apache.iceberg.mapping.MappedFields
 
identity(String) - Method in class org.apache.iceberg.PartitionSpec.Builder
 
identity(String, int) - Method in interface org.apache.iceberg.transforms.PartitionSpecVisitor
 
identity(Type) - Static method in class org.apache.iceberg.transforms.Transforms
Returns an identity Transform that can be used for any type.
identitySourceIds() - Method in class org.apache.iceberg.PartitionSpec
Returns the source field ids for identity partitions.
idToAlias(Integer) - Method in class org.apache.iceberg.Schema
Returns the full column name in the unconverted data schema for the given column id.
impl(String) - Method in class org.apache.iceberg.common.DynClasses.Builder
Checks for an implementation of the class by name.
impl(String, Class<?>...) - Method in class org.apache.iceberg.common.DynConstructors.Builder
 
impl(Class<T>, Class<?>...) - Method in class org.apache.iceberg.common.DynConstructors.Builder
 
impl(String, String) - Method in class org.apache.iceberg.common.DynFields.Builder
Checks for an implementation, first finding the class by name.
impl(Class<?>, String) - Method in class org.apache.iceberg.common.DynFields.Builder
Checks for an implementation.
impl(String, String, Class<?>...) - Method in class org.apache.iceberg.common.DynMethods.Builder
Checks for an implementation, first finding the given class by name.
impl(String, Class<?>...) - Method in class org.apache.iceberg.common.DynMethods.Builder
Checks for an implementation, first finding the given class by name.
impl(Class<?>, String, Class<?>...) - Method in class org.apache.iceberg.common.DynMethods.Builder
Checks for a method implementation.
impl(Class<?>, Class<?>...) - Method in class org.apache.iceberg.common.DynMethods.Builder
Checks for a method implementation.
in(String, T...) - Static method in class org.apache.iceberg.expressions.Expressions
 
in(UnboundTerm<T>, T...) - Static method in class org.apache.iceberg.expressions.Expressions
 
in(String, Iterable<T>) - Static method in class org.apache.iceberg.expressions.Expressions
 
in(UnboundTerm<T>, Iterable<T>) - Static method in class org.apache.iceberg.expressions.Expressions
 
in(BoundReference<T>, Set<T>) - Method in class org.apache.iceberg.expressions.ExpressionVisitors.BoundExpressionVisitor
Deprecated.
 
in(Bound<T>, Set<T>) - Method in class org.apache.iceberg.expressions.ExpressionVisitors.BoundVisitor
 
in(Table) - Static method in class org.apache.iceberg.FindFiles
 
includeColumnStats() - Method in interface org.apache.iceberg.TableScan
Create a new TableScan from this that loads the column stats with each data file.
inclusive(PartitionSpec) - Static method in class org.apache.iceberg.expressions.Projections
Creates an inclusive ProjectionEvaluator for the spec, defaulting to case sensitive mode.
inclusive(PartitionSpec, boolean) - Static method in class org.apache.iceberg.expressions.Projections
Creates an inclusive ProjectionEvaluator for the spec.
InclusiveMetricsEvaluator - Class in org.apache.iceberg.expressions
Evaluates an Expression on a DataFile to test whether rows in the file may match.
InclusiveMetricsEvaluator(Schema, Expression) - Constructor for class org.apache.iceberg.expressions.InclusiveMetricsEvaluator
 
InclusiveMetricsEvaluator(Schema, Expression, boolean) - Constructor for class org.apache.iceberg.expressions.InclusiveMetricsEvaluator
 
incrementDuplicateDeletes() - Method in class org.apache.iceberg.SnapshotSummary.Builder
 
indexById(Types.StructType) - Static method in class org.apache.iceberg.types.TypeUtil
 
indexByLowerCaseName(Types.StructType) - Static method in class org.apache.iceberg.types.TypeUtil
 
IndexByName - Class in org.apache.iceberg.types
 
IndexByName() - Constructor for class org.apache.iceberg.types.IndexByName
 
indexByName(Types.StructType) - Static method in class org.apache.iceberg.types.TypeUtil
 
initDataReader(Encoding, ByteBufferInputStream, int) - Method in class org.apache.iceberg.arrow.vectorized.parquet.VectorizedPageIterator
 
initDataReader(Encoding, ByteBufferInputStream, int) - Method in class org.apache.iceberg.parquet.BasePageIterator
 
initDefinitionLevelsReader(DataPageV1, ColumnDescriptor, ByteBufferInputStream, int) - Method in class org.apache.iceberg.arrow.vectorized.parquet.VectorizedPageIterator
 
initDefinitionLevelsReader(DataPageV2, ColumnDescriptor) - Method in class org.apache.iceberg.arrow.vectorized.parquet.VectorizedPageIterator
 
initDefinitionLevelsReader(DataPageV1, ColumnDescriptor, ByteBufferInputStream, int) - Method in class org.apache.iceberg.parquet.BasePageIterator
 
initDefinitionLevelsReader(DataPageV2, ColumnDescriptor) - Method in class org.apache.iceberg.parquet.BasePageIterator
 
initFromPage(int, ByteBufferInputStream) - Method in class org.apache.iceberg.arrow.vectorized.parquet.BaseVectorizedParquetValuesReader
 
initFromPage(DataPageV1) - Method in class org.apache.iceberg.parquet.BasePageIterator
 
initFromPage(DataPageV2) - Method in class org.apache.iceberg.parquet.BasePageIterator
 
initFromPage(int, ByteBufferInputStream) - Method in class org.apache.iceberg.parquet.ValuesAsBytesReader
 
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.iceberg.pig.IcebergPigInputFormat.IcebergRecordReader
 
inPartition(PartitionSpec, StructLike) - Method in class org.apache.iceberg.FindFiles.Builder
Filter results to files in any one of the given partitions.
inPartitions(PartitionSpec, StructLike...) - Method in class org.apache.iceberg.FindFiles.Builder
Filter results to files in any one of the given partitions.
inPartitions(PartitionSpec, List<StructLike>) - Method in class org.apache.iceberg.FindFiles.Builder
Filter results to files in any one of the given partitions.
InputFile - Interface in org.apache.iceberg.io
An interface used to read input files using SeekableInputStream instances.
inSnapshot(long) - Method in class org.apache.iceberg.FindFiles.Builder
Base results on the given snapshot.
IntAsLongReader(ColumnDescriptor) - Constructor for class org.apache.iceberg.parquet.ParquetValueReaders.IntAsLongReader
 
IntegerAsDecimalReader(ColumnDescriptor, int) - Constructor for class org.apache.iceberg.parquet.ParquetValueReaders.IntegerAsDecimalReader
 
IntegerType() - Constructor for class org.apache.iceberg.types.Types.IntegerType
 
internalWrite(TableMetadata, OutputFile, boolean) - Static method in class org.apache.iceberg.TableMetadataParser
 
IntIterator() - Constructor for class org.apache.iceberg.parquet.BasePageIterator.IntIterator
 
ints() - Static method in class org.apache.iceberg.avro.ValueReaders
 
ints() - Static method in class org.apache.iceberg.avro.ValueWriters
 
invoke(Object, Object...) - Method in class org.apache.iceberg.common.DynConstructors.Ctor
 
invoke(Object...) - Method in class org.apache.iceberg.common.DynMethods.BoundMethod
 
invoke(Object...) - Method in class org.apache.iceberg.common.DynMethods.StaticMethod
 
invoke(Object, Object...) - Method in class org.apache.iceberg.common.DynMethods.UnboundMethod
 
invokeChecked(Object, Object...) - Method in class org.apache.iceberg.common.DynConstructors.Ctor
 
invokeChecked(Object...) - Method in class org.apache.iceberg.common.DynMethods.BoundMethod
 
invokeChecked(Object...) - Method in class org.apache.iceberg.common.DynMethods.StaticMethod
 
invokeChecked(Object, Object...) - Method in class org.apache.iceberg.common.DynMethods.UnboundMethod
 
io() - Method in class org.apache.iceberg.BaseTable
 
io() - Method in class org.apache.iceberg.hadoop.HadoopTableOperations
 
io() - Method in class org.apache.iceberg.hive.HiveTableOperations
 
io() - Method in interface org.apache.iceberg.Table
 
io() - Method in interface org.apache.iceberg.TableOperations
 
isAlwaysNull() - Method in class org.apache.iceberg.common.DynFields.UnboundField
 
isCaseSensitive() - Method in interface org.apache.iceberg.TableScan
Returns whether this scan should apply column name case sensitiveness as per TableScan.caseSensitive(boolean).
isCharHighSurrogate(char) - Static method in class org.apache.iceberg.util.UnicodeUtil
Determines if the given character value is a unicode high-surrogate code unit.
isDataTask() - Method in interface org.apache.iceberg.DataTask
 
isDataTask() - Method in interface org.apache.iceberg.ScanTask
 
isDictionaryEncoded() - Method in class org.apache.iceberg.arrow.vectorized.VectorHolder
 
isElementOptional() - Method in class org.apache.iceberg.types.Types.ListType
 
isElementRequired() - Method in class org.apache.iceberg.types.Types.ListType
 
isEmpty() - Method in class org.apache.iceberg.catalog.Namespace
 
isEmpty() - Method in class org.apache.iceberg.util.CharSequenceSet
 
isFileScanTask() - Method in interface org.apache.iceberg.FileScanTask
 
isFileScanTask() - Method in interface org.apache.iceberg.ScanTask
 
isIdentity() - Method in interface org.apache.iceberg.transforms.Transform
Return whether this transform is the identity transform.
isIntType(PrimitiveType) - Static method in class org.apache.iceberg.parquet.ParquetUtil
 
isListType() - Method in interface org.apache.iceberg.types.Type
 
isListType() - Method in class org.apache.iceberg.types.Types.ListType
 
isLiteralPredicate() - Method in class org.apache.iceberg.expressions.BoundLiteralPredicate
 
isLiteralPredicate() - Method in class org.apache.iceberg.expressions.BoundPredicate
 
isMapType() - Method in interface org.apache.iceberg.types.Type
 
isMapType() - Method in class org.apache.iceberg.types.Types.MapType
 
isNestedType() - Method in interface org.apache.iceberg.types.Type
 
isNestedType() - Method in class org.apache.iceberg.types.Type.NestedType
 
isNoop() - Method in class org.apache.iceberg.common.DynMethods.UnboundMethod
 
isNull(String) - Static method in class org.apache.iceberg.expressions.Expressions
 
isNull(UnboundTerm<T>) - Static method in class org.apache.iceberg.expressions.Expressions
 
isNull(BoundReference<T>) - Method in class org.apache.iceberg.expressions.ExpressionVisitors.BoundExpressionVisitor
Deprecated.
 
isNull(Bound<T>) - Method in class org.apache.iceberg.expressions.ExpressionVisitors.BoundVisitor
 
isNullAt(int) - Method in class org.apache.iceberg.arrow.vectorized.NullabilityHolder
 
isOptional() - Method in class org.apache.iceberg.types.Types.NestedField
 
isPrimitiveType() - Method in interface org.apache.iceberg.types.Type
 
isPrimitiveType() - Method in class org.apache.iceberg.types.Type.PrimitiveType
 
isPromotionAllowed(Type, Type.PrimitiveType) - Static method in class org.apache.iceberg.types.TypeUtil
 
isRequired() - Method in class org.apache.iceberg.types.Types.NestedField
 
isSet(int) - Method in class org.apache.iceberg.arrow.vectorized.IcebergArrowVectors.DecimalArrowVector
Same as BaseFixedWidthVector.isNull(int).
isSet(int) - Method in class org.apache.iceberg.arrow.vectorized.IcebergArrowVectors.VarBinaryArrowVector
Same as BaseVariableWidthVector.isNull(int).
isSet(int) - Method in class org.apache.iceberg.arrow.vectorized.IcebergArrowVectors.VarcharArrowVector
Same as BaseVariableWidthVector.isNull(int).
isSetPredicate() - Method in class org.apache.iceberg.expressions.BoundPredicate
 
isSetPredicate() - Method in class org.apache.iceberg.expressions.BoundSetPredicate
 
isSplittable() - Method in enum org.apache.iceberg.FileFormat
 
isStatic() - Method in class org.apache.iceberg.common.DynConstructors.Ctor
 
isStatic() - Method in class org.apache.iceberg.common.DynFields.UnboundField
 
isStatic() - Method in class org.apache.iceberg.common.DynMethods.UnboundMethod
 
isStructType() - Method in interface org.apache.iceberg.types.Type
 
isStructType() - Method in class org.apache.iceberg.types.Types.StructType
 
isTimestamptz(Schema) - Static method in class org.apache.iceberg.avro.AvroSchemaUtil
 
isUnaryPredicate() - Method in class org.apache.iceberg.expressions.BoundPredicate
 
isUnaryPredicate() - Method in class org.apache.iceberg.expressions.BoundUnaryPredicate
 
isValidIdentifier(TableIdentifier) - Method in class org.apache.iceberg.BaseMetastoreCatalog
 
isValidIdentifier(TableIdentifier) - Method in class org.apache.iceberg.hadoop.HadoopCatalog
 
isValidIdentifier(TableIdentifier) - Method in class org.apache.iceberg.hive.HiveCatalog
 
isValueOptional() - Method in class org.apache.iceberg.types.Types.MapType
 
isValueRequired() - Method in class org.apache.iceberg.types.Types.MapType
 
iterator() - Method in class org.apache.iceberg.avro.AvroIterable
 
iterator() - Method in class org.apache.iceberg.FilteredManifest
 
iterator() - Method in class org.apache.iceberg.io.CloseableIterable.ConcatCloseableIterable
 
iterator() - Method in class org.apache.iceberg.ManifestReader
 
iterator() - Method in class org.apache.iceberg.parquet.ParquetIterable
 
iterator() - Method in class org.apache.iceberg.parquet.ParquetReader
 
iterator() - Method in class org.apache.iceberg.parquet.VectorizedParquetReader
 
iterator() - Method in class org.apache.iceberg.util.BinPacking.PackingIterable
 
iterator() - Method in class org.apache.iceberg.util.CharSequenceSet
 
iterator() - Method in class org.apache.iceberg.util.ParallelIterable
 

J

javaClass() - Method in enum org.apache.iceberg.types.Type.TypeID
 
javaClasses() - Method in class org.apache.iceberg.PartitionSpec
 
join(Schema, Schema) - Static method in class org.apache.iceberg.types.TypeUtil
 
JsonUtil - Class in org.apache.iceberg.util
 

K

KEY_ID_PROP - Static variable in class org.apache.iceberg.avro.AvroSchemaUtil
 
keyId() - Method in class org.apache.iceberg.types.Types.MapType
 
keyMetadata() - Method in interface org.apache.iceberg.DataFile
 
keyMetadata() - Method in interface org.apache.iceberg.encryption.EncryptedInputFile
Metadata pointing to some encryption key that would be used to decrypt the input file provided by EncryptedInputFile.encryptedInputFile().
keyMetadata() - Method in interface org.apache.iceberg.encryption.EncryptedOutputFile
Metadata about the encryption key that is being used to encrypt the associated EncryptedOutputFile.encryptingOutputFile().
keyMetadata() - Method in class org.apache.iceberg.spark.SparkDataFile
 
keyType() - Method in class org.apache.iceberg.types.Types.MapType
 

L

lastColumnId() - Method in class org.apache.iceberg.TableMetadata
 
lastSequenceNumber() - Method in class org.apache.iceberg.TableMetadata
 
lastUpdatedMillis() - Method in class org.apache.iceberg.TableMetadata
 
lazyLength() - Method in class org.apache.iceberg.GenericManifestFile
 
left() - Method in class org.apache.iceberg.expressions.And
 
left() - Method in class org.apache.iceberg.expressions.Or
 
length() - Method in interface org.apache.iceberg.FileScanTask
The number of bytes to scan from the FileScanTask.start() position in the file.
length() - Method in class org.apache.iceberg.GenericManifestFile
 
length() - Method in interface org.apache.iceberg.io.FileAppender
 
LENGTH - Static variable in interface org.apache.iceberg.ManifestFile
 
length() - Method in interface org.apache.iceberg.ManifestFile
 
length() - Method in class org.apache.iceberg.ManifestWriter
 
length() - Method in class org.apache.iceberg.MetricsModes.Truncate
 
length() - Method in class org.apache.iceberg.parquet.ParquetWriteAdapter
 
length() - Method in class org.apache.iceberg.types.Types.FixedType
 
length() - Method in class org.apache.iceberg.util.CharSequenceWrapper
 
lessThan(String, T) - Static method in class org.apache.iceberg.expressions.Expressions
 
lessThan(UnboundTerm<T>, T) - Static method in class org.apache.iceberg.expressions.Expressions
 
lessThanOrEqual(String, T) - Static method in class org.apache.iceberg.expressions.Expressions
 
lessThanOrEqual(UnboundTerm<T>, T) - Static method in class org.apache.iceberg.expressions.Expressions
 
level(int) - Method in class org.apache.iceberg.catalog.Namespace
 
levels() - Method in class org.apache.iceberg.catalog.Namespace
 
limit(int) - Method in class org.apache.iceberg.ScanSummary.Builder
 
list(GroupType, T) - Method in class org.apache.iceberg.parquet.ParquetTypeVisitor
 
list(Types.ListType, Type.Repetition, int, String) - Method in class org.apache.iceberg.parquet.TypeToMessageType
 
list(Types.ListType, GroupType, T) - Method in class org.apache.iceberg.parquet.TypeWithSchemaVisitor
 
list(Types.ListType, Supplier<Type>) - Method in class org.apache.iceberg.spark.PruneColumnsWithoutReordering
 
list(Types.ListType, Supplier<Type>) - Method in class org.apache.iceberg.spark.PruneColumnsWithReordering
 
list(Types.ListType, Supplier<List<String>>) - Method in class org.apache.iceberg.types.CheckCompatibility
 
list(Types.ListType, Supplier<Map<String, Integer>>) - Method in class org.apache.iceberg.types.IndexByName
 
list(Types.ListType, Supplier<T>) - Method in class org.apache.iceberg.types.TypeUtil.CustomOrderSchemaVisitor
 
list(Types.ListType, T) - Method in class org.apache.iceberg.types.TypeUtil.SchemaVisitor
 
Listener<E> - Interface in org.apache.iceberg.events
A listener interface that can receive notifications.
Listeners - Class in org.apache.iceberg.events
Static registration and notification for listeners.
listNamespaces() - Method in interface org.apache.iceberg.catalog.SupportsNamespaces
List top-level namespaces from the catalog.
listNamespaces(Namespace) - Method in interface org.apache.iceberg.catalog.SupportsNamespaces
List namespaces from the namespace.
listNamespaces(Namespace) - Method in class org.apache.iceberg.hadoop.HadoopCatalog
 
listNamespaces(Namespace) - Method in class org.apache.iceberg.hive.HiveCatalog
 
ListPacker(long, int, boolean) - Constructor for class org.apache.iceberg.util.BinPacking.ListPacker
 
ListReader(int, int, ParquetValueReader<E>) - Constructor for class org.apache.iceberg.parquet.ParquetValueReaders.ListReader
 
listTables(Namespace) - Method in class org.apache.iceberg.CachingCatalog
 
listTables(Namespace) - Method in interface org.apache.iceberg.catalog.Catalog
Return all the identifiers under this namespace.
listTables(Namespace) - Method in class org.apache.iceberg.hadoop.HadoopCatalog
 
listTables(Namespace) - Method in class org.apache.iceberg.hive.HiveCatalog
 
literal() - Method in class org.apache.iceberg.expressions.BoundLiteralPredicate
 
Literal<T> - Interface in org.apache.iceberg.expressions
Represents a literal fixed value in an expression predicate
literal() - Method in class org.apache.iceberg.expressions.UnboundPredicate
 
literals() - Method in class org.apache.iceberg.expressions.UnboundPredicate
 
literalSet() - Method in class org.apache.iceberg.expressions.BoundSetPredicate
 
load(String) - Method in class org.apache.iceberg.hadoop.HadoopTables
Loads the table location from a FileSystem path location.
load(String) - Method in interface org.apache.iceberg.Tables
 
loadCatalog(Configuration) - Static method in class org.apache.iceberg.hive.HiveCatalogs
 
loader(ClassLoader) - Method in class org.apache.iceberg.common.DynClasses.Builder
Set the ClassLoader used to lookup classes by name.
loader(ClassLoader) - Method in class org.apache.iceberg.common.DynConstructors.Builder
Set the ClassLoader used to lookup classes by name.
loader(ClassLoader) - Method in class org.apache.iceberg.common.DynFields.Builder
Set the ClassLoader used to lookup classes by name.
loader(ClassLoader) - Method in class org.apache.iceberg.common.DynMethods.Builder
Set the ClassLoader used to lookup classes by name.
loadNamespaceMetadata(Namespace) - Method in interface org.apache.iceberg.catalog.SupportsNamespaces
Load metadata properties for a namespace.
loadNamespaceMetadata(Namespace) - Method in class org.apache.iceberg.hadoop.HadoopCatalog
 
loadNamespaceMetadata(Namespace) - Method in class org.apache.iceberg.hive.HiveCatalog
 
loadTable(TableIdentifier) - Method in class org.apache.iceberg.BaseMetastoreCatalog
 
loadTable(TableIdentifier) - Method in class org.apache.iceberg.CachingCatalog
 
loadTable(TableIdentifier) - Method in interface org.apache.iceberg.catalog.Catalog
Load a table.
localInput(File) - Static method in class org.apache.iceberg.Files
 
localInput(String) - Static method in class org.apache.iceberg.Files
 
localOutput(File) - Static method in class org.apache.iceberg.Files
 
localOutput(String) - Static method in class org.apache.iceberg.Files
 
location(String) - Method in class org.apache.iceberg.actions.RemoveOrphanFilesAction
Removes orphan files in the given location.
location() - Method in class org.apache.iceberg.BaseTable
 
location(String) - Method in class org.apache.iceberg.FileHistory.Builder
 
location() - Method in class org.apache.iceberg.hadoop.HadoopInputFile
 
location() - Method in class org.apache.iceberg.hadoop.HadoopOutputFile
 
location() - Method in interface org.apache.iceberg.io.InputFile
The fully-qualified location of the input file as a String.
location() - Method in interface org.apache.iceberg.io.OutputFile
Return the location this output file will create.
location() - Method in interface org.apache.iceberg.Table
Return the table's base location.
location() - Method in class org.apache.iceberg.TableMetadata
 
locationProvider() - Method in class org.apache.iceberg.BaseMetastoreTableOperations
 
locationProvider() - Method in class org.apache.iceberg.BaseTable
 
locationProvider() - Method in class org.apache.iceberg.hadoop.HadoopTableOperations
 
LocationProvider - Interface in org.apache.iceberg.io
Interface for providing data file locations to write tasks.
locationProvider() - Method in interface org.apache.iceberg.Table
 
locationProvider() - Method in interface org.apache.iceberg.TableOperations
Returns a LocationProvider that supplies locations for new new data files.
LocationProviders - Class in org.apache.iceberg
 
locationsFor(String, Map<String, String>) - Static method in class org.apache.iceberg.LocationProviders
 
LogicalMap - Class in org.apache.iceberg.avro
 
LongAsDecimalReader(ColumnDescriptor, int) - Constructor for class org.apache.iceberg.parquet.ParquetValueReaders.LongAsDecimalReader
 
longs() - Static method in class org.apache.iceberg.avro.ValueReaders
 
longs() - Static method in class org.apache.iceberg.avro.ValueWriters
 
LongType() - Constructor for class org.apache.iceberg.types.Types.LongType
 
lowerBound() - Method in class org.apache.iceberg.GenericPartitionFieldSummary
 
lowerBound() - Method in interface org.apache.iceberg.ManifestFile.PartitionFieldSummary
 
lowerBounds() - Method in interface org.apache.iceberg.DataFile
 
lowerBounds() - Method in class org.apache.iceberg.Metrics
Get the non-null lower bound values for all fields in a file.
lowerBounds() - Method in class org.apache.iceberg.spark.SparkDataFile
 
lt(BoundReference<T>, Literal<T>) - Method in class org.apache.iceberg.expressions.ExpressionVisitors.BoundExpressionVisitor
Deprecated.
 
lt(Bound<T>, Literal<T>) - Method in class org.apache.iceberg.expressions.ExpressionVisitors.BoundVisitor
 
ltEq(BoundReference<T>, Literal<T>) - Method in class org.apache.iceberg.expressions.ExpressionVisitors.BoundExpressionVisitor
Deprecated.
 
ltEq(Bound<T>, Literal<T>) - Method in class org.apache.iceberg.expressions.ExpressionVisitors.BoundVisitor
 

M

makeColumnOptional(String) - Method in interface org.apache.iceberg.UpdateSchema
Update a column to optional.
makeCompatibleName(String) - Static method in class org.apache.iceberg.avro.AvroSchemaUtil
 
manageSnapshots() - Method in class org.apache.iceberg.BaseTable
 
ManageSnapshots - Interface in org.apache.iceberg
API for managing snapshots.
manageSnapshots() - Method in interface org.apache.iceberg.Table
Create a new manage snapshots API to manage snapshots in this table and commit.
MANIFEST_LISTS_ENABLED - Static variable in class org.apache.iceberg.TableProperties
 
MANIFEST_LISTS_ENABLED_DEFAULT - Static variable in class org.apache.iceberg.TableProperties
 
MANIFEST_MERGE_ENABLED - Static variable in class org.apache.iceberg.TableProperties
 
MANIFEST_MERGE_ENABLED_DEFAULT - Static variable in class org.apache.iceberg.TableProperties
 
MANIFEST_MIN_MERGE_COUNT - Static variable in class org.apache.iceberg.TableProperties
 
MANIFEST_MIN_MERGE_COUNT_DEFAULT - Static variable in class org.apache.iceberg.TableProperties
 
MANIFEST_TARGET_SIZE_BYTES - Static variable in class org.apache.iceberg.TableProperties
 
MANIFEST_TARGET_SIZE_BYTES_DEFAULT - Static variable in class org.apache.iceberg.TableProperties
 
ManifestEntriesTable - Class in org.apache.iceberg
A Table implementation that exposes a table's manifest entries as rows.
ManifestEntriesTable(TableOperations, Table) - Constructor for class org.apache.iceberg.ManifestEntriesTable
 
ManifestEvaluator - Class in org.apache.iceberg.expressions
Evaluates an Expression on a ManifestFile to test whether the file contains matching partitions.
ManifestFile - Interface in org.apache.iceberg
Represents a manifest file that can be scanned to find data files in a table.
ManifestFile.PartitionFieldSummary - Interface in org.apache.iceberg
Summarizes the values of one partition field stored in a manifest file.
ManifestFiles - Class in org.apache.iceberg
 
ManifestFileUtil - Class in org.apache.iceberg.util
 
manifestListLocation() - Method in interface org.apache.iceberg.Snapshot
Return the location of this snapshot's manifest list, or null if it is not separate.
ManifestReader - Class in org.apache.iceberg
Reader for manifest files.
manifests() - Method in interface org.apache.iceberg.Snapshot
Return the location of all manifests in this snapshot.
ManifestsTable - Class in org.apache.iceberg
A Table implementation that exposes a table's manifest files as rows.
ManifestsTable(TableOperations, Table) - Constructor for class org.apache.iceberg.ManifestsTable
 
ManifestWriter - Class in org.apache.iceberg
Writer for manifest files.
map(Schema, T) - Method in class org.apache.iceberg.avro.AvroSchemaVisitor
 
map(Types.MapType, Schema, T, T) - Method in class org.apache.iceberg.avro.AvroSchemaWithTypeVisitor
 
map(Types.MapType, Schema, T) - Method in class org.apache.iceberg.avro.AvroSchemaWithTypeVisitor
 
map(ValueReader<K>, ValueReader<V>) - Static method in class org.apache.iceberg.avro.ValueReaders
 
map(ValueWriter<K>, ValueWriter<V>) - Static method in class org.apache.iceberg.avro.ValueWriters
 
map(GroupType, T, T) - Method in class org.apache.iceberg.parquet.ParquetTypeVisitor
 
map(Types.MapType, Type.Repetition, int, String) - Method in class org.apache.iceberg.parquet.TypeToMessageType
 
map(Types.MapType, GroupType, T, T) - Method in class org.apache.iceberg.parquet.TypeWithSchemaVisitor
 
map(Types.MapType, Supplier<Type>, Supplier<Type>) - Method in class org.apache.iceberg.spark.PruneColumnsWithoutReordering
 
map(Types.MapType, Supplier<Type>, Supplier<Type>) - Method in class org.apache.iceberg.spark.PruneColumnsWithReordering
 
map(Types.MapType, Supplier<List<String>>, Supplier<List<String>>) - Method in class org.apache.iceberg.types.CheckCompatibility
 
map(Types.MapType, Supplier<Map<String, Integer>>, Supplier<Map<String, Integer>>) - Method in class org.apache.iceberg.types.IndexByName
 
map(Types.MapType, Supplier<T>, Supplier<T>) - Method in class org.apache.iceberg.types.TypeUtil.CustomOrderSchemaVisitor
 
map(Types.MapType, T, T) - Method in class org.apache.iceberg.types.TypeUtil.SchemaVisitor
 
MappedField - Class in org.apache.iceberg.mapping
An immutable mapping between a field ID and a set of names.
MappedFields - Class in org.apache.iceberg.mapping
 
mapper() - Static method in class org.apache.iceberg.util.JsonUtil
 
MappingUtil - Class in org.apache.iceberg.mapping
 
MapReader(int, int, ParquetValueReader<K>, ParquetValueReader<V>) - Constructor for class org.apache.iceberg.parquet.ParquetValueReaders.MapReader
 
maps(int, int, ParquetValueWriter<K>, ParquetValueWriter<V>) - Static method in class org.apache.iceberg.parquet.ParquetValueWriters
 
merge(SnapshotSummary.Builder) - Method in class org.apache.iceberg.SnapshotSummary.Builder
 
message(MessageType, List<T>) - Method in class org.apache.iceberg.parquet.ParquetTypeVisitor
 
message(Types.StructType, MessageType, List<T>) - Method in class org.apache.iceberg.parquet.TypeWithSchemaVisitor
 
meta(String, String) - Method in class org.apache.iceberg.avro.Avro.WriteBuilder
 
meta(Map<String, String>) - Method in class org.apache.iceberg.avro.Avro.WriteBuilder
 
meta(String, String) - Method in class org.apache.iceberg.parquet.Parquet.WriteBuilder
 
metadata(String, String) - Method in class org.apache.iceberg.orc.ORC.WriteBuilder
 
METADATA_COMPRESSION - Static variable in class org.apache.iceberg.TableProperties
 
METADATA_COMPRESSION_DEFAULT - Static variable in class org.apache.iceberg.TableProperties
 
METADATA_DELETE_AFTER_COMMIT_ENABLED - Static variable in class org.apache.iceberg.TableProperties
 
METADATA_DELETE_AFTER_COMMIT_ENABLED_DEFAULT - Static variable in class org.apache.iceberg.TableProperties
 
METADATA_LOCATION_PROP - Static variable in class org.apache.iceberg.BaseMetastoreTableOperations
 
METADATA_PREVIOUS_VERSIONS_MAX - Static variable in class org.apache.iceberg.TableProperties
 
METADATA_PREVIOUS_VERSIONS_MAX_DEFAULT - Static variable in class org.apache.iceberg.TableProperties
 
METADATA_SPLIT_SIZE - Static variable in class org.apache.iceberg.TableProperties
 
METADATA_SPLIT_SIZE_DEFAULT - Static variable in class org.apache.iceberg.TableProperties
 
metadataFileLocation(String) - Method in class org.apache.iceberg.BaseMetastoreTableOperations
 
metadataFileLocation(String) - Method in class org.apache.iceberg.hadoop.HadoopTableOperations
 
metadataFileLocation(String) - Method in interface org.apache.iceberg.TableOperations
Given the name of a metadata file, obtain the full path of that file using an appropriate base location of the implementation's choosing.
MetadataTableType - Enum in org.apache.iceberg
 
metrics() - Method in interface org.apache.iceberg.io.FileAppender
 
metrics() - Method in class org.apache.iceberg.ManifestWriter
 
Metrics - Class in org.apache.iceberg
Iceberg file format metrics.
Metrics() - Constructor for class org.apache.iceberg.Metrics
 
Metrics(Long, Map<Integer, Long>, Map<Integer, Long>, Map<Integer, Long>) - Constructor for class org.apache.iceberg.Metrics
 
Metrics(Long, Map<Integer, Long>, Map<Integer, Long>, Map<Integer, Long>, Map<Integer, ByteBuffer>, Map<Integer, ByteBuffer>) - Constructor for class org.apache.iceberg.Metrics
 
metrics() - Method in class org.apache.iceberg.parquet.ParquetWriteAdapter
 
METRICS_MODE_COLUMN_CONF_PREFIX - Static variable in class org.apache.iceberg.TableProperties
 
MetricsConfig - Class in org.apache.iceberg
 
metricsConfig(MetricsConfig) - Method in class org.apache.iceberg.parquet.Parquet.WriteBuilder
 
MetricsModes - Class in org.apache.iceberg
This class defines different metrics modes, which allow users to control the collection of value_counts, null_value_counts, lower_bounds, upper_bounds for different columns in metadata.
MetricsModes.Counts - Class in org.apache.iceberg
Under this mode, only value_counts, null_value_counts are persisted.
MetricsModes.Full - Class in org.apache.iceberg
Under this mode, value_counts, null_value_counts and full lower_bounds, upper_bounds are persisted.
MetricsModes.MetricsMode - Interface in org.apache.iceberg
 
MetricsModes.None - Class in org.apache.iceberg
Under this mode, value_counts, null_value_counts, lower_bounds, upper_bounds are not persisted.
MetricsModes.Truncate - Class in org.apache.iceberg
Under this mode, value_counts, null_value_counts and truncated lower_bounds, upper_bounds are persisted.
MIN_SEQUENCE_NUMBER - Static variable in interface org.apache.iceberg.ManifestFile
 
minSequenceNumber() - Method in class org.apache.iceberg.GenericManifestFile
 
minSequenceNumber() - Method in interface org.apache.iceberg.ManifestFile
 
month(String) - Static method in class org.apache.iceberg.expressions.Expressions
 
month(String, String) - Method in class org.apache.iceberg.PartitionSpec.Builder
 
month(String) - Method in class org.apache.iceberg.PartitionSpec.Builder
 
month(String, int) - Method in interface org.apache.iceberg.transforms.PartitionSpecVisitor
 
month(Type) - Static method in class org.apache.iceberg.transforms.Transforms
Returns a month Transform for date or timestamp types.

N

name() - Method in class org.apache.iceberg.BaseMetastoreCatalog
 
name() - Method in class org.apache.iceberg.catalog.TableIdentifier
 
name() - Method in class org.apache.iceberg.expressions.NamedReference
 
name() - Method in class org.apache.iceberg.hadoop.HadoopCatalog
 
name() - Method in class org.apache.iceberg.hive.HiveCatalog
 
name() - Method in class org.apache.iceberg.PartitionField
 
name() - Method in class org.apache.iceberg.types.Types.NestedField
 
named(String) - Method in class org.apache.iceberg.avro.Avro.WriteBuilder
 
named(String) - Method in class org.apache.iceberg.parquet.Parquet.WriteBuilder
 
NamedReference<T> - Class in org.apache.iceberg.expressions
 
nameMapping(NameMapping) - Method in class org.apache.iceberg.avro.Avro.ReadBuilder
 
NameMapping - Class in org.apache.iceberg.mapping
Represents a mapping from external schema names to Iceberg type IDs.
NameMappingParser - Class in org.apache.iceberg.mapping
Parses external name mappings from a JSON representation.
names() - Method in class org.apache.iceberg.mapping.MappedField
 
Namespace - Class in org.apache.iceberg.catalog
A namespace in a Catalog.
namespace() - Method in class org.apache.iceberg.catalog.TableIdentifier
 
namespaceExists(Namespace) - Method in interface org.apache.iceberg.catalog.SupportsNamespaces
Checks whether the Namespace exists.
NamespaceNotEmptyException - Exception in org.apache.iceberg.exceptions
Exception raised when attempting to drop a namespace that is not empty.
NamespaceNotEmptyException(String, Object...) - Constructor for exception org.apache.iceberg.exceptions.NamespaceNotEmptyException
 
NamespaceNotEmptyException(Throwable, String, Object...) - Constructor for exception org.apache.iceberg.exceptions.NamespaceNotEmptyException
 
negate() - Method in class org.apache.iceberg.expressions.And
 
negate() - Method in class org.apache.iceberg.expressions.BoundSetPredicate
 
negate() - Method in interface org.apache.iceberg.expressions.Expression
 
negate() - Method in enum org.apache.iceberg.expressions.Expression.Operation
 
negate() - Method in class org.apache.iceberg.expressions.False
 
negate() - Method in class org.apache.iceberg.expressions.Not
 
negate() - Method in class org.apache.iceberg.expressions.Or
 
negate() - Method in class org.apache.iceberg.expressions.True
 
negate() - Method in class org.apache.iceberg.expressions.UnboundPredicate
 
nestedMapping() - Method in class org.apache.iceberg.mapping.MappedField
 
NestedType() - Constructor for class org.apache.iceberg.types.Type.NestedType
 
newAppend() - Method in class org.apache.iceberg.BaseTable
 
newAppend() - Method in interface org.apache.iceberg.Table
Create a new append API to add files to this table and commit.
newAppend() - Method in interface org.apache.iceberg.Transaction
Create a new append API to add files to this table.
newAppender(PartitionSpec, OutputFile) - Method in class org.apache.iceberg.ManifestWriter
 
newClient() - Method in class org.apache.iceberg.hive.ClientPool
 
newClient() - Method in class org.apache.iceberg.hive.HiveClientPool
 
newCreateTableTransaction(TableIdentifier, Schema, PartitionSpec, String, Map<String, String>) - Method in class org.apache.iceberg.BaseMetastoreCatalog
 
newCreateTableTransaction(TableIdentifier, Schema, PartitionSpec, String, Map<String, String>) - Method in class org.apache.iceberg.CachingCatalog
 
newCreateTableTransaction(TableIdentifier, Schema, PartitionSpec, String, Map<String, String>) - Method in interface org.apache.iceberg.catalog.Catalog
Start a transaction to create a table.
newCreateTableTransaction(TableIdentifier, Schema, PartitionSpec, Map<String, String>) - Method in interface org.apache.iceberg.catalog.Catalog
Start a transaction to create a table.
newCreateTableTransaction(TableIdentifier, Schema, PartitionSpec) - Method in interface org.apache.iceberg.catalog.Catalog
Start a transaction to create a table.
newCreateTableTransaction(TableIdentifier, Schema) - Method in interface org.apache.iceberg.catalog.Catalog
Start a transaction to create a table.
newDataLocation(String) - Method in interface org.apache.iceberg.io.LocationProvider
Return a fully-qualified data file location for the given filename.
newDataLocation(PartitionSpec, StructLike, String) - Method in interface org.apache.iceberg.io.LocationProvider
Return a fully-qualified data file location for the given partition and filename.
newDelete() - Method in class org.apache.iceberg.BaseTable
 
newDelete() - Method in interface org.apache.iceberg.Table
Create a new delete API to replace files in this table and commit.
newDelete() - Method in interface org.apache.iceberg.Transaction
Create a new delete API to replace files in this table.
newFastAppend() - Method in class org.apache.iceberg.BaseTable
 
newFastAppend() - Method in interface org.apache.iceberg.Table
Create a new append API to add files to this table and commit.
newFastAppend() - Method in interface org.apache.iceberg.Transaction
Create a new append API to add files to this table.
newInputFile(String) - Method in class org.apache.iceberg.hadoop.HadoopFileIO
 
newInputFile(String) - Method in interface org.apache.iceberg.io.FileIO
Get a InputFile instance to read bytes from the file at the given path.
newInstance(Object...) - Method in class org.apache.iceberg.common.DynConstructors.Ctor
 
newInstanceChecked(Object...) - Method in class org.apache.iceberg.common.DynConstructors.Ctor
 
newListData(List<E>) - Method in class org.apache.iceberg.parquet.ParquetValueReaders.ListReader
 
newListData(T) - Method in class org.apache.iceberg.parquet.ParquetValueReaders.RepeatedReader
 
newMapData(Map<K, V>) - Method in class org.apache.iceberg.parquet.ParquetValueReaders.MapReader
 
newMapData(M) - Method in class org.apache.iceberg.parquet.ParquetValueReaders.RepeatedKeyValueReader
 
newOutputFile(String) - Method in class org.apache.iceberg.hadoop.HadoopFileIO
 
newOutputFile(String) - Method in interface org.apache.iceberg.io.FileIO
Get a OutputFile instance to write bytes to the file at the given path.
newOverwrite() - Method in class org.apache.iceberg.BaseTable
 
newOverwrite() - Method in interface org.apache.iceberg.Table
Create a new overwrite API to overwrite files by a filter expression.
newOverwrite() - Method in interface org.apache.iceberg.Transaction
Create a new overwrite API to overwrite files by a filter expression.
newRefinedScan(TableOperations, Table, Long, Schema, Expression, boolean, boolean, Collection<String>, ImmutableMap<String, String>) - Method in class org.apache.iceberg.AllDataFilesTable.AllDataFilesTableScan
 
newRefinedScan(TableOperations, Table, Long, Schema, Expression, boolean, boolean, Collection<String>, ImmutableMap<String, String>) - Method in class org.apache.iceberg.AllManifestsTable.AllManifestsTableScan
 
newRefinedScan(TableOperations, Table, Long, Schema, Expression, boolean, boolean, Collection<String>, ImmutableMap<String, String>) - Method in class org.apache.iceberg.DataFilesTable.FilesTableScan
 
newRefinedScan(TableOperations, Table, Long, Schema, Expression, boolean, boolean, Collection<String>, ImmutableMap<String, String>) - Method in class org.apache.iceberg.DataTableScan
 
newReplacePartitions() - Method in class org.apache.iceberg.BaseTable
 
newReplacePartitions() - Method in interface org.apache.iceberg.Table
Not recommended: Create a new replace partitions API to dynamically overwrite partitions in the table with new data.
newReplacePartitions() - Method in interface org.apache.iceberg.Transaction
Not recommended: Create a new replace partitions API to dynamically overwrite partitions in the table with new data.
newReplaceTableTransaction(TableIdentifier, Schema, PartitionSpec, String, Map<String, String>, boolean) - Method in class org.apache.iceberg.BaseMetastoreCatalog
 
newReplaceTableTransaction(TableIdentifier, Schema, PartitionSpec, String, Map<String, String>, boolean) - Method in class org.apache.iceberg.CachingCatalog
 
newReplaceTableTransaction(TableIdentifier, Schema, PartitionSpec, String, Map<String, String>, boolean) - Method in interface org.apache.iceberg.catalog.Catalog
Start a transaction to replace a table.
newReplaceTableTransaction(TableIdentifier, Schema, PartitionSpec, Map<String, String>, boolean) - Method in interface org.apache.iceberg.catalog.Catalog
Start a transaction to replace a table.
newReplaceTableTransaction(TableIdentifier, Schema, PartitionSpec, boolean) - Method in interface org.apache.iceberg.catalog.Catalog
Start a transaction to replace a table.
newReplaceTableTransaction(TableIdentifier, Schema, boolean) - Method in interface org.apache.iceberg.catalog.Catalog
Start a transaction to replace a table.
newRewrite() - Method in class org.apache.iceberg.BaseTable
 
newRewrite() - Method in interface org.apache.iceberg.Table
Create a new rewrite API to replace files in this table and commit.
newRewrite() - Method in interface org.apache.iceberg.Transaction
Create a new rewrite API to replace files in this table.
newScan() - Method in class org.apache.iceberg.AllDataFilesTable
 
newScan() - Method in class org.apache.iceberg.AllEntriesTable
 
newScan() - Method in class org.apache.iceberg.AllManifestsTable
 
newScan() - Method in class org.apache.iceberg.BaseTable
 
newScan() - Method in class org.apache.iceberg.DataFilesTable
 
newScan() - Method in class org.apache.iceberg.HistoryTable
 
newScan() - Method in class org.apache.iceberg.ManifestEntriesTable
 
newScan() - Method in class org.apache.iceberg.ManifestsTable
 
newScan() - Method in class org.apache.iceberg.PartitionsTable
 
newScan() - Method in class org.apache.iceberg.SnapshotsTable
 
newScan() - Method in interface org.apache.iceberg.Table
Create a new scan for this table.
newSnapshotId() - Method in interface org.apache.iceberg.TableOperations
Create a new ID for a Snapshot
newStream() - Method in class org.apache.iceberg.hadoop.HadoopInputFile
 
newStream() - Method in interface org.apache.iceberg.io.InputFile
Opens a new SeekableInputStream for the underlying data file
newStructData(T) - Method in class org.apache.iceberg.parquet.ParquetValueReaders.StructReader
 
newTableMetadata(TableOperations, Schema, PartitionSpec, String, Map<String, String>) - Static method in class org.apache.iceberg.TableMetadata
Deprecated.
will be removed in 0.9.0; use newTableMetadata(Schema, PartitionSpec, String, Map) instead.
newTableMetadata(Schema, PartitionSpec, String, Map<String, String>) - Static method in class org.apache.iceberg.TableMetadata
 
newTableOps(TableIdentifier) - Method in class org.apache.iceberg.BaseMetastoreCatalog
 
newTableOps(TableIdentifier) - Method in class org.apache.iceberg.hadoop.HadoopCatalog
 
newTableOps(TableIdentifier) - Method in class org.apache.iceberg.hive.HiveCatalog
 
newTransaction() - Method in class org.apache.iceberg.BaseTable
 
newTransaction() - Method in interface org.apache.iceberg.Table
Create a new transaction API to commit multiple table operations at once.
newTransaction(TableOperations) - Static method in class org.apache.iceberg.Transactions
 
next() - Method in class org.apache.iceberg.orc.VectorizedRowBatchIterator
 
nextBatchBoolean(FieldVector, NullabilityHolder) - Method in class org.apache.iceberg.arrow.vectorized.parquet.VectorizedColumnIterator
 
nextBatchBoolean(FieldVector, int, int, NullabilityHolder) - Method in class org.apache.iceberg.arrow.vectorized.parquet.VectorizedPageIterator
Method for reading batches of booleans.
nextBatchDictionaryIds(IntVector, NullabilityHolder) - Method in class org.apache.iceberg.arrow.vectorized.parquet.VectorizedColumnIterator
 
nextBatchDictionaryIds(IntVector, int, int, NullabilityHolder) - Method in class org.apache.iceberg.arrow.vectorized.parquet.VectorizedPageIterator
Method for reading a batch of dictionary ids from the dicitonary encoded data pages.
nextBatchDoubles(FieldVector, int, NullabilityHolder) - Method in class org.apache.iceberg.arrow.vectorized.parquet.VectorizedColumnIterator
 
nextBatchDoubles(FieldVector, int, int, int, NullabilityHolder) - Method in class org.apache.iceberg.arrow.vectorized.parquet.VectorizedPageIterator
Method for reading a batch of values of DOUBLE data type
nextBatchFixedLengthDecimal(FieldVector, int, NullabilityHolder) - Method in class org.apache.iceberg.arrow.vectorized.parquet.VectorizedColumnIterator
 
nextBatchFixedLengthDecimal(FieldVector, int, int, int, NullabilityHolder) - Method in class org.apache.iceberg.arrow.vectorized.parquet.VectorizedPageIterator
Method for reading a batch of decimals backed by fixed length byte array parquet data type.
nextBatchFixedWidthBinary(FieldVector, int, NullabilityHolder) - Method in class org.apache.iceberg.arrow.vectorized.parquet.VectorizedColumnIterator
 
nextBatchFixedWidthBinary(FieldVector, int, int, int, NullabilityHolder) - Method in class org.apache.iceberg.arrow.vectorized.parquet.VectorizedPageIterator
Method for reading batches of fixed width binary type (e.g.
nextBatchFloats(FieldVector, int, NullabilityHolder) - Method in class org.apache.iceberg.arrow.vectorized.parquet.VectorizedColumnIterator
 
nextBatchFloats(FieldVector, int, int, int, NullabilityHolder) - Method in class org.apache.iceberg.arrow.vectorized.parquet.VectorizedPageIterator
Method for reading a batch of values of FLOAT data type.
nextBatchIntegers(FieldVector, int, NullabilityHolder) - Method in class org.apache.iceberg.arrow.vectorized.parquet.VectorizedColumnIterator
 
nextBatchIntegers(FieldVector, int, int, int, NullabilityHolder) - Method in class org.apache.iceberg.arrow.vectorized.parquet.VectorizedPageIterator
Method for reading a batch of values of INT32 data type
nextBatchIntLongBackedDecimal(FieldVector, int, NullabilityHolder) - Method in class org.apache.iceberg.arrow.vectorized.parquet.VectorizedColumnIterator
 
nextBatchIntLongBackedDecimal(FieldVector, int, int, int, NullabilityHolder) - Method in class org.apache.iceberg.arrow.vectorized.parquet.VectorizedPageIterator
Method for reading a batch of decimals backed by INT32 and INT64 parquet data types.
nextBatchLongs(FieldVector, int, NullabilityHolder) - Method in class org.apache.iceberg.arrow.vectorized.parquet.VectorizedColumnIterator
 
nextBatchLongs(FieldVector, int, int, int, NullabilityHolder) - Method in class org.apache.iceberg.arrow.vectorized.parquet.VectorizedPageIterator
Method for reading a batch of values of INT64 data type
nextBatchTimestampMillis(FieldVector, int, NullabilityHolder) - Method in class org.apache.iceberg.arrow.vectorized.parquet.VectorizedColumnIterator
 
nextBatchTimestampMillis(FieldVector, int, int, int, NullabilityHolder) - Method in class org.apache.iceberg.arrow.vectorized.parquet.VectorizedPageIterator
Method for reading a batch of values of TIMESTAMP_MILLIS data type.
nextBatchVarWidthType(FieldVector, NullabilityHolder) - Method in class org.apache.iceberg.arrow.vectorized.parquet.VectorizedColumnIterator
 
nextBatchVarWidthType(FieldVector, int, int, NullabilityHolder) - Method in class org.apache.iceberg.arrow.vectorized.parquet.VectorizedPageIterator
Method for reading a batch of variable width data type (ENUM, JSON, UTF8, BSON).
nextBinary() - Method in class org.apache.iceberg.parquet.ColumnIterator
 
nextBoolean() - Method in class org.apache.iceberg.parquet.ColumnIterator
 
nextDouble() - Method in class org.apache.iceberg.parquet.ColumnIterator
 
nextFloat() - Method in class org.apache.iceberg.parquet.ColumnIterator
 
nextInteger() - Method in class org.apache.iceberg.parquet.ColumnIterator
 
nextKeyValue() - Method in class org.apache.iceberg.pig.IcebergPigInputFormat.IcebergRecordReader
 
nextLong() - Method in class org.apache.iceberg.parquet.ColumnIterator
 
nextNull() - Method in class org.apache.iceberg.parquet.ColumnIterator
 
nextSequenceNumber() - Method in class org.apache.iceberg.TableMetadata
 
None() - Constructor for class org.apache.iceberg.MetricsModes.None
 
noRetry() - Method in class org.apache.iceberg.util.Tasks.Builder
 
NoSuchNamespaceException - Exception in org.apache.iceberg.exceptions
Exception raised when attempting to load a namespace that does not exist.
NoSuchNamespaceException(String, Object...) - Constructor for exception org.apache.iceberg.exceptions.NoSuchNamespaceException
 
NoSuchNamespaceException(Throwable, String, Object...) - Constructor for exception org.apache.iceberg.exceptions.NoSuchNamespaceException
 
NoSuchTableException - Exception in org.apache.iceberg.exceptions
Exception raised when attempting to load a table that does not exist.
NoSuchTableException(String, Object...) - Constructor for exception org.apache.iceberg.exceptions.NoSuchTableException
 
NoSuchTableException(Throwable, String, Object...) - Constructor for exception org.apache.iceberg.exceptions.NoSuchTableException
 
not(Expression) - Static method in class org.apache.iceberg.expressions.Expressions
 
not(R) - Method in class org.apache.iceberg.expressions.ExpressionVisitors.ExpressionVisitor
 
Not - Class in org.apache.iceberg.expressions
 
notEq(BoundReference<T>, Literal<T>) - Method in class org.apache.iceberg.expressions.ExpressionVisitors.BoundExpressionVisitor
Deprecated.
 
notEq(Bound<T>, Literal<T>) - Method in class org.apache.iceberg.expressions.ExpressionVisitors.BoundVisitor
 
notEqual(String, T) - Static method in class org.apache.iceberg.expressions.Expressions
 
notEqual(UnboundTerm<T>, T) - Static method in class org.apache.iceberg.expressions.Expressions
 
NotFoundException - Exception in org.apache.iceberg.exceptions
Exception raised when attempting to read a file that does not exist.
NotFoundException(String, Object...) - Constructor for exception org.apache.iceberg.exceptions.NotFoundException
 
NotFoundException(Throwable, String, Object...) - Constructor for exception org.apache.iceberg.exceptions.NotFoundException
 
notify(E) - Method in interface org.apache.iceberg.events.Listener
 
notifyAll(E) - Static method in class org.apache.iceberg.events.Listeners
 
notIn(String, T...) - Static method in class org.apache.iceberg.expressions.Expressions
 
notIn(UnboundTerm<T>, T...) - Static method in class org.apache.iceberg.expressions.Expressions
 
notIn(String, Iterable<T>) - Static method in class org.apache.iceberg.expressions.Expressions
 
notIn(UnboundTerm<T>, Iterable<T>) - Static method in class org.apache.iceberg.expressions.Expressions
 
notIn(BoundReference<T>, Set<T>) - Method in class org.apache.iceberg.expressions.ExpressionVisitors.BoundExpressionVisitor
Deprecated.
 
notIn(Bound<T>, Set<T>) - Method in class org.apache.iceberg.expressions.ExpressionVisitors.BoundVisitor
 
notNull(String) - Static method in class org.apache.iceberg.expressions.Expressions
 
notNull(UnboundTerm<T>) - Static method in class org.apache.iceberg.expressions.Expressions
 
notNull(BoundReference<T>) - Method in class org.apache.iceberg.expressions.ExpressionVisitors.BoundExpressionVisitor
Deprecated.
 
notNull(Bound<T>) - Method in class org.apache.iceberg.expressions.ExpressionVisitors.BoundVisitor
 
NULL_VALUES_READER - Static variable in class org.apache.iceberg.arrow.vectorized.VectorizedArrowReader
 
NULL_VECTOR_HOLDER - Static variable in class org.apache.iceberg.arrow.vectorized.VectorHolder
 
NullabilityHolder - Class in org.apache.iceberg.arrow.vectorized
Instances of this class simply track whether a value at an index is null.
NullabilityHolder(int) - Constructor for class org.apache.iceberg.arrow.vectorized.NullabilityHolder
 
nullabilityHolder() - Method in class org.apache.iceberg.arrow.vectorized.VectorHolder
 
nulls() - Static method in class org.apache.iceberg.avro.ValueReaders
 
nulls() - Static method in class org.apache.iceberg.avro.ValueWriters
 
nulls() - Static method in class org.apache.iceberg.parquet.ParquetValueReaders
 
nullsFirst() - Static method in class org.apache.iceberg.types.Comparators
 
nullsLast() - Static method in class org.apache.iceberg.types.Comparators
 
nullValueCounts() - Method in interface org.apache.iceberg.DataFile
 
nullValueCounts() - Method in class org.apache.iceberg.Metrics
Get the number of null values for all fields in a file.
nullValueCounts() - Method in class org.apache.iceberg.spark.SparkDataFile
 
numNulls() - Method in class org.apache.iceberg.arrow.vectorized.NullabilityHolder
 

O

OBJECT_STORE_ENABLED - Static variable in class org.apache.iceberg.TableProperties
 
OBJECT_STORE_ENABLED_DEFAULT - Static variable in class org.apache.iceberg.TableProperties
 
OBJECT_STORE_PATH - Static variable in class org.apache.iceberg.TableProperties
 
of(String...) - Static method in class org.apache.iceberg.catalog.Namespace
 
of(String...) - Static method in class org.apache.iceberg.catalog.TableIdentifier
 
of(Namespace, String) - Static method in class org.apache.iceberg.catalog.TableIdentifier
 
of(ByteBuffer) - Static method in class org.apache.iceberg.encryption.EncryptionKeyMetadatas
 
of(byte[]) - Static method in class org.apache.iceberg.encryption.EncryptionKeyMetadatas
 
of(boolean) - Static method in interface org.apache.iceberg.expressions.Literal
 
of(int) - Static method in interface org.apache.iceberg.expressions.Literal
 
of(long) - Static method in interface org.apache.iceberg.expressions.Literal
 
of(float) - Static method in interface org.apache.iceberg.expressions.Literal
 
of(double) - Static method in interface org.apache.iceberg.expressions.Literal
 
of(CharSequence) - Static method in interface org.apache.iceberg.expressions.Literal
 
of(UUID) - Static method in interface org.apache.iceberg.expressions.Literal
 
of(byte[]) - Static method in interface org.apache.iceberg.expressions.Literal
 
of(ByteBuffer) - Static method in interface org.apache.iceberg.expressions.Literal
 
of(BigDecimal) - Static method in interface org.apache.iceberg.expressions.Literal
 
of(PartitionSpec, Expression, boolean) - Static method in class org.apache.iceberg.expressions.ResidualEvaluator
Return a residual evaluator for a spec and expression.
of(Integer, String) - Static method in class org.apache.iceberg.mapping.MappedField
 
of(Integer, Iterable<String>) - Static method in class org.apache.iceberg.mapping.MappedField
 
of(Integer, String, MappedFields) - Static method in class org.apache.iceberg.mapping.MappedField
 
of(Integer, Iterable<String>, MappedFields) - Static method in class org.apache.iceberg.mapping.MappedField
 
of(MappedField...) - Static method in class org.apache.iceberg.mapping.MappedFields
 
of(List<MappedField>) - Static method in class org.apache.iceberg.mapping.MappedFields
 
of(MappedField...) - Static method in class org.apache.iceberg.mapping.NameMapping
 
of(List<MappedField>) - Static method in class org.apache.iceberg.mapping.NameMapping
 
of(MappedFields) - Static method in class org.apache.iceberg.mapping.NameMapping
 
of(TableScan) - Static method in class org.apache.iceberg.ScanSummary
Create a scan summary builder for a table scan.
of(int, int) - Static method in class org.apache.iceberg.types.Types.DecimalType
 
of(int, boolean, String, Type) - Static method in class org.apache.iceberg.types.Types.NestedField
 
of(int, boolean, String, Type, String) - Static method in class org.apache.iceberg.types.Types.NestedField
 
of(Types.NestedField...) - Static method in class org.apache.iceberg.types.Types.StructType
 
of(List<Types.NestedField>) - Static method in class org.apache.iceberg.types.Types.StructType
 
of(Iterable<CharSequence>) - Static method in class org.apache.iceberg.util.CharSequenceSet
 
of(X, Y) - Static method in class org.apache.iceberg.util.Pair
 
ofLength(int) - Static method in class org.apache.iceberg.types.Types.FixedType
 
ofOptional(int, Type) - Static method in class org.apache.iceberg.types.Types.ListType
 
ofOptional(int, int, Type, Type) - Static method in class org.apache.iceberg.types.Types.MapType
 
ofRequired(int, Type) - Static method in class org.apache.iceberg.types.Types.ListType
 
ofRequired(int, int, Type, Type) - Static method in class org.apache.iceberg.types.Types.MapType
 
olderThan(long) - Method in class org.apache.iceberg.actions.RemoveOrphanFilesAction
Removes orphan files that are older than the given timestamp.
onFailure(Tasks.FailureTask<I, ?>) - Method in class org.apache.iceberg.util.Tasks.Builder
 
onlyRetryOn(Class<? extends Exception>) - Method in class org.apache.iceberg.util.Tasks.Builder
 
onlyRetryOn(Class<? extends Exception>...) - Method in class org.apache.iceberg.util.Tasks.Builder
 
op() - Method in class org.apache.iceberg.expressions.And
 
op() - Method in interface org.apache.iceberg.expressions.Expression
 
op() - Method in class org.apache.iceberg.expressions.False
 
op() - Method in class org.apache.iceberg.expressions.Not
 
op() - Method in class org.apache.iceberg.expressions.Or
 
op() - Method in class org.apache.iceberg.expressions.Predicate
 
op() - Method in class org.apache.iceberg.expressions.True
 
operation() - Method in class org.apache.iceberg.BaseOverwriteFiles
 
operation() - Method in class org.apache.iceberg.BaseReplacePartitions
 
operation() - Method in class org.apache.iceberg.BaseRewriteManifests
 
operation() - Method in interface org.apache.iceberg.Snapshot
Return the name of the data operation that produced this snapshot.
operation() - Method in class org.apache.iceberg.SnapshotManager
 
operations() - Method in class org.apache.iceberg.BaseTable
 
operations() - Method in interface org.apache.iceberg.HasTableOperations
 
option(int, ValueWriter<T>) - Static method in class org.apache.iceberg.avro.ValueWriters
 
option(Type, int, ParquetValueReader<T>) - Static method in class org.apache.iceberg.parquet.ParquetValueReaders
 
option(Type, int, ParquetValueWriter<T>) - Static method in class org.apache.iceberg.parquet.ParquetValueWriters
 
option(String, String) - Method in interface org.apache.iceberg.TableScan
Create a new TableScan from this scan's configuration that will override the Table's behavior based on the incoming pair.
optional(int, String, Type) - Static method in class org.apache.iceberg.types.Types.NestedField
 
optional(int, String, Type, String) - Static method in class org.apache.iceberg.types.Types.NestedField
 
or(Expression, Expression) - Static method in class org.apache.iceberg.expressions.Expressions
 
or(R, R) - Method in class org.apache.iceberg.expressions.ExpressionVisitors.ExpressionVisitor
 
Or - Class in org.apache.iceberg.expressions
 
ORC - Class in org.apache.iceberg.orc
 
ORC.ReadBuilder - Class in org.apache.iceberg.orc
 
ORC.WriteBuilder - Class in org.apache.iceberg.orc
 
OrcMetrics - Class in org.apache.iceberg.orc
 
ORCSchemaUtil - Class in org.apache.iceberg.orc
Utilities for mapping Iceberg to ORC schemas.
ORCSchemaUtil.BinaryType - Enum in org.apache.iceberg.orc
 
ORCSchemaUtil.LongType - Enum in org.apache.iceberg.orc
 
OrcValueReader<T> - Interface in org.apache.iceberg.orc
Used for implementing ORC value readers.
OrcValueWriter<T> - Interface in org.apache.iceberg.orc
Write data value of a schema.
org.apache.iceberg - package org.apache.iceberg
 
org.apache.iceberg.actions - package org.apache.iceberg.actions
 
org.apache.iceberg.arrow - package org.apache.iceberg.arrow
 
org.apache.iceberg.arrow.vectorized - package org.apache.iceberg.arrow.vectorized
 
org.apache.iceberg.arrow.vectorized.parquet - package org.apache.iceberg.arrow.vectorized.parquet
 
org.apache.iceberg.avro - package org.apache.iceberg.avro
 
org.apache.iceberg.catalog - package org.apache.iceberg.catalog
 
org.apache.iceberg.common - package org.apache.iceberg.common
 
org.apache.iceberg.data - package org.apache.iceberg.data
 
org.apache.iceberg.data.avro - package org.apache.iceberg.data.avro
 
org.apache.iceberg.data.orc - package org.apache.iceberg.data.orc
 
org.apache.iceberg.data.parquet - package org.apache.iceberg.data.parquet
 
org.apache.iceberg.encryption - package org.apache.iceberg.encryption
 
org.apache.iceberg.events - package org.apache.iceberg.events
 
org.apache.iceberg.exceptions - package org.apache.iceberg.exceptions
 
org.apache.iceberg.expressions - package org.apache.iceberg.expressions
 
org.apache.iceberg.hadoop - package org.apache.iceberg.hadoop
 
org.apache.iceberg.hive - package org.apache.iceberg.hive
 
org.apache.iceberg.io - package org.apache.iceberg.io
 
org.apache.iceberg.mapping - package org.apache.iceberg.mapping
 
org.apache.iceberg.mr - package org.apache.iceberg.mr
 
org.apache.iceberg.mr.mapreduce - package org.apache.iceberg.mr.mapreduce
 
org.apache.iceberg.orc - package org.apache.iceberg.orc
 
org.apache.iceberg.parquet - package org.apache.iceberg.parquet
 
org.apache.iceberg.pig - package org.apache.iceberg.pig
 
org.apache.iceberg.spark - package org.apache.iceberg.spark
 
org.apache.iceberg.spark.data - package org.apache.iceberg.spark.data
 
org.apache.iceberg.spark.source - package org.apache.iceberg.spark.source
 
org.apache.iceberg.transforms - package org.apache.iceberg.transforms
 
org.apache.iceberg.types - package org.apache.iceberg.types
 
org.apache.iceberg.util - package org.apache.iceberg.util
 
orNoop() - Method in class org.apache.iceberg.common.DynMethods.Builder
If no implementation has been found, adds a NOOP method.
orNull() - Method in class org.apache.iceberg.common.DynClasses.Builder
Instructs this builder to return null if no class is found, rather than throwing an Exception.
OutputFile - Interface in org.apache.iceberg.io
An interface used to create output files using PositionOutputStream instances.
overwrite() - Method in class org.apache.iceberg.avro.Avro.WriteBuilder
 
overwrite(boolean) - Method in class org.apache.iceberg.avro.Avro.WriteBuilder
 
OVERWRITE - Static variable in class org.apache.iceberg.DataOperations
New data is added to overwrite existing data.
overwrite() - Method in class org.apache.iceberg.orc.ORC.WriteBuilder
 
overwrite(boolean) - Method in class org.apache.iceberg.orc.ORC.WriteBuilder
 
overwrite() - Method in class org.apache.iceberg.parquet.Parquet.WriteBuilder
 
overwrite(boolean) - Method in class org.apache.iceberg.parquet.Parquet.WriteBuilder
 
overwrite(TableMetadata, OutputFile) - Static method in class org.apache.iceberg.TableMetadataParser
 
overwriteByRowFilter(Expression) - Method in class org.apache.iceberg.BaseOverwriteFiles
 
overwriteByRowFilter(Expression) - Method in interface org.apache.iceberg.OverwriteFiles
Delete files that match an Expression on data rows from the table.
OverwriteFiles - Interface in org.apache.iceberg
API for overwriting files in a table.

P

pack(Iterable<T>, Function<T, Long>) - Method in class org.apache.iceberg.util.BinPacking.ListPacker
 
packEnd(List<T>, Function<T, Long>) - Method in class org.apache.iceberg.util.BinPacking.ListPacker
 
PackingIterable(Iterable<T>, long, int, Function<T, Long>) - Constructor for class org.apache.iceberg.util.BinPacking.PackingIterable
 
PackingIterable(Iterable<T>, long, int, Function<T, Long>, boolean) - Constructor for class org.apache.iceberg.util.BinPacking.PackingIterable
 
page - Variable in class org.apache.iceberg.parquet.BasePageIterator
 
pageIterator() - Method in class org.apache.iceberg.arrow.vectorized.parquet.VectorizedColumnIterator
 
pageIterator() - Method in class org.apache.iceberg.parquet.BaseColumnIterator
 
pageIterator() - Method in class org.apache.iceberg.parquet.ColumnIterator
 
pageSource - Variable in class org.apache.iceberg.parquet.BaseColumnIterator
 
Pair<X,Y> - Class in org.apache.iceberg.util
 
pairs(M) - Method in class org.apache.iceberg.parquet.ParquetValueWriters.RepeatedKeyValueWriter
 
ParallelIterable<T> - Class in org.apache.iceberg.util
 
ParallelIterable(Iterable<? extends Iterable<T>>, ExecutorService) - Constructor for class org.apache.iceberg.util.ParallelIterable
 
parentId() - Method in interface org.apache.iceberg.Snapshot
Return this snapshot's parent ID or null.
Parquet - Class in org.apache.iceberg.parquet
 
Parquet.ReadBuilder - Class in org.apache.iceberg.parquet
 
Parquet.WriteBuilder - Class in org.apache.iceberg.parquet
 
PARQUET_COMPRESSION - Static variable in class org.apache.iceberg.TableProperties
 
PARQUET_COMPRESSION_DEFAULT - Static variable in class org.apache.iceberg.TableProperties
 
PARQUET_COMPRESSION_LEVEL - Static variable in class org.apache.iceberg.TableProperties
 
PARQUET_COMPRESSION_LEVEL_DEFAULT - Static variable in class org.apache.iceberg.TableProperties
 
PARQUET_DICT_SIZE_BYTES - Static variable in class org.apache.iceberg.TableProperties
 
PARQUET_DICT_SIZE_BYTES_DEFAULT - Static variable in class org.apache.iceberg.TableProperties
 
PARQUET_PAGE_SIZE_BYTES - Static variable in class org.apache.iceberg.TableProperties
 
PARQUET_PAGE_SIZE_BYTES_DEFAULT - Static variable in class org.apache.iceberg.TableProperties
 
PARQUET_ROW_GROUP_SIZE_BYTES - Static variable in class org.apache.iceberg.TableProperties
 
PARQUET_ROW_GROUP_SIZE_BYTES_DEFAULT - Static variable in class org.apache.iceberg.TableProperties
 
ParquetAvroReader - Class in org.apache.iceberg.parquet
 
ParquetAvroReader() - Constructor for class org.apache.iceberg.parquet.ParquetAvroReader
 
ParquetAvroValueReaders - Class in org.apache.iceberg.parquet
 
ParquetAvroValueReaders.TimeMillisReader - Class in org.apache.iceberg.parquet
 
ParquetAvroValueReaders.TimestampMillisReader - Class in org.apache.iceberg.parquet
 
ParquetAvroWriter - Class in org.apache.iceberg.parquet
 
ParquetDictionaryRowGroupFilter - Class in org.apache.iceberg.parquet
 
ParquetDictionaryRowGroupFilter(Schema, Expression) - Constructor for class org.apache.iceberg.parquet.ParquetDictionaryRowGroupFilter
 
ParquetDictionaryRowGroupFilter(Schema, Expression, boolean) - Constructor for class org.apache.iceberg.parquet.ParquetDictionaryRowGroupFilter
 
ParquetIterable<T> - Class in org.apache.iceberg.parquet
 
ParquetMetricsRowGroupFilter - Class in org.apache.iceberg.parquet
 
ParquetMetricsRowGroupFilter(Schema, Expression) - Constructor for class org.apache.iceberg.parquet.ParquetMetricsRowGroupFilter
 
ParquetMetricsRowGroupFilter(Schema, Expression, boolean) - Constructor for class org.apache.iceberg.parquet.ParquetMetricsRowGroupFilter
 
ParquetReader<T> - Class in org.apache.iceberg.parquet
 
ParquetReader(InputFile, Schema, ParquetReadOptions, Function<MessageType, ParquetValueReader<?>>, Expression, boolean, boolean) - Constructor for class org.apache.iceberg.parquet.ParquetReader
 
ParquetSchemaUtil - Class in org.apache.iceberg.parquet
 
ParquetTypeVisitor<T> - Class in org.apache.iceberg.parquet
 
ParquetTypeVisitor() - Constructor for class org.apache.iceberg.parquet.ParquetTypeVisitor
 
ParquetUtil - Class in org.apache.iceberg.parquet
 
ParquetValueReader<T> - Interface in org.apache.iceberg.parquet
 
ParquetValueReaders - Class in org.apache.iceberg.parquet
 
ParquetValueReaders.BinaryAsDecimalReader - Class in org.apache.iceberg.parquet
 
ParquetValueReaders.BytesReader - Class in org.apache.iceberg.parquet
 
ParquetValueReaders.FloatAsDoubleReader - Class in org.apache.iceberg.parquet
 
ParquetValueReaders.IntAsLongReader - Class in org.apache.iceberg.parquet
 
ParquetValueReaders.IntegerAsDecimalReader - Class in org.apache.iceberg.parquet
 
ParquetValueReaders.ListReader<E> - Class in org.apache.iceberg.parquet
 
ParquetValueReaders.LongAsDecimalReader - Class in org.apache.iceberg.parquet
 
ParquetValueReaders.MapReader<K,V> - Class in org.apache.iceberg.parquet
 
ParquetValueReaders.PrimitiveReader<T> - Class in org.apache.iceberg.parquet
 
ParquetValueReaders.RepeatedKeyValueReader<M,I,K,V> - Class in org.apache.iceberg.parquet
 
ParquetValueReaders.RepeatedReader<T,I,E> - Class in org.apache.iceberg.parquet
 
ParquetValueReaders.ReusableEntry<K,V> - Class in org.apache.iceberg.parquet
 
ParquetValueReaders.StringReader - Class in org.apache.iceberg.parquet
 
ParquetValueReaders.StructReader<T,I> - Class in org.apache.iceberg.parquet
 
ParquetValueReaders.UnboxedReader<T> - Class in org.apache.iceberg.parquet
 
ParquetValueWriter<T> - Interface in org.apache.iceberg.parquet
 
ParquetValueWriters - Class in org.apache.iceberg.parquet
 
ParquetValueWriters.PrimitiveWriter<T> - Class in org.apache.iceberg.parquet
 
ParquetValueWriters.RepeatedKeyValueWriter<M,K,V> - Class in org.apache.iceberg.parquet
 
ParquetValueWriters.RepeatedWriter<L,E> - Class in org.apache.iceberg.parquet
 
ParquetValueWriters.StructWriter<S> - Class in org.apache.iceberg.parquet
 
ParquetWriteAdapter<D> - Class in org.apache.iceberg.parquet
 
ParquetWriteAdapter(ParquetWriter<D>, MetricsConfig) - Constructor for class org.apache.iceberg.parquet.ParquetWriteAdapter
 
parse(String) - Static method in class org.apache.iceberg.catalog.TableIdentifier
 
partition() - Method in interface org.apache.iceberg.DataFile
 
partition() - Method in class org.apache.iceberg.spark.SparkDataFile
 
PARTITION_SUMMARIES - Static variable in interface org.apache.iceberg.ManifestFile
 
PARTITION_SUMMARY_TYPE - Static variable in interface org.apache.iceberg.ManifestFile
 
PartitionField - Class in org.apache.iceberg
Represents a single field in a PartitionSpec.
PartitionMetrics() - Constructor for class org.apache.iceberg.ScanSummary.PartitionMetrics
 
partitions() - Method in class org.apache.iceberg.GenericManifestFile
 
partitions() - Method in interface org.apache.iceberg.ManifestFile
Returns a list of partition field summaries.
PartitionSpec - Class in org.apache.iceberg
Represents how to produce partition data for a table.
PartitionSpec.Builder - Class in org.apache.iceberg
Used to create valid partition specs.
partitionSpecId() - Method in class org.apache.iceberg.GenericManifestFile
 
partitionSpecId() - Method in interface org.apache.iceberg.ManifestFile
 
PartitionSpecParser - Class in org.apache.iceberg
 
PartitionSpecVisitor<T> - Interface in org.apache.iceberg.transforms
 
PartitionsTable - Class in org.apache.iceberg
A Table implementation that exposes a table's partitions as rows.
PartitionsTable(TableOperations, Table) - Constructor for class org.apache.iceberg.PartitionsTable
 
partitionToPath(StructLike) - Method in class org.apache.iceberg.PartitionSpec
 
partitionType() - Method in class org.apache.iceberg.PartitionSpec
 
PartitionUtil - Class in org.apache.iceberg.util
 
path() - Method in interface org.apache.iceberg.DataFile
 
path() - Method in class org.apache.iceberg.GenericManifestFile
 
PATH - Static variable in interface org.apache.iceberg.ManifestFile
 
path() - Method in interface org.apache.iceberg.ManifestFile
 
path(String) - Method in class org.apache.iceberg.parquet.ParquetTypeVisitor
 
path(String) - Method in class org.apache.iceberg.parquet.TypeWithSchemaVisitor
 
path() - Method in class org.apache.iceberg.spark.SparkDataFile
 
PendingUpdate<T> - Interface in org.apache.iceberg
API for table metadata changes.
PIG_ICEBERG_TABLES_IMPL - Static variable in class org.apache.iceberg.pig.IcebergStorage
 
PigParquetReader - Class in org.apache.iceberg.pig
 
PlaintextEncryptionManager - Class in org.apache.iceberg.encryption
 
PlaintextEncryptionManager() - Constructor for class org.apache.iceberg.encryption.PlaintextEncryptionManager
 
planFiles(TableOperations, Snapshot, Expression, boolean, boolean) - Method in class org.apache.iceberg.AllDataFilesTable.AllDataFilesTableScan
 
planFiles(TableOperations, Snapshot, Expression, boolean, boolean) - Method in class org.apache.iceberg.AllManifestsTable.AllManifestsTableScan
 
planFiles(TableOperations, Snapshot, Expression, boolean, boolean) - Method in class org.apache.iceberg.DataFilesTable.FilesTableScan
 
planFiles(TableOperations, Snapshot, Expression, boolean, boolean) - Method in class org.apache.iceberg.DataTableScan
 
planFiles() - Method in interface org.apache.iceberg.TableScan
Plan the files that will be read by this scan.
planTasks() - Method in interface org.apache.iceberg.TableScan
Plan the tasks for this scan.
PositionOutputStream - Class in org.apache.iceberg.io
 
PositionOutputStream() - Constructor for class org.apache.iceberg.io.PositionOutputStream
 
precision() - Method in class org.apache.iceberg.types.Types.DecimalType
 
predicate(Expression.Operation, String, T) - Static method in class org.apache.iceberg.expressions.Expressions
 
predicate(Expression.Operation, String, Literal<T>) - Static method in class org.apache.iceberg.expressions.Expressions
 
predicate(Expression.Operation, String, Iterable<T>) - Static method in class org.apache.iceberg.expressions.Expressions
 
predicate(Expression.Operation, String) - Static method in class org.apache.iceberg.expressions.Expressions
 
predicate(BoundPredicate<T>) - Method in class org.apache.iceberg.expressions.ExpressionVisitors.BoundExpressionVisitor
Deprecated.
 
predicate(UnboundPredicate<T>) - Method in class org.apache.iceberg.expressions.ExpressionVisitors.BoundExpressionVisitor
Deprecated.
 
predicate(BoundPredicate<T>) - Method in class org.apache.iceberg.expressions.ExpressionVisitors.BoundVisitor
 
predicate(UnboundPredicate<T>) - Method in class org.apache.iceberg.expressions.ExpressionVisitors.BoundVisitor
 
predicate(BoundPredicate<T>) - Method in class org.apache.iceberg.expressions.ExpressionVisitors.ExpressionVisitor
 
predicate(UnboundPredicate<T>) - Method in class org.apache.iceberg.expressions.ExpressionVisitors.ExpressionVisitor
 
Predicate<T,C extends Term> - Class in org.apache.iceberg.expressions
 
preferLocality() - Method in class org.apache.iceberg.mr.mapreduce.IcebergInputFormat.ConfigBuilder
If this API is called.
prepare(ManifestEntry) - Method in class org.apache.iceberg.ManifestWriter
 
prepareToRead(RecordReader, PigSplit) - Method in class org.apache.iceberg.pig.IcebergStorage
 
PREVIOUS_METADATA_LOCATION_PROP - Static variable in class org.apache.iceberg.BaseMetastoreTableOperations
 
previousFiles() - Method in class org.apache.iceberg.TableMetadata
 
primitive(Schema) - Method in class org.apache.iceberg.avro.AvroSchemaVisitor
 
primitive(Type.PrimitiveType, Schema) - Method in class org.apache.iceberg.avro.AvroSchemaWithTypeVisitor
 
primitive(PrimitiveType) - Method in class org.apache.iceberg.parquet.ParquetTypeVisitor
 
primitive(Type.PrimitiveType, Type.Repetition, int, String) - Method in class org.apache.iceberg.parquet.TypeToMessageType
 
primitive(Type.PrimitiveType, PrimitiveType) - Method in class org.apache.iceberg.parquet.TypeWithSchemaVisitor
 
primitive(Type.PrimitiveType) - Method in class org.apache.iceberg.spark.PruneColumnsWithoutReordering
 
primitive(Type.PrimitiveType) - Method in class org.apache.iceberg.spark.PruneColumnsWithReordering
 
primitive(Type.PrimitiveType) - Method in class org.apache.iceberg.types.CheckCompatibility
 
primitive(Type.PrimitiveType) - Method in class org.apache.iceberg.types.TypeUtil.CustomOrderSchemaVisitor
 
primitive(Type.PrimitiveType) - Method in class org.apache.iceberg.types.TypeUtil.SchemaVisitor
 
PrimitiveReader(ColumnDescriptor) - Constructor for class org.apache.iceberg.parquet.ParquetValueReaders.PrimitiveReader
 
PrimitiveType() - Constructor for class org.apache.iceberg.types.Type.PrimitiveType
 
PrimitiveWriter(ColumnDescriptor) - Constructor for class org.apache.iceberg.parquet.ParquetValueWriters.PrimitiveWriter
 
project(Schema) - Method in class org.apache.iceberg.avro.Avro.ReadBuilder
 
project(Expression) - Method in class org.apache.iceberg.expressions.Projections.ProjectionEvaluator
Project the given row expression to a partition expression.
project(Schema) - Method in interface org.apache.iceberg.Filterable
Set the projection from a schema.
project(Schema) - Method in class org.apache.iceberg.FilteredManifest
 
project(Schema) - Method in class org.apache.iceberg.ManifestReader
 
project(Schema) - Method in class org.apache.iceberg.mr.mapreduce.IcebergInputFormat.ConfigBuilder
 
project(Schema) - Method in class org.apache.iceberg.orc.ORC.ReadBuilder
 
project(Schema) - Method in class org.apache.iceberg.parquet.Parquet.ReadBuilder
 
project(Schema, List<String>) - Static method in class org.apache.iceberg.pig.SchemaUtil
 
project(Schema) - Method in interface org.apache.iceberg.TableScan
Create a new TableScan from this with the schema as its projection.
project(String, BoundPredicate<S>) - Method in interface org.apache.iceberg.transforms.Transform
Transforms a predicate to an inclusive predicate on the partition values produced by Transform.apply(Object).
project(String, BoundPredicate<S>) - Method in class org.apache.iceberg.transforms.UnknownTransform
 
projection() - Method in class org.apache.iceberg.events.ScanEvent
 
ProjectionDatumReader<D> - Class in org.apache.iceberg.avro
 
ProjectionDatumReader(Function<Schema, DatumReader<?>>, Schema, Map<String, String>, NameMapping) - Constructor for class org.apache.iceberg.avro.ProjectionDatumReader
 
ProjectionEvaluator() - Constructor for class org.apache.iceberg.expressions.Projections.ProjectionEvaluator
 
Projections - Class in org.apache.iceberg.expressions
Utils to project expressions on rows to expressions on partitions.
Projections.ProjectionEvaluator - Class in org.apache.iceberg.expressions
A class that projects expressions for a table's data rows into expressions on the table's partition values, for a table's partition spec.
projectStrict(String, BoundPredicate<S>) - Method in interface org.apache.iceberg.transforms.Transform
Transforms a predicate to a strict predicate on the partition values produced by Transform.apply(Object).
projectStrict(String, BoundPredicate<S>) - Method in class org.apache.iceberg.transforms.UnknownTransform
 
properties() - Method in class org.apache.iceberg.BaseTable
 
properties() - Method in interface org.apache.iceberg.Table
Return a map of string properties for this table.
properties() - Method in class org.apache.iceberg.TableMetadata
 
property(String, String) - Method in class org.apache.iceberg.TableMetadata
 
propertyAsBoolean(String, boolean) - Method in class org.apache.iceberg.TableMetadata
 
propertyAsBoolean(Map<String, String>, String, boolean) - Static method in class org.apache.iceberg.util.PropertyUtil
 
propertyAsInt(String, int) - Method in class org.apache.iceberg.TableMetadata
 
propertyAsInt(Map<String, String>, String, int) - Static method in class org.apache.iceberg.util.PropertyUtil
 
propertyAsLong(String, long) - Method in class org.apache.iceberg.TableMetadata
 
propertyAsLong(Map<String, String>, String, long) - Static method in class org.apache.iceberg.util.PropertyUtil
 
PropertyUtil - Class in org.apache.iceberg.util
 
prune(Schema, StructType) - Static method in class org.apache.iceberg.spark.SparkSchemaUtil
Prune columns from a Schema using a Spark type projection.
prune(Schema, StructType, List<Expression>) - Static method in class org.apache.iceberg.spark.SparkSchemaUtil
Prune columns from a Schema using a Spark type projection.
prune(Schema, StructType, Expression, boolean) - Static method in class org.apache.iceberg.spark.SparkSchemaUtil
Prune columns from a Schema using a Spark type projection.
pruneColumns(Schema, Set<Integer>, NameMapping) - Static method in class org.apache.iceberg.avro.AvroSchemaUtil
 
pruneColumns(MessageType, Schema) - Static method in class org.apache.iceberg.parquet.ParquetSchemaUtil
 
pruneColumnsFallback(MessageType, Schema) - Static method in class org.apache.iceberg.parquet.ParquetSchemaUtil
Prunes columns from a Parquet file schema that was written without field ids.
PruneColumnsWithoutReordering - Class in org.apache.iceberg.spark
 
PruneColumnsWithReordering - Class in org.apache.iceberg.spark
 
PUBLISHED_WAP_ID_PROP - Static variable in class org.apache.iceberg.SnapshotSummary
 
publishedWapId(Snapshot) - Static method in class org.apache.iceberg.util.WapUtil
 
pushProjection(LoadPushDown.RequiredFieldList) - Method in class org.apache.iceberg.pig.IcebergStorage
 
put(int, Object) - Method in class org.apache.iceberg.GenericManifestFile
 
put(int, Object) - Method in class org.apache.iceberg.GenericPartitionFieldSummary
 
put(int, Object) - Method in class org.apache.iceberg.util.Pair
 

R

range(int) - Static method in class org.apache.iceberg.util.Tasks
 
read(int) - Method in class org.apache.iceberg.arrow.vectorized.VectorizedArrowReader
 
read(InputFile) - Static method in class org.apache.iceberg.avro.Avro
 
read(D, Decoder) - Method in class org.apache.iceberg.avro.ProjectionDatumReader
 
read(Decoder, Object) - Method in interface org.apache.iceberg.avro.ValueReader
 
read(Decoder, Object) - Method in class org.apache.iceberg.avro.ValueReaders.StructReader
 
read(T, Decoder) - Method in class org.apache.iceberg.data.avro.DataReader
 
read(Table) - Static method in class org.apache.iceberg.data.IcebergGenerics
Returns a builder to configure a read of the given table that produces generic records.
read(VectorizedRowBatch, int) - Method in class org.apache.iceberg.data.orc.GenericOrcReader
 
read(ManifestFile, FileIO) - Static method in class org.apache.iceberg.ManifestFiles
Returns a new ManifestReader for a ManifestFile.
read(ManifestFile, FileIO, Map<Integer, PartitionSpec>) - Static method in class org.apache.iceberg.ManifestFiles
Returns a new ManifestReader for a ManifestFile.
read(InputFile) - Static method in class org.apache.iceberg.ManifestReader
Deprecated.
will be removed in 0.9.0; use ManifestFiles.read(ManifestFile, FileIO, Map) instead.
read(InputFile, Function<Integer, PartitionSpec>) - Static method in class org.apache.iceberg.ManifestReader
Deprecated.
will be removed in 0.9.0; use ManifestFiles.read(ManifestFile, FileIO, Map) instead.
read(InputFile) - Static method in class org.apache.iceberg.orc.ORC
 
read(VectorizedRowBatch, int) - Method in interface org.apache.iceberg.orc.OrcValueReader
Reads a value in row.
read(InputFile) - Static method in class org.apache.iceberg.parquet.Parquet
 
read(T) - Method in interface org.apache.iceberg.parquet.ParquetValueReader
 
read(BigDecimal) - Method in class org.apache.iceberg.parquet.ParquetValueReaders.BinaryAsDecimalReader
 
read(ByteBuffer) - Method in class org.apache.iceberg.parquet.ParquetValueReaders.BytesReader
 
read(Double) - Method in class org.apache.iceberg.parquet.ParquetValueReaders.FloatAsDoubleReader
 
read(Long) - Method in class org.apache.iceberg.parquet.ParquetValueReaders.IntAsLongReader
 
read(BigDecimal) - Method in class org.apache.iceberg.parquet.ParquetValueReaders.IntegerAsDecimalReader
 
read(BigDecimal) - Method in class org.apache.iceberg.parquet.ParquetValueReaders.LongAsDecimalReader
 
read(M) - Method in class org.apache.iceberg.parquet.ParquetValueReaders.RepeatedKeyValueReader
 
read(T) - Method in class org.apache.iceberg.parquet.ParquetValueReaders.RepeatedReader
 
read(String) - Method in class org.apache.iceberg.parquet.ParquetValueReaders.StringReader
 
read(T) - Method in class org.apache.iceberg.parquet.ParquetValueReaders.StructReader
 
read(T) - Method in class org.apache.iceberg.parquet.ParquetValueReaders.UnboxedReader
 
read(int) - Method in interface org.apache.iceberg.parquet.VectorizedReader
Reads a batch of type @param <T> and of size numRows
read(InternalRow, Decoder) - Method in class org.apache.iceberg.spark.data.SparkAvroReader
 
read(VectorizedRowBatch, int) - Method in class org.apache.iceberg.spark.data.SparkOrcReader
 
read(TableOperations, InputFile) - Static method in class org.apache.iceberg.TableMetadataParser
Deprecated.
will be removed in 0.9.0; use read(FileIO, InputFile) instead.
read(FileIO, String) - Static method in class org.apache.iceberg.TableMetadataParser
 
read(FileIO, InputFile) - Static method in class org.apache.iceberg.TableMetadataParser
 
readBatchOfBooleans(FieldVector, int, int, NullabilityHolder, ValuesAsBytesReader) - Method in class org.apache.iceberg.arrow.vectorized.parquet.VectorizedParquetDefinitionLevelReader
 
readBatchOfDictionaryEncodedDoubles(FieldVector, int, int, int, NullabilityHolder, VectorizedDictionaryEncodedParquetValuesReader, Dictionary) - Method in class org.apache.iceberg.arrow.vectorized.parquet.VectorizedParquetDefinitionLevelReader
 
readBatchOfDictionaryEncodedFixedLengthDecimals(FieldVector, int, int, int, NullabilityHolder, VectorizedDictionaryEncodedParquetValuesReader, Dictionary) - Method in class org.apache.iceberg.arrow.vectorized.parquet.VectorizedParquetDefinitionLevelReader
 
readBatchOfDictionaryEncodedFixedWidthBinary(FieldVector, int, int, int, NullabilityHolder, VectorizedDictionaryEncodedParquetValuesReader, Dictionary) - Method in class org.apache.iceberg.arrow.vectorized.parquet.VectorizedParquetDefinitionLevelReader
 
readBatchOfDictionaryEncodedFloats(FieldVector, int, int, int, NullabilityHolder, VectorizedDictionaryEncodedParquetValuesReader, Dictionary) - Method in class org.apache.iceberg.arrow.vectorized.parquet.VectorizedParquetDefinitionLevelReader
 
readBatchOfDictionaryEncodedIntegers(FieldVector, int, int, int, NullabilityHolder, VectorizedDictionaryEncodedParquetValuesReader, Dictionary) - Method in class org.apache.iceberg.arrow.vectorized.parquet.VectorizedParquetDefinitionLevelReader
 
readBatchOfDictionaryEncodedIntLongBackedDecimals(FieldVector, int, int, int, NullabilityHolder, VectorizedDictionaryEncodedParquetValuesReader, Dictionary) - Method in class org.apache.iceberg.arrow.vectorized.parquet.VectorizedParquetDefinitionLevelReader
 
readBatchOfDictionaryEncodedLongs(FieldVector, int, int, int, NullabilityHolder, VectorizedDictionaryEncodedParquetValuesReader, Dictionary) - Method in class org.apache.iceberg.arrow.vectorized.parquet.VectorizedParquetDefinitionLevelReader
 
readBatchOfDictionaryEncodedTimestampMillis(FieldVector, int, int, int, NullabilityHolder, VectorizedDictionaryEncodedParquetValuesReader, Dictionary) - Method in class org.apache.iceberg.arrow.vectorized.parquet.VectorizedParquetDefinitionLevelReader
 
readBatchOfDictionaryEncodedVarWidth(FieldVector, int, int, NullabilityHolder, VectorizedDictionaryEncodedParquetValuesReader, Dictionary) - Method in class org.apache.iceberg.arrow.vectorized.parquet.VectorizedParquetDefinitionLevelReader
 
readBatchOfDictionaryIds(IntVector, int, int, NullabilityHolder, VectorizedDictionaryEncodedParquetValuesReader) - Method in class org.apache.iceberg.arrow.vectorized.parquet.VectorizedParquetDefinitionLevelReader
 
readBatchOfDoubles(FieldVector, int, int, int, NullabilityHolder, ValuesAsBytesReader) - Method in class org.apache.iceberg.arrow.vectorized.parquet.VectorizedParquetDefinitionLevelReader
 
readBatchOfFixedLengthDecimals(FieldVector, int, int, int, NullabilityHolder, ValuesAsBytesReader) - Method in class org.apache.iceberg.arrow.vectorized.parquet.VectorizedParquetDefinitionLevelReader
 
readBatchOfFixedWidthBinary(FieldVector, int, int, int, NullabilityHolder, ValuesAsBytesReader) - Method in class org.apache.iceberg.arrow.vectorized.parquet.VectorizedParquetDefinitionLevelReader
 
readBatchOfFloats(FieldVector, int, int, int, NullabilityHolder, ValuesAsBytesReader) - Method in class org.apache.iceberg.arrow.vectorized.parquet.VectorizedParquetDefinitionLevelReader
 
readBatchOfIntegers(FieldVector, int, int, int, NullabilityHolder, ValuesAsBytesReader) - Method in class org.apache.iceberg.arrow.vectorized.parquet.VectorizedParquetDefinitionLevelReader
 
readBatchOfIntLongBackedDecimals(FieldVector, int, int, int, NullabilityHolder, ValuesAsBytesReader) - Method in class org.apache.iceberg.arrow.vectorized.parquet.VectorizedParquetDefinitionLevelReader
 
readBatchOfLongs(FieldVector, int, int, int, NullabilityHolder, ValuesAsBytesReader) - Method in class org.apache.iceberg.arrow.vectorized.parquet.VectorizedParquetDefinitionLevelReader
 
readBatchOfTimestampMillis(FieldVector, int, int, int, NullabilityHolder, ValuesAsBytesReader) - Method in class org.apache.iceberg.arrow.vectorized.parquet.VectorizedParquetDefinitionLevelReader
 
readBatchVarWidth(FieldVector, int, int, NullabilityHolder, ValuesAsBytesReader) - Method in class org.apache.iceberg.arrow.vectorized.parquet.VectorizedParquetDefinitionLevelReader
 
readBinary() - Method in class org.apache.iceberg.parquet.ParquetValueReaders.UnboxedReader
 
readBoolean() - Method in class org.apache.iceberg.arrow.vectorized.parquet.BaseVectorizedParquetValuesReader
 
readBoolean() - Method in class org.apache.iceberg.parquet.ParquetValueReaders.UnboxedReader
 
readBoolean() - Method in class org.apache.iceberg.parquet.ValuesAsBytesReader
 
readBooleanAsInt() - Method in class org.apache.iceberg.parquet.ValuesAsBytesReader
 
readCompatibilityErrors(Schema, Schema) - Static method in class org.apache.iceberg.types.CheckCompatibility
Returns a list of compatibility errors for reading with the given read schema.
readDictionary(ColumnDescriptor, PageReader) - Static method in class org.apache.iceberg.parquet.ParquetUtil
 
readDouble() - Method in class org.apache.iceberg.parquet.ParquetValueReaders.FloatAsDoubleReader
 
readDouble() - Method in class org.apache.iceberg.parquet.ParquetValueReaders.UnboxedReader
 
readDouble() - Method in class org.apache.iceberg.parquet.ValuesAsBytesReader
 
reader(int) - Method in class org.apache.iceberg.avro.ValueReaders.StructReader
 
readFloat() - Method in class org.apache.iceberg.parquet.ParquetValueReaders.UnboxedReader
 
readFloat() - Method in class org.apache.iceberg.parquet.ValuesAsBytesReader
 
readFrom(String) - Method in class org.apache.iceberg.mr.mapreduce.IcebergInputFormat.ConfigBuilder
 
readInteger() - Method in class org.apache.iceberg.arrow.vectorized.parquet.BaseVectorizedParquetValuesReader
 
readInteger() - Method in class org.apache.iceberg.parquet.ParquetValueReaders.UnboxedReader
 
readInteger() - Method in class org.apache.iceberg.parquet.ValuesAsBytesReader
 
readLong() - Method in class org.apache.iceberg.parquet.ParquetAvroValueReaders.TimeMillisReader
 
readLong() - Method in class org.apache.iceberg.parquet.ParquetAvroValueReaders.TimestampMillisReader
 
readLong() - Method in class org.apache.iceberg.parquet.ParquetValueReaders.IntAsLongReader
 
readLong() - Method in class org.apache.iceberg.parquet.ParquetValueReaders.UnboxedReader
 
readLong() - Method in class org.apache.iceberg.parquet.ValuesAsBytesReader
 
readSupport(ReadSupport<?>) - Method in class org.apache.iceberg.parquet.Parquet.ReadBuilder
 
readValueDictionaryId() - Method in class org.apache.iceberg.arrow.vectorized.parquet.BaseVectorizedParquetValuesReader
 
reassignIds(Schema, Schema) - Static method in class org.apache.iceberg.types.TypeUtil
Reassigns ids in a schema from another schema.
reconnect(C) - Method in class org.apache.iceberg.hive.ClientPool
 
reconnect(HiveMetaStoreClient) - Method in class org.apache.iceberg.hive.HiveClientPool
 
record(Schema, List<String>, List<T>) - Method in class org.apache.iceberg.avro.AvroSchemaVisitor
 
record(Types.StructType, Schema, List<String>, List<T>) - Method in class org.apache.iceberg.avro.AvroSchemaWithTypeVisitor
 
record(List<ValueReader<?>>, Schema) - Static method in class org.apache.iceberg.avro.ValueReaders
 
record(List<ValueReader<?>>, Class<R>, Schema) - Static method in class org.apache.iceberg.avro.ValueReaders
 
record(List<ValueWriter<?>>) - Static method in class org.apache.iceberg.avro.ValueWriters
 
Record - Interface in org.apache.iceberg.data
 
recordCount() - Method in interface org.apache.iceberg.DataFile
 
recordCount() - Method in class org.apache.iceberg.Metrics
Get the number of records (rows) in file.
recordCount() - Method in class org.apache.iceberg.ScanSummary.PartitionMetrics
 
recordCount() - Method in class org.apache.iceberg.spark.SparkDataFile
 
recordsPerBatch(int) - Method in class org.apache.iceberg.parquet.Parquet.ReadBuilder
 
ref() - Method in interface org.apache.iceberg.expressions.Bound
 
ref() - Method in class org.apache.iceberg.expressions.BoundPredicate
 
ref() - Method in class org.apache.iceberg.expressions.BoundReference
 
ref() - Method in class org.apache.iceberg.expressions.BoundTransform
 
ref() - Method in class org.apache.iceberg.expressions.NamedReference
 
ref() - Method in interface org.apache.iceberg.expressions.Unbound
 
ref() - Method in class org.apache.iceberg.expressions.UnboundPredicate
 
ref() - Method in class org.apache.iceberg.expressions.UnboundTransform
 
Reference<T> - Interface in org.apache.iceberg.expressions
Represents a variable reference in an expression.
refresh() - Method in class org.apache.iceberg.BaseMetastoreTableOperations
 
refresh() - Method in class org.apache.iceberg.BaseTable
 
refresh() - Method in class org.apache.iceberg.hadoop.HadoopTableOperations
 
refresh() - Method in interface org.apache.iceberg.Table
Refresh the current table metadata.
refresh() - Method in interface org.apache.iceberg.TableOperations
Return the current table metadata after checking for updates.
refreshFromMetadataLocation(String) - Method in class org.apache.iceberg.BaseMetastoreTableOperations
 
refreshFromMetadataLocation(String, int) - Method in class org.apache.iceberg.BaseMetastoreTableOperations
 
refreshFromMetadataLocation(String, Predicate<Exception>, int) - Method in class org.apache.iceberg.BaseMetastoreTableOperations
 
register(Listener<E>, Class<E>) - Static method in class org.apache.iceberg.events.Listeners
 
relativeToAbsolutePath(String, Path) - Method in class org.apache.iceberg.pig.IcebergStorage
 
remove(String) - Method in interface org.apache.iceberg.UpdateProperties
Remove the given property key from the table.
remove(Object) - Method in class org.apache.iceberg.util.CharSequenceSet
 
removeAll(Collection<?>) - Method in class org.apache.iceberg.util.CharSequenceSet
 
removeOrphanFiles() - Method in class org.apache.iceberg.actions.Actions
 
RemoveOrphanFilesAction - Class in org.apache.iceberg.actions
An action that removes orphan metadata and data files by listing a given location and comparing the actual files in that location with data and metadata files referenced by all valid snapshots.
removeProperties(Namespace, Set<String>) - Method in interface org.apache.iceberg.catalog.SupportsNamespaces
Remove a set of metadata from a namespace in the catalog.
removeProperties(Namespace, Set<String>) - Method in class org.apache.iceberg.hadoop.HadoopCatalog
 
removeProperties(Namespace, Set<String>) - Method in class org.apache.iceberg.hive.HiveCatalog
 
removeSnapshotLogEntries(Set<Long>) - Method in class org.apache.iceberg.TableMetadata
 
removeSnapshotsIf(Predicate<Snapshot>) - Method in class org.apache.iceberg.TableMetadata
 
rename(String, String) - Method in class org.apache.iceberg.avro.Avro.ReadBuilder
 
renameColumn(String, String) - Method in interface org.apache.iceberg.UpdateSchema
Rename a column in the schema.
renameTable(TableIdentifier, TableIdentifier) - Method in class org.apache.iceberg.CachingCatalog
 
renameTable(TableIdentifier, TableIdentifier) - Method in interface org.apache.iceberg.catalog.Catalog
Rename a table.
renameTable(TableIdentifier, TableIdentifier) - Method in class org.apache.iceberg.hadoop.HadoopCatalog
 
renameTable(TableIdentifier, TableIdentifier) - Method in class org.apache.iceberg.hive.HiveCatalog
 
RepeatedKeyValueReader(int, int, ParquetValueReader<K>, ParquetValueReader<V>) - Constructor for class org.apache.iceberg.parquet.ParquetValueReaders.RepeatedKeyValueReader
 
RepeatedKeyValueWriter(int, int, ParquetValueWriter<K>, ParquetValueWriter<V>) - Constructor for class org.apache.iceberg.parquet.ParquetValueWriters.RepeatedKeyValueWriter
 
RepeatedReader(int, int, ParquetValueReader<E>) - Constructor for class org.apache.iceberg.parquet.ParquetValueReaders.RepeatedReader
 
RepeatedWriter(int, int, ParquetValueWriter<E>) - Constructor for class org.apache.iceberg.parquet.ParquetValueWriters.RepeatedWriter
 
repetitionLevels - Variable in class org.apache.iceberg.parquet.BasePageIterator
 
REPLACE - Static variable in class org.apache.iceberg.DataOperations
Files are removed and replaced, without changing the data in the table.
replaceCurrentSnapshot(Snapshot) - Method in class org.apache.iceberg.TableMetadata
 
ReplacePartitions - Interface in org.apache.iceberg
Not recommended: API for overwriting files in a table by partition.
replaceProperties(Map<String, String>) - Method in class org.apache.iceberg.TableMetadata
 
replaceTableTransaction(TableOperations, TableMetadata) - Static method in class org.apache.iceberg.Transactions
 
requestRefresh() - Method in class org.apache.iceberg.BaseMetastoreTableOperations
 
requireColumn(String) - Method in interface org.apache.iceberg.UpdateSchema
Update a column to required.
required(int, String, Type) - Static method in class org.apache.iceberg.types.Types.NestedField
 
required(int, String, Type, String) - Static method in class org.apache.iceberg.types.Types.NestedField
 
reset() - Method in class org.apache.iceberg.arrow.vectorized.NullabilityHolder
 
reset() - Method in class org.apache.iceberg.arrow.vectorized.parquet.VectorizedPageIterator
 
reset() - Method in class org.apache.iceberg.parquet.BasePageIterator
 
residual() - Method in interface org.apache.iceberg.FileScanTask
Returns the residual expression that should be applied to rows in this file scan.
ResidualEvaluator - Class in org.apache.iceberg.expressions
Finds the residuals for an Expression the partitions in the given PartitionSpec.
residualFor(StructLike) - Method in class org.apache.iceberg.expressions.ResidualEvaluator
Returns a residual expression for the given partition values.
retainAll(Collection<?>) - Method in class org.apache.iceberg.util.CharSequenceSet
 
retainLast(int) - Method in interface org.apache.iceberg.ExpireSnapshots
Retains the most recent ancestors of the current snapshot.
retry(int) - Method in class org.apache.iceberg.util.Tasks.Builder
 
ReusableEntry() - Constructor for class org.apache.iceberg.parquet.ParquetValueReaders.ReusableEntry
 
reuseContainers(boolean) - Method in class org.apache.iceberg.arrow.vectorized.VectorizedArrowReader
 
reuseContainers() - Method in class org.apache.iceberg.avro.Avro.ReadBuilder
 
reuseContainers(boolean) - Method in class org.apache.iceberg.avro.Avro.ReadBuilder
 
reuseContainers() - Method in class org.apache.iceberg.data.IcebergGenerics.ScanBuilder
 
reuseContainers(boolean) - Method in class org.apache.iceberg.mr.mapreduce.IcebergInputFormat.ConfigBuilder
 
reuseContainers() - Method in class org.apache.iceberg.parquet.Parquet.ReadBuilder
 
reuseContainers(boolean) - Method in interface org.apache.iceberg.parquet.VectorizedReader
Set up the reader to reuse the underlying containers used for storing batches
reuseOrCreate(Object) - Method in class org.apache.iceberg.avro.ValueReaders.StructReader
 
revertWith(Tasks.Task<I, ?>) - Method in class org.apache.iceberg.util.Tasks.Builder
 
RewriteFiles - Interface in org.apache.iceberg
API for replacing files in a table.
rewriteFiles(Set<DataFile>, Set<DataFile>) - Method in interface org.apache.iceberg.RewriteFiles
Add a rewrite that replaces one set of files with another set that contains the same data.
rewriteIf(Predicate<ManifestFile>) - Method in class org.apache.iceberg.actions.RewriteManifestsAction
Rewrites only manifests that match the given predicate.
rewriteIf(Predicate<ManifestFile>) - Method in class org.apache.iceberg.BaseRewriteManifests
 
rewriteIf(Predicate<ManifestFile>) - Method in interface org.apache.iceberg.RewriteManifests
Determines which existing ManifestFile for the table should be rewritten.
rewriteManifests() - Method in class org.apache.iceberg.actions.Actions
 
rewriteManifests() - Method in class org.apache.iceberg.BaseTable
 
RewriteManifests - Interface in org.apache.iceberg
API for rewriting manifests for a table.
rewriteManifests() - Method in interface org.apache.iceberg.Table
Create a new rewrite manifests API to replace manifests for this table and commit.
rewriteManifests() - Method in interface org.apache.iceberg.Transaction
Create a new rewrite manifests API to replace manifests for this table.
RewriteManifestsAction - Class in org.apache.iceberg.actions
An action that rewrites manifests in a distributed manner and co-locates metadata for partitions.
RewriteManifestsActionResult - Class in org.apache.iceberg.actions
 
RewriteManifestsActionResult(List<ManifestFile>, List<ManifestFile>) - Constructor for class org.apache.iceberg.actions.RewriteManifestsActionResult
 
rewriteNot(Expression) - Static method in class org.apache.iceberg.expressions.Expressions
 
right() - Method in class org.apache.iceberg.expressions.And
 
right() - Method in class org.apache.iceberg.expressions.Or
 
rollback() - Method in class org.apache.iceberg.BaseTable
 
Rollback - Interface in org.apache.iceberg
API for rolling table data back to the state at an older table snapshot.
rollback() - Method in interface org.apache.iceberg.Table
Deprecated.
rollbackTo(long) - Method in interface org.apache.iceberg.ManageSnapshots
Rollback table's state to a specific Snapshot identified by id.
rollbackTo(long) - Method in class org.apache.iceberg.SnapshotManager
 
rollbackToTime(long) - Method in interface org.apache.iceberg.ManageSnapshots
Roll this table's data back to the last Snapshot before the given timestamp.
rollbackToTime(long) - Method in class org.apache.iceberg.SnapshotManager
 
rows() - Method in interface org.apache.iceberg.DataTask
 
run(C) - Method in interface org.apache.iceberg.hive.ClientPool.Action
 
run(ClientPool.Action<R, C, E>) - Method in class org.apache.iceberg.hive.ClientPool
 
run(Tasks.Task<I, RuntimeException>) - Method in class org.apache.iceberg.util.Tasks.Builder
 
run(Tasks.Task<I, E>, Class<E>) - Method in class org.apache.iceberg.util.Tasks.Builder
 
run(I, Exception) - Method in interface org.apache.iceberg.util.Tasks.FailureTask
 
run(I) - Method in interface org.apache.iceberg.util.Tasks.Task
 
RuntimeIOException - Exception in org.apache.iceberg.exceptions
Exception used to wrap IOException as a RuntimeException and add context.
RuntimeIOException(IOException) - Constructor for exception org.apache.iceberg.exceptions.RuntimeIOException
 
RuntimeIOException(IOException, String, Object...) - Constructor for exception org.apache.iceberg.exceptions.RuntimeIOException
 
RuntimeIOException(String, Object...) - Constructor for exception org.apache.iceberg.exceptions.RuntimeIOException
 
RuntimeMetaException - Exception in org.apache.iceberg.hive
Exception used to wrap MetaException as a RuntimeException and add context.
RuntimeMetaException(MetaException) - Constructor for exception org.apache.iceberg.hive.RuntimeMetaException
 
RuntimeMetaException(MetaException, String, Object...) - Constructor for exception org.apache.iceberg.hive.RuntimeMetaException
 
RuntimeMetaException(Throwable, String, Object...) - Constructor for exception org.apache.iceberg.hive.RuntimeMetaException
 

S

scale() - Method in class org.apache.iceberg.types.Types.DecimalType
 
SCAN_THREAD_POOL_ENABLED - Static variable in class org.apache.iceberg.SystemProperties
Whether to use the shared worker pool when planning table scans.
ScanBuilder(Table) - Constructor for class org.apache.iceberg.data.IcebergGenerics.ScanBuilder
 
ScanEvent - Class in org.apache.iceberg.events
Event sent to listeners when a table scan is planned.
ScanEvent(String, long, Expression, Schema) - Constructor for class org.apache.iceberg.events.ScanEvent
 
ScanSummary - Class in org.apache.iceberg
 
ScanSummary.Builder - Class in org.apache.iceberg
 
ScanSummary.PartitionMetrics - Class in org.apache.iceberg
 
ScanTask - Interface in org.apache.iceberg
A scan task.
schema() - Method in class org.apache.iceberg.AllDataFilesTable
 
schema() - Method in class org.apache.iceberg.AllEntriesTable
 
schema() - Method in class org.apache.iceberg.AllManifestsTable
 
schema(Schema) - Method in class org.apache.iceberg.avro.Avro.WriteBuilder
 
schema() - Method in class org.apache.iceberg.BaseTable
 
schema() - Method in class org.apache.iceberg.DataFilesTable
 
schema() - Method in class org.apache.iceberg.HistoryTable
 
schema() - Method in class org.apache.iceberg.ManifestEntriesTable
 
SCHEMA - Static variable in interface org.apache.iceberg.ManifestFile
 
schema() - Static method in interface org.apache.iceberg.ManifestFile
 
schema() - Method in class org.apache.iceberg.ManifestReader
 
schema() - Method in class org.apache.iceberg.ManifestsTable
 
schema(Schema) - Method in class org.apache.iceberg.orc.ORC.WriteBuilder
 
schema(Schema) - Method in class org.apache.iceberg.parquet.Parquet.WriteBuilder
 
schema() - Method in class org.apache.iceberg.PartitionSpec
 
schema() - Method in class org.apache.iceberg.PartitionsTable
 
Schema - Class in org.apache.iceberg
The schema of a data table.
Schema(List<Types.NestedField>, Map<String, Integer>) - Constructor for class org.apache.iceberg.Schema
 
Schema(List<Types.NestedField>) - Constructor for class org.apache.iceberg.Schema
 
Schema(Types.NestedField...) - Constructor for class org.apache.iceberg.Schema
 
schema() - Method in class org.apache.iceberg.SnapshotsTable
 
schema(Schema, Supplier<Type>) - Method in class org.apache.iceberg.spark.PruneColumnsWithoutReordering
 
schema(Schema, Supplier<Type>) - Method in class org.apache.iceberg.spark.PruneColumnsWithReordering
 
schema() - Method in interface org.apache.iceberg.Table
Return the schema for this table.
schema() - Method in class org.apache.iceberg.TableMetadata
 
schema() - Method in interface org.apache.iceberg.TableScan
Returns this scan's projection Schema.
schema(Schema, Supplier<List<String>>) - Method in class org.apache.iceberg.types.CheckCompatibility
 
schema(Schema, Supplier<Map<String, Integer>>) - Method in class org.apache.iceberg.types.IndexByName
 
schema(Schema, Supplier<T>) - Method in class org.apache.iceberg.types.TypeUtil.CustomOrderSchemaVisitor
 
schema(Schema, T) - Method in class org.apache.iceberg.types.TypeUtil.SchemaVisitor
 
schemaForTable(SparkSession, String) - Static method in class org.apache.iceberg.spark.SparkSchemaUtil
Returns a Schema for the given table with fresh field ids.
SchemaParser - Class in org.apache.iceberg
 
SchemaUtil - Class in org.apache.iceberg.pig
 
SchemaVisitor() - Constructor for class org.apache.iceberg.types.TypeUtil.SchemaVisitor
 
second() - Method in class org.apache.iceberg.util.Pair
 
seek(long) - Method in class org.apache.iceberg.io.SeekableInputStream
Seek to a new position in the InputStream.
SeekableInputStream - Class in org.apache.iceberg.io
SeekableInputStream is an interface with the methods needed to read data from a file or Hadoop data stream.
SeekableInputStream() - Constructor for class org.apache.iceberg.io.SeekableInputStream
 
select(String...) - Method in class org.apache.iceberg.data.IcebergGenerics.ScanBuilder
 
select(String...) - Method in interface org.apache.iceberg.Filterable
Selects the columns of a file manifest to read.
select(Collection<String>) - Method in interface org.apache.iceberg.Filterable
Selects the columns of a file manifest to read.
select(Collection<String>) - Method in class org.apache.iceberg.FilteredManifest
 
select(Collection<String>) - Method in class org.apache.iceberg.ManifestReader
 
select(String...) - Method in class org.apache.iceberg.Schema
Creates a projection schema for a subset of columns, selected by name.
select(Collection<String>) - Method in class org.apache.iceberg.Schema
Creates a projection schema for a subset of columns, selected by name.
select(String...) - Method in interface org.apache.iceberg.TableScan
Create a new TableScan from this that will read the given data columns.
select(Collection<String>) - Method in interface org.apache.iceberg.TableScan
Create a new TableScan from this that will read the given data columns.
select(Schema, Set<Integer>) - Static method in class org.apache.iceberg.types.TypeUtil
 
selectNot(Schema, Set<Integer>) - Static method in class org.apache.iceberg.types.TypeUtil
 
self() - Method in class org.apache.iceberg.actions.RewriteManifestsAction
 
self() - Method in class org.apache.iceberg.BaseOverwriteFiles
 
self() - Method in class org.apache.iceberg.BaseReplacePartitions
 
self() - Method in class org.apache.iceberg.BaseRewriteManifests
 
self() - Method in class org.apache.iceberg.SnapshotManager
 
SEQUENCE_NUMBER - Static variable in interface org.apache.iceberg.ManifestFile
 
sequenceNumber() - Method in class org.apache.iceberg.GenericManifestFile
 
sequenceNumber() - Method in interface org.apache.iceberg.ManifestFile
 
sequenceNumber() - Method in interface org.apache.iceberg.Snapshot
Return this snapshot's sequence number.
SerializableConfiguration - Class in org.apache.iceberg.hadoop
Wraps a Configuration object in a Serializable layer.
SerializableConfiguration(Configuration) - Constructor for class org.apache.iceberg.hadoop.SerializableConfiguration
 
SerializableSupplier<T> - Interface in org.apache.iceberg.util
 
SerializationUtil - Class in org.apache.iceberg.mr
 
serializeToBase64(Object) - Static method in class org.apache.iceberg.mr.SerializationUtil
 
serializeToBytes(Object) - Static method in class org.apache.iceberg.mr.SerializationUtil
 
set(String, String) - Method in interface org.apache.iceberg.actions.SnapshotUpdateAction
 
set(String, String) - Method in class org.apache.iceberg.avro.Avro.WriteBuilder
 
set(S, int, Object) - Method in class org.apache.iceberg.avro.ValueReaders.StructReader
 
set(String, String) - Method in class org.apache.iceberg.BaseRewriteManifests
 
set(T) - Method in class org.apache.iceberg.common.DynFields.BoundField
 
set(T) - Method in class org.apache.iceberg.common.DynFields.StaticField
 
set(Object, T) - Method in class org.apache.iceberg.common.DynFields.UnboundField
 
set(int, T) - Method in class org.apache.iceberg.data.GenericRecord
 
set(int, T) - Method in class org.apache.iceberg.GenericManifestFile
 
set(int, T) - Method in class org.apache.iceberg.GenericPartitionFieldSummary
 
set(String, String) - Method in class org.apache.iceberg.parquet.Parquet.ReadBuilder
 
set(String, String) - Method in class org.apache.iceberg.parquet.Parquet.WriteBuilder
 
set(K, V) - Method in class org.apache.iceberg.parquet.ParquetValueReaders.ReusableEntry
 
set(I, int, Object) - Method in class org.apache.iceberg.parquet.ParquetValueReaders.StructReader
Used to set a struct value by position.
set(String, String) - Method in class org.apache.iceberg.SnapshotSummary.Builder
 
set(String, String) - Method in interface org.apache.iceberg.SnapshotUpdate
Set a summary property in the snapshot produced by this update.
set(int, T) - Method in class org.apache.iceberg.spark.SparkStructLike
 
set(int, T) - Method in interface org.apache.iceberg.StructLike
 
set(String, String) - Method in interface org.apache.iceberg.UpdateProperties
Add a key/value property to the table.
set(CharSequence) - Method in class org.apache.iceberg.util.CharSequenceWrapper
 
set(StructLike) - Method in class org.apache.iceberg.util.StructLikeWrapper
 
setAll(Map<String, String>) - Method in class org.apache.iceberg.avro.Avro.WriteBuilder
 
setAll(Map<String, String>) - Method in class org.apache.iceberg.orc.ORC.WriteBuilder
 
setAll(Map<String, String>) - Method in class org.apache.iceberg.parquet.Parquet.WriteBuilder
 
setAllPagesDictEncoded(boolean) - Method in class org.apache.iceberg.arrow.vectorized.parquet.VectorizedPageIterator
 
setBoolean(I, int, boolean) - Method in class org.apache.iceberg.parquet.ParquetValueReaders.StructReader
 
setColumnStore(ColumnWriteStore) - Method in class org.apache.iceberg.parquet.ColumnWriter
 
setColumnStore(ColumnWriteStore) - Method in interface org.apache.iceberg.parquet.ParquetValueWriter
 
setColumnStore(ColumnWriteStore) - Method in class org.apache.iceberg.parquet.ParquetValueWriters.PrimitiveWriter
 
setColumnStore(ColumnWriteStore) - Method in class org.apache.iceberg.parquet.ParquetValueWriters.RepeatedKeyValueWriter
 
setColumnStore(ColumnWriteStore) - Method in class org.apache.iceberg.parquet.ParquetValueWriters.RepeatedWriter
 
setColumnStore(ColumnWriteStore) - Method in class org.apache.iceberg.parquet.ParquetValueWriters.StructWriter
 
setConf(Configuration) - Method in class org.apache.iceberg.hadoop.HadoopTables
 
setCurrentSnapshot(long) - Method in interface org.apache.iceberg.ManageSnapshots
Roll this table's data back to a specific Snapshot identified by id.
setCurrentSnapshot(long) - Method in class org.apache.iceberg.SnapshotManager
 
setDictionary(Dictionary) - Method in class org.apache.iceberg.parquet.BasePageIterator
 
setDouble(I, int, double) - Method in class org.apache.iceberg.parquet.ParquetValueReaders.StructReader
 
setField(String, Object) - Method in class org.apache.iceberg.data.GenericRecord
 
setField(String, Object) - Method in interface org.apache.iceberg.data.Record
 
setFloat(I, int, float) - Method in class org.apache.iceberg.parquet.ParquetValueReaders.StructReader
 
setInteger(I, int, int) - Method in class org.apache.iceberg.parquet.ParquetValueReaders.StructReader
 
setLocation(String, Job) - Method in class org.apache.iceberg.pig.IcebergStorage
 
SetLocation - Class in org.apache.iceberg
 
SetLocation(TableOperations) - Constructor for class org.apache.iceberg.SetLocation
 
setLocation(String) - Method in class org.apache.iceberg.SetLocation
 
setLocation(String) - Method in interface org.apache.iceberg.UpdateLocation
Set the table's location.
setLong(I, int, long) - Method in class org.apache.iceberg.parquet.ParquetValueReaders.StructReader
 
setNotNull(int) - Method in class org.apache.iceberg.arrow.vectorized.NullabilityHolder
 
setNotNulls(int, int) - Method in class org.apache.iceberg.arrow.vectorized.NullabilityHolder
 
setNull(int) - Method in class org.apache.iceberg.arrow.vectorized.NullabilityHolder
 
setNull(I, int) - Method in class org.apache.iceberg.parquet.ParquetValueReaders.StructReader
 
setNullabilityHolder(NullabilityHolder) - Method in class org.apache.iceberg.arrow.vectorized.IcebergArrowVectors.DecimalArrowVector
 
setNullabilityHolder(NullabilityHolder) - Method in class org.apache.iceberg.arrow.vectorized.IcebergArrowVectors.VarBinaryArrowVector
 
setNullabilityHolder(NullabilityHolder) - Method in class org.apache.iceberg.arrow.vectorized.IcebergArrowVectors.VarcharArrowVector
 
setNulls(int, int) - Method in class org.apache.iceberg.arrow.vectorized.NullabilityHolder
 
setPage(DataPage) - Method in class org.apache.iceberg.parquet.BasePageIterator
 
setPageSource(PageReader) - Method in class org.apache.iceberg.parquet.BaseColumnIterator
 
setPageSource(PageReadStore) - Method in interface org.apache.iceberg.parquet.ParquetValueReader
 
setPageSource(PageReadStore) - Method in class org.apache.iceberg.parquet.ParquetValueReaders.PrimitiveReader
 
setPageSource(PageReadStore) - Method in class org.apache.iceberg.parquet.ParquetValueReaders.RepeatedKeyValueReader
 
setPageSource(PageReadStore) - Method in class org.apache.iceberg.parquet.ParquetValueReaders.RepeatedReader
 
setPageSource(PageReadStore) - Method in class org.apache.iceberg.parquet.ParquetValueReaders.StructReader
 
setPartitionFilter(Expression) - Method in class org.apache.iceberg.pig.IcebergStorage
 
setProperties(Namespace, Map<String, String>) - Method in interface org.apache.iceberg.catalog.SupportsNamespaces
Apply a set of metadata to a namespace in the catalog.
setProperties(Namespace, Map<String, String>) - Method in class org.apache.iceberg.hadoop.HadoopCatalog
 
setProperties(Namespace, Map<String, String>) - Method in class org.apache.iceberg.hive.HiveCatalog
 
setPushdownPredicate(Expression) - Method in class org.apache.iceberg.pig.IcebergStorage
 
setRowGroupInfo(PageReader, boolean) - Method in class org.apache.iceberg.arrow.vectorized.parquet.VectorizedColumnIterator
 
setRowGroupInfo(PageReadStore, Map<ColumnPath, ColumnChunkMetaData>) - Method in class org.apache.iceberg.arrow.vectorized.VectorizedArrowReader
 
setRowGroupInfo(PageReadStore, Map<ColumnPath, ColumnChunkMetaData>) - Method in interface org.apache.iceberg.parquet.VectorizedReader
 
setSchema(Schema) - Method in class org.apache.iceberg.avro.ProjectionDatumReader
 
setSchema(Schema) - Method in class org.apache.iceberg.data.avro.DataReader
 
setSchema(Schema) - Method in class org.apache.iceberg.data.avro.DataWriter
 
setSchema(Schema) - Method in class org.apache.iceberg.spark.data.SparkAvroReader
 
setSchema(Schema) - Method in class org.apache.iceberg.spark.data.SparkAvroWriter
 
setUDFContextSignature(String) - Method in class org.apache.iceberg.pig.IcebergStorage
 
setValue(V) - Method in class org.apache.iceberg.parquet.ParquetValueReaders.ReusableEntry
 
shortName() - Method in class org.apache.iceberg.spark.source.IcebergSource
 
shouldAdjustToUTC() - Method in class org.apache.iceberg.types.Types.TimestampType
 
shouldRead(MessageType, BlockMetaData, DictionaryPageReadStore) - Method in class org.apache.iceberg.parquet.ParquetDictionaryRowGroupFilter
Test whether the dictionaries for a row group may contain records that match the expression.
shouldRead(MessageType, BlockMetaData) - Method in class org.apache.iceberg.parquet.ParquetMetricsRowGroupFilter
Test whether the file may contain records that match the expression.
shouldRetryTest(Predicate<Exception>) - Method in class org.apache.iceberg.util.Tasks.Builder
 
signedBytes() - Static method in class org.apache.iceberg.types.Comparators
 
size() - Method in class org.apache.iceberg.data.GenericRecord
 
size() - Method in class org.apache.iceberg.GenericManifestFile
 
size() - Method in class org.apache.iceberg.GenericPartitionFieldSummary
 
size() - Method in class org.apache.iceberg.mapping.MappedFields
 
size() - Method in class org.apache.iceberg.spark.SparkStructLike
 
size() - Method in interface org.apache.iceberg.StructLike
 
size() - Method in class org.apache.iceberg.util.CharSequenceSet
 
skip() - Method in class org.apache.iceberg.arrow.vectorized.parquet.BaseVectorizedParquetValuesReader
 
skip() - Method in class org.apache.iceberg.parquet.ValuesAsBytesReader
 
skipResidualFiltering() - Method in class org.apache.iceberg.mr.mapreduce.IcebergInputFormat.ConfigBuilder
Compute platforms pass down filters to data sources.
snapshot(long) - Method in class org.apache.iceberg.BaseTable
 
Snapshot - Interface in org.apache.iceberg
A snapshot of the data in a table at a point in time.
snapshot(long) - Method in interface org.apache.iceberg.Table
Get the snapshot of this table with the given id, or null if there is no matching snapshot.
snapshot(long) - Method in class org.apache.iceberg.TableMetadata
 
snapshot() - Method in interface org.apache.iceberg.TableScan
Returns the Snapshot that will be used by this scan.
SNAPSHOT_ID - Static variable in interface org.apache.iceberg.ManifestFile
 
SNAPSHOT_ID_INHERITANCE_ENABLED - Static variable in class org.apache.iceberg.TableProperties
 
SNAPSHOT_ID_INHERITANCE_ENABLED_DEFAULT - Static variable in class org.apache.iceberg.TableProperties
 
snapshotId() - Method in class org.apache.iceberg.events.ScanEvent
 
snapshotId() - Method in class org.apache.iceberg.GenericManifestFile
 
snapshotId() - Method in interface org.apache.iceberg.HistoryEntry
 
snapshotId() - Method in interface org.apache.iceberg.ManifestFile
 
snapshotId(long) - Method in class org.apache.iceberg.mr.mapreduce.IcebergInputFormat.ConfigBuilder
 
snapshotId() - Method in interface org.apache.iceberg.Snapshot
Return this snapshot's ID.
snapshotId() - Method in class org.apache.iceberg.TableMetadata.SnapshotLogEntry
 
snapshotIdsBetween(Table, long, long) - Static method in class org.apache.iceberg.util.SnapshotUtil
 
snapshotLog() - Method in class org.apache.iceberg.TableMetadata
 
SnapshotManager - Class in org.apache.iceberg
 
SnapshotParser - Class in org.apache.iceberg
 
snapshots() - Method in class org.apache.iceberg.BaseTable
 
snapshots() - Method in interface org.apache.iceberg.Table
Get the snapshots of this table.
snapshots() - Method in class org.apache.iceberg.TableMetadata
 
SnapshotsTable - Class in org.apache.iceberg
A Table implementation that exposes a table's known snapshots as rows.
SnapshotsTable(TableOperations, Table) - Constructor for class org.apache.iceberg.SnapshotsTable
 
SnapshotSummary - Class in org.apache.iceberg
 
SnapshotSummary.Builder - Class in org.apache.iceberg
 
SnapshotUpdate<ThisT> - Interface in org.apache.iceberg
API for table changes that produce snapshots.
SnapshotUpdateAction<ThisT,R> - Interface in org.apache.iceberg.actions
 
SnapshotUtil - Class in org.apache.iceberg.util
 
SOURCE_SNAPSHOT_ID_PROP - Static variable in class org.apache.iceberg.SnapshotSummary
 
sourceId() - Method in class org.apache.iceberg.PartitionField
 
SparkAvroReader - Class in org.apache.iceberg.spark.data
 
SparkAvroReader(Schema, Schema) - Constructor for class org.apache.iceberg.spark.data.SparkAvroReader
 
SparkAvroReader(Schema, Schema, Map<Integer, ?>) - Constructor for class org.apache.iceberg.spark.data.SparkAvroReader
 
SparkAvroWriter - Class in org.apache.iceberg.spark.data
 
SparkAvroWriter(Schema) - Constructor for class org.apache.iceberg.spark.data.SparkAvroWriter
 
SparkDataFile - Class in org.apache.iceberg.spark
 
SparkDataFile(Types.StructType, StructType) - Constructor for class org.apache.iceberg.spark.SparkDataFile
 
SparkFilters - Class in org.apache.iceberg.spark
 
SparkOrcReader - Class in org.apache.iceberg.spark.data
Converts the OrcInterator, which returns ORC's VectorizedRowBatch to a set of Spark's UnsafeRows.
SparkOrcReader(TypeDescription) - Constructor for class org.apache.iceberg.spark.data.SparkOrcReader
 
SparkOrcWriter - Class in org.apache.iceberg.spark.data
This class acts as an adaptor from an OrcFileAppender to a FileAppender<InternalRow>.
SparkOrcWriter(TypeDescription) - Constructor for class org.apache.iceberg.spark.data.SparkOrcWriter
 
SparkParquetReaders - Class in org.apache.iceberg.spark.data
 
SparkParquetWriters - Class in org.apache.iceberg.spark.data
 
SparkSchemaUtil - Class in org.apache.iceberg.spark
Helper methods for working with Spark/Hive metadata.
SparkStructLike - Class in org.apache.iceberg.spark
 
SparkStructLike(Types.StructType) - Constructor for class org.apache.iceberg.spark.SparkStructLike
 
SparkValueConverter - Class in org.apache.iceberg.spark
A utility class that converts Spark values to Iceberg's internal representation.
SparkValueReaders - Class in org.apache.iceberg.spark.data
 
SparkValueWriters - Class in org.apache.iceberg.spark.data
 
spec() - Method in class org.apache.iceberg.BaseTable
 
spec() - Method in interface org.apache.iceberg.FileScanTask
The spec used to store this file.
spec() - Method in class org.apache.iceberg.ManifestReader
 
spec() - Method in interface org.apache.iceberg.Table
Return the partition spec for this table.
spec() - Method in class org.apache.iceberg.TableMetadata
 
spec(int) - Method in class org.apache.iceberg.TableMetadata
 
SPEC_ID - Static variable in interface org.apache.iceberg.ManifestFile
 
specForTable(SparkSession, String) - Static method in class org.apache.iceberg.spark.SparkSchemaUtil
Returns a PartitionSpec for the given table.
specId(int) - Method in class org.apache.iceberg.actions.RewriteManifestsAction
 
specId() - Method in class org.apache.iceberg.PartitionSpec
 
specs() - Method in class org.apache.iceberg.BaseTable
 
specs() - Method in interface org.apache.iceberg.Table
Return a map of partition specs for this table.
specs() - Method in class org.apache.iceberg.TableMetadata
 
specsById() - Method in class org.apache.iceberg.TableMetadata
 
split(long, long) - Method in class org.apache.iceberg.avro.Avro.ReadBuilder
Restricts the read to the given range: [start, end = start + length).
split(long) - Method in interface org.apache.iceberg.FileScanTask
Splits this scan task into component scan tasks, each of splitSize size
split(long, long) - Method in class org.apache.iceberg.orc.ORC.ReadBuilder
Restricts the read to the given range: [start, start + length).
split(long, long) - Method in class org.apache.iceberg.parquet.Parquet.ReadBuilder
Restricts the read to the given range: [start, start + length).
SPLIT_LOOKBACK - Static variable in class org.apache.iceberg.TableProperties
 
SPLIT_LOOKBACK_DEFAULT - Static variable in class org.apache.iceberg.TableProperties
 
SPLIT_OPEN_FILE_COST - Static variable in class org.apache.iceberg.TableProperties
 
SPLIT_OPEN_FILE_COST_DEFAULT - Static variable in class org.apache.iceberg.TableProperties
 
SPLIT_SIZE - Static variable in class org.apache.iceberg.TableProperties
 
SPLIT_SIZE_DEFAULT - Static variable in class org.apache.iceberg.TableProperties
 
splitOffsets() - Method in interface org.apache.iceberg.DataFile
 
splitOffsets() - Method in interface org.apache.iceberg.io.FileAppender
 
splitOffsets() - Method in class org.apache.iceberg.parquet.ParquetWriteAdapter
 
splitOffsets() - Method in class org.apache.iceberg.spark.SparkDataFile
 
splitSize(long) - Method in class org.apache.iceberg.mr.mapreduce.IcebergInputFormat.ConfigBuilder
 
STAGED_WAP_ID_PROP - Static variable in class org.apache.iceberg.SnapshotSummary
 
stagedWapId(Snapshot) - Static method in class org.apache.iceberg.util.WapUtil
 
stageOnly() - Method in interface org.apache.iceberg.SnapshotUpdate
Called to stage a snapshot in table metadata, but not update the current snapshot id.
stagingLocation(String) - Method in class org.apache.iceberg.actions.RewriteManifestsAction
Passes a location where the manifests should be written.
start() - Method in interface org.apache.iceberg.FileScanTask
The starting position of this scan range in the file.
startsWith(String, String) - Static method in class org.apache.iceberg.expressions.Expressions
 
startsWith(UnboundTerm<String>, String) - Static method in class org.apache.iceberg.expressions.Expressions
 
startsWith(BoundReference<T>, Literal<T>) - Method in class org.apache.iceberg.expressions.ExpressionVisitors.BoundExpressionVisitor
Deprecated.
 
startsWith(Bound<T>, Literal<T>) - Method in class org.apache.iceberg.expressions.ExpressionVisitors.BoundVisitor
 
stopAbortsOnFailure() - Method in class org.apache.iceberg.util.Tasks.Builder
 
stopOnFailure() - Method in class org.apache.iceberg.util.Tasks.Builder
 
stopRetryOn(Class<? extends Exception>...) - Method in class org.apache.iceberg.util.Tasks.Builder
 
stopRevertsOnFailure() - Method in class org.apache.iceberg.util.Tasks.Builder
 
StreamingWriter - Class in org.apache.iceberg.spark.source
 
strict(PartitionSpec) - Static method in class org.apache.iceberg.expressions.Projections
Creates a strict ProjectionEvaluator for the spec, defaulting to case sensitive mode.
strict(PartitionSpec, boolean) - Static method in class org.apache.iceberg.expressions.Projections
Creates a strict ProjectionEvaluator for the spec.
StrictMetricsEvaluator - Class in org.apache.iceberg.expressions
Evaluates an Expression on a DataFile to test whether all rows in the file match.
StrictMetricsEvaluator(Schema, Expression) - Constructor for class org.apache.iceberg.expressions.StrictMetricsEvaluator
 
StringReader(ColumnDescriptor) - Constructor for class org.apache.iceberg.parquet.ParquetValueReaders.StringReader
 
strings() - Static method in class org.apache.iceberg.avro.ValueReaders
 
strings() - Static method in class org.apache.iceberg.avro.ValueWriters
 
strings(ColumnDescriptor) - Static method in class org.apache.iceberg.parquet.ParquetValueWriters
 
StringType() - Constructor for class org.apache.iceberg.types.Types.StringType
 
struct() - Method in class org.apache.iceberg.data.GenericRecord
 
struct() - Method in interface org.apache.iceberg.data.Record
 
struct(GroupType, List<T>) - Method in class org.apache.iceberg.parquet.ParquetTypeVisitor
 
struct(Types.StructType, Type.Repetition, int, String) - Method in class org.apache.iceberg.parquet.TypeToMessageType
 
struct(Types.StructType, GroupType, List<T>) - Method in class org.apache.iceberg.parquet.TypeWithSchemaVisitor
 
struct(Types.StructType, Iterable<Type>) - Method in class org.apache.iceberg.spark.PruneColumnsWithoutReordering
 
struct(Types.StructType, Iterable<Type>) - Method in class org.apache.iceberg.spark.PruneColumnsWithReordering
 
struct(Types.StructType, Iterable<List<String>>) - Method in class org.apache.iceberg.types.CheckCompatibility
 
struct(Types.StructType, Iterable<Map<String, Integer>>) - Method in class org.apache.iceberg.types.IndexByName
 
struct(Types.StructType, Iterable<T>) - Method in class org.apache.iceberg.types.TypeUtil.CustomOrderSchemaVisitor
 
struct(Types.StructType, List<T>) - Method in class org.apache.iceberg.types.TypeUtil.SchemaVisitor
 
StructLike - Interface in org.apache.iceberg
Interface for accessing data by position in a schema.
StructLikeWrapper - Class in org.apache.iceberg.util
Wrapper to adapt StructLike for use in maps and sets by implementing equals and hashCode.
StructReader(List<ValueReader<?>>) - Constructor for class org.apache.iceberg.avro.ValueReaders.StructReader
 
StructReader(List<ValueReader<?>>, Types.StructType, Map<Integer, ?>) - Constructor for class org.apache.iceberg.avro.ValueReaders.StructReader
 
StructReader(List<Type>, List<ParquetValueReader<?>>) - Constructor for class org.apache.iceberg.parquet.ParquetValueReaders.StructReader
 
StructWriter(List<ValueWriter<?>>) - Constructor for class org.apache.iceberg.avro.ValueWriters.StructWriter
 
StructWriter(List<ParquetValueWriter<?>>) - Constructor for class org.apache.iceberg.parquet.ParquetValueWriters.StructWriter
 
subSequence(int, int) - Method in class org.apache.iceberg.util.CharSequenceWrapper
 
summary() - Method in class org.apache.iceberg.BaseRewriteManifests
 
summary() - Method in interface org.apache.iceberg.Snapshot
Return a string map of summary data for the operation that produced this snapshot.
SupportsNamespaces - Interface in org.apache.iceberg.catalog
Catalog methods for working with namespaces.
suppressAndThrow(E, Runnable) - Static method in class org.apache.iceberg.util.Exceptions
 
suppressExceptions(E, Runnable) - Static method in class org.apache.iceberg.util.Exceptions
 
suppressFailureWhenFinished() - Method in class org.apache.iceberg.util.Tasks.Builder
 
SystemProperties - Class in org.apache.iceberg
Configuration properties that are controlled by Java system properties.

T

table() - Method in class org.apache.iceberg.actions.RemoveOrphanFilesAction
 
table() - Method in class org.apache.iceberg.actions.RewriteManifestsAction
 
table(Table) - Static method in class org.apache.iceberg.FileHistory
 
Table - Interface in org.apache.iceberg
Represents a table.
table() - Method in interface org.apache.iceberg.TableScan
Returns the Table from which this scan loads data.
table() - Method in interface org.apache.iceberg.Transaction
Return the Table that this transaction will update.
TABLE_TYPE_PROP - Static variable in class org.apache.iceberg.BaseMetastoreTableOperations
 
tableExists(TableIdentifier) - Method in interface org.apache.iceberg.catalog.Catalog
Check whether table exists.
TableIdentifier - Class in org.apache.iceberg.catalog
Identifies a table in iceberg catalog.
TableMetadata - Class in org.apache.iceberg
Metadata for a table.
TableMetadata.MetadataLogEntry - Class in org.apache.iceberg
 
TableMetadata.SnapshotLogEntry - Class in org.apache.iceberg
 
TableMetadataParser - Class in org.apache.iceberg
 
TableMetadataParser.Codec - Enum in org.apache.iceberg
 
tableName() - Method in class org.apache.iceberg.events.ScanEvent
 
TableOperations - Interface in org.apache.iceberg
SPI interface to abstract table metadata access and updates.
TableProperties - Class in org.apache.iceberg
 
Tables - Interface in org.apache.iceberg
Generic interface for creating and loading a table implementation.
TableScan - Interface in org.apache.iceberg
API for configuring a table scan.
targetSplitSize(TableOperations) - Method in class org.apache.iceberg.AllDataFilesTable.AllDataFilesTableScan
 
targetSplitSize(TableOperations) - Method in class org.apache.iceberg.AllManifestsTable.AllManifestsTableScan
 
targetSplitSize(TableOperations) - Method in class org.apache.iceberg.DataFilesTable.FilesTableScan
 
targetSplitSize(TableOperations) - Method in class org.apache.iceberg.DataTableScan
 
task(TableScan) - Method in class org.apache.iceberg.ManifestsTable
 
Tasks - Class in org.apache.iceberg.util
 
Tasks.Builder<I> - Class in org.apache.iceberg.util
 
Tasks.FailureTask<I,E extends java.lang.Exception> - Interface in org.apache.iceberg.util
 
Tasks.Task<I,E extends java.lang.Exception> - Interface in org.apache.iceberg.util
 
Tasks.UnrecoverableException - Exception in org.apache.iceberg.util
 
temp(TableMetadata) - Method in class org.apache.iceberg.BaseMetastoreTableOperations
 
temp(TableMetadata) - Method in class org.apache.iceberg.hadoop.HadoopTableOperations
 
temp(TableMetadata) - Method in interface org.apache.iceberg.TableOperations
Return a temporary TableOperations instance that uses configuration from uncommitted metadata.
term() - Method in class org.apache.iceberg.expressions.Predicate
 
Term - Interface in org.apache.iceberg.expressions
An expression that evaluates to a value.
test(T) - Method in class org.apache.iceberg.expressions.BoundLiteralPredicate
 
test(StructLike) - Method in class org.apache.iceberg.expressions.BoundPredicate
 
test(T) - Method in class org.apache.iceberg.expressions.BoundPredicate
 
test(T) - Method in class org.apache.iceberg.expressions.BoundSetPredicate
 
test(T) - Method in class org.apache.iceberg.expressions.BoundUnaryPredicate
 
ThreadPools - Class in org.apache.iceberg.util
 
throwFailureWhenFinished() - Method in class org.apache.iceberg.util.Tasks.Builder
 
throwFailureWhenFinished(boolean) - Method in class org.apache.iceberg.util.Tasks.Builder
 
throwIfLimited() - Method in class org.apache.iceberg.ScanSummary.Builder
 
timeFromMicros(long) - Static method in class org.apache.iceberg.data.DateTimeUtil
 
timestampFromMicros(long) - Static method in class org.apache.iceberg.data.DateTimeUtil
 
timestampMillis() - Method in interface org.apache.iceberg.HistoryEntry
 
timestampMillis() - Method in interface org.apache.iceberg.Snapshot
Return this snapshot's timestamp.
timestampMillis() - Method in class org.apache.iceberg.TableMetadata.MetadataLogEntry
 
timestampMillis() - Method in class org.apache.iceberg.TableMetadata.SnapshotLogEntry
 
timestamptzFromMicros(long) - Static method in class org.apache.iceberg.data.DateTimeUtil
 
to(Type) - Method in interface org.apache.iceberg.expressions.Literal
Converts this literal to a literal of the given type.
toArray() - Method in class org.apache.iceberg.util.CharSequenceSet
 
toArray(T[]) - Method in class org.apache.iceberg.util.CharSequenceSet
 
toByteArray(ByteBuffer) - Static method in class org.apache.iceberg.util.ByteBuffers
 
toByteBuffer() - Method in interface org.apache.iceberg.expressions.Literal
Serializes the value wrapped by this literal to binary using the single-value serialization format described in the Iceberg table specification.
toByteBuffer(Type, Object) - Static method in class org.apache.iceberg.types.Conversions
 
toByteBuffer(Type.TypeID, Object) - Static method in class org.apache.iceberg.types.Conversions
 
toFixed(UUID, Schema, LogicalType) - Method in class org.apache.iceberg.avro.UUIDConversion
 
toHumanString(T) - Method in interface org.apache.iceberg.transforms.Transform
Returns a human-readable String representation of a transformed value.
toIceberg(Schema) - Static method in class org.apache.iceberg.avro.AvroSchemaUtil
 
toInputFile() - Method in class org.apache.iceberg.hadoop.HadoopOutputFile
 
toInputFile() - Method in interface org.apache.iceberg.io.OutputFile
Return an InputFile for the location of this output file.
toJson(NameMapping) - Static method in class org.apache.iceberg.mapping.NameMappingParser
 
toJson(PartitionSpec, JsonGenerator) - Static method in class org.apache.iceberg.PartitionSpecParser
 
toJson(PartitionSpec) - Static method in class org.apache.iceberg.PartitionSpecParser
 
toJson(PartitionSpec, boolean) - Static method in class org.apache.iceberg.PartitionSpecParser
 
toJson(Schema, JsonGenerator) - Static method in class org.apache.iceberg.SchemaParser
 
toJson(Schema) - Static method in class org.apache.iceberg.SchemaParser
 
toJson(Schema, boolean) - Static method in class org.apache.iceberg.SchemaParser
 
toJson(Snapshot) - Static method in class org.apache.iceberg.SnapshotParser
 
toJson(TableMetadata) - Static method in class org.apache.iceberg.TableMetadataParser
 
toLowerCase() - Method in class org.apache.iceberg.catalog.TableIdentifier
 
toManifestFile() - Method in class org.apache.iceberg.ManifestWriter
 
toPosition(Accessor<StructLike>) - Static method in class org.apache.iceberg.Accessors
 
toSnapshotAtTime(long) - Method in interface org.apache.iceberg.Rollback
Deprecated.
toSnapshotId(long) - Method in interface org.apache.iceberg.Rollback
toString() - Method in class org.apache.iceberg.arrow.vectorized.VectorizedArrowReader
 
toString() - Method in class org.apache.iceberg.BaseCombinedScanTask
 
toString() - Method in class org.apache.iceberg.BaseMetastoreCatalog
 
toString() - Method in class org.apache.iceberg.BaseTable
 
toString() - Method in class org.apache.iceberg.catalog.Namespace
 
toString() - Method in class org.apache.iceberg.catalog.TableIdentifier
 
toString() - Method in class org.apache.iceberg.common.DynConstructors.Ctor
 
toString() - Method in class org.apache.iceberg.common.DynFields.UnboundField
 
toString() - Method in class org.apache.iceberg.common.DynMethods.UnboundMethod
 
toString() - Method in class org.apache.iceberg.data.GenericRecord
 
toString() - Method in class org.apache.iceberg.expressions.And
 
toString() - Method in class org.apache.iceberg.expressions.BoundLiteralPredicate
 
toString() - Method in class org.apache.iceberg.expressions.BoundReference
 
toString() - Method in class org.apache.iceberg.expressions.BoundSetPredicate
 
toString() - Method in class org.apache.iceberg.expressions.BoundTransform
 
toString() - Method in class org.apache.iceberg.expressions.BoundUnaryPredicate
 
toString() - Method in class org.apache.iceberg.expressions.False
 
toString() - Method in class org.apache.iceberg.expressions.NamedReference
 
toString() - Method in class org.apache.iceberg.expressions.Not
 
toString() - Method in class org.apache.iceberg.expressions.Or
 
toString() - Method in class org.apache.iceberg.expressions.True
 
toString() - Method in class org.apache.iceberg.expressions.UnboundPredicate
 
toString() - Method in class org.apache.iceberg.expressions.UnboundTransform
 
toString() - Method in class org.apache.iceberg.GenericManifestFile
 
toString() - Method in class org.apache.iceberg.GenericPartitionFieldSummary
 
toString() - Method in class org.apache.iceberg.hadoop.HadoopInputFile
 
toString() - Method in class org.apache.iceberg.hadoop.HadoopOutputFile
 
toString() - Method in class org.apache.iceberg.mapping.MappedField
 
toString() - Method in class org.apache.iceberg.mapping.MappedFields
 
toString() - Method in class org.apache.iceberg.mapping.NameMapping
 
toString() - Method in class org.apache.iceberg.MetricsModes.Counts
 
toString() - Method in class org.apache.iceberg.MetricsModes.Full
 
toString() - Method in class org.apache.iceberg.MetricsModes.None
 
toString() - Method in class org.apache.iceberg.MetricsModes.Truncate
 
toString() - Method in class org.apache.iceberg.PartitionField
 
toString() - Method in class org.apache.iceberg.PartitionSpec
 
toString() - Method in class org.apache.iceberg.ScanSummary.PartitionMetrics
 
toString() - Method in class org.apache.iceberg.Schema
 
toString() - Method in class org.apache.iceberg.TableMetadata.MetadataLogEntry
 
toString() - Method in class org.apache.iceberg.TableMetadata.SnapshotLogEntry
 
toString() - Method in class org.apache.iceberg.transforms.UnknownTransform
 
toString() - Method in class org.apache.iceberg.types.Types.BinaryType
 
toString() - Method in class org.apache.iceberg.types.Types.BooleanType
 
toString() - Method in class org.apache.iceberg.types.Types.DateType
 
toString() - Method in class org.apache.iceberg.types.Types.DecimalType
 
toString() - Method in class org.apache.iceberg.types.Types.DoubleType
 
toString() - Method in class org.apache.iceberg.types.Types.FixedType
 
toString() - Method in class org.apache.iceberg.types.Types.FloatType
 
toString() - Method in class org.apache.iceberg.types.Types.IntegerType
 
toString() - Method in class org.apache.iceberg.types.Types.ListType
 
toString() - Method in class org.apache.iceberg.types.Types.LongType
 
toString() - Method in class org.apache.iceberg.types.Types.MapType
 
toString() - Method in class org.apache.iceberg.types.Types.NestedField
 
toString() - Method in class org.apache.iceberg.types.Types.StringType
 
toString() - Method in class org.apache.iceberg.types.Types.StructType
 
toString() - Method in class org.apache.iceberg.types.Types.TimestampType
 
toString() - Method in class org.apache.iceberg.types.Types.TimeType
 
toString() - Method in class org.apache.iceberg.types.Types.UUIDType
 
toString() - Method in class org.apache.iceberg.util.CharSequenceWrapper
 
toString() - Method in class org.apache.iceberg.util.Pair
 
TOTAL_FILES_PROP - Static variable in class org.apache.iceberg.SnapshotSummary
 
TOTAL_RECORDS_PROP - Static variable in class org.apache.iceberg.SnapshotSummary
 
totalSize() - Method in class org.apache.iceberg.ScanSummary.PartitionMetrics
 
Transaction - Interface in org.apache.iceberg
A transaction for performing multiple updates to a table.
Transactions - Class in org.apache.iceberg
 
transform() - Method in class org.apache.iceberg.expressions.BoundTransform
 
transform() - Method in class org.apache.iceberg.expressions.UnboundTransform
 
transform(CloseableIterable<I>, Function<I, O>) - Static method in interface org.apache.iceberg.io.CloseableIterable
 
transform() - Method in class org.apache.iceberg.PartitionField
 
Transform<S,T> - Interface in org.apache.iceberg.transforms
A transform function used for partitioning.
Transforms - Class in org.apache.iceberg.transforms
Factory methods for transforms.
triplesCount - Variable in class org.apache.iceberg.parquet.BaseColumnIterator
 
triplesCount - Variable in class org.apache.iceberg.parquet.BasePageIterator
 
triplesRead - Variable in class org.apache.iceberg.parquet.BaseColumnIterator
 
triplesRead - Variable in class org.apache.iceberg.parquet.BasePageIterator
 
TripleWriter<T> - Interface in org.apache.iceberg.parquet
 
True - Class in org.apache.iceberg.expressions
An expression that is always true.
truncate(String, int) - Static method in class org.apache.iceberg.expressions.Expressions
 
truncate(String, int, String) - Method in class org.apache.iceberg.PartitionSpec.Builder
 
truncate(String, int) - Method in class org.apache.iceberg.PartitionSpec.Builder
 
truncate(String, int, int) - Method in interface org.apache.iceberg.transforms.PartitionSpecVisitor
 
truncate(Type, int) - Static method in class org.apache.iceberg.transforms.Transforms
Returns a truncate Transform for the given type and width.
truncateBinary(ByteBuffer, int) - Static method in class org.apache.iceberg.util.BinaryUtil
Truncates the input byte buffer to the given length
truncateBinaryMax(Literal<ByteBuffer>, int) - Static method in class org.apache.iceberg.util.BinaryUtil
Returns a byte buffer whose length is lesser than or equal to truncateLength and is greater than the given input
truncateBinaryMin(Literal<ByteBuffer>, int) - Static method in class org.apache.iceberg.util.BinaryUtil
Returns a byte buffer whose length is lesser than or equal to truncateLength and is lower than the given input
truncateString(CharSequence, int) - Static method in class org.apache.iceberg.util.UnicodeUtil
Truncates the input charSequence such that the truncated charSequence is a valid unicode string and the number of unicode characters in the truncated charSequence is lesser than or equal to length
truncateStringMax(Literal<CharSequence>, int) - Static method in class org.apache.iceberg.util.UnicodeUtil
Returns a valid unicode charsequence that is greater than the given input such that the number of unicode characters in the truncated charSequence is lesser than or equal to length
truncateStringMin(Literal<CharSequence>, int) - Static method in class org.apache.iceberg.util.UnicodeUtil
Returns a valid unicode charsequence that is lower than the given input such that the number of unicode characters in the truncated charSequence is lesser than or equal to length
type() - Method in interface org.apache.iceberg.Accessor
 
type() - Method in class org.apache.iceberg.expressions.BoundReference
 
type() - Method in interface org.apache.iceberg.expressions.BoundTerm
 
type() - Method in class org.apache.iceberg.expressions.BoundTransform
 
Type - Interface in org.apache.iceberg.types
 
type() - Method in class org.apache.iceberg.types.Types.NestedField
 
Type.NestedType - Class in org.apache.iceberg.types
 
Type.PrimitiveType - Class in org.apache.iceberg.types
 
Type.TypeID - Enum in org.apache.iceberg.types
 
typeCompatibilityErrors(Schema, Schema, boolean) - Static method in class org.apache.iceberg.types.CheckCompatibility
Returns a list of compatibility errors for writing with the given write schema.
typeCompatibilityErrors(Schema, Schema) - Static method in class org.apache.iceberg.types.CheckCompatibility
Returns a list of compatibility errors for writing with the given write schema.
typeId() - Method in interface org.apache.iceberg.types.Type
 
typeId() - Method in class org.apache.iceberg.types.Types.BinaryType
 
typeId() - Method in class org.apache.iceberg.types.Types.BooleanType
 
typeId() - Method in class org.apache.iceberg.types.Types.DateType
 
typeId() - Method in class org.apache.iceberg.types.Types.DecimalType
 
typeId() - Method in class org.apache.iceberg.types.Types.DoubleType
 
typeId() - Method in class org.apache.iceberg.types.Types.FixedType
 
typeId() - Method in class org.apache.iceberg.types.Types.FloatType
 
typeId() - Method in class org.apache.iceberg.types.Types.IntegerType
 
typeId() - Method in class org.apache.iceberg.types.Types.ListType
 
typeId() - Method in class org.apache.iceberg.types.Types.LongType
 
typeId() - Method in class org.apache.iceberg.types.Types.MapType
 
typeId() - Method in class org.apache.iceberg.types.Types.StringType
 
typeId() - Method in class org.apache.iceberg.types.Types.StructType
 
typeId() - Method in class org.apache.iceberg.types.Types.TimestampType
 
typeId() - Method in class org.apache.iceberg.types.Types.TimeType
 
typeId() - Method in class org.apache.iceberg.types.Types.UUIDType
 
Types - Class in org.apache.iceberg.types
 
Types.BinaryType - Class in org.apache.iceberg.types
 
Types.BooleanType - Class in org.apache.iceberg.types
 
Types.DateType - Class in org.apache.iceberg.types
 
Types.DecimalType - Class in org.apache.iceberg.types
 
Types.DoubleType - Class in org.apache.iceberg.types
 
Types.FixedType - Class in org.apache.iceberg.types
 
Types.FloatType - Class in org.apache.iceberg.types
 
Types.IntegerType - Class in org.apache.iceberg.types
 
Types.ListType - Class in org.apache.iceberg.types
 
Types.LongType - Class in org.apache.iceberg.types
 
Types.MapType - Class in org.apache.iceberg.types
 
Types.NestedField - Class in org.apache.iceberg.types
 
Types.StringType - Class in org.apache.iceberg.types
 
Types.StructType - Class in org.apache.iceberg.types
 
Types.TimestampType - Class in org.apache.iceberg.types
 
Types.TimeType - Class in org.apache.iceberg.types
 
Types.UUIDType - Class in org.apache.iceberg.types
 
TypeToMessageType - Class in org.apache.iceberg.parquet
 
TypeToMessageType() - Constructor for class org.apache.iceberg.parquet.TypeToMessageType
 
TypeUtil - Class in org.apache.iceberg.types
 
TypeUtil.CustomOrderSchemaVisitor<T> - Class in org.apache.iceberg.types
 
TypeUtil.NextID - Interface in org.apache.iceberg.types
Interface for passing a function that assigns column IDs.
TypeUtil.SchemaVisitor<T> - Class in org.apache.iceberg.types
 
TypeWithSchemaVisitor<T> - Class in org.apache.iceberg.parquet
Visitor for traversing a Parquet type with a companion Iceberg type.
TypeWithSchemaVisitor() - Constructor for class org.apache.iceberg.parquet.TypeWithSchemaVisitor
 

U

Unbound<T,B> - Interface in org.apache.iceberg.expressions
Represents an unbound expression node.
UnboundPredicate<T> - Class in org.apache.iceberg.expressions
 
UnboundTerm<T> - Interface in org.apache.iceberg.expressions
Represents an unbound term.
UnboundTransform<S,T> - Class in org.apache.iceberg.expressions
 
unboxed(ColumnDescriptor) - Static method in class org.apache.iceberg.parquet.ParquetValueWriters
 
UnboxedReader(ColumnDescriptor) - Constructor for class org.apache.iceberg.parquet.ParquetValueReaders.UnboxedReader
 
UnicodeUtil - Class in org.apache.iceberg.util
 
union(Schema, List<T>) - Method in class org.apache.iceberg.avro.AvroSchemaVisitor
 
union(Type, Schema, List<T>) - Method in class org.apache.iceberg.avro.AvroSchemaWithTypeVisitor
 
union(List<ValueReader<?>>) - Static method in class org.apache.iceberg.avro.ValueReaders
 
UnknownTransform<S,T> - Class in org.apache.iceberg.transforms
 
unpartitioned(Expression) - Static method in class org.apache.iceberg.expressions.ResidualEvaluator
Return a residual evaluator for an unpartitioned spec.
unpartitioned() - Static method in class org.apache.iceberg.PartitionSpec
Returns a spec for unpartitioned tables.
UnrecoverableException(String) - Constructor for exception org.apache.iceberg.util.Tasks.UnrecoverableException
 
UnrecoverableException(String, Throwable) - Constructor for exception org.apache.iceberg.util.Tasks.UnrecoverableException
 
UnrecoverableException(Throwable) - Constructor for exception org.apache.iceberg.util.Tasks.UnrecoverableException
 
unsignedBytes() - Static method in class org.apache.iceberg.types.Comparators
 
update(NameMapping, Map<Integer, Types.NestedField>, Multimap<Integer, Types.NestedField>) - Static method in class org.apache.iceberg.mapping.MappingUtil
Update a name-based mapping using changes to a schema.
updateColumn(String, Type.PrimitiveType) - Method in interface org.apache.iceberg.UpdateSchema
Update a column in the schema to a new primitive type.
updateColumn(String, Type.PrimitiveType, String) - Method in interface org.apache.iceberg.UpdateSchema
Update a column in the schema to a new primitive type.
updateColumnDoc(String, String) - Method in interface org.apache.iceberg.UpdateSchema
Update a column in the schema to a new primitive type.
updateLocation() - Method in class org.apache.iceberg.BaseTable
 
updateLocation() - Method in interface org.apache.iceberg.Table
Create a new UpdateLocation to update table location and commit the changes.
updateLocation(String) - Method in class org.apache.iceberg.TableMetadata
 
updateLocation() - Method in interface org.apache.iceberg.Transaction
Create a new UpdateLocation to update table location.
UpdateLocation - Interface in org.apache.iceberg
API for setting a table's base location.
updatePartitionSpec(PartitionSpec) - Method in class org.apache.iceberg.TableMetadata
 
updateProperties() - Method in class org.apache.iceberg.BaseTable
 
updateProperties() - Method in interface org.apache.iceberg.Table
Create a new UpdateProperties to update table properties and commit the changes.
updateProperties() - Method in interface org.apache.iceberg.Transaction
Create a new UpdateProperties to update table properties.
UpdateProperties - Interface in org.apache.iceberg
API for updating table properties.
updateSchema() - Method in class org.apache.iceberg.BaseTable
 
updateSchema() - Method in interface org.apache.iceberg.Table
Create a new UpdateSchema to alter the columns of this table and commit the change.
updateSchema(Schema, int) - Method in class org.apache.iceberg.TableMetadata
 
updateSchema() - Method in interface org.apache.iceberg.Transaction
Create a new UpdateSchema to alter the columns of this table.
UpdateSchema - Interface in org.apache.iceberg
API for schema evolution.
upgradeToFormatVersion(int) - Method in class org.apache.iceberg.TableMetadata
 
upperBound() - Method in class org.apache.iceberg.GenericPartitionFieldSummary
 
upperBound() - Method in interface org.apache.iceberg.ManifestFile.PartitionFieldSummary
 
upperBounds() - Method in interface org.apache.iceberg.DataFile
 
upperBounds() - Method in class org.apache.iceberg.Metrics
Get the non-null upper bound values for all fields in a file.
upperBounds() - Method in class org.apache.iceberg.spark.SparkDataFile
 
useCaching(boolean) - Method in class org.apache.iceberg.actions.RewriteManifestsAction
Configures whether the action should cache manifest entries used in multiple jobs.
useHiveRows() - Method in class org.apache.iceberg.mr.mapreduce.IcebergInputFormat.ConfigBuilder
 
usePigTuples() - Method in class org.apache.iceberg.mr.mapreduce.IcebergInputFormat.ConfigBuilder
 
useSnapshot(long) - Method in class org.apache.iceberg.AllDataFilesTable.AllDataFilesTableScan
 
useSnapshot(long) - Method in class org.apache.iceberg.AllManifestsTable.AllManifestsTableScan
 
useSnapshot(long) - Method in class org.apache.iceberg.data.IcebergGenerics.ScanBuilder
 
useSnapshot(long) - Method in interface org.apache.iceberg.TableScan
Create a new TableScan from this scan's configuration that will use the given snapshot by ID.
utf8s() - Static method in class org.apache.iceberg.avro.ValueReaders
 
utf8s() - Static method in class org.apache.iceberg.avro.ValueWriters
 
Util - Class in org.apache.iceberg.hadoop
 
uuid() - Method in class org.apache.iceberg.TableMetadata
 
UUIDConversion - Class in org.apache.iceberg.avro
 
UUIDConversion() - Constructor for class org.apache.iceberg.avro.UUIDConversion
 
uuids() - Static method in class org.apache.iceberg.avro.ValueReaders
 
uuids() - Static method in class org.apache.iceberg.avro.ValueWriters
 
UUIDType() - Constructor for class org.apache.iceberg.types.Types.UUIDType
 

V

validate(Schema) - Method in class org.apache.iceberg.avro.LogicalMap
 
validateAddedFilesMatchOverwriteFilter() - Method in class org.apache.iceberg.BaseOverwriteFiles
 
validateAddedFilesMatchOverwriteFilter() - Method in interface org.apache.iceberg.OverwriteFiles
Signal that each file added to the table must match the overwrite expression.
validateAppendOnly() - Method in class org.apache.iceberg.BaseReplacePartitions
 
validateAppendOnly() - Method in interface org.apache.iceberg.ReplacePartitions
Validate that no partitions will be replaced and the operation is append-only.
validateNoConflictingAppends(Long, Expression) - Method in class org.apache.iceberg.BaseOverwriteFiles
 
validateNoConflictingAppends(Long, Expression) - Method in interface org.apache.iceberg.OverwriteFiles
Enables validation that files added concurrently do not conflict with this commit's operation.
validateWapPublish(TableMetadata, long) - Static method in class org.apache.iceberg.util.WapUtil
Check if a given staged snapshot's associated wap-id was already published.
ValidationException - Exception in org.apache.iceberg.exceptions
Exception raised when validation checks fail.
ValidationException(String, Object...) - Constructor for exception org.apache.iceberg.exceptions.ValidationException
 
ValidationException(Throwable, String, Object...) - Constructor for exception org.apache.iceberg.exceptions.ValidationException
 
value() - Method in interface org.apache.iceberg.expressions.Literal
 
VALUE_ID_PROP - Static variable in class org.apache.iceberg.avro.AvroSchemaUtil
 
valueCounts() - Method in interface org.apache.iceberg.DataFile
 
valueCounts() - Method in class org.apache.iceberg.Metrics
Get the number of all values, including nulls, NaN and repeated.
valueCounts() - Method in class org.apache.iceberg.spark.SparkDataFile
 
valueEncoding - Variable in class org.apache.iceberg.parquet.BasePageIterator
 
valueId() - Method in class org.apache.iceberg.types.Types.MapType
 
valueOf(String) - Static method in enum org.apache.iceberg.expressions.Expression.Operation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.iceberg.FileFormat
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.iceberg.MetadataTableType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.iceberg.orc.ORCSchemaUtil.BinaryType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.iceberg.orc.ORCSchemaUtil.LongType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.iceberg.TableMetadataParser.Codec
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.iceberg.types.Type.TypeID
Returns the enum constant of this type with the specified name.
ValueReader<T> - Interface in org.apache.iceberg.avro
 
ValueReaders - Class in org.apache.iceberg.avro
 
ValueReaders.StructReader<S> - Class in org.apache.iceberg.avro
 
values() - Static method in enum org.apache.iceberg.expressions.Expression.Operation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.iceberg.FileFormat
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.iceberg.MetadataTableType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.iceberg.orc.ORCSchemaUtil.BinaryType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.iceberg.orc.ORCSchemaUtil.LongType
Returns an array containing the constants of this enum type, in the order they are declared.
values - Variable in class org.apache.iceberg.parquet.BasePageIterator
 
values() - Static method in enum org.apache.iceberg.TableMetadataParser.Codec
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.iceberg.types.Type.TypeID
Returns an array containing the constants of this enum type, in the order they are declared.
ValuesAsBytesReader - Class in org.apache.iceberg.parquet
Implements a ValuesReader specifically to read given number of bytes from the underlying ByteBufferInputStream.
ValuesAsBytesReader() - Constructor for class org.apache.iceberg.parquet.ValuesAsBytesReader
 
valueType() - Method in class org.apache.iceberg.types.Types.MapType
 
ValueWriter<D> - Interface in org.apache.iceberg.avro
 
ValueWriters - Class in org.apache.iceberg.avro
 
ValueWriters.StructWriter<S> - Class in org.apache.iceberg.avro
 
VarBinaryArrowVector(String, BufferAllocator) - Constructor for class org.apache.iceberg.arrow.vectorized.IcebergArrowVectors.VarBinaryArrowVector
 
VarcharArrowVector(String, BufferAllocator) - Constructor for class org.apache.iceberg.arrow.vectorized.IcebergArrowVectors.VarcharArrowVector
 
vector() - Method in class org.apache.iceberg.arrow.vectorized.VectorHolder
 
VectorHolder - Class in org.apache.iceberg.arrow.vectorized
Container class for holding the Arrow vector holding a batch of values along with other state needed for reading values out of it.
VectorHolder(ColumnDescriptor, FieldVector, boolean, Dictionary, NullabilityHolder) - Constructor for class org.apache.iceberg.arrow.vectorized.VectorHolder
 
VectorizedArrowReader - Class in org.apache.iceberg.arrow.vectorized
VectorReader(s) that read in a batch of values into Arrow vectors.
VectorizedArrowReader(ColumnDescriptor, Types.NestedField, BufferAllocator, int, boolean) - Constructor for class org.apache.iceberg.arrow.vectorized.VectorizedArrowReader
 
VectorizedColumnIterator - Class in org.apache.iceberg.arrow.vectorized.parquet
Vectorized version of the ColumnIterator that reads column values in data pages of a column in a row group in a batched fashion.
VectorizedColumnIterator(ColumnDescriptor, String, int, boolean) - Constructor for class org.apache.iceberg.arrow.vectorized.parquet.VectorizedColumnIterator
 
VectorizedDictionaryEncodedParquetValuesReader - Class in org.apache.iceberg.arrow.vectorized.parquet
This decoder reads Parquet dictionary encoded data in a vectorized fashion.
VectorizedDictionaryEncodedParquetValuesReader(int, boolean) - Constructor for class org.apache.iceberg.arrow.vectorized.parquet.VectorizedDictionaryEncodedParquetValuesReader
 
VectorizedPageIterator - Class in org.apache.iceberg.arrow.vectorized.parquet
 
VectorizedPageIterator(ColumnDescriptor, String, boolean) - Constructor for class org.apache.iceberg.arrow.vectorized.parquet.VectorizedPageIterator
 
VectorizedParquetDefinitionLevelReader - Class in org.apache.iceberg.arrow.vectorized.parquet
 
VectorizedParquetDefinitionLevelReader(int, int, boolean) - Constructor for class org.apache.iceberg.arrow.vectorized.parquet.VectorizedParquetDefinitionLevelReader
 
VectorizedParquetReader<T> - Class in org.apache.iceberg.parquet
 
VectorizedParquetReader(InputFile, Schema, ParquetReadOptions, Function<MessageType, VectorizedReader<?>>, Expression, boolean, boolean, int) - Constructor for class org.apache.iceberg.parquet.VectorizedParquetReader
 
VectorizedReader<T> - Interface in org.apache.iceberg.parquet
Interface for vectorized Iceberg readers.
VectorizedRowBatchIterator - Class in org.apache.iceberg.orc
An adaptor so that the ORC RecordReader can be used as an Iterator.
visit(Schema, AvroSchemaVisitor<T>) - Static method in class org.apache.iceberg.avro.AvroSchemaVisitor
 
visit(Schema, Schema, AvroSchemaWithTypeVisitor<T>) - Static method in class org.apache.iceberg.avro.AvroSchemaWithTypeVisitor
 
visit(Type, Schema, AvroSchemaWithTypeVisitor<T>) - Static method in class org.apache.iceberg.avro.AvroSchemaWithTypeVisitor
 
visit(Expression, ExpressionVisitors.ExpressionVisitor<R>) - Static method in class org.apache.iceberg.expressions.ExpressionVisitors
Traverses the given expression with a visitor.
visit(Type, ParquetTypeVisitor<T>) - Static method in class org.apache.iceberg.parquet.ParquetTypeVisitor
 
visit(Type, Type, TypeWithSchemaVisitor<T>) - Static method in class org.apache.iceberg.parquet.TypeWithSchemaVisitor
 
visit(Schema, PartitionSpec, PartitionSpecVisitor<R>) - Static method in interface org.apache.iceberg.transforms.PartitionSpecVisitor
 
visit(Schema, TypeUtil.SchemaVisitor<T>) - Static method in class org.apache.iceberg.types.TypeUtil
 
visit(Type, TypeUtil.SchemaVisitor<T>) - Static method in class org.apache.iceberg.types.TypeUtil
 
visit(Schema, TypeUtil.CustomOrderSchemaVisitor<T>) - Static method in class org.apache.iceberg.types.TypeUtil
 
visit(Type, TypeUtil.CustomOrderSchemaVisitor<T>) - Static method in class org.apache.iceberg.types.TypeUtil
Used to traverse types with traversals other than pre-order.
visitEvaluator(Expression, ExpressionVisitors.ExpressionVisitor<Boolean>) - Static method in class org.apache.iceberg.expressions.ExpressionVisitors
Traverses the given expression with a visitor.

W

WapUtil - Class in org.apache.iceberg.util
 
where(Expression) - Method in class org.apache.iceberg.data.IcebergGenerics.ScanBuilder
 
withEncryptedOutputFile(EncryptedOutputFile) - Method in class org.apache.iceberg.DataFiles.Builder
 
withEncryptionKeyMetadata(ByteBuffer) - Method in class org.apache.iceberg.DataFiles.Builder
 
withEncryptionKeyMetadata(EncryptionKeyMetadata) - Method in class org.apache.iceberg.DataFiles.Builder
 
withFileSizeInBytes(long) - Method in class org.apache.iceberg.DataFiles.Builder
 
withFormat(String) - Method in class org.apache.iceberg.DataFiles.Builder
 
withFormat(FileFormat) - Method in class org.apache.iceberg.DataFiles.Builder
 
withInputFile(InputFile) - Method in class org.apache.iceberg.DataFiles.Builder
 
withLength(int) - Static method in class org.apache.iceberg.MetricsModes.Truncate
 
withMetadataMatching(Expression) - Method in class org.apache.iceberg.FindFiles.Builder
Filter results using a metadata filter for the data in a DataFile.
withMetrics(Metrics) - Method in class org.apache.iceberg.DataFiles.Builder
 
withNoopClose(E) - Static method in interface org.apache.iceberg.io.CloseableIterable
 
withNoopClose(Iterable<E>) - Static method in interface org.apache.iceberg.io.CloseableIterable
 
withoutZone() - Static method in class org.apache.iceberg.types.Types.TimestampType
 
withPartition(StructLike) - Method in class org.apache.iceberg.DataFiles.Builder
 
withPartitionPath(String) - Method in class org.apache.iceberg.DataFiles.Builder
 
withPath(String) - Method in class org.apache.iceberg.DataFiles.Builder
 
withRecordCount(long) - Method in class org.apache.iceberg.DataFiles.Builder
 
withRecordsMatching(Expression) - Method in class org.apache.iceberg.FindFiles.Builder
Filter results using a record filter.
withSnapshotId(Long) - Method in class org.apache.iceberg.GenericManifestFile.CopyBuilder
 
withSpecId(int) - Method in class org.apache.iceberg.PartitionSpec.Builder
 
withSplitOffsets(List<Long>) - Method in class org.apache.iceberg.DataFiles.Builder
 
withStatus(FileStatus) - Method in class org.apache.iceberg.DataFiles.Builder
 
withUUID() - Method in class org.apache.iceberg.TableMetadata
 
withZone() - Static method in class org.apache.iceberg.types.Types.TimestampType
 
WORKER_THREAD_POOL_SIZE - Static variable in class org.apache.iceberg.util.ThreadPools
 
WORKER_THREAD_POOL_SIZE_PROP - Static variable in class org.apache.iceberg.SystemProperties
Sets the size of the worker pool.
WORKER_THREAD_POOL_SIZE_PROP - Static variable in class org.apache.iceberg.util.ThreadPools
 
wrap(Catalog) - Static method in class org.apache.iceberg.CachingCatalog
 
wrap(Catalog, boolean) - Static method in class org.apache.iceberg.CachingCatalog
 
wrap(Row) - Method in class org.apache.iceberg.spark.SparkDataFile
 
wrap(Row) - Method in class org.apache.iceberg.spark.SparkStructLike
 
wrap(CharSequence) - Static method in class org.apache.iceberg.util.CharSequenceWrapper
 
wrap(StructLike) - Static method in class org.apache.iceberg.util.StructLikeWrapper
 
write(OutputFile) - Static method in class org.apache.iceberg.avro.Avro
 
write(D, Encoder) - Method in interface org.apache.iceberg.avro.ValueWriter
 
write(S, Encoder) - Method in class org.apache.iceberg.avro.ValueWriters.StructWriter
 
write(T, Encoder) - Method in class org.apache.iceberg.data.avro.DataWriter
 
write(Record, VectorizedRowBatch) - Method in class org.apache.iceberg.data.orc.GenericOrcWriter
 
write(PartitionSpec, OutputFile) - Static method in class org.apache.iceberg.ManifestFiles
Create a new ManifestWriter.
write(int, PartitionSpec, OutputFile, Long) - Static method in class org.apache.iceberg.ManifestFiles
Create a new ManifestWriter for the given format version.
write(PartitionSpec, OutputFile) - Static method in class org.apache.iceberg.ManifestWriter
Deprecated.
will be removed in 0.9.0; use ManifestFiles.write(PartitionSpec, OutputFile) instead.
write(OutputFile) - Static method in class org.apache.iceberg.orc.ORC
 
write(T, VectorizedRowBatch) - Method in interface org.apache.iceberg.orc.OrcValueWriter
Writes the data.
write(OutputFile) - Static method in class org.apache.iceberg.parquet.Parquet
 
write(int, T) - Method in interface org.apache.iceberg.parquet.ParquetValueWriter
 
write(int, T) - Method in class org.apache.iceberg.parquet.ParquetValueWriters.PrimitiveWriter
 
write(int, M) - Method in class org.apache.iceberg.parquet.ParquetValueWriters.RepeatedKeyValueWriter
 
write(int, L) - Method in class org.apache.iceberg.parquet.ParquetValueWriters.RepeatedWriter
 
write(int, S) - Method in class org.apache.iceberg.parquet.ParquetValueWriters.StructWriter
 
write(int, T) - Method in interface org.apache.iceberg.parquet.TripleWriter
Write a value.
write(InternalRow, Encoder) - Method in class org.apache.iceberg.spark.data.SparkAvroWriter
 
write(InternalRow, VectorizedRowBatch) - Method in class org.apache.iceberg.spark.data.SparkOrcWriter
 
write(TableMetadata, OutputFile) - Static method in class org.apache.iceberg.TableMetadataParser
 
WRITE_AUDIT_PUBLISH_ENABLED - Static variable in class org.apache.iceberg.TableProperties
 
WRITE_AUDIT_PUBLISH_ENABLED_DEFAULT - Static variable in class org.apache.iceberg.TableProperties
 
WRITE_METADATA_LOCATION - Static variable in class org.apache.iceberg.TableProperties
 
WRITE_NEW_DATA_LOCATION - Static variable in class org.apache.iceberg.TableProperties
 
WRITE_TARGET_FILE_SIZE_BYTES - Static variable in class org.apache.iceberg.TableProperties
 
WRITE_TARGET_FILE_SIZE_BYTES_DEFAULT - Static variable in class org.apache.iceberg.TableProperties
 
writeBinary(int, Binary) - Method in class org.apache.iceberg.parquet.ColumnWriter
 
writeBinary(int, Binary) - Method in interface org.apache.iceberg.parquet.TripleWriter
Write a triple.
writeBoolean(int, boolean) - Method in class org.apache.iceberg.parquet.ColumnWriter
 
writeBoolean(int, boolean) - Method in interface org.apache.iceberg.parquet.TripleWriter
Write a triple.
writeCompatibilityErrors(Schema, Schema) - Static method in class org.apache.iceberg.types.CheckCompatibility
Returns a list of compatibility errors for writing with the given write schema.
writeCompatibilityErrors(Schema, Schema, boolean) - Static method in class org.apache.iceberg.types.CheckCompatibility
Returns a list of compatibility errors for writing with the given write schema.
writeDouble(int, double) - Method in class org.apache.iceberg.parquet.ColumnWriter
 
writeDouble(int, double) - Method in interface org.apache.iceberg.parquet.TripleWriter
Write a triple.
writeFloat(int, float) - Method in class org.apache.iceberg.parquet.ColumnWriter
 
writeFloat(int, float) - Method in interface org.apache.iceberg.parquet.TripleWriter
Write a triple.
writeInteger(int, int) - Method in class org.apache.iceberg.parquet.ColumnWriter
 
writeInteger(int, int) - Method in interface org.apache.iceberg.parquet.TripleWriter
Write a triple.
writeLong(int, long) - Method in class org.apache.iceberg.parquet.ColumnWriter
 
writeLong(int, long) - Method in interface org.apache.iceberg.parquet.TripleWriter
Write a triple.
writeNewMetadata(TableMetadata, int) - Method in class org.apache.iceberg.BaseMetastoreTableOperations
 
writeNull(int, int) - Method in class org.apache.iceberg.parquet.ColumnWriter
 
writeNull(int, int) - Method in interface org.apache.iceberg.parquet.TripleWriter
Write a triple for a null value.
writer(int) - Method in class org.apache.iceberg.avro.ValueWriters.StructWriter
 
writerVersion - Variable in class org.apache.iceberg.parquet.BasePageIterator
 
writeSupport(WriteSupport<?>) - Method in class org.apache.iceberg.parquet.Parquet.WriteBuilder
 

Y

year(String) - Static method in class org.apache.iceberg.expressions.Expressions
 
year(String, String) - Method in class org.apache.iceberg.PartitionSpec.Builder
 
year(String) - Method in class org.apache.iceberg.PartitionSpec.Builder
 
year(String, int) - Method in interface org.apache.iceberg.transforms.PartitionSpecVisitor
 
year(Type) - Static method in class org.apache.iceberg.transforms.Transforms
Returns a year Transform for date or timestamp types.
A B C D E F G H I J K L M N O P R S T U V W Y 
Skip navigation links