- 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
-
- 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
-
Return an accessor for retrieving the data from
StructLike
.
- Accessors - Class in org.apache.iceberg
-
- 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(ManifestEntry) - Method in class org.apache.iceberg.ManifestWriter
-
- add(D) - Method in class org.apache.iceberg.parquet.ParquetWriteAdapter
-
- add(int, String, String) - Method in class org.apache.iceberg.PartitionSpec.Builder
-
- addAll(Iterator<D>) - Method in interface org.apache.iceberg.io.FileAppender
-
- addAll(Iterable<D>) - Method in interface org.apache.iceberg.io.FileAppender
-
- 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_PROP - Static variable in class org.apache.iceberg.SnapshotSummary
-
- ADDED_RECORDS_PROP - Static variable in class org.apache.iceberg.SnapshotSummary
-
- 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
-
- 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.OverwriteData
-
- addFile(DataFile) - Method in interface org.apache.iceberg.OverwriteFiles
-
- addFile(DataFile) - Method in interface org.apache.iceberg.ReplacePartitions
-
- addFile(DataFile) - Method in class org.apache.iceberg.ReplacePartitionsOperation
-
- 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
-
- addSchema(Schema) - Method in class org.apache.iceberg.data.avro.IcebergDecoder
-
- ADJUST_TO_UTC_PROP - Static variable in class org.apache.iceberg.avro.AvroSchemaUtil
-
- 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
-
- aliasToId(String) - Method in class org.apache.iceberg.Schema
-
Returns the column id for the given column alias.
- 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
-
- alwaysTrue() - Static method in class org.apache.iceberg.expressions.Expressions
-
- alwaysTrue() - Method in class org.apache.iceberg.expressions.ExpressionVisitors.ExpressionVisitor
-
- And - Class in org.apache.iceberg.expressions
-
- and(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
-
- AppendFiles - Interface in org.apache.iceberg
-
API for appending new files in a table.
- appendManifest(ManifestFile) - Method in interface org.apache.iceberg.AppendFiles
-
Append the contents of a manifest to the table.
- apply(TableMetadata) - Method in class org.apache.iceberg.OverwriteData
-
- apply() - Method in interface org.apache.iceberg.PendingUpdate
-
Apply the pending changes and return the uncommitted changes for validation.
- apply(TableMetadata) - Method in class org.apache.iceberg.ReplaceManifests
-
- apply(TableMetadata) - Method in class org.apache.iceberg.ReplacePartitionsOperation
-
- apply() - Method in class org.apache.iceberg.SetLocation
-
- apply(S) - Method in interface org.apache.iceberg.transforms.Transform
-
Transforms a value to its corresponding partition value.
- array(Schema, T) - Method in class org.apache.iceberg.avro.AvroSchemaVisitor
-
- 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
-
- asCombinedScanTask() - Method in interface org.apache.iceberg.CombinedScanTask
-
- asCombinedScanTask() - 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
-
- 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 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
-
- assignFreshIds(Type, TypeUtil.NextID) - Static method in class org.apache.iceberg.types.TypeUtil
-
- assignFreshIds(Schema, TypeUtil.NextID) - Static method in class org.apache.iceberg.types.TypeUtil
-
- 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
-
- 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
-
- 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(Configuration) - Constructor for class org.apache.iceberg.BaseMetastoreCatalog
-
- BaseMetastoreTableOperations - Class in org.apache.iceberg
-
- BaseMetastoreTableOperations(Configuration) - Constructor for class org.apache.iceberg.BaseMetastoreTableOperations
-
- BaseMetastoreTables - Class in org.apache.iceberg
-
- BaseMetastoreTables(Configuration) - Constructor for class org.apache.iceberg.BaseMetastoreTables
-
- BaseTable - Class in org.apache.iceberg
-
Base
Table
implementation.
- BaseTable(TableOperations, String) - Constructor for class org.apache.iceberg.BaseTable
-
- 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
-
- beginCreate(Schema, PartitionSpec, String, String) - Method in class org.apache.iceberg.BaseMetastoreTables
-
- beginCreate(Schema, PartitionSpec, Map<String, String>, String, String) - Method in class org.apache.iceberg.BaseMetastoreTables
-
- beginReplace(Schema, PartitionSpec, String, String) - Method in class org.apache.iceberg.BaseMetastoreTables
-
- beginReplace(Schema, PartitionSpec, Map<String, String>, String, String) - Method in class org.apache.iceberg.BaseMetastoreTables
-
- BinaryAsDecimalReader(ColumnDescriptor, int) - Constructor for class org.apache.iceberg.parquet.ParquetValueReaders.BinaryAsDecimalReader
-
- BinaryType() - Constructor for class org.apache.iceberg.types.Types.BinaryType
-
- 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.UnboundPredicate
-
Bind this UnboundPredicate.
- 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
-
- 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
-
- BoundExpressionVisitor() - Constructor for class org.apache.iceberg.expressions.ExpressionVisitors.BoundExpressionVisitor
-
- BoundPredicate<T> - Class in org.apache.iceberg.expressions
-
- BoundReference<T> - Class in org.apache.iceberg.expressions
-
- boundReferences(Types.StructType, List<Expression>, boolean) - Static method in class org.apache.iceberg.expressions.Binder
-
- 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.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(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
-
- 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
-
- buildReader(Schema, MessageType) - 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
-
- 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(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
-
- callInit() - Method in class org.apache.iceberg.parquet.Parquet.ReadBuilder
-
- canTransform(Type) - Method in interface org.apache.iceberg.transforms.Transform
-
Checks whether this function can be applied to the give
Type
.
- caseInsensitive() - Method in class org.apache.iceberg.data.IcebergGenerics.ScanBuilder
-
- 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 name
- caseInsensitiveSelect(Collection<String>) - Method in class org.apache.iceberg.Schema
-
Creates a projection schema for a subset of columns, selected by case insensitive name
- caseSensitive(boolean) - Method in class org.apache.iceberg.ManifestReader
-
- 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
-
- Catalog - Interface in org.apache.iceberg.catalog
-
A Catalog API for table create, drop, and load operations.
- CHANGED_PARTITION_COUNT_PROP - Static variable in class org.apache.iceberg.SnapshotSummary
-
- charSequences() - Static method in class org.apache.iceberg.types.Comparators
-
- 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(PartitionSpec, Schema) - Static method in class org.apache.iceberg.PartitionSpec
-
- CheckCompatibility - Class in org.apache.iceberg.types
-
- child() - Method in class org.apache.iceberg.expressions.Not
-
- cleanUncommitted(Set<ManifestFile>) - Method in class org.apache.iceberg.ReplaceManifests
-
- clear() - Method in class org.apache.iceberg.DataFiles.Builder
-
- clear() - Method in class org.apache.iceberg.orc.ColumnIdMap
-
- clear() - Method in class org.apache.iceberg.SnapshotSummary.Builder
-
- close() - Method in class org.apache.iceberg.FilteredManifest
-
- close() - Method in class org.apache.iceberg.hive.HiveCatalog
-
- close() - Method in class org.apache.iceberg.hive.HiveTables
-
- 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 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.ReplaceManifests
-
- clusterBy(Function<DataFile, Object>) - Method in interface org.apache.iceberg.RewriteManifests
-
Groups an existing
DataFile
by a cluster key produced by a function.
- 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
-
- ColumnIdMap - Class in org.apache.iceberg.orc
-
The mapping from ORC's TypeDescription to the Iceberg column ids.
- ColumnIdMap() - Constructor for class org.apache.iceberg.orc.ColumnIdMap
-
- ColumnIterator<T> - Class in org.apache.iceberg.parquet
-
- 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
-
- 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.hadoop.HadoopTableOperations
-
- commit(TableMetadata, TableMetadata) - Method in class org.apache.iceberg.hive.HiveTableOperations
-
- 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.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 ignored.
- COMPRESS_METADATA - Static variable in class org.apache.iceberg.ConfigProperties
-
- COMPRESS_METADATA_DEFAULT - Static variable in class org.apache.iceberg.ConfigProperties
-
- concat(Iterable<CloseableIterable<E>>) - Static method in interface org.apache.iceberg.io.CloseableIterable
-
- config(String, String) - Method in class org.apache.iceberg.orc.ORC.ReadBuilder
-
- config(String, String) - Method in class org.apache.iceberg.orc.ORC.WriteBuilder
-
- ConfigProperties - Class in org.apache.iceberg
-
- containsKey(Object) - Method in class org.apache.iceberg.orc.ColumnIdMap
-
- containsNull() - Method in class org.apache.iceberg.GenericPartitionFieldSummary
-
- containsNull() - Method in interface org.apache.iceberg.ManifestFile.PartitionFieldSummary
-
- containsValue(Object) - Method in class org.apache.iceberg.orc.ColumnIdMap
-
- Conversions - Class in org.apache.iceberg.types
-
- 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, 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.
- 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
-
- 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
-
- copy() - Method in interface org.apache.iceberg.ManifestFile.PartitionFieldSummary
-
- copy(ByteBuffer) - Static method in class org.apache.iceberg.util.ByteBuffers
-
- copyWithoutStats() - Method in interface org.apache.iceberg.DataFile
-
- create(Schema, String, String) - Method in class org.apache.iceberg.BaseMetastoreTables
-
- create(Schema, PartitionSpec, String, String) - Method in class org.apache.iceberg.BaseMetastoreTables
-
- create(Schema, PartitionSpec, Map<String, String>, String, String) - Method in class org.apache.iceberg.BaseMetastoreTables
-
- create(Schema) - 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(Schema, String) - Method in class org.apache.iceberg.hive.HiveTables
-
- create(Schema, PartitionSpec, Map<String, String>, String) - Method in class org.apache.iceberg.hive.HiveTables
-
- create() - Method in interface org.apache.iceberg.io.OutputFile
-
- 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
-
- createOrOverwrite() - Method in class org.apache.iceberg.hadoop.HadoopOutputFile
-
- createOrOverwrite() - Method in interface org.apache.iceberg.io.OutputFile
-
- createReader(DataSourceOptions) - Method in class org.apache.iceberg.spark.source.IcebergSource
-
- createReaderFunc(Function<Schema, DatumReader<?>>) - Method in class org.apache.iceberg.avro.Avro.ReadBuilder
-
- createReaderFunc(Function<Schema, 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.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 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.hive.HiveCatalog
-
- 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.
- currentDefinitionLevel() - Method in class org.apache.iceberg.parquet.ColumnIterator
-
- currentMetadataLocation() - Method in class org.apache.iceberg.BaseMetastoreTableOperations
-
- currentRepetitionLevel() - Method in class org.apache.iceberg.parquet.ColumnIterator
-
- 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
-
- 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
-
- DataOperations - Class in org.apache.iceberg
-
Data operations that produce snapshots.
- DataReader<T> - Class in org.apache.iceberg.data.avro
-
- dataTimestampMillis() - Method in class org.apache.iceberg.ScanSummary.PartitionMetrics
-
- DataWriter<T> - Class in org.apache.iceberg.data.avro
-
- DateType() - Constructor for class org.apache.iceberg.types.Types.DateType
-
- 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
-
- 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
-
- decimalRequriedBytes(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
-
- decrypt(Iterable<EncryptedInputFile>) - Method in interface org.apache.iceberg.encryption.EncryptionManager
-
- decrypt(EncryptedInputFile) - Method in class org.apache.iceberg.encryption.PlaintextEncryptionManager
-
- DEFAULT_FILE_FORMAT - Static variable in class org.apache.iceberg.TableProperties
-
- DEFAULT_FILE_FORMAT_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(Configuration, TableIdentifier) - Method in class org.apache.iceberg.BaseMetastoreCatalog
-
- defaultWarehouseLocation(Configuration, String, String) - Method in class org.apache.iceberg.BaseMetastoreTables
-
- defaultWarehouseLocation(Configuration, TableIdentifier) - Method in class org.apache.iceberg.hive.HiveCatalog
-
- 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_PROP - Static variable in class org.apache.iceberg.SnapshotSummary
-
- DELETED_RECORDS_PROP - Static variable in class org.apache.iceberg.SnapshotSummary
-
- 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
-
- 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
-
- deleteFile(OutputFile) - Method in interface org.apache.iceberg.io.FileIO
-
- 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.
- 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.
- deserialize(TypeDescription, ByteBuffer) - Static method in class org.apache.iceberg.orc.ColumnIdMap
-
- doc() - Method in class org.apache.iceberg.types.Types.NestedField
-
- 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
-
- dropTable(TableIdentifier) - Method in interface org.apache.iceberg.catalog.Catalog
-
Drop a table.
- dropTable(TableIdentifier) - Method in class org.apache.iceberg.hive.HiveCatalog
-
- 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
.
- range(int) - Static method in class org.apache.iceberg.util.Tasks
-
- 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(InputFile, Function<Integer, PartitionSpec>) - Static method in class org.apache.iceberg.ManifestReader
-
- 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(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
-
- readBinary() - Method in class org.apache.iceberg.parquet.ParquetValueReaders.UnboxedReader
-
- readBoolean() - Method in class org.apache.iceberg.parquet.ParquetValueReaders.UnboxedReader
-
- 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.
- readDouble() - Method in class org.apache.iceberg.parquet.ParquetValueReaders.FloatAsDoubleReader
-
- readDouble() - Method in class org.apache.iceberg.parquet.ParquetValueReaders.UnboxedReader
-
- reader(int) - Method in class org.apache.iceberg.avro.ValueReaders.StructReader
-
- readFloat() - Method in class org.apache.iceberg.parquet.ParquetValueReaders.UnboxedReader
-
- readInteger() - Method in class org.apache.iceberg.parquet.ParquetValueReaders.UnboxedReader
-
- 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
-
- readSupport(ReadSupport<?>) - Method in class org.apache.iceberg.parquet.Parquet.ReadBuilder
-
- reassignIds(Schema, Schema) - Static method in class org.apache.iceberg.types.TypeUtil
-
Reassigns ids in a schema from another schema.
- record(Schema, List<String>, List<T>) - Method in class org.apache.iceberg.avro.AvroSchemaVisitor
-
- 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
-
- recordCount() - Method in class org.apache.iceberg.ScanSummary.PartitionMetrics
-
- ref() - Method in class org.apache.iceberg.expressions.Predicate
-
- Reference - Interface in org.apache.iceberg.expressions
-
- refresh() - Method in class org.apache.iceberg.BaseTable
-
- refresh() - Method in class org.apache.iceberg.hadoop.HadoopTableOperations
-
- refresh() - Method in class org.apache.iceberg.hive.HiveTableOperations
-
- 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
-
- 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(Object) - Method in class org.apache.iceberg.orc.ColumnIdMap
-
- remove(String) - Method in interface org.apache.iceberg.UpdateProperties
-
Remove the given property key from the table.
- 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 interface org.apache.iceberg.catalog.Catalog
-
Rename a table.
- 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
-
- 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
-
- ReplaceManifests - Class in org.apache.iceberg
-
- ReplacePartitions - Interface in org.apache.iceberg
-
Not recommended: API for overwriting files in a table by partition.
- ReplacePartitionsOperation - Class in org.apache.iceberg
-
- 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
-
- 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
-
- 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
-
- ResidualEvaluator(PartitionSpec, Expression, boolean) - Constructor for class org.apache.iceberg.expressions.ResidualEvaluator
-
- residualFor(StructLike) - Method in class org.apache.iceberg.expressions.ResidualEvaluator
-
Returns a residual expression for the given partition values.
- retry(int) - Method in class org.apache.iceberg.util.Tasks.Builder
-
- ReusableEntry() - Constructor for class org.apache.iceberg.parquet.ParquetValueReaders.ReusableEntry
-
- 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() - Method in class org.apache.iceberg.parquet.Parquet.ReadBuilder
-
- 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.ReplaceManifests
-
- 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.BaseTable
-
- RewriteManifests - Interface in org.apache.iceberg
-
API for rewriting manifests for a table.
- rewriteManifests() - Method in interface org.apache.iceberg.Table
-
- rewriteManifests() - Method in interface org.apache.iceberg.Transaction
-
- 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
-
Create a new
rollback API
to roll back to a previous snapshot and commit.
- rollbackTo(Snapshot) - Method in class org.apache.iceberg.TableMetadata
-
- 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
-
- 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(Schema) - Method in class org.apache.iceberg.avro.Avro.WriteBuilder
-
- schema() - Method in class org.apache.iceberg.BaseTable
-
- 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(Schema) - Method in class org.apache.iceberg.orc.ORC.ReadBuilder
-
- 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 - 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(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, 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
-
- SchemaUtil() - Constructor for class org.apache.iceberg.pig.SchemaUtil
-
- 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.OverwriteData
-
- self() - Method in class org.apache.iceberg.ReplaceManifests
-
- self() - Method in class org.apache.iceberg.ReplacePartitionsOperation
-
- 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
-
- serialize() - Method in class org.apache.iceberg.orc.ColumnIdMap
-
- 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(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.ReplaceManifests
-
- 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 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
-
- 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
-
- 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
-
- setNull(I, int) - Method in class org.apache.iceberg.parquet.ParquetValueReaders.StructReader
-
- setPageSource(PageReader) - Method in class org.apache.iceberg.parquet.ColumnIterator
-
- 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
-
- setPushdownPredicate(Expression) - Method in class org.apache.iceberg.pig.IcebergStorage
-
- 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
-
- shouldCompress(Configuration) - Static method in class org.apache.iceberg.ConfigProperties
-
- 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.
- 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.orc.ColumnIdMap
-
- size() - Method in interface org.apache.iceberg.StructLike
-
- 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
-
- snapshotId() - Method in class org.apache.iceberg.events.ScanEvent
-
- snapshotId() - Method in class org.apache.iceberg.GenericManifestFile
-
- snapshotId() - Method in interface org.apache.iceberg.ManifestFile
-
- snapshotId() - Method in interface org.apache.iceberg.Snapshot
-
Return this snapshot's ID.
- snapshotId() - Method in class org.apache.iceberg.TableMetadata.SnapshotLogEntry
-
- snapshotLog() - Method in class org.apache.iceberg.TableMetadata
-
- SnapshotParser - Class in org.apache.iceberg
-
- snapshots() - Method in class org.apache.iceberg.BaseTable
-
- snapshots() - Method in interface org.apache.iceberg.Table
-
- snapshots() - Method in class org.apache.iceberg.TableMetadata
-
- 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.
- sortColumns() - Method in interface org.apache.iceberg.DataFile
-
- sourceId() - Method in class org.apache.iceberg.PartitionField
-
- SparkAvroReader - Class in org.apache.iceberg.spark.data
-
- SparkAvroReader(Schema) - 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
-
- 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(Schema) - 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.
- 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
-
- spec() - Method in class org.apache.iceberg.TableMetadata
-
- spec(int) - Method in class org.apache.iceberg.TableMetadata
-
- specForTable(SparkSession, String) - Static method in class org.apache.iceberg.spark.SparkSchemaUtil
-
- specId() - Method in class org.apache.iceberg.PartitionSpec
-
- specs() - 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
-
- start() - Method in interface org.apache.iceberg.FileScanTask
-
The starting position of this scan range in the file.
- 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
-
- 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, List<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<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
-
- summary() - Method in class org.apache.iceberg.ReplaceManifests
-
- summary() - Method in interface org.apache.iceberg.Snapshot
-
Return a string map of summary data for the operation that produced this snapshot.
- 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.