Index

A B C D E F G H I J K L M N O P R S T U V W _ 
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form

A

add(long) - Method in class io.delta.kernel.internal.deletionvectors.RoaringBitmapArray
 
add(StructField) - Method in class io.delta.kernel.types.StructType
 
add(String, DataType) - Method in class io.delta.kernel.types.StructType
 
add(String, DataType, boolean) - Method in class io.delta.kernel.types.StructType
 
add(String, DataType, boolean, FieldMetadata) - Method in class io.delta.kernel.types.StructType
 
add(String, DataType, FieldMetadata) - Method in class io.delta.kernel.types.StructType
 
ADD_FILE_DV_ORDINAL - Static variable in class io.delta.kernel.internal.replay.LogReplay
 
ADD_FILE_ORDINAL - Static variable in class io.delta.kernel.internal.InternalScanFileUtils
 
ADD_FILE_ORDINAL - Static variable in class io.delta.kernel.internal.replay.LogReplay
 
ADD_FILE_PARTITION_COL_REF - Static variable in class io.delta.kernel.internal.InternalScanFileUtils
Column expression referring to the `partitionValues` in scan `add` file.
ADD_FILE_PATH_ORDINAL - Static variable in class io.delta.kernel.internal.replay.LogReplay
 
ADD_FILE_STATS_ORDINAL - Static variable in class io.delta.kernel.internal.InternalScanFileUtils
 
AddFile - Class in io.delta.kernel.internal.actions
Delta log action representing an `AddFile`
AddFile() - Constructor for class io.delta.kernel.internal.actions.AddFile
 
ADDFILE_FIELD_NAME - Static variable in class io.delta.kernel.internal.replay.LogReplay
 
allLogFilesReversed() - Method in class io.delta.kernel.internal.snapshot.LogSegment
 
allLogFilesUnsorted() - Method in class io.delta.kernel.internal.snapshot.LogSegment
 
ALWAYS_FALSE - Static variable in class io.delta.kernel.expressions.AlwaysFalse
 
ALWAYS_TRUE - Static variable in class io.delta.kernel.expressions.AlwaysTrue
 
AlwaysFalse - Class in io.delta.kernel.expressions
Predicate which always evaluates to false.
AlwaysTrue - Class in io.delta.kernel.expressions
Predicate which always evaluates to true.
And - Class in io.delta.kernel.expressions
AND expression
And(Predicate, Predicate) - Constructor for class io.delta.kernel.expressions.And
 
ArrayType - Class in io.delta.kernel.types
Represent array data type
ArrayType(DataType, boolean) - Constructor for class io.delta.kernel.types.ArrayType
 
ArrayValue - Interface in io.delta.kernel.data
Abstraction to represent a single array value in a ColumnVector.
asPredicate(Expression) - Static method in class io.delta.kernel.internal.util.ExpressionUtils
Return an expression cast as a predicate, throw an error if it is not a predicate
assertLogFilesBelongToTable(Path, List<FileStatus>) - Static method in class io.delta.kernel.internal.replay.LogReplayUtils
Verifies that a set of delta or checkpoint files to be read actually belongs to this table.
at(int) - Method in class io.delta.kernel.types.StructType
 

B

Base85Codec - Class in io.delta.kernel.internal.deletionvectors
This implements Base85 using the 4 byte block aligned encoding and character set from Z85.
Base85Codec() - Constructor for class io.delta.kernel.internal.deletionvectors.Base85Codec
 
BasePrimitiveType - Class in io.delta.kernel.types
Base class for all primitive types DataType.
BINARY - Static variable in class io.delta.kernel.types.BinaryType
 
BinaryType - Class in io.delta.kernel.types
The data type representing byte[] values.
BOOLEAN - Static variable in class io.delta.kernel.types.BooleanType
 
BooleanType - Class in io.delta.kernel.types
Data type representing boolean type values.
build() - Method in class io.delta.kernel.internal.ScanBuilderImpl
 
build() - Method in interface io.delta.kernel.ScanBuilder
 
build() - Method in class io.delta.kernel.types.FieldMetadata.Builder
 
build(Engine) - Method in class io.delta.kernel.internal.TransactionBuilderImpl
 
build(Engine) - Method in interface io.delta.kernel.TransactionBuilder
Build the transaction.
builder() - Static method in class io.delta.kernel.types.FieldMetadata
 
Builder() - Constructor for class io.delta.kernel.types.FieldMetadata.Builder
 
buildLatestSnapshot(Engine) - Method in class io.delta.kernel.internal.snapshot.SnapshotManager
Construct the latest snapshot for given table.
BYTE - Static variable in class io.delta.kernel.types.ByteType
 
ByteType - Class in io.delta.kernel.types
The data type representing byte type values.

C

casePreservingPartitionColNames(StructType, List<String>) - Static method in class io.delta.kernel.internal.util.SchemaUtils
Delta expects partition column names to be same case preserving as the name in the schema.
casePreservingPartitionColNames(List<String>, Map<String, Literal>) - Static method in class io.delta.kernel.internal.util.SchemaUtils
Convert the partition column names in partitionValues map into the same case as the column in the table metadata.
checkArgument(boolean) - Static method in class io.delta.kernel.internal.util.Preconditions
Precondition-style validation that throws IllegalArgumentException.
checkArgument(boolean, String) - Static method in class io.delta.kernel.internal.util.Preconditions
Precondition-style validation that throws IllegalArgumentException.
checkArgument(boolean, String, Object...) - Static method in class io.delta.kernel.internal.util.Preconditions
Precondition-style validation that throws IllegalArgumentException.
checkpoint(Engine, long) - Method in class io.delta.kernel.internal.snapshot.SnapshotManager
 
checkpoint(Engine, long) - Method in class io.delta.kernel.internal.TableImpl
 
checkpoint(Engine, long) - Method in interface io.delta.kernel.Table
Checkpoint the table at given version.
CHECKPOINT_CLASSIC - Enum constant in enum io.delta.kernel.internal.replay.DeltaLogFile.LogType
 
CHECKPOINT_INTERVAL - Static variable in class io.delta.kernel.internal.TableConfig
How often to checkpoint the delta log? For every N (this config) commits to the log, we will suggest write out a checkpoint file that can speed up the Delta table state reconstruction.
CHECKPOINT_SCHEMA - Static variable in class io.delta.kernel.internal.actions.SingleAction
Get the schema of reading entries from Delta Log delta and checkpoint files for construction of new checkpoint.
CheckpointAlreadyExistsException - Exception in io.delta.kernel.exceptions
Thrown when trying to create a checkpoint at version v, but there already exists a checkpoint at version v.
CheckpointAlreadyExistsException(long) - Constructor for exception io.delta.kernel.exceptions.CheckpointAlreadyExistsException
 
Checkpointer - Class in io.delta.kernel.internal.checkpoints
Class to load and write the CheckpointMetaData from `_last_checkpoint` file.
Checkpointer(Path) - Constructor for class io.delta.kernel.internal.checkpoints.Checkpointer
 
checkpointFileSingular(Path, long) - Static method in class io.delta.kernel.internal.util.FileNames
Returns the path for a singular checkpoint up to the given version.
checkpointFileWithParts(Path, long, int) - Static method in class io.delta.kernel.internal.util.FileNames
Returns the paths for all parts of the checkpoint up to the given version.
CheckpointInstance - Class in io.delta.kernel.internal.checkpoints
Metadata about Delta checkpoint.
CheckpointInstance(long) - Constructor for class io.delta.kernel.internal.checkpoints.CheckpointInstance
 
CheckpointInstance(long, Optional<Integer>) - Constructor for class io.delta.kernel.internal.checkpoints.CheckpointInstance
 
CheckpointInstance(String) - Constructor for class io.delta.kernel.internal.checkpoints.CheckpointInstance
 
CheckpointInstance.CheckpointFormat - Enum in io.delta.kernel.internal.checkpoints
 
CheckpointMetaData - Class in io.delta.kernel.internal.checkpoints
 
CheckpointMetaData(long, long, Optional<Long>) - Constructor for class io.delta.kernel.internal.checkpoints.CheckpointMetaData
 
checkpoints - Variable in class io.delta.kernel.internal.snapshot.LogSegment
 
checkpointVersion(Path) - Static method in class io.delta.kernel.internal.util.FileNames
Returns the version for the given checkpoint path.
checkpointVersion(String) - Static method in class io.delta.kernel.internal.util.FileNames
 
checkpointVersionOpt - Variable in class io.delta.kernel.internal.snapshot.LogSegment
 
checkState(boolean, String) - Static method in class io.delta.kernel.internal.util.Preconditions
Ensures the truth of an expression involving the state of the calling instance.
ChildVectorBasedRow - Class in io.delta.kernel.internal.data
A Row implementation that wraps a set of child vectors for a specific rowId.
ChildVectorBasedRow(int, StructType) - Constructor for class io.delta.kernel.internal.data.ChildVectorBasedRow
 
CLASSIC - Enum constant in enum io.delta.kernel.internal.checkpoints.CheckpointInstance.CheckpointFormat
 
close() - Method in interface io.delta.kernel.data.ColumnVector
Cleans up memory for this column vector.
close() - Method in class io.delta.kernel.internal.data.SelectionColumnVector
 
close() - Method in class io.delta.kernel.internal.replay.CreateCheckpointIterator
 
CloseableIterable<T> - Interface in io.delta.kernel.utils
Extend the Java Iterable interface to provide a way to close the iterator.
CloseableIterator<T> - Interface in io.delta.kernel.utils
Closeable extension of Iterator
closeCloseables(AutoCloseable...) - Static method in class io.delta.kernel.internal.util.Utils
Close the given one or more AutoCloseables.
closeCloseablesSilently(AutoCloseable...) - Static method in class io.delta.kernel.internal.util.Utils
Close the given list of AutoCloseable objects.
column(int) - Method in class io.delta.kernel.types.StructType
Creates a Column expression for the field at the given ordinal
Column - Class in io.delta.kernel.expressions
An expression type that refers to a column (case-sensitive) in the input.
Column(String) - Constructor for class io.delta.kernel.expressions.Column
Create a column expression for referring to a column.
Column(String[]) - Constructor for class io.delta.kernel.expressions.Column
Create a column expression to refer to a nested column.
COLUMN_MAPPING_ID_KEY - Static variable in class io.delta.kernel.internal.util.ColumnMapping
 
COLUMN_MAPPING_MODE_ID - Static variable in class io.delta.kernel.internal.util.ColumnMapping
 
COLUMN_MAPPING_MODE_KEY - Static variable in class io.delta.kernel.internal.util.ColumnMapping
 
COLUMN_MAPPING_MODE_NAME - Static variable in class io.delta.kernel.internal.util.ColumnMapping
 
COLUMN_MAPPING_MODE_NONE - Static variable in class io.delta.kernel.internal.util.ColumnMapping
 
COLUMN_MAPPING_PHYSICAL_NAME_KEY - Static variable in class io.delta.kernel.internal.util.ColumnMapping
 
ColumnarBatch - Interface in io.delta.kernel.data
Represents zero or more rows of records with same schema type.
ColumnarBatchRow - Class in io.delta.kernel.internal.data
Row abstraction around a columnar batch and a particular row within the columnar batch.
ColumnarBatchRow(ColumnarBatch, int) - Constructor for class io.delta.kernel.internal.data.ColumnarBatchRow
 
columnInvariantsNotSupported() - Static method in class io.delta.kernel.internal.DeltaErrors
 
ColumnMapping - Class in io.delta.kernel.internal.util
Utilities related to the column mapping feature.
ColumnVector - Interface in io.delta.kernel.data
Represents zero or more values of a single column.
combine(CloseableIterator<T>) - Method in interface io.delta.kernel.utils.CloseableIterator
Combine the current iterator with another iterator.
commit(Engine, CloseableIterable<Row>) - Method in class io.delta.kernel.internal.TransactionImpl
 
commit(Engine, CloseableIterable<Row>) - Method in interface io.delta.kernel.Transaction
COMMIT - Enum constant in enum io.delta.kernel.internal.replay.DeltaLogFile.LogType
 
CommitInfo - Class in io.delta.kernel.internal.actions
Delta log action representing a commit information action.
CommitInfo(long, String, String, Map<String, String>, boolean, String) - Constructor for class io.delta.kernel.internal.actions.CommitInfo
 
compareTo(CheckpointInstance) - Method in class io.delta.kernel.internal.checkpoints.CheckpointInstance
Comparison rules: 1.
compareTo(Path) - Method in class io.delta.kernel.internal.fs.Path
 
concurrentTransaction(String, long, long) - Static method in class io.delta.kernel.internal.DeltaErrors
 
ConcurrentTransactionException - Exception in io.delta.kernel.exceptions
Thrown when concurrent transaction both attempt to update the table with same transaction identifier set through TransactionBuilder.withTransactionId(Engine, String, long) (String)}.
ConcurrentTransactionException(String, long, long) - Constructor for exception io.delta.kernel.exceptions.ConcurrentTransactionException
 
ConcurrentWriteException - Exception in io.delta.kernel.exceptions
Thrown when a concurrent transaction has written data after the current transaction has started.
ConcurrentWriteException() - Constructor for exception io.delta.kernel.exceptions.ConcurrentWriteException
 
ConcurrentWriteException(String) - Constructor for exception io.delta.kernel.exceptions.ConcurrentWriteException
 
CONFLICT_RESOLUTION_SCHEMA - Static variable in class io.delta.kernel.internal.actions.SingleAction
Schema to use when reading the winning commit files for conflict resolution.
ConflictChecker - Class in io.delta.kernel.internal.replay
Class containing the conflict resolution logic when writing to a Delta table.
ConflictChecker.TransactionRebaseState - Class in io.delta.kernel.internal.replay
Class containing the rebase state from winning transactions that the current transaction needs to rebase against before attempting the commit.
constructDataSkippingFilter(Predicate, StructType) - Static method in class io.delta.kernel.internal.skipping.DataSkippingUtils
Constructs a data skipping filter to prune files using column statistics given a query data filter if possible.
contains(long) - Method in class io.delta.kernel.internal.deletionvectors.RoaringBitmapArray
Checks whether the value is included, which is equivalent to checking if the corresponding bit is set.
contains(String) - Method in class io.delta.kernel.types.FieldMetadata
 
containsAddOrRemoveFileActions(StructType) - Static method in class io.delta.kernel.internal.replay.LogReplay
 
containsNull() - Method in class io.delta.kernel.types.ArrayType
 
convertDataFileStatus(URI, DataFileStatus, Map<String, Literal>, boolean) - Static method in class io.delta.kernel.internal.actions.AddFile
Utility to generate `AddFile` row from the given DataFileStatus and partition values.
convertToPhysicalSchema(StructType, StructType, String) - Static method in class io.delta.kernel.internal.util.ColumnMapping
Helper method that converts the logical schema (requested by the connector) to physical schema of the data stored in data files based on the table's column mapping mode.
create(long...) - Static method in class io.delta.kernel.internal.deletionvectors.RoaringBitmapArray
 
CREATE_TABLE - Enum constant in enum io.delta.kernel.Operation
Recorded when the table is created.
createAddFileSingleAction(Row) - Static method in class io.delta.kernel.internal.actions.SingleAction
 
CreateCheckpointIterator - Class in io.delta.kernel.internal.replay
Replays a history of actions from the transaction log to reconstruct the checkpoint state of the table.
CreateCheckpointIterator(Engine, LogSegment, long) - Constructor for class io.delta.kernel.internal.replay.CreateCheckpointIterator
 
createCommitInfoSingleAction(Row) - Static method in class io.delta.kernel.internal.actions.SingleAction
 
createMetadataSingleAction(Row) - Static method in class io.delta.kernel.internal.actions.SingleAction
 
createPrimitive(String) - Static method in class io.delta.kernel.types.BasePrimitiveType
Create a primitive type DataType
createProtocolSingleAction(Row) - Static method in class io.delta.kernel.internal.actions.SingleAction
 
createRemoveFileSingleAction(Row) - Static method in class io.delta.kernel.internal.actions.SingleAction
 
createSelectionVector(boolean[], int, int) - Method in interface io.delta.kernel.engine.ExpressionHandler
Create a selection vector, a boolean type ColumnVector, on top of the range of values given in values array.
createTransactionBuilder(Engine, String, Operation) - Method in class io.delta.kernel.internal.TableImpl
 
createTransactionBuilder(Engine, String, Operation) - Method in interface io.delta.kernel.Table
Create a TransactionBuilder which can create a Transaction object to mutate the table.
createTxnSingleAction(Row) - Static method in class io.delta.kernel.internal.actions.SingleAction
 
CUR_DIR - Static variable in class io.delta.kernel.internal.fs.Path
The current directory, ".".

D

DataFileStatistics - Class in io.delta.kernel.utils
Statistics about data file in a Delta Lake table.
DataFileStatistics(long, Map<Column, Literal>, Map<Column, Literal>, Map<Column, Long>) - Constructor for class io.delta.kernel.utils.DataFileStatistics
Create a new instance of DataFileStatistics.
DataFileStatus - Class in io.delta.kernel.utils
Extends FileStatus to include additional details such as column level statistics of the data file in the Delta Lake table.
DataFileStatus(String, long, long, Optional<DataFileStatistics>) - Constructor for class io.delta.kernel.utils.DataFileStatus
Create a new instance of DataFileStatus.
dataSchemaMismatch(String, StructType, StructType) - Static method in class io.delta.kernel.internal.DeltaErrors
 
DataSkippingPredicate - Class in io.delta.kernel.internal.skipping
A Predicate with a set of columns referenced by the expression.
DataSkippingUtils - Class in io.delta.kernel.internal.skipping
 
DataSkippingUtils() - Constructor for class io.delta.kernel.internal.skipping.DataSkippingUtils
 
DataType - Class in io.delta.kernel.types
Base class for all data types.
DataType() - Constructor for class io.delta.kernel.types.DataType
 
DataWriteContext - Interface in io.delta.kernel
Contains the context for writing data to Delta table.
DataWriteContextImpl - Class in io.delta.kernel.internal
Implements the DataWriteContext interface.
DataWriteContextImpl(String, Map<String, Literal>, List<Column>) - Constructor for class io.delta.kernel.internal.DataWriteContextImpl
Creates a new instance of WriteContext.
DATE - Static variable in class io.delta.kernel.types.DateType
 
DateTimeConstants - Class in io.delta.kernel.internal.util
 
DateTimeConstants() - Constructor for class io.delta.kernel.internal.util.DateTimeConstants
 
DateType - Class in io.delta.kernel.types
A date type, supporting "0001-01-01" through "9999-12-31".
DAYS_PER_WEEK - Static variable in class io.delta.kernel.internal.util.DateTimeConstants
 
daysSinceEpoch(Date) - Static method in class io.delta.kernel.internal.util.InternalUtils
Utility method to get the number of days since epoch this given date is.
DecimalType - Class in io.delta.kernel.types
The data type representing java.math.BigDecimal values.
DecimalType(int, int) - Constructor for class io.delta.kernel.types.DecimalType
 
DECODE_MAP - Static variable in class io.delta.kernel.internal.deletionvectors.Base85Codec
 
decodeAlignedBytes(String) - Static method in class io.delta.kernel.internal.deletionvectors.Base85Codec
Decode an arbitrary byte array.
decodeBytes(String, int) - Static method in class io.delta.kernel.internal.deletionvectors.Base85Codec
Decode an arbitrary byte array.
decodeUUID(String) - Static method in class io.delta.kernel.internal.deletionvectors.Base85Codec
Decode a 16 byte UUID.
DEFAULT_READ_VERSION - Static variable in class io.delta.kernel.internal.TransactionImpl
 
DEFAULT_WRITE_VERSION - Static variable in class io.delta.kernel.internal.TransactionImpl
 
DeletionVectorDescriptor - Class in io.delta.kernel.internal.actions
Information about a deletion vector attached to a file action.
DeletionVectorDescriptor(String, String, Optional<Integer>, int, long) - Constructor for class io.delta.kernel.internal.actions.DeletionVectorDescriptor
 
DeletionVectorStoredBitmap - Class in io.delta.kernel.internal.deletionvectors
Bitmap for a Deletion Vector, implemented as a thin wrapper around a Deletion Vector Descriptor.
DeletionVectorStoredBitmap(DeletionVectorDescriptor, Optional<String>) - Constructor for class io.delta.kernel.internal.deletionvectors.DeletionVectorStoredBitmap
 
DeletionVectorUtils - Class in io.delta.kernel.internal.deletionvectors
Utility methods regarding deletion vectors.
DeletionVectorUtils() - Constructor for class io.delta.kernel.internal.deletionvectors.DeletionVectorUtils
 
DeltaErrors - Class in io.delta.kernel.internal
Contains methods to create user-facing Delta exceptions.
deltaFile(Path, long) - Static method in class io.delta.kernel.internal.util.FileNames
Returns the delta (json format) path for a given delta file.
DeltaHistoryManager - Class in io.delta.kernel.internal
 
DeltaLogFile - Class in io.delta.kernel.internal.replay
Internal wrapper class holding information needed to perform log replay.
DeltaLogFile.LogType - Enum in io.delta.kernel.internal.replay
 
deltas - Variable in class io.delta.kernel.internal.snapshot.LogSegment
 
deltaVersion(Path) - Static method in class io.delta.kernel.internal.util.FileNames
Returns the version for the given delta path.
deltaVersion(String) - Static method in class io.delta.kernel.internal.util.FileNames
 
depth() - Method in class io.delta.kernel.internal.fs.Path
Returns the number of elements in this path.
deserializeStructType(String) - Method in interface io.delta.kernel.engine.JsonHandler
Deserialize the Delta schema from structTypeJson according to the Delta Protocol schema serialization rules .
DOUBLE - Static variable in class io.delta.kernel.types.DoubleType
 
DoubleType - Class in io.delta.kernel.types
The data type representing double type values.
duplicateColumnsInSchema(StructType, List<String>) - Static method in class io.delta.kernel.internal.DeltaErrors
 

E

empty() - Static method in class io.delta.kernel.types.FieldMetadata
 
empty(Path) - Static method in class io.delta.kernel.internal.snapshot.LogSegment
 
emptyIterable() - Static method in interface io.delta.kernel.utils.CloseableIterable
Return an CloseableIterable object for an empty collection.
ENCODE_MAP - Static variable in class io.delta.kernel.internal.deletionvectors.Base85Codec
 
encodeBytes(byte[]) - Static method in class io.delta.kernel.internal.deletionvectors.Base85Codec
Encode an arbitrary byte array.
ENCODED_UUID_LENGTH - Static variable in class io.delta.kernel.internal.deletionvectors.Base85Codec
 
encodeUUID(UUID) - Static method in class io.delta.kernel.internal.deletionvectors.Base85Codec
Encode a 16 byte UUID.
Engine - Interface in io.delta.kernel.engine
Interface encapsulating all clients needed by the Delta Kernel in order to read the Delta table.
equals(Object) - Method in class io.delta.kernel.expressions.Column
 
equals(Object) - Method in class io.delta.kernel.internal.actions.DeletionVectorDescriptor
 
equals(Object) - Method in class io.delta.kernel.internal.checkpoints.CheckpointInstance
 
equals(Object) - Method in class io.delta.kernel.internal.fs.Path
 
equals(Object) - Method in class io.delta.kernel.internal.util.Tuple2
 
equals(Object) - Method in class io.delta.kernel.types.ArrayType
 
equals(Object) - Method in class io.delta.kernel.types.BasePrimitiveType
 
equals(Object) - Method in class io.delta.kernel.types.DataType
 
equals(Object) - Method in class io.delta.kernel.types.DecimalType
 
equals(Object) - Method in class io.delta.kernel.types.FieldMetadata
 
equals(Object) - Method in class io.delta.kernel.types.MapType
 
equals(Object) - Method in class io.delta.kernel.types.StructField
 
equals(Object) - Method in class io.delta.kernel.types.StructType
 
equivalent(DataType) - Method in class io.delta.kernel.types.ArrayType
 
equivalent(DataType) - Method in class io.delta.kernel.types.DataType
Are the data types same? The metadata or column names could be different.
equivalent(DataType) - Method in class io.delta.kernel.types.MapType
 
equivalent(DataType) - Method in class io.delta.kernel.types.StructType
 
eval(ColumnarBatch) - Method in interface io.delta.kernel.expressions.ExpressionEvaluator
Evaluate the expression on given ColumnarBatch data.
eval(ColumnarBatch, Optional<ColumnVector>) - Method in interface io.delta.kernel.expressions.PredicateEvaluator
Evaluate the predicate on given inputData.
Evolving - Annotation Type in io.delta.kernel.annotation
APIs that are meant to evolve towards becoming stable APIs, but are not stable APIs yet.
Expression - Interface in io.delta.kernel.expressions
Base interface for all Kernel expressions.
ExpressionEvaluator - Interface in io.delta.kernel.expressions
Interface for implementing an Expression evaluator.
ExpressionHandler - Interface in io.delta.kernel.engine
Provides expression evaluation capability to Delta Kernel.
ExpressionUtils - Class in io.delta.kernel.internal.util
 
ExpressionUtils() - Constructor for class io.delta.kernel.internal.util.ExpressionUtils
 

F

FieldMetadata - Class in io.delta.kernel.types
The metadata for a given StructField.
FieldMetadata.Builder - Class in io.delta.kernel.types
Builder class for FieldMetadata.
fieldNames() - Method in class io.delta.kernel.types.StructType
 
fields() - Method in class io.delta.kernel.types.StructType
 
FileNames - Class in io.delta.kernel.internal.util
 
filePath - Variable in class io.delta.kernel.internal.checkpoints.CheckpointInstance
 
FileReadRequest - Interface in io.delta.kernel.engine
Represents a request to read a range of bytes from a given file.
FileStatus - Class in io.delta.kernel.utils
Class for encapsulating metadata about a file in Delta Lake table.
FileSystemClient - Interface in io.delta.kernel.engine
Provides file system related functionalities to Delta Kernel.
filter(Function<T, Boolean>) - Method in interface io.delta.kernel.utils.CloseableIterator
 
FilteredColumnarBatch - Class in io.delta.kernel.data
Represents a filtered version of ColumnarBatch.
FilteredColumnarBatch(ColumnarBatch, Optional<ColumnVector>) - Constructor for class io.delta.kernel.data.FilteredColumnarBatch
 
findColIndex(StructType, String) - Static method in class io.delta.kernel.internal.util.SchemaUtils
Search (case-insensitive) for the given colName in the schema and return its position in the schema.
findLastCompleteCheckpointBefore(Engine, Path, long) - Static method in class io.delta.kernel.internal.checkpoints.Checkpointer
Find the last complete checkpoint before (strictly less than) a given version.
FLOAT - Static variable in class io.delta.kernel.types.FloatType
 
FloatType - Class in io.delta.kernel.types
The data type representing float type values.
forCommitOrCheckpoint(FileStatus) - Static method in class io.delta.kernel.internal.replay.DeltaLogFile
 
forEach(Consumer<? super T>) - Method in interface io.delta.kernel.utils.CloseableIterable
 
format - Variable in class io.delta.kernel.internal.checkpoints.CheckpointInstance
 
Format - Class in io.delta.kernel.internal.actions
 
Format() - Constructor for class io.delta.kernel.internal.actions.Format
 
Format(String, Map<String, String>) - Constructor for class io.delta.kernel.internal.actions.Format
 
forPath(Engine, String) - Static method in class io.delta.kernel.internal.TableImpl
 
forPath(Engine, String) - Static method in interface io.delta.kernel.Table
Instantiate a table object for the Delta Lake table at the given path.
fromColumnVector(ColumnVector, int) - Static method in class io.delta.kernel.internal.actions.DeletionVectorDescriptor
 
fromColumnVector(ColumnVector, int) - Static method in class io.delta.kernel.internal.actions.Format
 
fromColumnVector(ColumnVector, int) - Static method in class io.delta.kernel.internal.actions.Protocol
 
fromColumnVector(ColumnVector, int) - Static method in class io.delta.kernel.internal.actions.SetTransaction
 
fromColumnVector(ColumnVector, int) - Static method in class io.delta.kernel.internal.checkpoints.SidecarFile
 
fromColumnVector(ColumnVector, int, Engine) - Static method in class io.delta.kernel.internal.actions.Metadata
 
fromMetadata(Metadata) - Method in class io.delta.kernel.internal.TableConfig
Returns the value of the table property from the given metadata.
fromRow(Row) - Static method in class io.delta.kernel.internal.actions.DeletionVectorDescriptor
 
fromRow(Row) - Static method in class io.delta.kernel.internal.checkpoints.CheckpointMetaData
 
fromStructVector(ColumnVector, int) - Static method in class io.delta.kernel.internal.data.StructRow
 
FULL_SCHEMA - Static variable in class io.delta.kernel.internal.actions.AddFile
Full schema of the add action in the Delta Log.
FULL_SCHEMA - Static variable in class io.delta.kernel.internal.actions.CommitInfo
 
FULL_SCHEMA - Static variable in class io.delta.kernel.internal.actions.Format
 
FULL_SCHEMA - Static variable in class io.delta.kernel.internal.actions.Metadata
 
FULL_SCHEMA - Static variable in class io.delta.kernel.internal.actions.Protocol
 
FULL_SCHEMA - Static variable in class io.delta.kernel.internal.actions.RemoveFile
Full schema of the remove action in the Delta Log.
FULL_SCHEMA - Static variable in class io.delta.kernel.internal.actions.SetTransaction
 
FULL_SCHEMA - Static variable in class io.delta.kernel.internal.actions.SingleAction
 

G

generateAppendActions(Engine, Row, CloseableIterator<DataFileStatus>, DataWriteContext) - Static method in interface io.delta.kernel.Transaction
For given data files, generate Delta actions that can be committed in a transaction.
generateScanFileRow(FileStatus) - Static method in class io.delta.kernel.internal.InternalScanFileUtils
Create a scan file row conforming to the schema InternalScanFileUtils.SCAN_FILE_SCHEMA for given file status.
GenericRow - Class in io.delta.kernel.internal.data
Exposes a given map of values as a Row
GenericRow(StructType, Map<Integer, Object>) - Constructor for class io.delta.kernel.internal.data.GenericRow
 
get() - Method in class io.delta.kernel.internal.lang.Lazy
 
get(String) - Method in class io.delta.kernel.types.FieldMetadata
 
get(String) - Method in class io.delta.kernel.types.StructType
 
getAbsolutePath(String) - Method in class io.delta.kernel.internal.actions.DeletionVectorDescriptor
 
getActiveCommitAtTimestamp(Engine, Path, long) - Static method in class io.delta.kernel.internal.DeltaHistoryManager
Returns the latest recreatable commit that happened at or before timestamp.
getAddFilesAsColumnarBatches(Engine, boolean, Optional<Predicate>) - Method in class io.delta.kernel.internal.replay.LogReplay
Returns an iterator of FilteredColumnarBatch representing all the active AddFiles in the table.
getAddFileStatus(Row) - Static method in class io.delta.kernel.internal.InternalScanFileUtils
Get the FileStatus of AddFile from given scan file Row.
getAddRemoveReadSchema(boolean) - Static method in class io.delta.kernel.internal.replay.LogReplay
Read schema when searching for all the active AddFiles
getAllPrimitiveTypes() - Static method in class io.delta.kernel.types.BasePrimitiveType
For testing only
getAppId() - Method in class io.delta.kernel.internal.actions.SetTransaction
 
getArray(int) - Method in interface io.delta.kernel.data.ColumnVector
Return the array value located at rowId.
getArray(int) - Method in interface io.delta.kernel.data.Row
Return array value of the column located at the given ordinal.
getArray(int) - Method in class io.delta.kernel.internal.data.ChildVectorBasedRow
 
getArray(int) - Method in class io.delta.kernel.internal.data.GenericRow
 
getBinary(int) - Method in interface io.delta.kernel.data.ColumnVector
Returns the binary type value for rowId.
getBinary(int) - Method in interface io.delta.kernel.data.Row
Return binary value of the column located at the given ordinal.
getBinary(int) - Method in class io.delta.kernel.internal.data.ChildVectorBasedRow
 
getBinary(int) - Method in class io.delta.kernel.internal.data.GenericRow
 
getBoolean(int) - Method in interface io.delta.kernel.data.ColumnVector
Returns the boolean type value for rowId.
getBoolean(int) - Method in interface io.delta.kernel.data.Row
Return boolean value of the column located at the given ordinal.
getBoolean(int) - Method in class io.delta.kernel.internal.data.ChildVectorBasedRow
 
getBoolean(int) - Method in class io.delta.kernel.internal.data.GenericRow
 
getBoolean(int) - Method in class io.delta.kernel.internal.data.SelectionColumnVector
 
getByte(int) - Method in interface io.delta.kernel.data.ColumnVector
Returns the byte type value for rowId.
getByte(int) - Method in interface io.delta.kernel.data.Row
Return byte value of the column located at the given ordinal.
getByte(int) - Method in class io.delta.kernel.internal.data.ChildVectorBasedRow
 
getByte(int) - Method in class io.delta.kernel.internal.data.GenericRow
 
getCardinality() - Method in class io.delta.kernel.internal.actions.DeletionVectorDescriptor
 
getChild(int) - Method in interface io.delta.kernel.data.ColumnVector
Get the child vector associated with the given ordinal.
getChildren() - Method in class io.delta.kernel.expressions.Column
 
getChildren() - Method in interface io.delta.kernel.expressions.Expression
 
getChildren() - Method in class io.delta.kernel.expressions.Literal
 
getChildren() - Method in class io.delta.kernel.expressions.PartitionValueExpression
 
getChildren() - Method in class io.delta.kernel.expressions.ScalarExpression
 
getColumnMappingMode(Row) - Static method in class io.delta.kernel.internal.data.ScanStateRow
Get the column mapping mode from the scan state Row returned by Scan.getScanState(Engine).
getColumnMappingMode(Map<String, String>) - Static method in class io.delta.kernel.internal.util.ColumnMapping
Returns the column mapping mode from the given configuration.
getColumnVector(int) - Method in interface io.delta.kernel.data.ColumnarBatch
Return the ColumnVector for the given ordinal in the columnar batch.
getConfiguration() - Method in class io.delta.kernel.internal.actions.Metadata
 
getConfigurationMapValue() - Method in class io.delta.kernel.internal.actions.Metadata
 
getCorrespondingFiles(Path) - Method in class io.delta.kernel.internal.checkpoints.CheckpointInstance
 
getCreateCheckpointIterator(Engine) - Method in class io.delta.kernel.internal.SnapshotImpl
 
getCreatedTime() - Method in class io.delta.kernel.internal.actions.Metadata
 
getData() - Method in class io.delta.kernel.data.FilteredColumnarBatch
Return the data as ColumnarBatch.
getDataPath() - Method in class io.delta.kernel.internal.SnapshotImpl
 
getDataSchema() - Method in class io.delta.kernel.internal.actions.Metadata
The logical data schema which excludes partition columns
getDataType() - Method in interface io.delta.kernel.data.ColumnVector
 
getDataType() - Method in class io.delta.kernel.expressions.Literal
Get the datatype of the literal object.
getDataType() - Method in class io.delta.kernel.expressions.PartitionValueExpression
Get the data type of the partition value.
getDataType() - Method in class io.delta.kernel.internal.data.SelectionColumnVector
 
getDataType() - Method in class io.delta.kernel.types.StructField
 
getDecimal(int) - Method in interface io.delta.kernel.data.ColumnVector
Returns the decimal type value for rowId.
getDecimal(int) - Method in interface io.delta.kernel.data.Row
Return decimal value of the column located at the given ordinal.
getDecimal(int) - Method in class io.delta.kernel.internal.data.ChildVectorBasedRow
 
getDecimal(int) - Method in class io.delta.kernel.internal.data.GenericRow
 
getDeletionVectorDescriptorFromRow(Row) - Static method in class io.delta.kernel.internal.InternalScanFileUtils
Create a DeletionVectorDescriptor from add entry in the given scan file row.
getDescription() - Method in class io.delta.kernel.internal.actions.Metadata
 
getDescription() - Method in enum io.delta.kernel.Operation
Returns the string that will be recorded in the transaction log.
getDouble(int) - Method in interface io.delta.kernel.data.ColumnVector
Returns the double type value for rowId.
getDouble(int) - Method in interface io.delta.kernel.data.Row
Return double value of the column located at the given ordinal.
getDouble(int) - Method in class io.delta.kernel.internal.data.ChildVectorBasedRow
 
getDouble(int) - Method in class io.delta.kernel.internal.data.GenericRow
 
getEarliestRecreatableCommit(Engine, Path) - Static method in class io.delta.kernel.internal.DeltaHistoryManager
Gets the earliest commit that we can recreate.
getElements() - Method in interface io.delta.kernel.data.ArrayValue
A ColumnVector containing the array elements with exactly ArrayValue.getSize() elements.
getElementType() - Method in class io.delta.kernel.types.ArrayType
 
getEngineInfo() - Method in class io.delta.kernel.internal.actions.CommitInfo
 
getEntries() - Method in class io.delta.kernel.types.FieldMetadata
 
getEvaluator(StructType, Expression, DataType) - Method in interface io.delta.kernel.engine.ExpressionHandler
Create an ExpressionEvaluator that can evaluate the given expression on ColumnarBatchs with the given batchSchema.
getExpressionHandler() - Method in interface io.delta.kernel.engine.Engine
Get the connector provided ExpressionHandler.
getFile() - Method in class io.delta.kernel.internal.replay.DeltaLogFile
 
getFileSystemClient() - Method in interface io.delta.kernel.engine.Engine
Get the connector provided FileSystemClient.
getFileVersion(Path) - Static method in class io.delta.kernel.internal.util.FileNames
Get the version of the checkpoint, checksum or delta file.
getFloat(int) - Method in interface io.delta.kernel.data.ColumnVector
Returns the float type value for rowId.
getFloat(int) - Method in interface io.delta.kernel.data.Row
Return float value of the column located at the given ordinal.
getFloat(int) - Method in class io.delta.kernel.internal.data.ChildVectorBasedRow
 
getFloat(int) - Method in class io.delta.kernel.internal.data.GenericRow
 
getFormat() - Method in class io.delta.kernel.internal.actions.Metadata
 
getId() - Method in class io.delta.kernel.internal.actions.Metadata
 
getInput() - Method in class io.delta.kernel.expressions.PartitionValueExpression
Get the expression reference to the serialized partition value.
getInt(int) - Method in interface io.delta.kernel.data.ColumnVector
Returns the int type value for rowId.
getInt(int) - Method in interface io.delta.kernel.data.Row
Return integer value of the column located at the given ordinal.
getInt(int) - Method in class io.delta.kernel.internal.data.ChildVectorBasedRow
 
getInt(int) - Method in class io.delta.kernel.internal.data.GenericRow
 
getJsonHandler() - Method in interface io.delta.kernel.engine.Engine
Get the connector provided JsonHandler.
getKeys() - Method in interface io.delta.kernel.data.MapValue
A ColumnVector containing the keys.
getKeyType() - Method in class io.delta.kernel.types.MapType
 
getLastUpdated() - Method in class io.delta.kernel.internal.actions.SetTransaction
 
getLatestCompleteCheckpointFromList(List<CheckpointInstance>, CheckpointInstance) - Static method in class io.delta.kernel.internal.checkpoints.Checkpointer
Given a list of checkpoint files, pick the latest complete checkpoint instance which is not later than `notLaterThan`.
getLatestSnapshot(Engine) - Method in class io.delta.kernel.internal.TableImpl
 
getLatestSnapshot(Engine) - Method in interface io.delta.kernel.Table
Get the latest snapshot of the table.
getLatestTransactionIdentifier(Engine, String) - Method in class io.delta.kernel.internal.replay.LogReplay
 
getLatestTransactionVersion(Engine, String) - Method in class io.delta.kernel.internal.SnapshotImpl
Get the latest transaction version for given applicationId.
getLatestVersion() - Method in class io.delta.kernel.internal.replay.ConflictChecker.TransactionRebaseState
Return the latest winning version of the table.
getLeft() - Method in class io.delta.kernel.expressions.And
 
getLeft() - Method in class io.delta.kernel.expressions.Or
 
getLeft(Expression) - Static method in class io.delta.kernel.internal.util.ExpressionUtils
Utility method to return the left child of the binary input expression
getLogicalSchema(Engine, Row) - Static method in class io.delta.kernel.internal.data.ScanStateRow
Utility method to get the logical schema from the scan state Row returned by Scan.getScanState(Engine).
getLogicalSchema(Engine, Row) - Static method in class io.delta.kernel.internal.data.TransactionStateRow
Get the logical schema of the table from the transaction state Row returned by Transaction.getTransactionState(Engine)}
getLogPath() - Method in class io.delta.kernel.internal.SnapshotImpl
 
getLogSegment() - Method in class io.delta.kernel.internal.SnapshotImpl
 
getLogSegmentForVersion(Engine, Optional<Long>, Optional<Long>) - Method in class io.delta.kernel.internal.snapshot.SnapshotManager
Get a list of files that can be used to compute a Snapshot at version `versionToLoad`, If `versionToLoad` is not provided, will generate the list of files that are needed to load the latest version of the Delta table.
getLogType() - Method in class io.delta.kernel.internal.replay.DeltaLogFile
 
getLong(int) - Method in interface io.delta.kernel.data.ColumnVector
Returns the long type value for rowId.
getLong(int) - Method in interface io.delta.kernel.data.Row
Return long value of the column located at the given ordinal.
getLong(int) - Method in class io.delta.kernel.internal.data.ChildVectorBasedRow
 
getLong(int) - Method in class io.delta.kernel.internal.data.GenericRow
 
getMap(int) - Method in interface io.delta.kernel.data.ColumnVector
Return the map value located at rowId.
getMap(int) - Method in interface io.delta.kernel.data.Row
Return map value of the column located at the given ordinal.
getMap(int) - Method in class io.delta.kernel.internal.data.ChildVectorBasedRow
 
getMap(int) - Method in class io.delta.kernel.internal.data.GenericRow
 
getMaxColumn(Column) - Method in class io.delta.kernel.internal.skipping.StatsSchemaHelper
Given a logical column in the data schema provided when creating this, return the corresponding MAX column in the statistic schema that stores the MAX values for the provided logical column.
getMaxValues() - Method in class io.delta.kernel.utils.DataFileStatistics
Get the maximum values of the columns in the data file.
getMessage() - Method in exception io.delta.kernel.exceptions.TableAlreadyExistsException
 
getMetadata() - Method in class io.delta.kernel.internal.replay.LogReplay
 
getMetadata() - Method in class io.delta.kernel.internal.snapshot.SnapshotHint
 
getMetadata() - Method in class io.delta.kernel.internal.SnapshotImpl
 
getMetadata() - Method in class io.delta.kernel.types.StructField
 
getMinColumn(Column) - Method in class io.delta.kernel.internal.skipping.StatsSchemaHelper
Given a logical column in the data schema provided when creating this, return the corresponding MIN column in the statistic schema that stores the MIN values for the provided logical column.
getMinReaderVersion() - Method in class io.delta.kernel.internal.actions.Protocol
 
getMinValues() - Method in class io.delta.kernel.utils.DataFileStatistics
Get the minimum values of the columns in the data file.
getMinWriterVersion() - Method in class io.delta.kernel.internal.actions.Protocol
 
getModificationTime() - Method in class io.delta.kernel.internal.checkpoints.SidecarFile
 
getModificationTime() - Method in class io.delta.kernel.utils.FileStatus
Get the modification time of the file in epoch millis.
getName() - Method in class io.delta.kernel.expressions.ScalarExpression
 
getName() - Method in class io.delta.kernel.internal.actions.Metadata
 
getName() - Method in class io.delta.kernel.internal.fs.Path
Returns the final component of this path.
getName() - Method in class io.delta.kernel.types.StructField
 
getName(String) - Static method in class io.delta.kernel.internal.fs.Path
 
getNames() - Method in class io.delta.kernel.expressions.Column
 
getNullCountColumn(Column) - Method in class io.delta.kernel.internal.skipping.StatsSchemaHelper
Given a logical column in the data schema provided when creating this, return the corresponding NULL_COUNT column in the statistic schema that stores the null count values for the provided logical column.
getNullCounts() - Method in class io.delta.kernel.utils.DataFileStatistics
Get the number of nulls of columns in the data file.
getNumberOfAddActions() - Method in class io.delta.kernel.internal.replay.CreateCheckpointIterator
Number of add files in the final checkpoint.
getNumRecords() - Method in class io.delta.kernel.utils.DataFileStatistics
Get the number of records in the data file.
getNumRecordsColumn() - Method in class io.delta.kernel.internal.skipping.StatsSchemaHelper
Returns the NUM_RECORDS column in the statistic schema
getOffset() - Method in class io.delta.kernel.internal.actions.DeletionVectorDescriptor
 
getOperation() - Method in class io.delta.kernel.internal.actions.CommitInfo
 
getOptions() - Method in class io.delta.kernel.internal.actions.Format
 
getParent() - Method in class io.delta.kernel.internal.fs.Path
Returns the parent of a path or null if at root.
getParquetHandler() - Method in interface io.delta.kernel.engine.Engine
Get the connector provided ParquetHandler.
getPartitionColNames() - Method in class io.delta.kernel.internal.actions.Metadata
Set of lowercase partition column names
getPartitionColumns() - Method in class io.delta.kernel.internal.actions.Metadata
 
getPartitionColumns(Row) - Static method in class io.delta.kernel.internal.data.ScanStateRow
Get the list of partition column names from the scan state Row returned by Scan.getScanState(Engine).
getPartitionColumns(Engine) - Method in class io.delta.kernel.internal.TransactionImpl
 
getPartitionColumns(Engine) - Method in interface io.delta.kernel.Transaction
Get the list of logical names of the partition columns.
getPartitionColumnsList(Row) - Static method in class io.delta.kernel.internal.data.TransactionStateRow
Get the list of partition column names from the write state Row returned by Transaction.getTransactionState(Engine)
getPartitionValues() - Method in class io.delta.kernel.internal.DataWriteContextImpl
Returns the partition values for the data to be written.
getPartitionValues(Row) - Static method in class io.delta.kernel.internal.InternalScanFileUtils
Get the partition columns and values belonging to the AddFile from given scan file row.
getPartitionValuesParsedRefInAddFile(String) - Static method in class io.delta.kernel.internal.InternalScanFileUtils
Get a references column for given partition column name in partitionValues_parsed column in scan file row.
getPath() - Method in interface io.delta.kernel.engine.FileReadRequest
Get the fully qualified path of the file from which to read the data.
getPath() - Method in class io.delta.kernel.internal.checkpoints.SidecarFile
 
getPath() - Method in class io.delta.kernel.utils.FileStatus
Get the path to the file.
getPath(Engine) - Method in class io.delta.kernel.internal.TableImpl
 
getPath(Engine) - Method in interface io.delta.kernel.Table
The fully qualified path of this Table instance.
getPathOrInlineDv() - Method in class io.delta.kernel.internal.actions.DeletionVectorDescriptor
 
getPathWithoutSchemeAndAuthority(Path) - Static method in class io.delta.kernel.internal.fs.Path
Return a version of the given Path without the scheme information.
getPhysicalDataReadSchema(Engine, Row) - Static method in class io.delta.kernel.internal.data.ScanStateRow
Utility method to get the physical data read schema from the scan state Row returned by Scan.getScanState(Engine).
getPhysicalName(StructField) - Static method in class io.delta.kernel.internal.util.ColumnMapping
Returns the physical name for a given StructField
getPhysicalSchema(Engine, Row) - Static method in class io.delta.kernel.internal.data.ScanStateRow
Utility method to get the physical schema from the scan state Row returned by Scan.getScanState(Engine).
getPrecision() - Method in class io.delta.kernel.types.DecimalType
 
getPredicateEvaluator(StructType, Predicate) - Method in interface io.delta.kernel.engine.ExpressionHandler
Create a PredicateEvaluator that can evaluate the given predicate expression and return a selection vector (ColumnVector of boolean type).
getProtocol() - Method in class io.delta.kernel.internal.replay.LogReplay
 
getProtocol() - Method in class io.delta.kernel.internal.snapshot.SnapshotHint
 
getProtocol() - Method in class io.delta.kernel.internal.SnapshotImpl
 
getProvider() - Method in class io.delta.kernel.internal.actions.Format
 
getReaderFeatures() - Method in class io.delta.kernel.internal.actions.Protocol
 
getReadLength() - Method in interface io.delta.kernel.engine.FileReadRequest
Get the length of the data to read from the file starting at the startOffset.
getReferencedCols() - Method in class io.delta.kernel.internal.skipping.DataSkippingPredicate
 
getRemainingFilter() - Method in class io.delta.kernel.internal.ScanImpl
 
getRemainingFilter() - Method in interface io.delta.kernel.Scan
Get the remaining filter that is not guaranteed to be satisfied for the data Delta Kernel returns.
getRight() - Method in class io.delta.kernel.expressions.And
 
getRight() - Method in class io.delta.kernel.expressions.Or
 
getRight(Expression) - Static method in class io.delta.kernel.internal.util.ExpressionUtils
Utility method to return the right child of the binary input expression
getRows() - Method in interface io.delta.kernel.data.ColumnarBatch
 
getRows() - Method in class io.delta.kernel.data.FilteredColumnarBatch
Iterator of rows that survived the filter.
getScale() - Method in class io.delta.kernel.types.DecimalType
 
getScanBuilder(Engine) - Method in class io.delta.kernel.internal.SnapshotImpl
 
getScanBuilder(Engine) - Method in interface io.delta.kernel.Snapshot
Create a scan builder to construct a Scan to read data from this snapshot.
getScanFiles(Engine) - Method in class io.delta.kernel.internal.ScanImpl
Get an iterator of data files in this version of scan that survived the predicate pruning.
getScanFiles(Engine) - Method in interface io.delta.kernel.Scan
Get an iterator of data files to scan.
getScanFiles(Engine, boolean) - Method in class io.delta.kernel.internal.ScanImpl
Get an iterator of data files in this version of scan that survived the predicate pruning.
getScanState(Engine) - Method in class io.delta.kernel.internal.ScanImpl
 
getScanState(Engine) - Method in interface io.delta.kernel.Scan
Get the scan state associated with the current scan.
getSchema() - Method in interface io.delta.kernel.data.ColumnarBatch
 
getSchema() - Method in interface io.delta.kernel.data.Row
 
getSchema() - Method in class io.delta.kernel.internal.actions.Metadata
 
getSchema() - Method in class io.delta.kernel.internal.data.ChildVectorBasedRow
 
getSchema() - Method in class io.delta.kernel.internal.data.GenericRow
 
getSchema(Engine) - Method in class io.delta.kernel.internal.SnapshotImpl
 
getSchema(Engine) - Method in class io.delta.kernel.internal.TransactionImpl
 
getSchema(Engine) - Method in interface io.delta.kernel.Snapshot
Get the schema of the table at this snapshot.
getSchema(Engine) - Method in interface io.delta.kernel.Transaction
Get the schema of the table.
getSchemaString() - Method in class io.delta.kernel.internal.actions.Metadata
 
getSelectionVector() - Method in class io.delta.kernel.data.FilteredColumnarBatch
Optional selection vector containing one entry for each row in data indicating whether a row is selected or not selected.
getSetTxnOpt() - Method in class io.delta.kernel.internal.TransactionImpl
 
getShort(int) - Method in interface io.delta.kernel.data.ColumnVector
Returns the short type value for rowId.
getShort(int) - Method in interface io.delta.kernel.data.Row
Return short value of the column located at the given ordinal.
getShort(int) - Method in class io.delta.kernel.internal.data.ChildVectorBasedRow
 
getShort(int) - Method in class io.delta.kernel.internal.data.GenericRow
 
getSingularElement(CloseableIterator<T>) - Static method in class io.delta.kernel.internal.util.InternalUtils
Utility method to read at most one element from a CloseableIterator.
getSingularRow(CloseableIterator<ColumnarBatch>) - Static method in class io.delta.kernel.internal.util.InternalUtils
Utility method to read at most one row from the given data ColumnarBatch iterator.
getSize() - Method in interface io.delta.kernel.data.ArrayValue
The number of elements in the array
getSize() - Method in interface io.delta.kernel.data.ColumnarBatch
 
getSize() - Method in interface io.delta.kernel.data.ColumnVector
 
getSize() - Method in interface io.delta.kernel.data.MapValue
The number of elements in the map
getSize() - Method in class io.delta.kernel.internal.data.SelectionColumnVector
 
getSize() - Method in class io.delta.kernel.utils.FileStatus
Get the size of the file in bytes.
getSizeInBytes() - Method in class io.delta.kernel.internal.actions.DeletionVectorDescriptor
 
getSizeInBytes() - Method in class io.delta.kernel.internal.checkpoints.SidecarFile
 
getSnapshotAsOfTimestamp(Engine, long) - Method in class io.delta.kernel.internal.TableImpl
 
getSnapshotAsOfTimestamp(Engine, long) - Method in interface io.delta.kernel.Table
Get the snapshot of the table at the given timestamp.
getSnapshotAsOfVersion(Engine, long) - Method in class io.delta.kernel.internal.TableImpl
 
getSnapshotAsOfVersion(Engine, long) - Method in interface io.delta.kernel.Table
Get the snapshot at the given versionId.
getSnapshotAt(Engine, long) - Method in class io.delta.kernel.internal.snapshot.SnapshotManager
Construct the snapshot for the given table at the version provided.
getSnapshotForTimestamp(Engine, long) - Method in class io.delta.kernel.internal.snapshot.SnapshotManager
Construct the snapshot for the given table at the provided timestamp.
getStartOffset() - Method in interface io.delta.kernel.engine.FileReadRequest
Get the start offset in the file from where to start reading the data.
getStatistics() - Method in class io.delta.kernel.utils.DataFileStatus
Get the statistics of the data file encapsulated in this object.
getStatisticsColumns() - Method in interface io.delta.kernel.DataWriteContext
Returns the list of Column that the connector can optionally collect statistics.
getStatisticsColumns() - Method in class io.delta.kernel.internal.DataWriteContextImpl
Returns the list of Column that the connector can optionally collect statistics.
getStatisticsColumns(Engine, Row) - Static method in class io.delta.kernel.internal.TransactionImpl
Get the part of the schema of the table that needs the statistics to be collected per file.
getStatsSchema(StructType) - Static method in class io.delta.kernel.internal.skipping.StatsSchemaHelper
Returns the expected statistics schema given a table schema.
getStorageType() - Method in class io.delta.kernel.internal.actions.DeletionVectorDescriptor
 
getString(int) - Method in interface io.delta.kernel.data.ColumnVector
Returns the string type value for rowId.
getString(int) - Method in interface io.delta.kernel.data.Row
Return string value of the column located at the given ordinal.
getString(int) - Method in class io.delta.kernel.internal.data.ChildVectorBasedRow
 
getString(int) - Method in class io.delta.kernel.internal.data.GenericRow
 
getStruct(int) - Method in interface io.delta.kernel.data.Row
Return struct value of the column located at the given ordinal.
getStruct(int) - Method in class io.delta.kernel.internal.data.ChildVectorBasedRow
 
getStruct(int) - Method in class io.delta.kernel.internal.data.GenericRow
 
getTablePath() - Method in exception io.delta.kernel.exceptions.TableNotFoundException
 
getTablePath(Row) - Static method in class io.delta.kernel.internal.data.TransactionStateRow
Get the table path from scan state Row returned by Transaction.getTransactionState(Engine)
getTableRoot(Row) - Static method in class io.delta.kernel.internal.data.ScanStateRow
Get the table root from scan state Row returned by Scan.getScanState(Engine)
getTargetDirectory() - Method in interface io.delta.kernel.DataWriteContext
Returns the target directory where the data should be written.
getTargetDirectory() - Method in class io.delta.kernel.internal.DataWriteContextImpl
Returns the target directory where the data should be written.
getTargetDirectory(String, List<String>, Map<String, Literal>) - Static method in class io.delta.kernel.internal.util.PartitionUtils
Get the target directory for writing data for given partition values.
getTimestamp() - Method in class io.delta.kernel.internal.actions.CommitInfo
 
getTransactionState(Engine) - Method in class io.delta.kernel.internal.TransactionImpl
 
getTransactionState(Engine) - Method in interface io.delta.kernel.Transaction
Get the state of the transaction.
getUnaryChild(Expression) - Static method in class io.delta.kernel.internal.util.ExpressionUtils
Utility method to return the single child of the unary input expression
getUniqueFileAction(ColumnVector, ColumnVector, int) - Static method in class io.delta.kernel.internal.replay.LogReplayUtils
 
getUniqueId() - Method in class io.delta.kernel.internal.actions.DeletionVectorDescriptor
 
getValue() - Method in class io.delta.kernel.expressions.Literal
Get the literal value.
getValues() - Method in interface io.delta.kernel.data.MapValue
A ColumnVector containing the values.
getValueType() - Method in class io.delta.kernel.types.MapType
 
getVersion() - Method in class io.delta.kernel.internal.actions.SetTransaction
 
getVersion() - Method in class io.delta.kernel.internal.replay.DeltaLogFile
 
getVersion() - Method in class io.delta.kernel.internal.snapshot.SnapshotHint
 
getVersion() - Method in class io.delta.kernel.TransactionCommitResult
Contains the version of the transaction committed as.
getVersion(Engine) - Method in class io.delta.kernel.internal.SnapshotImpl
 
getVersion(Engine) - Method in interface io.delta.kernel.Snapshot
Get the version of this snapshot in the table.
getWriteContext(Engine, Row, Map<String, Literal>) - Static method in interface io.delta.kernel.Transaction
Get the context for writing data into a table.
getWriterFeatures() - Method in class io.delta.kernel.internal.actions.Protocol
 

H

hashCode() - Method in class io.delta.kernel.expressions.Column
 
hashCode() - Method in class io.delta.kernel.internal.actions.DeletionVectorDescriptor
 
hashCode() - Method in class io.delta.kernel.internal.checkpoints.CheckpointInstance
 
hashCode() - Method in class io.delta.kernel.internal.fs.Path
 
hashCode() - Method in class io.delta.kernel.internal.util.Tuple2
 
hashCode() - Method in class io.delta.kernel.types.ArrayType
 
hashCode() - Method in class io.delta.kernel.types.BasePrimitiveType
 
hashCode() - Method in class io.delta.kernel.types.DataType
 
hashCode() - Method in class io.delta.kernel.types.DecimalType
 
hashCode() - Method in class io.delta.kernel.types.FieldMetadata
 
hashCode() - Method in class io.delta.kernel.types.MapType
 
hashCode() - Method in class io.delta.kernel.types.StructField
 
hashCode() - Method in class io.delta.kernel.types.StructType
 
hasNext() - Method in class io.delta.kernel.internal.replay.CreateCheckpointIterator
 
hasNext() - Method in interface io.delta.kernel.utils.CloseableIterator
Returns true if the iteration has more elements.
HOURS_PER_DAY - Static variable in class io.delta.kernel.internal.util.DateTimeConstants
 

I

indexOf(String) - Method in class io.delta.kernel.types.StructType
 
INLINE_DV_MARKER - Static variable in class io.delta.kernel.internal.actions.DeletionVectorDescriptor
 
inlineData() - Method in class io.delta.kernel.internal.actions.DeletionVectorDescriptor
 
inMemoryIterable(CloseableIterator<T>) - Static method in interface io.delta.kernel.utils.CloseableIterable
Return an CloseableIterable object that is backed by an in-memory collection of given CloseableIterator.
INTEGER - Static variable in class io.delta.kernel.types.IntegerType
 
IntegerType - Class in io.delta.kernel.types
The data type representing integer type values.
InternalScanFileUtils - Class in io.delta.kernel.internal
Utilities to extract information out of the scan file rows returned by Scan.getScanFiles(Engine).
InternalUtils - Class in io.delta.kernel.internal.util
 
IntervalParserUtils - Class in io.delta.kernel.internal.util
Copy of `org/apache/spark/sql/catalyst/util/SparkIntervalUtils.scala` from Apache Spark.
invalidColumnName(String, String) - Static method in class io.delta.kernel.internal.DeltaErrors
 
io.delta.kernel - package io.delta.kernel
Delta Kernel interfaces for constructing table object representing a Delta Lake table, getting snapshot from the table and building a scan object to scan a subset of the data in the table.
io.delta.kernel.annotation - package io.delta.kernel.annotation
 
io.delta.kernel.data - package io.delta.kernel.data
Delta Kernel interfaces for representing data in columnar and row format.
io.delta.kernel.engine - package io.delta.kernel.engine
Interfaces to allow the connector to bring their own implementation of functions such as reading parquet files, listing files in a file system, parsing a JSON string etc.
io.delta.kernel.exceptions - package io.delta.kernel.exceptions
 
io.delta.kernel.expressions - package io.delta.kernel.expressions
Expressions framework that defines the most common expressions which the connectors can use to pass predicates to Delta Kernel.
io.delta.kernel.internal - package io.delta.kernel.internal
 
io.delta.kernel.internal.actions - package io.delta.kernel.internal.actions
 
io.delta.kernel.internal.checkpoints - package io.delta.kernel.internal.checkpoints
 
io.delta.kernel.internal.data - package io.delta.kernel.internal.data
 
io.delta.kernel.internal.deletionvectors - package io.delta.kernel.internal.deletionvectors
 
io.delta.kernel.internal.fs - package io.delta.kernel.internal.fs
 
io.delta.kernel.internal.lang - package io.delta.kernel.internal.lang
 
io.delta.kernel.internal.replay - package io.delta.kernel.internal.replay
 
io.delta.kernel.internal.skipping - package io.delta.kernel.internal.skipping
 
io.delta.kernel.internal.snapshot - package io.delta.kernel.internal.snapshot
 
io.delta.kernel.internal.util - package io.delta.kernel.internal.util
 
io.delta.kernel.types - package io.delta.kernel.types
Data types defined by the Delta Kernel to exchange the type info between the Delta Kernel and the connectors.
io.delta.kernel.utils - package io.delta.kernel.utils
Utilities.
isAbsolute() - Method in class io.delta.kernel.internal.fs.Path
Returns true if the path component (i.e.
isAbsoluteAndSchemeAuthorityNull() - Method in class io.delta.kernel.internal.fs.Path
Returns true if the path component (i.e.
isBlindAppend() - Method in class io.delta.kernel.internal.TransactionImpl
 
isCheckpointFile(String) - Static method in class io.delta.kernel.internal.util.FileNames
 
isClassicCheckpointFile(String) - Static method in class io.delta.kernel.internal.util.FileNames
 
isCommitFile(String) - Static method in class io.delta.kernel.internal.util.FileNames
 
isDataColumn() - Method in class io.delta.kernel.types.StructField
 
isInline() - Method in class io.delta.kernel.internal.actions.DeletionVectorDescriptor
 
isMetadataColumn() - Method in class io.delta.kernel.types.StructField
 
isMulitPartCheckpointFile(String) - Static method in class io.delta.kernel.internal.util.FileNames
 
isNullable() - Method in class io.delta.kernel.types.StructField
 
isNullAt(int) - Method in interface io.delta.kernel.data.ColumnVector
 
isNullAt(int) - Method in interface io.delta.kernel.data.Row
 
isNullAt(int) - Method in class io.delta.kernel.internal.data.ChildVectorBasedRow
 
isNullAt(int) - Method in class io.delta.kernel.internal.data.GenericRow
 
isNullAt(int) - Method in class io.delta.kernel.internal.data.SelectionColumnVector
 
isOnDisk() - Method in class io.delta.kernel.internal.actions.DeletionVectorDescriptor
 
isPrimitiveType(String) - Static method in class io.delta.kernel.types.BasePrimitiveType
Is the given type name a primitive type?
isReadyForCheckpoint() - Method in class io.delta.kernel.TransactionCommitResult
Is the table ready for checkpoint (i.e.
isRoot() - Method in class io.delta.kernel.internal.fs.Path
Returns true if and only if this path represents the root of a file system.
isSkippingEligibleLiteral(Literal) - Static method in class io.delta.kernel.internal.skipping.StatsSchemaHelper
Returns true if the given literal is skipping-eligible.
isSkippingEligibleMinMaxColumn(Column) - Method in class io.delta.kernel.internal.skipping.StatsSchemaHelper
Returns true if the given column is skipping-eligible using min/max statistics.
isSkippingEligibleNullCountColumn(Column) - Method in class io.delta.kernel.internal.skipping.StatsSchemaHelper
Returns true if the given column is skipping-eligible using null count statistics.
isUriPathAbsolute() - Method in class io.delta.kernel.internal.fs.Path
Returns true if the path component (i.e.
isV2CheckpointFile(String) - Static method in class io.delta.kernel.internal.util.FileNames
 
isValueContainsNull() - Method in class io.delta.kernel.types.MapType
 
isWindowsAbsolutePath(String, boolean) - Static method in class io.delta.kernel.internal.fs.Path
Determine whether a given path string represents an absolute path on Windows.
iterator() - Method in interface io.delta.kernel.utils.CloseableIterable
Overrides the default iterator method to return a CloseableIterator.

J

JsonHandler - Interface in io.delta.kernel.engine
Provides JSON handling functionality to Delta Kernel.

K

KERNEL_VERSION - Static variable in class io.delta.kernel.Meta
 
KernelEngineException - Exception in io.delta.kernel.exceptions
Throws when the Engine encountered an error while executing an operation.
KernelEngineException(String, Throwable) - Constructor for exception io.delta.kernel.exceptions.KernelEngineException
 
KernelException - Exception in io.delta.kernel.exceptions
Thrown when Kernel cannot execute the requested operation due to the operation being invalid or unsupported.
KernelException() - Constructor for exception io.delta.kernel.exceptions.KernelException
 
KernelException(String) - Constructor for exception io.delta.kernel.exceptions.KernelException
 
KernelException(String, Throwable) - Constructor for exception io.delta.kernel.exceptions.KernelException
 
KernelException(Throwable) - Constructor for exception io.delta.kernel.exceptions.KernelException
 

L

LAST_CHECKPOINT_FILE_NAME - Static variable in class io.delta.kernel.internal.checkpoints.Checkpointer
The name of the last checkpoint file
lastCommitTimestamp - Variable in class io.delta.kernel.internal.snapshot.LogSegment
 
Lazy<T> - Class in io.delta.kernel.internal.lang
 
Lazy(Supplier<T>) - Constructor for class io.delta.kernel.internal.lang.Lazy
 
length() - Method in class io.delta.kernel.types.StructType
 
listFrom(String) - Method in interface io.delta.kernel.engine.FileSystemClient
List the paths in the same directory that are lexicographically greater or equal to (UTF-8 sorting) the given `path`.
listingPrefix(Path, long) - Static method in class io.delta.kernel.internal.util.FileNames
Returns the prefix of all delta log files for the given version.
ListUtils - Class in io.delta.kernel.internal.lang
 
Literal - Class in io.delta.kernel.expressions
A literal value.
load(FileSystemClient) - Method in class io.delta.kernel.internal.deletionvectors.DeletionVectorStoredBitmap
 
loadNewDvAndBitmap(Engine, String, DeletionVectorDescriptor) - Static method in class io.delta.kernel.internal.deletionvectors.DeletionVectorUtils
 
logPath - Variable in class io.delta.kernel.internal.snapshot.LogSegment
 
LogReplay - Class in io.delta.kernel.internal.replay
Replays a history of actions, resolving them to produce the current state of the table.
LogReplay(Path, Path, long, Engine, LogSegment, Optional<SnapshotHint>) - Constructor for class io.delta.kernel.internal.replay.LogReplay
 
LogReplayUtils - Class in io.delta.kernel.internal.replay
 
LogReplayUtils.UniqueFileActionTuple - Class in io.delta.kernel.internal.replay
 
LogSegment - Class in io.delta.kernel.internal.snapshot
 
LogSegment(Path, long, List<FileStatus>, List<FileStatus>, Optional<Long>, long) - Constructor for class io.delta.kernel.internal.snapshot.LogSegment
Provides information around which files in the transaction log need to be read to create the given version of the log.
LONG - Static variable in class io.delta.kernel.types.LongType
 
LongType - Class in io.delta.kernel.types
The data type representing long type values.

M

makeQualified(URI, Path) - Method in class io.delta.kernel.internal.fs.Path
Returns a qualified path object.
MANUAL_UPDATE - Enum constant in enum io.delta.kernel.Operation
For any operation that doesn't fit the above categories.
map(Function<T, U>) - Method in interface io.delta.kernel.utils.CloseableIterator
 
MapType - Class in io.delta.kernel.types
Data type representing a map type.
MapType(DataType, DataType, boolean) - Constructor for class io.delta.kernel.types.MapType
 
MapValue - Interface in io.delta.kernel.data
Abstraction to represent a single map value in a ColumnVector.
MAX_VALUE - Static variable in class io.delta.kernel.internal.checkpoints.CheckpointInstance
Placeholder to identify the version that is always the latest on timeline
mergePaths(Path, Path) - Static method in class io.delta.kernel.internal.fs.Path
Merge 2 paths such that the second path is appended relative to the first.
Meta - Class in io.delta.kernel
 
Meta() - Constructor for class io.delta.kernel.Meta
 
Metadata - Class in io.delta.kernel.internal.actions
 
Metadata(String, Optional<String>, Optional<String>, Format, String, StructType, ArrayValue, Optional<Long>, MapValue) - Constructor for class io.delta.kernel.internal.actions.Metadata
 
METADATA_ROW_INDEX_COLUMN - Static variable in class io.delta.kernel.types.StructField
 
METADATA_ROW_INDEX_COLUMN_NAME - Static variable in class io.delta.kernel.types.StructField
The name of a row index metadata column.
metadataChangedException() - Static method in class io.delta.kernel.internal.DeltaErrors
 
MetadataChangedException - Exception in io.delta.kernel.exceptions
Thrown when the metadata of the Delta table has changed between the time of transaction start and the time of commit.
MetadataChangedException() - Constructor for exception io.delta.kernel.exceptions.MetadataChangedException
 
MICROS_PER_DAY - Static variable in class io.delta.kernel.internal.util.DateTimeConstants
 
MICROS_PER_HOUR - Static variable in class io.delta.kernel.internal.util.DateTimeConstants
 
MICROS_PER_MILLIS - Static variable in class io.delta.kernel.internal.util.DateTimeConstants
 
MICROS_PER_MINUTE - Static variable in class io.delta.kernel.internal.util.DateTimeConstants
 
MICROS_PER_SECOND - Static variable in class io.delta.kernel.internal.util.DateTimeConstants
 
microsSinceEpoch(Timestamp) - Static method in class io.delta.kernel.internal.util.InternalUtils
Utility method to get the number of microseconds since the unix epoch for the given timestamp interpreted in UTC.
MILLIS_PER_DAY - Static variable in class io.delta.kernel.internal.util.DateTimeConstants
 
MILLIS_PER_HOUR - Static variable in class io.delta.kernel.internal.util.DateTimeConstants
 
MILLIS_PER_MINUTE - Static variable in class io.delta.kernel.internal.util.DateTimeConstants
 
MILLIS_PER_SECOND - Static variable in class io.delta.kernel.internal.util.DateTimeConstants
 
MINUTES_PER_HOUR - Static variable in class io.delta.kernel.internal.util.DateTimeConstants
 
mkdirs(String) - Method in interface io.delta.kernel.engine.FileSystemClient
Create a directory at the given path including parent directories.
MONTHS_PER_YEAR - Static variable in class io.delta.kernel.internal.util.DateTimeConstants
 
MULTI_PART - Enum constant in enum io.delta.kernel.internal.checkpoints.CheckpointInstance.CheckpointFormat
 
MULTIPART_CHECKPOINT - Enum constant in enum io.delta.kernel.internal.replay.DeltaLogFile.LogType
 

N

NANOS_PER_MICROS - Static variable in class io.delta.kernel.internal.util.DateTimeConstants
 
NANOS_PER_MILLIS - Static variable in class io.delta.kernel.internal.util.DateTimeConstants
 
NANOS_PER_SECOND - Static variable in class io.delta.kernel.internal.util.DateTimeConstants
 
next() - Method in class io.delta.kernel.internal.replay.CreateCheckpointIterator
 
next() - Method in interface io.delta.kernel.utils.CloseableIterator
Returns the next element in the iteration.
numParts - Variable in class io.delta.kernel.internal.checkpoints.CheckpointInstance
 

O

of(Metadata, Protocol, String, String, String, String) - Static method in class io.delta.kernel.internal.data.ScanStateRow
 
of(Metadata, String) - Static method in class io.delta.kernel.internal.data.TransactionStateRow
 
of(String, long, long) - Static method in class io.delta.kernel.utils.FileStatus
Create a FileStatus with the given path, size and modification time.
ofBinary(byte[]) - Static method in class io.delta.kernel.expressions.Literal
Create a binary type literal expression.
ofBoolean(boolean) - Static method in class io.delta.kernel.expressions.Literal
Create a boolean type literal expression.
ofByte(byte) - Static method in class io.delta.kernel.expressions.Literal
Create a byte type literal expression.
ofDate(int) - Static method in class io.delta.kernel.expressions.Literal
Create a date type literal expression.
ofDecimal(BigDecimal, int, int) - Static method in class io.delta.kernel.expressions.Literal
Create a decimal type literal expression.
ofDouble(double) - Static method in class io.delta.kernel.expressions.Literal
Create a double type literal expression.
ofFloat(float) - Static method in class io.delta.kernel.expressions.Literal
Create a float type literal expression.
ofInt(int) - Static method in class io.delta.kernel.expressions.Literal
Create a integer type literal expression.
ofLong(long) - Static method in class io.delta.kernel.expressions.Literal
Create a long type literal expression.
ofNull(DataType) - Static method in class io.delta.kernel.expressions.Literal
Create null value literal.
ofShort(short) - Static method in class io.delta.kernel.expressions.Literal
Create a short type literal expression.
ofSideCar(FileStatus, long) - Static method in class io.delta.kernel.internal.replay.DeltaLogFile
 
ofString(String) - Static method in class io.delta.kernel.expressions.Literal
Create a string type literal expression.
ofTimestamp(long) - Static method in class io.delta.kernel.expressions.Literal
Create a timestamp type literal expression.
ofTimestampNtz(long) - Static method in class io.delta.kernel.expressions.Literal
Create a timestamp_ntz type literal expression.
Operation - Enum in io.delta.kernel
An operation that can be performed on a Delta table.
Or - Class in io.delta.kernel.expressions
OR expression
Or(Predicate, Predicate) - Constructor for class io.delta.kernel.expressions.Or
 

P

PARQUET_FIELD_ID_KEY - Static variable in class io.delta.kernel.internal.util.ColumnMapping
 
ParquetHandler - Interface in io.delta.kernel.engine
Provides Parquet file related functionalities to Delta Kernel.
parseIntervalAsMicros(String) - Static method in class io.delta.kernel.internal.util.IntervalParserUtils
 
parseJson(ColumnVector, StructType, Optional<ColumnVector>) - Method in interface io.delta.kernel.engine.JsonHandler
Parse the given json strings and return the fields requested by outputSchema as columns in a ColumnarBatch.
parseJsonStats(Engine, FilteredColumnarBatch, StructType) - Static method in class io.delta.kernel.internal.skipping.DataSkippingUtils
Given a FilteredColumnarBatch of scan files and the statistics schema to parse, return the parsed JSON stats from the scan files.
partition(List<T>, Predicate<? super T>) - Static method in class io.delta.kernel.internal.lang.ListUtils
 
partitionColumnMissingInData(String, String) - Static method in class io.delta.kernel.internal.DeltaErrors
 
PartitionUtils - Class in io.delta.kernel.internal.util
 
PartitionValueExpression - Class in io.delta.kernel.expressions
Expression to decode the serialized partition value into partition type value according the Delta Protocol spec.
PartitionValueExpression(Expression, DataType) - Constructor for class io.delta.kernel.expressions.PartitionValueExpression
Create partition_value expression.
parts - Variable in class io.delta.kernel.internal.checkpoints.CheckpointMetaData
 
Path - Class in io.delta.kernel.internal.fs
Names a file or directory in a FileSystem.
Path(Path, Path) - Constructor for class io.delta.kernel.internal.fs.Path
Create a new Path based on the child path resolved against the parent path.
Path(Path, String) - Constructor for class io.delta.kernel.internal.fs.Path
Create a new Path based on the child path resolved against the parent path.
Path(String) - Constructor for class io.delta.kernel.internal.fs.Path
Construct a path from a String.
Path(String, Path) - Constructor for class io.delta.kernel.internal.fs.Path
Create a new Path based on the child path resolved against the parent path.
Path(String, String) - Constructor for class io.delta.kernel.internal.fs.Path
Create a new Path based on the child path resolved against the parent path.
Path(String, String, String) - Constructor for class io.delta.kernel.internal.fs.Path
Construct a Path from components.
Path(URI) - Constructor for class io.delta.kernel.internal.fs.Path
Construct a path from a URI
PATH_DV_MARKER - Static variable in class io.delta.kernel.internal.actions.DeletionVectorDescriptor
 
physicalSchemaWithoutPartitionColumns(StructType, StructType, Set<String>) - Static method in class io.delta.kernel.internal.util.PartitionUtils
Utility method to remove the given columns (as columnsToRemove) from the given physicalSchema.
Preconditions - Class in io.delta.kernel.internal.util
Static convenience methods that help a method or constructor check whether it was invoked correctly (that is, whether its preconditions were met).
Predicate - Class in io.delta.kernel.expressions
Defines predicate scalar expression which is an extension of ScalarExpression that evaluates to true, false, or null for each input row.
Predicate(String, Expression) - Constructor for class io.delta.kernel.expressions.Predicate
Constructor for a unary Predicate expression
Predicate(String, Expression, Expression) - Constructor for class io.delta.kernel.expressions.Predicate
Constructor for a binary Predicate expression
Predicate(String, List<Expression>) - Constructor for class io.delta.kernel.expressions.Predicate
 
PredicateEvaluator - Interface in io.delta.kernel.expressions
Special interface for evaluating Predicate on input batch and return a selection vector containing one value for each row in input batch indicating whether the row has passed the predicate or not.
Protocol - Class in io.delta.kernel.internal.actions
 
Protocol(int, int, List<String>, List<String>) - Constructor for class io.delta.kernel.internal.actions.Protocol
 
PROTOCOL_METADATA_READ_SCHEMA - Static variable in class io.delta.kernel.internal.replay.LogReplay
Read schema when searching for the latest Protocol and Metadata.
protocolChangedException(long) - Static method in class io.delta.kernel.internal.DeltaErrors
 
ProtocolChangedException - Exception in io.delta.kernel.exceptions
Thrown when the protocol of the Delta table has changed between the time of transaction start and the time of commit.
ProtocolChangedException(long) - Constructor for exception io.delta.kernel.exceptions.ProtocolChangedException
 
pruneStatsSchema(StructType, Set<Column>) - Static method in class io.delta.kernel.internal.skipping.DataSkippingUtils
Prunes the given schema to only include the referenced leaf columns.
putBoolean(String, boolean) - Method in class io.delta.kernel.types.FieldMetadata.Builder
 
putBooleanArray(String, Boolean[]) - Method in class io.delta.kernel.types.FieldMetadata.Builder
 
putDouble(String, double) - Method in class io.delta.kernel.types.FieldMetadata.Builder
 
putDoubleArray(String, Double[]) - Method in class io.delta.kernel.types.FieldMetadata.Builder
 
putFieldMetadata(String, FieldMetadata) - Method in class io.delta.kernel.types.FieldMetadata.Builder
 
putFieldMetadataArray(String, FieldMetadata[]) - Method in class io.delta.kernel.types.FieldMetadata.Builder
 
putLong(String, long) - Method in class io.delta.kernel.types.FieldMetadata.Builder
 
putLongArray(String, Long[]) - Method in class io.delta.kernel.types.FieldMetadata.Builder
 
putNull(String) - Method in class io.delta.kernel.types.FieldMetadata.Builder
 
putString(String, String) - Method in class io.delta.kernel.types.FieldMetadata.Builder
 
putStringArray(String, String[]) - Method in class io.delta.kernel.types.FieldMetadata.Builder
 

R

READ_SCHEMA - Static variable in class io.delta.kernel.internal.actions.DeletionVectorDescriptor
 
READ_SCHEMA - Static variable in class io.delta.kernel.internal.checkpoints.CheckpointMetaData
 
READ_SCHEMA - Static variable in class io.delta.kernel.internal.checkpoints.SidecarFile
 
readFiles(CloseableIterator<FileReadRequest>) - Method in interface io.delta.kernel.engine.FileSystemClient
Return an iterator of byte streams one for each read request in readRequests.
readJsonFiles(CloseableIterator<FileStatus>, StructType, Optional<Predicate>) - Method in interface io.delta.kernel.engine.JsonHandler
Read and parse the JSON format file at given locations and return the data as a ColumnarBatch with the columns requested by physicalSchema.
readLastCheckpointFile(Engine) - Method in class io.delta.kernel.internal.checkpoints.Checkpointer
Returns information about the most recent checkpoint.
readParquetFiles(CloseableIterator<FileStatus>, StructType, Optional<Predicate>) - Method in interface io.delta.kernel.engine.ParquetHandler
Read the Parquet format files at the given locations and return the data as a ColumnarBatch with the columns requested by physicalSchema.
relativizePath(Path, URI) - Static method in class io.delta.kernel.internal.util.InternalUtils
Relativize the given child path with respect to the given root URI.
REMOVE_FILE_DV_ORDINAL - Static variable in class io.delta.kernel.internal.replay.LogReplay
 
REMOVE_FILE_ORDINAL - Static variable in class io.delta.kernel.internal.replay.LogReplay
 
REMOVE_FILE_PATH_ORDINAL - Static variable in class io.delta.kernel.internal.replay.LogReplay
 
RemoveFile - Class in io.delta.kernel.internal.actions
Metadata about remove action in the Delta Log.
RemoveFile() - Constructor for class io.delta.kernel.internal.actions.RemoveFile
 
REMOVEFILE_FIELD_NAME - Static variable in class io.delta.kernel.internal.replay.LogReplay
 
requireNonNull(ColumnVector, int, String) - Static method in class io.delta.kernel.internal.util.InternalUtils
 
requireNonNull(Row, int, String) - Static method in class io.delta.kernel.internal.util.InternalUtils
 
requiresSchemaForNewTable(String) - Static method in class io.delta.kernel.internal.DeltaErrors
 
resolveConflicts(Engine) - Method in class io.delta.kernel.internal.replay.ConflictChecker
 
resolveConflicts(Engine, SnapshotImpl, long, TransactionImpl) - Static method in class io.delta.kernel.internal.replay.ConflictChecker
Resolve conflicts between the losing transaction and the winning transactions and return a rebase state that the losing transaction needs to rebase against before attempting the commit.
resolvePath(String) - Method in interface io.delta.kernel.engine.FileSystemClient
Resolve the given path to a fully qualified path.
rewritePartitionPredicateOnCheckpointFileSchema(Predicate, Map<String, StructField>) - Static method in class io.delta.kernel.internal.util.PartitionUtils
Rewrite the given predicate on partition columns on `partitionValues_parsed` in checkpoint schema.
rewritePartitionPredicateOnScanFileSchema(Predicate, Map<String, StructField>) - Static method in class io.delta.kernel.internal.util.PartitionUtils
Utility method to rewrite the partition predicate referring to the table schema as predicate referring to the partitionValues in scan files read from Delta log.
RoaringBitmapArray - Class in io.delta.kernel.internal.deletionvectors
A 64-bit extension of [[RoaringBitmap]] that is optimized for cases that usually fit within a 32-bit bitmap, but may run over by a few bits on occasion.
RoaringBitmapArray() - Constructor for class io.delta.kernel.internal.deletionvectors.RoaringBitmapArray
 
Row - Interface in io.delta.kernel.data
Represent a single record

S

safeParseIntervalAsMillis(String) - Static method in class io.delta.kernel.internal.util.IntervalParserUtils
Parse the given interval string into milliseconds.
ScalarExpression - Class in io.delta.kernel.expressions
Scalar SQL expressions which take zero or more inputs and for each input row generate one output value.
ScalarExpression(String, List<Expression>) - Constructor for class io.delta.kernel.expressions.ScalarExpression
 
Scan - Interface in io.delta.kernel
Represents a scan of a Delta table.
SCAN_FILE_SCHEMA - Static variable in class io.delta.kernel.internal.InternalScanFileUtils
Schema of the returned scan files.
SCAN_FILE_SCHEMA_WITH_STATS - Static variable in class io.delta.kernel.internal.InternalScanFileUtils
Schema of the returned scan files when ScanImpl.getScanFiles(Engine, boolean) is called with includeStats=true.
ScanBuilder - Interface in io.delta.kernel
Builder to construct Scan object.
ScanBuilderImpl - Class in io.delta.kernel.internal
Implementation of ScanBuilder.
ScanBuilderImpl(Path, Protocol, Metadata, StructType, LogReplay, Engine) - Constructor for class io.delta.kernel.internal.ScanBuilderImpl
 
ScanImpl - Class in io.delta.kernel.internal
Implementation of Scan
ScanImpl(StructType, StructType, Protocol, Metadata, LogReplay, Optional<Predicate>, Path) - Constructor for class io.delta.kernel.internal.ScanImpl
 
ScanStateRow - Class in io.delta.kernel.internal.data
Encapsulate the scan state (common info for all scan files) as a Row
ScanStateRow(HashMap<Integer, Object>) - Constructor for class io.delta.kernel.internal.data.ScanStateRow
 
SCHEMA_WITH_STATS - Static variable in class io.delta.kernel.internal.actions.AddFile
 
SCHEMA_WITHOUT_STATS - Static variable in class io.delta.kernel.internal.actions.AddFile
Schema of the add action in the Delta Log without stats.
SchemaUtils - Class in io.delta.kernel.internal.util
Utility methods for schema related operations such as validating the schema has no duplicate columns and the names contain only valid characters.
SECONDS_PER_DAY - Static variable in class io.delta.kernel.internal.util.DateTimeConstants
 
SECONDS_PER_HOUR - Static variable in class io.delta.kernel.internal.util.DateTimeConstants
 
SECONDS_PER_MINUTE - Static variable in class io.delta.kernel.internal.util.DateTimeConstants
 
SelectionColumnVector - Class in io.delta.kernel.internal.data
The selection vector for a columnar batch as a boolean ColumnVector.
SelectionColumnVector(RoaringBitmapArray, ColumnVector) - Constructor for class io.delta.kernel.internal.data.SelectionColumnVector
 
SEPARATOR - Static variable in class io.delta.kernel.internal.fs.Path
The directory separator, a slash.
SEPARATOR_CHAR - Static variable in class io.delta.kernel.internal.fs.Path
The directory separator, a slash, as a character.
serializeAsJson() - Method in class io.delta.kernel.utils.DataFileStatistics
 
serializePartitionMap(Map<String, Literal>) - Static method in class io.delta.kernel.internal.util.PartitionUtils
Convert the given partition values to a MapValue that can be serialized to a Delta commit file.
SET_TRANSACTION_READ_SCHEMA - Static variable in class io.delta.kernel.internal.replay.LogReplay
Read schema when searching for just the transaction identifiers
SetTransaction - Class in io.delta.kernel.internal.actions
Delta log action representing a transaction identifier action.
SetTransaction(String, Long, Optional<Long>) - Constructor for class io.delta.kernel.internal.actions.SetTransaction
 
SHORT - Static variable in class io.delta.kernel.types.ShortType
 
ShortType - Class in io.delta.kernel.types
The data type representing short type values.
SIDECAR - Enum constant in enum io.delta.kernel.internal.replay.DeltaLogFile.LogType
 
SIDECAR_DIRECTORY - Static variable in class io.delta.kernel.internal.util.FileNames
 
SIDECAR_FIELD_NAME - Static variable in class io.delta.kernel.internal.replay.LogReplay
 
sidecarFile(Path, String) - Static method in class io.delta.kernel.internal.util.FileNames
 
SidecarFile - Class in io.delta.kernel.internal.checkpoints
Action representing a SidecarFile in a top-level V2 checkpoint file.
SidecarFile(String, long, long) - Constructor for class io.delta.kernel.internal.checkpoints.SidecarFile
 
SingleAction - Class in io.delta.kernel.internal.actions
 
SingleAction() - Constructor for class io.delta.kernel.internal.actions.SingleAction
 
singletonCloseableIterator(T) - Static method in class io.delta.kernel.internal.util.Utils
Utility method to create a singleton CloseableIterator.
singletonStringColumnVector(String) - Static method in class io.delta.kernel.internal.util.InternalUtils
Utility method to create a singleton string ColumnVector
size - Variable in class io.delta.kernel.internal.checkpoints.CheckpointMetaData
 
slice(int, int) - Method in interface io.delta.kernel.data.ColumnarBatch
Return a slice of the current batch.
Snapshot - Interface in io.delta.kernel
Represents the snapshot of a Delta table.
SnapshotHint - Class in io.delta.kernel.internal.snapshot
Contains summary information of a Snapshot.
SnapshotHint(long, Protocol, Metadata) - Constructor for class io.delta.kernel.internal.snapshot.SnapshotHint
 
SnapshotImpl - Class in io.delta.kernel.internal
Implementation of Snapshot.
SnapshotImpl(Path, LogSegment, LogReplay, Protocol, Metadata) - Constructor for class io.delta.kernel.internal.SnapshotImpl
 
SnapshotManager - Class in io.delta.kernel.internal.snapshot
 
SnapshotManager(Path, Path) - Constructor for class io.delta.kernel.internal.snapshot.SnapshotManager
 
spliterator() - Method in interface io.delta.kernel.utils.CloseableIterable
 
splitMetadataAndDataPredicates(Predicate, Set<String>) - Static method in class io.delta.kernel.internal.util.PartitionUtils
Split the given predicate into predicate on partition columns and predicate on data columns.
StatsSchemaHelper - Class in io.delta.kernel.internal.skipping
Provides information and utilities for statistics columns given a table schema.
StatsSchemaHelper(StructType) - Constructor for class io.delta.kernel.internal.skipping.StatsSchemaHelper
 
STREAMING_UPDATE - Enum constant in enum io.delta.kernel.Operation
Recorded during streaming inserts.
STRING - Static variable in class io.delta.kernel.types.StringType
 
stringArrayValue(List<String>) - Static method in class io.delta.kernel.internal.util.VectorUtils
Creates an ArrayValue from list of strings.
stringStringMapValue(Map<String, String>) - Static method in class io.delta.kernel.internal.util.VectorUtils
Creates a MapValue from map of string keys and string values.
StringType - Class in io.delta.kernel.types
The data type representing string type values.
stringVector(List<String>) - Static method in class io.delta.kernel.internal.util.VectorUtils
Utility method to create a ColumnVector for given list of strings.
StructField - Class in io.delta.kernel.types
Represents a subfield of StructType with additional properties and metadata.
StructField(String, DataType, boolean) - Constructor for class io.delta.kernel.types.StructField
 
StructField(String, DataType, boolean, FieldMetadata) - Constructor for class io.delta.kernel.types.StructField
 
StructRow - Class in io.delta.kernel.internal.data
A Row abstraction for a struct type column vector and a specific rowId.
StructType - Class in io.delta.kernel.types
Struct type which contains one or more columns.
StructType() - Constructor for class io.delta.kernel.types.StructType
 
StructType(List<StructField>) - Constructor for class io.delta.kernel.types.StructType
 
suffix(String) - Method in class io.delta.kernel.internal.fs.Path
Adds a suffix to the final name in the path.

T

Table - Interface in io.delta.kernel
Represents the Delta Lake table for a given path.
TABLE_ROOT_STRUCT_FIELD - Static variable in class io.delta.kernel.internal.InternalScanFileUtils
 
tableAlreadyExists(String, String) - Static method in class io.delta.kernel.internal.DeltaErrors
 
TableAlreadyExistsException - Exception in io.delta.kernel.exceptions
Thrown when trying to create a Delta table at a location where a Delta table already exists.
TableAlreadyExistsException(String) - Constructor for exception io.delta.kernel.exceptions.TableAlreadyExistsException
 
TableAlreadyExistsException(String, String) - Constructor for exception io.delta.kernel.exceptions.TableAlreadyExistsException
 
TableConfig<T> - Class in io.delta.kernel.internal
Represents the table properties.
TableFeatures - Class in io.delta.kernel.internal
Contains utility methods related to the Delta table feature support in protocol.
TableFeatures() - Constructor for class io.delta.kernel.internal.TableFeatures
 
TableImpl - Class in io.delta.kernel.internal
 
TableImpl(String) - Constructor for class io.delta.kernel.internal.TableImpl
 
TableNotFoundException - Exception in io.delta.kernel.exceptions
Thrown when there is no Delta table at the given location.
TableNotFoundException(String) - Constructor for exception io.delta.kernel.exceptions.TableNotFoundException
 
TableNotFoundException(String, String) - Constructor for exception io.delta.kernel.exceptions.TableNotFoundException
 
throwOnUnsupportedColumnMappingMode(Metadata) - Static method in class io.delta.kernel.internal.util.ColumnMapping
Checks if the given column mapping mode in the given table metadata is supported.
TIMESTAMP - Static variable in class io.delta.kernel.types.TimestampType
 
TIMESTAMP_NTZ - Static variable in class io.delta.kernel.types.TimestampNTZType
 
timestampAfterLatestCommit(String, long, long, long) - Static method in class io.delta.kernel.internal.DeltaErrors
 
timestampBeforeFirstAvailableCommit(String, long, long, long) - Static method in class io.delta.kernel.internal.DeltaErrors
 
TimestampNTZType - Class in io.delta.kernel.types
The timestamp without time zone type represents a local time in microsecond precision, which is independent of time zone.
TimestampType - Class in io.delta.kernel.types
A timestamp type, supporting [0001-01-01T00:00:00.000000Z, 9999-12-31T23:59:59.999999Z] where the left/right-bound is a date and time of the proleptic Gregorian calendar in UTC+00:00.
toCloseableIterator(Iterator<T>) - Static method in class io.delta.kernel.internal.util.Utils
toJavaList(ArrayValue) - Static method in class io.delta.kernel.internal.util.VectorUtils
Converts an ArrayValue to a Java list.
toJavaMap(MapValue) - Static method in class io.delta.kernel.internal.util.VectorUtils
Converts a MapValue to a Java map.
toJson() - Method in class io.delta.kernel.types.ArrayType
 
toJson() - Method in class io.delta.kernel.types.BasePrimitiveType
 
toJson() - Method in class io.delta.kernel.types.DataType
Convert the data type to Delta protocol specified serialization format.
toJson() - Method in class io.delta.kernel.types.DecimalType
 
toJson() - Method in class io.delta.kernel.types.FieldMetadata
 
toJson() - Method in class io.delta.kernel.types.MapType
 
toJson() - Method in class io.delta.kernel.types.StructField
 
toJson() - Method in class io.delta.kernel.types.StructType
 
toLowerCaseSet(Collection<String>) - Static method in class io.delta.kernel.internal.util.InternalUtils
 
TOMBSTONE_RETENTION - Static variable in class io.delta.kernel.internal.TableConfig
The shortest duration we have to keep logically deleted data files around before deleting them physically.
topLevelV2CheckpointFile(Path, long, String, String) - Static method in class io.delta.kernel.internal.util.FileNames
Returns the path for a top-level V2 checkpoint file up to the given version with a given UUID and filetype (JSON or Parquet).
toRow() - Method in class io.delta.kernel.internal.actions.CommitInfo
Encode as a Row object with the schema CommitInfo.FULL_SCHEMA.
toRow() - Method in class io.delta.kernel.internal.actions.Format
Encode as a Row object with the schema Format.FULL_SCHEMA.
toRow() - Method in class io.delta.kernel.internal.actions.Metadata
Encode as a Row object with the schema Metadata.FULL_SCHEMA.
toRow() - Method in class io.delta.kernel.internal.actions.Protocol
Encode as a Row object with the schema Protocol.FULL_SCHEMA.
toRow() - Method in class io.delta.kernel.internal.actions.SetTransaction
Encode as a Row object with the schema SetTransaction.FULL_SCHEMA.
toRow() - Method in class io.delta.kernel.internal.checkpoints.CheckpointMetaData
 
toString() - Method in class io.delta.kernel.expressions.Column
 
toString() - Method in class io.delta.kernel.expressions.Literal
 
toString() - Method in class io.delta.kernel.expressions.PartitionValueExpression
 
toString() - Method in class io.delta.kernel.expressions.Predicate
 
toString() - Method in class io.delta.kernel.expressions.ScalarExpression
 
toString() - Method in class io.delta.kernel.internal.actions.DeletionVectorDescriptor
 
toString() - Method in class io.delta.kernel.internal.actions.Protocol
 
toString() - Method in class io.delta.kernel.internal.checkpoints.CheckpointInstance
 
toString() - Method in class io.delta.kernel.internal.checkpoints.CheckpointMetaData
 
toString() - Method in class io.delta.kernel.internal.fs.Path
 
toString() - Method in class io.delta.kernel.types.ArrayType
 
toString() - Method in class io.delta.kernel.types.BasePrimitiveType
 
toString() - Method in class io.delta.kernel.types.DataType
 
toString() - Method in class io.delta.kernel.types.DecimalType
 
toString() - Method in class io.delta.kernel.types.FieldMetadata
 
toString() - Method in class io.delta.kernel.types.MapType
 
toString() - Method in class io.delta.kernel.types.StructField
 
toString() - Method in class io.delta.kernel.types.StructType
 
toUri() - Method in class io.delta.kernel.internal.fs.Path
Convert this Path to a URI.
Transaction - Interface in io.delta.kernel
Represents a transaction to mutate a Delta table.
TransactionBuilder - Interface in io.delta.kernel
Builder for creating a Transaction to mutate a Delta table.
TransactionBuilderImpl - Class in io.delta.kernel.internal
 
TransactionBuilderImpl(TableImpl, String, Operation) - Constructor for class io.delta.kernel.internal.TransactionBuilderImpl
 
TransactionCommitResult - Class in io.delta.kernel
Contains the result of a successful transaction commit.
TransactionCommitResult(long, boolean) - Constructor for class io.delta.kernel.TransactionCommitResult
 
TransactionImpl - Class in io.delta.kernel.internal
 
TransactionImpl(boolean, Path, Path, SnapshotImpl, String, Operation, Protocol, Metadata, Optional<SetTransaction>) - Constructor for class io.delta.kernel.internal.TransactionImpl
 
TransactionRebaseState(long) - Constructor for class io.delta.kernel.internal.replay.ConflictChecker.TransactionRebaseState
 
TransactionStateRow - Class in io.delta.kernel.internal.data
 
transformLogicalData(Engine, Row, CloseableIterator<FilteredColumnarBatch>, Map<String, Literal>) - Static method in interface io.delta.kernel.Transaction
Given the logical data that needs to be written to the table, convert it into the required physical data depending upon the table Delta protocol and features enabled on the table.
transformPhysicalData(Engine, Row, Row, CloseableIterator<ColumnarBatch>) - Static method in interface io.delta.kernel.Scan
Transform the physical data read from the table data file into the logical data that expected out of the Delta table.
Tuple2<K,V> - Class in io.delta.kernel.internal.util
Represents tuple of objects.
Tuple2(K, V) - Constructor for class io.delta.kernel.internal.util.Tuple2
 

U

unsupportedDataType(DataType) - Static method in class io.delta.kernel.internal.DeltaErrors
 
unsupportedPartitionDataType(String, DataType) - Static method in class io.delta.kernel.internal.DeltaErrors
 
unsupportedReaderFeature(String, String) - Static method in class io.delta.kernel.internal.DeltaErrors
 
unsupportedReaderProtocol(String, int) - Static method in class io.delta.kernel.internal.DeltaErrors
 
unsupportedWriterFeature(String, String) - Static method in class io.delta.kernel.internal.DeltaErrors
 
unsupportedWriterProtocol(String, int) - Static method in class io.delta.kernel.internal.DeltaErrors
 
USER_DEFAULT - Static variable in class io.delta.kernel.types.DecimalType
 
usesSidecars() - Method in enum io.delta.kernel.internal.checkpoints.CheckpointInstance.CheckpointFormat
 
Utils - Class in io.delta.kernel.internal.util
Various utility methods to help the connectors work with data objects returned by Kernel
Utils() - Constructor for class io.delta.kernel.internal.util.Utils
 
UUID_DV_MARKER - Static variable in class io.delta.kernel.internal.actions.DeletionVectorDescriptor
 

V

V2 - Enum constant in enum io.delta.kernel.internal.checkpoints.CheckpointInstance.CheckpointFormat
 
V2_CHECKPOINT_MANIFEST - Enum constant in enum io.delta.kernel.internal.replay.DeltaLogFile.LogType
 
v2CheckpointSidecarFile(Path, String) - Static method in class io.delta.kernel.internal.util.FileNames
Returns the path for a V2 sidecar file with a given UUID.
validateAndSanitizePartitionValues(StructType, List<String>, Map<String, Literal>) - Static method in class io.delta.kernel.internal.util.PartitionUtils
Validate partitionValues contains values for every partition column in the table and the type of the value is correct.
validateObject() - Method in class io.delta.kernel.internal.fs.Path
Validate the contents of a deserialized Path, so as to defend against malicious object streams.
validatePartitionColumns(StructType, List<String>) - Static method in class io.delta.kernel.internal.util.SchemaUtils
Verify the partition columns exists in the table schema and a supported data type for a partition column.
validateReadSupportedTable(Protocol, Metadata, String) - Static method in class io.delta.kernel.internal.TableFeatures
 
validateSchema(StructType, boolean) - Static method in class io.delta.kernel.internal.util.SchemaUtils
Validate the schema.
validateWriteSupportedTable(Protocol, Metadata, StructType, String) - Static method in class io.delta.kernel.internal.TableFeatures
Utility method to validate whether the given table is supported for writing from Kernel.
valueOf(String) - Static method in enum io.delta.kernel.internal.checkpoints.CheckpointInstance.CheckpointFormat
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.delta.kernel.internal.replay.DeltaLogFile.LogType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.delta.kernel.Operation
Returns the enum constant of this type with the specified name.
values() - Static method in enum io.delta.kernel.internal.checkpoints.CheckpointInstance.CheckpointFormat
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.delta.kernel.internal.replay.DeltaLogFile.LogType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.delta.kernel.Operation
Returns an array containing the constants of this enum type, in the order they are declared.
VectorUtils - Class in io.delta.kernel.internal.util
 
verifyDeltaVersions(List<Long>, Optional<Long>, Optional<Long>) - Static method in class io.delta.kernel.internal.snapshot.SnapshotManager
- Verify the versions are contiguous.
version - Variable in class io.delta.kernel.internal.checkpoints.CheckpointInstance
 
version - Variable in class io.delta.kernel.internal.checkpoints.CheckpointMetaData
 
version - Variable in class io.delta.kernel.internal.snapshot.LogSegment
 
versionAfterLatestCommit(String, long, long) - Static method in class io.delta.kernel.internal.DeltaErrors
 
versionBeforeFirstAvailableCommit(String, long, long) - Static method in class io.delta.kernel.internal.DeltaErrors
 

W

WINDOWS - Static variable in class io.delta.kernel.internal.fs.Path
Whether the current host is a Windows machine.
withDeletedColumnAt(int) - Method in interface io.delta.kernel.data.ColumnarBatch
Return a copy of this ColumnarBatch with the column at given ordinal removed.
withFilter(Engine, Predicate) - Method in class io.delta.kernel.internal.ScanBuilderImpl
 
withFilter(Engine, Predicate) - Method in interface io.delta.kernel.ScanBuilder
Apply the given filter expression to prune any files that do not possibly contain the data that satisfies the given filter.
withNewColumn(int, StructField, ColumnVector) - Method in interface io.delta.kernel.data.ColumnarBatch
Return a copy of the ColumnarBatch with given new column vector inserted at the given columnVector at given ordinal.
withNewSchema(StructType) - Method in interface io.delta.kernel.data.ColumnarBatch
Generate a copy of this ColumnarBatch with the given newSchema.
withPartitionColumns(Engine, List<String>) - Method in class io.delta.kernel.internal.TransactionBuilderImpl
 
withPartitionColumns(Engine, List<String>) - Method in interface io.delta.kernel.TransactionBuilder
Set the list of partitions columns when create a new partitioned table.
withPartitionColumns(ExpressionHandler, ColumnarBatch, Map<String, String>, StructType) - Static method in class io.delta.kernel.internal.util.PartitionUtils
 
withReadSchema(Engine, StructType) - Method in class io.delta.kernel.internal.ScanBuilderImpl
 
withReadSchema(Engine, StructType) - Method in interface io.delta.kernel.ScanBuilder
Apply the given readSchema.
withSchema(Engine, StructType) - Method in class io.delta.kernel.internal.TransactionBuilderImpl
 
withSchema(Engine, StructType) - Method in interface io.delta.kernel.TransactionBuilder
Set the schema of the table when creating a new table.
withSidecarFileSchema(StructType) - Static method in class io.delta.kernel.internal.replay.LogReplay
 
withTransactionId(Engine, String, long) - Method in class io.delta.kernel.internal.TransactionBuilderImpl
 
withTransactionId(Engine, String, long) - Method in interface io.delta.kernel.TransactionBuilder
Set the transaction identifier for idempotent writes.
WRITE - Enum constant in enum io.delta.kernel.Operation
Recorded during batch inserts.
writeJsonFileAtomically(String, CloseableIterator<Row>, boolean) - Method in interface io.delta.kernel.engine.JsonHandler
Serialize each Row in the iterator as JSON and write as a separate line in destination file.
writeLastCheckpointFile(Engine, CheckpointMetaData) - Method in class io.delta.kernel.internal.checkpoints.Checkpointer
Write the given data to last checkpoint metadata file.
writeParquetFileAtomically(String, CloseableIterator<FilteredColumnarBatch>) - Method in interface io.delta.kernel.engine.ParquetHandler
Write the given data as a Parquet file.
writeParquetFiles(String, CloseableIterator<FilteredColumnarBatch>, List<Column>) - Method in interface io.delta.kernel.engine.ParquetHandler
Write the given data batches to a Parquet files.

_

_1 - Variable in class io.delta.kernel.internal.util.Tuple2
 
_2 - Variable in class io.delta.kernel.internal.util.Tuple2
 
A B C D E F G H I J K L M N O P R S T U V W _ 
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form