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(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
 
addDomainMetadata(String, String) - Method in interface io.delta.kernel.Transaction
Commit the provided domain metadata as part of this transaction.
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
 
appendNestedField(String) - Method in class io.delta.kernel.expressions.Column
Returns a new column that appends the input column name to the current column.
ArrayType - Class in io.delta.kernel.types
Represent array data type
ArrayType(DataType, boolean) - Constructor for class io.delta.kernel.types.ArrayType
 
ArrayType(StructField) - 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.
at(int) - Method in class io.delta.kernel.types.StructType
 
available() - Method in class io.delta.kernel.defaults.engine.hadoopio.HadoopSeekableInputStream
 

B

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.
BREAK - Enum constant in enum class io.delta.kernel.utils.CloseableIterator.BreakableFilterResult
Indicates that the iteration should stop immediately and that no further elements should be processed by CloseableIterator.breakableFilter(Function).
breakableFilter(Function<T, CloseableIterator.BreakableFilterResult>) - Method in interface io.delta.kernel.utils.CloseableIterator
Returns a new CloseableIterator that applies a CloseableIterator.BreakableFilterResult-based filtering function to determine whether elements of this iterator should be included or excluded, or whether the iteration should terminate.
build() - Method in interface io.delta.kernel.ScanBuilder
 
build() - Method in class io.delta.kernel.types.FieldMetadata.Builder
 
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
 
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

checkpoint(Engine, long) - Method in interface io.delta.kernel.Table
Checkpoint the table at given version.
CHECKPOINT - Enum constant in enum class io.delta.kernel.hook.PostCommitHook.PostCommitHookType
Writes a new checkpoint at the version committed by the transaction.
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
 
checksum(Engine, long) - Method in interface io.delta.kernel.Table
Computes and writes a checksum file for the table at given version.
CHECKSUM_FULL - Enum constant in enum class io.delta.kernel.hook.PostCommitHook.PostCommitHookType
Writes a checksum file at the version committed by the transaction.
CHECKSUM_SIMPLE - Enum constant in enum class io.delta.kernel.hook.PostCommitHook.PostCommitHookType
Writes a checksum file at the version committed by the transaction.
close() - Method in interface io.delta.kernel.data.ColumnVector
Cleans up memory for this column vector.
close() - Method in class io.delta.kernel.defaults.engine.hadoopio.HadoopPositionOutputStream
 
close() - Method in class io.delta.kernel.defaults.engine.hadoopio.HadoopSeekableInputStream
 
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
CloseableIterator.BreakableFilterResult - Enum Class in io.delta.kernel.utils
Represents the result of applying the filter condition in the CloseableIterator.breakableFilter(Function) method of a CloseableIterator.
CollationIdentifier - Class in io.delta.kernel.types
Identifies collation for string type.
COLLATIONS_METADATA_KEY - Static variable in class io.delta.kernel.types.StructField
 
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.
ColumnarBatch - Interface in io.delta.kernel.data
Represents zero or more rows of records with same schema type.
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 interface io.delta.kernel.Transaction
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
 
contains(String) - Method in class io.delta.kernel.types.FieldMetadata
 
containsNull() - Method in class io.delta.kernel.types.ArrayType
 
create(boolean) - Method in interface io.delta.kernel.defaults.engine.fileio.OutputFile
Get the output stream to write to the file.
create(boolean) - Method in class io.delta.kernel.defaults.engine.hadoopio.HadoopOutputFile
 
create(FileIO) - Static method in class io.delta.kernel.defaults.engine.DefaultEngine
Create an instance of DefaultEngine.
create(Configuration) - Static method in class io.delta.kernel.defaults.engine.DefaultEngine
Create an instance of DefaultEngine.
CREATE_TABLE - Enum constant in enum class io.delta.kernel.Operation
Recorded when the table is created.
createPrimitive(String) - Static method in class io.delta.kernel.types.BasePrimitiveType
Create a primitive type DataType
createSelectionVector(boolean[], int, int) - Method in class io.delta.kernel.defaults.engine.DefaultExpressionHandler
 
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 interface io.delta.kernel.Table
Create a TransactionBuilder which can create a Transaction object to mutate the table.

D

DataFileStatistics - Class in io.delta.kernel.statistics
Encapsulates statistics for a data file in a Delta Lake table and provides methods to serialize those stats to JSON with basic physical-type validation.
DataFileStatistics(long, Map<Column, Literal>, Map<Column, Literal>, Map<Column, Long>) - Constructor for class io.delta.kernel.statistics.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.
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.
DATE - Static variable in class io.delta.kernel.types.DateType
 
DateType - Class in io.delta.kernel.types
A date type, supporting "0001-01-01" through "9999-12-31".
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
 
DefaultEngine - Class in io.delta.kernel.defaults.engine
Default implementation of Engine based on Hadoop APIs.
DefaultExpressionHandler - Class in io.delta.kernel.defaults.engine
Default implementation of ExpressionHandler
DefaultExpressionHandler() - Constructor for class io.delta.kernel.defaults.engine.DefaultExpressionHandler
 
DefaultFileSystemClient - Class in io.delta.kernel.defaults.engine
Default implementation of FileSystemClient based on Hadoop APIs.
DefaultFileSystemClient(FileIO) - Constructor for class io.delta.kernel.defaults.engine.DefaultFileSystemClient
Create an instance of the default FileSystemClient implementation.
DefaultJsonHandler - Class in io.delta.kernel.defaults.engine
Default implementation of JsonHandler based on Hadoop APIs.
DefaultJsonHandler(FileIO) - Constructor for class io.delta.kernel.defaults.engine.DefaultJsonHandler
 
DefaultParquetHandler - Class in io.delta.kernel.defaults.engine
Default implementation of ParquetHandler based on Hadoop APIs.
DefaultParquetHandler(FileIO) - Constructor for class io.delta.kernel.defaults.engine.DefaultParquetHandler
Create an instance of default ParquetHandler implementation.
delete(String) - Method in class io.delta.kernel.defaults.engine.DefaultFileSystemClient
 
delete(String) - Method in interface io.delta.kernel.defaults.engine.fileio.FileIO
Delete the file at given path.
delete(String) - Method in class io.delta.kernel.defaults.engine.hadoopio.HadoopFileIO
 
delete(String) - Method in interface io.delta.kernel.engine.FileSystemClient
Delete the file at given path.
DeltaOperationReport - Interface in io.delta.kernel.metrics
Defines the common fields that are shared by reports for Delta operations
DomainDoesNotExistException - Exception in io.delta.kernel.exceptions
Thrown when attempting to remove a domain metadata that does not exist in the read snapshot.
DomainDoesNotExistException(String, String, long) - Constructor for exception io.delta.kernel.exceptions.DomainDoesNotExistException
 
DOUBLE - Static variable in class io.delta.kernel.types.DoubleType
 
DoubleType - Class in io.delta.kernel.types
The data type representing double type values.

E

empty() - Static method in class io.delta.kernel.types.FieldMetadata
 
emptyIterable() - Static method in interface io.delta.kernel.utils.CloseableIterable
Return an CloseableIterable object for an empty collection.
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.expressions.Literal
 
equals(Object) - Method in class io.delta.kernel.statistics.DataFileStatistics
 
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.CollationIdentifier
Collation identifiers are identical when the provider, name, and version are the same.
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.StringType
 
equals(Object) - Method in class io.delta.kernel.types.StructField
 
equals(Object) - Method in class io.delta.kernel.types.StructType
 
equals(Object) - Method in class io.delta.kernel.utils.FileStatus
 
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 Interface in io.delta.kernel.annotation
APIs that are meant to evolve towards becoming stable APIs, but are not stable APIs yet.
EXCLUDE - Enum constant in enum class io.delta.kernel.utils.CloseableIterator.BreakableFilterResult
Indicates that the current element should be excluded from the resulting iterator produced by CloseableIterator.breakableFilter(Function).
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.

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
 
FileIO - Interface in io.delta.kernel.defaults.engine.fileio
Interface for file IO operations.
FileReadRequest - Interface in io.delta.kernel.engine
Represents a request to read a range of bytes from a given file.
FileSizeHistogramResult - Interface in io.delta.kernel.metrics
Stores the file size histogram information to track file size distribution and their counts.
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
Returns a new CloseableIterator that includes only the elements of this iterator for which the given mapper function returns true.
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
 
FLOAT - Static variable in class io.delta.kernel.types.FloatType
 
FloatType - Class in io.delta.kernel.types
The data type representing float type values.
flush() - Method in class io.delta.kernel.defaults.engine.hadoopio.HadoopPositionOutputStream
 
forEach(Consumer<? super T>) - Method in interface io.delta.kernel.utils.CloseableIterable
 
forPath(Engine, String) - Static method in interface io.delta.kernel.Table
Instantiate a table object for the Delta Lake table at the given path.
fromMetadata(FieldMetadata) - Method in class io.delta.kernel.types.FieldMetadata.Builder
Adds all metadata from meta.metadata to the builder's metadata.
fromString(String) - Static method in class io.delta.kernel.types.CollationIdentifier
 

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.
get(String) - Method in class io.delta.kernel.types.FieldMetadata
 
get(String) - Method in class io.delta.kernel.types.StructType
 
getAllPrimitiveTypes() - Static method in class io.delta.kernel.types.BasePrimitiveType
For testing only
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.
getBaseSnapshotVersion() - Method in interface io.delta.kernel.metrics.TransactionReport
The version of the table the transaction was created from.
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.
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(String) - Method in class io.delta.kernel.types.FieldMetadata
 
getBooleanArray(String) - Method in class io.delta.kernel.types.FieldMetadata
 
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.
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
 
getCollationIdentifier() - Method in class io.delta.kernel.types.StringType
 
getColumnVector(int) - Method in interface io.delta.kernel.data.ColumnarBatch
Return the ColumnVector for the given ordinal in the columnar batch.
getCommittedVersion() - Method in interface io.delta.kernel.metrics.TransactionReport
 
getConf(String) - Method in interface io.delta.kernel.defaults.engine.fileio.FileIO
Get the configuration value for the given key.
getConf(String) - Method in class io.delta.kernel.defaults.engine.hadoopio.HadoopFileIO
 
getData() - Method in class io.delta.kernel.data.FilteredColumnarBatch
Return the data as ColumnarBatch.
getDataSkippingFilter() - Method in interface io.delta.kernel.metrics.ScanReport
 
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.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.
getDescription() - Method in enum class io.delta.kernel.Operation
Returns the string that will be recorded in the transaction log.
getDomainMetadata(String) - Method in interface io.delta.kernel.Snapshot
Returns the configuration for the provided domain if it exists in the snapshot.
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(String) - Method in class io.delta.kernel.types.FieldMetadata
 
getDoubleArray(String) - Method in class io.delta.kernel.types.FieldMetadata
 
getElementField() - Method in class io.delta.kernel.types.ArrayType
 
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 interface io.delta.kernel.metrics.TransactionReport
 
getEntries() - Method in class io.delta.kernel.types.FieldMetadata
 
getEvaluator(StructType, Expression, DataType) - Method in class io.delta.kernel.defaults.engine.DefaultExpressionHandler
 
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.
getException() - Method in interface io.delta.kernel.metrics.DeltaOperationReport
 
getExpressionHandler() - Method in class io.delta.kernel.defaults.engine.DefaultEngine
 
getExpressionHandler() - Method in interface io.delta.kernel.engine.Engine
Get the connector provided ExpressionHandler.
getFileCounts() - Method in interface io.delta.kernel.metrics.FileSizeHistogramResult
The total number of files in each bin of FileSizeHistogramResult.getSortedBinBoundaries()
getFileStatus(String) - Method in interface io.delta.kernel.defaults.engine.fileio.FileIO
Get the metadata of the file at the given path.
getFileStatus(String) - Method in class io.delta.kernel.defaults.engine.hadoopio.HadoopFileIO
 
getFileSystemClient() - Method in class io.delta.kernel.defaults.engine.DefaultEngine
 
getFileSystemClient() - Method in interface io.delta.kernel.engine.Engine
Get the connector provided FileSystemClient.
getFilter() - Method in interface io.delta.kernel.metrics.ScanReport
 
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.
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.
getIsFullyConsumed() - Method in interface io.delta.kernel.metrics.ScanReport
Whether the scan file iterator had been fully consumed when it was closed.
getJsonHandler() - Method in class io.delta.kernel.defaults.engine.DefaultEngine
 
getJsonHandler() - Method in interface io.delta.kernel.engine.Engine
Get the connector provided JsonHandler.
getKeyField() - Method in class io.delta.kernel.types.MapType
 
getKeys() - Method in interface io.delta.kernel.data.MapValue
A ColumnVector containing the keys.
getKeyType() - Method in class io.delta.kernel.types.MapType
 
getLatestSnapshot(Engine) - Method in interface io.delta.kernel.Table
Get the latest snapshot of the table.
getLeft() - Method in class io.delta.kernel.expressions.And
 
getLeft() - Method in class io.delta.kernel.expressions.Or
 
getLoadInitialDeltaActionsDurationNs() - Method in interface io.delta.kernel.metrics.SnapshotMetricsResult
 
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(String) - Method in class io.delta.kernel.types.FieldMetadata
 
getLongArray(String) - Method in class io.delta.kernel.types.FieldMetadata
 
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.
getMaxValues() - Method in class io.delta.kernel.statistics.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.types.StructField
 
getMetadata(String) - Method in class io.delta.kernel.types.FieldMetadata.Builder
 
getMetadata(String) - Method in class io.delta.kernel.types.FieldMetadata
 
getMetadataArray(String) - Method in class io.delta.kernel.types.FieldMetadata
 
getMetricsReporters() - Method in class io.delta.kernel.defaults.engine.DefaultEngine
 
getMetricsReporters() - Method in interface io.delta.kernel.engine.Engine
Get the engine's MetricsReporter instances to push reports to.
getMinValues() - Method in class io.delta.kernel.statistics.DataFileStatistics
Get the minimum values of the columns in the data file.
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.types.CollationIdentifier
 
getName() - Method in class io.delta.kernel.types.StructField
 
getNames() - Method in class io.delta.kernel.expressions.Column
 
getNullCount() - Method in class io.delta.kernel.statistics.DataFileStatistics
Get the number of nulls of columns in the data file.
getNumActiveAddFiles() - Method in interface io.delta.kernel.metrics.ScanMetricsResult
 
getNumAddFiles() - Method in interface io.delta.kernel.metrics.TransactionMetricsResult
 
getNumAddFilesSeen() - Method in interface io.delta.kernel.metrics.ScanMetricsResult
 
getNumAddFilesSeenFromDeltaFiles() - Method in interface io.delta.kernel.metrics.ScanMetricsResult
 
getNumCommitAttempts() - Method in interface io.delta.kernel.metrics.TransactionMetricsResult
 
getNumDuplicateAddFiles() - Method in interface io.delta.kernel.metrics.ScanMetricsResult
Returns the number of duplicate AddFile actions seen during log replay.
getNumRecords() - Method in class io.delta.kernel.statistics.DataFileStatistics
Get the number of records in the data file.
getNumRemoveFiles() - Method in interface io.delta.kernel.metrics.TransactionMetricsResult
 
getNumRemoveFilesSeenFromDeltaFiles() - Method in interface io.delta.kernel.metrics.ScanMetricsResult
 
getNumTotalActions() - Method in interface io.delta.kernel.metrics.TransactionMetricsResult
 
getOperation() - Method in interface io.delta.kernel.metrics.TransactionReport
 
getOperationType() - Method in interface io.delta.kernel.metrics.DeltaOperationReport
 
getOperationType() - Method in interface io.delta.kernel.metrics.ScanReport
 
getOperationType() - Method in interface io.delta.kernel.metrics.SnapshotReport
 
getOperationType() - Method in interface io.delta.kernel.metrics.TransactionReport
 
getParquetHandler() - Method in class io.delta.kernel.defaults.engine.DefaultEngine
 
getParquetHandler() - Method in interface io.delta.kernel.engine.Engine
Get the connector provided ParquetHandler.
getPartitionColumnNames() - Method in interface io.delta.kernel.Snapshot
Get the names of the partition columns in the Delta table at this snapshot.
getPartitionColumns(Engine) - Method in interface io.delta.kernel.Transaction
Get the list of logical names of the partition columns.
getPartitionPredicate() - Method in interface io.delta.kernel.metrics.ScanReport
 
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.utils.FileStatus
Get the path to the file.
getPath(Engine) - Method in interface io.delta.kernel.Table
The fully qualified path of this Table instance.
getPos() - Method in class io.delta.kernel.defaults.engine.fileio.PositionOutputStream
Get the current position in the stream.
getPos() - Method in class io.delta.kernel.defaults.engine.fileio.SeekableInputStream
Get the current position in the stream.
getPos() - Method in class io.delta.kernel.defaults.engine.hadoopio.HadoopPositionOutputStream
 
getPos() - Method in class io.delta.kernel.defaults.engine.hadoopio.HadoopSeekableInputStream
 
getPostCommitHooks() - Method in class io.delta.kernel.TransactionCommitResult
Operations for connector to trigger post-commit.
getPrecision() - Method in class io.delta.kernel.types.DecimalType
 
getPredicateEvaluator(StructType, Predicate) - Method in class io.delta.kernel.defaults.engine.DefaultExpressionHandler
 
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).
getProvidedTimestamp() - Method in interface io.delta.kernel.metrics.SnapshotReport
 
getProvider() - Method in class io.delta.kernel.types.CollationIdentifier
 
getReadLength() - Method in interface io.delta.kernel.engine.FileReadRequest
Get the length of the data to read from the file starting at the startOffset.
getReadSchema() - Method in interface io.delta.kernel.metrics.ScanReport
 
getReadTableVersion() - Method in interface io.delta.kernel.Transaction
Gets the latest version of the table used as the base of this transaction.
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.
getReportUUID() - Method in interface io.delta.kernel.metrics.DeltaOperationReport
 
getRight() - Method in class io.delta.kernel.expressions.And
 
getRight() - Method in class io.delta.kernel.expressions.Or
 
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() - 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 interface io.delta.kernel.Scan
Get an iterator of data files to scan.
getScanMetrics() - Method in interface io.delta.kernel.metrics.ScanReport
 
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 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.
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.
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.
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.utils.FileStatus
Get the size of the file in bytes.
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 interface io.delta.kernel.Table
Get the snapshot at the given versionId.
getSnapshotMetrics() - Method in interface io.delta.kernel.metrics.SnapshotReport
 
getSnapshotReportUUID() - Method in interface io.delta.kernel.metrics.ScanReport
 
getSnapshotReportUUID() - Method in interface io.delta.kernel.metrics.TransactionReport
 
getSortedBinBoundaries() - Method in interface io.delta.kernel.metrics.FileSizeHistogramResult
Sorted list of bin boundaries where each element represents the start of the bin (inclusive) and the next element represents the end of the bin (exclusive).
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.
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(String) - Method in class io.delta.kernel.types.FieldMetadata
 
getStringArray(String) - Method in class io.delta.kernel.types.FieldMetadata
 
getStruct(int) - Method in interface io.delta.kernel.data.Row
Return struct value of the column located at the given ordinal.
getTableFileSizeHistogram() - Method in interface io.delta.kernel.metrics.TransactionMetricsResult
 
getTablePath() - Method in exception io.delta.kernel.exceptions.TableNotFoundException
 
getTablePath() - Method in interface io.delta.kernel.metrics.DeltaOperationReport
 
getTableSchema() - Method in interface io.delta.kernel.metrics.ScanReport
 
getTableVersion() - Method in interface io.delta.kernel.metrics.ScanReport
 
getTargetDirectory() - Method in interface io.delta.kernel.DataWriteContext
Returns the target directory where the data should be written.
getTimestamp(Engine) - Method in interface io.delta.kernel.Snapshot
Get the timestamp (in milliseconds since the Unix epoch) of the latest commit in this snapshot.
getTimestampToVersionResolutionDurationNs() - Method in interface io.delta.kernel.metrics.SnapshotMetricsResult
 
getTotalAddFilesSizeInBytes() - Method in interface io.delta.kernel.metrics.TransactionMetricsResult
 
getTotalBytes() - Method in interface io.delta.kernel.metrics.FileSizeHistogramResult
The total number of bytes in each bin of FileSizeHistogramResult.getSortedBinBoundaries()
getTotalCommitDurationNs() - Method in interface io.delta.kernel.metrics.TransactionMetricsResult
 
getTotalPlanningDurationNs() - Method in interface io.delta.kernel.metrics.ScanMetricsResult
Returns the total duration to find, filter, and consume the scan files.
getTotalRemoveFilesSizeInBytes() - Method in interface io.delta.kernel.metrics.TransactionMetricsResult
 
getTransactionMetrics() - Method in interface io.delta.kernel.metrics.TransactionReport
 
getTransactionMetrics() - Method in class io.delta.kernel.TransactionCommitResult
 
getTransactionState(Engine) - Method in interface io.delta.kernel.Transaction
Get the state of the transaction.
getType() - Method in interface io.delta.kernel.hook.PostCommitHook
 
getValue() - Method in class io.delta.kernel.expressions.Literal
Get the literal value.
getValueField() - Method in class io.delta.kernel.types.MapType
 
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 interface io.delta.kernel.metrics.SnapshotReport
For a time-travel by version query, this is the version provided.
getVersion() - Method in interface io.delta.kernel.Snapshot
Get the version of this snapshot in the table.
getVersion() - Method in class io.delta.kernel.TransactionCommitResult
Contains the version of the transaction committed as.
getVersion() - Method in class io.delta.kernel.types.CollationIdentifier
 
getWriteContext(Engine, Row, Map<String, Literal>) - Static method in interface io.delta.kernel.Transaction
Get the context for writing data into a table.

H

HadoopFileIO - Class in io.delta.kernel.defaults.engine.hadoopio
Implementation of FileIO based on Hadoop APIs.
HadoopFileIO(Configuration) - Constructor for class io.delta.kernel.defaults.engine.hadoopio.HadoopFileIO
 
HadoopInputFile - Class in io.delta.kernel.defaults.engine.hadoopio
 
HadoopInputFile(FileSystem, Path, long) - Constructor for class io.delta.kernel.defaults.engine.hadoopio.HadoopInputFile
 
HadoopOutputFile - Class in io.delta.kernel.defaults.engine.hadoopio
 
HadoopOutputFile(Configuration, String) - Constructor for class io.delta.kernel.defaults.engine.hadoopio.HadoopOutputFile
 
HadoopPositionOutputStream - Class in io.delta.kernel.defaults.engine.hadoopio
 
HadoopPositionOutputStream(FSDataOutputStream) - Constructor for class io.delta.kernel.defaults.engine.hadoopio.HadoopPositionOutputStream
 
HadoopSeekableInputStream - Class in io.delta.kernel.defaults.engine.hadoopio
 
HadoopSeekableInputStream(FSDataInputStream) - Constructor for class io.delta.kernel.defaults.engine.hadoopio.HadoopSeekableInputStream
 
hashCode() - Method in class io.delta.kernel.expressions.Column
 
hashCode() - Method in class io.delta.kernel.statistics.DataFileStatistics
 
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
 
hashCode() - Method in class io.delta.kernel.utils.FileStatus
 
hasNext() - Method in interface io.delta.kernel.utils.CloseableIterator
Returns true if the iteration has more elements.

I

INCLUDE - Enum constant in enum class io.delta.kernel.utils.CloseableIterator.BreakableFilterResult
Indicates that the current element should be included in the resulting iterator produced by CloseableIterator.breakableFilter(Function).
indexOf(String) - Method in class io.delta.kernel.types.StructType
 
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.
InputFile - Interface in io.delta.kernel.defaults.engine.fileio
Interface for reading a file and getting metadata about it.
INTEGER - Static variable in class io.delta.kernel.types.IntegerType
 
IntegerType - Class in io.delta.kernel.types
The data type representing integer type values.
InvalidConfigurationValueException - Exception in io.delta.kernel.exceptions
Thrown when an illegal value is specified for a table property.
InvalidConfigurationValueException(String, String, String) - Constructor for exception io.delta.kernel.exceptions.InvalidConfigurationValueException
 
InvalidTableException - Exception in io.delta.kernel.exceptions
Thrown when an invalid table is encountered; the table's log and/or checkpoint files are in an invalid state.
InvalidTableException(String, String) - Constructor for exception io.delta.kernel.exceptions.InvalidTableException
 
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.defaults.engine - package io.delta.kernel.defaults.engine
Default implementation of Engine interface and the sub-interfaces exposed by the Engine.
io.delta.kernel.defaults.engine.fileio - package io.delta.kernel.defaults.engine.fileio
 
io.delta.kernel.defaults.engine.hadoopio - package io.delta.kernel.defaults.engine.hadoopio
 
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.hook - package io.delta.kernel.hook
 
io.delta.kernel.metrics - package io.delta.kernel.metrics
 
io.delta.kernel.statistics - package io.delta.kernel.statistics
 
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.
isDataColumn() - Method in class io.delta.kernel.types.StructField
 
isMetadataColumn() - Method in class io.delta.kernel.types.StructField
 
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
 
isPrimitiveType(String) - Static method in class io.delta.kernel.types.BasePrimitiveType
Is the given type name a primitive type?
isValueContainsNull() - Method in class io.delta.kernel.types.MapType
 
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

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

length() - Method in interface io.delta.kernel.defaults.engine.fileio.InputFile
Get the size of the file.
length() - Method in class io.delta.kernel.defaults.engine.hadoopio.HadoopInputFile
 
length() - Method in class io.delta.kernel.types.StructType
 
listFrom(String) - Method in class io.delta.kernel.defaults.engine.DefaultFileSystemClient
 
listFrom(String) - Method in interface io.delta.kernel.defaults.engine.fileio.FileIO
List the paths in the same directory that are lexicographically greater or equal to (UTF-8 sorting) the given `path`.
listFrom(String) - Method in class io.delta.kernel.defaults.engine.hadoopio.HadoopFileIO
 
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`.
Literal - Class in io.delta.kernel.expressions
A literal value.
LOG_COMPACTION - Enum constant in enum class io.delta.kernel.hook.PostCommitHook.PostCommitHookType
Writes a log compaction file that merges a range of commit JSON files into a single file.
LoggingMetricsReporter - Class in io.delta.kernel.defaults.engine
An implementation of MetricsReporter that logs the reports (as JSON) to Log4J at the info level.
LoggingMetricsReporter() - Constructor for class io.delta.kernel.defaults.engine.LoggingMetricsReporter
 
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

MANUAL_UPDATE - Enum constant in enum class 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
 
MapType(StructField, StructField) - 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.
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 - 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
 
MetricsReport - Interface in io.delta.kernel.metrics
Interface containing the metrics for a given operation
MetricsReporter - Interface in io.delta.kernel.engine
Interface for reporting metrics for operations to a Delta table
MICROSECONDS_PER_SECOND - Static variable in class io.delta.kernel.statistics.DataFileStatistics
 
mkdirs(String) - Method in class io.delta.kernel.defaults.engine.DefaultFileSystemClient
 
mkdirs(String) - Method in interface io.delta.kernel.defaults.engine.fileio.FileIO
Create a directory at the given path including parent directories.
mkdirs(String) - Method in class io.delta.kernel.defaults.engine.hadoopio.HadoopFileIO
 
mkdirs(String) - Method in interface io.delta.kernel.engine.FileSystemClient
Create a directory at the given path including parent directories.

N

NANOSECONDS_PER_MICROSECOND - Static variable in class io.delta.kernel.statistics.DataFileStatistics
 
newInputFile(String, long) - Method in interface io.delta.kernel.defaults.engine.fileio.FileIO
Get an InputFile for file at given path which can be used to read the file from any arbitrary position in the file.
newInputFile(String, long) - Method in class io.delta.kernel.defaults.engine.hadoopio.HadoopFileIO
 
newOutputFile(String) - Method in interface io.delta.kernel.defaults.engine.fileio.FileIO
Create a OutputFile to write new file at the given path.
newOutputFile(String) - Method in class io.delta.kernel.defaults.engine.hadoopio.HadoopFileIO
 
newStream() - Method in interface io.delta.kernel.defaults.engine.fileio.InputFile
Get the input stream to read the file.
newStream() - Method in class io.delta.kernel.defaults.engine.hadoopio.HadoopInputFile
 
next() - Method in interface io.delta.kernel.utils.CloseableIterator
Returns the next element in the iteration.

O

of(String) - Static method in class io.delta.kernel.utils.FileStatus
Create a FileStatus with the given path with size and modification time set to 0.
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.
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 Class 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
 
OutputFile - Interface in io.delta.kernel.defaults.engine.fileio
Interface for writing to a file and getting metadata about it.

P

ParquetHandler - Interface in io.delta.kernel.engine
Provides Parquet file related functionalities to Delta Kernel.
parseJson(ColumnVector, StructType, Optional<ColumnVector>) - Method in class io.delta.kernel.defaults.engine.DefaultJsonHandler
 
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.
partitionExists(Engine, Snapshot, Predicate) - Static method in class io.delta.kernel.utils.PartitionUtils
Check if a partition exists (i.e.
PartitionUtils - Class in io.delta.kernel.utils
 
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.
path() - Method in interface io.delta.kernel.defaults.engine.fileio.InputFile
Get the path of the file.
path() - Method in interface io.delta.kernel.defaults.engine.fileio.OutputFile
Get the path of the file.
path() - Method in class io.delta.kernel.defaults.engine.hadoopio.HadoopInputFile
 
path() - Method in class io.delta.kernel.defaults.engine.hadoopio.HadoopOutputFile
 
PositionOutputStream - Class in io.delta.kernel.defaults.engine.fileio
Extends OutputStream to provide the current position in the stream.
PositionOutputStream() - Constructor for class io.delta.kernel.defaults.engine.fileio.PositionOutputStream
 
PostCommitHook - Interface in io.delta.kernel.hook
A hook for executing operation after a transaction commit.
PostCommitHook.PostCommitHookType - Enum Class in io.delta.kernel.hook
 
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.
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
 
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() - Method in class io.delta.kernel.defaults.engine.hadoopio.HadoopSeekableInputStream
 
read(byte[]) - Method in class io.delta.kernel.defaults.engine.hadoopio.HadoopSeekableInputStream
 
read(byte[], int, int) - Method in class io.delta.kernel.defaults.engine.hadoopio.HadoopSeekableInputStream
 
readFiles(CloseableIterator<FileReadRequest>) - Method in class io.delta.kernel.defaults.engine.DefaultFileSystemClient
 
readFiles(CloseableIterator<FileReadRequest>) - Method in interface io.delta.kernel.engine.FileSystemClient
Return an iterator of byte streams one for each read request in readRequests.
readFully(byte[], int, int) - Method in class io.delta.kernel.defaults.engine.fileio.SeekableInputStream
Read fully len bytes into the buffer b.
readFully(byte[], int, int) - Method in class io.delta.kernel.defaults.engine.hadoopio.HadoopSeekableInputStream
 
readJsonFiles(CloseableIterator<FileStatus>, StructType, Optional<Predicate>) - Method in class io.delta.kernel.defaults.engine.DefaultJsonHandler
 
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.
readParquetFiles(CloseableIterator<FileStatus>, StructType, Optional<Predicate>) - Method in class io.delta.kernel.defaults.engine.DefaultParquetHandler
 
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.
removeDomainMetadata(String) - Method in interface io.delta.kernel.Transaction
Mark the domain metadata with identifier domain as removed in this transaction.
REPLACE_TABLE - Enum constant in enum class io.delta.kernel.Operation
Recorded during REPLACE operation (may also be considered an overwrite)
report(MetricsReport) - Method in class io.delta.kernel.defaults.engine.LoggingMetricsReporter
 
report(MetricsReport) - Method in interface io.delta.kernel.engine.MetricsReporter
Indicates that an operation is done by reporting a MetricsReport
resolvePath(String) - Method in class io.delta.kernel.defaults.engine.DefaultFileSystemClient
 
resolvePath(String) - Method in interface io.delta.kernel.defaults.engine.fileio.FileIO
Resolve the given path to a fully qualified path.
resolvePath(String) - Method in class io.delta.kernel.defaults.engine.hadoopio.HadoopFileIO
 
resolvePath(String) - Method in interface io.delta.kernel.engine.FileSystemClient
Resolve the given path to a fully qualified path.
Row - Interface in io.delta.kernel.data
Represent a single record

S

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.
ScanBuilder - Interface in io.delta.kernel
Builder to construct Scan object.
ScanMetricsResult - Interface in io.delta.kernel.metrics
Stores the metrics results for a ScanReport
ScanReport - Interface in io.delta.kernel.metrics
Defines the metadata and metrics for a Scan MetricsReport
seek(long) - Method in class io.delta.kernel.defaults.engine.fileio.SeekableInputStream
Seek to a new position in the stream.
seek(long) - Method in class io.delta.kernel.defaults.engine.hadoopio.HadoopSeekableInputStream
 
SeekableInputStream - Class in io.delta.kernel.defaults.engine.fileio
Extends InputStream to provide the current position in the stream and seek to a new position.
SeekableInputStream() - Constructor for class io.delta.kernel.defaults.engine.fileio.SeekableInputStream
 
serializeAsJson(StructType) - Method in class io.delta.kernel.statistics.DataFileStatistics
Serializes the statistics as a JSON string.
SHORT - Static variable in class io.delta.kernel.types.ShortType
 
ShortType - Class in io.delta.kernel.types
The data type representing short type values.
skip(long) - Method in class io.delta.kernel.defaults.engine.hadoopio.HadoopSeekableInputStream
 
Snapshot - Interface in io.delta.kernel
Represents the snapshot of a Delta table.
SnapshotMetricsResult - Interface in io.delta.kernel.metrics
Stores the metrics results for a SnapshotReport
SnapshotReport - Interface in io.delta.kernel.metrics
Defines the metadata and metrics for a snapshot construction MetricsReport
spliterator() - Method in interface io.delta.kernel.utils.CloseableIterable
 
STREAMING_UPDATE - Enum constant in enum class io.delta.kernel.Operation
Recorded during streaming inserts.
STRING - Static variable in class io.delta.kernel.types.StringType
 
StringType - Class in io.delta.kernel.types
The data type representing string type values.
StringType(CollationIdentifier) - Constructor for class io.delta.kernel.types.StringType
 
StringType(String) - Constructor for class io.delta.kernel.types.StringType
 
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
 
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
 

T

Table - Interface in io.delta.kernel
Represents the Delta Lake table for a given path.
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
 
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
 
takeWhile(Function<T, Boolean>) - Method in interface io.delta.kernel.utils.CloseableIterator
Returns a new CloseableIterator that includes elements from this iterator as long as the given mapper function returns true.
threadSafeInvoke(Engine) - Method in interface io.delta.kernel.hook.PostCommitHook
Invokes the post commit operation whose implementation must be thread safe.
TIMESTAMP - Static variable in class io.delta.kernel.types.TimestampType
 
TIMESTAMP_NTZ - Static variable in class io.delta.kernel.types.TimestampNTZType
 
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.
toInMemoryList() - Method in interface io.delta.kernel.utils.CloseableIterator
Collects all elements from this CloseableIterator into a List.
toJson() - Method in class io.delta.kernel.types.StructType
Convert the struct type to Delta protocol specified serialization format.
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.statistics.DataFileStatistics
 
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.CollationIdentifier
 
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
 
toString() - Method in class io.delta.kernel.utils.DataFileStatus
 
toString() - Method in class io.delta.kernel.utils.FileStatus
 
toStringWithoutVersion() - Method in class io.delta.kernel.types.CollationIdentifier
 
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.
TransactionCommitResult - Class in io.delta.kernel
Contains the result of a successful transaction commit.
TransactionCommitResult(long, List<PostCommitHook>, TransactionMetricsResult) - Constructor for class io.delta.kernel.TransactionCommitResult
 
TransactionMetricsResult - Interface in io.delta.kernel.metrics
Stores the metrics results for a TransactionReport
TransactionReport - Interface in io.delta.kernel.metrics
Defines the metadata and metrics for a transaction MetricsReport
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.

U

UnknownConfigurationException - Exception in io.delta.kernel.exceptions
Thrown when an unknown configuration key is specified.
UnknownConfigurationException(String) - Constructor for exception io.delta.kernel.exceptions.UnknownConfigurationException
 
USER_DEFAULT - Static variable in class io.delta.kernel.types.DecimalType
 

V

valueOf(String) - Static method in enum class io.delta.kernel.hook.PostCommitHook.PostCommitHookType
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class io.delta.kernel.Operation
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class io.delta.kernel.utils.CloseableIterator.BreakableFilterResult
Returns the enum constant of this class with the specified name.
values() - Static method in enum class io.delta.kernel.hook.PostCommitHook.PostCommitHookType
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class io.delta.kernel.Operation
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class io.delta.kernel.utils.CloseableIterator.BreakableFilterResult
Returns an array containing the constants of this enum class, in the order they are declared.
VARIANT - Static variable in class io.delta.kernel.types.VariantType
 
VariantType - Class in io.delta.kernel.types
A logical variant type.

W

withClusteringColumns(Engine, List<Column>) - Method in interface io.delta.kernel.TransactionBuilder
Set the list of clustering columns when create a new clustered table.
withDeletedColumnAt(int) - Method in interface io.delta.kernel.data.ColumnarBatch
Return a copy of this ColumnarBatch with the column at given ordinal removed.
withDomainMetadataSupported() - Method in interface io.delta.kernel.TransactionBuilder
Enables support for Domain Metadata on this table if it is not supported already.
withFilter(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.
withLogCompactionInverval(int) - Method in interface io.delta.kernel.TransactionBuilder
Set the number of commits between log compactions.
withMaxRetries(int) - Method in interface io.delta.kernel.TransactionBuilder
Set the maximum number of times to retry a transaction if a concurrent write is detected.
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.
withNewMetadata(FieldMetadata) - Method in class io.delta.kernel.types.StructField
 
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 interface io.delta.kernel.TransactionBuilder
Set the list of partitions columns when create a new partitioned table.
withReadSchema(StructType) - Method in interface io.delta.kernel.ScanBuilder
Apply the given readSchema.
withSchema(Engine, StructType) - Method in interface io.delta.kernel.TransactionBuilder
Set the schema of the table.
withTableProperties(Engine, Map<String, String>) - Method in interface io.delta.kernel.TransactionBuilder
Set the table properties for the table.
withTablePropertiesRemoved(Set<String>) - Method in interface io.delta.kernel.TransactionBuilder
Unset the provided table properties on the table.
withTransactionId(Engine, String, long) - Method in interface io.delta.kernel.TransactionBuilder
Set the transaction identifier for idempotent writes.
write(byte[]) - Method in class io.delta.kernel.defaults.engine.hadoopio.HadoopPositionOutputStream
 
write(byte[], int, int) - Method in class io.delta.kernel.defaults.engine.hadoopio.HadoopPositionOutputStream
 
write(int) - Method in class io.delta.kernel.defaults.engine.hadoopio.HadoopPositionOutputStream
 
WRITE - Enum constant in enum class io.delta.kernel.Operation
Recorded during batch inserts.
writeAtomically(CloseableIterator<String>, boolean) - Method in interface io.delta.kernel.defaults.engine.fileio.OutputFile
Atomically write (either write is completely or don't write all - i.e.
writeAtomically(CloseableIterator<String>, boolean) - Method in class io.delta.kernel.defaults.engine.hadoopio.HadoopOutputFile
 
writeJsonFileAtomically(String, CloseableIterator<Row>, boolean) - Method in class io.delta.kernel.defaults.engine.DefaultJsonHandler
Makes use of LogStore implementations in `delta-storage` to atomically write the data to a file depending upon the destination filesystem.
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.
writeParquetFileAtomically(String, CloseableIterator<FilteredColumnarBatch>) - Method in class io.delta.kernel.defaults.engine.DefaultParquetHandler
Makes use of LogStore implementations in `delta-storage` to atomically write the data to a file depending upon the destination filesystem.
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 class io.delta.kernel.defaults.engine.DefaultParquetHandler
 
writeParquetFiles(String, CloseableIterator<FilteredColumnarBatch>, List<Column>) - Method in interface io.delta.kernel.engine.ParquetHandler
Write the given data batches to a Parquet files.
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