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

abortWith(Tasks.Task<I, ?>) - Method in class com.netflix.iceberg.util.Tasks.Builder
 
add(D) - Method in interface com.netflix.iceberg.io.FileAppender
 
add(VectorizedRowBatch) - Method in class com.netflix.iceberg.orc.OrcFileAppender
 
add(D) - Method in class com.netflix.iceberg.parquet.ParquetWriteAdapter
 
add(int, String, String) - Method in class com.netflix.iceberg.PartitionSpec.Builder
 
add(InternalRow) - Method in class com.netflix.iceberg.spark.data.SparkOrcWriter
 
addAll(Iterator<D>) - Method in interface com.netflix.iceberg.io.FileAppender
 
addAll(Iterable<D>) - Method in interface com.netflix.iceberg.io.FileAppender
 
addCloseable(Closeable) - Method in class com.netflix.iceberg.io.CloseableGroup
 
addColumn(String, Type) - Method in interface com.netflix.iceberg.UpdateSchema
Add a new top-level column.
addColumn(String, String, Type) - Method in interface com.netflix.iceberg.UpdateSchema
Add a new column to a nested struct.
addedFiles() - Method in class com.netflix.iceberg.ManifestReader
 
addedFiles() - Method in interface com.netflix.iceberg.Snapshot
Return all files added to the table in this snapshot.
addElement(List<E>, E) - Method in class com.netflix.iceberg.parquet.ParquetValueReaders.ListReader
 
addElement(I, E) - Method in class com.netflix.iceberg.parquet.ParquetValueReaders.RepeatedReader
 
addExtension(String) - Method in enum com.netflix.iceberg.FileFormat
Returns filename with this format's extension added, if necessary.
addFallbackIds(MessageType) - Static method in class com.netflix.iceberg.parquet.ParquetSchemaUtil
 
addFile(DataFile) - Method in class com.netflix.iceberg.OverwriteData
 
addFile(DataFile) - Method in interface com.netflix.iceberg.OverwriteFiles
Add a DataFile to the table.
addFile(DataFile) - Method in interface com.netflix.iceberg.ReplacePartitions
Add a DataFile to the table.
addFile(DataFile) - Method in class com.netflix.iceberg.ReplacePartitionsOperation
 
addFiles(PartitionSpec) - Method in class com.netflix.iceberg.BaseReplaceFiles
 
addPair(Map<K, V>, K, V) - Method in class com.netflix.iceberg.parquet.ParquetValueReaders.MapReader
 
addPair(I, K, V) - Method in class com.netflix.iceberg.parquet.ParquetValueReaders.RepeatedKeyValueReader
 
addSchema(Schema) - Method in class com.netflix.iceberg.data.avro.IcebergDecoder
Adds an Iceberg schema that can be used to decode buffers.
addSnapshot(Snapshot) - Method in class com.netflix.iceberg.TableMetadata
 
ADJUST_TO_UTC_PROP - Static variable in class com.netflix.iceberg.avro.AvroSchemaUtil
 
aliasToId(String) - Method in class com.netflix.iceberg.Schema
Returns the column id for the given column alias.
ALL_COLUMNS - Static variable in interface com.netflix.iceberg.Filterable
 
AlreadyExistsException - Exception in com.netflix.iceberg.exceptions
Exception raised when attempting to create a table that already exists.
AlreadyExistsException(String, Object...) - Constructor for exception com.netflix.iceberg.exceptions.AlreadyExistsException
 
AlreadyExistsException(Throwable, String, Object...) - Constructor for exception com.netflix.iceberg.exceptions.AlreadyExistsException
 
alwaysFalse() - Static method in class com.netflix.iceberg.expressions.Expressions
 
alwaysFalse() - Method in class com.netflix.iceberg.expressions.ExpressionVisitors.ExpressionVisitor
 
alwaysTrue() - Static method in class com.netflix.iceberg.expressions.Expressions
 
alwaysTrue() - Method in class com.netflix.iceberg.expressions.ExpressionVisitors.ExpressionVisitor
 
And - Class in com.netflix.iceberg.expressions
 
and(Expression, Expression) - Static method in class com.netflix.iceberg.expressions.Expressions
 
and(R, R) - Method in class com.netflix.iceberg.expressions.ExpressionVisitors.ExpressionVisitor
 
appendFile(DataFile) - Method in interface com.netflix.iceberg.AppendFiles
Append a DataFile to the table.
AppendFiles - Interface in com.netflix.iceberg
API for appending new files in a table.
apply(TableMetadata) - Method in class com.netflix.iceberg.BaseReplaceFiles
 
apply(TableMetadata) - Method in class com.netflix.iceberg.OverwriteData
 
apply() - Method in interface com.netflix.iceberg.PendingUpdate
Apply the pending changes and return the uncommitted changes for validation.
apply(TableMetadata) - Method in class com.netflix.iceberg.ReplacePartitionsOperation
 
apply(S) - Method in interface com.netflix.iceberg.transforms.Transform
Transforms a value to its corresponding partition value.
array(Schema, T) - Method in class com.netflix.iceberg.avro.AvroSchemaVisitor
 
array(ValueReader<T>) - Static method in class com.netflix.iceberg.avro.ValueReaders
 
array(ValueWriter<T>) - Static method in class com.netflix.iceberg.avro.ValueWriters
 
arrayMap(ValueReader<K>, ValueReader<V>) - Static method in class com.netflix.iceberg.avro.ValueReaders
 
arrayMap(ValueWriter<K>, ValueWriter<V>) - Static method in class com.netflix.iceberg.avro.ValueWriters
 
asCombinedScanTask() - Method in interface com.netflix.iceberg.CombinedScanTask
 
asCombinedScanTask() - Method in interface com.netflix.iceberg.ScanTask
 
asFileScanTask() - Method in interface com.netflix.iceberg.FileScanTask
 
asFileScanTask() - Method in interface com.netflix.iceberg.ScanTask
 
asListType() - Method in interface com.netflix.iceberg.types.Type
 
asListType() - Method in class com.netflix.iceberg.types.Types.ListType
 
asMapType() - Method in interface com.netflix.iceberg.types.Type
 
asMapType() - Method in class com.netflix.iceberg.types.Types.MapType
 
asNestedType() - Method in interface com.netflix.iceberg.types.Type
 
asNestedType() - Method in class com.netflix.iceberg.types.Type.NestedType
 
asOfTime(long) - Method in interface com.netflix.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 com.netflix.iceberg.types.Type
 
asPrimitiveType() - Method in class com.netflix.iceberg.types.Type.PrimitiveType
 
assignFreshIds(Type, TypeUtil.NextID) - Static method in class com.netflix.iceberg.types.TypeUtil
Assigns fresh ids from the nextId function for all fields in a type.
assignFreshIds(Schema, TypeUtil.NextID) - Static method in class com.netflix.iceberg.types.TypeUtil
Assigns fresh ids from the nextId function for all fields in a schema.
asStatic() - Method in class com.netflix.iceberg.common.DynFields.UnboundField
Returns this field as a StaticField.
asStatic() - Method in class com.netflix.iceberg.common.DynMethods.UnboundMethod
Returns this method as a StaticMethod.
asStruct() - Method in class com.netflix.iceberg.Schema
Returns the underlying struct type for this schema.
asStructType() - Method in interface com.netflix.iceberg.types.Type
 
asStructType() - Method in class com.netflix.iceberg.types.Types.StructType
 
Avro - Class in com.netflix.iceberg.avro
 
Avro.ReadBuilder - Class in com.netflix.iceberg.avro
 
Avro.WriteBuilder - Class in com.netflix.iceberg.avro
 
AVRO_COMPRESSION - Static variable in class com.netflix.iceberg.TableProperties
 
AVRO_COMPRESSION_DEFAULT - Static variable in class com.netflix.iceberg.TableProperties
 
AvroIterable<D> - Class in com.netflix.iceberg.avro
 
AvroSchemaUtil - Class in com.netflix.iceberg.avro
 
AvroSchemaUtil() - Constructor for class com.netflix.iceberg.avro.AvroSchemaUtil
 
AvroSchemaVisitor<T> - Class in com.netflix.iceberg.avro
 
AvroSchemaVisitor() - Constructor for class com.netflix.iceberg.avro.AvroSchemaVisitor
 

B

BaseCombinedScanTask - Class in com.netflix.iceberg
 
BaseCombinedScanTask(FileScanTask...) - Constructor for class com.netflix.iceberg.BaseCombinedScanTask
 
BaseCombinedScanTask(List<FileScanTask>) - Constructor for class com.netflix.iceberg.BaseCombinedScanTask
 
BaseMetastoreTableOperations - Class in com.netflix.iceberg
 
BaseMetastoreTableOperations(Configuration) - Constructor for class com.netflix.iceberg.BaseMetastoreTableOperations
 
BaseMetastoreTables - Class in com.netflix.iceberg
 
BaseMetastoreTables(Configuration) - Constructor for class com.netflix.iceberg.BaseMetastoreTables
 
BaseReplaceFiles - Class in com.netflix.iceberg
 
BaseReplaceFiles(TableOperations) - Constructor for class com.netflix.iceberg.BaseReplaceFiles
 
BaseTable - Class in com.netflix.iceberg
Base Table implementation.
BaseTable(TableOperations, String) - Constructor for class com.netflix.iceberg.BaseTable
 
beginCreate(Schema, PartitionSpec, String, String) - Method in class com.netflix.iceberg.BaseMetastoreTables
 
beginCreate(Schema, PartitionSpec, Map<String, String>, String, String) - Method in class com.netflix.iceberg.BaseMetastoreTables
 
beginReplace(Schema, PartitionSpec, String, String) - Method in class com.netflix.iceberg.BaseMetastoreTables
 
beginReplace(Schema, PartitionSpec, Map<String, String>, String, String) - Method in class com.netflix.iceberg.BaseMetastoreTables
 
BinaryAsDecimalReader(ColumnDescriptor, int) - Constructor for class com.netflix.iceberg.parquet.ParquetValueReaders.BinaryAsDecimalReader
 
BinaryType() - Constructor for class com.netflix.iceberg.types.Types.BinaryType
 
bind(Object) - Method in class com.netflix.iceberg.common.DynConstructors.Ctor
 
bind(Object) - Method in class com.netflix.iceberg.common.DynFields.UnboundField
Returns this method as a BoundMethod for the given receiver.
bind(Object) - Method in class com.netflix.iceberg.common.DynMethods.UnboundMethod
Returns this method as a BoundMethod for the given receiver.
bind(Types.StructType, Expression) - Static method in class com.netflix.iceberg.expressions.Binder
Replaces all unbound/named references with bound references to fields in the given struct.
bind(Types.StructType) - Method in class com.netflix.iceberg.expressions.UnboundPredicate
 
Binder - Class in com.netflix.iceberg.expressions
Rewrites expressions by replacing unbound named references with references to fields in a struct schema.
BinPacking - Class in com.netflix.iceberg.util
 
BinPacking() - Constructor for class com.netflix.iceberg.util.BinPacking
 
BinPacking.ListPacker<T> - Class in com.netflix.iceberg.util
 
BinPacking.PackingIterable<T> - Class in com.netflix.iceberg.util
 
blockSizeInBytes() - Method in interface com.netflix.iceberg.DataFile
 
booleans() - Static method in class com.netflix.iceberg.avro.ValueReaders
 
booleans() - Static method in class com.netflix.iceberg.avro.ValueWriters
 
BooleanType() - Constructor for class com.netflix.iceberg.types.Types.BooleanType
 
BoundExpressionVisitor() - Constructor for class com.netflix.iceberg.expressions.ExpressionVisitors.BoundExpressionVisitor
 
BoundPredicate<T> - Class in com.netflix.iceberg.expressions
 
BoundReference<T> - Class in com.netflix.iceberg.expressions
 
boundReferences(Types.StructType, List<Expression>) - Static method in class com.netflix.iceberg.expressions.Binder
 
bucket(String, int) - Method in class com.netflix.iceberg.PartitionSpec.Builder
 
bucket(String, int, int) - Method in interface com.netflix.iceberg.transforms.PartitionSpecVisitor
 
bucket(Type, int) - Static method in class com.netflix.iceberg.transforms.Transforms
Returns a bucket Transform for the given type and number of buckets.
build() - Method in class com.netflix.iceberg.avro.Avro.ReadBuilder
 
build() - Method in class com.netflix.iceberg.avro.Avro.WriteBuilder
 
build() - Method in class com.netflix.iceberg.common.DynClasses.Builder
Returns the first implementation or throws RuntimeException if one was not found.
build() - Method in class com.netflix.iceberg.common.DynConstructors.Builder
 
build() - Method in class com.netflix.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 com.netflix.iceberg.common.DynFields.Builder
Returns the first valid implementation as a BoundMethod or throws a RuntimeException if there is none.
build() - Method in class com.netflix.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 com.netflix.iceberg.common.DynMethods.Builder
Returns the first valid implementation as a BoundMethod or throws a RuntimeError if there is none.
build() - Method in class com.netflix.iceberg.data.IcebergGenerics.ScanBuilder
 
build() - Method in class com.netflix.iceberg.DataFiles.Builder
 
build() - Method in class com.netflix.iceberg.orc.ORC.ReadBuilder
 
build() - Method in class com.netflix.iceberg.orc.ORC.WriteBuilder
 
build() - Method in class com.netflix.iceberg.parquet.Parquet.ReadBuilder
 
build() - Method in class com.netflix.iceberg.parquet.Parquet.WriteBuilder
 
build() - Method in class com.netflix.iceberg.PartitionSpec.Builder
 
build() - Method in class com.netflix.iceberg.ScanSummary.Builder
Summarizes a table scan as a map of partition key to metrics for that partition.
buildAvroProjection(Schema, Schema, Map<String, String>) - Static method in class com.netflix.iceberg.avro.AvroSchemaUtil
 
buildChecked() - Method in class com.netflix.iceberg.common.DynClasses.Builder
Returns the first implementation or throws ClassNotFoundException if one was not found.
buildChecked() - Method in class com.netflix.iceberg.common.DynConstructors.Builder
 
buildChecked() - Method in class com.netflix.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 com.netflix.iceberg.common.DynFields.Builder
Returns the first valid implementation as a BoundMethod or throws a NoSuchMethodException if there is none.
buildChecked() - Method in class com.netflix.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 com.netflix.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 com.netflix.iceberg.common.DynClasses
 
Builder() - Constructor for class com.netflix.iceberg.common.DynClasses.Builder
 
builder() - Static method in class com.netflix.iceberg.common.DynConstructors
 
builder(Class<?>) - Static method in class com.netflix.iceberg.common.DynConstructors
 
Builder(Class<?>) - Constructor for class com.netflix.iceberg.common.DynConstructors.Builder
 
Builder() - Constructor for class com.netflix.iceberg.common.DynConstructors.Builder
 
builder() - Static method in class com.netflix.iceberg.common.DynFields
 
Builder() - Constructor for class com.netflix.iceberg.common.DynFields.Builder
 
builder(String) - Static method in class com.netflix.iceberg.common.DynMethods
Constructs a new builder for calling methods dynamically.
Builder(String) - Constructor for class com.netflix.iceberg.common.DynMethods.Builder
 
builder(PartitionSpec) - Static method in class com.netflix.iceberg.DataFiles
 
Builder() - Constructor for class com.netflix.iceberg.DataFiles.Builder
 
Builder(PartitionSpec) - Constructor for class com.netflix.iceberg.DataFiles.Builder
 
Builder(TableScan) - Constructor for class com.netflix.iceberg.ScanSummary.Builder
 
Builder(Iterable<I>) - Constructor for class com.netflix.iceberg.util.Tasks.Builder
 
builderFor(Schema) - Static method in class com.netflix.iceberg.PartitionSpec
Creates a new partition spec builder for the given Schema.
buildList(List<E>) - Method in class com.netflix.iceberg.parquet.ParquetValueReaders.ListReader
 
buildList(I) - Method in class com.netflix.iceberg.parquet.ParquetValueReaders.RepeatedReader
 
buildMap(Map<K, V>) - Method in class com.netflix.iceberg.parquet.ParquetValueReaders.MapReader
 
buildMap(I) - Method in class com.netflix.iceberg.parquet.ParquetValueReaders.RepeatedKeyValueReader
 
buildReader(Schema, MessageType) - Static method in class com.netflix.iceberg.data.parquet.GenericParquetReaders
 
buildReader(Schema, MessageType) - Static method in class com.netflix.iceberg.parquet.ParquetAvroValueReaders
 
buildReader(MessageType, Schema, Map<Integer, Object>) - Static method in class com.netflix.iceberg.pig.PigParquetReader
 
buildReader(Schema, MessageType) - Static method in class com.netflix.iceberg.spark.data.SparkParquetReaders
 
buildReplacement(Schema, PartitionSpec, Map<String, String>) - Method in class com.netflix.iceberg.TableMetadata
 
buildStatic() - Method in class com.netflix.iceberg.common.DynFields.Builder
Returns the first valid implementation as a StaticField or throws a RuntimeException if there is none.
buildStatic() - Method in class com.netflix.iceberg.common.DynMethods.Builder
Returns the first valid implementation as a StaticMethod or throws a RuntimeException if there is none.
buildStaticChecked() - Method in class com.netflix.iceberg.common.DynFields.Builder
Returns the first valid implementation as a StaticField or throws a NoSuchFieldException if there is none.
buildStaticChecked() - Method in class com.netflix.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 com.netflix.iceberg.parquet.ParquetValueReaders.StructReader
 
buildWriter(MessageType) - Static method in class com.netflix.iceberg.data.parquet.GenericParquetWriter
 
buildWriter(MessageType) - Static method in class com.netflix.iceberg.parquet.ParquetAvroWriter
 
byteBuffers() - Static method in class com.netflix.iceberg.avro.ValueReaders
 
byteBuffers() - Static method in class com.netflix.iceberg.avro.ValueWriters
 
byteBuffers(ColumnDescriptor) - Static method in class com.netflix.iceberg.parquet.ParquetValueWriters
 
bytes() - Static method in class com.netflix.iceberg.avro.ValueReaders
 
bytes() - Static method in class com.netflix.iceberg.avro.ValueWriters
 
BytesReader(ColumnDescriptor) - Constructor for class com.netflix.iceberg.parquet.ParquetValueReaders.BytesReader
 

C

callInit() - Method in class com.netflix.iceberg.parquet.Parquet.ReadBuilder
 
canTransform(Type) - Method in interface com.netflix.iceberg.transforms.Transform
Checks whether this function can be applied to the give Type.
charSequences() - Static method in class com.netflix.iceberg.types.Comparators
 
CharSequenceWrapper - Class in com.netflix.iceberg.util
Wrapper class to adapt CharSequence for use in maps and sets.
check(boolean, String, Object...) - Static method in exception com.netflix.iceberg.exceptions.ValidationException
 
checkCompatibility(PartitionSpec, Schema) - Static method in class com.netflix.iceberg.PartitionSpec
 
CheckCompatibility - Class in com.netflix.iceberg.types
 
child() - Method in class com.netflix.iceberg.expressions.Not
 
cleanUncommitted(Set<String>) - Method in class com.netflix.iceberg.BaseReplaceFiles
 
clear() - Method in class com.netflix.iceberg.DataFiles.Builder
 
clear() - Method in class com.netflix.iceberg.orc.ColumnIdMap
 
close() - Method in class com.netflix.iceberg.io.CloseableGroup
 
close() - Method in class com.netflix.iceberg.orc.OrcFileAppender
 
close() - Method in class com.netflix.iceberg.orc.OrcIterator
 
close() - Method in class com.netflix.iceberg.parquet.ParquetWriteAdapter
 
close() - Method in class com.netflix.iceberg.pig.IcebergPigInputFormat.IcebergRecordReader
 
close() - Method in class com.netflix.iceberg.spark.data.SparkOrcReader
 
close() - Method in class com.netflix.iceberg.spark.data.SparkOrcWriter
 
CloseableGroup - Class in com.netflix.iceberg.io
 
CloseableGroup() - Constructor for class com.netflix.iceberg.io.CloseableGroup
 
CloseableIterable<T> - Interface in com.netflix.iceberg.io
 
collections(int, int, ParquetValueWriter<E>) - Static method in class com.netflix.iceberg.parquet.ParquetValueWriters
 
column() - Method in interface com.netflix.iceberg.parquet.ParquetValueReader
 
column - Variable in class com.netflix.iceberg.parquet.ParquetValueReaders.PrimitiveReader
 
column() - Method in class com.netflix.iceberg.parquet.ParquetValueReaders.PrimitiveReader
 
column() - Method in class com.netflix.iceberg.parquet.ParquetValueReaders.RepeatedKeyValueReader
 
column() - Method in class com.netflix.iceberg.parquet.ParquetValueReaders.RepeatedReader
 
column() - Method in class com.netflix.iceberg.parquet.ParquetValueReaders.StructReader
 
column - Variable in class com.netflix.iceberg.parquet.ParquetValueWriters.PrimitiveWriter
 
COLUMN_NUMBERS_ATTRIBUTE - Static variable in class com.netflix.iceberg.orc.OrcFileAppender
 
ColumnIdMap - Class in com.netflix.iceberg.orc
The mapping from ORC's TypeDescription to the Iceberg column ids.
ColumnIdMap() - Constructor for class com.netflix.iceberg.orc.ColumnIdMap
 
ColumnIterator<T> - Class in com.netflix.iceberg.parquet
 
columns() - Method in interface com.netflix.iceberg.parquet.ParquetValueReader
 
columns() - Method in class com.netflix.iceberg.parquet.ParquetValueReaders.PrimitiveReader
 
columns() - Method in class com.netflix.iceberg.parquet.ParquetValueReaders.RepeatedKeyValueReader
 
columns() - Method in class com.netflix.iceberg.parquet.ParquetValueReaders.RepeatedReader
 
columns() - Method in class com.netflix.iceberg.parquet.ParquetValueReaders.StructReader
 
columns() - Method in interface com.netflix.iceberg.parquet.ParquetValueWriter
 
columns() - Method in class com.netflix.iceberg.parquet.ParquetValueWriters.PrimitiveWriter
 
columns() - Method in class com.netflix.iceberg.parquet.ParquetValueWriters.RepeatedKeyValueWriter
 
columns() - Method in class com.netflix.iceberg.parquet.ParquetValueWriters.RepeatedWriter
 
columns() - Method in class com.netflix.iceberg.parquet.ParquetValueWriters.StructWriter
 
columns() - Method in class com.netflix.iceberg.Schema
 
columnSizes() - Method in interface com.netflix.iceberg.DataFile
 
columnSizes() - Method in class com.netflix.iceberg.Metrics
 
ColumnWriter<T> - Class in com.netflix.iceberg.parquet
 
com.netflix.iceberg - package com.netflix.iceberg
 
com.netflix.iceberg.avro - package com.netflix.iceberg.avro
 
com.netflix.iceberg.common - package com.netflix.iceberg.common
 
com.netflix.iceberg.data - package com.netflix.iceberg.data
 
com.netflix.iceberg.data.avro - package com.netflix.iceberg.data.avro
 
com.netflix.iceberg.data.parquet - package com.netflix.iceberg.data.parquet
 
com.netflix.iceberg.exceptions - package com.netflix.iceberg.exceptions
 
com.netflix.iceberg.expressions - package com.netflix.iceberg.expressions
 
com.netflix.iceberg.hadoop - package com.netflix.iceberg.hadoop
 
com.netflix.iceberg.io - package com.netflix.iceberg.io
 
com.netflix.iceberg.orc - package com.netflix.iceberg.orc
 
com.netflix.iceberg.parquet - package com.netflix.iceberg.parquet
 
com.netflix.iceberg.pig - package com.netflix.iceberg.pig
 
com.netflix.iceberg.spark - package com.netflix.iceberg.spark
 
com.netflix.iceberg.spark.data - package com.netflix.iceberg.spark.data
 
com.netflix.iceberg.spark.hacks - package com.netflix.iceberg.spark.hacks
 
com.netflix.iceberg.spark.source - package com.netflix.iceberg.spark.source
 
com.netflix.iceberg.transforms - package com.netflix.iceberg.transforms
 
com.netflix.iceberg.types - package com.netflix.iceberg.types
 
com.netflix.iceberg.util - package com.netflix.iceberg.util
 
CombinedScanTask - Interface in com.netflix.iceberg
A scan task made of several ranges from files.
commit() - Method in interface com.netflix.iceberg.PendingUpdate
Apply the pending changes and commit.
commit(TableMetadata, TableMetadata) - Method in interface com.netflix.iceberg.TableOperations
Replace the base table metadata with a new version.
COMMIT_MAX_RETRY_WAIT_MS - Static variable in class com.netflix.iceberg.TableProperties
 
COMMIT_MAX_RETRY_WAIT_MS_DEFAULT - Static variable in class com.netflix.iceberg.TableProperties
 
COMMIT_MIN_RETRY_WAIT_MS - Static variable in class com.netflix.iceberg.TableProperties
 
COMMIT_MIN_RETRY_WAIT_MS_DEFAULT - Static variable in class com.netflix.iceberg.TableProperties
 
COMMIT_NUM_RETRIES - Static variable in class com.netflix.iceberg.TableProperties
 
COMMIT_NUM_RETRIES_DEFAULT - Static variable in class com.netflix.iceberg.TableProperties
 
COMMIT_TOTAL_RETRY_TIME_MS - Static variable in class com.netflix.iceberg.TableProperties
 
COMMIT_TOTAL_RETRY_TIME_MS_DEFAULT - Static variable in class com.netflix.iceberg.TableProperties
 
CommitFailedException - Exception in com.netflix.iceberg.exceptions
Exception raised when a commit fails because of out of date metadata.
CommitFailedException(String, Object...) - Constructor for exception com.netflix.iceberg.exceptions.CommitFailedException
 
CommitFailedException(Throwable, String, Object...) - Constructor for exception com.netflix.iceberg.exceptions.CommitFailedException
 
commitTransaction() - Method in interface com.netflix.iceberg.Transaction
Apply the pending changes from all actions and commit.
comparator() - Method in interface com.netflix.iceberg.expressions.Literal
Return a Comparator for values.
Comparators - Class in com.netflix.iceberg.types
 
Comparators() - Constructor for class com.netflix.iceberg.types.Comparators
 
compatibleWith(PartitionSpec) - Method in class com.netflix.iceberg.PartitionSpec
 
config(String, String) - Method in class com.netflix.iceberg.orc.ORC.ReadBuilder
 
config(String, String) - Method in class com.netflix.iceberg.orc.ORC.WriteBuilder
 
containsKey(Object) - Method in class com.netflix.iceberg.orc.ColumnIdMap
 
containsValue(Object) - Method in class com.netflix.iceberg.orc.ColumnIdMap
 
Conversions - Class in com.netflix.iceberg.types
 
Conversions() - Constructor for class com.netflix.iceberg.types.Conversions
 
convert(Schema, String) - Static method in class com.netflix.iceberg.avro.AvroSchemaUtil
 
convert(Schema, Map<Types.StructType, String>) - Static method in class com.netflix.iceberg.avro.AvroSchemaUtil
 
convert(Type) - Static method in class com.netflix.iceberg.avro.AvroSchemaUtil
 
convert(Types.StructType, String) - Static method in class com.netflix.iceberg.avro.AvroSchemaUtil
 
convert(Type, Map<Types.StructType, String>) - Static method in class com.netflix.iceberg.avro.AvroSchemaUtil
 
convert(Schema) - Static method in class com.netflix.iceberg.avro.AvroSchemaUtil
 
convert(Schema, String) - Static method in class com.netflix.iceberg.parquet.ParquetSchemaUtil
 
convert(MessageType) - Static method in class com.netflix.iceberg.parquet.ParquetSchemaUtil
 
convert(Schema, String) - Method in class com.netflix.iceberg.parquet.TypeToMessageType
 
convert(Schema) - Static method in class com.netflix.iceberg.pig.SchemaUtil
 
convert(Expression) - Static method in class com.netflix.iceberg.spark.SparkExpressions
 
convert(Expression, Schema) - Static method in class com.netflix.iceberg.spark.SparkExpressions
 
convert(Filter) - Static method in class com.netflix.iceberg.spark.SparkFilters
 
convert(Schema) - Static method in class com.netflix.iceberg.spark.SparkSchemaUtil
Convert a Schema to a Spark type.
convert(Type) - Static method in class com.netflix.iceberg.spark.SparkSchemaUtil
Convert a Type to a Spark type.
convert(StructType) - Static method in class com.netflix.iceberg.spark.SparkSchemaUtil
Convert a Spark struct to a Schema with new field ids.
convert(DataType) - Static method in class com.netflix.iceberg.spark.SparkSchemaUtil
Convert a Spark struct to a Type with new field ids.
convert(Schema, StructType) - Static method in class com.netflix.iceberg.spark.SparkSchemaUtil
Convert a Spark struct to a Schema based on the given schema.
convertTypes(Types.StructType, String) - Static method in class com.netflix.iceberg.avro.AvroSchemaUtil
 
copy() - Method in class com.netflix.iceberg.data.GenericRecord
 
copy(Map<String, Object>) - Method in class com.netflix.iceberg.data.GenericRecord
 
copy() - Method in interface com.netflix.iceberg.data.Record
 
copy(Map<String, Object>) - Method in interface com.netflix.iceberg.data.Record
 
copy() - Method in interface com.netflix.iceberg.DataFile
Copies this data file.
copy(DataFile) - Method in class com.netflix.iceberg.DataFiles.Builder
 
copy(PartitionSpec, StructLike) - Static method in class com.netflix.iceberg.DataFiles
 
create(Schema, String, String) - Method in class com.netflix.iceberg.BaseMetastoreTables
 
create(Schema, PartitionSpec, String, String) - Method in class com.netflix.iceberg.BaseMetastoreTables
 
create(Schema, PartitionSpec, Map<String, String>, String, String) - Method in class com.netflix.iceberg.BaseMetastoreTables
 
create(Schema) - Static method in class com.netflix.iceberg.data.avro.DataReader
 
create(Schema) - Static method in class com.netflix.iceberg.data.avro.DataWriter
 
create(Schema) - Static method in class com.netflix.iceberg.data.GenericRecord
 
create(Types.StructType) - Static method in class com.netflix.iceberg.data.GenericRecord
 
create() - Method in class com.netflix.iceberg.hadoop.HadoopOutputFile
 
create(Schema, PartitionSpec, Map<String, String>, String) - Method in class com.netflix.iceberg.hadoop.HadoopTables
Create a table using the FileSystem implementation resolve from location.
create() - Method in interface com.netflix.iceberg.io.OutputFile
Create a new file and return a PositionOutputStream to it.
create(Schema, String) - Method in interface com.netflix.iceberg.Tables
 
create(Schema, PartitionSpec, String) - Method in interface com.netflix.iceberg.Tables
 
create(Schema, PartitionSpec, Map<String, String>, String) - Method in interface com.netflix.iceberg.Tables
 
createOrOverwrite() - Method in class com.netflix.iceberg.hadoop.HadoopOutputFile
 
createOrOverwrite() - Method in interface com.netflix.iceberg.io.OutputFile
Create a new file and return a PositionOutputStream to it.
createReader(DataSourceOptions) - Method in class com.netflix.iceberg.spark.source.IcebergSource
 
createReaderFunc(Function<Schema, DatumReader<?>>) - Method in class com.netflix.iceberg.avro.Avro.ReadBuilder
 
createReaderFunc(Function<MessageType, ParquetValueReader<?>>) - Method in class com.netflix.iceberg.parquet.Parquet.ReadBuilder
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class com.netflix.iceberg.pig.IcebergPigInputFormat
 
createWriter(String, StructType, SaveMode, DataSourceOptions) - Method in class com.netflix.iceberg.spark.source.IcebergSource
 
createWriterFunc(Function<Schema, DatumWriter<?>>) - Method in class com.netflix.iceberg.avro.Avro.WriteBuilder
 
createWriterFunc(Function<MessageType, ParquetValueWriter<?>>) - Method in class com.netflix.iceberg.parquet.Parquet.WriteBuilder
 
ctorImpl(Class<?>, Class<?>...) - Method in class com.netflix.iceberg.common.DynMethods.Builder
 
ctorImpl(String, Class<?>...) - Method in class com.netflix.iceberg.common.DynMethods.Builder
 
current() - Method in class com.netflix.iceberg.BaseMetastoreTableOperations
 
current() - Method in interface com.netflix.iceberg.TableOperations
Return the currently loaded table metadata, without checking for updates.
currentDefinitionLevel() - Method in class com.netflix.iceberg.parquet.ColumnIterator
 
currentMetadataLocation() - Method in class com.netflix.iceberg.BaseMetastoreTableOperations
 
currentRepetitionLevel() - Method in class com.netflix.iceberg.parquet.ColumnIterator
 
currentSnapshot() - Method in class com.netflix.iceberg.BaseTable
 
currentSnapshot() - Method in interface com.netflix.iceberg.Table
Get the current snapshot for this table.
currentSnapshot() - Method in class com.netflix.iceberg.TableMetadata
 
currentVersion() - Method in class com.netflix.iceberg.BaseMetastoreTableOperations
 
CustomOrderSchemaVisitor() - Constructor for class com.netflix.iceberg.types.TypeUtil.CustomOrderSchemaVisitor
 

D

data(PartitionSpec, String) - Static method in class com.netflix.iceberg.DataFiles
 
DataFile - Interface in com.netflix.iceberg
Interface for files listed in a table manifest.
DataFiles - Class in com.netflix.iceberg
 
DataFiles() - Constructor for class com.netflix.iceberg.DataFiles
 
DataFiles.Builder - Class in com.netflix.iceberg
 
dataLocation() - Method in class com.netflix.iceberg.BaseMetastoreTableOperations
 
DataReader<T> - Class in com.netflix.iceberg.data.avro
 
DataWriter<T> - Class in com.netflix.iceberg.data.avro
 
DateType() - Constructor for class com.netflix.iceberg.types.Types.DateType
 
day(String) - Method in class com.netflix.iceberg.PartitionSpec.Builder
 
day(String, int) - Method in interface com.netflix.iceberg.transforms.PartitionSpecVisitor
 
day(Type) - Static method in class com.netflix.iceberg.transforms.Transforms
Returns a day Transform for date or timestamp types.
decimal(ValueReader<byte[]>, int) - Static method in class com.netflix.iceberg.avro.ValueReaders
 
decimal(int, int) - Static method in class com.netflix.iceberg.avro.ValueWriters
 
DECIMAL_INT32_MAX_DIGITS - Static variable in class com.netflix.iceberg.parquet.TypeToMessageType
 
DECIMAL_INT64_MAX_DIGITS - Static variable in class com.netflix.iceberg.parquet.TypeToMessageType
 
decimalAsFixed(ColumnDescriptor, int, int) - Static method in class com.netflix.iceberg.parquet.ParquetValueWriters
 
decimalAsInteger(ColumnDescriptor, int, int) - Static method in class com.netflix.iceberg.parquet.ParquetValueWriters
 
decimalAsLong(ColumnDescriptor, int, int) - Static method in class com.netflix.iceberg.parquet.ParquetValueWriters
 
decimalRequriedBytes(int) - Static method in class com.netflix.iceberg.types.TypeUtil
 
decode(InputStream, D) - Method in class com.netflix.iceberg.data.avro.IcebergDecoder
 
DEFAULT_FILE_FORMAT - Static variable in class com.netflix.iceberg.TableProperties
 
DEFAULT_FILE_FORMAT_DEFAULT - Static variable in class com.netflix.iceberg.TableProperties
 
defaultAlwaysNull() - Method in class com.netflix.iceberg.common.DynFields.Builder
Instructs this builder to return AlwaysNull if no implementation is found.
defaultFormat(FileFormat) - Method in interface com.netflix.iceberg.UpdateProperties
Set the default file format for the table.
DelegatingInputStream - Interface in com.netflix.iceberg.io
 
DelegatingOutputStream - Interface in com.netflix.iceberg.io
 
deleteColumn(String) - Method in interface com.netflix.iceberg.UpdateSchema
Delete a column in the schema.
deletedFiles() - Method in class com.netflix.iceberg.BaseReplaceFiles
 
deletedFiles() - Method in class com.netflix.iceberg.ManifestReader
 
deletedFiles() - Method in interface com.netflix.iceberg.Snapshot
Return all files deleted from the table in this snapshot.
deleteFile(String) - Method in class com.netflix.iceberg.BaseMetastoreTableOperations
 
deleteFile(CharSequence) - Method in interface com.netflix.iceberg.DeleteFiles
Delete a file path from the underlying table.
deleteFile(DataFile) - Method in interface com.netflix.iceberg.DeleteFiles
Delete a file tracked by a DataFile from the underlying table.
deleteFile(String) - Method in interface com.netflix.iceberg.TableOperations
Delete a file.
DeleteFiles - Interface in com.netflix.iceberg
API for deleting files from a table.
deleteFromRowFilter(Expression) - Method in interface com.netflix.iceberg.DeleteFiles
Delete files that match an Expression on data rows from the table.
deleteWith(Consumer<String>) - Method in interface com.netflix.iceberg.ExpireSnapshots
Passes an alternative delete implementation that will be used for manifests and data files.
deserialize(TypeDescription, ByteBuffer) - Static method in class com.netflix.iceberg.orc.ColumnIdMap
 
doubles() - Static method in class com.netflix.iceberg.avro.ValueReaders
 
doubles() - Static method in class com.netflix.iceberg.avro.ValueWriters
 
DoubleType() - Constructor for class com.netflix.iceberg.types.Types.DoubleType
 
DynClasses - Class in com.netflix.iceberg.common
 
DynClasses() - Constructor for class com.netflix.iceberg.common.DynClasses
 
DynClasses.Builder - Class in com.netflix.iceberg.common
 
DynConstructors - Class in com.netflix.iceberg.common
Copied from parquet-common
DynConstructors() - Constructor for class com.netflix.iceberg.common.DynConstructors
 
DynConstructors.Builder - Class in com.netflix.iceberg.common
 
DynConstructors.Ctor<C> - Class in com.netflix.iceberg.common
 
DynFields - Class in com.netflix.iceberg.common
 
DynFields() - Constructor for class com.netflix.iceberg.common.DynFields
 
DynFields.BoundField<T> - Class in com.netflix.iceberg.common
 
DynFields.Builder - Class in com.netflix.iceberg.common
 
DynFields.StaticField<T> - Class in com.netflix.iceberg.common
 
DynFields.UnboundField<T> - Class in com.netflix.iceberg.common
Convenience wrapper class around Field.
DynMethods - Class in com.netflix.iceberg.common
Copied from parquet-common
DynMethods() - Constructor for class com.netflix.iceberg.common.DynMethods
 
DynMethods.BoundMethod - Class in com.netflix.iceberg.common
 
DynMethods.Builder - Class in com.netflix.iceberg.common
 
DynMethods.StaticMethod - Class in com.netflix.iceberg.common
 
DynMethods.UnboundMethod - Class in com.netflix.iceberg.common
Convenience wrapper class around Method.

E

ELEMENT_ID_PROP - Static variable in class com.netflix.iceberg.avro.AvroSchemaUtil
 
elementId() - Method in class com.netflix.iceberg.types.Types.ListType
 
elements(L) - Method in class com.netflix.iceberg.parquet.ParquetValueWriters.RepeatedWriter
 
elementType() - Method in class com.netflix.iceberg.types.Types.ListType
 
encode(D) - Method in class com.netflix.iceberg.data.avro.IcebergEncoder
 
encode(D, OutputStream) - Method in class com.netflix.iceberg.data.avro.IcebergEncoder
 
entrySet() - Method in class com.netflix.iceberg.orc.ColumnIdMap
 
eq(BoundReference<T>, Literal<T>) - Method in class com.netflix.iceberg.expressions.ExpressionVisitors.BoundExpressionVisitor
 
equal(String, T) - Static method in class com.netflix.iceberg.expressions.Expressions
 
equals(Object) - Method in class com.netflix.iceberg.data.GenericRecord
 
equals(Object) - Method in class com.netflix.iceberg.PartitionField
 
equals(Object) - Method in class com.netflix.iceberg.PartitionSpec
 
equals(Object) - Method in class com.netflix.iceberg.TableMetadata.SnapshotLogEntry
 
equals(Object) - Method in class com.netflix.iceberg.types.Types.DecimalType
 
equals(Object) - Method in class com.netflix.iceberg.types.Types.FixedType
 
equals(Object) - Method in class com.netflix.iceberg.types.Types.ListType
 
equals(Object) - Method in class com.netflix.iceberg.types.Types.MapType
 
equals(Object) - Method in class com.netflix.iceberg.types.Types.NestedField
 
equals(Object) - Method in class com.netflix.iceberg.types.Types.StructType
 
equals(Object) - Method in class com.netflix.iceberg.types.Types.TimestampType
 
equals(Object) - Method in class com.netflix.iceberg.util.CharSequenceWrapper
 
equals(Object) - Method in class com.netflix.iceberg.util.Pair
 
equals(Object) - Method in class com.netflix.iceberg.util.StructLikeWrapper
 
eval(StructLike) - Method in class com.netflix.iceberg.expressions.Evaluator
 
eval(DataFile) - Method in class com.netflix.iceberg.expressions.InclusiveMetricsEvaluator
Test whether the file may contain records that match the expression.
eval(DataFile) - Method in class com.netflix.iceberg.expressions.StrictMetricsEvaluator
Test whether the file may contain records that match the expression.
Evaluator - Class in com.netflix.iceberg.expressions
Evaluates an Expression for data described by a Types.StructType.
Evaluator(Types.StructType, Expression) - Constructor for class com.netflix.iceberg.expressions.Evaluator
 
Exceptions - Class in com.netflix.iceberg.util
 
ExceptionUtil - Class in com.netflix.iceberg.util
 
ExceptionUtil() - Constructor for class com.netflix.iceberg.util.ExceptionUtil
 
executeWith(ExecutorService) - Method in class com.netflix.iceberg.util.Tasks.Builder
 
expireOlderThan(long) - Method in interface com.netflix.iceberg.ExpireSnapshots
Expires all snapshots older than the given timestamp.
expireSnapshotId(long) - Method in interface com.netflix.iceberg.ExpireSnapshots
Expires a specific Snapshot identified by id.
expireSnapshots() - Method in class com.netflix.iceberg.BaseTable
 
ExpireSnapshots - Interface in com.netflix.iceberg
API for removing old snapshots from a table.
expireSnapshots() - Method in interface com.netflix.iceberg.Table
Create a new expire API to manage snapshots in this table and commit.
expireSnapshots() - Method in interface com.netflix.iceberg.Transaction
Create a new expire API to manage snapshots in this table.
exponentialBackoff(long, long, long, double) - Method in class com.netflix.iceberg.util.Tasks.Builder
 
Expression - Interface in com.netflix.iceberg.expressions
Represents a boolean expression tree.
Expression.Operation - Enum in com.netflix.iceberg.expressions
 
Expressions - Class in com.netflix.iceberg.expressions
Factory methods for creating expressions.
Expressions() - Constructor for class com.netflix.iceberg.expressions.Expressions
 
ExpressionVisitor() - Constructor for class com.netflix.iceberg.expressions.ExpressionVisitors.ExpressionVisitor
 
ExpressionVisitors - Class in com.netflix.iceberg.expressions
Utils for traversing expressions.
ExpressionVisitors() - Constructor for class com.netflix.iceberg.expressions.ExpressionVisitors
 
ExpressionVisitors.BoundExpressionVisitor<R> - Class in com.netflix.iceberg.expressions
 
ExpressionVisitors.ExpressionVisitor<R> - Class in com.netflix.iceberg.expressions
 

F

factory() - Static method in class com.netflix.iceberg.util.JsonUtil
 
False - Class in com.netflix.iceberg.expressions
An expression that is always false.
field(Types.NestedField) - Method in class com.netflix.iceberg.parquet.TypeToMessageType
 
field(Types.NestedField, Supplier<Type>) - Method in class com.netflix.iceberg.spark.PruneColumnsWithoutReordering
 
field(Types.NestedField, Supplier<Type>) - Method in class com.netflix.iceberg.spark.PruneColumnsWithReordering
 
field(Types.NestedField, Supplier<List<String>>) - Method in class com.netflix.iceberg.types.CheckCompatibility
 
field(Types.NestedField, Map<String, Integer>) - Method in class com.netflix.iceberg.types.IndexByName
 
field(int) - Method in class com.netflix.iceberg.types.Type.NestedType
 
field(int) - Method in class com.netflix.iceberg.types.Types.ListType
 
field(int) - Method in class com.netflix.iceberg.types.Types.MapType
 
field(String) - Method in class com.netflix.iceberg.types.Types.StructType
 
field(int) - Method in class com.netflix.iceberg.types.Types.StructType
 
field(Types.NestedField, Supplier<T>) - Method in class com.netflix.iceberg.types.TypeUtil.CustomOrderSchemaVisitor
 
field(Types.NestedField, T) - Method in class com.netflix.iceberg.types.TypeUtil.SchemaVisitor
 
FIELD_ID_PROP - Static variable in class com.netflix.iceberg.avro.AvroSchemaUtil
 
fieldId() - Method in class com.netflix.iceberg.expressions.BoundReference
 
fieldId() - Method in class com.netflix.iceberg.types.Types.NestedField
 
fieldIds - Variable in class com.netflix.iceberg.types.TypeUtil.SchemaVisitor
 
fieldNames - Variable in class com.netflix.iceberg.parquet.ParquetTypeVisitor
 
fieldNames - Variable in class com.netflix.iceberg.parquet.TypeWithSchemaVisitor
 
fieldNames - Variable in class com.netflix.iceberg.types.TypeUtil.SchemaVisitor
 
fields() - Method in class com.netflix.iceberg.PartitionSpec
 
fields() - Method in class com.netflix.iceberg.types.Type.NestedType
 
fields() - Method in class com.netflix.iceberg.types.Types.ListType
 
fields() - Method in class com.netflix.iceberg.types.Types.MapType
 
fields() - Method in class com.netflix.iceberg.types.Types.StructType
 
fieldType(String) - Method in class com.netflix.iceberg.types.Type.NestedType
 
fieldType(String) - Method in class com.netflix.iceberg.types.Types.ListType
 
fieldType(String) - Method in class com.netflix.iceberg.types.Types.MapType
 
fieldType(String) - Method in class com.netflix.iceberg.types.Types.StructType
 
file() - Method in interface com.netflix.iceberg.FileScanTask
The file to scan.
file() - Method in class com.netflix.iceberg.ManifestReader
 
file() - Method in class com.netflix.iceberg.TableMetadata
 
FileAppender<D> - Interface in com.netflix.iceberg.io
 
fileCount() - Method in class com.netflix.iceberg.ScanSummary.PartitionMetrics
 
FileFormat - Enum in com.netflix.iceberg
Enum of supported file formats.
fileOrdinal() - Method in interface com.netflix.iceberg.DataFile
 
files() - Method in class com.netflix.iceberg.BaseCombinedScanTask
 
files() - Method in interface com.netflix.iceberg.CombinedScanTask
Return the tasks in this combined task.
Files - Class in com.netflix.iceberg
 
Files() - Constructor for class com.netflix.iceberg.Files
 
FileScanTask - Interface in com.netflix.iceberg
A scan task over a range of a single file.
fileSizeInBytes() - Method in interface com.netflix.iceberg.DataFile
 
filesToAdd - Variable in class com.netflix.iceberg.BaseReplaceFiles
 
filter(Expression) - Method in class com.netflix.iceberg.parquet.Parquet.ReadBuilder
 
filter(Expression) - Method in interface com.netflix.iceberg.TableScan
Create a new TableScan from the results of this filtered by the Expression.
filter() - Method in interface com.netflix.iceberg.TableScan
Returns this scan's filter Expression.
Filterable<T extends Filterable<T>> - Interface in com.netflix.iceberg
Methods to filter files in a snapshot or manifest when reading.
FilteredManifest - Class in com.netflix.iceberg
 
FilteredSnapshot - Class in com.netflix.iceberg
 
filterPartitions(Expression) - Method in interface com.netflix.iceberg.Filterable
Adds a filter expression on partition data for matching files.
filterPartitions(Expression) - Method in class com.netflix.iceberg.FilteredManifest
 
filterPartitions(Expression) - Method in class com.netflix.iceberg.FilteredSnapshot
 
filterPartitions(Expression) - Method in class com.netflix.iceberg.ManifestReader
 
filterRecords(boolean) - Method in class com.netflix.iceberg.parquet.Parquet.ReadBuilder
 
filterRows(Expression) - Method in interface com.netflix.iceberg.Filterable
Adds a filter expression on data rows for matching files.
filterRows(Expression) - Method in class com.netflix.iceberg.FilteredManifest
 
filterRows(Expression) - Method in class com.netflix.iceberg.FilteredSnapshot
 
filterRows(Expression) - Method in class com.netflix.iceberg.ManifestReader
 
find(Schema, Predicate<Type>) - Static method in class com.netflix.iceberg.types.TypeUtil
 
findColumnName(int) - Method in class com.netflix.iceberg.Schema
Returns the full column name for the given id.
findField(int) - Method in class com.netflix.iceberg.Schema
Returns the sub-field identified by the field id as a Types.NestedField.
findField(String) - Method in class com.netflix.iceberg.Schema
Returns a sub-field field by name as a Types.NestedField.
findTable(DataSourceOptions) - Method in class com.netflix.iceberg.spark.source.IcebergSource
 
findType(String) - Method in class com.netflix.iceberg.Schema
 
findType(int) - Method in class com.netflix.iceberg.Schema
Returns the Type of a sub-field identified by the field id.
first() - Method in class com.netflix.iceberg.util.Pair
 
fixed(int) - Static method in class com.netflix.iceberg.avro.ValueReaders
 
fixed(Schema) - Static method in class com.netflix.iceberg.avro.ValueReaders
 
fixed(int) - Static method in class com.netflix.iceberg.avro.ValueWriters
 
flipLR() - Method in enum com.netflix.iceberg.expressions.Expression.Operation
 
FloatAsDoubleReader(ColumnDescriptor) - Constructor for class com.netflix.iceberg.parquet.ParquetValueReaders.FloatAsDoubleReader
 
floats() - Static method in class com.netflix.iceberg.avro.ValueReaders
 
floats() - Static method in class com.netflix.iceberg.avro.ValueWriters
 
FloatType() - Constructor for class com.netflix.iceberg.types.Types.FloatType
 
foreach(Iterable<I>) - Static method in class com.netflix.iceberg.util.Tasks
 
foreach(I...) - Static method in class com.netflix.iceberg.util.Tasks
 
format() - Method in interface com.netflix.iceberg.DataFile
 
forTable(Table) - Method in class com.netflix.iceberg.parquet.Parquet.WriteBuilder
 
fromByteBuffer(Type, ByteBuffer) - Static method in class com.netflix.iceberg.types.Conversions
 
fromFileName(CharSequence) - Static method in enum com.netflix.iceberg.FileFormat
 
fromFixed(GenericFixed, Schema, LogicalType) - Method in class com.netflix.iceberg.avro.UUIDConversion
 
fromInputFile(InputFile, long) - Static method in class com.netflix.iceberg.DataFiles
 
fromInputFile(InputFile, PartitionData, long) - Static method in class com.netflix.iceberg.DataFiles
 
fromInputFile(InputFile, PartitionData, Metrics) - Static method in class com.netflix.iceberg.DataFiles
 
fromInputFile(InputFile) - Static method in class com.netflix.iceberg.parquet.ParquetMetrics
 
fromJson(Schema, JsonNode) - Static method in class com.netflix.iceberg.PartitionSpecParser
 
fromJson(Schema, String) - Static method in class com.netflix.iceberg.PartitionSpecParser
 
fromJson(JsonNode) - Static method in class com.netflix.iceberg.SchemaParser
 
fromJson(String) - Static method in class com.netflix.iceberg.SchemaParser
 
fromJson(TableOperations, String) - Static method in class com.netflix.iceberg.SnapshotParser
 
fromLocation(CharSequence, Configuration) - Static method in class com.netflix.iceberg.hadoop.HadoopInputFile
 
fromLocation(CharSequence, long, Configuration) - Static method in class com.netflix.iceberg.hadoop.HadoopInputFile
 
fromMetadata(ParquetMetadata) - Static method in class com.netflix.iceberg.parquet.ParquetMetrics
 
fromOrc(TypeDescription, ColumnIdMap) - Method in class com.netflix.iceberg.orc.TypeConversion
Convert an ORC schema to an Iceberg schema.
fromParquetInputFile(InputFile, PartitionData, Metrics) - Static method in class com.netflix.iceberg.DataFiles
 
fromParquetStat(FileStatus, PartitionData, Metrics) - Static method in class com.netflix.iceberg.DataFiles
 
fromPartitionString(Type, String) - Static method in class com.netflix.iceberg.types.Conversions
 
fromPath(Path, Configuration) - Static method in class com.netflix.iceberg.hadoop.HadoopInputFile
 
fromPath(Path, long, Configuration) - Static method in class com.netflix.iceberg.hadoop.HadoopInputFile
 
fromPath(Path, Configuration) - Static method in class com.netflix.iceberg.hadoop.HadoopOutputFile
 
fromPrimitiveString(String) - Static method in class com.netflix.iceberg.types.Types
 
fromStat(FileStatus, long) - Static method in class com.netflix.iceberg.DataFiles
 
fromStat(FileStatus, PartitionData, long) - Static method in class com.netflix.iceberg.DataFiles
 
fromStat(FileStatus, PartitionData, Metrics) - Static method in class com.netflix.iceberg.DataFiles
 
fromStatus(FileStatus, Configuration) - Static method in class com.netflix.iceberg.hadoop.HadoopInputFile
 
fromString(Type, String) - Static method in class com.netflix.iceberg.transforms.Transforms
 

G

genericFixed(int) - Static method in class com.netflix.iceberg.avro.ValueWriters
 
GenericParquetReaders - Class in com.netflix.iceberg.data.parquet
 
GenericParquetWriter - Class in com.netflix.iceberg.data.parquet
 
GenericRecord - Class in com.netflix.iceberg.data
 
get(S, int) - Method in class com.netflix.iceberg.avro.ValueReaders.StructReader
 
get(S, int) - Method in class com.netflix.iceberg.avro.ValueWriters.StructWriter
 
get() - Method in class com.netflix.iceberg.common.DynFields.BoundField
 
get() - Method in class com.netflix.iceberg.common.DynFields.StaticField
 
get(Object) - Method in class com.netflix.iceberg.common.DynFields.UnboundField
 
get(int) - Method in class com.netflix.iceberg.data.GenericRecord
 
get(int, Class<T>) - Method in class com.netflix.iceberg.data.GenericRecord
 
get(int) - Method in interface com.netflix.iceberg.data.Record
 
get(StructLike) - Method in class com.netflix.iceberg.expressions.BoundReference
 
get(Object) - Method in class com.netflix.iceberg.orc.ColumnIdMap
 
get(S, int) - Method in class com.netflix.iceberg.parquet.ParquetValueWriters.StructWriter
 
get(int, Class<T>) - Method in interface com.netflix.iceberg.StructLike
 
get() - Static method in class com.netflix.iceberg.types.Types.BinaryType
 
get() - Static method in class com.netflix.iceberg.types.Types.BooleanType
 
get() - Static method in class com.netflix.iceberg.types.Types.DateType
 
get() - Static method in class com.netflix.iceberg.types.Types.DoubleType
 
get() - Static method in class com.netflix.iceberg.types.Types.FloatType
 
get() - Static method in class com.netflix.iceberg.types.Types.IntegerType
 
get() - Static method in class com.netflix.iceberg.types.Types.LongType
 
get() - Static method in class com.netflix.iceberg.types.Types.StringType
 
get() - Static method in class com.netflix.iceberg.types.Types.TimeType
 
get() - Static method in class com.netflix.iceberg.types.Types.UUIDType
 
get() - Method in interface com.netflix.iceberg.types.TypeUtil.NextID
 
get(int) - Method in class com.netflix.iceberg.util.Pair
 
getAliases() - Method in class com.netflix.iceberg.Schema
Returns an alias map for this schema, if set.
getBool(String, JsonNode) - Static method in class com.netflix.iceberg.util.JsonUtil
 
getConf() - Method in class com.netflix.iceberg.hadoop.HadoopInputFile
 
getConf() - Method in class com.netflix.iceberg.hadoop.HadoopOutputFile
 
getConf() - Method in class com.netflix.iceberg.hadoop.HadoopTables
 
getConstructedClass() - Method in class com.netflix.iceberg.common.DynConstructors.Ctor
 
getConvertedType() - Method in class com.netflix.iceberg.avro.UUIDConversion
 
getCurrentKey() - Method in class com.netflix.iceberg.pig.IcebergPigInputFormat.IcebergRecordReader
 
getCurrentValue() - Method in class com.netflix.iceberg.pig.IcebergPigInputFormat.IcebergRecordReader
 
getDelegate() - Method in interface com.netflix.iceberg.io.DelegatingInputStream
 
getDelegate() - Method in interface com.netflix.iceberg.io.DelegatingOutputStream
 
getElement(List<E>) - Method in class com.netflix.iceberg.parquet.ParquetValueReaders.ListReader
 
getElement(I) - Method in class com.netflix.iceberg.parquet.ParquetValueReaders.RepeatedReader
 
getElementId(Schema) - Static method in class com.netflix.iceberg.avro.AvroSchemaUtil
 
getFeatures() - Method in class com.netflix.iceberg.pig.IcebergStorage
 
getField(String) - Method in class com.netflix.iceberg.data.GenericRecord
 
getField(String) - Method in interface com.netflix.iceberg.data.Record
 
getField(I, int) - Method in class com.netflix.iceberg.parquet.ParquetValueReaders.StructReader
 
getFieldBySourceId(int) - Method in class com.netflix.iceberg.PartitionSpec
 
getFieldId(Schema.Field) - Static method in class com.netflix.iceberg.avro.AvroSchemaUtil
 
getFromUDFContext(String, Class<T>) - Method in class com.netflix.iceberg.pig.IcebergStorage
 
getInputFormat() - Method in class com.netflix.iceberg.pig.IcebergStorage
 
getInt(String, JsonNode) - Static method in class com.netflix.iceberg.util.JsonUtil
 
getKey() - Method in class com.netflix.iceberg.parquet.ParquetValueReaders.ReusableEntry
 
getKeyId(Schema) - Static method in class com.netflix.iceberg.avro.AvroSchemaUtil
 
getLength() - Method in class com.netflix.iceberg.hadoop.HadoopInputFile
 
getLength() - Method in interface com.netflix.iceberg.io.InputFile
 
getLogicalTypeName() - Method in class com.netflix.iceberg.avro.UUIDConversion
 
getLong(String, JsonNode) - Static method in class com.netflix.iceberg.util.JsonUtil
 
getMetadata() - Method in class com.netflix.iceberg.avro.AvroIterable
 
getNext() - Method in class com.netflix.iceberg.pig.IcebergStorage
 
getPair(Map<K, V>) - Method in class com.netflix.iceberg.parquet.ParquetValueReaders.MapReader
 
getPair(I) - Method in class com.netflix.iceberg.parquet.ParquetValueReaders.RepeatedKeyValueReader
 
getPartitionKeys(String, Job) - Method in class com.netflix.iceberg.pig.IcebergStorage
 
getPath() - Method in class com.netflix.iceberg.hadoop.HadoopOutputFile
 
getPlannerPool() - Static method in class com.netflix.iceberg.util.ThreadPools
Return an ExecutorService that uses the "planner" thread-pool.
getPos() - Method in class com.netflix.iceberg.io.PositionOutputStream
Return the current position in the OutputStream.
getPos() - Method in class com.netflix.iceberg.io.SeekableInputStream
Return the current position in the InputStream.
getPredicateFields(String, Job) - Method in class com.netflix.iceberg.pig.IcebergStorage
 
getProgress() - Method in class com.netflix.iceberg.pig.IcebergPigInputFormat.IcebergRecordReader
 
getProjectedIds(Schema) - Static method in class com.netflix.iceberg.types.TypeUtil
 
getProjectedIds(Type) - Static method in class com.netflix.iceberg.types.TypeUtil
 
getResultType(Type) - Method in interface com.netflix.iceberg.transforms.Transform
Returns the Type produced by this transform given a source type.
getSchema() - Method in class com.netflix.iceberg.orc.OrcFileAppender
 
getSchema(String, Job) - Method in class com.netflix.iceberg.pig.IcebergStorage
 
getSchema() - Method in class com.netflix.iceberg.util.Pair
 
getSplits(JobContext) - Method in class com.netflix.iceberg.pig.IcebergPigInputFormat
 
getStat() - Method in class com.netflix.iceberg.hadoop.HadoopInputFile
 
getStatistics(String, Job) - Method in class com.netflix.iceberg.pig.IcebergStorage
 
getString(String, JsonNode) - Static method in class com.netflix.iceberg.util.JsonUtil
 
getStringList(String, JsonNode) - Static method in class com.netflix.iceberg.util.JsonUtil
 
getStringMap(String, JsonNode) - Static method in class com.netflix.iceberg.util.JsonUtil
 
getSupportedExpressionTypes() - Method in class com.netflix.iceberg.pig.IcebergStorage
 
getType(Types.StructType) - Static method in interface com.netflix.iceberg.DataFile
 
getValue() - Method in class com.netflix.iceberg.parquet.ParquetValueReaders.ReusableEntry
 
getValueId(Schema) - Static method in class com.netflix.iceberg.avro.AvroSchemaUtil
 
getWorkerPool() - Static method in class com.netflix.iceberg.util.ThreadPools
Return an ExecutorService that uses the "worker" thread-pool.
greaterThan(String, T) - Static method in class com.netflix.iceberg.expressions.Expressions
 
greaterThanOrEqual(String, T) - Static method in class com.netflix.iceberg.expressions.Expressions
 
gt(BoundReference<T>, Literal<T>) - Method in class com.netflix.iceberg.expressions.ExpressionVisitors.BoundExpressionVisitor
 
gtEq(BoundReference<T>, Literal<T>) - Method in class com.netflix.iceberg.expressions.ExpressionVisitors.BoundExpressionVisitor
 

H

HadoopInputFile - Class in com.netflix.iceberg.hadoop
InputFile implementation using the Hadoop FileSystem API.
HadoopOutputFile - Class in com.netflix.iceberg.hadoop
OutputFile implementation using the Hadoop FileSystem API.
HadoopTables - Class in com.netflix.iceberg.hadoop
Implementation of Iceberg tables that uses the Hadoop FileSystem to store metadata and manifests.
HadoopTables() - Constructor for class com.netflix.iceberg.hadoop.HadoopTables
 
HadoopTables(Configuration) - Constructor for class com.netflix.iceberg.hadoop.HadoopTables
 
hashCode() - Method in class com.netflix.iceberg.data.GenericRecord
 
hashCode() - Method in class com.netflix.iceberg.PartitionField
 
hashCode() - Method in class com.netflix.iceberg.PartitionSpec
 
hashCode() - Method in class com.netflix.iceberg.TableMetadata.SnapshotLogEntry
 
hashCode() - Method in class com.netflix.iceberg.types.Types.DecimalType
 
hashCode() - Method in class com.netflix.iceberg.types.Types.FixedType
 
hashCode() - Method in class com.netflix.iceberg.types.Types.ListType
 
hashCode() - Method in class com.netflix.iceberg.types.Types.MapType
 
hashCode() - Method in class com.netflix.iceberg.types.Types.NestedField
 
hashCode() - Method in class com.netflix.iceberg.types.Types.StructType
 
hashCode() - Method in class com.netflix.iceberg.types.Types.TimestampType
 
hashCode() - Method in class com.netflix.iceberg.util.CharSequenceWrapper
 
hashCode() - Method in class com.netflix.iceberg.util.Pair
 
hashCode() - Method in class com.netflix.iceberg.util.StructLikeWrapper
 
hasIds(MessageType) - Static method in class com.netflix.iceberg.parquet.ParquetSchemaUtil
 
hasNewFiles - Variable in class com.netflix.iceberg.BaseReplaceFiles
 
hasNext() - Method in class com.netflix.iceberg.orc.OrcIterator
 
hasNext() - Method in class com.netflix.iceberg.parquet.ColumnIterator
 
hasNext() - Method in class com.netflix.iceberg.spark.data.SparkOrcReader
 
HasTableOperations - Interface in com.netflix.iceberg
Used to expose a table's TableOperations.
hiddenImpl(Class<?>...) - Method in class com.netflix.iceberg.common.DynConstructors.Builder
 
hiddenImpl(String, Class<?>...) - Method in class com.netflix.iceberg.common.DynConstructors.Builder
 
hiddenImpl(Class<T>, Class<?>...) - Method in class com.netflix.iceberg.common.DynConstructors.Builder
 
hiddenImpl(String, String) - Method in class com.netflix.iceberg.common.DynFields.Builder
Checks for a hidden implementation, first finding the class by name.
hiddenImpl(Class<?>, String) - Method in class com.netflix.iceberg.common.DynFields.Builder
Checks for a hidden implementation.
hiddenImpl(String, String, Class<?>...) - Method in class com.netflix.iceberg.common.DynMethods.Builder
Checks for an implementation, first finding the given class by name.
hiddenImpl(String, Class<?>...) - Method in class com.netflix.iceberg.common.DynMethods.Builder
Checks for an implementation, first finding the given class by name.
hiddenImpl(Class<?>, String, Class<?>...) - Method in class com.netflix.iceberg.common.DynMethods.Builder
Checks for a method implementation.
hiddenImpl(Class<?>, Class<?>...) - Method in class com.netflix.iceberg.common.DynMethods.Builder
Checks for a method implementation.
Hive - Class in com.netflix.iceberg.spark.hacks
 
Hive() - Constructor for class com.netflix.iceberg.spark.hacks.Hive
 
hiveTableLocation() - Method in class com.netflix.iceberg.BaseMetastoreTableOperations
 
hour(String) - Method in class com.netflix.iceberg.PartitionSpec.Builder
 
hour(String, int) - Method in interface com.netflix.iceberg.transforms.PartitionSpecVisitor
 
hour(Type) - Static method in class com.netflix.iceberg.transforms.Transforms
Returns a hour Transform for timestamps.

I

ICEBERG_TABLE_TYPE_VALUE - Static variable in class com.netflix.iceberg.BaseMetastoreTableOperations
 
IcebergDecoder<D> - Class in com.netflix.iceberg.data.avro
 
IcebergDecoder(Schema) - Constructor for class com.netflix.iceberg.data.avro.IcebergDecoder
Creates a new decoder that constructs datum instances described by an Iceberg schema.
IcebergDecoder(Schema, SchemaStore) - Constructor for class com.netflix.iceberg.data.avro.IcebergDecoder
Creates a new decoder that constructs datum instances described by an Iceberg schema.
IcebergEncoder<D> - Class in com.netflix.iceberg.data.avro
 
IcebergEncoder(Schema) - Constructor for class com.netflix.iceberg.data.avro.IcebergEncoder
Creates a new MessageEncoder that will deconstruct datum instances described by the schema.
IcebergEncoder(Schema, boolean) - Constructor for class com.netflix.iceberg.data.avro.IcebergEncoder
Creates a new MessageEncoder that will deconstruct datum instances described by the schema.
IcebergGenerics - Class in com.netflix.iceberg.data
 
IcebergGenerics.ScanBuilder - Class in com.netflix.iceberg.data
 
IcebergPigInputFormat<T> - Class in com.netflix.iceberg.pig
 
IcebergPigInputFormat.IcebergRecordReader<T> - Class in com.netflix.iceberg.pig
 
IcebergRecordReader() - Constructor for class com.netflix.iceberg.pig.IcebergPigInputFormat.IcebergRecordReader
 
IcebergSource - Class in com.netflix.iceberg.spark.source
 
IcebergSource() - Constructor for class com.netflix.iceberg.spark.source.IcebergSource
 
IcebergStorage - Class in com.netflix.iceberg.pig
 
IcebergStorage() - Constructor for class com.netflix.iceberg.pig.IcebergStorage
 
identity(String) - Method in class com.netflix.iceberg.PartitionSpec.Builder
 
identity(String, int) - Method in interface com.netflix.iceberg.transforms.PartitionSpecVisitor
 
identity(Type) - Static method in class com.netflix.iceberg.transforms.Transforms
Returns an identity Transform that can be used for any type.
identitySourceIds() - Method in class com.netflix.iceberg.PartitionSpec
Returns the source field ids for identity partitions.
idToAlias(Integer) - Method in class com.netflix.iceberg.Schema
Returns the column id for the given column alias.
impl(String) - Method in class com.netflix.iceberg.common.DynClasses.Builder
Checks for an implementation of the class by name.
impl(String, Class<?>...) - Method in class com.netflix.iceberg.common.DynConstructors.Builder
 
impl(Class<T>, Class<?>...) - Method in class com.netflix.iceberg.common.DynConstructors.Builder
 
impl(String, String) - Method in class com.netflix.iceberg.common.DynFields.Builder
Checks for an implementation, first finding the class by name.
impl(Class<?>, String) - Method in class com.netflix.iceberg.common.DynFields.Builder
Checks for an implementation.
impl(String, String, Class<?>...) - Method in class com.netflix.iceberg.common.DynMethods.Builder
Checks for an implementation, first finding the given class by name.
impl(String, Class<?>...) - Method in class com.netflix.iceberg.common.DynMethods.Builder
Checks for an implementation, first finding the given class by name.
impl(Class<?>, String, Class<?>...) - Method in class com.netflix.iceberg.common.DynMethods.Builder
Checks for a method implementation.
impl(Class<?>, Class<?>...) - Method in class com.netflix.iceberg.common.DynMethods.Builder
Checks for a method implementation.
in(BoundReference<T>, Literal<T>) - Method in class com.netflix.iceberg.expressions.ExpressionVisitors.BoundExpressionVisitor
 
inclusive(PartitionSpec) - Static method in class com.netflix.iceberg.expressions.Projections
Creates an inclusive ProjectionEvaluator for the spec.
InclusiveMetricsEvaluator - Class in com.netflix.iceberg.expressions
Evaluates an Expression on a DataFile to test whether rows in the file may match.
InclusiveMetricsEvaluator(Schema, Expression) - Constructor for class com.netflix.iceberg.expressions.InclusiveMetricsEvaluator
 
indexById(Types.StructType) - Static method in class com.netflix.iceberg.types.TypeUtil
 
IndexByName - Class in com.netflix.iceberg.types
 
IndexByName() - Constructor for class com.netflix.iceberg.types.IndexByName
 
indexByName(Types.StructType) - Static method in class com.netflix.iceberg.types.TypeUtil
 
initialize(InputSplit, TaskAttemptContext) - Method in class com.netflix.iceberg.pig.IcebergPigInputFormat.IcebergRecordReader
 
inMemory(PartitionSpec, Iterable<ManifestEntry>) - Static method in class com.netflix.iceberg.ManifestReader
Returns a new ManifestReader for an in-memory list of ManifestEntry.
InputFile - Interface in com.netflix.iceberg.io
An interface used to read input files using SeekableInputStream instances.
IntAsLongReader(ColumnDescriptor) - Constructor for class com.netflix.iceberg.parquet.ParquetValueReaders.IntAsLongReader
 
IntegerAsDecimalReader(ColumnDescriptor, int) - Constructor for class com.netflix.iceberg.parquet.ParquetValueReaders.IntegerAsDecimalReader
 
IntegerType() - Constructor for class com.netflix.iceberg.types.Types.IntegerType
 
ints() - Static method in class com.netflix.iceberg.avro.ValueReaders
 
ints() - Static method in class com.netflix.iceberg.avro.ValueWriters
 
invoke(Object, Object...) - Method in class com.netflix.iceberg.common.DynConstructors.Ctor
 
invoke(Object...) - Method in class com.netflix.iceberg.common.DynMethods.BoundMethod
 
invoke(Object...) - Method in class com.netflix.iceberg.common.DynMethods.StaticMethod
 
invoke(Object, Object...) - Method in class com.netflix.iceberg.common.DynMethods.UnboundMethod
 
invokeChecked(Object, Object...) - Method in class com.netflix.iceberg.common.DynConstructors.Ctor
 
invokeChecked(Object...) - Method in class com.netflix.iceberg.common.DynMethods.BoundMethod
 
invokeChecked(Object...) - Method in class com.netflix.iceberg.common.DynMethods.StaticMethod
 
invokeChecked(Object, Object...) - Method in class com.netflix.iceberg.common.DynMethods.UnboundMethod
 
isAlwaysNull() - Method in class com.netflix.iceberg.common.DynFields.UnboundField
 
isElementOptional() - Method in class com.netflix.iceberg.types.Types.ListType
 
isElementRequired() - Method in class com.netflix.iceberg.types.Types.ListType
 
isEmpty() - Method in class com.netflix.iceberg.orc.ColumnIdMap
 
isFileScanTask() - Method in interface com.netflix.iceberg.FileScanTask
 
isFileScanTask() - Method in interface com.netflix.iceberg.ScanTask
 
isListType() - Method in interface com.netflix.iceberg.types.Type
 
isListType() - Method in class com.netflix.iceberg.types.Types.ListType
 
isMapType() - Method in interface com.netflix.iceberg.types.Type
 
isMapType() - Method in class com.netflix.iceberg.types.Types.MapType
 
isNestedType() - Method in interface com.netflix.iceberg.types.Type
 
isNestedType() - Method in class com.netflix.iceberg.types.Type.NestedType
 
isNoop() - Method in class com.netflix.iceberg.common.DynMethods.UnboundMethod
 
isNull(String) - Static method in class com.netflix.iceberg.expressions.Expressions
 
isNull(BoundReference<T>) - Method in class com.netflix.iceberg.expressions.ExpressionVisitors.BoundExpressionVisitor
 
isOptional() - Method in class com.netflix.iceberg.types.Types.NestedField
 
isPrimitiveType() - Method in interface com.netflix.iceberg.types.Type
 
isPrimitiveType() - Method in class com.netflix.iceberg.types.Type.PrimitiveType
 
isPromotionAllowed(Type, Type.PrimitiveType) - Static method in class com.netflix.iceberg.types.TypeUtil
 
isRequired() - Method in class com.netflix.iceberg.types.Types.NestedField
 
isStatic() - Method in class com.netflix.iceberg.common.DynConstructors.Ctor
 
isStatic() - Method in class com.netflix.iceberg.common.DynFields.UnboundField
 
isStatic() - Method in class com.netflix.iceberg.common.DynMethods.UnboundMethod
 
isStructType() - Method in interface com.netflix.iceberg.types.Type
 
isStructType() - Method in class com.netflix.iceberg.types.Types.StructType
 
isTimestamptz(Schema) - Static method in class com.netflix.iceberg.avro.AvroSchemaUtil
 
isValueOptional() - Method in class com.netflix.iceberg.types.Types.MapType
 
isValueRequired() - Method in class com.netflix.iceberg.types.Types.MapType
 
iterator() - Method in class com.netflix.iceberg.avro.AvroIterable
 
iterator() - Method in class com.netflix.iceberg.FilteredManifest
 
iterator() - Method in class com.netflix.iceberg.FilteredSnapshot
 
iterator() - Method in class com.netflix.iceberg.ManifestReader
 
iterator() - Method in class com.netflix.iceberg.parquet.ParquetIterable
 
iterator() - Method in class com.netflix.iceberg.parquet.ParquetReader
 
iterator() - Method in class com.netflix.iceberg.util.BinPacking.PackingIterable
 
iterator() - Method in class com.netflix.iceberg.util.ParallelIterable
 

J

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

K

KEY_ID_PROP - Static variable in class com.netflix.iceberg.avro.AvroSchemaUtil
 
keyId() - Method in class com.netflix.iceberg.types.Types.MapType
 
keySet() - Method in class com.netflix.iceberg.orc.ColumnIdMap
 
keyType() - Method in class com.netflix.iceberg.types.Types.MapType
 

L

lastColumnId() - Method in class com.netflix.iceberg.TableMetadata
 
lastUpdatedMillis() - Method in class com.netflix.iceberg.TableMetadata
 
lazyConf() - Method in class com.netflix.iceberg.spark.source.IcebergSource
 
left() - Method in class com.netflix.iceberg.expressions.And
 
left() - Method in class com.netflix.iceberg.expressions.Or
 
length() - Method in interface com.netflix.iceberg.FileScanTask
The number of bytes to scan from the FileScanTask.start() position in the file.
length() - Method in class com.netflix.iceberg.types.Types.FixedType
 
lessThan(String, T) - Static method in class com.netflix.iceberg.expressions.Expressions
 
lessThanOrEqual(String, T) - Static method in class com.netflix.iceberg.expressions.Expressions
 
limit(int) - Method in class com.netflix.iceberg.ScanSummary.Builder
 
list(GroupType, T) - Method in class com.netflix.iceberg.parquet.ParquetTypeVisitor
 
list(Types.ListType, Type.Repetition, int, String) - Method in class com.netflix.iceberg.parquet.TypeToMessageType
 
list(Types.ListType, GroupType, T) - Method in class com.netflix.iceberg.parquet.TypeWithSchemaVisitor
 
list(Types.ListType, Supplier<Type>) - Method in class com.netflix.iceberg.spark.PruneColumnsWithoutReordering
 
list(Types.ListType, Supplier<Type>) - Method in class com.netflix.iceberg.spark.PruneColumnsWithReordering
 
list(Types.ListType, Supplier<List<String>>) - Method in class com.netflix.iceberg.types.CheckCompatibility
 
list(Types.ListType, Map<String, Integer>) - Method in class com.netflix.iceberg.types.IndexByName
 
list(Types.ListType, Supplier<T>) - Method in class com.netflix.iceberg.types.TypeUtil.CustomOrderSchemaVisitor
 
list(Types.ListType, T) - Method in class com.netflix.iceberg.types.TypeUtil.SchemaVisitor
 
ListPacker(long, int) - Constructor for class com.netflix.iceberg.util.BinPacking.ListPacker
 
ListReader(int, int, ParquetValueReader<E>) - Constructor for class com.netflix.iceberg.parquet.ParquetValueReaders.ListReader
 
Literal<T> - Interface in com.netflix.iceberg.expressions
Represents a literal fixed value in an expression predicate
literal() - Method in class com.netflix.iceberg.expressions.Predicate
 
load(String, String) - Method in class com.netflix.iceberg.BaseMetastoreTables
 
load(String) - Method in class com.netflix.iceberg.hadoop.HadoopTables
Loads the table location from a FileSystem path location.
load(String) - Method in interface com.netflix.iceberg.Tables
 
loader(ClassLoader) - Method in class com.netflix.iceberg.common.DynClasses.Builder
Set the ClassLoader used to lookup classes by name.
loader(ClassLoader) - Method in class com.netflix.iceberg.common.DynConstructors.Builder
Set the ClassLoader used to lookup classes by name.
loader(ClassLoader) - Method in class com.netflix.iceberg.common.DynFields.Builder
Set the ClassLoader used to lookup classes by name.
loader(ClassLoader) - Method in class com.netflix.iceberg.common.DynMethods.Builder
Set the ClassLoader used to lookup classes by name.
localInput(File) - Static method in class com.netflix.iceberg.Files
 
localInput(String) - Static method in class com.netflix.iceberg.Files
 
localOutput(File) - Static method in class com.netflix.iceberg.Files
 
localOutput(String) - Static method in class com.netflix.iceberg.Files
 
location() - Method in class com.netflix.iceberg.BaseTable
 
location() - Method in class com.netflix.iceberg.hadoop.HadoopInputFile
 
location() - Method in class com.netflix.iceberg.hadoop.HadoopOutputFile
 
location() - Method in interface com.netflix.iceberg.io.InputFile
The fully-qualified location of the input file as a String.
location() - Method in interface com.netflix.iceberg.io.OutputFile
Return the location this output file will create.
location() - Method in interface com.netflix.iceberg.Table
Return the table's base location.
location() - Method in class com.netflix.iceberg.TableMetadata
 
LogicalMap - Class in com.netflix.iceberg.avro
 
LongAsDecimalReader(ColumnDescriptor, int) - Constructor for class com.netflix.iceberg.parquet.ParquetValueReaders.LongAsDecimalReader
 
longs() - Static method in class com.netflix.iceberg.avro.ValueReaders
 
longs() - Static method in class com.netflix.iceberg.avro.ValueWriters
 
LongType() - Constructor for class com.netflix.iceberg.types.Types.LongType
 
lowerBounds() - Method in interface com.netflix.iceberg.DataFile
 
lowerBounds() - Method in class com.netflix.iceberg.Metrics
 
lt(BoundReference<T>, Literal<T>) - Method in class com.netflix.iceberg.expressions.ExpressionVisitors.BoundExpressionVisitor
 
ltEq(BoundReference<T>, Literal<T>) - Method in class com.netflix.iceberg.expressions.ExpressionVisitors.BoundExpressionVisitor
 

M

MANIFEST_MIN_MERGE_COUNT - Static variable in class com.netflix.iceberg.TableProperties
 
MANIFEST_MIN_MERGE_COUNT_DEFAULT - Static variable in class com.netflix.iceberg.TableProperties
 
MANIFEST_TARGET_SIZE_BYTES - Static variable in class com.netflix.iceberg.TableProperties
 
MANIFEST_TARGET_SIZE_BYTES_DEFAULT - Static variable in class com.netflix.iceberg.TableProperties
 
ManifestReader - Class in com.netflix.iceberg
Reader for manifest files.
manifests() - Method in interface com.netflix.iceberg.Snapshot
Return the location of all manifests in this snapshot.
map(Schema, T) - Method in class com.netflix.iceberg.avro.AvroSchemaVisitor
 
map(ValueReader<K>, ValueReader<V>) - Static method in class com.netflix.iceberg.avro.ValueReaders
 
map(ValueWriter<K>, ValueWriter<V>) - Static method in class com.netflix.iceberg.avro.ValueWriters
 
map(GroupType, T, T) - Method in class com.netflix.iceberg.parquet.ParquetTypeVisitor
 
map(Types.MapType, Type.Repetition, int, String) - Method in class com.netflix.iceberg.parquet.TypeToMessageType
 
map(Types.MapType, GroupType, T, T) - Method in class com.netflix.iceberg.parquet.TypeWithSchemaVisitor
 
map(Types.MapType, Supplier<Type>, Supplier<Type>) - Method in class com.netflix.iceberg.spark.PruneColumnsWithoutReordering
 
map(Types.MapType, Supplier<Type>, Supplier<Type>) - Method in class com.netflix.iceberg.spark.PruneColumnsWithReordering
 
map(Types.MapType, Supplier<List<String>>, Supplier<List<String>>) - Method in class com.netflix.iceberg.types.CheckCompatibility
 
map(Types.MapType, Map<String, Integer>, Map<String, Integer>) - Method in class com.netflix.iceberg.types.IndexByName
 
map(Types.MapType, Supplier<T>, Supplier<T>) - Method in class com.netflix.iceberg.types.TypeUtil.CustomOrderSchemaVisitor
 
map(Types.MapType, T, T) - Method in class com.netflix.iceberg.types.TypeUtil.SchemaVisitor
 
mapper() - Static method in class com.netflix.iceberg.util.JsonUtil
 
MapReader(int, int, ParquetValueReader<K>, ParquetValueReader<V>) - Constructor for class com.netflix.iceberg.parquet.ParquetValueReaders.MapReader
 
maps(int, int, ParquetValueWriter<K>, ParquetValueWriter<V>) - Static method in class com.netflix.iceberg.parquet.ParquetValueWriters
 
message(MessageType, List<T>) - Method in class com.netflix.iceberg.parquet.ParquetTypeVisitor
 
message(Types.StructType, MessageType, List<T>) - Method in class com.netflix.iceberg.parquet.TypeWithSchemaVisitor
 
meta(String, String) - Method in class com.netflix.iceberg.avro.Avro.WriteBuilder
 
meta(String, String) - Method in class com.netflix.iceberg.parquet.Parquet.WriteBuilder
 
metadata(String, String) - Method in class com.netflix.iceberg.orc.ORC.WriteBuilder
 
METADATA_LOCATION_PROP - Static variable in class com.netflix.iceberg.BaseMetastoreTableOperations
 
metrics() - Method in interface com.netflix.iceberg.io.FileAppender
 
Metrics - Class in com.netflix.iceberg
 
Metrics() - Constructor for class com.netflix.iceberg.Metrics
 
Metrics(Long, Map<Integer, Long>, Map<Integer, Long>, Map<Integer, Long>) - Constructor for class com.netflix.iceberg.Metrics
 
Metrics(Long, Map<Integer, Long>, Map<Integer, Long>, Map<Integer, Long>, Map<Integer, ByteBuffer>, Map<Integer, ByteBuffer>) - Constructor for class com.netflix.iceberg.Metrics
 
metrics() - Method in class com.netflix.iceberg.orc.OrcFileAppender
 
metrics() - Method in class com.netflix.iceberg.parquet.ParquetWriteAdapter
 
metrics() - Method in class com.netflix.iceberg.spark.data.SparkOrcWriter
 
month(String) - Method in class com.netflix.iceberg.PartitionSpec.Builder
 
month(String, int) - Method in interface com.netflix.iceberg.transforms.PartitionSpecVisitor
 
month(Type) - Static method in class com.netflix.iceberg.transforms.Transforms
Returns a month Transform for date or timestamp types.

N

name - Variable in class com.netflix.iceberg.expressions.NamedReference
 
name() - Method in class com.netflix.iceberg.expressions.NamedReference
 
name() - Method in class com.netflix.iceberg.PartitionField
 
name() - Method in class com.netflix.iceberg.types.Types.NestedField
 
named(String) - Method in class com.netflix.iceberg.avro.Avro.WriteBuilder
 
named(String) - Method in class com.netflix.iceberg.parquet.Parquet.WriteBuilder
 
NamedReference - Class in com.netflix.iceberg.expressions
 
negate() - Method in class com.netflix.iceberg.expressions.And
 
negate() - Method in class com.netflix.iceberg.expressions.BoundPredicate
 
negate() - Method in interface com.netflix.iceberg.expressions.Expression
 
negate() - Method in enum com.netflix.iceberg.expressions.Expression.Operation
 
negate() - Method in class com.netflix.iceberg.expressions.False
 
negate() - Method in class com.netflix.iceberg.expressions.Not
 
negate() - Method in class com.netflix.iceberg.expressions.Or
 
negate() - Method in class com.netflix.iceberg.expressions.True
 
negate() - Method in class com.netflix.iceberg.expressions.UnboundPredicate
 
NestedType() - Constructor for class com.netflix.iceberg.types.Type.NestedType
 
newAppend() - Method in class com.netflix.iceberg.BaseTable
 
newAppend() - Method in interface com.netflix.iceberg.Table
Create a new append API to add files to this table and commit.
newAppend() - Method in interface com.netflix.iceberg.Transaction
Create a new append API to add files to this table.
newDelete() - Method in class com.netflix.iceberg.BaseTable
 
newDelete() - Method in interface com.netflix.iceberg.Table
Create a new delete API to replace files in this table and commit.
newDelete() - Method in interface com.netflix.iceberg.Transaction
Create a new delete API to replace files in this table.
newFastAppend() - Method in class com.netflix.iceberg.BaseTable
 
newFastAppend() - Method in interface com.netflix.iceberg.Table
Create a new append API to add files to this table and commit.
newFastAppend() - Method in interface com.netflix.iceberg.Transaction
Create a new append API to add files to this table.
newInputFile(String) - Method in class com.netflix.iceberg.BaseMetastoreTableOperations
 
newInputFile(String) - Method in interface com.netflix.iceberg.TableOperations
Create a new InputFile for a path.
newInstance(Object...) - Method in class com.netflix.iceberg.common.DynConstructors.Ctor
 
newInstanceChecked(Object...) - Method in class com.netflix.iceberg.common.DynConstructors.Ctor
 
newListData(List<E>) - Method in class com.netflix.iceberg.parquet.ParquetValueReaders.ListReader
 
newListData(T) - Method in class com.netflix.iceberg.parquet.ParquetValueReaders.RepeatedReader
 
newMapData(Map<K, V>) - Method in class com.netflix.iceberg.parquet.ParquetValueReaders.MapReader
 
newMapData(M) - Method in class com.netflix.iceberg.parquet.ParquetValueReaders.RepeatedKeyValueReader
 
newMetadataFile(String) - Method in class com.netflix.iceberg.BaseMetastoreTableOperations
 
newMetadataFile(String) - Method in interface com.netflix.iceberg.TableOperations
Create a new OutputFile in the table's metadata store.
newOverwrite() - Method in class com.netflix.iceberg.BaseTable
 
newOverwrite() - Method in interface com.netflix.iceberg.Table
Create a new overwrite API to overwrite files by a filter expression.
newOverwrite() - Method in interface com.netflix.iceberg.Transaction
Create a new overwrite API to overwrite files by a filter expression.
newReplacePartitions() - Method in class com.netflix.iceberg.BaseTable
 
newReplacePartitions() - Method in interface com.netflix.iceberg.Table
Not recommended: Create a new replace partitions API to dynamically overwrite partitions in the table with new data.
newReplacePartitions() - Method in interface com.netflix.iceberg.Transaction
Not recommended: Create a new replace partitions API to dynamically overwrite partitions in the table with new data.
newRewrite() - Method in class com.netflix.iceberg.BaseTable
 
newRewrite() - Method in interface com.netflix.iceberg.Table
Create a new rewrite API to replace files in this table and commit.
newRewrite() - Method in interface com.netflix.iceberg.Transaction
Create a new rewrite API to replace files in this table.
newScan() - Method in class com.netflix.iceberg.BaseTable
 
newScan() - Method in interface com.netflix.iceberg.Table
Create a new scan for this table.
newSnapshotId() - Method in class com.netflix.iceberg.BaseMetastoreTableOperations
 
newSnapshotId() - Method in interface com.netflix.iceberg.TableOperations
Create a new ID for a Snapshot
newStream() - Method in class com.netflix.iceberg.hadoop.HadoopInputFile
 
newStream() - Method in interface com.netflix.iceberg.io.InputFile
Opens a new SeekableInputStream for the underlying data file
newStructData(T) - Method in class com.netflix.iceberg.parquet.ParquetValueReaders.StructReader
 
newTableMetadata(TableOperations, Schema, PartitionSpec, String) - Static method in class com.netflix.iceberg.TableMetadata
 
newTableMetadata(TableOperations, Schema, PartitionSpec, String, Map<String, String>) - Static method in class com.netflix.iceberg.TableMetadata
 
newTableOps(Configuration, String, String) - Method in class com.netflix.iceberg.BaseMetastoreTables
 
newTransaction() - Method in class com.netflix.iceberg.BaseTable
 
newTransaction() - Method in interface com.netflix.iceberg.Table
Create a new transaction API to commit multiple table operations at once.
next() - Method in class com.netflix.iceberg.orc.OrcIterator
 
next() - Method in class com.netflix.iceberg.spark.data.SparkOrcReader
 
nextBinary() - Method in class com.netflix.iceberg.parquet.ColumnIterator
 
nextBoolean() - Method in class com.netflix.iceberg.parquet.ColumnIterator
 
nextDouble() - Method in class com.netflix.iceberg.parquet.ColumnIterator
 
nextFloat() - Method in class com.netflix.iceberg.parquet.ColumnIterator
 
nextInteger() - Method in class com.netflix.iceberg.parquet.ColumnIterator
 
nextKeyValue() - Method in class com.netflix.iceberg.pig.IcebergPigInputFormat.IcebergRecordReader
 
nextLong() - Method in class com.netflix.iceberg.parquet.ColumnIterator
 
nextNull() - Method in class com.netflix.iceberg.parquet.ColumnIterator
 
noRetry() - Method in class com.netflix.iceberg.util.Tasks.Builder
 
NoSuchTableException - Exception in com.netflix.iceberg.exceptions
Exception raised when attempting to load a table that does not exist.
NoSuchTableException(String, Object...) - Constructor for exception com.netflix.iceberg.exceptions.NoSuchTableException
 
NoSuchTableException(Throwable, String, Object...) - Constructor for exception com.netflix.iceberg.exceptions.NoSuchTableException
 
not(Expression) - Static method in class com.netflix.iceberg.expressions.Expressions
 
not(R) - Method in class com.netflix.iceberg.expressions.ExpressionVisitors.ExpressionVisitor
 
Not - Class in com.netflix.iceberg.expressions
 
notEq(BoundReference<T>, Literal<T>) - Method in class com.netflix.iceberg.expressions.ExpressionVisitors.BoundExpressionVisitor
 
notEqual(String, T) - Static method in class com.netflix.iceberg.expressions.Expressions
 
notIn(BoundReference<T>, Literal<T>) - Method in class com.netflix.iceberg.expressions.ExpressionVisitors.BoundExpressionVisitor
 
notNull(String) - Static method in class com.netflix.iceberg.expressions.Expressions
 
notNull(BoundReference<T>) - Method in class com.netflix.iceberg.expressions.ExpressionVisitors.BoundExpressionVisitor
 
nulls() - Static method in class com.netflix.iceberg.avro.ValueReaders
 
nulls() - Static method in class com.netflix.iceberg.avro.ValueWriters
 
nulls() - Static method in class com.netflix.iceberg.parquet.ParquetValueReaders
 
nullsFirst() - Static method in class com.netflix.iceberg.types.Comparators
 
nullsLast() - Static method in class com.netflix.iceberg.types.Comparators
 
nullValueCounts() - Method in interface com.netflix.iceberg.DataFile
 
nullValueCounts() - Method in class com.netflix.iceberg.Metrics
 

O

OBJECT_STORE_ENABLED - Static variable in class com.netflix.iceberg.TableProperties
 
OBJECT_STORE_ENABLED_DEFAULT - Static variable in class com.netflix.iceberg.TableProperties
 
OBJECT_STORE_PATH - Static variable in class com.netflix.iceberg.TableProperties
 
of(boolean) - Static method in interface com.netflix.iceberg.expressions.Literal
 
of(int) - Static method in interface com.netflix.iceberg.expressions.Literal
 
of(long) - Static method in interface com.netflix.iceberg.expressions.Literal
 
of(float) - Static method in interface com.netflix.iceberg.expressions.Literal
 
of(double) - Static method in interface com.netflix.iceberg.expressions.Literal
 
of(CharSequence) - Static method in interface com.netflix.iceberg.expressions.Literal
 
of(UUID) - Static method in interface com.netflix.iceberg.expressions.Literal
 
of(byte[]) - Static method in interface com.netflix.iceberg.expressions.Literal
 
of(ByteBuffer) - Static method in interface com.netflix.iceberg.expressions.Literal
 
of(BigDecimal) - Static method in interface com.netflix.iceberg.expressions.Literal
 
of(TableScan) - Static method in class com.netflix.iceberg.ScanSummary
Create a scan summary builder for a table scan.
of(int, int) - Static method in class com.netflix.iceberg.types.Types.DecimalType
 
of(Types.NestedField...) - Static method in class com.netflix.iceberg.types.Types.StructType
 
of(List<Types.NestedField>) - Static method in class com.netflix.iceberg.types.Types.StructType
 
of(X, Y) - Static method in class com.netflix.iceberg.util.Pair
 
ofLength(int) - Static method in class com.netflix.iceberg.types.Types.FixedType
 
ofOptional(int, Type) - Static method in class com.netflix.iceberg.types.Types.ListType
 
ofOptional(int, int, Type, Type) - Static method in class com.netflix.iceberg.types.Types.MapType
 
ofRequired(int, Type) - Static method in class com.netflix.iceberg.types.Types.ListType
 
ofRequired(int, int, Type, Type) - Static method in class com.netflix.iceberg.types.Types.MapType
 
onFailure(Tasks.FailureTask<I, ?>) - Method in class com.netflix.iceberg.util.Tasks.Builder
 
onlyRetryOn(Class<? extends Exception>) - Method in class com.netflix.iceberg.util.Tasks.Builder
 
onlyRetryOn(Class<? extends Exception>...) - Method in class com.netflix.iceberg.util.Tasks.Builder
 
op() - Method in class com.netflix.iceberg.expressions.And
 
op() - Method in interface com.netflix.iceberg.expressions.Expression
 
op() - Method in class com.netflix.iceberg.expressions.False
 
op() - Method in class com.netflix.iceberg.expressions.Not
 
op() - Method in class com.netflix.iceberg.expressions.Or
 
op() - Method in class com.netflix.iceberg.expressions.Predicate
 
op() - Method in class com.netflix.iceberg.expressions.True
 
operations() - Method in class com.netflix.iceberg.BaseTable
 
operations() - Method in interface com.netflix.iceberg.HasTableOperations
 
option(int, ValueWriter<T>) - Static method in class com.netflix.iceberg.avro.ValueWriters
 
option(Type, int, ParquetValueReader<T>) - Static method in class com.netflix.iceberg.parquet.ParquetValueReaders
 
option(Type, int, ParquetValueWriter<T>) - Static method in class com.netflix.iceberg.parquet.ParquetValueWriters
 
optional(int, String, Type) - Static method in class com.netflix.iceberg.types.Types.NestedField
 
or(Expression, Expression) - Static method in class com.netflix.iceberg.expressions.Expressions
 
or(R, R) - Method in class com.netflix.iceberg.expressions.ExpressionVisitors.ExpressionVisitor
 
Or - Class in com.netflix.iceberg.expressions
 
ORC - Class in com.netflix.iceberg.orc
 
ORC.ReadBuilder - Class in com.netflix.iceberg.orc
 
ORC.WriteBuilder - Class in com.netflix.iceberg.orc
 
OrcFileAppender - Class in com.netflix.iceberg.orc
Create a file appender for ORC.
OrcIterator - Class in com.netflix.iceberg.orc
An adaptor so that the ORC RecordReader can be used as an Iterator.
orNoop() - Method in class com.netflix.iceberg.common.DynMethods.Builder
If no implementation has been found, adds a NOOP method.
orNull() - Method in class com.netflix.iceberg.common.DynClasses.Builder
Instructs this builder to return null if no class is found, rather than throwing an Exception.
OutputFile - Interface in com.netflix.iceberg.io
An interface used to create output files using PositionOutputStream instances.
overwriteByRowFilter(Expression) - Method in class com.netflix.iceberg.OverwriteData
 
overwriteByRowFilter(Expression) - Method in interface com.netflix.iceberg.OverwriteFiles
Delete files that match an Expression on data rows from the table.
OverwriteData - Class in com.netflix.iceberg
 
OverwriteData(TableOperations) - Constructor for class com.netflix.iceberg.OverwriteData
 
OverwriteFiles - Interface in com.netflix.iceberg
API for overwriting files in a table by filter expression.

P

pack(Iterable<T>, Function<T, Long>) - Method in class com.netflix.iceberg.util.BinPacking.ListPacker
 
packEnd(List<T>, Function<T, Long>) - Method in class com.netflix.iceberg.util.BinPacking.ListPacker
 
PackingIterable(Iterable<T>, long, int, Function<T, Long>) - Constructor for class com.netflix.iceberg.util.BinPacking.PackingIterable
 
Pair<X,Y> - Class in com.netflix.iceberg.util
 
pairs(M) - Method in class com.netflix.iceberg.parquet.ParquetValueWriters.RepeatedKeyValueWriter
 
ParallelIterable<T> - Class in com.netflix.iceberg.util
 
ParallelIterable(Iterable<Iterable<T>>, ExecutorService, ExecutorService) - Constructor for class com.netflix.iceberg.util.ParallelIterable
 
Parquet - Class in com.netflix.iceberg.parquet
 
Parquet.ReadBuilder - Class in com.netflix.iceberg.parquet
 
Parquet.WriteBuilder - Class in com.netflix.iceberg.parquet
 
PARQUET_COMPRESSION - Static variable in class com.netflix.iceberg.TableProperties
 
PARQUET_COMPRESSION_DEFAULT - Static variable in class com.netflix.iceberg.TableProperties
 
PARQUET_DICT_SIZE_BYTES - Static variable in class com.netflix.iceberg.TableProperties
 
PARQUET_DICT_SIZE_BYTES_DEFAULT - Static variable in class com.netflix.iceberg.TableProperties
 
PARQUET_PAGE_SIZE_BYTES - Static variable in class com.netflix.iceberg.TableProperties
 
PARQUET_PAGE_SIZE_BYTES_DEFAULT - Static variable in class com.netflix.iceberg.TableProperties
 
PARQUET_ROW_GROUP_SIZE_BYTES - Static variable in class com.netflix.iceberg.TableProperties
 
PARQUET_ROW_GROUP_SIZE_BYTES_DEFAULT - Static variable in class com.netflix.iceberg.TableProperties
 
ParquetAvroReader - Class in com.netflix.iceberg.parquet
 
ParquetAvroReader() - Constructor for class com.netflix.iceberg.parquet.ParquetAvroReader
 
ParquetAvroValueReaders - Class in com.netflix.iceberg.parquet
 
ParquetAvroValueReaders.TimeMillisReader - Class in com.netflix.iceberg.parquet
 
ParquetAvroValueReaders.TimestampMillisReader - Class in com.netflix.iceberg.parquet
 
ParquetAvroWriter - Class in com.netflix.iceberg.parquet
 
ParquetDictionaryRowGroupFilter - Class in com.netflix.iceberg.parquet
 
ParquetDictionaryRowGroupFilter(Schema, Expression) - Constructor for class com.netflix.iceberg.parquet.ParquetDictionaryRowGroupFilter
 
ParquetIterable<T> - Class in com.netflix.iceberg.parquet
 
ParquetMetrics - Class in com.netflix.iceberg.parquet
 
ParquetMetricsRowGroupFilter - Class in com.netflix.iceberg.parquet
 
ParquetMetricsRowGroupFilter(Schema, Expression) - Constructor for class com.netflix.iceberg.parquet.ParquetMetricsRowGroupFilter
 
ParquetReader<T> - Class in com.netflix.iceberg.parquet
 
ParquetReader(InputFile, Schema, ParquetReadOptions, Function<MessageType, ParquetValueReader<?>>, Expression, boolean) - Constructor for class com.netflix.iceberg.parquet.ParquetReader
 
ParquetSchemaUtil - Class in com.netflix.iceberg.parquet
 
ParquetSchemaUtil() - Constructor for class com.netflix.iceberg.parquet.ParquetSchemaUtil
 
ParquetTypeVisitor<T> - Class in com.netflix.iceberg.parquet
 
ParquetTypeVisitor() - Constructor for class com.netflix.iceberg.parquet.ParquetTypeVisitor
 
ParquetValueReader<T> - Interface in com.netflix.iceberg.parquet
 
ParquetValueReaders - Class in com.netflix.iceberg.parquet
 
ParquetValueReaders.BinaryAsDecimalReader - Class in com.netflix.iceberg.parquet
 
ParquetValueReaders.BytesReader - Class in com.netflix.iceberg.parquet
 
ParquetValueReaders.FloatAsDoubleReader - Class in com.netflix.iceberg.parquet
 
ParquetValueReaders.IntAsLongReader - Class in com.netflix.iceberg.parquet
 
ParquetValueReaders.IntegerAsDecimalReader - Class in com.netflix.iceberg.parquet
 
ParquetValueReaders.ListReader<E> - Class in com.netflix.iceberg.parquet
 
ParquetValueReaders.LongAsDecimalReader - Class in com.netflix.iceberg.parquet
 
ParquetValueReaders.MapReader<K,V> - Class in com.netflix.iceberg.parquet
 
ParquetValueReaders.PrimitiveReader<T> - Class in com.netflix.iceberg.parquet
 
ParquetValueReaders.RepeatedKeyValueReader<M,I,K,V> - Class in com.netflix.iceberg.parquet
 
ParquetValueReaders.RepeatedReader<T,I,E> - Class in com.netflix.iceberg.parquet
 
ParquetValueReaders.ReusableEntry<K,V> - Class in com.netflix.iceberg.parquet
 
ParquetValueReaders.StringReader - Class in com.netflix.iceberg.parquet
 
ParquetValueReaders.StructReader<T,I> - Class in com.netflix.iceberg.parquet
 
ParquetValueReaders.UnboxedReader<T> - Class in com.netflix.iceberg.parquet
 
ParquetValueWriter<T> - Interface in com.netflix.iceberg.parquet
 
ParquetValueWriters - Class in com.netflix.iceberg.parquet
 
ParquetValueWriters.PrimitiveWriter<T> - Class in com.netflix.iceberg.parquet
 
ParquetValueWriters.RepeatedKeyValueWriter<M,K,V> - Class in com.netflix.iceberg.parquet
 
ParquetValueWriters.RepeatedWriter<L,E> - Class in com.netflix.iceberg.parquet
 
ParquetValueWriters.StructWriter<S> - Class in com.netflix.iceberg.parquet
 
ParquetWriteAdapter<D> - Class in com.netflix.iceberg.parquet
 
ParquetWriteAdapter(ParquetWriter<D>) - Constructor for class com.netflix.iceberg.parquet.ParquetWriteAdapter
 
partition() - Method in interface com.netflix.iceberg.DataFile
 
PartitionField - Class in com.netflix.iceberg
Represents a single field in a PartitionSpec.
PartitionMetrics() - Constructor for class com.netflix.iceberg.ScanSummary.PartitionMetrics
 
partitions(SparkSession, String) - Static method in class com.netflix.iceberg.spark.hacks.Hive
 
PartitionSpec - Class in com.netflix.iceberg
Represents how to produce partition data for a table.
PartitionSpec.Builder - Class in com.netflix.iceberg
Used to create valid partition specs.
PartitionSpecParser - Class in com.netflix.iceberg
 
PartitionSpecVisitor<T> - Interface in com.netflix.iceberg.transforms
 
partitionToPath(StructLike) - Method in class com.netflix.iceberg.PartitionSpec
 
partitionType() - Method in class com.netflix.iceberg.PartitionSpec
 
path() - Method in interface com.netflix.iceberg.DataFile
 
PendingUpdate<T> - Interface in com.netflix.iceberg
API for table metadata changes.
PIG_ICEBERG_TABLES_IMPL - Static variable in class com.netflix.iceberg.pig.IcebergStorage
 
PigParquetReader - Class in com.netflix.iceberg.pig
 
PigParquetReader(Schema, MessageType, Map<Integer, Object>) - Constructor for class com.netflix.iceberg.pig.PigParquetReader
 
planFiles() - Method in interface com.netflix.iceberg.TableScan
Plan the files that will be read by this scan.
PLANNER_THREAD_POOL_SIZE_PROP - Static variable in class com.netflix.iceberg.util.ThreadPools
 
planTasks() - Method in interface com.netflix.iceberg.TableScan
Plan the tasks for this scan.
PositionOutputStream - Class in com.netflix.iceberg.io
 
PositionOutputStream() - Constructor for class com.netflix.iceberg.io.PositionOutputStream
 
precision() - Method in class com.netflix.iceberg.types.Types.DecimalType
 
predicate(Expression.Operation, String, T) - Static method in class com.netflix.iceberg.expressions.Expressions
 
predicate(Expression.Operation, String, Literal<T>) - Static method in class com.netflix.iceberg.expressions.Expressions
 
predicate(Expression.Operation, String) - Static method in class com.netflix.iceberg.expressions.Expressions
 
predicate(BoundPredicate<T>) - Method in class com.netflix.iceberg.expressions.ExpressionVisitors.BoundExpressionVisitor
 
predicate(UnboundPredicate<T>) - Method in class com.netflix.iceberg.expressions.ExpressionVisitors.BoundExpressionVisitor
 
predicate(BoundPredicate<T>) - Method in class com.netflix.iceberg.expressions.ExpressionVisitors.ExpressionVisitor
 
predicate(UnboundPredicate<T>) - Method in class com.netflix.iceberg.expressions.ExpressionVisitors.ExpressionVisitor
 
Predicate<T,R extends Reference> - Class in com.netflix.iceberg.expressions
 
prepareToRead(RecordReader, PigSplit) - Method in class com.netflix.iceberg.pig.IcebergStorage
 
PREVIOUS_METADATA_LOCATION_PROP - Static variable in class com.netflix.iceberg.BaseMetastoreTableOperations
 
primitive(Schema) - Method in class com.netflix.iceberg.avro.AvroSchemaVisitor
 
primitive(PrimitiveType) - Method in class com.netflix.iceberg.parquet.ParquetTypeVisitor
 
primitive(Type.PrimitiveType, Type.Repetition, int, String) - Method in class com.netflix.iceberg.parquet.TypeToMessageType
 
primitive(Type.PrimitiveType, PrimitiveType) - Method in class com.netflix.iceberg.parquet.TypeWithSchemaVisitor
 
primitive(Type.PrimitiveType) - Method in class com.netflix.iceberg.spark.PruneColumnsWithoutReordering
 
primitive(Type.PrimitiveType) - Method in class com.netflix.iceberg.spark.PruneColumnsWithReordering
 
primitive(Type.PrimitiveType) - Method in class com.netflix.iceberg.types.CheckCompatibility
 
primitive(Type.PrimitiveType) - Method in class com.netflix.iceberg.types.TypeUtil.CustomOrderSchemaVisitor
 
primitive(Type.PrimitiveType) - Method in class com.netflix.iceberg.types.TypeUtil.SchemaVisitor
 
PrimitiveReader(ColumnDescriptor) - Constructor for class com.netflix.iceberg.parquet.ParquetValueReaders.PrimitiveReader
 
PrimitiveType() - Constructor for class com.netflix.iceberg.types.Type.PrimitiveType
 
PrimitiveWriter(ColumnDescriptor) - Constructor for class com.netflix.iceberg.parquet.ParquetValueWriters.PrimitiveWriter
 
project(Schema) - Method in class com.netflix.iceberg.avro.Avro.ReadBuilder
 
project(Expression) - Method in class com.netflix.iceberg.expressions.Projections.ProjectionEvaluator
Project the given row expression to a partition expression.
project(Schema) - Method in class com.netflix.iceberg.parquet.Parquet.ReadBuilder
 
project(Schema, List<String>) - Static method in class com.netflix.iceberg.pig.SchemaUtil
 
project(String, BoundPredicate<S>) - Method in interface com.netflix.iceberg.transforms.Transform
Transforms a predicate to an inclusive predicate on the partition values produced by Transform.apply(Object).
ProjectionDatumReader<D> - Class in com.netflix.iceberg.avro
 
ProjectionDatumReader(Function<Schema, DatumReader<?>>, Schema, Map<String, String>) - Constructor for class com.netflix.iceberg.avro.ProjectionDatumReader
 
ProjectionEvaluator() - Constructor for class com.netflix.iceberg.expressions.Projections.ProjectionEvaluator
 
Projections - Class in com.netflix.iceberg.expressions
Utils to project expressions on rows to expressions on partitions.
Projections.ProjectionEvaluator - Class in com.netflix.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 com.netflix.iceberg.transforms.Transform
Transforms a predicate to a strict predicate on the partition values produced by Transform.apply(Object).
properties() - Method in class com.netflix.iceberg.BaseTable
 
properties() - Method in interface com.netflix.iceberg.Table
Return a map of string properties for this table.
properties() - Method in class com.netflix.iceberg.TableMetadata
 
propertyAsInt(String, int) - Method in class com.netflix.iceberg.TableMetadata
 
propertyAsLong(String, long) - Method in class com.netflix.iceberg.TableMetadata
 
prune(Schema, StructType) - Static method in class com.netflix.iceberg.spark.SparkSchemaUtil
Prune columns from a Schema using a Spark type projection.
prune(Schema, StructType, List<Expression>) - Static method in class com.netflix.iceberg.spark.SparkSchemaUtil
Prune columns from a Schema using a Spark type projection.
prune(Schema, StructType, Expression) - Static method in class com.netflix.iceberg.spark.SparkSchemaUtil
Prune columns from a Schema using a Spark type projection.
pruneColumns(Schema, Set<Integer>) - Static method in class com.netflix.iceberg.avro.AvroSchemaUtil
 
pruneColumns(MessageType, Schema) - Static method in class com.netflix.iceberg.parquet.ParquetSchemaUtil
 
pruneColumnsFallback(MessageType, Schema) - Static method in class com.netflix.iceberg.parquet.ParquetSchemaUtil
Prunes columns from a Parquet file schema that was written without field ids.
PruneColumnsWithoutReordering - Class in com.netflix.iceberg.spark
 
PruneColumnsWithReordering - Class in com.netflix.iceberg.spark
 
pushProjection(LoadPushDown.RequiredFieldList) - Method in class com.netflix.iceberg.pig.IcebergStorage
 
put(TypeDescription, Integer) - Method in class com.netflix.iceberg.orc.ColumnIdMap
 
put(int, Object) - Method in class com.netflix.iceberg.util.Pair
 
putAll(Map<? extends TypeDescription, ? extends Integer>) - Method in class com.netflix.iceberg.orc.ColumnIdMap
 

R

range(int) - Static method in class com.netflix.iceberg.util.Tasks
 
read(InputFile) - Static method in class com.netflix.iceberg.avro.Avro
 
read(D, Decoder) - Method in class com.netflix.iceberg.avro.ProjectionDatumReader
 
read(Decoder, Object) - Method in interface com.netflix.iceberg.avro.ValueReader
 
read(Decoder, Object) - Method in class com.netflix.iceberg.avro.ValueReaders.StructReader
 
read(T, Decoder) - Method in class com.netflix.iceberg.data.avro.DataReader
 
read(Table) - Static method in class com.netflix.iceberg.data.IcebergGenerics
Returns a builder to configure a read of the given table that produces generic records.
read(InputFile) - Static method in class com.netflix.iceberg.ManifestReader
Returns a new ManifestReader for an InputFile.
read(InputFile) - Static method in class com.netflix.iceberg.orc.ORC
 
read(InputFile) - Static method in class com.netflix.iceberg.parquet.Parquet
 
read(T) - Method in interface com.netflix.iceberg.parquet.ParquetValueReader
 
read(BigDecimal) - Method in class com.netflix.iceberg.parquet.ParquetValueReaders.BinaryAsDecimalReader
 
read(ByteBuffer) - Method in class com.netflix.iceberg.parquet.ParquetValueReaders.BytesReader
 
read(Double) - Method in class com.netflix.iceberg.parquet.ParquetValueReaders.FloatAsDoubleReader
 
read(Long) - Method in class com.netflix.iceberg.parquet.ParquetValueReaders.IntAsLongReader
 
read(BigDecimal) - Method in class com.netflix.iceberg.parquet.ParquetValueReaders.IntegerAsDecimalReader
 
read(BigDecimal) - Method in class com.netflix.iceberg.parquet.ParquetValueReaders.LongAsDecimalReader
 
read(M) - Method in class com.netflix.iceberg.parquet.ParquetValueReaders.RepeatedKeyValueReader
 
read(T) - Method in class com.netflix.iceberg.parquet.ParquetValueReaders.RepeatedReader
 
read(String) - Method in class com.netflix.iceberg.parquet.ParquetValueReaders.StringReader
 
read(T) - Method in class com.netflix.iceberg.parquet.ParquetValueReaders.StructReader
 
read(T) - Method in class com.netflix.iceberg.parquet.ParquetValueReaders.UnboxedReader
 
read(InternalRow, Decoder) - Method in class com.netflix.iceberg.spark.data.SparkAvroReader
 
read(TableOperations, InputFile) - Static method in class com.netflix.iceberg.TableMetadataParser
 
readBinary() - Method in class com.netflix.iceberg.parquet.ParquetValueReaders.UnboxedReader
 
readBoolean() - Method in class com.netflix.iceberg.parquet.ParquetValueReaders.UnboxedReader
 
readCompatibilityErrors(Schema, Schema) - Static method in class com.netflix.iceberg.types.CheckCompatibility
Returns a list of compatibility errors for reading with the given read schema.
readDouble() - Method in class com.netflix.iceberg.parquet.ParquetValueReaders.UnboxedReader
 
reader(int) - Method in class com.netflix.iceberg.avro.ValueReaders.StructReader
 
readFloat() - Method in class com.netflix.iceberg.parquet.ParquetValueReaders.UnboxedReader
 
readInteger() - Method in class com.netflix.iceberg.parquet.ParquetValueReaders.UnboxedReader
 
readLong() - Method in class com.netflix.iceberg.parquet.ParquetAvroValueReaders.TimeMillisReader
 
readLong() - Method in class com.netflix.iceberg.parquet.ParquetAvroValueReaders.TimestampMillisReader
 
readLong() - Method in class com.netflix.iceberg.parquet.ParquetValueReaders.FloatAsDoubleReader
 
readLong() - Method in class com.netflix.iceberg.parquet.ParquetValueReaders.IntAsLongReader
 
readLong() - Method in class com.netflix.iceberg.parquet.ParquetValueReaders.UnboxedReader
 
readSupport(ReadSupport<?>) - Method in class com.netflix.iceberg.parquet.Parquet.ReadBuilder
 
reassignIds(Schema, Schema) - Static method in class com.netflix.iceberg.types.TypeUtil
Reassigns ids in a schema from another schema.
record(Schema, List<String>, List<T>) - Method in class com.netflix.iceberg.avro.AvroSchemaVisitor
 
record(List<ValueReader<?>>, Schema) - Static method in class com.netflix.iceberg.avro.ValueReaders
 
record(List<ValueReader<?>>, Class<R>, Schema) - Static method in class com.netflix.iceberg.avro.ValueReaders
 
record(List<ValueWriter<?>>) - Static method in class com.netflix.iceberg.avro.ValueWriters
 
Record - Interface in com.netflix.iceberg.data
 
recordCount() - Method in interface com.netflix.iceberg.DataFile
 
recordCount() - Method in class com.netflix.iceberg.Metrics
 
recordCount() - Method in class com.netflix.iceberg.ScanSummary.PartitionMetrics
 
recordLevels - Variable in class com.netflix.iceberg.avro.AvroSchemaVisitor
 
ref() - Method in class com.netflix.iceberg.expressions.Predicate
 
Reference - Interface in com.netflix.iceberg.expressions
Represents a variable reference in an expression.
refresh() - Method in class com.netflix.iceberg.BaseTable
 
refresh() - Method in interface com.netflix.iceberg.Table
Refresh the current table metadata.
refresh() - Method in interface com.netflix.iceberg.TableOperations
Return the current table metadata after checking for updates.
refreshFromMetadataLocation(String) - Method in class com.netflix.iceberg.BaseMetastoreTableOperations
 
relativeToAbsolutePath(String, Path) - Method in class com.netflix.iceberg.pig.IcebergStorage
 
remove(Object) - Method in class com.netflix.iceberg.orc.ColumnIdMap
 
remove(String) - Method in interface com.netflix.iceberg.UpdateProperties
Remove the given property key from the table.
removeSnapshotLogEntries(Set<Long>) - Method in class com.netflix.iceberg.TableMetadata
 
removeSnapshotsIf(Predicate<Snapshot>) - Method in class com.netflix.iceberg.TableMetadata
 
rename(String, String) - Method in class com.netflix.iceberg.avro.Avro.ReadBuilder
 
renameColumn(String, String) - Method in interface com.netflix.iceberg.UpdateSchema
Rename a column in the schema.
RepeatedKeyValueReader(int, int, ParquetValueReader<K>, ParquetValueReader<V>) - Constructor for class com.netflix.iceberg.parquet.ParquetValueReaders.RepeatedKeyValueReader
 
RepeatedKeyValueWriter(int, int, ParquetValueWriter<K>, ParquetValueWriter<V>) - Constructor for class com.netflix.iceberg.parquet.ParquetValueWriters.RepeatedKeyValueWriter
 
RepeatedReader(int, int, ParquetValueReader<E>) - Constructor for class com.netflix.iceberg.parquet.ParquetValueReaders.RepeatedReader
 
RepeatedWriter(int, int, ParquetValueWriter<E>) - Constructor for class com.netflix.iceberg.parquet.ParquetValueWriters.RepeatedWriter
 
ReplacePartitions - Interface in com.netflix.iceberg
Not recommended: API for overwriting files in a table by partition.
ReplacePartitionsOperation - Class in com.netflix.iceberg
 
replaceProperties(Map<String, String>) - Method in class com.netflix.iceberg.TableMetadata
 
required(int, String, Type) - Static method in class com.netflix.iceberg.types.Types.NestedField
 
residual() - Method in interface com.netflix.iceberg.FileScanTask
Returns the residual expression that should be applied to rows in this file scan.
ResidualEvaluator - Class in com.netflix.iceberg.expressions
Finds the residuals for an Expression the partitions in the given PartitionSpec.
ResidualEvaluator(PartitionSpec, Expression) - Constructor for class com.netflix.iceberg.expressions.ResidualEvaluator
 
residualFor(StructLike) - Method in class com.netflix.iceberg.expressions.ResidualEvaluator
Returns a residual expression for the given partition values.
retry(int) - Method in class com.netflix.iceberg.util.Tasks.Builder
 
ReusableEntry() - Constructor for class com.netflix.iceberg.parquet.ParquetValueReaders.ReusableEntry
 
reuseContainers() - Method in class com.netflix.iceberg.avro.Avro.ReadBuilder
 
reuseContainers(boolean) - Method in class com.netflix.iceberg.avro.Avro.ReadBuilder
 
reuseContainers() - Method in class com.netflix.iceberg.data.IcebergGenerics.ScanBuilder
 
reuseContainers() - Method in class com.netflix.iceberg.parquet.Parquet.ReadBuilder
 
reuseOrCreate(Object) - Method in class com.netflix.iceberg.avro.ValueReaders.StructReader
 
revertWith(Tasks.Task<I, ?>) - Method in class com.netflix.iceberg.util.Tasks.Builder
 
RewriteFiles - Interface in com.netflix.iceberg
API for replacing files in a table.
rewriteFiles(Set<DataFile>, Set<DataFile>) - Method in interface com.netflix.iceberg.RewriteFiles
 
rewriteNot(Expression) - Static method in class com.netflix.iceberg.expressions.Expressions
 
right() - Method in class com.netflix.iceberg.expressions.And
 
right() - Method in class com.netflix.iceberg.expressions.Or
 
rollback() - Method in class com.netflix.iceberg.BaseTable
 
Rollback - Interface in com.netflix.iceberg
API for rolling table data back to the state at an older table snapshot.
rollback() - Method in interface com.netflix.iceberg.Table
Create a new rollback API to roll back to a previous snapshot and commit.
rollbackTo(Snapshot) - Method in class com.netflix.iceberg.TableMetadata
 
run(Tasks.Task<I, RuntimeException>) - Method in class com.netflix.iceberg.util.Tasks.Builder
 
run(Tasks.Task<I, E>, Class<E>) - Method in class com.netflix.iceberg.util.Tasks.Builder
 
run(I, Exception) - Method in interface com.netflix.iceberg.util.Tasks.FailureTask
 
run(I) - Method in interface com.netflix.iceberg.util.Tasks.Task
 
RuntimeIOException - Exception in com.netflix.iceberg.exceptions
Exception used to wrap IOException as a RuntimeException and add context.
RuntimeIOException(IOException) - Constructor for exception com.netflix.iceberg.exceptions.RuntimeIOException
 
RuntimeIOException(IOException, String, Object...) - Constructor for exception com.netflix.iceberg.exceptions.RuntimeIOException
 
RuntimeIOException(String, Object...) - Constructor for exception com.netflix.iceberg.exceptions.RuntimeIOException
 

S

scale() - Method in class com.netflix.iceberg.types.Types.DecimalType
 
ScanBuilder(Table) - Constructor for class com.netflix.iceberg.data.IcebergGenerics.ScanBuilder
 
ScanSummary - Class in com.netflix.iceberg
 
ScanSummary.Builder - Class in com.netflix.iceberg
 
ScanSummary.PartitionMetrics - Class in com.netflix.iceberg
 
ScanTask - Interface in com.netflix.iceberg
A scan task.
schema(Schema) - Method in class com.netflix.iceberg.avro.Avro.WriteBuilder
 
schema() - Method in class com.netflix.iceberg.BaseTable
 
schema() - Method in class com.netflix.iceberg.ManifestReader
 
schema(Schema) - Method in class com.netflix.iceberg.orc.ORC.ReadBuilder
 
schema(Schema) - Method in class com.netflix.iceberg.orc.ORC.WriteBuilder
 
schema(Schema) - Method in class com.netflix.iceberg.parquet.Parquet.WriteBuilder
 
schema() - Method in class com.netflix.iceberg.PartitionSpec
 
Schema - Class in com.netflix.iceberg
The schema of a data table.
Schema(List<Types.NestedField>, Map<String, Integer>) - Constructor for class com.netflix.iceberg.Schema
 
Schema(List<Types.NestedField>) - Constructor for class com.netflix.iceberg.Schema
 
Schema(Types.NestedField...) - Constructor for class com.netflix.iceberg.Schema
 
schema(Schema, Supplier<Type>) - Method in class com.netflix.iceberg.spark.PruneColumnsWithoutReordering
 
schema(Schema, Supplier<Type>) - Method in class com.netflix.iceberg.spark.PruneColumnsWithReordering
 
schema() - Method in interface com.netflix.iceberg.Table
Return the schema for this table.
schema() - Method in class com.netflix.iceberg.TableMetadata
 
schema(Schema, Supplier<List<String>>) - Method in class com.netflix.iceberg.types.CheckCompatibility
 
schema(Schema, Map<String, Integer>) - Method in class com.netflix.iceberg.types.IndexByName
 
schema(Schema, Supplier<T>) - Method in class com.netflix.iceberg.types.TypeUtil.CustomOrderSchemaVisitor
 
schema(Schema, T) - Method in class com.netflix.iceberg.types.TypeUtil.SchemaVisitor
 
schemaForTable(SparkSession, String) - Static method in class com.netflix.iceberg.spark.SparkSchemaUtil
Returns a Schema for the given table with fresh field ids.
SchemaParser - Class in com.netflix.iceberg
 
SchemaParser() - Constructor for class com.netflix.iceberg.SchemaParser
 
SchemaUtil - Class in com.netflix.iceberg.pig
 
SchemaUtil() - Constructor for class com.netflix.iceberg.pig.SchemaUtil
 
SchemaVisitor() - Constructor for class com.netflix.iceberg.types.TypeUtil.SchemaVisitor
 
second() - Method in class com.netflix.iceberg.util.Pair
 
seek(long) - Method in class com.netflix.iceberg.io.SeekableInputStream
Seek to a new position in the InputStream.
SeekableInputStream - Class in com.netflix.iceberg.io
SeekableInputStream is an interface with the methods needed to read data from a file or Hadoop data stream.
SeekableInputStream() - Constructor for class com.netflix.iceberg.io.SeekableInputStream
 
select(String...) - Method in class com.netflix.iceberg.data.IcebergGenerics.ScanBuilder
 
select(String...) - Method in interface com.netflix.iceberg.Filterable
Selects the columns of a file manifest to read.
select(Collection<String>) - Method in interface com.netflix.iceberg.Filterable
Selects the columns of a file manifest to read.
select(Collection<String>) - Method in class com.netflix.iceberg.FilteredManifest
 
select(Collection<String>) - Method in class com.netflix.iceberg.FilteredSnapshot
 
select(Collection<String>) - Method in class com.netflix.iceberg.ManifestReader
 
select(String...) - Method in class com.netflix.iceberg.Schema
Creates a projection schema for a subset of columns, selected by name.
select(Collection<String>) - Method in class com.netflix.iceberg.Schema
Creates a projection schema for a subset of columns, selected by name.
select(String...) - Method in interface com.netflix.iceberg.TableScan
Create a new TableScan from the results of this that will project the given columns.
select(Collection<String>) - Method in interface com.netflix.iceberg.TableScan
Create a new TableScan from this that will read the given manifest columns.
select(Schema, Set<Integer>) - Static method in class com.netflix.iceberg.types.TypeUtil
 
selectNot(Schema, Set<Integer>) - Static method in class com.netflix.iceberg.types.TypeUtil
 
serialize() - Method in class com.netflix.iceberg.orc.ColumnIdMap
 
set(String, String) - Method in class com.netflix.iceberg.avro.Avro.WriteBuilder
 
set(S, int, Object) - Method in class com.netflix.iceberg.avro.ValueReaders.StructReader
 
set(T) - Method in class com.netflix.iceberg.common.DynFields.BoundField
 
set(T) - Method in class com.netflix.iceberg.common.DynFields.StaticField
 
set(Object, T) - Method in class com.netflix.iceberg.common.DynFields.UnboundField
 
set(int, T) - Method in class com.netflix.iceberg.data.GenericRecord
 
set(String, String) - Method in class com.netflix.iceberg.parquet.Parquet.ReadBuilder
 
set(String, String) - Method in class com.netflix.iceberg.parquet.Parquet.WriteBuilder
 
set(K, V) - Method in class com.netflix.iceberg.parquet.ParquetValueReaders.ReusableEntry
 
set(I, int, Object) - Method in class com.netflix.iceberg.parquet.ParquetValueReaders.StructReader
Used to set a struct value by position.
set(int, T) - Method in interface com.netflix.iceberg.StructLike
 
set(String, String) - Method in interface com.netflix.iceberg.UpdateProperties
Add a key/value property to the table.
set(CharSequence) - Method in class com.netflix.iceberg.util.CharSequenceWrapper
 
set(StructLike) - Method in class com.netflix.iceberg.util.StructLikeWrapper
 
setAll(Map<String, String>) - Method in class com.netflix.iceberg.avro.Avro.WriteBuilder
 
setAll(Map<String, String>) - Method in class com.netflix.iceberg.parquet.Parquet.WriteBuilder
 
setBoolean(I, int, boolean) - Method in class com.netflix.iceberg.parquet.ParquetValueReaders.StructReader
 
setColumnStore(ColumnWriteStore) - Method in class com.netflix.iceberg.parquet.ColumnWriter
 
setColumnStore(ColumnWriteStore) - Method in interface com.netflix.iceberg.parquet.ParquetValueWriter
 
setColumnStore(ColumnWriteStore) - Method in class com.netflix.iceberg.parquet.ParquetValueWriters.PrimitiveWriter
 
setColumnStore(ColumnWriteStore) - Method in class com.netflix.iceberg.parquet.ParquetValueWriters.RepeatedKeyValueWriter
 
setColumnStore(ColumnWriteStore) - Method in class com.netflix.iceberg.parquet.ParquetValueWriters.RepeatedWriter
 
setColumnStore(ColumnWriteStore) - Method in class com.netflix.iceberg.parquet.ParquetValueWriters.StructWriter
 
setConf(Configuration) - Method in class com.netflix.iceberg.hadoop.HadoopTables
 
setDouble(I, int, double) - Method in class com.netflix.iceberg.parquet.ParquetValueReaders.StructReader
 
setField(String, Object) - Method in class com.netflix.iceberg.data.GenericRecord
 
setField(String, Object) - Method in interface com.netflix.iceberg.data.Record
 
setFloat(I, int, float) - Method in class com.netflix.iceberg.parquet.ParquetValueReaders.StructReader
 
setInteger(I, int, int) - Method in class com.netflix.iceberg.parquet.ParquetValueReaders.StructReader
 
setLocation(String, Job) - Method in class com.netflix.iceberg.pig.IcebergStorage
 
setLong(I, int, long) - Method in class com.netflix.iceberg.parquet.ParquetValueReaders.StructReader
 
setNull(I, int) - Method in class com.netflix.iceberg.parquet.ParquetValueReaders.StructReader
 
setPageSource(PageReader) - Method in class com.netflix.iceberg.parquet.ColumnIterator
 
setPageSource(PageReadStore) - Method in interface com.netflix.iceberg.parquet.ParquetValueReader
 
setPageSource(PageReadStore) - Method in class com.netflix.iceberg.parquet.ParquetValueReaders.PrimitiveReader
 
setPageSource(PageReadStore) - Method in class com.netflix.iceberg.parquet.ParquetValueReaders.RepeatedKeyValueReader
 
setPageSource(PageReadStore) - Method in class com.netflix.iceberg.parquet.ParquetValueReaders.RepeatedReader
 
setPageSource(PageReadStore) - Method in class com.netflix.iceberg.parquet.ParquetValueReaders.StructReader
 
setPartitionFilter(Expression) - Method in class com.netflix.iceberg.pig.IcebergStorage
 
setPushdownPredicate(Expression) - Method in class com.netflix.iceberg.pig.IcebergStorage
 
setSchema(Schema) - Method in class com.netflix.iceberg.avro.ProjectionDatumReader
 
setSchema(Schema) - Method in class com.netflix.iceberg.data.avro.DataReader
 
setSchema(Schema) - Method in class com.netflix.iceberg.data.avro.DataWriter
 
setSchema(Schema) - Method in class com.netflix.iceberg.spark.data.SparkAvroReader
 
setSchema(Schema) - Method in class com.netflix.iceberg.spark.data.SparkAvroWriter
 
setUDFContextSignature(String) - Method in class com.netflix.iceberg.pig.IcebergStorage
 
setValue(V) - Method in class com.netflix.iceberg.parquet.ParquetValueReaders.ReusableEntry
 
shortName() - Method in class com.netflix.iceberg.spark.source.IcebergSource
 
shouldAdjustToUTC() - Method in class com.netflix.iceberg.types.Types.TimestampType
 
shouldDelete(PartitionSpec) - Method in class com.netflix.iceberg.BaseReplaceFiles
Function that would be used during manifest processing to chose if a given manifest entry should be deleted or not.
shouldRead(MessageType, BlockMetaData, DictionaryPageReadStore) - Method in class com.netflix.iceberg.parquet.ParquetDictionaryRowGroupFilter
Test whether the dictionaries for a row group may contain records that match the expression.
shouldRead(MessageType, BlockMetaData) - Method in class com.netflix.iceberg.parquet.ParquetMetricsRowGroupFilter
Test whether the file may contain records that match the expression.
signedBytes() - Static method in class com.netflix.iceberg.types.Comparators
 
size() - Method in class com.netflix.iceberg.data.GenericRecord
 
size() - Method in class com.netflix.iceberg.orc.ColumnIdMap
 
size() - Method in interface com.netflix.iceberg.StructLike
 
Snapshot - Interface in com.netflix.iceberg
A snapshot of the data in a table at a point in time.
snapshot(long) - Method in class com.netflix.iceberg.TableMetadata
 
snapshotId() - Method in interface com.netflix.iceberg.Snapshot
Return this snapshot's ID.
snapshotId() - Method in class com.netflix.iceberg.TableMetadata.SnapshotLogEntry
 
snapshotLog() - Method in class com.netflix.iceberg.TableMetadata
 
SnapshotParser - Class in com.netflix.iceberg
 
SnapshotParser() - Constructor for class com.netflix.iceberg.SnapshotParser
 
snapshots() - Method in class com.netflix.iceberg.BaseTable
 
snapshots() - Method in interface com.netflix.iceberg.Table
Get the snapshots of this table.
snapshots() - Method in class com.netflix.iceberg.TableMetadata
 
sortColumns() - Method in interface com.netflix.iceberg.DataFile
 
sourceId() - Method in class com.netflix.iceberg.PartitionField
 
SparkAvroReader - Class in com.netflix.iceberg.spark.data
 
SparkAvroReader(Schema) - Constructor for class com.netflix.iceberg.spark.data.SparkAvroReader
 
SparkAvroWriter - Class in com.netflix.iceberg.spark.data
 
SparkAvroWriter(Schema) - Constructor for class com.netflix.iceberg.spark.data.SparkAvroWriter
 
SparkExpressions - Class in com.netflix.iceberg.spark
 
SparkFilters - Class in com.netflix.iceberg.spark
 
SparkOrcReader - Class in com.netflix.iceberg.spark.data
Converts the OrcInterator, which returns ORC's VectorizedRowBatch to a set of Spark's UnsafeRows.
SparkOrcReader(InputFile, FileScanTask, Schema) - Constructor for class com.netflix.iceberg.spark.data.SparkOrcReader
 
SparkOrcWriter - Class in com.netflix.iceberg.spark.data
This class acts as an adaptor from an OrcFileAppender to a FileAppender<InternalRow>.
SparkOrcWriter(OrcFileAppender) - Constructor for class com.netflix.iceberg.spark.data.SparkOrcWriter
 
SparkParquetReaders - Class in com.netflix.iceberg.spark.data
 
SparkSchemaUtil - Class in com.netflix.iceberg.spark
Helper methods for working with Spark/Hive metadata.
SparkValueReaders - Class in com.netflix.iceberg.spark.data
 
SparkValueReaders() - Constructor for class com.netflix.iceberg.spark.data.SparkValueReaders
 
SparkValueWriters - Class in com.netflix.iceberg.spark.data
 
SparkValueWriters() - Constructor for class com.netflix.iceberg.spark.data.SparkValueWriters
 
spec() - Method in class com.netflix.iceberg.BaseTable
 
spec() - Method in interface com.netflix.iceberg.FileScanTask
The spec used to store this file.
spec() - Method in class com.netflix.iceberg.ManifestReader
 
spec() - Method in interface com.netflix.iceberg.Table
Return the partition spec for this table.
spec() - Method in class com.netflix.iceberg.TableMetadata
 
specForTable(SparkSession, String) - Static method in class com.netflix.iceberg.spark.SparkSchemaUtil
Returns a PartitionSpec for the given table.
split(long, long) - Method in class com.netflix.iceberg.avro.Avro.ReadBuilder
Restricts the read to the given range: [start, end = start + length).
split(long, long) - Method in class com.netflix.iceberg.orc.ORC.ReadBuilder
Restricts the read to the given range: [start, start + length).
split(long, long) - Method in class com.netflix.iceberg.parquet.Parquet.ReadBuilder
Restricts the read to the given range: [start, start + length).
SPLIT_LOOKBACK - Static variable in class com.netflix.iceberg.TableProperties
 
SPLIT_LOOKBACK_DEFAULT - Static variable in class com.netflix.iceberg.TableProperties
 
SPLIT_SIZE - Static variable in class com.netflix.iceberg.TableProperties
 
SPLIT_SIZE_DEFAULT - Static variable in class com.netflix.iceberg.TableProperties
 
start() - Method in interface com.netflix.iceberg.FileScanTask
The starting position of this scan range in the file.
stopAbortsOnFailure() - Method in class com.netflix.iceberg.util.Tasks.Builder
 
stopOnFailure() - Method in class com.netflix.iceberg.util.Tasks.Builder
 
stopRetryOn(Class<? extends Exception>...) - Method in class com.netflix.iceberg.util.Tasks.Builder
 
stopRevertsOnFailure() - Method in class com.netflix.iceberg.util.Tasks.Builder
 
strict(PartitionSpec) - Static method in class com.netflix.iceberg.expressions.Projections
Creates a strict ProjectionEvaluator for the spec.
StrictMetricsEvaluator - Class in com.netflix.iceberg.expressions
Evaluates an Expression on a DataFile to test whether all rows in the file match.
StrictMetricsEvaluator(Schema, Expression) - Constructor for class com.netflix.iceberg.expressions.StrictMetricsEvaluator
 
StringReader(ColumnDescriptor) - Constructor for class com.netflix.iceberg.parquet.ParquetValueReaders.StringReader
 
strings() - Static method in class com.netflix.iceberg.avro.ValueReaders
 
strings() - Static method in class com.netflix.iceberg.avro.ValueWriters
 
strings(ColumnDescriptor) - Static method in class com.netflix.iceberg.parquet.ParquetValueWriters
 
StringType() - Constructor for class com.netflix.iceberg.types.Types.StringType
 
struct() - Method in class com.netflix.iceberg.data.GenericRecord
 
struct() - Method in interface com.netflix.iceberg.data.Record
 
struct(GroupType, List<T>) - Method in class com.netflix.iceberg.parquet.ParquetTypeVisitor
 
struct(Types.StructType, Type.Repetition, int, String) - Method in class com.netflix.iceberg.parquet.TypeToMessageType
 
struct(Types.StructType, GroupType, List<T>) - Method in class com.netflix.iceberg.parquet.TypeWithSchemaVisitor
 
struct(Types.StructType, Iterable<Type>) - Method in class com.netflix.iceberg.spark.PruneColumnsWithoutReordering
 
struct(Types.StructType, Iterable<Type>) - Method in class com.netflix.iceberg.spark.PruneColumnsWithReordering
 
struct(Types.StructType, Iterable<List<String>>) - Method in class com.netflix.iceberg.types.CheckCompatibility
 
struct(Types.StructType, List<Map<String, Integer>>) - Method in class com.netflix.iceberg.types.IndexByName
 
struct(Types.StructType, Iterable<T>) - Method in class com.netflix.iceberg.types.TypeUtil.CustomOrderSchemaVisitor
 
struct(Types.StructType, List<T>) - Method in class com.netflix.iceberg.types.TypeUtil.SchemaVisitor
 
StructLike - Interface in com.netflix.iceberg
Interface for accessing data by position in a schema.
StructLikeWrapper - Class in com.netflix.iceberg.util
Wrapper to adapt StructLike for use in maps and sets by implementing equals and hashCode.
StructReader(List<ValueReader<?>>) - Constructor for class com.netflix.iceberg.avro.ValueReaders.StructReader
 
StructReader(List<Type>, List<ParquetValueReader<?>>) - Constructor for class com.netflix.iceberg.parquet.ParquetValueReaders.StructReader
 
StructWriter(List<ValueWriter<?>>) - Constructor for class com.netflix.iceberg.avro.ValueWriters.StructWriter
 
StructWriter(List<ParquetValueWriter<?>>) - Constructor for class com.netflix.iceberg.parquet.ParquetValueWriters.StructWriter
 
suppressAndThrow(E, Runnable) - Static method in class com.netflix.iceberg.util.Exceptions
 
suppressExceptions(E, Runnable) - Static method in class com.netflix.iceberg.util.Exceptions
 
suppressFailureWhenFinished() - Method in class com.netflix.iceberg.util.Tasks.Builder
 

T

Table - Interface in com.netflix.iceberg
Represents a table.
table() - Method in interface com.netflix.iceberg.TableScan
Returns the Table from which this scan loads data.
table() - Method in interface com.netflix.iceberg.Transaction
Return the Table that this transaction will update.
TABLE_TYPE_PROP - Static variable in class com.netflix.iceberg.BaseMetastoreTableOperations
 
TableMetadata - Class in com.netflix.iceberg
Metadata for a table.
TableMetadata.SnapshotLogEntry - Class in com.netflix.iceberg
 
TableMetadataParser - Class in com.netflix.iceberg
 
TableMetadataParser() - Constructor for class com.netflix.iceberg.TableMetadataParser
 
TableOperations - Interface in com.netflix.iceberg
SPI interface to abstract table metadata access and updates.
TableProperties - Class in com.netflix.iceberg
 
TableProperties() - Constructor for class com.netflix.iceberg.TableProperties
 
Tables - Interface in com.netflix.iceberg
Generic interface for creating and loading a table implementation.
TableScan - Interface in com.netflix.iceberg
API for configuring a table scan.
Tasks - Class in com.netflix.iceberg.util
 
Tasks() - Constructor for class com.netflix.iceberg.util.Tasks
 
Tasks.Builder<I> - Class in com.netflix.iceberg.util
 
Tasks.FailureTask<I,E extends java.lang.Exception> - Interface in com.netflix.iceberg.util
 
Tasks.Task<I,E extends java.lang.Exception> - Interface in com.netflix.iceberg.util
 
Tasks.UnrecoverableException - Exception in com.netflix.iceberg.util
 
ThreadPools - Class in com.netflix.iceberg.util
 
ThreadPools() - Constructor for class com.netflix.iceberg.util.ThreadPools
 
throwFailureWhenFinished() - Method in class com.netflix.iceberg.util.Tasks.Builder
 
throwFailureWhenFinished(boolean) - Method in class com.netflix.iceberg.util.Tasks.Builder
 
timestampMillis() - Method in interface com.netflix.iceberg.Snapshot
Return this snapshot's timestamp.
timestampMillis() - Method in class com.netflix.iceberg.TableMetadata.SnapshotLogEntry
 
to(Type) - Method in interface com.netflix.iceberg.expressions.Literal
Converts this literal to a literal of the given type.
toByteBuffer(Type, Object) - Static method in class com.netflix.iceberg.types.Conversions
 
toFixed(UUID, Schema, LogicalType) - Method in class com.netflix.iceberg.avro.UUIDConversion
 
toHumanString(T) - Method in interface com.netflix.iceberg.transforms.Transform
Returns a human-readable String representation of a transformed value.
toJson(PartitionSpec, JsonGenerator) - Static method in class com.netflix.iceberg.PartitionSpecParser
 
toJson(PartitionSpec) - Static method in class com.netflix.iceberg.PartitionSpecParser
 
toJson(PartitionSpec, boolean) - Static method in class com.netflix.iceberg.PartitionSpecParser
 
toJson(Schema, JsonGenerator) - Static method in class com.netflix.iceberg.SchemaParser
 
toJson(Schema) - Static method in class com.netflix.iceberg.SchemaParser
 
toJson(Schema, boolean) - Static method in class com.netflix.iceberg.SchemaParser
 
toJson(Snapshot) - Static method in class com.netflix.iceberg.SnapshotParser
 
toJson(TableMetadata) - Static method in class com.netflix.iceberg.TableMetadataParser
 
toOrc(Schema, ColumnIdMap) - Static method in class com.netflix.iceberg.orc.TypeConversion
Convert a given Iceberg schema to ORC.
toSnapshotAtTime(long) - Method in interface com.netflix.iceberg.Rollback
Roll this table's data back to the last Snapshot before the given timestamp.
toSnapshotId(long) - Method in interface com.netflix.iceberg.Rollback
Roll this table's data back to a specific Snapshot identified by id.
toString() - Method in class com.netflix.iceberg.BaseTable
 
toString() - Method in class com.netflix.iceberg.common.DynConstructors.Ctor
 
toString() - Method in class com.netflix.iceberg.common.DynFields.UnboundField
 
toString() - Method in class com.netflix.iceberg.common.DynMethods.UnboundMethod
 
toString() - Method in class com.netflix.iceberg.data.GenericRecord
 
toString() - Method in class com.netflix.iceberg.expressions.And
 
toString() - Method in class com.netflix.iceberg.expressions.BoundReference
 
toString() - Method in class com.netflix.iceberg.expressions.False
 
toString() - Method in class com.netflix.iceberg.expressions.NamedReference
 
toString() - Method in class com.netflix.iceberg.expressions.Not
 
toString() - Method in class com.netflix.iceberg.expressions.Or
 
toString() - Method in class com.netflix.iceberg.expressions.Predicate
 
toString() - Method in class com.netflix.iceberg.expressions.True
 
toString() - Method in class com.netflix.iceberg.hadoop.HadoopInputFile
 
toString() - Method in class com.netflix.iceberg.hadoop.HadoopOutputFile
 
toString() - Method in class com.netflix.iceberg.PartitionSpec
 
toString() - Method in class com.netflix.iceberg.ScanSummary.PartitionMetrics
 
toString() - Method in class com.netflix.iceberg.Schema
 
toString() - Method in class com.netflix.iceberg.TableMetadata.SnapshotLogEntry
 
toString() - Method in class com.netflix.iceberg.types.Types.BinaryType
 
toString() - Method in class com.netflix.iceberg.types.Types.BooleanType
 
toString() - Method in class com.netflix.iceberg.types.Types.DateType
 
toString() - Method in class com.netflix.iceberg.types.Types.DecimalType
 
toString() - Method in class com.netflix.iceberg.types.Types.DoubleType
 
toString() - Method in class com.netflix.iceberg.types.Types.FixedType
 
toString() - Method in class com.netflix.iceberg.types.Types.FloatType
 
toString() - Method in class com.netflix.iceberg.types.Types.IntegerType
 
toString() - Method in class com.netflix.iceberg.types.Types.ListType
 
toString() - Method in class com.netflix.iceberg.types.Types.LongType
 
toString() - Method in class com.netflix.iceberg.types.Types.MapType
 
toString() - Method in class com.netflix.iceberg.types.Types.NestedField
 
toString() - Method in class com.netflix.iceberg.types.Types.StringType
 
toString() - Method in class com.netflix.iceberg.types.Types.StructType
 
toString() - Method in class com.netflix.iceberg.types.Types.TimestampType
 
toString() - Method in class com.netflix.iceberg.types.Types.TimeType
 
toString() - Method in class com.netflix.iceberg.types.Types.UUIDType
 
toString() - Method in class com.netflix.iceberg.util.Pair
 
Transaction - Interface in com.netflix.iceberg
A transaction for performing multiple updates to a table.
transform() - Method in class com.netflix.iceberg.PartitionField
 
Transform<S,T> - Interface in com.netflix.iceberg.transforms
A transform function used for partitioning.
Transforms - Class in com.netflix.iceberg.transforms
Factory methods for transforms.
TripleWriter<T> - Interface in com.netflix.iceberg.parquet
 
True - Class in com.netflix.iceberg.expressions
An expression that is always true.
truncate(String, int) - Method in class com.netflix.iceberg.PartitionSpec.Builder
 
truncate(String, int, int) - Method in interface com.netflix.iceberg.transforms.PartitionSpecVisitor
 
truncate(Type, int) - Static method in class com.netflix.iceberg.transforms.Transforms
Returns a truncate Transform for the given type and width.
type() - Method in class com.netflix.iceberg.expressions.BoundReference
 
Type - Interface in com.netflix.iceberg.types
 
type() - Method in class com.netflix.iceberg.types.Types.NestedField
 
Type.NestedType - Class in com.netflix.iceberg.types
 
Type.PrimitiveType - Class in com.netflix.iceberg.types
 
Type.TypeID - Enum in com.netflix.iceberg.types
 
TypeConversion - Class in com.netflix.iceberg.orc
 
TypeConversion() - Constructor for class com.netflix.iceberg.orc.TypeConversion
 
typeId() - Method in interface com.netflix.iceberg.types.Type
 
typeId() - Method in class com.netflix.iceberg.types.Types.BinaryType
 
typeId() - Method in class com.netflix.iceberg.types.Types.BooleanType
 
typeId() - Method in class com.netflix.iceberg.types.Types.DateType
 
typeId() - Method in class com.netflix.iceberg.types.Types.DecimalType
 
typeId() - Method in class com.netflix.iceberg.types.Types.DoubleType
 
typeId() - Method in class com.netflix.iceberg.types.Types.FixedType
 
typeId() - Method in class com.netflix.iceberg.types.Types.FloatType
 
typeId() - Method in class com.netflix.iceberg.types.Types.IntegerType
 
typeId() - Method in class com.netflix.iceberg.types.Types.ListType
 
typeId() - Method in class com.netflix.iceberg.types.Types.LongType
 
typeId() - Method in class com.netflix.iceberg.types.Types.MapType
 
typeId() - Method in class com.netflix.iceberg.types.Types.StringType
 
typeId() - Method in class com.netflix.iceberg.types.Types.StructType
 
typeId() - Method in class com.netflix.iceberg.types.Types.TimestampType
 
typeId() - Method in class com.netflix.iceberg.types.Types.TimeType
 
typeId() - Method in class com.netflix.iceberg.types.Types.UUIDType
 
Types - Class in com.netflix.iceberg.types
 
Types() - Constructor for class com.netflix.iceberg.types.Types
 
Types.BinaryType - Class in com.netflix.iceberg.types
 
Types.BooleanType - Class in com.netflix.iceberg.types
 
Types.DateType - Class in com.netflix.iceberg.types
 
Types.DecimalType - Class in com.netflix.iceberg.types
 
Types.DoubleType - Class in com.netflix.iceberg.types
 
Types.FixedType - Class in com.netflix.iceberg.types
 
Types.FloatType - Class in com.netflix.iceberg.types
 
Types.IntegerType - Class in com.netflix.iceberg.types
 
Types.ListType - Class in com.netflix.iceberg.types
 
Types.LongType - Class in com.netflix.iceberg.types
 
Types.MapType - Class in com.netflix.iceberg.types
 
Types.NestedField - Class in com.netflix.iceberg.types
 
Types.StringType - Class in com.netflix.iceberg.types
 
Types.StructType - Class in com.netflix.iceberg.types
 
Types.TimestampType - Class in com.netflix.iceberg.types
 
Types.TimeType - Class in com.netflix.iceberg.types
 
Types.UUIDType - Class in com.netflix.iceberg.types
 
TypeToMessageType - Class in com.netflix.iceberg.parquet
 
TypeToMessageType() - Constructor for class com.netflix.iceberg.parquet.TypeToMessageType
 
TypeUtil - Class in com.netflix.iceberg.types
 
TypeUtil() - Constructor for class com.netflix.iceberg.types.TypeUtil
 
TypeUtil.CustomOrderSchemaVisitor<T> - Class in com.netflix.iceberg.types
 
TypeUtil.NextID - Interface in com.netflix.iceberg.types
Interface for passing a function that assigns column IDs.
TypeUtil.SchemaVisitor<T> - Class in com.netflix.iceberg.types
 
TypeWithSchemaVisitor<T> - Class in com.netflix.iceberg.parquet
Visitor for traversing a Parquet type with a companion Iceberg type.
TypeWithSchemaVisitor() - Constructor for class com.netflix.iceberg.parquet.TypeWithSchemaVisitor
 

U

UnboundPredicate<T> - Class in com.netflix.iceberg.expressions
 
unboxed(ColumnDescriptor) - Static method in class com.netflix.iceberg.parquet.ParquetValueWriters
 
UnboxedReader(ColumnDescriptor) - Constructor for class com.netflix.iceberg.parquet.ParquetValueReaders.UnboxedReader
 
union(Schema, List<T>) - Method in class com.netflix.iceberg.avro.AvroSchemaVisitor
 
union(List<ValueReader<?>>) - Static method in class com.netflix.iceberg.avro.ValueReaders
 
unpartitioned() - Static method in class com.netflix.iceberg.PartitionSpec
Returns a spec for unpartitioned tables.
UnrecoverableException(String) - Constructor for exception com.netflix.iceberg.util.Tasks.UnrecoverableException
 
UnrecoverableException(String, Throwable) - Constructor for exception com.netflix.iceberg.util.Tasks.UnrecoverableException
 
UnrecoverableException(Throwable) - Constructor for exception com.netflix.iceberg.util.Tasks.UnrecoverableException
 
unsignedBytes() - Static method in class com.netflix.iceberg.types.Comparators
 
updateColumn(String, Type.PrimitiveType) - Method in interface com.netflix.iceberg.UpdateSchema
Update a column in the schema to a new primitive type.
updateProperties() - Method in class com.netflix.iceberg.BaseTable
 
updateProperties() - Method in interface com.netflix.iceberg.Table
Create a new UpdateProperties to update table properties and commit the changes.
updateProperties() - Method in interface com.netflix.iceberg.Transaction
Create a new UpdateProperties to update table properties.
UpdateProperties - Interface in com.netflix.iceberg
API for updating table properties.
updateSchema() - Method in class com.netflix.iceberg.BaseTable
 
updateSchema() - Method in interface com.netflix.iceberg.Table
Create a new UpdateSchema to alter the columns of this table and commit the change.
updateSchema(Schema, int) - Method in class com.netflix.iceberg.TableMetadata
 
UpdateSchema - Interface in com.netflix.iceberg
API for schema evolution.
updateTableLocation(String) - Method in class com.netflix.iceberg.TableMetadata
 
upperBounds() - Method in interface com.netflix.iceberg.DataFile
 
upperBounds() - Method in class com.netflix.iceberg.Metrics
 
useSnapshot(long) - Method in interface com.netflix.iceberg.TableScan
Create a new TableScan from this scan's configuration that will use the given snapshot by ID.
utf8s() - Static method in class com.netflix.iceberg.avro.ValueReaders
 
utf8s() - Static method in class com.netflix.iceberg.avro.ValueWriters
 
UUIDConversion - Class in com.netflix.iceberg.avro
 
UUIDConversion() - Constructor for class com.netflix.iceberg.avro.UUIDConversion
 
uuids() - Static method in class com.netflix.iceberg.avro.ValueReaders
 
uuids() - Static method in class com.netflix.iceberg.avro.ValueWriters
 
UUIDType() - Constructor for class com.netflix.iceberg.types.Types.UUIDType
 

V

validate(Schema) - Method in class com.netflix.iceberg.avro.LogicalMap
 
validateAddedFiles() - Method in class com.netflix.iceberg.OverwriteData
 
validateAddedFiles() - Method in interface com.netflix.iceberg.OverwriteFiles
Signal that each file added to the table must match the overwrite expression.
validateAppendOnly() - Method in interface com.netflix.iceberg.ReplacePartitions
Validate that no partitions will be replaced and the operation is append-only.
validateAppendOnly() - Method in class com.netflix.iceberg.ReplacePartitionsOperation
 
ValidationException - Exception in com.netflix.iceberg.exceptions
Exception raised when validation checks fail.
ValidationException(String, Object...) - Constructor for exception com.netflix.iceberg.exceptions.ValidationException
 
ValidationException(Throwable, String, Object...) - Constructor for exception com.netflix.iceberg.exceptions.ValidationException
 
value() - Method in interface com.netflix.iceberg.expressions.Literal
 
VALUE_ID_PROP - Static variable in class com.netflix.iceberg.avro.AvroSchemaUtil
 
valueCounts() - Method in interface com.netflix.iceberg.DataFile
 
valueCounts() - Method in class com.netflix.iceberg.Metrics
 
valueId() - Method in class com.netflix.iceberg.types.Types.MapType
 
valueOf(String) - Static method in enum com.netflix.iceberg.expressions.Expression.Operation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.netflix.iceberg.FileFormat
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.netflix.iceberg.types.Type.TypeID
Returns the enum constant of this type with the specified name.
ValueReader<T> - Interface in com.netflix.iceberg.avro
 
ValueReaders - Class in com.netflix.iceberg.avro
 
ValueReaders.StructReader<S> - Class in com.netflix.iceberg.avro
 
values() - Static method in enum com.netflix.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 com.netflix.iceberg.FileFormat
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class com.netflix.iceberg.orc.ColumnIdMap
 
values() - Static method in enum com.netflix.iceberg.types.Type.TypeID
Returns an array containing the constants of this enum type, in the order they are declared.
valueType() - Method in class com.netflix.iceberg.types.Types.MapType
 
ValueWriter<D> - Interface in com.netflix.iceberg.avro
 
ValueWriters - Class in com.netflix.iceberg.avro
 
ValueWriters.StructWriter<S> - Class in com.netflix.iceberg.avro
 
visit(Schema, AvroSchemaVisitor<T>) - Static method in class com.netflix.iceberg.avro.AvroSchemaVisitor
 
visit(Expression, ExpressionVisitors.ExpressionVisitor<R>) - Static method in class com.netflix.iceberg.expressions.ExpressionVisitors
Traverses the given expression with a visitor.
visit(Type, ParquetTypeVisitor<T>) - Static method in class com.netflix.iceberg.parquet.ParquetTypeVisitor
 
visit(Type, Type, TypeWithSchemaVisitor<T>) - Static method in class com.netflix.iceberg.parquet.TypeWithSchemaVisitor
 
visit(Schema, PartitionSpec, PartitionSpecVisitor<R>) - Static method in interface com.netflix.iceberg.transforms.PartitionSpecVisitor
 
visit(Schema, TypeUtil.SchemaVisitor<T>) - Static method in class com.netflix.iceberg.types.TypeUtil
 
visit(Type, TypeUtil.SchemaVisitor<T>) - Static method in class com.netflix.iceberg.types.TypeUtil
 
visit(Schema, TypeUtil.CustomOrderSchemaVisitor<T>) - Static method in class com.netflix.iceberg.types.TypeUtil
 
visit(Type, TypeUtil.CustomOrderSchemaVisitor<T>) - Static method in class com.netflix.iceberg.types.TypeUtil
Used to traverse types with traversals other than pre-order.

W

where(Expression) - Method in class com.netflix.iceberg.data.IcebergGenerics.ScanBuilder
 
withBlockSizeInBytes(long) - Method in class com.netflix.iceberg.DataFiles.Builder
 
withFileSizeInBytes(long) - Method in class com.netflix.iceberg.DataFiles.Builder
 
withFormat(String) - Method in class com.netflix.iceberg.DataFiles.Builder
 
withFormat(FileFormat) - Method in class com.netflix.iceberg.DataFiles.Builder
 
withInputFile(InputFile) - Method in class com.netflix.iceberg.DataFiles.Builder
 
withMetrics(Metrics) - Method in class com.netflix.iceberg.DataFiles.Builder
 
withoutZone() - Static method in class com.netflix.iceberg.types.Types.TimestampType
 
withPartition(StructLike) - Method in class com.netflix.iceberg.DataFiles.Builder
 
withPartitionPath(String) - Method in class com.netflix.iceberg.DataFiles.Builder
 
withPath(String) - Method in class com.netflix.iceberg.DataFiles.Builder
 
withRecordCount(long) - Method in class com.netflix.iceberg.DataFiles.Builder
 
withStatus(FileStatus) - Method in class com.netflix.iceberg.DataFiles.Builder
 
withZone() - Static method in class com.netflix.iceberg.types.Types.TimestampType
 
WORKER_THREAD_POOL_SIZE_PROP - Static variable in class com.netflix.iceberg.util.ThreadPools
 
wrap(CharSequence) - Static method in class com.netflix.iceberg.util.CharSequenceWrapper
 
wrap(StructLike) - Static method in class com.netflix.iceberg.util.StructLikeWrapper
 
write(OutputFile) - Static method in class com.netflix.iceberg.avro.Avro
 
write(D, Encoder) - Method in interface com.netflix.iceberg.avro.ValueWriter
 
write(S, Encoder) - Method in class com.netflix.iceberg.avro.ValueWriters.StructWriter
 
write(T, Encoder) - Method in class com.netflix.iceberg.data.avro.DataWriter
 
write(OutputFile) - Static method in class com.netflix.iceberg.orc.ORC
 
write(OutputFile) - Static method in class com.netflix.iceberg.parquet.Parquet
 
write(int, T) - Method in interface com.netflix.iceberg.parquet.ParquetValueWriter
 
write(int, T) - Method in class com.netflix.iceberg.parquet.ParquetValueWriters.PrimitiveWriter
 
write(int, M) - Method in class com.netflix.iceberg.parquet.ParquetValueWriters.RepeatedKeyValueWriter
 
write(int, L) - Method in class com.netflix.iceberg.parquet.ParquetValueWriters.RepeatedWriter
 
write(int, S) - Method in class com.netflix.iceberg.parquet.ParquetValueWriters.StructWriter
 
write(int, T) - Method in interface com.netflix.iceberg.parquet.TripleWriter
Write a value.
write(InternalRow, Encoder) - Method in class com.netflix.iceberg.spark.data.SparkAvroWriter
 
write(TableMetadata, OutputFile) - Static method in class com.netflix.iceberg.TableMetadataParser
 
writeBinary(int, Binary) - Method in class com.netflix.iceberg.parquet.ColumnWriter
 
writeBinary(int, Binary) - Method in interface com.netflix.iceberg.parquet.TripleWriter
Write a triple.
writeBoolean(int, boolean) - Method in class com.netflix.iceberg.parquet.ColumnWriter
 
writeBoolean(int, boolean) - Method in interface com.netflix.iceberg.parquet.TripleWriter
Write a triple.
writeCompatibilityErrors(Schema, Schema) - Static method in class com.netflix.iceberg.types.CheckCompatibility
Returns a list of compatibility errors for writing with the given write schema.
writeDouble(int, double) - Method in class com.netflix.iceberg.parquet.ColumnWriter
 
writeDouble(int, double) - Method in interface com.netflix.iceberg.parquet.TripleWriter
Write a triple.
writeFloat(int, float) - Method in class com.netflix.iceberg.parquet.ColumnWriter
 
writeFloat(int, float) - Method in interface com.netflix.iceberg.parquet.TripleWriter
Write a triple.
writeInteger(int, int) - Method in class com.netflix.iceberg.parquet.ColumnWriter
 
writeInteger(int, int) - Method in interface com.netflix.iceberg.parquet.TripleWriter
Write a triple.
writeLong(int, long) - Method in class com.netflix.iceberg.parquet.ColumnWriter
 
writeLong(int, long) - Method in interface com.netflix.iceberg.parquet.TripleWriter
Write a triple.
writeNewMetadata(TableMetadata, int) - Method in class com.netflix.iceberg.BaseMetastoreTableOperations
 
writeNull(int, int) - Method in class com.netflix.iceberg.parquet.ColumnWriter
 
writeNull(int, int) - Method in interface com.netflix.iceberg.parquet.TripleWriter
Write a triple for a null value.
writer(int) - Method in class com.netflix.iceberg.avro.ValueWriters.StructWriter
 
writeSupport(WriteSupport<?>) - Method in class com.netflix.iceberg.parquet.Parquet.WriteBuilder
 

Y

year(String) - Method in class com.netflix.iceberg.PartitionSpec.Builder
 
year(String, int) - Method in interface com.netflix.iceberg.transforms.PartitionSpecVisitor
 
year(Type) - Static method in class com.netflix.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