- 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
-
- 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
-
- 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
-
- 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
-
- spec() - Method in class com.netflix.iceberg.TableMetadata
-
- specForTable(SparkSession, String) - Static method in class com.netflix.iceberg.spark.SparkSchemaUtil
-
- 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
-
- 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
-