Skip navigation links

Back to Paimon Website

A B C D E F G H I J K L M N O P Q R S T U V W X Y Z _ 

A

abort() - Method in interface org.apache.paimon.io.FileWriter
Abort to clear orphan file(s) if encounter any error.
abort() - Method in class org.apache.paimon.io.RollingFileWriter
 
abort() - Method in class org.apache.paimon.io.SingleFileWriter
 
abort() - Method in class org.apache.paimon.io.SingleFileWriter.AbortExecutor
 
abort(List<CommitMessage>) - Method in interface org.apache.paimon.operation.FileStoreCommit
Abort an unsuccessful commit.
abort(List<CommitMessage>) - Method in class org.apache.paimon.operation.FileStoreCommitImpl
 
abort(List<CommitMessage>) - Method in interface org.apache.paimon.table.sink.TableCommit
Abort an unsuccessful commit.
abort(List<CommitMessage>) - Method in class org.apache.paimon.table.sink.TableCommitImpl
 
abortExecutor() - Method in class org.apache.paimon.io.SingleFileWriter
 
abortJob(JobContext, int) - Method in class org.apache.paimon.hive.mapred.PaimonOutputCommitter
 
abortTask(TaskAttemptContext) - Method in class org.apache.paimon.hive.mapred.PaimonOutputCommitter
 
absoluteTimeMillis() - Method in class org.apache.paimon.benchmark.metric.cpu.clock.Clock
 
absoluteTimeMillis() - Method in class org.apache.paimon.benchmark.metric.cpu.clock.SystemClock
 
ABSTRACT - Static variable in class org.apache.paimon.codegen.codesplit.JavaLexer
 
ABSTRACT - Static variable in class org.apache.paimon.codegen.codesplit.JavaLexer
 
ABSTRACT - Static variable in class org.apache.paimon.codegen.codesplit.JavaParser
 
ABSTRACT - Static variable in class org.apache.paimon.codegen.codesplit.JavaParser
 
ABSTRACT() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ClassOrInterfaceModifierContext
 
ABSTRACT() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ClassOrInterfaceModifierContext
 
ABSTRACT() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.InterfaceMethodModifierContext
 
ABSTRACT() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.InterfaceMethodModifierContext
 
AbstractBinaryExternalMerger<Entry> - Class in org.apache.paimon.sort
Spilled files Merger of BinaryExternalSortBuffer.
AbstractBinaryExternalMerger(IOManager, int, int, SpillChannelManager, BlockCompressionFactory, int) - Constructor for class org.apache.paimon.sort.AbstractBinaryExternalMerger
 
AbstractCatalog - Class in org.apache.paimon.catalog
Common implementation of Catalog.
AbstractCatalog(FileIO) - Constructor for class org.apache.paimon.catalog.AbstractCatalog
 
AbstractCatalog(FileIO, Options) - Constructor for class org.apache.paimon.catalog.AbstractCatalog
 
AbstractColumnReader<VECTOR extends WritableColumnVector> - Class in org.apache.paimon.format.parquet.reader
Abstract ColumnReader.
AbstractColumnReader(ColumnDescriptor, PageReader) - Constructor for class org.apache.paimon.format.parquet.reader.AbstractColumnReader
 
AbstractCompactRewriter - Class in org.apache.paimon.mergetree.compact
Common implementation of CompactRewriter.
AbstractCompactRewriter() - Constructor for class org.apache.paimon.mergetree.compact.AbstractCompactRewriter
 
AbstractDataFormat - Class in org.apache.paimon.flink.action.cdc.format
Data format common implementation of DataFormat.
AbstractDataFormat() - Constructor for class org.apache.paimon.flink.action.cdc.format.AbstractDataFormat
 
AbstractDataTableRead<T> - Class in org.apache.paimon.table.source
A InnerTableRead for data table.
AbstractDataTableRead(TableSchema) - Constructor for class org.apache.paimon.table.source.AbstractDataTableRead
 
AbstractDataTableScan - Class in org.apache.paimon.table.source
An abstraction layer above FileStoreScan to provide input split generation.
AbstractDataTableScan(CoreOptions, SnapshotReader) - Constructor for class org.apache.paimon.table.source.AbstractDataTableScan
 
AbstractDistributedLockDialect - Class in org.apache.paimon.jdbc
Jdbc distributed lock interface.
AbstractDistributedLockDialect() - Constructor for class org.apache.paimon.jdbc.AbstractDistributedLockDialect
 
AbstractFileIOChannel - Class in org.apache.paimon.disk
Abstract FileIOChannel to share some implementation.
AbstractFileIOChannel(FileIOChannel.ID, boolean) - Constructor for class org.apache.paimon.disk.AbstractFileIOChannel
Creates a new channel to the path indicated by the given ID.
AbstractFileStoreScan - Class in org.apache.paimon.operation
Default implementation of FileStoreScan.
AbstractFileStoreScan(RowType, ScanBucketFilter, SnapshotManager, SchemaManager, TableSchema, ManifestFile.Factory, ManifestList.Factory, int, boolean, Integer) - Constructor for class org.apache.paimon.operation.AbstractFileStoreScan
 
AbstractFileStoreWrite<T> - Class in org.apache.paimon.operation
Base FileStoreWrite implementation.
AbstractFileStoreWrite(String, SnapshotManager, FileStoreScan, IndexMaintainer.Factory<T>, DeletionVectorsMaintainer.Factory, String, int) - Constructor for class org.apache.paimon.operation.AbstractFileStoreWrite
 
AbstractFileStoreWrite.WriterContainer<T> - Class in org.apache.paimon.operation
RecordWriter with the snapshot id it is created upon and the identifier of its last modified commit.
AbstractFlinkTableFactory - Class in org.apache.paimon.flink
Abstract paimon factory to create table source and table sink.
AbstractFlinkTableFactory() - Constructor for class org.apache.paimon.flink.AbstractFlinkTableFactory
 
AbstractHeapVector - Class in org.apache.paimon.data.columnar.heap
Heap vector that nullable shared structure.
AbstractHeapVector(int) - Constructor for class org.apache.paimon.data.columnar.heap.AbstractHeapVector
 
AbstractIcebergCommitCallback - Class in org.apache.paimon.iceberg
A CommitCallback to create Iceberg compatible metadata, so Iceberg readers can read Paimon's RawFile.
AbstractIcebergCommitCallback(FileStoreTable, String) - Constructor for class org.apache.paimon.iceberg.AbstractIcebergCommitCallback
 
AbstractJsonDataFormat - Class in org.apache.paimon.flink.action.cdc.format
The message queue's record json deserialization class common implementation of DataFormat.
AbstractJsonDataFormat() - Constructor for class org.apache.paimon.flink.action.cdc.format.AbstractJsonDataFormat
 
AbstractJsonRecordParser - Class in org.apache.paimon.flink.action.cdc.format
Provides a base implementation for parsing messages of various formats into RichCdcMultiplexRecord objects.
AbstractJsonRecordParser(TypeMapping, List<ComputedColumn>) - Constructor for class org.apache.paimon.flink.action.cdc.format.AbstractJsonRecordParser
 
AbstractMemorySegmentPool - Class in org.apache.paimon.memory
Abstract memory segment pool.
AbstractMemorySegmentPool(long, int) - Constructor for class org.apache.paimon.memory.AbstractMemorySegmentPool
 
AbstractOrcColumnVector - Class in org.apache.paimon.format.orc.reader
This column vector is used to adapt hive's ColumnVector to Paimon's ColumnVector.
AbstractPagedInputView - Class in org.apache.paimon.data
The base class for all input views that are backed by multiple memory pages.
AbstractPagedInputView(MemorySegment, int) - Constructor for class org.apache.paimon.data.AbstractPagedInputView
Creates a new view that starts with the given segment.
AbstractPagedInputView() - Constructor for class org.apache.paimon.data.AbstractPagedInputView
Creates a new view that is initially not bound to a memory segment.
AbstractPagedOutputView - Class in org.apache.paimon.data
The base class for all output views that are backed by multiple memory pages.
AbstractPagedOutputView(MemorySegment, int) - Constructor for class org.apache.paimon.data.AbstractPagedOutputView
Creates a new output view that writes initially to the given initial segment.
AbstractRecordParser - Class in org.apache.paimon.flink.action.cdc.format
Provides a base implementation for parsing messages of various formats into RichCdcMultiplexRecord objects.
AbstractRecordParser(TypeMapping, List<ComputedColumn>) - Constructor for class org.apache.paimon.flink.action.cdc.format.AbstractRecordParser
 
AbstractRowDataSerializer<T extends InternalRow> - Class in org.apache.paimon.data.serializer
Row serializer, provided paged serialize paged method.
AbstractRowDataSerializer() - Constructor for class org.apache.paimon.data.serializer.AbstractRowDataSerializer
 
AbstractServerHandler<REQ extends MessageBody,RESP extends MessageBody> - Class in org.apache.paimon.service.network
The base class of every handler used by an NetworkServer.
AbstractServerHandler(NetworkServer<REQ, RESP>, MessageSerializer<REQ, RESP>, ServiceRequestStats) - Constructor for class org.apache.paimon.service.network.AbstractServerHandler
Create the handler.
AbstractSimpleColStatsCollector - Class in org.apache.paimon.statistics
Abstract base stats collector.
AbstractSimpleColStatsCollector() - Constructor for class org.apache.paimon.statistics.AbstractSimpleColStatsCollector
 
AbstractStartingScanner - Class in org.apache.paimon.table.source.snapshot
The abstract class for StartingScanner.
AbstractWritableVector - Class in org.apache.paimon.data.columnar.writable
Contains the shared structure for ColumnVectors, including NULL information and dictionary.
AbstractWritableVector() - Constructor for class org.apache.paimon.data.columnar.writable.AbstractWritableVector
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.AnnotationConstantRestContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.AnnotationConstantRestContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.AnnotationContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.AnnotationContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.AnnotationMethodOrConstantRestContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.AnnotationMethodOrConstantRestContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.AnnotationMethodRestContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.AnnotationMethodRestContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.AnnotationTypeBodyContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.AnnotationTypeBodyContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.AnnotationTypeDeclarationContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.AnnotationTypeDeclarationContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.AnnotationTypeElementDeclarationContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.AnnotationTypeElementDeclarationContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.AnnotationTypeElementRestContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.AnnotationTypeElementRestContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ArgumentsContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ArgumentsContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ArrayCreatorRestContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ArrayCreatorRestContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ArrayInitializerContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ArrayInitializerContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.BlockContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.BlockContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.BlockStatementContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.BlockStatementContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.CatchClauseContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.CatchClauseContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.CatchTypeContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.CatchTypeContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ClassBodyContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ClassBodyContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ClassBodyDeclarationContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ClassBodyDeclarationContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ClassCreatorRestContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ClassCreatorRestContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ClassDeclarationContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ClassDeclarationContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ClassOrInterfaceModifierContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ClassOrInterfaceModifierContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ClassOrInterfaceTypeContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ClassOrInterfaceTypeContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ClassTypeContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ClassTypeContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.CompilationUnitContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.CompilationUnitContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ConstantDeclaratorContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ConstantDeclaratorContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ConstDeclarationContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ConstDeclarationContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ConstructorCallContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ConstructorCallContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ConstructorDeclarationContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ConstructorDeclarationContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.CreatedNameContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.CreatedNameContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.CreatorContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.CreatorContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.DefaultValueContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.DefaultValueContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ElementValueArrayInitializerContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ElementValueArrayInitializerContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ElementValueContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ElementValueContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ElementValuePairContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ElementValuePairContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ElementValuePairsContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ElementValuePairsContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.EnhancedForControlContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.EnhancedForControlContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.EnumBodyDeclarationsContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.EnumBodyDeclarationsContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.EnumConstantContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.EnumConstantContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.EnumConstantsContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.EnumConstantsContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.EnumDeclarationContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.EnumDeclarationContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ExplicitGenericInvocationContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ExplicitGenericInvocationContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ExplicitGenericInvocationSuffixContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ExplicitGenericInvocationSuffixContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ExpressionContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ExpressionContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ExpressionListContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ExpressionListContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.FieldDeclarationContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.FieldDeclarationContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.FinallyBlockContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.FinallyBlockContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.FloatLiteralContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.FloatLiteralContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ForControlContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ForControlContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ForInitContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ForInitContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.FormalParameterContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.FormalParameterContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.FormalParameterListContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.FormalParameterListContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.FormalParametersContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.FormalParametersContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.GenericConstructorDeclarationContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.GenericConstructorDeclarationContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.GenericInterfaceMethodDeclarationContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.GenericInterfaceMethodDeclarationContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.GenericMethodDeclarationContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.GenericMethodDeclarationContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ImportDeclarationContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ImportDeclarationContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.InnerCreatorContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.InnerCreatorContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.IntegerLiteralContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.IntegerLiteralContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.InterfaceBodyContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.InterfaceBodyContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.InterfaceBodyDeclarationContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.InterfaceBodyDeclarationContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.InterfaceDeclarationContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.InterfaceDeclarationContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.InterfaceMemberDeclarationContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.InterfaceMemberDeclarationContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.InterfaceMethodDeclarationContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.InterfaceMethodDeclarationContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.InterfaceMethodModifierContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.InterfaceMethodModifierContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.LambdaBodyContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.LambdaBodyContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.LambdaExpressionContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.LambdaExpressionContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.LambdaParametersContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.LambdaParametersContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.LastFormalParameterContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.LastFormalParameterContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.LiteralContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.LiteralContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.LocalTypeDeclarationContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.LocalTypeDeclarationContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.LocalVariableDeclarationContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.LocalVariableDeclarationContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.MemberDeclarationContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.MemberDeclarationContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.MethodBodyContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.MethodBodyContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.MethodCallContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.MethodCallContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.MethodDeclarationContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.MethodDeclarationContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ModifierContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ModifierContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.NonWildcardTypeArgumentsContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.NonWildcardTypeArgumentsContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.NonWildcardTypeArgumentsOrDiamondContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.NonWildcardTypeArgumentsOrDiamondContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.PackageDeclarationContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.PackageDeclarationContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ParExpressionContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ParExpressionContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.PrimaryContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.PrimaryContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.PrimitiveTypeContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.PrimitiveTypeContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.QualifiedNameContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.QualifiedNameContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.QualifiedNameListContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.QualifiedNameListContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ResourceContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ResourceContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ResourcesContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ResourcesContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ResourceSpecificationContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ResourceSpecificationContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.StatementContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.StatementContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.SuperSuffixContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.SuperSuffixContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.SwitchBlockStatementGroupContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.SwitchBlockStatementGroupContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.SwitchLabelContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.SwitchLabelContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.TypeArgumentContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.TypeArgumentContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.TypeArgumentsContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.TypeArgumentsContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.TypeArgumentsOrDiamondContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.TypeArgumentsOrDiamondContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.TypeBoundContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.TypeBoundContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.TypeDeclarationContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.TypeDeclarationContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.TypeListContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.TypeListContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.TypeParameterContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.TypeParameterContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.TypeParametersContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.TypeParametersContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.TypeTypeContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.TypeTypeContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.TypeTypeOrVoidContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.TypeTypeOrVoidContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.VariableDeclaratorContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.VariableDeclaratorContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.VariableDeclaratorIdContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.VariableDeclaratorIdContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.VariableDeclaratorsContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.VariableDeclaratorsContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.VariableInitializerContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.VariableInitializerContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.VariableModifierContext
 
accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.VariableModifierContext
 
accept(Object) - Method in interface org.apache.paimon.fileindex.bitmap.BitmapFileIndexMeta.ThrowableConsumer
 
accept(KeyValue) - Method in interface org.apache.paimon.mergetree.WriteBuffer.KvConsumer
 
accept(DataTypeVisitor<R>) - Method in class org.apache.paimon.types.ArrayType
 
accept(DataTypeVisitor<R>) - Method in class org.apache.paimon.types.BigIntType
 
accept(DataTypeVisitor<R>) - Method in class org.apache.paimon.types.BinaryType
 
accept(DataTypeVisitor<R>) - Method in class org.apache.paimon.types.BooleanType
 
accept(DataTypeVisitor<R>) - Method in class org.apache.paimon.types.CharType
 
accept(DataTypeVisitor<R>) - Method in class org.apache.paimon.types.DataType
 
accept(DataTypeVisitor<R>) - Method in class org.apache.paimon.types.DateType
 
accept(DataTypeVisitor<R>) - Method in class org.apache.paimon.types.DecimalType
 
accept(DataTypeVisitor<R>) - Method in class org.apache.paimon.types.DoubleType
 
accept(DataTypeVisitor<R>) - Method in class org.apache.paimon.types.FloatType
 
accept(DataTypeVisitor<R>) - Method in class org.apache.paimon.types.IntType
 
accept(DataTypeVisitor<R>) - Method in class org.apache.paimon.types.LocalZonedTimestampType
 
accept(DataTypeVisitor<R>) - Method in class org.apache.paimon.types.MapType
 
accept(DataTypeVisitor<R>) - Method in class org.apache.paimon.types.MultisetType
 
accept(DataTypeVisitor<R>) - Method in class org.apache.paimon.types.RowType
 
accept(DataTypeVisitor<R>) - Method in class org.apache.paimon.types.SmallIntType
 
accept(DataTypeVisitor<R>) - Method in class org.apache.paimon.types.TimestampType
 
accept(DataTypeVisitor<R>) - Method in class org.apache.paimon.types.TimeType
 
accept(DataTypeVisitor<R>) - Method in class org.apache.paimon.types.TinyIntType
 
accept(DataTypeVisitor<R>) - Method in class org.apache.paimon.types.VarBinaryType
 
accept(DataTypeVisitor<R>) - Method in class org.apache.paimon.types.VarCharType
 
accept(T) - Method in interface org.apache.paimon.utils.ThrowingConsumer
Performs this operation on the given argument.
AccessControlListHandler() - Constructor for class com.amazonaws.services.s3.model.transform.XmlResponsesSaxParser.AccessControlListHandler
 
accessed - Variable in class org.apache.paimon.index.PartitionIndex
 
acquire(JdbcClientPool, String, long) - Static method in class org.apache.paimon.jdbc.JdbcUtils
 
acquireTimeout(HiveConf) - Static method in class org.apache.paimon.hive.HiveCatalogLock
 
acquireTimeout(Map<String, String>) - Static method in class org.apache.paimon.jdbc.JdbcCatalogLock
 
Action - Interface in org.apache.paimon.flink.action
Abstract class for Flink actions.
ActionBase - Class in org.apache.paimon.flink.action
Abstract base of Action for table.
ActionBase(String, Map<String, String>) - Constructor for class org.apache.paimon.flink.action.ActionBase
 
ActionFactory - Interface in org.apache.paimon.flink.action
Factory to create Action.
adapterForIterator(Iterator<T>) - Static method in interface org.apache.paimon.utils.CloseableIterator
 
adapterForIterator(Iterator<T>, AutoCloseable) - Static method in interface org.apache.paimon.utils.CloseableIterator
 
AdaptiveParallelism - Class in org.apache.paimon.flink.sink
Get adaptive config from Flink.
AdaptiveParallelism() - Constructor for class org.apache.paimon.flink.sink.AdaptiveParallelism
 
ADD - Static variable in class org.apache.paimon.codegen.codesplit.JavaLexer
 
ADD - Static variable in class org.apache.paimon.codegen.codesplit.JavaLexer
 
ADD - Static variable in class org.apache.paimon.codegen.codesplit.JavaParser
 
ADD - Static variable in class org.apache.paimon.codegen.codesplit.JavaParser
 
ADD() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ExpressionContext
 
ADD() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ExpressionContext
 
add(long) - Method in class org.apache.paimon.flink.source.RecordLimiter
 
add(SearchArgument.Builder) - Method in class org.apache.paimon.format.orc.filter.OrcFilters.And
 
add(SearchArgument.Builder) - Method in class org.apache.paimon.format.orc.filter.OrcFilters.Equals
 
add(SearchArgument.Builder) - Method in class org.apache.paimon.format.orc.filter.OrcFilters.IsNull
 
add(SearchArgument.Builder) - Method in class org.apache.paimon.format.orc.filter.OrcFilters.LessThan
 
add(SearchArgument.Builder) - Method in class org.apache.paimon.format.orc.filter.OrcFilters.LessThanEquals
 
add(SearchArgument.Builder) - Method in class org.apache.paimon.format.orc.filter.OrcFilters.Not
 
add(SearchArgument.Builder) - Method in class org.apache.paimon.format.orc.filter.OrcFilters.Or
 
add(SearchArgument.Builder) - Method in class org.apache.paimon.format.orc.filter.OrcFilters.Predicate
 
add(K, V) - Method in class org.apache.paimon.lookup.RocksDBListState
 
add(K, V) - Method in class org.apache.paimon.lookup.RocksDBSetState
 
add(byte[], byte[]) - Method in class org.apache.paimon.lookup.sort.BlockWriter
 
add(KeyValue) - Method in class org.apache.paimon.mergetree.compact.aggregate.AggregateMergeFunction
 
add(KeyValue) - Method in class org.apache.paimon.mergetree.compact.DeduplicateMergeFunction
 
add(KeyValue) - Method in class org.apache.paimon.mergetree.compact.FirstRowMergeFunction
 
add(KeyValue) - Method in class org.apache.paimon.mergetree.compact.FirstRowMergeFunctionWrapper
 
add(KeyValue) - Method in class org.apache.paimon.mergetree.compact.FullChangelogMergeFunctionWrapper
 
add(KeyValue) - Method in class org.apache.paimon.mergetree.compact.LookupChangelogMergeFunctionWrapper
 
add(KeyValue) - Method in class org.apache.paimon.mergetree.compact.LookupMergeFunction
 
add(KeyValue) - Method in interface org.apache.paimon.mergetree.compact.MergeFunction
Add the given KeyValue to the merge function.
add(KeyValue) - Method in interface org.apache.paimon.mergetree.compact.MergeFunctionWrapper
 
add(KeyValue) - Method in class org.apache.paimon.mergetree.compact.PartialUpdateMergeFunction
 
add(KeyValue) - Method in class org.apache.paimon.mergetree.compact.ReducerMergeFunctionWrapper
Adds the given KeyValue to the MergeFunction helper.
add(BlockElement) - Method in class org.apache.paimon.options.description.Description.DescriptionBuilder
Block of description add.
add(MemorySize) - Method in class org.apache.paimon.options.MemorySize
 
add(boolean) - Method in class org.apache.paimon.utils.BooleanArrayList
 
add(Decimal, Decimal, int, int) - Static method in class org.apache.paimon.utils.DecimalUtils
 
add(int) - Method in class org.apache.paimon.utils.IntArrayList
 
add(int) - Method in class org.apache.paimon.utils.IntHashSet
 
add(long) - Method in class org.apache.paimon.utils.LongArrayList
 
add(Long) - Method in class org.apache.paimon.utils.LongCounter
Consider using LongCounter.add(long) instead for primitive long values.
add(long) - Method in class org.apache.paimon.utils.LongCounter
 
add(T) - Method in class org.apache.paimon.utils.Pool
Adds an entry to the pool with an optional payload.
add(int) - Method in class org.apache.paimon.utils.RoaringBitmap32
 
add(long) - Method in class org.apache.paimon.utils.RoaringBitmap64
 
ADD_ASSIGN - Static variable in class org.apache.paimon.codegen.codesplit.JavaLexer
 
ADD_ASSIGN - Static variable in class org.apache.paimon.codegen.codesplit.JavaLexer
 
ADD_ASSIGN - Static variable in class org.apache.paimon.codegen.codesplit.JavaParser
 
ADD_ASSIGN - Static variable in class org.apache.paimon.codegen.codesplit.JavaParser
 
ADD_ASSIGN() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ExpressionContext
 
ADD_ASSIGN() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ExpressionContext
 
addAllToProperties(Properties) - Method in class org.apache.paimon.options.Options
Adds all entries in these options to the given Properties.
AddBoolBeforeReturnRewriter - Class in org.apache.paimon.codegen.codesplit
A helper class of FunctionSplitter.
AddBoolBeforeReturnRewriter(String, int) - Constructor for class org.apache.paimon.codegen.codesplit.AddBoolBeforeReturnRewriter
 
addChangelog(KeyValue) - Method in class org.apache.paimon.mergetree.compact.ChangelogResult
 
addChannel(FileIOChannel.ID) - Method in class org.apache.paimon.sort.SpillChannelManager
Add a new File channel.
addColumn(String, DataType) - Static method in interface org.apache.paimon.schema.SchemaChange
 
addColumn(String, DataType, String) - Static method in interface org.apache.paimon.schema.SchemaChange
 
addColumn(String, DataType, String, SchemaChange.Move) - Static method in interface org.apache.paimon.schema.SchemaChange
 
addDirectDependency(Dependency) - Method in class org.apache.paimon.tools.ci.utils.shared.DependencyTree
 
AddDonePartitionAction - Class in org.apache.paimon.partition.actions
A PartitionMarkDoneAction which add ".done" partition.
AddDonePartitionAction(MetastoreClient) - Constructor for class org.apache.paimon.partition.actions.AddDonePartitionAction
 
addDropFileCallback(Levels.DropFileCallback) - Method in class org.apache.paimon.mergetree.Levels
 
addedFilesCount() - Method in class org.apache.paimon.iceberg.manifest.IcebergManifestFileMeta
 
addedRowsCount() - Method in class org.apache.paimon.iceberg.manifest.IcebergManifestFileMeta
 
addedSnapshotId() - Method in class org.apache.paimon.iceberg.manifest.IcebergManifestFileMeta
 
addElement(T) - Method in class org.apache.paimon.format.avro.AvroBulkWriter
 
addElement(InternalRow) - Method in interface org.apache.paimon.format.FormatWriter
Adds an element to the encoder.
addElement(InternalRow) - Method in class org.apache.paimon.format.orc.writer.OrcBulkWriter
 
addElement(InternalRow) - Method in class org.apache.paimon.format.parquet.writer.ParquetBulkWriter
 
addField(int, boolean, boolean) - Method in class org.apache.paimon.codegen.SortSpec.SortSpecBuilder
 
addFileCommittable(CommitMessage) - Method in class org.apache.paimon.manifest.ManifestCommittable
 
addHash(int) - Method in class org.apache.paimon.utils.BloomFilter
 
addHash(int) - Method in class org.apache.paimon.utils.BloomFilter.Builder
 
addHash(long) - Method in class org.apache.paimon.utils.BloomFilter64
 
addKeyNamePrefix(RowType) - Static method in class org.apache.paimon.table.PrimaryKeyTableUtils
 
addKeyNamePrefix(List<DataField>) - Static method in class org.apache.paimon.table.PrimaryKeyTableUtils
 
addLevel0File(DataFileMeta) - Method in class org.apache.paimon.mergetree.Levels
 
addLogOffset(int, long) - Method in class org.apache.paimon.manifest.ManifestCommittable
 
addMergedDataFiles(Map<BinaryRow, Map<Integer, Set<String>>>, Snapshot) - Method in class org.apache.paimon.operation.FileDeletionBase
NOTE: This method is used for building data file skipping set.
addNewFile(DataFileMeta) - Method in class org.apache.paimon.append.BucketedAppendCompactManager
 
addNewFile(DataFileMeta) - Method in interface org.apache.paimon.compact.CompactManager
Add a new file.
addNewFile(DataFileMeta) - Method in class org.apache.paimon.compact.NoopCompactManager
 
addNewFile(DataFileMeta) - Method in class org.apache.paimon.mergetree.compact.MergeTreeCompactManager
 
addNewFiles(List<DataFileMeta>) - Method in class org.apache.paimon.append.AppendOnlyWriter
 
addNewFiles(List<DataFileMeta>) - Method in class org.apache.paimon.mergetree.MergeTreeWriter
 
addNewFiles(List<DataFileMeta>) - Method in interface org.apache.paimon.utils.RecordWriter
Add files to the internal CompactManager.
addOpenChannels(List<FileIOChannel>) - Method in class org.apache.paimon.sort.SpillChannelManager
Open File channels.
addOwners(Iterable<MemoryOwner>) - Method in class org.apache.paimon.memory.MemoryPoolFactory
 
addPartition(BinaryRow) - Method in class org.apache.paimon.hive.HiveMetastoreClient
 
addPartition(LinkedHashMap<String, String>) - Method in class org.apache.paimon.hive.HiveMetastoreClient
 
addPartition(BinaryRow) - Method in interface org.apache.paimon.metastore.MetastoreClient
 
addPartition(LinkedHashMap<String, String>) - Method in interface org.apache.paimon.metastore.MetastoreClient
 
AddPartitionCommitCallback - Class in org.apache.paimon.metastore
A CommitCallback to add newly created partitions to metastore.
AddPartitionCommitCallback(MetastoreClient) - Constructor for class org.apache.paimon.metastore.AddPartitionCommitCallback
 
addPartitionKeysTo(List<String>, List<String>) - Method in class org.apache.paimon.flink.lookup.DynamicPartitionLoader
 
AddPartitionTagCallback - Class in org.apache.paimon.metastore
A TagCallback to add newly created partitions to metastore.
AddPartitionTagCallback(MetastoreClient, String) - Constructor for class org.apache.paimon.metastore.AddPartitionTagCallback
 
addReader(int) - Method in class org.apache.paimon.flink.source.ContinuousFileSplitEnumerator
 
addReader(int) - Method in class org.apache.paimon.flink.source.StaticFileStoreSplitEnumerator
 
addRowBatch(VectorizedRowBatch) - Method in class org.apache.orc.impl.WriterImpl
 
addRowCount() - Method in class org.apache.paimon.io.DataFileMeta
 
addSafely(int, int) - Static method in class org.apache.paimon.utils.MathUtils
Safely add the given int value by another int value, ensuring that no overflow occurs.
addScanTable(FileStoreTable, Identifier) - Method in class org.apache.paimon.flink.compact.MultiAwareBucketTableScan
 
addScanTable(FileStoreTable, Identifier) - Method in class org.apache.paimon.flink.compact.MultiUnawareBucketTableScan
 
addSchema(Identifier, Schema) - Method in class org.apache.paimon.flink.action.cdc.schema.JdbcSchemasInfo
 
addSchema(Identifier, String, Schema) - Method in class org.apache.paimon.flink.action.cdc.schema.JdbcSchemasInfo
 
addSplit(int, FileStoreSourceSplit) - Method in class org.apache.paimon.flink.source.assigners.AlignedSplitAssigner
 
addSplit(int, FileStoreSourceSplit) - Method in class org.apache.paimon.flink.source.assigners.DynamicPartitionPruningAssigner
 
addSplit(int, FileStoreSourceSplit) - Method in class org.apache.paimon.flink.source.assigners.FIFOSplitAssigner
 
addSplit(int, FileStoreSourceSplit) - Method in class org.apache.paimon.flink.source.assigners.PreAssignSplitAssigner
 
addSplit(int, FileStoreSourceSplit) - Method in interface org.apache.paimon.flink.source.assigners.SplitAssigner
Add one split of a specified subtask to the assigner.
addSplits(Collection<FileStoreSourceSplit>) - Method in class org.apache.paimon.flink.source.align.AlignedContinuousFileSplitEnumerator
 
addSplits(Collection<FileStoreSourceSplit>) - Method in class org.apache.paimon.flink.source.ContinuousFileSplitEnumerator
 
addSplitsBack(List<FileStoreSourceSplit>, int) - Method in class org.apache.paimon.flink.source.align.AlignedContinuousFileSplitEnumerator
 
addSplitsBack(int, List<FileStoreSourceSplit>) - Method in class org.apache.paimon.flink.source.assigners.AlignedSplitAssigner
 
addSplitsBack(int, List<FileStoreSourceSplit>) - Method in class org.apache.paimon.flink.source.assigners.DynamicPartitionPruningAssigner
 
addSplitsBack(int, List<FileStoreSourceSplit>) - Method in class org.apache.paimon.flink.source.assigners.FIFOSplitAssigner
 
addSplitsBack(int, List<FileStoreSourceSplit>) - Method in class org.apache.paimon.flink.source.assigners.PreAssignSplitAssigner
 
addSplitsBack(int, List<FileStoreSourceSplit>) - Method in interface org.apache.paimon.flink.source.assigners.SplitAssigner
Adds a set of splits to this assigner.
addSplitsBack(List<FileStoreSourceSplit>, int) - Method in class org.apache.paimon.flink.source.ContinuousFileSplitEnumerator
 
addSplitsBack(List<FileStoreSourceSplit>, int) - Method in class org.apache.paimon.flink.source.StaticFileStoreSplitEnumerator
 
addTransitiveDependencyTo(Dependency, Dependency) - Method in class org.apache.paimon.tools.ci.utils.shared.DependencyTree
 
addUserMetadata(String, ByteBuffer) - Method in class org.apache.orc.impl.WriterImpl
 
AdjustedProjection(int[][], int[][]) - Constructor for class org.apache.paimon.mergetree.compact.MergeFunctionFactory.AdjustedProjection
 
adjustForNextLoop() - Method in class org.apache.paimon.mergetree.compact.LoserTree
Adjust the Key that needs to be returned in the next round.
adjustProjection(int[][]) - Method in interface org.apache.paimon.mergetree.compact.MergeFunctionFactory
 
adjustTop() - Method in class org.apache.paimon.sort.PartialOrderPriorityQueue
Should be called when the Object at top changes values.
advance() - Method in class org.apache.paimon.data.AbstractPagedInputView
Advances the view to the next memory segment.
advance() - Method in class org.apache.paimon.data.AbstractPagedOutputView
Moves the output view to the next page.
advanceNext() - Method in class org.apache.paimon.disk.ExternalBuffer.BufferIterator
 
advanceNext() - Method in interface org.apache.paimon.disk.RowBuffer.RowBufferIterator
 
advanceNext() - Method in interface org.apache.paimon.utils.KeyValueIterator
 
after() - Method in class org.apache.paimon.compact.CompactResult
 
after() - Method in class org.apache.paimon.flink.action.cdc.mysql.format.DebeziumEvent.Payload
 
after(String, String) - Static method in class org.apache.paimon.schema.SchemaChange.Move
 
afterFields() - Method in class org.apache.paimon.flink.action.cdc.mysql.format.DebeziumEvent.Field
 
afterGrow() - Method in class org.apache.paimon.data.BinaryArrayWriter
 
afterGrow() - Method in class org.apache.paimon.data.BinaryRowWriter
 
afterReadPage() - Method in class org.apache.paimon.format.parquet.reader.AbstractColumnReader
After read a page, we may need some initialization.
afterReadPage() - Method in class org.apache.paimon.format.parquet.reader.BooleanColumnReader
 
agg(Object, Object) - Method in class org.apache.paimon.mergetree.compact.aggregate.FieldAggregator
 
agg(Object, Object) - Method in class org.apache.paimon.mergetree.compact.aggregate.FieldBoolAndAgg
 
agg(Object, Object) - Method in class org.apache.paimon.mergetree.compact.aggregate.FieldBoolOrAgg
 
agg(Object, Object) - Method in class org.apache.paimon.mergetree.compact.aggregate.FieldCollectAgg
 
agg(Object, Object) - Method in class org.apache.paimon.mergetree.compact.aggregate.FieldFirstNonNullValueAgg
 
agg(Object, Object) - Method in class org.apache.paimon.mergetree.compact.aggregate.FieldFirstValueAgg
 
agg(Object, Object) - Method in class org.apache.paimon.mergetree.compact.aggregate.FieldHllSketchAgg
 
agg(Object, Object) - Method in class org.apache.paimon.mergetree.compact.aggregate.FieldIgnoreRetractAgg
 
agg(Object, Object) - Method in class org.apache.paimon.mergetree.compact.aggregate.FieldLastNonNullValueAgg
 
agg(Object, Object) - Method in class org.apache.paimon.mergetree.compact.aggregate.FieldLastValueAgg
 
agg(Object, Object) - Method in class org.apache.paimon.mergetree.compact.aggregate.FieldListaggAgg
 
agg(Object, Object) - Method in class org.apache.paimon.mergetree.compact.aggregate.FieldMaxAgg
 
agg(Object, Object) - Method in class org.apache.paimon.mergetree.compact.aggregate.FieldMergeMapAgg
 
agg(Object, Object) - Method in class org.apache.paimon.mergetree.compact.aggregate.FieldMinAgg
 
agg(Object, Object) - Method in class org.apache.paimon.mergetree.compact.aggregate.FieldNestedUpdateAgg
 
agg(Object, Object) - Method in class org.apache.paimon.mergetree.compact.aggregate.FieldPrimaryKeyAgg
 
agg(Object, Object) - Method in class org.apache.paimon.mergetree.compact.aggregate.FieldProductAgg
 
agg(Object, Object) - Method in class org.apache.paimon.mergetree.compact.aggregate.FieldRoaringBitmap32Agg
 
agg(Object, Object) - Method in class org.apache.paimon.mergetree.compact.aggregate.FieldRoaringBitmap64Agg
 
agg(Object, Object) - Method in class org.apache.paimon.mergetree.compact.aggregate.FieldSumAgg
 
agg(Object, Object) - Method in class org.apache.paimon.mergetree.compact.aggregate.FieldThetaSketchAgg
 
AGG_FUNCTION - Static variable in class org.apache.paimon.CoreOptions
 
AggregateMergeFunction - Class in org.apache.paimon.mergetree.compact.aggregate
A MergeFunction where key is primary key (unique) and value is the partial record, pre-aggregate non-null fields on merge.
AggregateMergeFunction(InternalRow.FieldGetter[], FieldAggregator[]) - Constructor for class org.apache.paimon.mergetree.compact.aggregate.AggregateMergeFunction
 
AGGREGATION_FIELDS - Static variable in class org.apache.paimon.table.system.AggregationFieldsTable
 
AggregationFieldsTable - Class in org.apache.paimon.table.system
A Table for showing Aggregation of table.
AggregationFieldsTable(FileStoreTable) - Constructor for class org.apache.paimon.table.system.AggregationFieldsTable
 
AggregationFieldsTable(FileIO, Path, String) - Constructor for class org.apache.paimon.table.system.AggregationFieldsTable
 
aggReversed(Object, Object) - Method in class org.apache.paimon.mergetree.compact.aggregate.FieldAggregator
 
aggReversed(Object, Object) - Method in class org.apache.paimon.mergetree.compact.aggregate.FieldCollectAgg
 
AirBlockCompressor - Class in org.apache.paimon.compression
Implementation of BlockCompressor for airlift compressors.
AirBlockCompressor(Compressor) - Constructor for class org.apache.paimon.compression.AirBlockCompressor
 
AirBlockDecompressor - Class in org.apache.paimon.compression
Implementation of BlockDecompressor for airlift compressors.
AirBlockDecompressor(Decompressor) - Constructor for class org.apache.paimon.compression.AirBlockDecompressor
 
AirCompressorFactory - Class in org.apache.paimon.compression
Implementation of BlockCompressionFactory for airlift compressors.
AirCompressorFactory(BlockCompressionType, Compressor, Decompressor) - Constructor for class org.apache.paimon.compression.AirCompressorFactory
 
AlignedContinuousFileSplitEnumerator - Class in org.apache.paimon.flink.source.align
An aligned continuously monitoring enumerator.
AlignedContinuousFileSplitEnumerator(SplitEnumeratorContext<FileStoreSourceSplit>, Collection<FileStoreSourceSplit>, Long, long, StreamTableScan, BucketMode, long, int, boolean) - Constructor for class org.apache.paimon.flink.source.align.AlignedContinuousFileSplitEnumerator
 
AlignedContinuousFileStoreSource - Class in org.apache.paimon.flink.source.align
AlignedContinuousFileStoreSource(ReadBuilder, Map<String, String>, Long, BucketMode) - Constructor for class org.apache.paimon.flink.source.align.AlignedContinuousFileStoreSource
 
AlignedSourceReader - Class in org.apache.paimon.flink.source.align
The difference with FileStoreSourceReader is that only after the allocated splits are fully consumed, checkpoints will be made and the next batch of splits will be requested.
AlignedSourceReader(SourceReaderContext, TableRead, FileStoreSourceReaderMetrics, IOManager, Long, FutureCompletingBlockingQueue<RecordsWithSplitIds<BulkFormat.RecordIterator<RowData>>>) - Constructor for class org.apache.paimon.flink.source.align.AlignedSourceReader
 
AlignedSplitAssigner - Class in org.apache.paimon.flink.source.assigners
Splits are allocated at the granularity of snapshots.
AlignedSplitAssigner() - Constructor for class org.apache.paimon.flink.source.assigners.AlignedSplitAssigner
 
ALL_TABLE_OPTIONS - Static variable in class org.apache.paimon.table.system.AllTableOptionsTable
 
AllDeltaFollowUpScanner - Class in org.apache.paimon.table.source.snapshot
FollowUpScanner for read all file changes.
AllDeltaFollowUpScanner() - Constructor for class org.apache.paimon.table.source.snapshot.AllDeltaFollowUpScanner
 
allFiles() - Method in class org.apache.paimon.append.BucketedAppendCompactManager
 
allFiles() - Method in interface org.apache.paimon.compact.CompactManager
 
allFiles() - Method in class org.apache.paimon.compact.NoopCompactManager
 
allFiles() - Method in class org.apache.paimon.mergetree.compact.MergeTreeCompactManager
 
allFiles() - Method in class org.apache.paimon.mergetree.Levels
 
AllGrantedPrivilegeChecker - Class in org.apache.paimon.privilege
Allows current user to perform all operations.
AllGrantedPrivilegeChecker() - Constructor for class org.apache.paimon.privilege.AllGrantedPrivilegeChecker
 
AllMergedJdbcTableInfo - Class in org.apache.paimon.flink.action.cdc.schema
Describe a table whose schema is merged from all source tables.
AllMergedJdbcTableInfo() - Constructor for class org.apache.paimon.flink.action.cdc.schema.AllMergedJdbcTableInfo
 
allocate() - Method in class org.apache.paimon.flink.memory.MemorySegmentAllocator
Allocates a set of memory segments for memory pool.
allocateHeapMemory(int) - Static method in class org.apache.paimon.memory.MemorySegment
 
allocateMemory() - Method in class org.apache.paimon.flink.memory.FlinkMemorySegmentPool
 
allocateMemory() - Method in class org.apache.paimon.memory.AbstractMemorySegmentPool
 
allocateMemory() - Method in class org.apache.paimon.memory.HeapMemorySegmentPool
 
allocateOffHeapMemory(int) - Static method in class org.apache.paimon.memory.MemorySegment
 
allocateReuseBytes(int) - Static method in class org.apache.paimon.memory.MemorySegmentUtils
Allocate bytes that is only for temporary usage, it should not be stored in somewhere else.
allocateReuseChars(int) - Static method in class org.apache.paimon.memory.MemorySegmentUtils
 
allOptions - Variable in class org.apache.paimon.flink.factories.FlinkFactoryUtil.FlinkFactoryHelper
 
ALLOW_UPPER_CASE - Static variable in class org.apache.paimon.options.CatalogOptions
 
allowUpperCase() - Method in class org.apache.paimon.catalog.AbstractCatalog
 
allowUpperCase() - Method in interface org.apache.paimon.catalog.Catalog
Return a boolean that indicates whether this catalog allow upper case.
allowUpperCase() - Method in class org.apache.paimon.catalog.DelegateCatalog
 
allowUpperCase() - Method in class org.apache.paimon.catalog.FileSystemCatalog
 
allowUpperCase - Variable in class org.apache.paimon.flink.action.cdc.SynchronizationActionBase
 
allowUpperCase() - Method in class org.apache.paimon.hive.HiveCatalog
 
allowUpperCase() - Method in class org.apache.paimon.jdbc.JdbcCatalog
 
AllTableOptionsTable - Class in org.apache.paimon.table.system
This is a system table to display all the database-table properties.
AllTableOptionsTable(FileIO, Map<String, Map<String, Path>>) - Constructor for class org.apache.paimon.table.system.AllTableOptionsTable
 
allTablePaths() - Method in class org.apache.paimon.catalog.AbstractCatalog
 
allTagNames() - Method in class org.apache.paimon.utils.TagManager
 
alterDatabase(String, CatalogDatabase, boolean) - Method in class org.apache.paimon.flink.FlinkCatalog
 
alterDatabase(String, CatalogDatabase, boolean) - Method in class org.apache.paimon.flink.FlinkGenericCatalog
 
alterFunction(ObjectPath, CatalogFunction, boolean) - Method in class org.apache.paimon.flink.FlinkCatalog
 
alterFunction(ObjectPath, CatalogFunction, boolean) - Method in class org.apache.paimon.flink.FlinkGenericCatalog
 
alterNamespace(String[], NamespaceChange...) - Method in class org.apache.paimon.spark.SparkCatalog
 
alterNamespace(String[], NamespaceChange...) - Method in class org.apache.paimon.spark.SparkGenericCatalog
 
alterPartition(ObjectPath, CatalogPartitionSpec, CatalogPartition, boolean) - Method in class org.apache.paimon.flink.FlinkCatalog
 
alterPartition(ObjectPath, CatalogPartitionSpec, CatalogPartition, boolean) - Method in class org.apache.paimon.flink.FlinkGenericCatalog
 
alterPartitionColumnStatistics(ObjectPath, CatalogPartitionSpec, CatalogColumnStatistics, boolean) - Method in class org.apache.paimon.flink.FlinkCatalog
 
alterPartitionColumnStatistics(ObjectPath, CatalogPartitionSpec, CatalogColumnStatistics, boolean) - Method in class org.apache.paimon.flink.FlinkGenericCatalog
 
alterPartitionStatistics(ObjectPath, CatalogPartitionSpec, CatalogTableStatistics, boolean) - Method in class org.apache.paimon.flink.FlinkCatalog
 
alterPartitionStatistics(ObjectPath, CatalogPartitionSpec, CatalogTableStatistics, boolean) - Method in class org.apache.paimon.flink.FlinkGenericCatalog
 
alterTable(Identifier, List<SchemaChange>, boolean) - Method in class org.apache.paimon.catalog.AbstractCatalog
 
alterTable(Identifier, List<SchemaChange>, boolean) - Method in class org.apache.paimon.catalog.CachingCatalog
 
alterTable(Identifier, List<SchemaChange>, boolean) - Method in interface org.apache.paimon.catalog.Catalog
Modify an existing table from SchemaChanges.
alterTable(Identifier, SchemaChange, boolean) - Method in interface org.apache.paimon.catalog.Catalog
Modify an existing table from a SchemaChange.
alterTable(Identifier, List<SchemaChange>, boolean) - Method in class org.apache.paimon.catalog.DelegateCatalog
 
alterTable(ObjectPath, CatalogBaseTable, boolean) - Method in class org.apache.paimon.flink.FlinkCatalog
 
alterTable(ObjectPath, CatalogBaseTable, List<TableChange>, boolean) - Method in class org.apache.paimon.flink.FlinkCatalog
 
alterTable(ObjectPath, CatalogBaseTable, boolean) - Method in class org.apache.paimon.flink.FlinkGenericCatalog
 
alterTable(ObjectPath, CatalogBaseTable, List<TableChange>, boolean) - Method in class org.apache.paimon.flink.FlinkGenericCatalog
 
alterTable(Identifier, List<SchemaChange>, boolean) - Method in class org.apache.paimon.privilege.PrivilegedCatalog
 
alterTable(Identifier, TableChange...) - Method in class org.apache.paimon.spark.SparkCatalog
 
alterTable(Identifier, TableChange...) - Method in class org.apache.paimon.spark.SparkGenericCatalog
 
alterTableColumnStatistics(ObjectPath, CatalogColumnStatistics, boolean) - Method in class org.apache.paimon.flink.FlinkCatalog
 
alterTableColumnStatistics(ObjectPath, CatalogColumnStatistics, boolean) - Method in class org.apache.paimon.flink.FlinkGenericCatalog
 
alterTableImpl(Identifier, List<SchemaChange>) - Method in class org.apache.paimon.catalog.AbstractCatalog
 
alterTableImpl(Identifier, List<SchemaChange>) - Method in class org.apache.paimon.catalog.FileSystemCatalog
 
alterTableImpl(Identifier, List<SchemaChange>) - Method in class org.apache.paimon.hive.HiveCatalog
 
alterTableImpl(Identifier, List<SchemaChange>) - Method in class org.apache.paimon.jdbc.JdbcCatalog
 
alterTableOptions(Identifier, FileStoreTable) - Method in class org.apache.paimon.flink.action.cdc.SynchronizationActionBase
 
alterTableStatistics(ObjectPath, CatalogTableStatistics, boolean) - Method in class org.apache.paimon.flink.FlinkCatalog
 
alterTableStatistics(ObjectPath, CatalogTableStatistics, boolean) - Method in class org.apache.paimon.flink.FlinkGenericCatalog
 
ALWAYS_TRUE - Static variable in interface org.apache.paimon.utils.Filter
 
alwaysRawConvertible() - Method in class org.apache.paimon.table.source.AppendOnlySplitGenerator
 
alwaysRawConvertible() - Method in class org.apache.paimon.table.source.MergeTreeSplitGenerator
 
alwaysRawConvertible() - Method in interface org.apache.paimon.table.source.SplitGenerator
 
alwaysTrue() - Static method in interface org.apache.paimon.utils.Filter
 
AND - Static variable in class org.apache.paimon.codegen.codesplit.JavaLexer
 
AND - Static variable in class org.apache.paimon.codegen.codesplit.JavaLexer
 
AND - Static variable in class org.apache.paimon.codegen.codesplit.JavaParser
 
AND - Static variable in class org.apache.paimon.codegen.codesplit.JavaParser
 
AND() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ExpressionContext
 
AND() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ExpressionContext
 
and(FileIndexResult) - Method in class org.apache.paimon.fileindex.bitmap.BitmapIndexResultLazy
 
and(FileIndexResult) - Method in interface org.apache.paimon.fileindex.FileIndexResult
 
and() - Method in class org.apache.paimon.flink.utils.FlinkCalciteClasses.SqlKindDelegate
 
And(OrcFilters.Predicate...) - Constructor for class org.apache.paimon.format.orc.filter.OrcFilters.And
Creates an AND predicate.
And - Class in org.apache.paimon.predicate
and(Predicate...) - Static method in class org.apache.paimon.predicate.PredicateBuilder
 
and(List<Predicate>) - Static method in class org.apache.paimon.predicate.PredicateBuilder
 
and(RoaringBitmap32, RoaringBitmap32) - Static method in class org.apache.paimon.utils.RoaringBitmap32
 
AND_ASSIGN - Static variable in class org.apache.paimon.codegen.codesplit.JavaLexer
 
AND_ASSIGN - Static variable in class org.apache.paimon.codegen.codesplit.JavaLexer
 
AND_ASSIGN - Static variable in class org.apache.paimon.codegen.codesplit.JavaParser
 
AND_ASSIGN - Static variable in class org.apache.paimon.codegen.codesplit.JavaParser
 
AND_ASSIGN() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ExpressionContext
 
AND_ASSIGN() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ExpressionContext
 
andNullable(Predicate...) - Static method in class org.apache.paimon.predicate.PredicateBuilder
 
andNullable(List<Predicate>) - Static method in class org.apache.paimon.predicate.PredicateBuilder
 
annotation() - Method in class org.apache.paimon.codegen.codesplit.JavaParser
 
annotation() - Method in class org.apache.paimon.codegen.codesplit.JavaParser
 
annotation() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ClassOrInterfaceModifierContext
 
annotation() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ClassOrInterfaceModifierContext
 
annotation() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ClassTypeContext
 
annotation(int) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ClassTypeContext
 
annotation() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ClassTypeContext
 
annotation(int) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ClassTypeContext
 
annotation() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ElementValueContext
 
annotation() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ElementValueContext
 
annotation() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.EnumConstantContext
 
annotation(int) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.EnumConstantContext
 
annotation() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.EnumConstantContext
 
annotation(int) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.EnumConstantContext
 
annotation() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.InterfaceMethodDeclarationContext
 
annotation(int) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.InterfaceMethodDeclarationContext
 
annotation() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.InterfaceMethodDeclarationContext
 
annotation(int) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.InterfaceMethodDeclarationContext
 
annotation() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.InterfaceMethodModifierContext
 
annotation() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.InterfaceMethodModifierContext
 
annotation() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.PackageDeclarationContext
 
annotation(int) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.PackageDeclarationContext
 
annotation() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.PackageDeclarationContext
 
annotation(int) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.PackageDeclarationContext
 
annotation() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.TypeParameterContext
 
annotation(int) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.TypeParameterContext
 
annotation() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.TypeParameterContext
 
annotation(int) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.TypeParameterContext
 
annotation() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.TypeTypeContext
 
annotation() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.TypeTypeContext
 
annotation() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.VariableModifierContext
 
annotation() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.VariableModifierContext
 
annotationConstantRest() - Method in class org.apache.paimon.codegen.codesplit.JavaParser
 
annotationConstantRest() - Method in class org.apache.paimon.codegen.codesplit.JavaParser
 
annotationConstantRest() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.AnnotationMethodOrConstantRestContext
 
annotationConstantRest() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.AnnotationMethodOrConstantRestContext
 
AnnotationConstantRestContext(ParserRuleContext, int) - Constructor for class org.apache.paimon.codegen.codesplit.JavaParser.AnnotationConstantRestContext
 
AnnotationConstantRestContext(ParserRuleContext, int) - Constructor for class org.apache.paimon.codegen.codesplit.JavaParser.AnnotationConstantRestContext
 
AnnotationContext(ParserRuleContext, int) - Constructor for class org.apache.paimon.codegen.codesplit.JavaParser.AnnotationContext
 
AnnotationContext(ParserRuleContext, int) - Constructor for class org.apache.paimon.codegen.codesplit.JavaParser.AnnotationContext
 
annotationMethodOrConstantRest() - Method in class org.apache.paimon.codegen.codesplit.JavaParser
 
annotationMethodOrConstantRest() - Method in class org.apache.paimon.codegen.codesplit.JavaParser
 
annotationMethodOrConstantRest() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.AnnotationTypeElementRestContext
 
annotationMethodOrConstantRest() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.AnnotationTypeElementRestContext
 
AnnotationMethodOrConstantRestContext(ParserRuleContext, int) - Constructor for class org.apache.paimon.codegen.codesplit.JavaParser.AnnotationMethodOrConstantRestContext
 
AnnotationMethodOrConstantRestContext(ParserRuleContext, int) - Constructor for class org.apache.paimon.codegen.codesplit.JavaParser.AnnotationMethodOrConstantRestContext
 
annotationMethodRest() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.AnnotationMethodOrConstantRestContext
 
annotationMethodRest() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.AnnotationMethodOrConstantRestContext
 
annotationMethodRest() - Method in class org.apache.paimon.codegen.codesplit.JavaParser
 
annotationMethodRest() - Method in class org.apache.paimon.codegen.codesplit.JavaParser
 
AnnotationMethodRestContext(ParserRuleContext, int) - Constructor for class org.apache.paimon.codegen.codesplit.JavaParser.AnnotationMethodRestContext
 
AnnotationMethodRestContext(ParserRuleContext, int) - Constructor for class org.apache.paimon.codegen.codesplit.JavaParser.AnnotationMethodRestContext
 
annotationTypeBody() - Method in class org.apache.paimon.codegen.codesplit.JavaParser
 
annotationTypeBody() - Method in class org.apache.paimon.codegen.codesplit.JavaParser
 
annotationTypeBody() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.AnnotationTypeDeclarationContext
 
annotationTypeBody() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.AnnotationTypeDeclarationContext
 
AnnotationTypeBodyContext(ParserRuleContext, int) - Constructor for class org.apache.paimon.codegen.codesplit.JavaParser.AnnotationTypeBodyContext
 
AnnotationTypeBodyContext(ParserRuleContext, int) - Constructor for class org.apache.paimon.codegen.codesplit.JavaParser.AnnotationTypeBodyContext
 
annotationTypeDeclaration() - Method in class org.apache.paimon.codegen.codesplit.JavaParser
 
annotationTypeDeclaration() - Method in class org.apache.paimon.codegen.codesplit.JavaParser
 
annotationTypeDeclaration() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.AnnotationTypeElementRestContext
 
annotationTypeDeclaration() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.AnnotationTypeElementRestContext
 
annotationTypeDeclaration() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.InterfaceMemberDeclarationContext
 
annotationTypeDeclaration() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.InterfaceMemberDeclarationContext
 
annotationTypeDeclaration() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.MemberDeclarationContext
 
annotationTypeDeclaration() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.MemberDeclarationContext
 
annotationTypeDeclaration() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.TypeDeclarationContext
 
annotationTypeDeclaration() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.TypeDeclarationContext
 
AnnotationTypeDeclarationContext(ParserRuleContext, int) - Constructor for class org.apache.paimon.codegen.codesplit.JavaParser.AnnotationTypeDeclarationContext
 
AnnotationTypeDeclarationContext(ParserRuleContext, int) - Constructor for class org.apache.paimon.codegen.codesplit.JavaParser.AnnotationTypeDeclarationContext
 
annotationTypeElementDeclaration() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.AnnotationTypeBodyContext
 
annotationTypeElementDeclaration(int) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.AnnotationTypeBodyContext
 
annotationTypeElementDeclaration() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.AnnotationTypeBodyContext
 
annotationTypeElementDeclaration(int) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.AnnotationTypeBodyContext
 
annotationTypeElementDeclaration() - Method in class org.apache.paimon.codegen.codesplit.JavaParser
 
annotationTypeElementDeclaration() - Method in class org.apache.paimon.codegen.codesplit.JavaParser
 
AnnotationTypeElementDeclarationContext(ParserRuleContext, int) - Constructor for class org.apache.paimon.codegen.codesplit.JavaParser.AnnotationTypeElementDeclarationContext
 
AnnotationTypeElementDeclarationContext(ParserRuleContext, int) - Constructor for class org.apache.paimon.codegen.codesplit.JavaParser.AnnotationTypeElementDeclarationContext
 
annotationTypeElementRest() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.AnnotationTypeElementDeclarationContext
 
annotationTypeElementRest() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.AnnotationTypeElementDeclarationContext
 
annotationTypeElementRest() - Method in class org.apache.paimon.codegen.codesplit.JavaParser
 
annotationTypeElementRest() - Method in class org.apache.paimon.codegen.codesplit.JavaParser
 
AnnotationTypeElementRestContext(ParserRuleContext, int) - Constructor for class org.apache.paimon.codegen.codesplit.JavaParser.AnnotationTypeElementRestContext
 
AnnotationTypeElementRestContext(ParserRuleContext, int) - Constructor for class org.apache.paimon.codegen.codesplit.JavaParser.AnnotationTypeElementRestContext
 
ANY - Static variable in class org.apache.paimon.codegen.SortSpec
SortSpec does not require sort.
anyCauseMatches(Class<? extends Throwable>, String) - Static method in class org.apache.paimon.testutils.assertj.PaimonAssertions
Shorthand to assert the chain of causes includes a Throwable matching a specific Class and containing the provided message.
anyCauseMatches(Class<? extends Throwable>) - Static method in class org.apache.paimon.testutils.assertj.PaimonAssertions
Shorthand to assert the chain of causes includes a Throwable matching a specific Class.
anyCauseMatches(String) - Static method in class org.apache.paimon.testutils.assertj.PaimonAssertions
Shorthand to assert the chain of causes includes a Throwable matching a specific Class and containing the provided message.
anyNull() - Method in class org.apache.paimon.data.BinaryArray
 
anyNull() - Method in class org.apache.paimon.data.BinaryRow
The bit is 1 when the field is null.
anyNull(int[]) - Method in class org.apache.paimon.data.BinaryRow
 
apacheHeaderToHtml() - Static method in class org.apache.paimon.docs.util.Utils
 
append(Path, int, Progressable) - Method in class org.apache.paimon.format.fs.HadoopReadOnlyFileSystem
 
APPEND - Static variable in class org.apache.paimon.iceberg.metadata.IcebergSnapshotSummary
 
AppendBypassCompactWorkerOperator - Class in org.apache.paimon.flink.sink
A AppendCompactWorkerOperator to bypass Committable inputs.
AppendBypassCompactWorkerOperator(FileStoreTable, String) - Constructor for class org.apache.paimon.flink.sink.AppendBypassCompactWorkerOperator
 
AppendBypassCoordinateOperator<CommitT> - Class in org.apache.paimon.flink.source
A OneInputStreamOperator to accept commit messages and send append compact coordinate compact task to downstream operators.
AppendBypassCoordinateOperator(FileStoreTable, ProcessingTimeService, MailboxExecutor) - Constructor for class org.apache.paimon.flink.source.AppendBypassCoordinateOperator
 
AppendBypassCoordinateOperatorFactory<CommitT> - Class in org.apache.paimon.flink.source
AppendBypassCoordinateOperatorFactory(FileStoreTable) - Constructor for class org.apache.paimon.flink.source.AppendBypassCoordinateOperatorFactory
 
appendBytes(int, byte[], int, int) - Method in class org.apache.paimon.data.columnar.heap.HeapBytesVector
 
appendBytes(int, byte[], int, int) - Method in interface org.apache.paimon.data.columnar.writable.WritableBytesVector
Append byte[] at rowId with the provided value.
appendBytes(int, byte[], int, int) - Method in class org.apache.paimon.format.parquet.reader.ParquetDecimalVector
 
AppendCompactWorkerOperator<IN> - Class in org.apache.paimon.flink.sink
An abstract Operator to execute UnawareAppendCompactionTask passed from BucketUnawareCompactSource for compacting table.
AppendCompactWorkerOperator(FileStoreTable, String) - Constructor for class org.apache.paimon.flink.sink.AppendCompactWorkerOperator
 
appendDataField(String, DataType) - Method in class org.apache.paimon.types.RowType
 
AppendDeletionFileMaintainer - Interface in org.apache.paimon.deletionvectors.append
A maintainer to maintain deletion files for append table, the core methods: AppendDeletionFileMaintainer.notifyNewDeletionVector(java.lang.String, org.apache.paimon.deletionvectors.DeletionVector): Mark the deletion of data files, create new deletion vectors.
AppendOnlyFileStore - Class in org.apache.paimon
FileStore for reading and writing InternalRow.
AppendOnlyFileStore(FileIO, SchemaManager, TableSchema, CoreOptions, RowType, RowType, RowType, String, CatalogEnvironment) - Constructor for class org.apache.paimon.AppendOnlyFileStore
 
AppendOnlyFileStoreScan - Class in org.apache.paimon.operation
AppendOnlyFileStoreScan(RowType, ScanBucketFilter, SnapshotManager, SchemaManager, TableSchema, ManifestFile.Factory, ManifestList.Factory, int, boolean, Integer, boolean) - Constructor for class org.apache.paimon.operation.AppendOnlyFileStoreScan
 
AppendOnlyFileStoreWrite - Class in org.apache.paimon.operation
AppendOnlyFileStoreWrite(FileIO, RawFileSplitRead, long, String, RowType, FileStorePathFactory, SnapshotManager, FileStoreScan, CoreOptions, BucketMode, DeletionVectorsMaintainer.Factory, String) - Constructor for class org.apache.paimon.operation.AppendOnlyFileStoreWrite
 
AppendOnlyIcebergCommitCallback - Class in org.apache.paimon.iceberg
AbstractIcebergCommitCallback for append only tables.
AppendOnlyIcebergCommitCallback(FileStoreTable, String) - Constructor for class org.apache.paimon.iceberg.AppendOnlyIcebergCommitCallback
 
AppendOnlyMultiTableCompactionWorkerOperator - Class in org.apache.paimon.flink.sink
Operator to execute UnawareAppendCompactionTask passed for support compacting multi unaware bucket tables in combined mode.
AppendOnlyMultiTableCompactionWorkerOperator(Catalog.Loader, String, Options) - Constructor for class org.apache.paimon.flink.sink.AppendOnlyMultiTableCompactionWorkerOperator
 
AppendOnlySingleTableCompactionWorkerOperator - Class in org.apache.paimon.flink.sink
Operator to execute UnawareAppendCompactionTask passed from BucketUnawareCompactSource for compacting single unaware bucket tables in divided mode.
AppendOnlySingleTableCompactionWorkerOperator(FileStoreTable, String) - Constructor for class org.apache.paimon.flink.sink.AppendOnlySingleTableCompactionWorkerOperator
 
AppendOnlySplitGenerator - Class in org.apache.paimon.table.source
Append only implementation of SplitGenerator.
AppendOnlySplitGenerator(long, long, BucketMode) - Constructor for class org.apache.paimon.table.source.AppendOnlySplitGenerator
 
AppendOnlyWriter - Class in org.apache.paimon.append
A RecordWriter implementation that only accepts records which are always insert operations and don't have any unique keys or sort keys.
AppendOnlyWriter(FileIO, IOManager, long, FileFormat, long, RowType, long, CompactManager, IOFunction<List<DataFileMeta>, RecordReaderIterator<InternalRow>>, boolean, DataFilePathFactory, CommitIncrement, boolean, boolean, String, CompressOptions, SimpleColStatsCollector.Factory[], MemorySize, FileIndexOptions, boolean) - Constructor for class org.apache.paimon.append.AppendOnlyWriter
 
appendRawStripe(ByteBuffer, OrcProto.StripeInformation.Builder) - Method in class org.apache.orc.impl.PhysicalFsWriter
 
appendStripe(byte[], int, int, StripeInformation, OrcProto.StripeStatistics) - Method in class org.apache.orc.impl.WriterImpl
 
appendStripe(byte[], int, int, StripeInformation, StripeStatistics[]) - Method in class org.apache.orc.impl.WriterImpl
 
appendTo(ParquetFileWriter) - Method in class org.apache.parquet.hadoop.ParquetFileReader
 
appendUdsFieldNumber - Variable in class org.apache.paimon.flink.lookup.FullCacheLookupTable
 
appendUserMetadata(List<OrcProto.UserMetadataItem>) - Method in class org.apache.orc.impl.WriterImpl
 
apply(InternalRow) - Method in interface org.apache.paimon.codegen.Projection
 
apply() - Method in interface org.apache.paimon.fs.PluginFileIO.Func
 
apply(T, U) - Method in interface org.apache.paimon.utils.BiFunctionWithIOE
Applies this function to the given arguments.
apply(T) - Method in interface org.apache.paimon.utils.FunctionWithException
Calls this function.
apply(T) - Method in interface org.apache.paimon.utils.IOFunction
 
apply(InternalRow, BinaryRow) - Method in class org.apache.paimon.utils.ProjectToRowFunction
 
applyDeleteFilters(List<ResolvedExpression>) - Method in class org.apache.paimon.flink.sink.SupportsRowLevelOperationFlinkTableSink
 
ApplyDeletionFileRecordIterator - Class in org.apache.paimon.deletionvectors
ApplyDeletionFileRecordIterator(FileRecordIterator<InternalRow>, DeletionVector) - Constructor for class org.apache.paimon.deletionvectors.ApplyDeletionFileRecordIterator
 
ApplyDeletionVectorReader - Class in org.apache.paimon.deletionvectors
A RecordReader which apply DeletionVector to filter record.
ApplyDeletionVectorReader(RecordReader<InternalRow>, DeletionVector) - Constructor for class org.apache.paimon.deletionvectors.ApplyDeletionVectorReader
 
applyDynamicFiltering(List<String>) - Method in class org.apache.paimon.flink.source.DataTableSource
 
applyDynamicFiltering(List<String>) - Method in class org.apache.paimon.flink.source.FlinkTableSource
 
applyDynamicFiltering(List<String>) - Method in class org.apache.paimon.flink.source.SystemTableSource
 
applyDynamicFiltering(List<String>) - Method in class org.apache.paimon.flink.source.table.RichTableSource
 
applyFilters(List<ResolvedExpression>) - Method in class org.apache.paimon.flink.source.table.PushedRichTableSource
 
applyFilters(List<ResolvedExpression>) - Method in class org.apache.paimon.flink.source.table.PushedTableSource
 
applyLimit(long) - Method in class org.apache.paimon.flink.source.table.PushedRichTableSource
 
applyLimit(long) - Method in class org.apache.paimon.flink.source.table.PushedTableSource
 
applyMove(List<DataField>, SchemaChange.Move) - Method in class org.apache.paimon.schema.SchemaManager
 
applyOverwrite(boolean) - Method in class org.apache.paimon.flink.sink.FlinkTableSinkBase
 
applyProjection(int[][]) - Method in class org.apache.paimon.flink.source.table.PushedRichTableSource
 
applyProjection(int[][]) - Method in class org.apache.paimon.flink.source.table.PushedTableSource
 
applyRowLevelDelete(RowLevelModificationScanContext) - Method in class org.apache.paimon.flink.sink.SupportsRowLevelOperationFlinkTableSink
 
applyRowLevelUpdate(List<Column>, RowLevelModificationScanContext) - Method in class org.apache.paimon.flink.sink.SupportsRowLevelOperationFlinkTableSink
 
applySchemaChange(SchemaManager, SchemaChange, Identifier) - Method in class org.apache.paimon.flink.sink.cdc.UpdatedDataFieldsProcessFunctionBase
 
applyStaticPartition(Map<String, String>) - Method in class org.apache.paimon.flink.sink.FlinkTableSinkBase
 
applyWatermark(WatermarkStrategy<RowData>) - Method in class org.apache.paimon.flink.source.table.RichTableSource
 
arguments() - Method in class org.apache.paimon.codegen.codesplit.JavaParser
 
arguments() - Method in class org.apache.paimon.codegen.codesplit.JavaParser
 
arguments() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ClassCreatorRestContext
 
arguments() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ClassCreatorRestContext
 
arguments() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.EnumConstantContext
 
arguments() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.EnumConstantContext
 
arguments() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ExplicitGenericInvocationSuffixContext
 
arguments() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ExplicitGenericInvocationSuffixContext
 
arguments() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.PrimaryContext
 
arguments() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.PrimaryContext
 
arguments() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.SuperSuffixContext
 
arguments() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.SuperSuffixContext
 
ArgumentsContext(ParserRuleContext, int) - Constructor for class org.apache.paimon.codegen.codesplit.JavaParser.ArgumentsContext
 
ArgumentsContext(ParserRuleContext, int) - Constructor for class org.apache.paimon.codegen.codesplit.JavaParser.ArgumentsContext
 
array() - Method in class org.apache.paimon.spark.SparkArrayData
 
ARRAY(DataType) - Static method in class org.apache.paimon.types.DataTypes
 
arrayAddress() - Method in class org.apache.paimon.arrow.vector.ArrowCStruct
 
ArrayColumnVector - Interface in org.apache.paimon.data.columnar
Array column vector.
arrayCreatorRest() - Method in class org.apache.paimon.codegen.codesplit.JavaParser
 
arrayCreatorRest() - Method in class org.apache.paimon.codegen.codesplit.JavaParser
 
arrayCreatorRest() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.CreatorContext
 
arrayCreatorRest() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.CreatorContext
 
ArrayCreatorRestContext(ParserRuleContext, int) - Constructor for class org.apache.paimon.codegen.codesplit.JavaParser.ArrayCreatorRestContext
 
ArrayCreatorRestContext(ParserRuleContext, int) - Constructor for class org.apache.paimon.codegen.codesplit.JavaParser.ArrayCreatorRestContext
 
arrayInitializer() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ArrayCreatorRestContext
 
arrayInitializer() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ArrayCreatorRestContext
 
arrayInitializer() - Method in class org.apache.paimon.codegen.codesplit.JavaParser
 
arrayInitializer() - Method in class org.apache.paimon.codegen.codesplit.JavaParser
 
arrayInitializer() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.VariableInitializerContext
 
arrayInitializer() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.VariableInitializerContext
 
ArrayInitializerContext(ParserRuleContext, int) - Constructor for class org.apache.paimon.codegen.codesplit.JavaParser.ArrayInitializerContext
 
ArrayInitializerContext(ParserRuleContext, int) - Constructor for class org.apache.paimon.codegen.codesplit.JavaParser.ArrayInitializerContext
 
ArraySegmentPool - Class in org.apache.paimon.memory
A MemorySegmentPool for allocated segments.
ArraySegmentPool(List<MemorySegment>) - Constructor for class org.apache.paimon.memory.ArraySegmentPool
 
ArrayType - Class in org.apache.paimon.types
Data type of an array of elements with same subtype.
ArrayType(boolean, DataType) - Constructor for class org.apache.paimon.types.ArrayType
 
ArrayType(DataType) - Constructor for class org.apache.paimon.types.ArrayType
 
ArrayUtils - Class in org.apache.paimon.utils
Utils for array.
ArrayWriter(FieldVector, ArrowFieldWriter) - Constructor for class org.apache.paimon.arrow.writer.ArrowFieldWriters.ArrayWriter
 
ARROW - Static variable in class org.apache.paimon.codegen.codesplit.JavaLexer
 
ARROW - Static variable in class org.apache.paimon.codegen.codesplit.JavaLexer
 
ARROW - Static variable in class org.apache.paimon.codegen.codesplit.JavaParser
 
ARROW - Static variable in class org.apache.paimon.codegen.codesplit.JavaParser
 
ARROW() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.LambdaExpressionContext
 
ARROW() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.LambdaExpressionContext
 
Arrow2PaimonVectorConverter - Interface in org.apache.paimon.arrow.converter
Convert a FieldVector to ColumnVector.
Arrow2PaimonVectorConverter.Arrow2PaimonVectorConvertorVisitor - Class in org.apache.paimon.arrow.converter
Visitor to create convertor from arrow to paimon.
Arrow2PaimonVectorConvertorVisitor() - Constructor for class org.apache.paimon.arrow.converter.Arrow2PaimonVectorConverter.Arrow2PaimonVectorConvertorVisitor
 
ARROW_FIELD_TYPE_VISITOR - Static variable in class org.apache.paimon.arrow.ArrowFieldTypeConversion
 
ArrowBatchConverter - Class in org.apache.paimon.arrow.converter
A reusable converter to convert Paimon data in RecordReader.RecordIterator into Arrow format.
ArrowBatchReader - Class in org.apache.paimon.arrow.reader
Reader from a VectorSchemaRoot to paimon rows.
ArrowBatchReader(RowType) - Constructor for class org.apache.paimon.arrow.reader.ArrowBatchReader
 
ArrowBundleRecords - Class in org.apache.paimon.arrow
Batch records for vector schema root.
ArrowBundleRecords(VectorSchemaRoot, RowType) - Constructor for class org.apache.paimon.arrow.ArrowBundleRecords
 
ArrowCStruct - Class in org.apache.paimon.arrow.vector
Cache for Arrow c struct.
ArrowCStruct(ArrowArray, ArrowSchema) - Constructor for class org.apache.paimon.arrow.vector.ArrowCStruct
 
ArrowFieldTypeConversion - Class in org.apache.paimon.arrow
Utils for conversion between Paimon DataType and Arrow FieldType.
ArrowFieldTypeConversion() - Constructor for class org.apache.paimon.arrow.ArrowFieldTypeConversion
 
ArrowFieldTypeConversion.ArrowFieldTypeVisitor - Class in org.apache.paimon.arrow
Convert DataType to FieldType.
ArrowFieldTypeVisitor() - Constructor for class org.apache.paimon.arrow.ArrowFieldTypeConversion.ArrowFieldTypeVisitor
 
ArrowFieldWriter - Class in org.apache.paimon.arrow.writer
A reusable writer to convert a field into Arrow FieldVector.
ArrowFieldWriter(FieldVector) - Constructor for class org.apache.paimon.arrow.writer.ArrowFieldWriter
 
ArrowFieldWriterFactory - Interface in org.apache.paimon.arrow.writer
Factory to create ArrowFieldWriter.
ArrowFieldWriterFactoryVisitor - Class in org.apache.paimon.arrow.writer
Visitor to create ArrowFieldWriterFactory.
ArrowFieldWriterFactoryVisitor() - Constructor for class org.apache.paimon.arrow.writer.ArrowFieldWriterFactoryVisitor
 
ArrowFieldWriters - Class in org.apache.paimon.arrow.writer
Registry of ArrowFieldWriters.
ArrowFieldWriters() - Constructor for class org.apache.paimon.arrow.writer.ArrowFieldWriters
 
ArrowFieldWriters.ArrayWriter - Class in org.apache.paimon.arrow.writer
Writer for ARRAY.
ArrowFieldWriters.BigIntWriter - Class in org.apache.paimon.arrow.writer
Writer for BIGINT.
ArrowFieldWriters.BinaryWriter - Class in org.apache.paimon.arrow.writer
Writer for BINARY & VARBINARY.
ArrowFieldWriters.BooleanWriter - Class in org.apache.paimon.arrow.writer
Writer for BOOLEAN.
ArrowFieldWriters.DateWriter - Class in org.apache.paimon.arrow.writer
Writer for DATE.
ArrowFieldWriters.DecimalWriter - Class in org.apache.paimon.arrow.writer
Writer for DECIMAL.
ArrowFieldWriters.DoubleWriter - Class in org.apache.paimon.arrow.writer
Writer for DOUBLE.
ArrowFieldWriters.FloatWriter - Class in org.apache.paimon.arrow.writer
Writer for FLOAT.
ArrowFieldWriters.IntWriter - Class in org.apache.paimon.arrow.writer
Writer for INT.
ArrowFieldWriters.MapWriter - Class in org.apache.paimon.arrow.writer
Writer for MAP.
ArrowFieldWriters.RowWriter - Class in org.apache.paimon.arrow.writer
Writer for ROW.
ArrowFieldWriters.SmallIntWriter - Class in org.apache.paimon.arrow.writer
Writer for SMALLINT.
ArrowFieldWriters.StringWriter - Class in org.apache.paimon.arrow.writer
Writer for CHAR & VARCHAR.
ArrowFieldWriters.TimestampWriter - Class in org.apache.paimon.arrow.writer
Writer for TIMESTAMP & TIMESTAMP_LTZ.
ArrowFieldWriters.TimeWriter - Class in org.apache.paimon.arrow.writer
Writer for TIME.
ArrowFieldWriters.TinyIntWriter - Class in org.apache.paimon.arrow.writer
Writer for TINYINT.
ArrowFormatCWriter - Class in org.apache.paimon.arrow.vector
This writer could flush to c struct, but you need to release it, except it has been released in c code.
ArrowFormatCWriter(RowType, int, boolean) - Constructor for class org.apache.paimon.arrow.vector.ArrowFormatCWriter
 
ArrowFormatWriter - Class in org.apache.paimon.arrow.vector
Write from InternalRow to VectorSchemaRoot.
ArrowFormatWriter(RowType, int, boolean) - Constructor for class org.apache.paimon.arrow.vector.ArrowFormatWriter
 
ArrowPerRowBatchConverter - Class in org.apache.paimon.arrow.converter
To convert iterator row by row.
ArrowPerRowBatchConverter(VectorSchemaRoot, ArrowFieldWriter[]) - Constructor for class org.apache.paimon.arrow.converter.ArrowPerRowBatchConverter
 
ArrowUtils - Class in org.apache.paimon.arrow
Utilities for creating Arrow objects.
ArrowUtils() - Constructor for class org.apache.paimon.arrow.ArrowUtils
 
ArrowVectorizedBatchConverter - Class in org.apache.paimon.arrow.converter
To convert VectorizedColumnBatch to Arrow format.
ArrowVectorizedBatchConverter(VectorSchemaRoot, ArrowFieldWriter[]) - Constructor for class org.apache.paimon.arrow.converter.ArrowVectorizedBatchConverter
 
ASSERT - Static variable in class org.apache.paimon.codegen.codesplit.JavaLexer
 
ASSERT - Static variable in class org.apache.paimon.codegen.codesplit.JavaLexer
 
ASSERT - Static variable in class org.apache.paimon.codegen.codesplit.JavaParser
 
ASSERT - Static variable in class org.apache.paimon.codegen.codesplit.JavaParser
 
ASSERT() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.StatementContext
 
ASSERT() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.StatementContext
 
assertBatchAdaptiveParallelism(StreamExecutionEnvironment, int) - Static method in class org.apache.paimon.flink.sink.FlinkSink
 
assertBatchAdaptiveParallelism(StreamExecutionEnvironment, int, boolean, boolean) - Static method in class org.apache.paimon.flink.sink.FlinkSink
 
assertBatchAdaptiveParallelism(StreamExecutionEnvironment, int, String) - Static method in class org.apache.paimon.flink.sink.FlinkSink
 
assertCanAlterTable(Identifier) - Method in class org.apache.paimon.privilege.AllGrantedPrivilegeChecker
 
assertCanAlterTable(Identifier) - Method in interface org.apache.paimon.privilege.PrivilegeChecker
 
assertCanAlterTable(Identifier) - Method in class org.apache.paimon.privilege.PrivilegeCheckerImpl
 
assertCanCreateDatabase() - Method in class org.apache.paimon.privilege.AllGrantedPrivilegeChecker
 
assertCanCreateDatabase() - Method in interface org.apache.paimon.privilege.PrivilegeChecker
 
assertCanCreateDatabase() - Method in class org.apache.paimon.privilege.PrivilegeCheckerImpl
 
assertCanCreateTable(String) - Method in class org.apache.paimon.privilege.AllGrantedPrivilegeChecker
 
assertCanCreateTable(String) - Method in interface org.apache.paimon.privilege.PrivilegeChecker
 
assertCanCreateTable(String) - Method in class org.apache.paimon.privilege.PrivilegeCheckerImpl
 
assertCanCreateUser() - Method in class org.apache.paimon.privilege.AllGrantedPrivilegeChecker
 
assertCanCreateUser() - Method in interface org.apache.paimon.privilege.PrivilegeChecker
 
assertCanCreateUser() - Method in class org.apache.paimon.privilege.PrivilegeCheckerImpl
 
assertCanDropDatabase(String) - Method in class org.apache.paimon.privilege.AllGrantedPrivilegeChecker
 
assertCanDropDatabase(String) - Method in interface org.apache.paimon.privilege.PrivilegeChecker
 
assertCanDropDatabase(String) - Method in class org.apache.paimon.privilege.PrivilegeCheckerImpl
 
assertCanDropTable(Identifier) - Method in class org.apache.paimon.privilege.AllGrantedPrivilegeChecker
 
assertCanDropTable(Identifier) - Method in interface org.apache.paimon.privilege.PrivilegeChecker
 
assertCanDropTable(Identifier) - Method in class org.apache.paimon.privilege.PrivilegeCheckerImpl
 
assertCanDropUser() - Method in class org.apache.paimon.privilege.AllGrantedPrivilegeChecker
 
assertCanDropUser() - Method in interface org.apache.paimon.privilege.PrivilegeChecker
 
assertCanDropUser() - Method in class org.apache.paimon.privilege.PrivilegeCheckerImpl
 
assertCanGrant(String, PrivilegeType) - Method in class org.apache.paimon.privilege.AllGrantedPrivilegeChecker
 
assertCanGrant(String, PrivilegeType) - Method in interface org.apache.paimon.privilege.PrivilegeChecker
 
assertCanGrant(String, PrivilegeType) - Method in class org.apache.paimon.privilege.PrivilegeCheckerImpl
 
assertCanInsert(Identifier) - Method in class org.apache.paimon.privilege.AllGrantedPrivilegeChecker
 
assertCanInsert(Identifier) - Method in interface org.apache.paimon.privilege.PrivilegeChecker
 
assertCanInsert(Identifier) - Method in class org.apache.paimon.privilege.PrivilegeCheckerImpl
 
assertCanRevoke() - Method in class org.apache.paimon.privilege.AllGrantedPrivilegeChecker
 
assertCanRevoke() - Method in interface org.apache.paimon.privilege.PrivilegeChecker
 
assertCanRevoke() - Method in class org.apache.paimon.privilege.PrivilegeCheckerImpl
 
assertCanSelect(Identifier) - Method in class org.apache.paimon.privilege.AllGrantedPrivilegeChecker
 
assertCanSelect(Identifier) - Method in interface org.apache.paimon.privilege.PrivilegeChecker
 
assertCanSelect(Identifier) - Method in class org.apache.paimon.privilege.PrivilegeCheckerImpl
 
assertMainBranch(Identifier) - Method in class org.apache.paimon.catalog.AbstractCatalog
 
assertSchemaCompatible(TableSchema, List<DataField>) - Static method in class org.apache.paimon.flink.action.cdc.CdcActionCommonUtils
 
assertStreamingConfiguration(StreamExecutionEnvironment) - Static method in class org.apache.paimon.flink.sink.FlinkSink
 
assertThatChainOfCauses(Throwable) - Static method in class org.apache.paimon.testutils.assertj.PaimonAssertions
Shorthand to assert chain of causes.
assertThatFuture(CompletableFuture<T>) - Static method in class org.apache.paimon.testutils.assertj.PaimonAssertions
Create assertion for CompletableFuture.
assertThatFuture(CompletionStage<T>) - Static method in class org.apache.paimon.testutils.assertj.PaimonAssertions
Create assertion for CompletionStage.
assertThrowable(Throwable, Class<T>) - Static method in class org.apache.paimon.utils.ExceptionUtils
The same as ExceptionUtils.findThrowable(Throwable, Class), but rethrows original exception if the expected exception was not found.
assertThrowableWithMessage(Throwable, String) - Static method in class org.apache.paimon.utils.ExceptionUtils
The same as ExceptionUtils.findThrowableWithMessage(Throwable, String), but rethrows original exception if the expected exception was not found.
ASSIGN - Static variable in class org.apache.paimon.codegen.codesplit.JavaLexer
 
ASSIGN - Static variable in class org.apache.paimon.codegen.codesplit.JavaLexer
 
ASSIGN - Static variable in class org.apache.paimon.codegen.codesplit.JavaParser
 
ASSIGN - Static variable in class org.apache.paimon.codegen.codesplit.JavaParser
 
ASSIGN() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ConstantDeclaratorContext
 
ASSIGN() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ConstantDeclaratorContext
 
ASSIGN() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ElementValuePairContext
 
ASSIGN() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ElementValuePairContext
 
ASSIGN() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ExpressionContext
 
ASSIGN() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ExpressionContext
 
ASSIGN() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ResourceContext
 
ASSIGN() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ResourceContext
 
ASSIGN() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.VariableDeclaratorContext
 
ASSIGN() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.VariableDeclaratorContext
 
assign(BinaryRow, int) - Method in interface org.apache.paimon.index.BucketAssigner
 
assign(BinaryRow, int) - Method in class org.apache.paimon.index.HashBucketAssigner
Assign a bucket for key hash of a record.
assign(int, IntPredicate) - Method in class org.apache.paimon.index.PartitionIndex
 
assign(BinaryRow, int) - Method in class org.apache.paimon.index.SimpleHashBucketAssigner
 
assignBucket(BinaryRow, Filter<Integer>, int) - Method in class org.apache.paimon.crosspartition.BucketAssigner
 
assignerChannelComputer(Integer) - Method in class org.apache.paimon.flink.sink.cdc.CdcDynamicBucketSinkBase
 
assignerChannelComputer(Integer) - Method in class org.apache.paimon.flink.sink.DynamicBucketSink
 
assignerChannelComputer(Integer) - Method in class org.apache.paimon.flink.sink.RowDynamicBucketSink
 
assignFieldsDefaultValue(RecordReader<InternalRow>) - Method in class org.apache.paimon.operation.DefaultValueAssigner
assign default value for column which value is null.
assignSplits() - Method in class org.apache.paimon.flink.source.ContinuousFileSplitEnumerator
assignSuggestedTask(FileStoreSourceSplit) - Method in class org.apache.paimon.flink.source.ContinuousFileSplitEnumerator
 
asSpecificNodeType(String, Class<T>) - Static method in class org.apache.paimon.utils.JsonSerdeUtil
Parses the provided JSON string and casts it to the specified type of JsonNode.
asSQLString() - Method in class org.apache.paimon.types.ArrayType
 
asSQLString() - Method in class org.apache.paimon.types.BigIntType
 
asSQLString() - Method in class org.apache.paimon.types.BinaryType
 
asSQLString() - Method in class org.apache.paimon.types.BooleanType
 
asSQLString() - Method in class org.apache.paimon.types.CharType
 
asSQLString() - Method in class org.apache.paimon.types.DataField
 
asSQLString() - Method in class org.apache.paimon.types.DataType
Returns a string that summarizes this type as SQL standard string for printing to a console.
asSQLString() - Method in class org.apache.paimon.types.DateType
 
asSQLString() - Method in class org.apache.paimon.types.DecimalType
 
asSQLString() - Method in class org.apache.paimon.types.DoubleType
 
asSQLString() - Method in class org.apache.paimon.types.FloatType
 
asSQLString() - Method in class org.apache.paimon.types.IntType
 
asSQLString() - Method in class org.apache.paimon.types.LocalZonedTimestampType
 
asSQLString() - Method in class org.apache.paimon.types.MapType
 
asSQLString() - Method in class org.apache.paimon.types.MultisetType
 
asSQLString() - Method in class org.apache.paimon.types.RowType
 
asSQLString() - Method in class org.apache.paimon.types.SmallIntType
 
asSQLString() - Method in class org.apache.paimon.types.TimestampType
 
asSQLString() - Method in class org.apache.paimon.types.TimeType
 
asSQLString() - Method in class org.apache.paimon.types.TinyIntType
 
asSQLString() - Method in class org.apache.paimon.types.VarBinaryType
 
asSQLString() - Method in class org.apache.paimon.types.VarCharType
 
asSummaryString() - Method in class org.apache.paimon.flink.sink.FlinkTableSinkBase
 
asSummaryString() - Method in class org.apache.paimon.flink.source.DataTableSource
 
asSummaryString() - Method in class org.apache.paimon.flink.source.FlinkTableSource
 
asSummaryString() - Method in class org.apache.paimon.flink.source.SystemTableSource
 
asSummaryString() - Method in class org.apache.paimon.flink.source.table.BaseTableSource
 
ASYNC_FILE_WRITE - Static variable in class org.apache.paimon.CoreOptions
 
asyncFileWrite() - Method in class org.apache.paimon.CoreOptions
 
asyncLookup(RowData) - Method in class org.apache.paimon.flink.lookup.AsyncLookupFunctionWrapper
 
AsyncLookupFunctionWrapper - Class in org.apache.paimon.flink.lookup
A AsyncLookupFunction to wrap sync function.
AsyncLookupFunctionWrapper(NewLookupFunction, int) - Constructor for class org.apache.paimon.flink.lookup.AsyncLookupFunctionWrapper
 
AsyncLookupSinkWrite - Class in org.apache.paimon.flink.sink
StoreSinkWrite for tables with lookup changelog producer and CoreOptions.LOOKUP_WAIT set to false.
AsyncLookupSinkWrite(FileStoreTable, String, StoreSinkWriteState, IOManager, boolean, boolean, boolean, MemorySegmentPool, MetricGroup) - Constructor for class org.apache.paimon.flink.sink.AsyncLookupSinkWrite
 
AsyncPositionOutputStream - Class in org.apache.paimon.fs
A PositionOutputStream which uses a async thread to write data.
AsyncPositionOutputStream(PositionOutputStream) - Constructor for class org.apache.paimon.fs.AsyncPositionOutputStream
 
AsyncRecordReader<T> - Class in org.apache.paimon.utils
A RecordReader to use ASYNC_EXECUTOR to read records async.
AsyncRecordReader(IOExceptionSupplier<RecordReader<T>>) - Constructor for class org.apache.paimon.utils.AsyncRecordReader
 
AT - Static variable in class org.apache.paimon.codegen.codesplit.JavaLexer
 
AT - Static variable in class org.apache.paimon.codegen.codesplit.JavaLexer
 
AT() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.AnnotationContext
 
AT() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.AnnotationContext
 
AT() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.AnnotationTypeDeclarationContext
 
AT() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.AnnotationTypeDeclarationContext
 
AT - Static variable in class org.apache.paimon.codegen.codesplit.JavaParser
 
AT - Static variable in class org.apache.paimon.codegen.codesplit.JavaParser
 
AtomicServiceRequestStats - Class in org.apache.paimon.service.network.stats
Atomic ServiceRequestStats implementation.
AtomicServiceRequestStats() - Constructor for class org.apache.paimon.service.network.stats.AtomicServiceRequestStats
 
AUDIT_LOG - Static variable in class org.apache.paimon.table.system.AuditLogTable
 
AuditLogTable - Class in org.apache.paimon.table.system
A Table for reading audit log of table.
AuditLogTable(FileStoreTable) - Constructor for class org.apache.paimon.table.system.AuditLogTable
 
AUTO_CREATE - Static variable in class org.apache.paimon.CoreOptions
 
AutoClosableProcess - Class in org.apache.paimon.benchmark.utils
Utility class to terminate a given Process when exiting a try-with-resources statement.
AutoClosableProcess.AutoClosableProcessBuilder - Class in org.apache.paimon.benchmark.utils
Builder for most sophisticated processes.
AutoCompactTask(DeletionVectorsMaintainer, List<DataFileMeta>, BucketedAppendCompactManager.CompactRewriter, CompactionMetrics.Reporter) - Constructor for class org.apache.paimon.append.BucketedAppendCompactManager.AutoCompactTask
 
AutoTagForSavepointCommitterOperator<CommitT,GlobalCommitT> - Class in org.apache.paimon.flink.sink
Commit Committable for each snapshot using the CommitterOperator.
AutoTagForSavepointCommitterOperator(CommitterOperator<CommitT, GlobalCommitT>, SerializableSupplier<SnapshotManager>, SerializableSupplier<TagManager>, SerializableSupplier<TagDeletion>, SerializableSupplier<List<TagCallback>>, Duration) - Constructor for class org.apache.paimon.flink.sink.AutoTagForSavepointCommitterOperator
 
available() - Method in class org.apache.paimon.fs.ByteArraySeekableStream
 
available() - Method in class org.apache.paimon.io.DataInputDeserializer
 
available() - Method in class org.apache.paimon.memory.MemorySliceInput
 
AVG_COMPACTION_TIME - Static variable in class org.apache.paimon.operation.metrics.CompactionMetrics
 
AVG_LEVEL0_FILE_COUNT - Static variable in class org.apache.paimon.operation.metrics.CompactionMetrics
 
avgLen() - Method in class org.apache.paimon.stats.ColStats
 
AVRO_OUTPUT_CODEC - Static variable in class org.apache.paimon.format.avro.AvroFileFormat
 
AVRO_ROW_NAME_MAPPING - Static variable in class org.apache.paimon.format.avro.AvroFileFormat
 
AvroBuilder<T> - Interface in org.apache.paimon.format.avro
A builder to create an AvroBulkWriter from an OutputStream.
AvroBulkFormat - Class in org.apache.paimon.format.avro
Provides a FormatReaderFactory for Avro records.
AvroBulkFormat(RowType) - Constructor for class org.apache.paimon.format.avro.AvroBulkFormat
 
AvroBulkWriter<T> - Class in org.apache.paimon.format.avro
A simple writer implementation that wraps an Avro DataFileWriter.
AvroBulkWriter(DataFileWriter<T>) - Constructor for class org.apache.paimon.format.avro.AvroBulkWriter
Create a new AvroBulkWriter wrapping the given Avro DataFileWriter.
AvroFileFormat - Class in org.apache.paimon.format.avro
AvroFileFormat(FileFormatFactory.FormatContext) - Constructor for class org.apache.paimon.format.avro.AvroFileFormat
 
AvroFileFormatFactory - Class in org.apache.paimon.format.avro
Factory to create AvroFileFormat.
AvroFileFormatFactory() - Constructor for class org.apache.paimon.format.avro.AvroFileFormatFactory
 
AvroRowDatumReader - Class in org.apache.paimon.format.avro
A DatumReader for reading InternalRow.
AvroRowDatumReader(RowType) - Constructor for class org.apache.paimon.format.avro.AvroRowDatumReader
 
AvroRowDatumWriter - Class in org.apache.paimon.format.avro
A DatumWriter for writing InternalRow.
AvroRowDatumWriter(RowType) - Constructor for class org.apache.paimon.format.avro.AvroRowDatumWriter
 
AvroSchemaConverter - Class in org.apache.paimon.format.avro
Converts an Avro schema into Paimon's type information.
AvroSchemaTypelessReader<T> - Interface in org.apache.paimon.format.avro
Visitor to visit Schema which could generate reader without type, but that reader should only call to skip.
AvroSchemaVisitor<T> - Interface in org.apache.paimon.format.avro
Visitor to visit Schema.
AvroSimpleStatsExtractor - Class in org.apache.paimon.format.avro
SimpleStatsExtractor for avro files.
AvroSimpleStatsExtractor(RowType, SimpleColStatsCollector.Factory[]) - Constructor for class org.apache.paimon.format.avro.AvroSimpleStatsExtractor
 
avroToPaimonDataType(Schema) - Static method in class org.apache.paimon.flink.action.cdc.format.debezium.DebeziumSchemaUtils
 
AvroWriterFactory<T> - Class in org.apache.paimon.format.avro
A factory that creates an AvroBulkWriter.
AvroWriterFactory(AvroBuilder<T>) - Constructor for class org.apache.paimon.format.avro.AvroWriterFactory
Creates a new AvroWriterFactory using the given builder to assemble the ParquetWriter.
AWAIT_TIMEOUT_SECONDS - Static variable in class org.apache.paimon.fs.AsyncPositionOutputStream
 

B

BadRequestException - Exception in org.apache.paimon.service.network
Base class for exceptions thrown during querying.
BadRequestException(String, String) - Constructor for exception org.apache.paimon.service.network.BadRequestException
 
BANG - Static variable in class org.apache.paimon.codegen.codesplit.JavaLexer
 
BANG - Static variable in class org.apache.paimon.codegen.codesplit.JavaLexer
 
BANG - Static variable in class org.apache.paimon.codegen.codesplit.JavaParser
 
BANG - Static variable in class org.apache.paimon.codegen.codesplit.JavaParser
 
BANG() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ExpressionContext
 
BANG() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ExpressionContext
 
baseManifestList - Variable in class org.apache.paimon.Snapshot
 
baseManifestList() - Method in class org.apache.paimon.Snapshot
 
baseSnapshotId - Variable in class org.apache.paimon.operation.AbstractFileStoreWrite.WriterContainer
 
baseSnapshotId - Variable in class org.apache.paimon.operation.FileStoreWrite.State
 
BaseTableSource - Class in org.apache.paimon.flink.source.table
The ScanTableSource with push down interfaces.
BaseTableSource(FlinkTableSource) - Constructor for class org.apache.paimon.flink.source.table.BaseTableSource
 
BaseTagPeriodHandler() - Constructor for class org.apache.paimon.tag.TagPeriodHandler.BaseTagPeriodHandler
 
batch() - Method in class org.apache.paimon.data.columnar.ColumnarRow
 
batch() - Method in class org.apache.paimon.data.columnar.ColumnarRowIterator
 
batch() - Method in interface org.apache.paimon.reader.VectorizedRecordIterator
 
BatchRecordWriter - Interface in org.apache.paimon.utils
Write BundleRecords directly.
batchSink(DataStream<RowData>) - Method in class org.apache.paimon.flink.action.TableActionBase
Sink DataStream dataStream to table with Flink Table API in batch environment.
batchSize - Variable in class org.apache.paimon.format.orc.OrcReaderFactory
 
batchSizeForVectorReads() - Method in interface org.apache.paimon.fs.VectoredReadable
The batch size of data read by a single parallelism.
BatchTableCommit - Interface in org.apache.paimon.table.sink
A TableCommit for batch processing.
BatchTableWrite - Interface in org.apache.paimon.table.sink
A TableWrite for batch processing.
batchTEnv - Variable in class org.apache.paimon.flink.action.ActionBase
 
batchTEnv - Variable in class org.apache.paimon.flink.sorter.TableSorter
 
BatchWriteBuilder - Interface in org.apache.paimon.table.sink
An interface for building the BatchTableWrite and BatchTableCommit.
BatchWriteBuilderImpl - Class in org.apache.paimon.table.sink
Implementation for WriteBuilder.
BatchWriteBuilderImpl(InnerTable) - Constructor for class org.apache.paimon.table.sink.BatchWriteBuilderImpl
 
BatchWriteGeneratorTagOperator<CommitT,GlobalCommitT> - Class in org.apache.paimon.flink.sink
Commit Committable for snapshot using the CommitterOperator.
BatchWriteGeneratorTagOperator(CommitterOperator<CommitT, GlobalCommitT>, FileStoreTable) - Constructor for class org.apache.paimon.flink.sink.BatchWriteGeneratorTagOperator
 
before() - Method in class org.apache.paimon.compact.CompactResult
 
before() - Method in class org.apache.paimon.flink.action.cdc.mysql.format.DebeziumEvent.Payload
 
before(String, String) - Static method in class org.apache.paimon.schema.SchemaChange.Move
 
beforeAndAfterFields() - Method in class org.apache.paimon.flink.action.cdc.mysql.format.DebeziumEvent.Field
 
beforeBuildingSourceSink() - Method in class org.apache.paimon.flink.action.cdc.mysql.MySqlSyncDatabaseAction
 
beforeBuildingSourceSink() - Method in class org.apache.paimon.flink.action.cdc.SynchronizationActionBase
 
beforeBuildingSourceSink() - Method in class org.apache.paimon.flink.action.cdc.SyncTableActionBase
 
beforeDeletionFiles() - Method in class org.apache.paimon.table.source.DataSplit
 
beforeEach(ExtensionContext) - Method in class org.apache.paimon.testutils.junit.TestLoggerExtension
 
beforeFiles() - Method in class org.apache.paimon.flink.source.align.PlaceholderSplit
 
beforeFiles() - Method in class org.apache.paimon.table.source.DataSplit
 
beforeFiles() - Method in class org.apache.paimon.table.system.FileMonitorTable.FileChange
 
beforeSql() - Method in class org.apache.paimon.benchmark.Sink
 
Benchmark - Class in org.apache.paimon.benchmark
The entry point to run benchmark.
Benchmark() - Constructor for class org.apache.paimon.benchmark.Benchmark
 
BENCHMARK_CONF_FILENAME - Static variable in class org.apache.paimon.benchmark.utils.BenchmarkGlobalConfiguration
 
BenchmarkGlobalConfiguration - Class in org.apache.paimon.benchmark.utils
Global configuration object for benchmark.
BenchmarkMetric - Class in org.apache.paimon.benchmark.metric
Metric collected per BenchmarkOptions.METRIC_MONITOR_INTERVAL for a single query.
BenchmarkMetric(double, long, double, Long) - Constructor for class org.apache.paimon.benchmark.metric.BenchmarkMetric
 
BenchmarkOptions - Class in org.apache.paimon.benchmark
Benchmark execution options.
BenchmarkOptions() - Constructor for class org.apache.paimon.benchmark.BenchmarkOptions
 
BenchmarkUtils - Class in org.apache.paimon.benchmark.utils
Formatting utils for benchmark.
BenchmarkUtils() - Constructor for class org.apache.paimon.benchmark.utils.BenchmarkUtils
 
between(int, Object, Object) - Method in class org.apache.paimon.predicate.PredicateBuilder
 
bfGenerator(Options) - Static method in interface org.apache.paimon.lookup.LookupStoreFactory
 
BiFunctionWithIOE<T,U,R> - Interface in org.apache.paimon.utils
A bi function with IOException.
BIGINT() - Static method in class org.apache.paimon.types.DataTypes
 
BigIntType - Class in org.apache.paimon.types
Data type of an 8-byte signed integer with values from -9,223,372,036,854,775,808 to 9,223,372,036,854,775,807.
BigIntType(boolean) - Constructor for class org.apache.paimon.types.BigIntType
 
BigIntType() - Constructor for class org.apache.paimon.types.BigIntType
 
BigIntWriter(FieldVector) - Constructor for class org.apache.paimon.arrow.writer.ArrowFieldWriters.BigIntWriter
 
BINARY(int) - Static method in class org.apache.paimon.types.DataTypes
 
BINARY_LITERAL - Static variable in class org.apache.paimon.codegen.codesplit.JavaLexer
 
BINARY_LITERAL - Static variable in class org.apache.paimon.codegen.codesplit.JavaLexer
 
BINARY_LITERAL - Static variable in class org.apache.paimon.codegen.codesplit.JavaParser
 
BINARY_LITERAL - Static variable in class org.apache.paimon.codegen.codesplit.JavaParser
 
BINARY_LITERAL() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.IntegerLiteralContext
 
BINARY_LITERAL() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.IntegerLiteralContext
 
BinaryArray - Class in org.apache.paimon.data
A binary implementation of InternalArray which is backed by MemorySegments.
BinaryArray() - Constructor for class org.apache.paimon.data.BinaryArray
 
BinaryArrayWriter - Class in org.apache.paimon.data
Writer for binary array.
BinaryArrayWriter(BinaryArray, int, int) - Constructor for class org.apache.paimon.data.BinaryArrayWriter
 
BinaryArrayWriter.NullSetter - Interface in org.apache.paimon.data
Accessor for setting the elements of an array writer to null during runtime.
BinaryExternalMerger - Class in org.apache.paimon.sort
Record merger for sort of BinaryRow.
BinaryExternalMerger(IOManager, int, int, SpillChannelManager, BinaryRowSerializer, RecordComparator, BlockCompressionFactory, int) - Constructor for class org.apache.paimon.sort.BinaryExternalMerger
 
BinaryExternalSortBuffer - Class in org.apache.paimon.sort
A spillable SortBuffer.
BinaryExternalSortBuffer(BinaryRowSerializer, RecordComparator, int, BinaryInMemorySortBuffer, IOManager, int, CompressOptions, MemorySize) - Constructor for class org.apache.paimon.sort.BinaryExternalSortBuffer
 
BinaryIndexedSortable - Class in org.apache.paimon.sort
An abstract sortable, provide basic compare and swap.
BinaryIndexedSortable(NormalizedKeyComputer, BinaryRowSerializer, RecordComparator, ArrayList<MemorySegment>, MemorySegmentPool) - Constructor for class org.apache.paimon.sort.BinaryIndexedSortable
 
BinaryInMemorySortBuffer - Class in org.apache.paimon.sort
In memory sort buffer for binary row.
BinaryMap - Class in org.apache.paimon.data
[4 byte(keyArray size in bytes)] + [Key BinaryArray] + [Value BinaryArray].
BinaryMap() - Constructor for class org.apache.paimon.data.BinaryMap
 
BinaryMergeIterator<Entry> - Class in org.apache.paimon.sort
Binary version of MergeIterator.
BinaryMergeIterator(List<MutableObjectIterator<Entry>>, List<Entry>, Comparator<Entry>) - Constructor for class org.apache.paimon.sort.BinaryMergeIterator
 
BinaryRow - Class in org.apache.paimon.data
An implementation of InternalRow which is backed by MemorySegment instead of Object.
BinaryRow(int) - Constructor for class org.apache.paimon.data.BinaryRow
 
BinaryRowDataUtil - Class in org.apache.paimon.utils
Utilities for BinaryRow.
BinaryRowDataUtil() - Constructor for class org.apache.paimon.utils.BinaryRowDataUtil
 
BinaryRowSerializer - Class in org.apache.paimon.data.serializer
Serializer for BinaryRow.
BinaryRowSerializer(int) - Constructor for class org.apache.paimon.data.serializer.BinaryRowSerializer
 
BinaryRowWriter - Class in org.apache.paimon.data
Writer for BinaryRow.
BinaryRowWriter(BinaryRow) - Constructor for class org.apache.paimon.data.BinaryRowWriter
 
BinaryRowWriter(BinaryRow, int) - Constructor for class org.apache.paimon.data.BinaryRowWriter
 
BinarySection - Class in org.apache.paimon.data
Describe a section of memory.
BinarySection() - Constructor for class org.apache.paimon.data.BinarySection
 
BinarySection(MemorySegment[], int, int) - Constructor for class org.apache.paimon.data.BinarySection
 
BinarySerializer - Class in org.apache.paimon.data.serializer
Type serializer for byte[].
BinarySerializer() - Constructor for class org.apache.paimon.data.serializer.BinarySerializer
 
BinaryString - Class in org.apache.paimon.data
A string which is backed by MemorySegments.
BinaryString(MemorySegment[], int, int) - Constructor for class org.apache.paimon.data.BinaryString
 
BinaryStringSerializer - Class in org.apache.paimon.data.serializer
Serializer for BinaryString.
BinaryStringUtils - Class in org.apache.paimon.utils
Util for BinaryString.
BinaryStringUtils() - Constructor for class org.apache.paimon.utils.BinaryStringUtils
 
BinaryToStringCastRule - Class in org.apache.paimon.casting
BinaryType - Class in org.apache.paimon.types
Data type of a fixed-length binary string (=a sequence of bytes).
BinaryType(boolean, int) - Constructor for class org.apache.paimon.types.BinaryType
 
BinaryType(int) - Constructor for class org.apache.paimon.types.BinaryType
 
BinaryType() - Constructor for class org.apache.paimon.types.BinaryType
 
BinaryWriter(FieldVector) - Constructor for class org.apache.paimon.arrow.writer.ArrowFieldWriters.BinaryWriter
 
BinaryWriter - Interface in org.apache.paimon.data
Writer to write a composite data format, like row, array.
BinaryWriter.ValueSetter - Interface in org.apache.paimon.data
Accessor for setting the elements of a binary writer during runtime.
bind(StructType) - Method in class org.apache.paimon.spark.catalog.functions.PaimonFunctions.BucketFunction
 
BinPacking - Class in org.apache.paimon.utils
Contains bin packing implementations.
BIT_BYTE_INDEX_MASK - Static variable in class org.apache.paimon.memory.MemorySegmentUtils
 
BITAND - Static variable in class org.apache.paimon.codegen.codesplit.JavaLexer
 
BITAND - Static variable in class org.apache.paimon.codegen.codesplit.JavaLexer
 
BITAND - Static variable in class org.apache.paimon.codegen.codesplit.JavaParser
 
BITAND - Static variable in class org.apache.paimon.codegen.codesplit.JavaParser
 
BITAND() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ExpressionContext
 
BITAND() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ExpressionContext
 
BITAND() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.TypeBoundContext
 
BITAND(int) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.TypeBoundContext
 
BITAND() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.TypeBoundContext
 
BITAND(int) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.TypeBoundContext
 
bitGet(MemorySegment, int, int) - Static method in class org.apache.paimon.memory.MemorySegmentUtils
read bit.
bitGet(MemorySegment[], int, int) - Static method in class org.apache.paimon.memory.MemorySegmentUtils
read bit from segments.
BITMAP_INDEX - Static variable in class org.apache.paimon.fileindex.bitmap.BitmapFileIndexFactory
 
BitmapDeletionVector - Class in org.apache.paimon.deletionvectors
A DeletionVector based on RoaringBitmap32, it only supports files with row count not exceeding RoaringBitmap32.MAX_VALUE.
BitmapDeletionVector() - Constructor for class org.apache.paimon.deletionvectors.BitmapDeletionVector
 
BitmapFileIndex - Class in org.apache.paimon.fileindex.bitmap
implementation of bitmap file index.
BitmapFileIndex(DataType, Options) - Constructor for class org.apache.paimon.fileindex.bitmap.BitmapFileIndex
 
BitmapFileIndexFactory - Class in org.apache.paimon.fileindex.bitmap
Factory to create BitmapFileIndex.
BitmapFileIndexFactory() - Constructor for class org.apache.paimon.fileindex.bitmap.BitmapFileIndexFactory
 
BitmapFileIndexMeta - Class in org.apache.paimon.fileindex.bitmap
Bitmap file index format (V1) +-------------------------------------------------+----------------- | version (1 byte) | +-------------------------------------------------+ | row count (4 bytes int) | +-------------------------------------------------+ | non-null value bitmap number (4 bytes int) | +-------------------------------------------------+ | has null value (1 byte) | +-------------------------------------------------+ | null value offset (4 bytes if has null value) | HEAD +-------------------------------------------------+ | value 1 | offset 1 | +-------------------------------------------------+ | value 2 | offset 2 | +-------------------------------------------------+ | value 3 | offset 3 | +-------------------------------------------------+ | ...
BitmapFileIndexMeta(DataType) - Constructor for class org.apache.paimon.fileindex.bitmap.BitmapFileIndexMeta
 
BitmapFileIndexMeta(DataType, int, int, boolean, int, LinkedHashMap<Object, Integer>) - Constructor for class org.apache.paimon.fileindex.bitmap.BitmapFileIndexMeta
 
BitmapFileIndexMeta.DataTypeVisitorAdapter<R> - Class in org.apache.paimon.fileindex.bitmap
simplified visitor.
BitmapFileIndexMeta.ThrowableConsumer - Interface in org.apache.paimon.fileindex.bitmap
functional interface.
BitmapFileIndexMeta.ThrowableSupplier - Interface in org.apache.paimon.fileindex.bitmap
functional interface.
BitmapIndexResultLazy - Class in org.apache.paimon.fileindex.bitmap
bitmap file index result.
BitmapIndexResultLazy(Supplier<RoaringBitmap32>) - Constructor for class org.apache.paimon.fileindex.bitmap.BitmapIndexResultLazy
 
bitmapOf(int...) - Static method in class org.apache.paimon.utils.RoaringBitmap32
 
bitmapOf(long...) - Static method in class org.apache.paimon.utils.RoaringBitmap64
 
BITOR - Static variable in class org.apache.paimon.codegen.codesplit.JavaLexer
 
BITOR - Static variable in class org.apache.paimon.codegen.codesplit.JavaLexer
 
BITOR - Static variable in class org.apache.paimon.codegen.codesplit.JavaParser
 
BITOR - Static variable in class org.apache.paimon.codegen.codesplit.JavaParser
 
BITOR() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.CatchTypeContext
 
BITOR(int) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.CatchTypeContext
 
BITOR() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.CatchTypeContext
 
BITOR(int) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.CatchTypeContext
 
BITOR() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ExpressionContext
 
BITOR() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ExpressionContext
 
bitSet(MemorySegment, int, int) - Static method in class org.apache.paimon.memory.MemorySegmentUtils
set bit.
bitSet(MemorySegment[], int, int) - Static method in class org.apache.paimon.memory.MemorySegmentUtils
set bit from segments.
BitSet - Class in org.apache.paimon.utils
BitSet based on MemorySegment.
BitSet(int) - Constructor for class org.apache.paimon.utils.BitSet
 
BitSet(byte[], int) - Constructor for class org.apache.paimon.utils.BloomFilter64.BitSet
 
bitSize() - Method in class org.apache.paimon.utils.BitSet
Number of bits.
bitSize() - Method in class org.apache.paimon.utils.BloomFilter64.BitSet
 
bitUnSet(MemorySegment, int, int) - Static method in class org.apache.paimon.memory.MemorySegmentUtils
unset bit.
bitUnSet(MemorySegment[], int, int) - Static method in class org.apache.paimon.memory.MemorySegmentUtils
unset bit from segments.
blankString(int) - Static method in class org.apache.paimon.data.BinaryString
Creates a BinaryString instance that contains `length` spaces.
block() - Method in class org.apache.paimon.codegen.codesplit.JavaParser
 
block() - Method in class org.apache.paimon.codegen.codesplit.JavaParser
 
block() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.CatchClauseContext
 
block() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.CatchClauseContext
 
block() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ClassBodyDeclarationContext
 
block() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ClassBodyDeclarationContext
 
block() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ConstructorDeclarationContext
 
block() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ConstructorDeclarationContext
 
block() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.FinallyBlockContext
 
block() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.FinallyBlockContext
 
block() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.LambdaBodyContext
 
block() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.LambdaBodyContext
 
block() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.MethodBodyContext
 
block() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.MethodBodyContext
 
block() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.StatementContext
 
block() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.StatementContext
 
BLOCK_CACHE_SIZE - Static variable in class org.apache.paimon.lookup.RocksDBOptions
 
BLOCK_SIZE - Static variable in class org.apache.paimon.lookup.RocksDBOptions
 
BlockAlignedType - Enum in org.apache.paimon.lookup.sort
Aligned type for block.
BlockCompressionFactory - Interface in org.apache.paimon.compression
Each compression codec has an implementation of BlockCompressionFactory to create compressors and decompressors.
BlockCompressionType - Enum in org.apache.paimon.compression
Block Compression type.
BlockCompressor - Interface in org.apache.paimon.compression
A compressor which compresses a whole byte array each time.
BlockContext(ParserRuleContext, int) - Constructor for class org.apache.paimon.codegen.codesplit.JavaParser.BlockContext
 
BlockContext(ParserRuleContext, int) - Constructor for class org.apache.paimon.codegen.codesplit.JavaParser.BlockContext
 
BlockDecompressor - Interface in org.apache.paimon.compression
A decompressor which decompresses a block each time.
BlockElement - Interface in org.apache.paimon.options.description
Part of description that represents a block e.g.
BlockEntry - Class in org.apache.paimon.lookup.sort
Entry represents a key value.
BlockEntry(MemorySlice, MemorySlice) - Constructor for class org.apache.paimon.lookup.sort.BlockEntry
 
BlockHandle - Class in org.apache.paimon.lookup.sort
Handle for a block.
BlockingExecutor - Class in org.apache.paimon.utils
A executor wrapper to execute with Semaphore.
BlockingExecutor(ExecutorService, int) - Constructor for class org.apache.paimon.utils.BlockingExecutor
 
BlockIterator - Class in org.apache.paimon.lookup.sort
An Iterator for a block.
BlockIterator(MemorySliceInput, int, Comparator<MemorySlice>) - Constructor for class org.apache.paimon.lookup.sort.BlockIterator
 
blockLabel - Variable in class org.apache.paimon.codegen.codesplit.JavaParser.StatementContext
 
blockLabel - Variable in class org.apache.paimon.codegen.codesplit.JavaParser.StatementContext
 
blockPadding(boolean) - Method in class org.apache.orc.OrcFile.WriterOptions
Sets whether the HDFS blocks are padded to prevent stripes from straddling blocks.
BlockReader - Class in org.apache.paimon.lookup.sort
Reader for a block.
BlockReader(MemorySlice, Comparator<MemorySlice>) - Constructor for class org.apache.paimon.lookup.sort.BlockReader
 
blockSize(long) - Method in class org.apache.orc.OrcFile.WriterOptions
Set the file system block size for the file.
blockSize() - Method in class org.apache.paimon.format.FileFormatFactory.FormatContext
 
blockStatement() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.BlockContext
 
blockStatement(int) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.BlockContext
 
blockStatement() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.BlockContext
 
blockStatement(int) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.BlockContext
 
blockStatement() - Method in class org.apache.paimon.codegen.codesplit.JavaParser
 
blockStatement() - Method in class org.apache.paimon.codegen.codesplit.JavaParser
 
blockStatement() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.SwitchBlockStatementGroupContext
 
blockStatement(int) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.SwitchBlockStatementGroupContext
 
blockStatement() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.SwitchBlockStatementGroupContext
 
blockStatement(int) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.SwitchBlockStatementGroupContext
 
BlockStatementContext(ParserRuleContext, int) - Constructor for class org.apache.paimon.codegen.codesplit.JavaParser.BlockStatementContext
 
BlockStatementContext(ParserRuleContext, int) - Constructor for class org.apache.paimon.codegen.codesplit.JavaParser.BlockStatementContext
 
BlockStatementGrouper - Class in org.apache.paimon.codegen.codesplit
Groups end extract single line statements such as operations on fields/local variables, IF and WHILE statements and extract new method for each group making them smaller.
BlockStatementGrouper(String, long, String) - Constructor for class org.apache.paimon.codegen.codesplit.BlockStatementGrouper
Initialize new BlockStatementGrouper.
BlockStatementGrouper.RewriteGroupedCode - Class in org.apache.paimon.codegen.codesplit
This object represents a rewritten code block.
BlockStatementRewriter - Class in org.apache.paimon.codegen.codesplit
Extract branch of IFs, ELSEs statements and WHILEs code blocks into smaller methods.
BlockStatementRewriter(String, long) - Constructor for class org.apache.paimon.codegen.codesplit.BlockStatementRewriter
 
BlockStatementSplitter - Class in org.apache.paimon.codegen.codesplit
Extract statements from IFs, ELSEs and WHILEs blocks making them smaller.
BlockStatementSplitter(String, String) - Constructor for class org.apache.paimon.codegen.codesplit.BlockStatementSplitter
Initialize new BlockStatementSplitter.
BlockTrailer - Class in org.apache.paimon.lookup.sort
Trailer of a block.
BlockTrailer(BlockCompressionType, int) - Constructor for class org.apache.paimon.lookup.sort.BlockTrailer
 
BlockWriter - Class in org.apache.paimon.lookup.sort
Writer to build a Block.
BlockWriter(int) - Constructor for class org.apache.paimon.lookup.sort.BlockWriter
 
BLOOM_FILTER - Static variable in class org.apache.paimon.fileindex.bloomfilter.BloomFilterFileIndexFactory
 
BLOOM_FILTER_BITS_PER_KEY - Static variable in class org.apache.paimon.lookup.RocksDBOptions
 
BLOOM_FILTER_BLOCK_BASED_MODE - Static variable in class org.apache.paimon.lookup.RocksDBOptions
 
BloomFilter - Class in org.apache.paimon.utils
Bloom filter based on one memory segment.
BloomFilter(long, int) - Constructor for class org.apache.paimon.utils.BloomFilter
 
BloomFilter.Builder - Class in org.apache.paimon.utils
Bloom filter based on one memory segment.
BloomFilter64 - Class in org.apache.paimon.utils
Bloom filter 64 handle 64 bits hash.
BloomFilter64(long, double) - Constructor for class org.apache.paimon.utils.BloomFilter64
 
BloomFilter64(int, BloomFilter64.BitSet) - Constructor for class org.apache.paimon.utils.BloomFilter64
 
BloomFilter64.BitSet - Class in org.apache.paimon.utils
Bit set used for bloom filter 64.
bloomFilterColumns(String) - Method in class org.apache.orc.OrcFile.WriterOptions
Comma separated values of column names for which bloom filter is to be created.
BloomFilterFileIndex - Class in org.apache.paimon.fileindex.bloomfilter
Bloom filter for file index.
BloomFilterFileIndex(DataType, Options) - Constructor for class org.apache.paimon.fileindex.bloomfilter.BloomFilterFileIndex
 
BloomFilterFileIndexFactory - Class in org.apache.paimon.fileindex.bloomfilter
Index factory to construct BloomFilterFileIndex.
BloomFilterFileIndexFactory() - Constructor for class org.apache.paimon.fileindex.bloomfilter.BloomFilterFileIndexFactory
 
bloomFilterFpp(double) - Method in class org.apache.orc.OrcFile.WriterOptions
Specify the false positive probability for bloom filter.
BloomFilterHandle - Class in org.apache.paimon.lookup.sort
Handle for bloom filter.
bloomFilterVersion(OrcFile.BloomFilterVersion) - Method in class org.apache.orc.OrcFile.WriterOptions
Set the version of the bloom filters to write.
BOOL_LITERAL - Static variable in class org.apache.paimon.codegen.codesplit.JavaLexer
 
BOOL_LITERAL - Static variable in class org.apache.paimon.codegen.codesplit.JavaLexer
 
BOOL_LITERAL - Static variable in class org.apache.paimon.codegen.codesplit.JavaParser
 
BOOL_LITERAL - Static variable in class org.apache.paimon.codegen.codesplit.JavaParser
 
BOOL_LITERAL() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.LiteralContext
 
BOOL_LITERAL() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.LiteralContext
 
BOOLEAN - Static variable in class org.apache.paimon.codegen.codesplit.JavaLexer
 
BOOLEAN - Static variable in class org.apache.paimon.codegen.codesplit.JavaLexer
 
BOOLEAN - Static variable in class org.apache.paimon.codegen.codesplit.JavaParser
 
BOOLEAN - Static variable in class org.apache.paimon.codegen.codesplit.JavaParser
 
BOOLEAN() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.PrimitiveTypeContext
 
BOOLEAN() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.PrimitiveTypeContext
 
BOOLEAN() - Static method in class org.apache.paimon.types.DataTypes
 
BooleanArrayList - Class in org.apache.paimon.utils
Minimal implementation of an array-backed list of booleans.
BooleanArrayList(int) - Constructor for class org.apache.paimon.utils.BooleanArrayList
 
BooleanColumnReader - Class in org.apache.paimon.format.parquet.reader
Boolean ColumnReader.
BooleanColumnReader(ColumnDescriptor, PageReader) - Constructor for class org.apache.paimon.format.parquet.reader.BooleanColumnReader
 
BooleanColumnVector - Interface in org.apache.paimon.data.columnar
Boolean column vector.
BooleanSerializer - Class in org.apache.paimon.data.serializer
Type serializer for Boolean (and bool, via auto-boxing).
BooleanSerializer() - Constructor for class org.apache.paimon.data.serializer.BooleanSerializer
 
booleanType() - Method in class org.apache.paimon.options.ConfigOptions.OptionBuilder
Defines that the value of the option should be of Boolean type.
BooleanType - Class in org.apache.paimon.types
Data type of a boolean with a (possibly) three-valued logic of TRUE, FALSE, UNKNOWN.
BooleanType(boolean) - Constructor for class org.apache.paimon.types.BooleanType
 
BooleanType() - Constructor for class org.apache.paimon.types.BooleanType
 
BooleanWriter(FieldVector) - Constructor for class org.apache.paimon.arrow.writer.ArrowFieldWriters.BooleanWriter
 
bootstrap(int, int, Consumer<InternalRow>) - Method in class org.apache.paimon.crosspartition.IndexBootstrap
 
bootstrap(int, int) - Method in class org.apache.paimon.crosspartition.IndexBootstrap
 
bootstrap() - Method in class org.apache.paimon.flink.lookup.FullCacheLookupTable
 
BOOTSTRAP_SERVERS - Static variable in class org.apache.paimon.flink.kafka.KafkaLogOptions
 
bootstrapBucket(BinaryRow, int) - Method in class org.apache.paimon.crosspartition.BucketAssigner
 
bootstrapKey(InternalRow) - Method in class org.apache.paimon.crosspartition.GlobalIndexAssigner
 
bootstrapType(TableSchema) - Static method in class org.apache.paimon.crosspartition.IndexBootstrap
 
bop - Variable in class org.apache.paimon.codegen.codesplit.JavaParser.ExpressionContext
 
bop - Variable in class org.apache.paimon.codegen.codesplit.JavaParser.ExpressionContext
 
BoundedChecker - Interface in org.apache.paimon.table.source.snapshot
Checker to check whether the bounded stream is end.
BRANCH - Static variable in class org.apache.paimon.CoreOptions
 
branch() - Method in class org.apache.paimon.CoreOptions
 
branch(Map<String, String>) - Static method in class org.apache.paimon.CoreOptions
 
branch() - Method in class org.apache.paimon.utils.SnapshotManager
 
BRANCH_PREFIX - Static variable in class org.apache.paimon.utils.BranchManager
 
branchDirectory() - Method in class org.apache.paimon.utils.BranchManager
Return the root Directory of branch.
BRANCHES - Static variable in class org.apache.paimon.table.system.BranchesTable
 
branches() - Method in class org.apache.paimon.utils.BranchManager
Get all branches for the table.
BranchesTable - Class in org.apache.paimon.table.system
A Table for showing branches of table.
BranchesTable(FileStoreTable) - Constructor for class org.apache.paimon.table.system.BranchesTable
 
BranchesTable(FileIO, Path) - Constructor for class org.apache.paimon.table.system.BranchesTable
 
branchExists(String) - Method in class org.apache.paimon.utils.BranchManager
Check if a branch exists.
branchManager() - Method in class org.apache.paimon.privilege.PrivilegedFileStoreTable
 
branchManager() - Method in interface org.apache.paimon.table.DataTable
 
branchManager() - Method in class org.apache.paimon.table.DelegatedFileStoreTable
 
branchManager() - Method in class org.apache.paimon.table.system.AuditLogTable
 
branchManager() - Method in class org.apache.paimon.table.system.CompactBucketsTable
 
branchManager() - Method in class org.apache.paimon.table.system.FileMonitorTable
 
branchManager() - Method in class org.apache.paimon.table.system.ReadOptimizedTable
 
BranchManager - Class in org.apache.paimon.utils
Manager for Branch.
BranchManager(FileIO, Path, SnapshotManager, TagManager, SchemaManager) - Constructor for class org.apache.paimon.utils.BranchManager
 
branchPath(Path, String) - Static method in class org.apache.paimon.utils.BranchManager
Return the path string of a branch.
branchPath(String) - Method in class org.apache.paimon.utils.BranchManager
Return the path of a branch.
BREAK - Static variable in class org.apache.paimon.codegen.codesplit.JavaLexer
 
BREAK - Static variable in class org.apache.paimon.codegen.codesplit.JavaLexer
 
BREAK - Static variable in class org.apache.paimon.codegen.codesplit.JavaParser
 
BREAK - Static variable in class org.apache.paimon.codegen.codesplit.JavaParser
 
BREAK() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.StatementContext
 
BREAK() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.StatementContext
 
BUCKET - Static variable in class org.apache.paimon.CoreOptions
 
bucket() - Method in class org.apache.paimon.CoreOptions
 
bucket() - Method in class org.apache.paimon.flink.lookup.FixedBucketFromPkExtractor
 
bucket() - Method in class org.apache.paimon.flink.sink.cdc.CdcRecordKeyAndBucketExtractor
 
bucket() - Method in class org.apache.paimon.flink.sink.LogOffsetCommittable
 
bucket() - Method in class org.apache.paimon.flink.sink.RowDataKeyAndBucketExtractor
 
bucket() - Method in class org.apache.paimon.flink.sink.StoreSinkWriteState.StateValue
 
bucket() - Method in class org.apache.paimon.flink.source.align.PlaceholderSplit
 
bucket() - Method in class org.apache.paimon.manifest.BucketEntry
 
bucket() - Method in interface org.apache.paimon.manifest.FileEntry
 
bucket - Variable in class org.apache.paimon.manifest.FileEntry.Identifier
 
bucket() - Method in class org.apache.paimon.manifest.IndexManifestEntry
 
bucket() - Method in class org.apache.paimon.manifest.ManifestEntry
 
bucket() - Method in class org.apache.paimon.manifest.SimpleFileEntry
 
bucket - Variable in class org.apache.paimon.operation.FileStoreWrite.State
 
bucket() - Method in class org.apache.paimon.service.messages.KvRequest
 
bucket() - Method in interface org.apache.paimon.table.sink.CommitMessage
Bucket of this commit message.
bucket() - Method in class org.apache.paimon.table.sink.CommitMessageImpl
 
bucket() - Method in class org.apache.paimon.table.sink.DynamicBucketRowKeyExtractor
 
bucket() - Method in class org.apache.paimon.table.sink.FixedBucketRowKeyExtractor
 
bucket() - Method in interface org.apache.paimon.table.sink.KeyAndBucketExtractor
 
bucket(int, int) - Static method in interface org.apache.paimon.table.sink.KeyAndBucketExtractor
 
bucket() - Method in class org.apache.paimon.table.sink.SinkRecord
 
bucket() - Method in class org.apache.paimon.table.sink.UnawareBucketRowKeyExtractor
 
bucket() - Method in class org.apache.paimon.table.source.DataSplit
 
bucket() - Method in class org.apache.paimon.table.system.FileMonitorTable.FileChange
 
BUCKET_FIELD - Static variable in class org.apache.paimon.crosspartition.IndexBootstrap
 
BUCKET_KEY - Static variable in class org.apache.paimon.CoreOptions
 
BUCKET_PATH_PREFIX - Static variable in class org.apache.paimon.utils.FileStorePathFactory
 
BucketAccelerateConfigurationHandler() - Constructor for class com.amazonaws.services.s3.model.transform.XmlResponsesSaxParser.BucketAccelerateConfigurationHandler
 
BucketAssigner - Class in org.apache.paimon.crosspartition
Bucket Assigner to assign bucket in a partition.
BucketAssigner() - Constructor for class org.apache.paimon.crosspartition.BucketAssigner
 
BucketAssigner - Interface in org.apache.paimon.index
Assigner a bucket for a record, just used in dynamic bucket table.
BucketCrossOriginConfigurationHandler() - Constructor for class com.amazonaws.services.s3.model.transform.XmlResponsesSaxParser.BucketCrossOriginConfigurationHandler
 
BucketedAppendCompactManager - Class in org.apache.paimon.append
Compact manager for AppendOnlyFileStore.
BucketedAppendCompactManager(ExecutorService, List<DataFileMeta>, DeletionVectorsMaintainer, int, int, long, BucketedAppendCompactManager.CompactRewriter, CompactionMetrics.Reporter) - Constructor for class org.apache.paimon.append.BucketedAppendCompactManager
 
BucketedAppendCompactManager.AutoCompactTask - Class in org.apache.paimon.append
A CompactTask impl for append-only table auto-compaction.
BucketedAppendCompactManager.CompactRewriter - Interface in org.apache.paimon.append
Compact rewriter for append-only table.
BucketedAppendCompactManager.FullCompactTask - Class in org.apache.paimon.append
A CompactTask impl for full compaction of append-only table.
BucketedAppendDeletionFileMaintainer - Class in org.apache.paimon.deletionvectors.append
A AppendDeletionFileMaintainer of bucketed append table.
bucketEntries() - Method in interface org.apache.paimon.table.source.snapshot.SnapshotReader
 
bucketEntries() - Method in class org.apache.paimon.table.source.snapshot.SnapshotReaderImpl
 
BucketEntry - Class in org.apache.paimon.manifest
Entry representing a bucket.
BucketEntry(BinaryRow, int, long, long, long, long) - Constructor for class org.apache.paimon.manifest.BucketEntry
 
BucketFunction() - Constructor for class org.apache.paimon.spark.catalog.functions.PaimonFunctions.BucketFunction
 
bucketGetter() - Static method in class org.apache.paimon.manifest.ManifestEntrySerializer
 
bucketKeyFilter - Variable in class org.apache.paimon.operation.AbstractFileStoreScan
 
bucketKeyHashCode(BinaryRow) - Static method in interface org.apache.paimon.table.sink.KeyAndBucketExtractor
 
bucketKeys() - Method in class org.apache.paimon.schema.TableSchema
 
BucketLifecycleConfigurationHandler() - Constructor for class com.amazonaws.services.s3.model.transform.XmlResponsesSaxParser.BucketLifecycleConfigurationHandler
 
BucketLocationHandler() - Constructor for class com.amazonaws.services.s3.model.transform.XmlResponsesSaxParser.BucketLocationHandler
 
BucketLoggingConfigurationHandler() - Constructor for class com.amazonaws.services.s3.model.transform.XmlResponsesSaxParser.BucketLoggingConfigurationHandler
 
bucketMode() - Method in class org.apache.paimon.AppendOnlyFileStore
 
bucketMode() - Method in interface org.apache.paimon.FileStore
 
bucketMode - Variable in class org.apache.paimon.flink.source.ContinuousFileStoreSource
 
bucketMode() - Method in class org.apache.paimon.KeyValueFileStore
 
bucketMode() - Method in class org.apache.paimon.privilege.PrivilegedFileStore
 
BucketMode - Enum in org.apache.paimon.table
Bucket mode of the table, it affects the writing process and also affects the bucket skipping in reading.
bucketMode() - Method in interface org.apache.paimon.table.FileStoreTable
 
bucketPath() - Method in class org.apache.paimon.table.source.DataSplit
 
bucketPath(BinaryRow, int) - Method in class org.apache.paimon.utils.FileStorePathFactory
 
BucketReplicationConfigurationHandler() - Constructor for class com.amazonaws.services.s3.model.transform.XmlResponsesSaxParser.BucketReplicationConfigurationHandler
 
BUCKETS - Static variable in class org.apache.paimon.table.system.BucketsTable
 
BucketSpec - Class in org.apache.paimon.table
Bucket spec holds all bucket information, we can do plan optimization during table scan.
BucketSpec(BucketMode, List<String>, int) - Constructor for class org.apache.paimon.table.BucketSpec
 
bucketSpec() - Method in interface org.apache.paimon.table.FileStoreTable
 
BucketsRowChannelComputer - Class in org.apache.paimon.flink.sink
ChannelComputer to partition RowData from CompactBucketsTable.
BucketsRowChannelComputer() - Constructor for class org.apache.paimon.flink.sink.BucketsRowChannelComputer
 
BucketsTable - Class in org.apache.paimon.table.system
A Table for showing buckets info.
BucketsTable(FileStoreTable) - Constructor for class org.apache.paimon.table.system.BucketsTable
 
BucketTaggingConfigurationHandler() - Constructor for class com.amazonaws.services.s3.model.transform.XmlResponsesSaxParser.BucketTaggingConfigurationHandler
 
BucketUnawareCompactSource - Class in org.apache.paimon.flink.source
Source Function for unaware-bucket Compaction.
BucketUnawareCompactSource(FileStoreTable, boolean, long, Predicate) - Constructor for class org.apache.paimon.flink.source.BucketUnawareCompactSource
 
BucketVersioningConfigurationHandler() - Constructor for class com.amazonaws.services.s3.model.transform.XmlResponsesSaxParser.BucketVersioningConfigurationHandler
 
BucketWebsiteConfigurationHandler() - Constructor for class com.amazonaws.services.s3.model.transform.XmlResponsesSaxParser.BucketWebsiteConfigurationHandler
 
buffer - Variable in class org.apache.paimon.data.columnar.heap.HeapBytesVector
buffer to use when actually copying in data.
Buffer - Class in org.apache.paimon.memory
A buffer with size.
Buffer(MemorySegment, int) - Constructor for class org.apache.paimon.memory.Buffer
 
buffer() - Method in class org.apache.paimon.service.network.NettyBufferPool
 
buffer(int) - Method in class org.apache.paimon.service.network.NettyBufferPool
 
buffer(int, int) - Method in class org.apache.paimon.service.network.NettyBufferPool
 
BUFFER_SIZE - Static variable in class org.apache.paimon.fs.AsyncPositionOutputStream
 
BufferCompressionException - Exception in org.apache.paimon.compression
A BufferCompressionException is thrown when the target data cannot be compressed, such as insufficient target buffer space for compression, etc.
BufferCompressionException() - Constructor for exception org.apache.paimon.compression.BufferCompressionException
 
BufferCompressionException(String) - Constructor for exception org.apache.paimon.compression.BufferCompressionException
 
BufferCompressionException(String, Throwable) - Constructor for exception org.apache.paimon.compression.BufferCompressionException
 
BufferCompressionException(Throwable) - Constructor for exception org.apache.paimon.compression.BufferCompressionException
 
BufferDecompressionException - Exception in org.apache.paimon.compression
A BufferDecompressionException is thrown when the target data cannot be decompressed, such as data corruption, insufficient target buffer space for decompression, etc.
BufferDecompressionException() - Constructor for exception org.apache.paimon.compression.BufferDecompressionException
 
BufferDecompressionException(String) - Constructor for exception org.apache.paimon.compression.BufferDecompressionException
 
BufferDecompressionException(String, Throwable) - Constructor for exception org.apache.paimon.compression.BufferDecompressionException
 
BufferDecompressionException(Throwable) - Constructor for exception org.apache.paimon.compression.BufferDecompressionException
 
BufferFileChannelReader - Class in org.apache.paimon.disk
Helper class to read Buffers from files into objects.
BufferFileReader - Interface in org.apache.paimon.disk
Read Buffer from file.
BufferFileReaderImpl - Class in org.apache.paimon.disk
A synchronous BufferFileReader implementation.
BufferFileReaderImpl(FileIOChannel.ID) - Constructor for class org.apache.paimon.disk.BufferFileReaderImpl
 
BufferFileWriter - Interface in org.apache.paimon.disk
Write MemorySegment to file.
BufferFileWriterImpl - Class in org.apache.paimon.disk
A synchronous BufferFileWriter implementation.
BufferFileWriterImpl(FileIOChannel.ID) - Constructor for class org.apache.paimon.disk.BufferFileWriterImpl
 
bufferPreemptCount() - Method in class org.apache.paimon.memory.MemoryPoolFactory
 
bufferSize(int) - Method in class org.apache.orc.OrcFile.WriterOptions
The size of the memory buffers used for compressing and storing the stripe in memory.
bufferSpillable() - Method in class org.apache.paimon.operation.KeyValueFileStoreWrite
 
build() - Method in class org.apache.paimon.casting.CastRulePredicate.Builder
 
build() - Method in class org.apache.paimon.codegen.SortSpec.SortSpecBuilder
 
build() - Method in interface org.apache.paimon.flink.action.Action
Builds the action within the given Flink Stream Execution Environment.
build() - Method in class org.apache.paimon.flink.action.cdc.SynchronizationActionBase
 
build() - Method in class org.apache.paimon.flink.action.CloneAction
 
build() - Method in class org.apache.paimon.flink.action.CompactAction
 
build() - Method in class org.apache.paimon.flink.action.CompactDatabaseAction
 
build() - Method in class org.apache.paimon.flink.action.SortCompactAction
 
build() - Method in class org.apache.paimon.flink.clone.CloneSourceBuilder
 
build() - Method in class org.apache.paimon.flink.compact.UnawareBucketCompactionTopoBuilder
 
build(StreamExecutionEnvironment, Table) - Static method in class org.apache.paimon.flink.service.QueryFileMonitor
 
build(StreamExecutionEnvironment, Table, int) - Static method in class org.apache.paimon.flink.service.QueryService
 
build() - Method in class org.apache.paimon.flink.sink.cdc.CdcSinkBuilder
 
build() - Method in class org.apache.paimon.flink.sink.cdc.FlinkCdcSyncDatabaseSinkBuilder
 
build(RichCdcMultiplexRecord) - Method in class org.apache.paimon.flink.sink.cdc.NewTableSchemaBuilder
 
build() - Method in class org.apache.paimon.flink.sink.cdc.RichCdcRecord.Builder
 
build() - Method in class org.apache.paimon.flink.sink.cdc.RichCdcSinkBuilder
 
build() - Method in class org.apache.paimon.flink.sink.CompactorSinkBuilder
 
build(DataStream<InternalRow>, Integer) - Method in class org.apache.paimon.flink.sink.DynamicBucketCompactSink
 
build(DataStream<T>, Integer) - Method in class org.apache.paimon.flink.sink.DynamicBucketSink
 
build() - Method in class org.apache.paimon.flink.sink.FlinkSinkBuilder
Build DataStreamSink.
build(DataStream<InternalRow>, Integer) - Method in class org.apache.paimon.flink.sink.index.GlobalDynamicBucketSink
 
build() - Method in class org.apache.paimon.flink.sorter.TableSortInfo.Builder
 
build() - Method in class org.apache.paimon.flink.source.CompactorSourceBuilder
 
build() - Method in class org.apache.paimon.flink.source.FlinkSourceBuilder
Build source DataStream with RowData.
build(BinaryRow, int, DeletionVector.Factory) - Method in class org.apache.paimon.io.KeyValueFileReaderFactory.Builder
 
build(BinaryRow, int, DeletionVector.Factory, boolean, List<Predicate>) - Method in class org.apache.paimon.io.KeyValueFileReaderFactory.Builder
 
build(BinaryRow, int, CoreOptions) - Method in class org.apache.paimon.io.KeyValueFileWriterFactory.Builder
 
build() - Method in class org.apache.paimon.options.description.Description.DescriptionBuilder
Creates description representation.
build() - Method in class org.apache.paimon.options.ExpireConfig.Builder
 
build() - Method in class org.apache.paimon.schema.Schema.Builder
Returns an instance of an unresolved Schema.
build() - Method in interface org.apache.paimon.spark.procedure.ProcedureBuilder
Builds a stored procedure via given identifier.
build() - Method in class org.apache.paimon.table.FormatTable.Builder
 
build() - Method in class org.apache.paimon.table.source.DataSplit.Builder
 
build() - Method in class org.apache.paimon.types.RowType.Builder
 
build() - Method in class org.apache.paimon.utils.ExecutorThreadFactory.Builder
 
build() - Method in class org.apache.paimon.utils.Int2ShortHashMap.Builder
 
build() - Method in class org.apache.parquet.hadoop.ParquetWriter.Builder
Build a ParquetWriter with the accumulated configuration.
buildAwareBucketTableSource() - Method in class org.apache.paimon.flink.source.CombinedTableCompactorSourceBuilder
 
buildComputedColumns(List<String>, List<DataField>) - Static method in class org.apache.paimon.flink.action.cdc.ComputedColumnUtils
 
buildComputedColumns(List<String>, List<DataField>, boolean) - Static method in class org.apache.paimon.flink.action.cdc.ComputedColumnUtils
The caseSensitive only affects check.
buildDataStream() - Method in class org.apache.paimon.flink.action.MergeIntoAction
 
buildDynamicBucketSink(DataStream<InternalRow>, boolean) - Method in class org.apache.paimon.flink.sink.FlinkSinkBuilder
 
buildEnumerator(SplitEnumeratorContext<FileStoreSourceSplit>, Collection<FileStoreSourceSplit>, Long, StreamTableScan) - Method in class org.apache.paimon.flink.source.align.AlignedContinuousFileStoreSource
 
buildEnumerator(SplitEnumeratorContext<FileStoreSourceSplit>, Collection<FileStoreSourceSplit>, Long, StreamTableScan) - Method in class org.apache.paimon.flink.source.ContinuousFileStoreSource
 
builder() - Static method in class org.apache.paimon.casting.CastRulePredicate
 
Builder() - Constructor for class org.apache.paimon.casting.CastRulePredicate.Builder
 
builder() - Static method in class org.apache.paimon.codegen.SortSpec
 
builder(RowKind) - Static method in class org.apache.paimon.flink.sink.cdc.RichCdcRecord
 
Builder(RowKind, AtomicInteger) - Constructor for class org.apache.paimon.flink.sink.cdc.RichCdcRecord.Builder
 
Builder() - Constructor for class org.apache.paimon.flink.sorter.TableSortInfo.Builder
 
builder(FileIO, SchemaManager, TableSchema, RowType, RowType, FileFormatDiscover, FileStorePathFactory, KeyValueFieldsExtractor, CoreOptions) - Static method in class org.apache.paimon.io.KeyValueFileReaderFactory
 
builder(FileIO, long, RowType, RowType, FileFormat, Map<String, FileStorePathFactory>, long) - Static method in class org.apache.paimon.io.KeyValueFileWriterFactory
 
builder() - Static method in class org.apache.paimon.options.description.Description
 
builder() - Static method in class org.apache.paimon.options.ExpireConfig
 
Builder() - Constructor for class org.apache.paimon.options.ExpireConfig.Builder
 
builder() - Static method in class org.apache.paimon.options.ExpireConfig.Builder
 
Builder() - Constructor for class org.apache.paimon.schema.Schema.Builder
 
builder() - Static method in class org.apache.paimon.spark.procedure.CompactProcedure
 
builder() - Static method in class org.apache.paimon.spark.procedure.CreateBranchProcedure
 
builder() - Static method in class org.apache.paimon.spark.procedure.CreateTagFromTimestampProcedure
 
builder() - Static method in class org.apache.paimon.spark.procedure.CreateTagProcedure
 
builder() - Static method in class org.apache.paimon.spark.procedure.DeleteBranchProcedure
 
builder() - Static method in class org.apache.paimon.spark.procedure.DeleteTagProcedure
 
builder() - Static method in class org.apache.paimon.spark.procedure.ExpirePartitionsProcedure
 
builder() - Static method in class org.apache.paimon.spark.procedure.ExpireSnapshotsProcedure
 
builder() - Static method in class org.apache.paimon.spark.procedure.FastForwardProcedure
 
builder() - Static method in class org.apache.paimon.spark.procedure.MarkPartitionDoneProcedure
 
builder() - Static method in class org.apache.paimon.spark.procedure.MigrateFileProcedure
 
builder() - Static method in class org.apache.paimon.spark.procedure.MigrateTableProcedure
 
builder() - Static method in class org.apache.paimon.spark.procedure.RemoveOrphanFilesProcedure
 
builder() - Static method in class org.apache.paimon.spark.procedure.RepairProcedure
 
builder() - Static method in class org.apache.paimon.spark.procedure.ResetConsumerProcedure
 
builder() - Static method in class org.apache.paimon.spark.procedure.RollbackProcedure
 
builder() - Static method in interface org.apache.paimon.table.FormatTable
Create a new builder for FormatTable.
Builder() - Constructor for class org.apache.paimon.table.FormatTable.Builder
 
builder() - Static method in class org.apache.paimon.table.source.DataSplit
 
Builder() - Constructor for class org.apache.paimon.table.source.DataSplit.Builder
 
builder() - Static method in class org.apache.paimon.types.RowType
 
builder(boolean, AtomicInteger) - Static method in class org.apache.paimon.types.RowType
 
builder(long, double) - Static method in class org.apache.paimon.utils.BloomFilter
 
Builder() - Constructor for class org.apache.paimon.utils.ExecutorThreadFactory.Builder
 
builder() - Static method in class org.apache.paimon.utils.Int2ShortHashMap
 
Builder() - Constructor for class org.apache.paimon.utils.Int2ShortHashMap.Builder
 
Builder(OutputFile) - Constructor for class org.apache.parquet.hadoop.ParquetWriter.Builder
 
buildEventParserFactory() - Method in class org.apache.paimon.flink.action.cdc.SyncDatabaseActionBase
 
buildEventParserFactory() - Method in class org.apache.paimon.flink.action.cdc.SynchronizationActionBase
 
buildEventParserFactory() - Method in class org.apache.paimon.flink.action.cdc.SyncTableActionBase
 
buildFieldsList(List<DataField>, List<String>, MessageColumnIO) - Static method in class org.apache.paimon.format.parquet.reader.ParquetSplitReaderUtil
 
buildForFixedBucket(DataStream<InternalRow>) - Method in class org.apache.paimon.flink.sink.FlinkSinkBuilder
 
buildForRow() - Method in class org.apache.paimon.flink.source.FlinkSourceBuilder
Build source DataStream with RowData.
buildForUnawareBucketsTableSource() - Method in class org.apache.paimon.flink.source.CombinedTableCompactorSourceBuilder
 
buildHybridFirstSource(Table, int[][], Predicate) - Static method in class org.apache.paimon.flink.source.LogHybridSourceFactory
 
buildKafkaSource(Configuration, KafkaDeserializationSchema<CdcSourceRecord>) - Static method in class org.apache.paimon.flink.action.cdc.kafka.KafkaActionUtils
 
buildMongodbSource(Configuration, String) - Static method in class org.apache.paimon.flink.action.cdc.mongodb.MongoDBActionUtils
 
buildMySqlSource(Configuration, String, TypeMapping) - Static method in class org.apache.paimon.flink.action.cdc.mysql.MySqlActionUtils
 
buildPaimonSchema(String, List<String>, List<String>, List<ComputedColumn>, Map<String, String>, Schema, CdcMetadataConverter[], boolean, boolean, boolean) - Static method in class org.apache.paimon.flink.action.cdc.CdcActionCommonUtils
 
buildPaimonSchema(Schema) - Method in class org.apache.paimon.flink.action.cdc.MessageQueueSyncTableActionBase
 
buildPaimonSchema(Schema) - Method in class org.apache.paimon.flink.action.cdc.SyncTableActionBase
 
buildPaimonSchema(Identifier, CatalogTable, Map<String, String>) - Method in class org.apache.paimon.flink.FlinkCatalog
 
buildPostgresSource(Configuration, String[], String[]) - Static method in class org.apache.paimon.flink.action.cdc.postgres.PostgresActionUtils
 
buildPulsarSource(Configuration, DeserializationSchema<CdcSourceRecord>) - Static method in class org.apache.paimon.flink.action.cdc.pulsar.PulsarActionUtils
 
buildSchema(CdcSourceRecord) - Method in class org.apache.paimon.flink.action.cdc.format.AbstractRecordParser
 
buildSchema(DatabaseMetaData, String, String, String, TypeMapping, JdbcToPaimonTypeVisitor) - Static method in class org.apache.paimon.flink.action.cdc.schema.JdbcSchemaUtils
 
buildSchema(DatabaseMetaData, String, String, String, String, TypeMapping, JdbcToPaimonTypeVisitor) - Static method in class org.apache.paimon.flink.action.cdc.schema.JdbcSchemaUtils
 
buildSink(DataStream<RichCdcMultiplexRecord>, EventParser.Factory<RichCdcMultiplexRecord>) - Method in class org.apache.paimon.flink.action.cdc.SyncDatabaseActionBase
 
buildSink(DataStream<RichCdcMultiplexRecord>, EventParser.Factory<RichCdcMultiplexRecord>) - Method in class org.apache.paimon.flink.action.cdc.SynchronizationActionBase
 
buildSink(DataStream<RichCdcMultiplexRecord>, EventParser.Factory<RichCdcMultiplexRecord>) - Method in class org.apache.paimon.flink.action.cdc.SyncTableActionBase
 
buildSource() - Method in class org.apache.paimon.flink.action.cdc.mongodb.MongoDBSyncDatabaseAction
 
buildSource() - Method in class org.apache.paimon.flink.action.cdc.mongodb.MongoDBSyncTableAction
 
buildSource() - Method in class org.apache.paimon.flink.action.cdc.mysql.MySqlSyncDatabaseAction
 
buildSource() - Method in class org.apache.paimon.flink.action.cdc.mysql.MySqlSyncTableAction
 
buildSource() - Method in class org.apache.paimon.flink.action.cdc.postgres.PostgresSyncTableAction
 
buildSource() - Method in class org.apache.paimon.flink.action.cdc.SynchronizationActionBase
 
buildSource(StreamExecutionEnvironment, BucketUnawareCompactSource, boolean, String) - Static method in class org.apache.paimon.flink.source.BucketUnawareCompactSource
 
buildSource(StreamExecutionEnvironment, String, TypeInformation<RowData>, Catalog.Loader, Pattern, Pattern, Pattern, Duration) - Static method in class org.apache.paimon.flink.source.operator.CombinedAwareBatchSourceFunction
 
buildSource(StreamExecutionEnvironment, String, TypeInformation<RowData>, Catalog.Loader, Pattern, Pattern, Pattern, long) - Static method in class org.apache.paimon.flink.source.operator.CombinedAwareStreamingSourceFunction
 
buildSource(StreamExecutionEnvironment, String, Catalog.Loader, Pattern, Pattern, Pattern, Duration) - Static method in class org.apache.paimon.flink.source.operator.CombinedUnawareBatchSourceFunction
 
buildSource(StreamExecutionEnvironment, String, Catalog.Loader, Pattern, Pattern, Pattern, long) - Static method in class org.apache.paimon.flink.source.operator.CombinedUnawareStreamingSourceFunction
 
buildSource(StreamExecutionEnvironment, String, TypeInformation<RowData>, ReadBuilder, long, boolean, boolean, BucketMode) - Static method in class org.apache.paimon.flink.source.operator.MonitorFunction
 
BulkFormatMapping - Class in org.apache.paimon.utils
Class with index mapping and bulk format.
BulkFormatMapping(int[], CastFieldGetter[], Pair<int[], RowType>, FormatReaderFactory) - Constructor for class org.apache.paimon.utils.BulkFormatMapping
 
bulkGetPartitionColumnStatistics(ObjectPath, List<CatalogPartitionSpec>) - Method in class org.apache.paimon.flink.FlinkGenericCatalog
 
bulkGetPartitionStatistics(ObjectPath, List<CatalogPartitionSpec>) - Method in class org.apache.paimon.flink.FlinkGenericCatalog
 
bulkLoadCollectFirst(BiConsumer<InternalRow, Integer>, RowIterator, Function<InternalRow, BinaryRow>, Function<InternalRow, BinaryRow>, Function<BinaryRow, Integer>) - Static method in interface org.apache.paimon.crosspartition.ExistingProcessor
 
BulkLoader - Class in org.apache.paimon.lookup
Bulk loader for RocksDB.
BulkLoader(RocksDB, Options, ColumnFamilyHandle, String) - Constructor for class org.apache.paimon.lookup.BulkLoader
 
BulkLoader.WriteException - Exception in org.apache.paimon.lookup
Exception during writing.
bulkLoadNewRecords(Function<ExistingProcessor.SortOrder, RowIterator>, Function<InternalRow, BinaryRow>, Function<InternalRow, BinaryRow>, Function<BinaryRow, Integer>) - Method in class org.apache.paimon.crosspartition.DeleteExistingProcessor
 
bulkLoadNewRecords(Function<ExistingProcessor.SortOrder, RowIterator>, Function<InternalRow, BinaryRow>, Function<InternalRow, BinaryRow>, Function<BinaryRow, Integer>) - Method in interface org.apache.paimon.crosspartition.ExistingProcessor
 
bulkLoadNewRecords(Function<ExistingProcessor.SortOrder, RowIterator>, Function<InternalRow, BinaryRow>, Function<InternalRow, BinaryRow>, Function<BinaryRow, Integer>) - Method in class org.apache.paimon.crosspartition.SkipNewExistingProcessor
 
bulkLoadNewRecords(Function<ExistingProcessor.SortOrder, RowIterator>, Function<InternalRow, BinaryRow>, Function<InternalRow, BinaryRow>, Function<BinaryRow, Integer>) - Method in class org.apache.paimon.crosspartition.UseOldExistingProcessor
 
bulkLoadWritePlus(byte[], byte[]) - Method in class org.apache.paimon.flink.lookup.PrimaryKeyLookupTable
 
bulkLoadWritePlus(byte[], byte[]) - Method in class org.apache.paimon.flink.lookup.SecondaryIndexLookupTable
 
BundleFileStoreWriter - Interface in org.apache.paimon.operation
Whether the writer could write bundle.
BundleFormatWriter - Interface in org.apache.paimon.format
Format write with bundle interface.
BundleRecords - Interface in org.apache.paimon.io
Interface of bundle records.
byName(String) - Static method in enum org.apache.orc.OrcFile.Version
 
BYTE - Static variable in class org.apache.paimon.codegen.codesplit.JavaLexer
 
BYTE - Static variable in class org.apache.paimon.codegen.codesplit.JavaLexer
 
BYTE - Static variable in class org.apache.paimon.codegen.codesplit.JavaParser
 
BYTE - Static variable in class org.apache.paimon.codegen.codesplit.JavaParser
 
BYTE() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.PrimitiveTypeContext
 
BYTE() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.PrimitiveTypeContext
 
BYTE_ARRAY_BASE_OFFSET - Static variable in class org.apache.paimon.memory.MemorySegment
 
BYTE_ARRAY_BASE_OFFSET - Static variable in class org.apache.paimon.utils.BinaryRowDataUtil
 
BYTE_ARRAY_OFFSET - Static variable in class org.apache.paimon.data.columnar.heap.AbstractHeapVector
 
ByteArray(byte[]) - Constructor for class org.apache.paimon.lookup.RocksDBState.ByteArray
 
byteArrayEquals(byte[], byte[], int) - Static method in class org.apache.paimon.utils.BinaryRowDataUtil
 
byteArrayEquals(Object, long, Object, long, int) - Static method in class org.apache.paimon.utils.BinaryRowDataUtil
 
ByteArraySeekableStream - Class in org.apache.paimon.fs
Wrap byte buf to a seekable input stream.
ByteArraySeekableStream(byte[]) - Constructor for class org.apache.paimon.fs.ByteArraySeekableStream
 
byteAt(int) - Method in class org.apache.paimon.data.BinaryString
Returns the byte value at the specified index.
ByteBufferAllocatorPool() - Constructor for class org.apache.orc.impl.RecordReaderUtils.ByteBufferAllocatorPool
 
ByteColumnReader - Class in org.apache.paimon.format.parquet.reader
ByteColumnReader(ColumnDescriptor, PageReader) - Constructor for class org.apache.paimon.format.parquet.reader.ByteColumnReader
 
ByteColumnVector - Interface in org.apache.paimon.data.columnar
Byte column vector.
byteIndex(int) - Static method in class org.apache.paimon.memory.MemorySegmentUtils
Given a bit index, return the byte index containing it.
Bytes(byte[], int, int) - Constructor for class org.apache.paimon.data.columnar.BytesColumnVector.Bytes
 
bytes - Variable in class org.apache.paimon.lookup.RocksDBState.ByteArray
 
bytes - Variable in class org.apache.paimon.lookup.RocksDBState.Reference
 
BYTES() - Static method in class org.apache.paimon.types.DataTypes
 
BytesColumnReader - Class in org.apache.paimon.format.parquet.reader
BytesColumnReader(ColumnDescriptor, PageReader) - Constructor for class org.apache.paimon.format.parquet.reader.BytesColumnReader
 
BytesColumnVector - Interface in org.apache.paimon.data.columnar
Bytes column vector to get BytesColumnVector.Bytes, it include original data and offset and length.
BytesColumnVector.Bytes - Class in org.apache.paimon.data.columnar
Bytes data.
ByteSerializer - Class in org.apache.paimon.data.serializer
Type serializer for Byte (and byte, via auto-boxing).
ByteSerializer() - Constructor for class org.apache.paimon.data.serializer.ByteSerializer
 
bytesToBinaryString(byte[]) - Static method in class org.apache.paimon.utils.StringUtils
Given an array of bytes it will convert the bytes to a binary (0-1) string representation of the bytes.
BytesUtils - Class in org.apache.paimon.memory
Utils for byte[].
BytesUtils() - Constructor for class org.apache.paimon.memory.BytesUtils
 
byteToHexString(byte[], int, int) - Static method in class org.apache.paimon.utils.StringUtils
Given an array of bytes it will convert the bytes to a hex string representation of the bytes.
byteToHexString(byte[]) - Static method in class org.apache.paimon.utils.StringUtils
Given an array of bytes it will convert the bytes to a hex string representation of the bytes.
byteTruncateOrFill(byte[], int, ByteBuffer) - Static method in class org.apache.paimon.utils.ZOrderByteUtils
Return a bytebuffer with the given bytes truncated to length, or filled with 0's to length depending on whether the given bytes are larger or smaller than the given length.

C

cache() - Method in class org.apache.paimon.io.cache.CacheManager
 
cache - Variable in class org.apache.paimon.lookup.RocksDBState
 
CACHE_ENABLED - Static variable in class org.apache.paimon.options.CatalogOptions
 
CACHE_EXPIRATION_INTERVAL_MS - Static variable in class org.apache.paimon.options.CatalogOptions
 
CACHE_MANIFEST_MAX_MEMORY - Static variable in class org.apache.paimon.options.CatalogOptions
 
CACHE_MANIFEST_SMALL_FILE_MEMORY - Static variable in class org.apache.paimon.options.CatalogOptions
 
CACHE_MANIFEST_SMALL_FILE_THRESHOLD - Static variable in class org.apache.paimon.options.CatalogOptions
 
CACHE_PAGE_SIZE - Static variable in class org.apache.paimon.CoreOptions
 
CacheCallback - Interface in org.apache.paimon.io.cache
Callback for cache removal.
CachedClientPool - Class in org.apache.paimon.hive.pool
A ClientPool that caches the underlying HiveClientPool instances.
CachedClientPool(Configuration, Options, String) - Constructor for class org.apache.paimon.hive.pool.CachedClientPool
 
CacheKey - Interface in org.apache.paimon.io.cache
Key for cache manager.
CacheKey.PageIndexCacheKey - Class in org.apache.paimon.io.cache
Key for file page index.
CacheKey.PositionCacheKey - Class in org.apache.paimon.io.cache
Key for file position and length.
CachelessSegmentPool - Class in org.apache.paimon.memory
A MemorySegmentPool without cache.
CachelessSegmentPool(long, int) - Constructor for class org.apache.paimon.memory.CachelessSegmentPool
 
CacheManager - Class in org.apache.paimon.io.cache
Cache manager to cache bytes to paged MemorySegments.
CacheManager(MemorySize) - Constructor for class org.apache.paimon.io.cache.CacheManager
 
cacheManager - Variable in class org.apache.paimon.operation.MemoryFileStoreWrite
 
cachePageSize() - Method in class org.apache.paimon.CoreOptions
 
CacheReader - Interface in org.apache.paimon.io.cache
Reader to read byte[].
CachingCatalog - Class in org.apache.paimon.catalog
A Catalog to cache databases and tables and manifests.
CachingCatalog(Catalog) - Constructor for class org.apache.paimon.catalog.CachingCatalog
 
CachingCatalog(Catalog, Duration, MemorySize, long) - Constructor for class org.apache.paimon.catalog.CachingCatalog
 
CachingCatalog(Catalog, Duration, MemorySize, long, Ticker) - Constructor for class org.apache.paimon.catalog.CachingCatalog
 
calculateBitSetInBytes(int) - Static method in class org.apache.paimon.data.serializer.RowCompactedSerializer
 
calculateBitSetWidthInBytes(int) - Static method in class org.apache.paimon.data.BinaryRow
 
calculateChecksum(byte[]) - Static method in class org.apache.paimon.deletionvectors.DeletionVectorsIndexFile
 
calculateCollectionOffsets(ParquetField, int[], int[], boolean) - Static method in class org.apache.paimon.format.parquet.reader.NestedPositionUtil
Calculate the collection's offsets according to column's max repetition level, definition level, value's repetition level and definition level.
calculateFixLengthPartSize(DataType) - Static method in class org.apache.paimon.data.BinaryArray
It store real value when type is primitive.
calculateFixPartSizeInBytes(int) - Static method in class org.apache.paimon.data.BinaryRow
 
calculateHeaderInBytes(int) - Static method in class org.apache.paimon.data.BinaryArray
 
calculateLength() - Method in class org.apache.paimon.operation.metrics.CompactTimer
 
calculateLengthByOffsets(boolean[], long[]) - Static method in class org.apache.paimon.format.parquet.reader.NestedPositionUtil
 
calculateNewCapacity(int, int) - Method in class org.apache.paimon.service.network.NettyBufferPool
 
call() - Method in class org.apache.paimon.compact.CompactTask
 
call(ProcedureContext, String, String, String, String, String, String, String, String, Integer) - Method in class org.apache.paimon.flink.procedure.CloneProcedure
 
call(ProcedureContext, String, String, String, String, String, String) - Method in class org.apache.paimon.flink.procedure.CompactDatabaseProcedure
 
call(ProcedureContext, String, String, String, String, String, String, String) - Method in class org.apache.paimon.flink.procedure.CompactProcedure
 
call(ProcedureContext, String, String, String) - Method in class org.apache.paimon.flink.procedure.CreateBranchProcedure
 
call(ProcedureContext, String, String, Long, String) - Method in class org.apache.paimon.flink.procedure.CreateTagFromTimestampProcedure
 
call(ProcedureContext, String, String, Long, String) - Method in class org.apache.paimon.flink.procedure.CreateTagFromWatermarkProcedure
 
call(ProcedureContext, String, String, Long, String) - Method in class org.apache.paimon.flink.procedure.CreateTagProcedure
 
call(ProcedureContext, String, String) - Method in class org.apache.paimon.flink.procedure.DeleteBranchProcedure
 
call(ProcedureContext, String, String) - Method in class org.apache.paimon.flink.procedure.DeleteTagProcedure
 
call(ProcedureContext, String, String...) - Method in class org.apache.paimon.flink.procedure.DropPartitionProcedure
Deprecated.
 
call(ProcedureContext, String, String, String, String, String) - Method in class org.apache.paimon.flink.procedure.ExpirePartitionsProcedure
 
call(ProcedureContext, String, Integer, Integer, String, Integer) - Method in class org.apache.paimon.flink.procedure.ExpireSnapshotsProcedure
 
call(ProcedureContext, String, String) - Method in class org.apache.paimon.flink.procedure.FastForwardProcedure
 
call(ProcedureContext, String, String) - Method in class org.apache.paimon.flink.procedure.MarkPartitionDoneProcedure
 
call(ProcedureContext, String, String, String, String, String, String, String, String, String, String) - Method in class org.apache.paimon.flink.procedure.MergeIntoProcedure
 
call(ProcedureContext, String, String, String) - Method in class org.apache.paimon.flink.procedure.MigrateDatabaseProcedure
 
call(ProcedureContext, String, String, String, Boolean) - Method in class org.apache.paimon.flink.procedure.MigrateFileProcedure
 
call(ProcedureContext, String, String, String) - Method in class org.apache.paimon.flink.procedure.MigrateTableProcedure
 
call(ProcedureContext, String, String) - Method in class org.apache.paimon.flink.procedure.privilege.CreatePrivilegedUserProcedure
 
call(ProcedureContext, String) - Method in class org.apache.paimon.flink.procedure.privilege.DropPrivilegedUserProcedure
 
call(ProcedureContext, String, String, String, String) - Method in class org.apache.paimon.flink.procedure.privilege.GrantPrivilegeToUserProcedure
 
call(ProcedureContext, String) - Method in class org.apache.paimon.flink.procedure.privilege.InitFileBasedPrivilegeProcedure
 
call(ProcedureContext, String, String, String, String) - Method in class org.apache.paimon.flink.procedure.privilege.RevokePrivilegeFromUserProcedure
 
call(ProcedureContext, String, int) - Method in class org.apache.paimon.flink.procedure.QueryServiceProcedure
 
call(ProcedureContext, String, String, Boolean, String) - Method in class org.apache.paimon.flink.procedure.RemoveOrphanFilesProcedure
 
call(ProcedureContext, String) - Method in class org.apache.paimon.flink.procedure.RepairProcedure
 
call(ProcedureContext, String, String, Long) - Method in class org.apache.paimon.flink.procedure.ResetConsumerProcedure
 
call(ProcedureContext, String, String) - Method in class org.apache.paimon.flink.procedure.RewriteFileIndexProcedure
 
call(ProcedureContext, String, String, Long) - Method in class org.apache.paimon.flink.procedure.RollbackToProcedure
 
call() - Method in class org.apache.paimon.hive.migrate.HiveMigrator.MigrateTask
 
call(List<ManifestEntry>, Snapshot) - Method in class org.apache.paimon.iceberg.AbstractIcebergCommitCallback
 
call(List<ManifestEntry>, Snapshot) - Method in class org.apache.paimon.metastore.AddPartitionCommitCallback
 
call(List<ManifestEntry>, Snapshot) - Method in class org.apache.paimon.metastore.TagPreviewCommitCallback
 
call(InternalRow) - Method in class org.apache.paimon.spark.procedure.CompactProcedure
 
call(InternalRow) - Method in class org.apache.paimon.spark.procedure.CreateBranchProcedure
 
call(InternalRow) - Method in class org.apache.paimon.spark.procedure.CreateTagFromTimestampProcedure
 
call(InternalRow) - Method in class org.apache.paimon.spark.procedure.CreateTagProcedure
 
call(InternalRow) - Method in class org.apache.paimon.spark.procedure.DeleteBranchProcedure
 
call(InternalRow) - Method in class org.apache.paimon.spark.procedure.DeleteTagProcedure
 
call(InternalRow) - Method in class org.apache.paimon.spark.procedure.ExpirePartitionsProcedure
 
call(InternalRow) - Method in class org.apache.paimon.spark.procedure.ExpireSnapshotsProcedure
 
call(InternalRow) - Method in class org.apache.paimon.spark.procedure.FastForwardProcedure
 
call(InternalRow) - Method in class org.apache.paimon.spark.procedure.MarkPartitionDoneProcedure
 
call(InternalRow) - Method in class org.apache.paimon.spark.procedure.MigrateFileProcedure
 
call(InternalRow) - Method in class org.apache.paimon.spark.procedure.MigrateTableProcedure
 
call(InternalRow) - Method in interface org.apache.paimon.spark.procedure.Procedure
Executes the given stored procedure.
call(InternalRow) - Method in class org.apache.paimon.spark.procedure.RemoveOrphanFilesProcedure
 
call(InternalRow) - Method in class org.apache.paimon.spark.procedure.RepairProcedure
 
call(InternalRow) - Method in class org.apache.paimon.spark.procedure.ResetConsumerProcedure
 
call(InternalRow) - Method in class org.apache.paimon.spark.procedure.RollbackProcedure
 
call(List<ManifestEntry>, Snapshot) - Method in interface org.apache.paimon.table.sink.CommitCallback
 
callback(OrcFile.WriterCallback) - Method in class org.apache.orc.OrcFile.WriterOptions
Add a listener for when the stripe and file are about to be closed.
CallbackUtils - Class in org.apache.paimon.table.sink
Utils to load callbacks.
CallbackUtils() - Constructor for class org.apache.paimon.table.sink.CallbackUtils
 
CanalDataFormat - Class in org.apache.paimon.flink.action.cdc.format.canal
Supports the message queue's canal json data format and provides definitions for the message queue's record json deserialization class and parsing class CanalRecordParser.
CanalDataFormat() - Constructor for class org.apache.paimon.flink.action.cdc.format.canal.CanalDataFormat
 
CanalDataFormatFactory - Class in org.apache.paimon.flink.action.cdc.format.canal
Factory to create CanalDataFormat.
CanalDataFormatFactory() - Constructor for class org.apache.paimon.flink.action.cdc.format.canal.CanalDataFormatFactory
 
CanalFieldParser - Class in org.apache.paimon.flink.action.cdc.format.canal
Converts some special types such as enum、set、geometry.
CanalFieldParser() - Constructor for class org.apache.paimon.flink.action.cdc.format.canal.CanalFieldParser
 
CanalRecordParser - Class in org.apache.paimon.flink.action.cdc.format.canal
The CanalRecordParser class is responsible for parsing records from the Canal-JSON format.
CanalRecordParser(TypeMapping, List<ComputedColumn>) - Constructor for class org.apache.paimon.flink.action.cdc.format.canal.CanalRecordParser
 
canBePrefixMap(ConfigOption<?>) - Static method in class org.apache.paimon.options.OptionsUtils
Maps can be represented in two ways.
cancel() - Method in class org.apache.paimon.flink.query.RemoteTableQuery
 
cancel() - Method in class org.apache.paimon.flink.service.QueryFileMonitor
 
cancel() - Method in class org.apache.paimon.flink.source.BucketUnawareCompactSource
 
cancel() - Method in class org.apache.paimon.flink.source.operator.CombinedCompactorSourceFunction
 
cancel() - Method in class org.apache.paimon.flink.source.operator.MonitorFunction
 
cancelCompaction() - Method in class org.apache.paimon.compact.CompactFutureManager
 
cancelCompaction() - Method in interface org.apache.paimon.compact.CompactManager
Cancel currently running compaction task.
cancelCompaction() - Method in class org.apache.paimon.compact.NoopCompactManager
 
cancelJob(String) - Method in class org.apache.paimon.benchmark.metric.FlinkRestClient
 
canConvert(DataType, DataType) - Static method in class org.apache.paimon.flink.sink.cdc.UpdatedDataFieldsProcessFunctionBase
 
canEqual(Object) - Method in class org.apache.paimon.flink.sink.CommittableTypeInfo
 
canEqual(Object) - Method in class org.apache.paimon.flink.sink.CompactionTaskTypeInfo
 
canEqual(Object) - Method in class org.apache.paimon.flink.sink.MultiTableCommittableTypeInfo
 
canEqual(Object) - Method in class org.apache.paimon.flink.sink.MultiTableCompactionTaskTypeInfo
 
canEqual(Object) - Method in class org.apache.paimon.flink.utils.InternalTypeInfo
 
canEqual(Object) - Method in class org.apache.paimon.flink.utils.JavaTypeInfo
 
canGrantOnCatalog() - Method in enum org.apache.paimon.privilege.PrivilegeType
 
canGrantOnDatabase() - Method in enum org.apache.paimon.privilege.PrivilegeType
 
canGrantOnTable() - Method in enum org.apache.paimon.privilege.PrivilegeType
 
CARET - Static variable in class org.apache.paimon.codegen.codesplit.JavaLexer
 
CARET - Static variable in class org.apache.paimon.codegen.codesplit.JavaLexer
 
CARET - Static variable in class org.apache.paimon.codegen.codesplit.JavaParser
 
CARET - Static variable in class org.apache.paimon.codegen.codesplit.JavaParser
 
CARET() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ExpressionContext
 
CARET() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ExpressionContext
 
CASE - Static variable in class org.apache.paimon.codegen.codesplit.JavaLexer
 
CASE - Static variable in class org.apache.paimon.codegen.codesplit.JavaLexer
 
CASE - Static variable in class org.apache.paimon.codegen.codesplit.JavaParser
 
CASE - Static variable in class org.apache.paimon.codegen.codesplit.JavaParser
 
CASE() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.SwitchLabelContext
 
CASE() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.SwitchLabelContext
 
CASE_SENSITIVE - Static variable in class org.apache.paimon.catalog.FileSystemCatalogOptions
 
caseSensitiveConversion(String, boolean) - Static method in class org.apache.paimon.utils.StringUtils
 
CaseSensitiveUtils - Class in org.apache.paimon.flink.sink.cdc
Add convert operator if the catalog is case-insensitive.
CaseSensitiveUtils() - Constructor for class org.apache.paimon.flink.sink.cdc.CaseSensitiveUtils
 
cast(IN) - Method in interface org.apache.paimon.casting.CastExecutor
Cast the input value.
cast(String...) - Static method in interface org.apache.paimon.flink.action.cdc.Expression
 
CastedRow - Class in org.apache.paimon.casting
An implementation of InternalRow which provides a casted view of the underlying InternalRow.
CastedRow(CastFieldGetter[]) - Constructor for class org.apache.paimon.casting.CastedRow
 
CastExecutor<IN,OUT> - Interface in org.apache.paimon.casting
Interface to model a function that performs the casting of a value from one type to another.
CastExecutors - Class in org.apache.paimon.casting
Cast executors for input type and output type.
CastExecutors() - Constructor for class org.apache.paimon.casting.CastExecutors
 
CastFieldGetter - Class in org.apache.paimon.casting
Get field value from row with given pos and cast it according to specific CastExecutor.
CastFieldGetter(InternalRow.FieldGetter, CastExecutor<?, ?>) - Constructor for class org.apache.paimon.casting.CastFieldGetter
 
castFrom(Decimal, int, int) - Static method in class org.apache.paimon.utils.DecimalUtils
 
castFrom(String, int, int) - Static method in class org.apache.paimon.utils.DecimalUtils
 
castFrom(BinaryString, int, int) - Static method in class org.apache.paimon.utils.DecimalUtils
 
castFrom(double, int, int) - Static method in class org.apache.paimon.utils.DecimalUtils
 
castFrom(long, int, int) - Static method in class org.apache.paimon.utils.DecimalUtils
 
castFromCdcValueString(String, DataType) - Static method in class org.apache.paimon.utils.TypeUtils
 
castFromString(String, DataType) - Static method in class org.apache.paimon.utils.TypeUtils
 
castFromStringInternal(String, DataType, boolean) - Static method in class org.apache.paimon.utils.TypeUtils
 
CastRule<IN,OUT> - Interface in org.apache.paimon.casting
A CastRule provides the logic to create a CastExecutor starting from the input and the target types.
CastRulePredicate - Class in org.apache.paimon.casting
In order to apply a CastRule, the runtime checks if a particular rule matches the tuple of input and target type using this class.
CastRulePredicate.Builder - Class in org.apache.paimon.casting
Builder for the CastRulePredicate.
castToBoolean(Decimal) - Static method in class org.apache.paimon.utils.DecimalUtils
 
castToDecimal(Decimal, int, int) - Static method in class org.apache.paimon.utils.DecimalUtils
 
castToIntegral(Decimal) - Static method in class org.apache.paimon.utils.DecimalUtils
 
castToIntegral(Decimal) - Static method in class org.apache.paimon.utils.InternalRowUtils
 
Catalog - Interface in org.apache.paimon.catalog
This interface is responsible for reading and writing metadata such as database/table from a paimon catalog.
catalog - Variable in class org.apache.paimon.flink.action.ActionBase
 
catalog - Variable in class org.apache.paimon.flink.compact.MultiTableScanBase
 
catalog() - Method in class org.apache.paimon.flink.FlinkCatalog
 
catalog - Variable in class org.apache.paimon.flink.procedure.ProcedureBase
 
catalog - Variable in class org.apache.paimon.flink.sink.cdc.UpdatedDataFieldsProcessFunctionBase
 
catalog - Variable in class org.apache.paimon.flink.sink.MultiTablesStoreCompactOperator
 
catalog - Variable in class org.apache.paimon.spark.SparkCatalog
 
catalog() - Method in class org.apache.paimon.spark.SparkUtils.CatalogAndIdentifier
 
Catalog.ColumnAlreadyExistException - Exception in org.apache.paimon.catalog
Exception for trying to alter a column that already exists.
Catalog.ColumnNotExistException - Exception in org.apache.paimon.catalog
Exception for trying to operate on a column that doesn't exist.
Catalog.DatabaseAlreadyExistException - Exception in org.apache.paimon.catalog
Exception for trying to create a database that already exists.
Catalog.DatabaseNotEmptyException - Exception in org.apache.paimon.catalog
Exception for trying to drop on a database that is not empty.
Catalog.DatabaseNotExistException - Exception in org.apache.paimon.catalog
Exception for trying to operate on a database that doesn't exist.
Catalog.Loader - Interface in org.apache.paimon.catalog
Loader of Catalog.
Catalog.PartitionNotExistException - Exception in org.apache.paimon.catalog
Exception for trying to operate on a partition that doesn't exist.
Catalog.ProcessSystemDatabaseException - Exception in org.apache.paimon.catalog
Exception for trying to operate on a system database.
Catalog.TableAlreadyExistException - Exception in org.apache.paimon.catalog
Exception for trying to create a table that already exists.
Catalog.TableNotExistException - Exception in org.apache.paimon.catalog
Exception for trying to operate on a table that doesn't exist.
CATALOG_CONF - Static variable in interface org.apache.paimon.flink.action.ActionFactory
 
CATALOG_KEY - Static variable in class org.apache.paimon.jdbc.JdbcCatalogOptions
 
CATALOG_KEY - Static variable in class org.apache.paimon.jdbc.JdbcUtils
 
CATALOG_OPTIONS - Static variable in class org.apache.paimon.table.system.CatalogOptionsTable
 
CATALOG_TABLE_NAME - Static variable in class org.apache.paimon.jdbc.JdbcUtils
 
catalogAndIdentifier(List<String>, Function<String, C>, BiFunction<String[], String, T>, C, String[]) - Static method in class org.apache.paimon.spark.SparkUtils
A modified version of Spark's LookupCatalog.CatalogAndIdentifier.unapply Attempts to find the catalog and identifier a multipart identifier represents.
catalogAndIdentifier(SparkSession, List<String>, CatalogPlugin) - Static method in class org.apache.paimon.spark.SparkUtils
A modified version of Spark's LookupCatalog.CatalogAndIdentifier.unapply Attempts to find the catalog and identifier a multipart identifier represents.
catalogAndIdentifier(SparkSession, String, CatalogPlugin) - Static method in class org.apache.paimon.spark.SparkUtils
 
catalogAndIdentifier(String, SparkSession, String, CatalogPlugin) - Static method in class org.apache.paimon.spark.SparkUtils
 
CatalogAndIdentifier(Pair<CatalogPlugin, Identifier>) - Constructor for class org.apache.paimon.spark.SparkUtils.CatalogAndIdentifier
 
catalogConfig() - Method in class org.apache.paimon.flink.action.ActionBase
 
catalogConfig - Variable in class org.apache.paimon.flink.action.cdc.SynchronizationActionFactoryBase
 
CatalogContext - Class in org.apache.paimon.catalog
Context of catalog.
CatalogEnvironment - Class in org.apache.paimon.table
Catalog environment in table which contains log factory, metastore client factory and lineage meta.
CatalogEnvironment(Identifier, Lock.Factory, MetastoreClient.Factory, LineageMetaFactory) - Constructor for class org.apache.paimon.table.CatalogEnvironment
 
catalogEnvironment() - Method in class org.apache.paimon.table.DelegatedFileStoreTable
 
catalogEnvironment() - Method in interface org.apache.paimon.table.FileStoreTable
 
CatalogFactory - Interface in org.apache.paimon.catalog
Factory to create Catalog.
catalogKey() - Method in class org.apache.paimon.jdbc.JdbcCatalogLockContext
 
catalogLoader() - Method in class org.apache.paimon.flink.action.ActionBase
 
catalogLoader(Catalog.Loader) - Method in class org.apache.paimon.flink.sink.cdc.RichCdcSinkBuilder
 
catalogLoader - Variable in class org.apache.paimon.flink.sink.cdc.UpdatedDataFieldsProcessFunctionBase
 
catalogLoader - Variable in class org.apache.paimon.flink.source.operator.CombinedCompactorSourceFunction
 
CatalogLock - Interface in org.apache.paimon.catalog
An interface that allows source and sink to use global lock to some transaction-related things.
CatalogLockContext - Interface in org.apache.paimon.catalog
Context for lock factory to create lock.
CatalogLockFactory - Interface in org.apache.paimon.catalog
Factory to create CatalogLock.
catalogName - Variable in class org.apache.paimon.flink.action.ActionBase
 
catalogName - Variable in class org.apache.paimon.spark.catalog.SparkBaseCatalog
 
catalogOptions - Variable in class org.apache.paimon.catalog.AbstractCatalog
 
catalogOptions - Variable in class org.apache.paimon.flink.action.ActionBase
 
CatalogOptions - Class in org.apache.paimon.options
Options for catalog.
CatalogOptions() - Constructor for class org.apache.paimon.options.CatalogOptions
 
CatalogOptionsTable - Class in org.apache.paimon.table.system
This is a system Table to display catalog options.
CatalogOptionsTable(Options) - Constructor for class org.apache.paimon.table.system.CatalogOptionsTable
 
CatalogUtils - Class in org.apache.paimon.catalog
Utils for Catalog.
CatalogUtils() - Constructor for class org.apache.paimon.catalog.CatalogUtils
 
CATCH - Static variable in class org.apache.paimon.codegen.codesplit.JavaLexer
 
CATCH - Static variable in class org.apache.paimon.codegen.codesplit.JavaLexer
 
CATCH - Static variable in class org.apache.paimon.codegen.codesplit.JavaParser
 
CATCH - Static variable in class org.apache.paimon.codegen.codesplit.JavaParser
 
CATCH() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.CatchClauseContext
 
CATCH() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.CatchClauseContext
 
catchClause() - Method in class org.apache.paimon.codegen.codesplit.JavaParser
 
catchClause() - Method in class org.apache.paimon.codegen.codesplit.JavaParser
 
catchClause() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.StatementContext
 
catchClause(int) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.StatementContext
 
catchClause() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.StatementContext
 
catchClause(int) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.StatementContext
 
CatchClauseContext(ParserRuleContext, int) - Constructor for class org.apache.paimon.codegen.codesplit.JavaParser.CatchClauseContext
 
CatchClauseContext(ParserRuleContext, int) - Constructor for class org.apache.paimon.codegen.codesplit.JavaParser.CatchClauseContext
 
catchType() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.CatchClauseContext
 
catchType() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.CatchClauseContext
 
catchType() - Method in class org.apache.paimon.codegen.codesplit.JavaParser
 
catchType() - Method in class org.apache.paimon.codegen.codesplit.JavaParser
 
CatchTypeContext(ParserRuleContext, int) - Constructor for class org.apache.paimon.codegen.codesplit.JavaParser.CatchTypeContext
 
CatchTypeContext(ParserRuleContext, int) - Constructor for class org.apache.paimon.codegen.codesplit.JavaParser.CatchTypeContext
 
CdcActionCommonUtils - Class in org.apache.paimon.flink.action.cdc
Common utils for CDC Action.
CdcActionCommonUtils() - Constructor for class org.apache.paimon.flink.action.cdc.CdcActionCommonUtils
 
cdcConfigIdentifier() - Method in class org.apache.paimon.flink.action.cdc.kafka.KafkaSyncDatabaseActionFactory
 
cdcConfigIdentifier() - Method in class org.apache.paimon.flink.action.cdc.kafka.KafkaSyncTableActionFactory
 
cdcConfigIdentifier() - Method in class org.apache.paimon.flink.action.cdc.mongodb.MongoDBSyncDatabaseActionFactory
 
cdcConfigIdentifier() - Method in class org.apache.paimon.flink.action.cdc.mongodb.MongoDBSyncTableActionFactory
 
cdcConfigIdentifier() - Method in class org.apache.paimon.flink.action.cdc.mysql.MySqlSyncDatabaseActionFactory
 
cdcConfigIdentifier() - Method in class org.apache.paimon.flink.action.cdc.mysql.MySqlSyncTableActionFactory
 
cdcConfigIdentifier() - Method in class org.apache.paimon.flink.action.cdc.postgres.PostgresSyncTableActionFactory
 
cdcConfigIdentifier() - Method in class org.apache.paimon.flink.action.cdc.pulsar.PulsarSyncDatabaseActionFactory
 
cdcConfigIdentifier() - Method in class org.apache.paimon.flink.action.cdc.pulsar.PulsarSyncTableActionFactory
 
cdcConfigIdentifier() - Method in class org.apache.paimon.flink.action.cdc.SynchronizationActionFactoryBase
 
CdcDebeziumDeserializationSchema - Class in org.apache.paimon.flink.action.cdc.serialization
A JSON format implementation of DebeziumDeserializationSchema which deserializes the received SourceRecord to CdcSourceRecord.
CdcDebeziumDeserializationSchema() - Constructor for class org.apache.paimon.flink.action.cdc.serialization.CdcDebeziumDeserializationSchema
 
CdcDebeziumDeserializationSchema(Boolean) - Constructor for class org.apache.paimon.flink.action.cdc.serialization.CdcDebeziumDeserializationSchema
 
CdcDebeziumDeserializationSchema(Boolean, Map<String, Object>) - Constructor for class org.apache.paimon.flink.action.cdc.serialization.CdcDebeziumDeserializationSchema
 
CdcDebeziumTimestampExtractor - Class in org.apache.paimon.flink.action.cdc.watermark
Timestamp extractor for Cdc debezium deserialization.
CdcDebeziumTimestampExtractor() - Constructor for class org.apache.paimon.flink.action.cdc.watermark.CdcDebeziumTimestampExtractor
 
CdcDynamicBucketSink - Class in org.apache.paimon.flink.sink.cdc
CdcDynamicBucketSink(FileStoreTable) - Constructor for class org.apache.paimon.flink.sink.cdc.CdcDynamicBucketSink
 
CdcDynamicBucketSinkBase<T> - Class in org.apache.paimon.flink.sink.cdc
CDC sink for dynamic bucket table.
CdcDynamicBucketSinkBase(FileStoreTable) - Constructor for class org.apache.paimon.flink.sink.cdc.CdcDynamicBucketSinkBase
 
CdcDynamicBucketWriteOperator - Class in org.apache.paimon.flink.sink.cdc
A PrepareCommitOperator to write CdcRecord with bucket.
CdcDynamicBucketWriteOperator(FileStoreTable, StoreSinkWrite.Provider, String) - Constructor for class org.apache.paimon.flink.sink.cdc.CdcDynamicBucketWriteOperator
 
CdcDynamicTableParsingProcessFunction<T> - Class in org.apache.paimon.flink.sink.cdc
A ProcessFunction to parse CDC change event to either a list of DataFields or CdcRecord and send them to different side outputs according to table name.
CdcDynamicTableParsingProcessFunction(String, Catalog.Loader, EventParser.Factory<T>) - Constructor for class org.apache.paimon.flink.sink.cdc.CdcDynamicTableParsingProcessFunction
 
CdcFixedBucketChannelComputerBase<T> - Class in org.apache.paimon.flink.sink.cdc
ChannelComputer for distributing CDC records into writers for fixed-bucket mode tables.
CdcFixedBucketChannelComputerBase(TableSchema) - Constructor for class org.apache.paimon.flink.sink.cdc.CdcFixedBucketChannelComputerBase
 
CdcFixedBucketSink - Class in org.apache.paimon.flink.sink.cdc
A FlinkSink for fixed-bucket table which accepts CdcRecord and waits for a schema change if necessary.
CdcFixedBucketSink(FileStoreTable) - Constructor for class org.apache.paimon.flink.sink.cdc.CdcFixedBucketSink
 
CdcJsonDeserializationSchema - Class in org.apache.paimon.flink.action.cdc.serialization
A simple deserialization schema for CdcSourceRecord.
CdcJsonDeserializationSchema(Configuration) - Constructor for class org.apache.paimon.flink.action.cdc.serialization.CdcJsonDeserializationSchema
 
CdcJsonDeserializationSchema() - Constructor for class org.apache.paimon.flink.action.cdc.serialization.CdcJsonDeserializationSchema
 
CdcMetadataConverter - Interface in org.apache.paimon.flink.action.cdc
A functional interface for converting CDC metadata.
CdcMetadataConverter.DatabaseNameConverter - Class in org.apache.paimon.flink.action.cdc
Name of the database that contain the row.
CdcMetadataConverter.OpTsConverter - Class in org.apache.paimon.flink.action.cdc
It indicates the time that the change was made in the database.
CdcMetadataConverter.SchemaNameConverter - Class in org.apache.paimon.flink.action.cdc
Name of the schema that contain the row.
CdcMetadataConverter.TableNameConverter - Class in org.apache.paimon.flink.action.cdc
Name of the table that contain the row.
CdcMetadataProcessor - Enum in org.apache.paimon.flink.action.cdc
Enumerates the metadata processing behaviors for CDC related data.
CdcMultiplexRecord - Class in org.apache.paimon.flink.sink.cdc
A data change message from the CDC source.
CdcMultiplexRecord(String, String, CdcRecord) - Constructor for class org.apache.paimon.flink.sink.cdc.CdcMultiplexRecord
 
CdcMultiplexRecordChannelComputer - Class in org.apache.paimon.flink.sink.cdc
CdcMultiplexRecordChannelComputer(Catalog.Loader) - Constructor for class org.apache.paimon.flink.sink.cdc.CdcMultiplexRecordChannelComputer
 
cdcMultiplexRecordConvert(Catalog.Loader, DataStream<CdcMultiplexRecord>) - Static method in class org.apache.paimon.flink.sink.cdc.CaseSensitiveUtils
 
CdcMultiTableParsingProcessFunction<T> - Class in org.apache.paimon.flink.sink.cdc
A ProcessFunction to parse CDC change event to either a list of DataFields or CdcRecord and send them to different side outputs according to table name.
CdcMultiTableParsingProcessFunction(EventParser.Factory<T>) - Constructor for class org.apache.paimon.flink.sink.cdc.CdcMultiTableParsingProcessFunction
 
CdcParsingProcessFunction<T> - Class in org.apache.paimon.flink.sink.cdc
A ProcessFunction to parse CDC change event to either a list of DataFields or CdcRecord and send them to different downstreams.
CdcParsingProcessFunction(EventParser.Factory<T>) - Constructor for class org.apache.paimon.flink.sink.cdc.CdcParsingProcessFunction
 
CdcRecord - Class in org.apache.paimon.flink.sink.cdc
A data change message from the CDC source.
CdcRecord(RowKind, Map<String, String>) - Constructor for class org.apache.paimon.flink.sink.cdc.CdcRecord
 
CdcRecordChannelComputer - Class in org.apache.paimon.flink.sink.cdc
CdcRecordChannelComputer(TableSchema) - Constructor for class org.apache.paimon.flink.sink.cdc.CdcRecordChannelComputer
 
cdcRecordConvert(Catalog.Loader, DataStream<CdcRecord>) - Static method in class org.apache.paimon.flink.sink.cdc.CaseSensitiveUtils
 
CdcRecordKeyAndBucketExtractor - Class in org.apache.paimon.flink.sink.cdc
CdcRecordKeyAndBucketExtractor(TableSchema) - Constructor for class org.apache.paimon.flink.sink.cdc.CdcRecordKeyAndBucketExtractor
 
CdcRecordPartitionKeyExtractor - Class in org.apache.paimon.flink.sink.cdc
CdcRecordPartitionKeyExtractor(TableSchema) - Constructor for class org.apache.paimon.flink.sink.cdc.CdcRecordPartitionKeyExtractor
 
CdcRecordStoreMultiWriteOperator - Class in org.apache.paimon.flink.sink.cdc
CdcRecordStoreMultiWriteOperator(Catalog.Loader, StoreSinkWrite.WithWriteBufferProvider, String, Options) - Constructor for class org.apache.paimon.flink.sink.cdc.CdcRecordStoreMultiWriteOperator
 
CdcRecordStoreWriteOperator - Class in org.apache.paimon.flink.sink.cdc
CdcRecordStoreWriteOperator(FileStoreTable, StoreSinkWrite.Provider, String) - Constructor for class org.apache.paimon.flink.sink.cdc.CdcRecordStoreWriteOperator
 
CdcRecordUtils - Class in org.apache.paimon.flink.sink.cdc
Utils for CdcRecord.
CdcRecordUtils() - Constructor for class org.apache.paimon.flink.sink.cdc.CdcRecordUtils
 
CdcSinkBuilder<T> - Class in org.apache.paimon.flink.sink.cdc
Builder for sink when syncing records into one Paimon table.
CdcSinkBuilder() - Constructor for class org.apache.paimon.flink.sink.cdc.CdcSinkBuilder
 
cdcSourceConfig - Variable in class org.apache.paimon.flink.action.cdc.SynchronizationActionBase
 
cdcSourceConfig - Variable in class org.apache.paimon.flink.action.cdc.SynchronizationActionFactoryBase
 
CdcSourceRecord - Class in org.apache.paimon.flink.action.cdc
A data change record from the CDC source.
CdcSourceRecord(String, Object, Object) - Constructor for class org.apache.paimon.flink.action.cdc.CdcSourceRecord
 
CdcSourceRecord(Object) - Constructor for class org.apache.paimon.flink.action.cdc.CdcSourceRecord
 
CdcTimestampExtractor - Interface in org.apache.paimon.flink.action.cdc.watermark
Interface defining the contract for CDC timestamp extraction.
CdcUnawareBucketSink - Class in org.apache.paimon.flink.sink.cdc
CDC Sink for unaware bucket table.
CdcUnawareBucketSink(FileStoreTable, Integer) - Constructor for class org.apache.paimon.flink.sink.cdc.CdcUnawareBucketSink
 
CdcUnawareBucketWriteOperator - Class in org.apache.paimon.flink.sink.cdc
A PrepareCommitOperator to write CdcRecord to unaware-bucket mode table.
CdcUnawareBucketWriteOperator(FileStoreTable, StoreSinkWrite.Provider, String) - Constructor for class org.apache.paimon.flink.sink.cdc.CdcUnawareBucketWriteOperator
 
CdcWatermarkStrategy - Class in org.apache.paimon.flink.action.cdc.watermark
Watermark strategy for CDC sources, generating watermarks based on timestamps extracted from records.
CdcWatermarkStrategy(CdcTimestampExtractor) - Constructor for class org.apache.paimon.flink.action.cdc.watermark.CdcWatermarkStrategy
 
chainOfCauses(Throwable) - Static method in class org.apache.paimon.testutils.assertj.PaimonAssertions
 
changedPartBuckets(List<ManifestEntry>...) - Static method in class org.apache.paimon.operation.metrics.CommitStats
 
changedPartitions(List<ManifestEntry>...) - Static method in class org.apache.paimon.operation.metrics.CommitStats
 
Changelog - Class in org.apache.paimon
The metadata of changelog.
Changelog(Snapshot) - Constructor for class org.apache.paimon.Changelog
 
Changelog(Integer, long, long, String, String, String, String, String, long, Snapshot.CommitKind, long, Map<Integer, Long>, Long, Long, Long, Long, String) - Constructor for class org.apache.paimon.Changelog
 
changelog() - Method in class org.apache.paimon.compact.CompactResult
 
changelog(long) - Method in class org.apache.paimon.utils.SnapshotManager
 
CHANGELOG_FILE_PREFIX - Static variable in class org.apache.paimon.CoreOptions
 
CHANGELOG_NUM_RETAINED_MAX - Static variable in class org.apache.paimon.CoreOptions
 
CHANGELOG_NUM_RETAINED_MIN - Static variable in class org.apache.paimon.CoreOptions
 
CHANGELOG_PRODUCER - Static variable in class org.apache.paimon.CoreOptions
 
CHANGELOG_PRODUCER_FULL_COMPACTION_TRIGGER_INTERVAL - Static variable in class org.apache.paimon.flink.FlinkConnectorOptions
Deprecated.
CHANGELOG_PRODUCER_ROW_DEDUPLICATE - Static variable in class org.apache.paimon.CoreOptions
 
CHANGELOG_PRODUCER_ROW_DEDUPLICATE_IGNORE_FIELDS - Static variable in class org.apache.paimon.CoreOptions
 
CHANGELOG_TIME_RETAINED - Static variable in class org.apache.paimon.CoreOptions
 
changelogDecoupled - Variable in class org.apache.paimon.operation.FileDeletionBase
 
ChangelogDeletion - Class in org.apache.paimon.operation
Delete changelog files.
ChangelogDeletion(FileIO, FileStorePathFactory, ManifestFile, ManifestList, IndexFileHandler, StatsFileHandler, boolean, int) - Constructor for class org.apache.paimon.operation.ChangelogDeletion
 
changelogDirectory() - Method in class org.apache.paimon.utils.SnapshotManager
 
changelogFilePrefix() - Method in class org.apache.paimon.CoreOptions
 
changelogFiles() - Method in class org.apache.paimon.io.CompactIncrement
 
changelogFiles() - Method in class org.apache.paimon.io.DataIncrement
 
changelogLifecycleDecoupled() - Method in class org.apache.paimon.CoreOptions
 
changelogManifestList - Variable in class org.apache.paimon.Snapshot
 
changelogManifestList() - Method in class org.apache.paimon.Snapshot
 
changelogMaxDeletes(Integer) - Method in class org.apache.paimon.options.ExpireConfig.Builder
 
ChangelogMergeTreeRewriter - Class in org.apache.paimon.mergetree.compact
A MergeTreeCompactRewriter which produces changelog files while performing compaction.
ChangelogMergeTreeRewriter(int, CoreOptions.MergeEngine, FileReaderFactory<KeyValue>, KeyValueFileWriterFactory, Comparator<InternalRow>, FieldsComparator, MergeFunctionFactory<KeyValue>, MergeSorter, boolean, boolean) - Constructor for class org.apache.paimon.mergetree.compact.ChangelogMergeTreeRewriter
 
ChangelogMergeTreeRewriter.UpgradeStrategy - Enum in org.apache.paimon.mergetree.compact
Strategy for upgrade.
changelogNumRetainMax() - Method in class org.apache.paimon.CoreOptions
 
changelogNumRetainMin() - Method in class org.apache.paimon.CoreOptions
 
changelogProducer() - Method in class org.apache.paimon.CoreOptions
 
changelogRecordCount - Variable in class org.apache.paimon.Snapshot
 
changelogRecordCount() - Method in class org.apache.paimon.Snapshot
 
ChangelogResult - Class in org.apache.paimon.mergetree.compact
Changelog and final result for the same key.
ChangelogResult() - Constructor for class org.apache.paimon.mergetree.compact.ChangelogResult
 
changelogRetainMax(Integer) - Method in class org.apache.paimon.options.ExpireConfig.Builder
 
changelogRetainMin(Integer) - Method in class org.apache.paimon.options.ExpireConfig.Builder
 
changelogRowDeduplicate() - Method in class org.apache.paimon.CoreOptions
 
changelogRowDeduplicateIgnoreFields() - Method in class org.apache.paimon.CoreOptions
 
changelogs() - Method in class org.apache.paimon.mergetree.compact.ChangelogResult
 
changelogs() - Method in class org.apache.paimon.utils.SnapshotManager
 
changelogTimeRetain() - Method in class org.apache.paimon.CoreOptions
 
changelogTimeRetain(Duration) - Method in class org.apache.paimon.options.ExpireConfig.Builder
 
channel(CloneFileInfo) - Method in class org.apache.paimon.flink.clone.SnapshotHintChannelComputer
 
channel(RowData) - Method in class org.apache.paimon.flink.sink.BucketsRowChannelComputer
 
channel(T) - Method in class org.apache.paimon.flink.sink.cdc.CdcFixedBucketChannelComputerBase
 
channel(CdcMultiplexRecord) - Method in class org.apache.paimon.flink.sink.cdc.CdcMultiplexRecordChannelComputer
 
channel(Tuple2<KeyPartOrRow, InternalRow>) - Method in class org.apache.paimon.flink.sink.index.KeyPartRowChannelComputer
 
channel(MultiTableCommittable) - Method in class org.apache.paimon.flink.sink.MultiTableCommittableChannelComputer
 
channel(InternalRow) - Method in class org.apache.paimon.flink.sink.RowAssignerChannelComputer
 
channel(InternalRow) - Method in class org.apache.paimon.flink.sink.RowDataChannelComputer
 
channel(BinaryRow, int) - Method in class org.apache.paimon.flink.sink.RowDataChannelComputer
 
channel(Tuple2<InternalRow, Integer>) - Method in class org.apache.paimon.flink.sink.RowWithBucketChannelComputer
 
channel(T) - Method in interface org.apache.paimon.table.sink.ChannelComputer
 
channelActive(ChannelHandlerContext) - Method in class org.apache.paimon.service.network.AbstractServerHandler
 
ChannelComputer<T> - Interface in org.apache.paimon.table.sink
A utility class to compute which downstream channel a given record should be sent to.
channelComputer2() - Method in class org.apache.paimon.flink.sink.cdc.CdcDynamicBucketSinkBase
 
channelComputer2() - Method in class org.apache.paimon.flink.sink.DynamicBucketSink
 
channelComputer2() - Method in class org.apache.paimon.flink.sink.RowDynamicBucketSink
 
channelInactive(ChannelHandlerContext) - Method in class org.apache.paimon.service.network.AbstractServerHandler
 
channelInactive(ChannelHandlerContext) - Method in class org.apache.paimon.service.network.ClientHandler
 
channelNames - Static variable in class org.apache.paimon.codegen.codesplit.JavaLexer
 
channelNames - Static variable in class org.apache.paimon.codegen.codesplit.JavaLexer
 
channelRead(ChannelHandlerContext, Object) - Method in class org.apache.paimon.service.network.AbstractServerHandler
 
channelRead(ChannelHandlerContext, Object) - Method in class org.apache.paimon.service.network.ClientHandler
 
ChannelReaderInputView - Class in org.apache.paimon.disk
A DataInputView that is backed by a BufferFileReader, making it effectively a data input stream.
ChannelReaderInputView(FileIOChannel.ID, IOManager, BlockCompressionFactory, int, int) - Constructor for class org.apache.paimon.disk.ChannelReaderInputView
 
ChannelReaderInputViewIterator - Class in org.apache.paimon.disk
A simple iterator over the input read though an I/O channel.
ChannelReaderInputViewIterator(ChannelReaderInputView, List<MemorySegment>, BinaryRowSerializer) - Constructor for class org.apache.paimon.disk.ChannelReaderInputViewIterator
 
channelReaderInputViewIterator(ChannelReaderInputView) - Method in class org.apache.paimon.sort.AbstractBinaryExternalMerger
 
channelReaderInputViewIterator(ChannelReaderInputView) - Method in class org.apache.paimon.sort.BinaryExternalMerger
 
ChannelWithMeta - Class in org.apache.paimon.disk
Channel with block count and numBytesInLastBlock of file.
ChannelWithMeta(FileIOChannel.ID, int, long) - Constructor for class org.apache.paimon.disk.ChannelWithMeta
 
ChannelWriterOutputView - Class in org.apache.paimon.disk
A DataOutputView that is backed by a FileIOChannel, making it effectively a data output stream.
ChannelWriterOutputView(BufferFileWriter, BlockCompressionFactory, int) - Constructor for class org.apache.paimon.disk.ChannelWriterOutputView
 
CHAR - Static variable in class org.apache.paimon.codegen.codesplit.JavaLexer
 
CHAR - Static variable in class org.apache.paimon.codegen.codesplit.JavaLexer
 
CHAR - Static variable in class org.apache.paimon.codegen.codesplit.JavaParser
 
CHAR - Static variable in class org.apache.paimon.codegen.codesplit.JavaParser
 
CHAR() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.PrimitiveTypeContext
 
CHAR() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.PrimitiveTypeContext
 
CHAR(int) - Static method in class org.apache.paimon.types.DataTypes
 
CHAR_LITERAL - Static variable in class org.apache.paimon.codegen.codesplit.JavaLexer
 
CHAR_LITERAL - Static variable in class org.apache.paimon.codegen.codesplit.JavaLexer
 
CHAR_LITERAL - Static variable in class org.apache.paimon.codegen.codesplit.JavaParser
 
CHAR_LITERAL - Static variable in class org.apache.paimon.codegen.codesplit.JavaParser
 
CHAR_LITERAL() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.LiteralContext
 
CHAR_LITERAL() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.LiteralContext
 
CharType - Class in org.apache.paimon.types
Data type of a fixed-length character string.
CharType(boolean, int) - Constructor for class org.apache.paimon.types.CharType
 
CharType(int) - Constructor for class org.apache.paimon.types.CharType
 
CharType() - Constructor for class org.apache.paimon.types.CharType
 
checkAccess(FileIOLoader, Path, CatalogContext) - Static method in class org.apache.paimon.fs.FileIOUtils
 
checkAlterTableOption(String, String, String, boolean) - Static method in class org.apache.paimon.schema.SchemaManager
 
checkAlterTablePath(String) - Static method in class org.apache.paimon.schema.SchemaManager
 
checkAndGetOneAutoTag(List<String>) - Static method in class org.apache.paimon.tag.TagAutoCreation
 
checkArgument(Map<String, DataType>, boolean, String...) - Static method in class org.apache.paimon.flink.action.cdc.Expression.ReferencedField
 
checkArgument(boolean) - Static method in class org.apache.paimon.utils.Preconditions
Checks the given boolean condition, and throws an IllegalArgumentException if the condition is not met (evaluates to false).
checkArgument(boolean, Object) - Static method in class org.apache.paimon.utils.Preconditions
Checks the given boolean condition, and throws an IllegalArgumentException if the condition is not met (evaluates to false).
checkArgument(boolean, String, Object...) - Static method in class org.apache.paimon.utils.Preconditions
Checks the given boolean condition, and throws an IllegalArgumentException if the condition is not met (evaluates to false).
checkCompletedNormally(CompletableFuture<?>) - Static method in class org.apache.paimon.utils.Preconditions
Ensures that future has completed normally.
checkDuplicateFields(String, List<String>) - Static method in class org.apache.paimon.flink.action.cdc.CdcActionCommonUtils
 
checkedAdd(int) - Method in class org.apache.paimon.utils.RoaringBitmap32
 
checkedDelete(long) - Method in class org.apache.paimon.deletionvectors.BitmapDeletionVector
 
checkedDelete(long) - Method in interface org.apache.paimon.deletionvectors.DeletionVector
Marks the row at the specified position as deleted.
checkElementIndex(int, int) - Static method in class org.apache.paimon.utils.Preconditions
Ensures that the given index is valid for an array, list or string of the given size.
checkElementIndex(int, int, String) - Static method in class org.apache.paimon.utils.Preconditions
Ensures that the given index is valid for an array, list or string of the given size.
checkExists(FileIO, Path) - Static method in class org.apache.paimon.utils.FileUtils
 
checkIfNullSupported(Serializer<T>) - Static method in class org.apache.paimon.data.serializer.NullableSerializer
This method checks if serializer supports null value.
checkInterrupted(Throwable) - Static method in class org.apache.paimon.utils.ExceptionUtils
Checks whether the given exception is a InterruptedException and sets the interrupted flag accordingly.
checkMaxSleep(HiveConf) - Static method in class org.apache.paimon.hive.HiveCatalogLock
 
checkMaxSleep(Map<String, String>) - Static method in class org.apache.paimon.jdbc.JdbcCatalogLock
 
checkMemory(double) - Method in class org.apache.orc.impl.WriterImpl
 
checkNextIndexOffset() - Method in class org.apache.paimon.sort.BinaryIndexedSortable
check if we need request next index memory.
checkNotBranch(Identifier, String) - Static method in class org.apache.paimon.catalog.AbstractCatalog
 
checkNotEmpty() - Method in class org.apache.paimon.spark.sort.TableSorter
 
checkNotNull(JsonNode, String) - Method in class org.apache.paimon.flink.action.cdc.format.AbstractJsonRecordParser
 
checkNotNull(JsonNode, String, String, String) - Method in class org.apache.paimon.flink.action.cdc.format.AbstractJsonRecordParser
 
checkNotNull(T) - Static method in class org.apache.paimon.utils.Preconditions
Ensures that the given object reference is not null.
checkNotNull(T, String) - Static method in class org.apache.paimon.utils.Preconditions
Ensures that the given object reference is not null.
checkNotNull(T, String, Object...) - Static method in class org.apache.paimon.utils.Preconditions
Ensures that the given object reference is not null.
checkNotNull(Snapshot, String) - Static method in exception org.apache.paimon.utils.SnapshotNotExistException
 
checkNotSystemDatabase(String) - Method in class org.apache.paimon.catalog.AbstractCatalog
Validate database cannot be a system database.
checkNotSystemTable(Identifier, String) - Static method in class org.apache.paimon.catalog.AbstractCatalog
 
checkOneRequiredOption(Configuration, String, ConfigOption<?>...) - Static method in class org.apache.paimon.flink.action.cdc.CdcActionCommonUtils
 
checkOrMkdirs(Path) - Method in interface org.apache.paimon.fs.FileIO
 
checkOutputSpecs(FileSystem, JobConf) - Method in class org.apache.paimon.hive.mapred.PaimonOutputFormat
 
checkPath(Path) - Static method in class org.apache.paimon.tools.ci.licensecheck.JarFileChecker
 
checkPidPgrpidForMatch() - Method in class org.apache.paimon.benchmark.metric.cpu.ProcfsBasedProcessTree
Verify that the given process id is same as its process group id.
checkPidPgrpidForMatch(String, String) - Static method in class org.apache.paimon.benchmark.metric.cpu.ProcfsBasedProcessTree
 
checkpoint() - Method in class org.apache.paimon.operation.AbstractFileStoreWrite
 
checkpoint() - Method in class org.apache.paimon.table.sink.TableWriteImpl
 
checkpoint() - Method in class org.apache.paimon.table.source.DataTableStreamScan
 
checkpoint() - Method in interface org.apache.paimon.table.source.StreamTableScan
Checkpoint to return next snapshot id.
checkpoint() - Method in interface org.apache.paimon.utils.Restorable
Extract state of the current operation instance.
CheckpointEvent - Class in org.apache.paimon.flink.source.align
Event sent from AlignedContinuousFileSplitEnumerator to AlignedSourceReader to notify the checkpointId that is about to be triggered.
CheckpointEvent(long) - Constructor for class org.apache.paimon.flink.source.align.CheckpointEvent
 
checkpointId() - Method in class org.apache.paimon.flink.sink.Committable
 
checkpointId() - Method in class org.apache.paimon.flink.sink.MultiTableCommittable
 
checkpointId() - Method in class org.apache.paimon.manifest.WrappedManifestCommittable
 
CheckpointState(List<RewriteFileIndexSource.Split>) - Constructor for class org.apache.paimon.flink.source.RewriteFileIndexSource.CheckpointState
 
checkRefresh() - Method in class org.apache.paimon.flink.lookup.DynamicPartitionLoader
 
checkRequiredArgument(MultipleParameterToolAdapter, String) - Method in interface org.apache.paimon.flink.action.ActionFactory
 
checkRequiredOption() - Method in class org.apache.paimon.flink.action.cdc.SyncJobHandler
 
checkRequiredOptions(Configuration, String, ConfigOption<?>...) - Static method in class org.apache.paimon.flink.action.cdc.CdcActionCommonUtils
 
checkResetTableOption(String) - Static method in class org.apache.paimon.schema.SchemaManager
 
checkScanSnapshotIdValidity() - Method in class org.apache.paimon.table.source.snapshot.IncrementalStartingScanner
Check the validity of staring snapshotId early.
checkSkipReadForFixLengthPart(AbstractPagedInputView) - Method in class org.apache.paimon.data.serializer.BinaryRowSerializer
We need skip bytes to read when the remain bytes of current segment is not enough to write binary row fixed part.
checkState(boolean) - Static method in class org.apache.paimon.utils.Preconditions
Checks the given boolean condition, and throws an IllegalStateException if the condition is not met (evaluates to false).
checkState(boolean, Object) - Static method in class org.apache.paimon.utils.Preconditions
Checks the given boolean condition, and throws an IllegalStateException if the condition is not met (evaluates to false).
checkState(boolean, String, Object...) - Static method in class org.apache.paimon.utils.Preconditions
Checks the given boolean condition, and throws an IllegalStateException if the condition is not met (evaluates to false).
checkTableScanned(Identifier) - Method in class org.apache.paimon.flink.compact.MultiAwareBucketTableScan
 
checkTableScanned(Identifier) - Method in class org.apache.paimon.flink.compact.MultiUnawareBucketTableScan
 
checkTypeName(PrimitiveType.PrimitiveTypeName) - Method in class org.apache.paimon.format.parquet.reader.AbstractColumnReader
 
children() - Method in class org.apache.paimon.predicate.CompoundPredicate
 
ChunkedByteBuf - Class in org.apache.paimon.service.network
A ByteBuf instance to be consumed in chunks by ChunkedWriteHandler, respecting the high and low watermarks.
ChunkedByteBuf(ByteBuf, int) - Constructor for class org.apache.paimon.service.network.ChunkedByteBuf
 
CLASS - Static variable in class org.apache.paimon.codegen.codesplit.JavaLexer
 
CLASS - Static variable in class org.apache.paimon.codegen.codesplit.JavaLexer
 
CLASS - Static variable in class org.apache.paimon.codegen.codesplit.JavaParser
 
CLASS - Static variable in class org.apache.paimon.codegen.codesplit.JavaParser
 
CLASS() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ClassDeclarationContext
 
CLASS() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ClassDeclarationContext
 
CLASS() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.PrimaryContext
 
CLASS() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.PrimaryContext
 
classBody() - Method in class org.apache.paimon.codegen.codesplit.JavaParser
 
classBody() - Method in class org.apache.paimon.codegen.codesplit.JavaParser
 
classBody() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ClassCreatorRestContext
 
classBody() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ClassCreatorRestContext
 
classBody() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ClassDeclarationContext
 
classBody() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ClassDeclarationContext
 
classBody() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.EnumConstantContext
 
classBody() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.EnumConstantContext
 
ClassBodyContext(ParserRuleContext, int) - Constructor for class org.apache.paimon.codegen.codesplit.JavaParser.ClassBodyContext
 
ClassBodyContext(ParserRuleContext, int) - Constructor for class org.apache.paimon.codegen.codesplit.JavaParser.ClassBodyContext
 
classBodyDeclaration() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ClassBodyContext
 
classBodyDeclaration(int) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ClassBodyContext
 
classBodyDeclaration() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ClassBodyContext
 
classBodyDeclaration(int) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ClassBodyContext
 
classBodyDeclaration() - Method in class org.apache.paimon.codegen.codesplit.JavaParser
 
classBodyDeclaration() - Method in class org.apache.paimon.codegen.codesplit.JavaParser
 
classBodyDeclaration() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.EnumBodyDeclarationsContext
 
classBodyDeclaration(int) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.EnumBodyDeclarationsContext
 
classBodyDeclaration() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.EnumBodyDeclarationsContext
 
classBodyDeclaration(int) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.EnumBodyDeclarationsContext
 
ClassBodyDeclarationContext(ParserRuleContext, int) - Constructor for class org.apache.paimon.codegen.codesplit.JavaParser.ClassBodyDeclarationContext
 
ClassBodyDeclarationContext(ParserRuleContext, int) - Constructor for class org.apache.paimon.codegen.codesplit.JavaParser.ClassBodyDeclarationContext
 
classCreatorRest() - Method in class org.apache.paimon.codegen.codesplit.JavaParser
 
classCreatorRest() - Method in class org.apache.paimon.codegen.codesplit.JavaParser
 
classCreatorRest() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.CreatorContext
 
classCreatorRest() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.CreatorContext
 
classCreatorRest() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.InnerCreatorContext
 
classCreatorRest() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.InnerCreatorContext
 
ClassCreatorRestContext(ParserRuleContext, int) - Constructor for class org.apache.paimon.codegen.codesplit.JavaParser.ClassCreatorRestContext
 
ClassCreatorRestContext(ParserRuleContext, int) - Constructor for class org.apache.paimon.codegen.codesplit.JavaParser.ClassCreatorRestContext
 
classDeclaration() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.AnnotationTypeElementRestContext
 
classDeclaration() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.AnnotationTypeElementRestContext
 
classDeclaration() - Method in class org.apache.paimon.codegen.codesplit.JavaParser
 
classDeclaration() - Method in class org.apache.paimon.codegen.codesplit.JavaParser
 
classDeclaration() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.InterfaceMemberDeclarationContext
 
classDeclaration() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.InterfaceMemberDeclarationContext
 
classDeclaration() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.LocalTypeDeclarationContext
 
classDeclaration() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.LocalTypeDeclarationContext
 
classDeclaration() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.MemberDeclarationContext
 
classDeclaration() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.MemberDeclarationContext
 
classDeclaration() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.TypeDeclarationContext
 
classDeclaration() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.TypeDeclarationContext
 
ClassDeclarationContext(ParserRuleContext, int) - Constructor for class org.apache.paimon.codegen.codesplit.JavaParser.ClassDeclarationContext
 
ClassDeclarationContext(ParserRuleContext, int) - Constructor for class org.apache.paimon.codegen.codesplit.JavaParser.ClassDeclarationContext
 
classLoader - Variable in class org.apache.paimon.utils.InstantiationUtil.ClassLoaderObjectInputStream
 
ClassLoaderObjectInputStream(InputStream, ClassLoader) - Constructor for class org.apache.paimon.utils.InstantiationUtil.ClassLoaderObjectInputStream
 
classOrInterfaceModifier() - Method in class org.apache.paimon.codegen.codesplit.JavaParser
 
classOrInterfaceModifier() - Method in class org.apache.paimon.codegen.codesplit.JavaParser
 
classOrInterfaceModifier() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.LocalTypeDeclarationContext
 
classOrInterfaceModifier(int) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.LocalTypeDeclarationContext
 
classOrInterfaceModifier() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.LocalTypeDeclarationContext
 
classOrInterfaceModifier(int) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.LocalTypeDeclarationContext
 
classOrInterfaceModifier() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ModifierContext
 
classOrInterfaceModifier() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ModifierContext
 
classOrInterfaceModifier() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.TypeDeclarationContext
 
classOrInterfaceModifier(int) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.TypeDeclarationContext
 
classOrInterfaceModifier() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.TypeDeclarationContext
 
classOrInterfaceModifier(int) - Method in class org.apache.paimon.codegen.codesplit.JavaParser.TypeDeclarationContext
 
ClassOrInterfaceModifierContext(ParserRuleContext, int) - Constructor for class org.apache.paimon.codegen.codesplit.JavaParser.ClassOrInterfaceModifierContext
 
ClassOrInterfaceModifierContext(ParserRuleContext, int) - Constructor for class org.apache.paimon.codegen.codesplit.JavaParser.ClassOrInterfaceModifierContext
 
classOrInterfaceType() - Method in class org.apache.paimon.codegen.codesplit.JavaParser
 
classOrInterfaceType() - Method in class org.apache.paimon.codegen.codesplit.JavaParser
 
classOrInterfaceType() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ClassTypeContext
 
classOrInterfaceType() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ClassTypeContext
 
classOrInterfaceType() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ResourceContext
 
classOrInterfaceType() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ResourceContext
 
classOrInterfaceType() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.TypeTypeContext
 
classOrInterfaceType() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.TypeTypeContext
 
ClassOrInterfaceTypeContext(ParserRuleContext, int) - Constructor for class org.apache.paimon.codegen.codesplit.JavaParser.ClassOrInterfaceTypeContext
 
ClassOrInterfaceTypeContext(ParserRuleContext, int) - Constructor for class org.apache.paimon.codegen.codesplit.JavaParser.ClassOrInterfaceTypeContext
 
classType() - Method in class org.apache.paimon.codegen.codesplit.JavaParser
 
classType() - Method in class org.apache.paimon.codegen.codesplit.JavaParser
 
classType() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ExpressionContext
 
classType() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ExpressionContext
 
ClassTypeContext(ParserRuleContext, int) - Constructor for class org.apache.paimon.codegen.codesplit.JavaParser.ClassTypeContext
 
ClassTypeContext(ParserRuleContext, int) - Constructor for class org.apache.paimon.codegen.codesplit.JavaParser.ClassTypeContext
 
clean() - Method in interface org.apache.paimon.compact.CompactDeletionFile
 
clean() - Method in class org.apache.paimon.compact.CompactDeletionFile.GeneratedDeletionFile
 
clean() - Method in class org.apache.paimon.compact.CompactDeletionFile.LazyCompactDeletionFile
 
clean() - Method in class org.apache.paimon.operation.OrphanFilesClean
 
cleanEmptyDirectories() - Method in class org.apache.paimon.CoreOptions
 
cleanEmptyDirectories() - Method in class org.apache.paimon.operation.FileDeletionBase
Try to delete data directories that may be empty after data file deletion.
cleanLargerThan(Snapshot) - Method in class org.apache.paimon.table.RollbackHelper
Clean snapshots and tags whose id is larger than given snapshot's.
cleanUnusedDataFiles(Changelog, Predicate<ManifestEntry>) - Method in class org.apache.paimon.operation.ChangelogDeletion
 
cleanUnusedDataFiles(T, Predicate<ManifestEntry>) - Method in class org.apache.paimon.operation.FileDeletionBase
Clean data files that will not be used anymore in the snapshot.
cleanUnusedDataFiles(String, Predicate<ManifestEntry>) - Method in class org.apache.paimon.operation.FileDeletionBase
 
cleanUnusedDataFiles(Snapshot, Predicate<ManifestEntry>) - Method in class org.apache.paimon.operation.SnapshotDeletion
 
cleanUnusedDataFiles(Snapshot, Predicate<ManifestEntry>) - Method in class org.apache.paimon.operation.TagDeletion
 
cleanUnusedIndexManifests(Snapshot, Set<String>) - Method in class org.apache.paimon.operation.FileDeletionBase
 
cleanUnusedManifestList(String, Set<String>) - Method in class org.apache.paimon.operation.FileDeletionBase
 
cleanUnusedManifests(Changelog, Set<String>) - Method in class org.apache.paimon.operation.ChangelogDeletion
 
cleanUnusedManifests(T, Set<String>) - Method in class org.apache.paimon.operation.FileDeletionBase
Clean metadata files that will not be used anymore of a snapshot, including data manifests, index manifests and manifest lists.
cleanUnusedManifests(Snapshot, Set<String>, boolean, boolean) - Method in class org.apache.paimon.operation.FileDeletionBase
 
cleanUnusedManifests(Snapshot, Set<String>) - Method in class org.apache.paimon.operation.SnapshotDeletion
 
cleanUnusedManifests(Snapshot, Set<String>) - Method in class org.apache.paimon.operation.TagDeletion
 
cleanUnusedStatisticsManifests(Snapshot, Set<String>) - Method in class org.apache.paimon.operation.FileDeletionBase
 
clear() - Method in class org.apache.orc.impl.RecordReaderUtils.ByteBufferAllocatorPool
 
clear() - Method in class org.apache.paimon.data.AbstractPagedInputView
Clears the internal state of the view.
clear() - Method in class org.apache.paimon.data.AbstractPagedOutputView
Clears the internal state.
clear() - Method in class org.apache.paimon.data.BinaryRow
 
clear() - Method in class org.apache.paimon.io.DataOutputSerializer
 
clear() - Method in class org.apache.paimon.mergetree.SortBufferWriteBuffer
 
clear() - Method in interface org.apache.paimon.mergetree.WriteBuffer
Removes all records from this table.
clear() - Method in class org.apache.paimon.sort.BinaryExternalSortBuffer
 
clear() - Method in class org.apache.paimon.sort.BinaryInMemorySortBuffer
 
clear() - Method in class org.apache.paimon.sort.PartialOrderPriorityQueue
Removes all entries from the PriorityQueue.
clear() - Method in interface org.apache.paimon.sort.SortBuffer
 
clear() - Method in class org.apache.paimon.utils.BitSet
Clear the bit set.
clear() - Method in class org.apache.paimon.utils.BooleanArrayList
 
clear() - Method in class org.apache.paimon.utils.IntArrayList
 
clear() - Method in class org.apache.paimon.utils.LongArrayList
 
clear() - Method in class org.apache.paimon.utils.RoaringBitmap32
 
clear() - Method in class org.apache.paimon.utils.RoaringBitmap64
 
client() - Method in class org.apache.paimon.hive.HiveMetastoreClient
 
CLIENT_POOL_CACHE_EVICTION_INTERVAL_MS - Static variable in class org.apache.paimon.hive.HiveCatalogOptions
 
CLIENT_POOL_CACHE_KEYS - Static variable in class org.apache.paimon.hive.HiveCatalogOptions
 
CLIENT_POOL_SIZE - Static variable in class org.apache.paimon.options.CatalogOptions
 
clientClassName() - Method in class org.apache.paimon.hive.HiveCatalogLockContext
 
ClientHandler<REQ extends MessageBody,RESP extends MessageBody> - Class in org.apache.paimon.service.network
The handler used by a NetworkClient to handling incoming messages.
ClientHandler(MessageSerializer<REQ, RESP>, ClientHandlerCallback<RESP>) - Constructor for class org.apache.paimon.service.network.ClientHandler
Creates a handler with the callback.
ClientHandlerCallback<RESP extends MessageBody> - Interface in org.apache.paimon.service.network
Callback for ClientHandler.
ClientPool<C,E extends Exception> - Interface in org.apache.paimon.client
Client pool for using multiple clients to execute actions.
ClientPool.Action<R,C,E extends Exception> - Interface in org.apache.paimon.client
Action interface with return object for client.
ClientPool.ClientPoolImpl<C,E extends Exception> - Class in org.apache.paimon.client
Default implementation for ClientPool.
ClientPool.ExecuteAction<C,E extends Exception> - Interface in org.apache.paimon.client
Action interface with return void for client.
ClientPoolImpl(int, Class<? extends E>, boolean) - Constructor for class org.apache.paimon.client.ClientPool.ClientPoolImpl
 
Clock - Class in org.apache.paimon.benchmark.metric.cpu.clock
A clock that gives access to time.
Clock() - Constructor for class org.apache.paimon.benchmark.metric.cpu.clock.Clock
 
clone() - Method in class org.apache.orc.OrcFile.WriterOptions
 
clone(T) - Static method in class org.apache.paimon.utils.InstantiationUtil
Clones the given serializable object using Java serialization.
clone(T, ClassLoader) - Static method in class org.apache.paimon.utils.InstantiationUtil
Clones the given serializable object using Java serialization, using the given classloader to resolve the cloned classes.
CloneAction - Class in org.apache.paimon.flink.action
The Latest Snapshot clone action for Flink.
CloneAction(String, String, String, Map<String, String>, String, String, String, Map<String, String>, String) - Constructor for class org.apache.paimon.flink.action.CloneAction
 
CloneActionFactory - Class in org.apache.paimon.flink.action
Factory to create CloneAction.
CloneActionFactory() - Constructor for class org.apache.paimon.flink.action.CloneActionFactory
 
CloneFileInfo - Class in org.apache.paimon.flink.clone
The information of copy file.
CloneFileInfo(String, String, String) - Constructor for class org.apache.paimon.flink.clone.CloneFileInfo
 
CloneProcedure - Class in org.apache.paimon.flink.procedure
Clone Procedure.
CloneProcedure() - Constructor for class org.apache.paimon.flink.procedure.CloneProcedure
 
CloneSourceBuilder - Class in org.apache.paimon.flink.clone
Pick the tables to be cloned based on the user input parameters.
CloneSourceBuilder(StreamExecutionEnvironment, Map<String, String>, String, String, String, String) - Constructor for class org.apache.paimon.flink.clone.CloneSourceBuilder
 
close() - Method in class org.apache.orc.impl.PhysicalFsWriter
 
close() - Method in class org.apache.orc.impl.WriterImpl
 
close() - Method in class org.apache.orc.impl.ZstdCodec
 
close() - Method in class org.apache.paimon.append.AppendOnlyWriter
 
close() - Method in class org.apache.paimon.append.BucketedAppendCompactManager
 
close() - Method in class org.apache.paimon.arrow.converter.ArrowBatchConverter
 
close() - Method in class org.apache.paimon.arrow.vector.ArrowFormatCWriter
 
close() - Method in class org.apache.paimon.arrow.vector.ArrowFormatWriter
 
close() - Method in class org.apache.paimon.arrow.vector.OneElementFieldVectorGenerator
 
close() - Method in class org.apache.paimon.benchmark.metric.cpu.CpuMetricReceiver
 
close() - Method in class org.apache.paimon.benchmark.metric.cpu.CpuMetricSender
 
close() - Method in class org.apache.paimon.benchmark.metric.FlinkRestClient
 
close() - Method in class org.apache.paimon.benchmark.metric.MetricReporter
 
close() - Method in class org.apache.paimon.benchmark.utils.AutoClosableProcess
 
close() - Method in class org.apache.paimon.catalog.DelegateCatalog
 
close() - Method in class org.apache.paimon.catalog.FileSystemCatalog
 
close(C) - Method in class org.apache.paimon.client.ClientPool.ClientPoolImpl
 
close() - Method in class org.apache.paimon.client.ClientPool.ClientPoolImpl
 
close() - Method in class org.apache.paimon.compact.NoopCompactManager
 
close() - Method in class org.apache.paimon.crosspartition.GlobalIndexAssigner
 
close() - Method in class org.apache.paimon.deletionvectors.ApplyDeletionVectorReader
 
close() - Method in class org.apache.paimon.disk.AbstractFileIOChannel
 
close() - Method in class org.apache.paimon.disk.ChannelReaderInputView
 
close() - Method in class org.apache.paimon.disk.ChannelWriterOutputView
 
close() - Method in class org.apache.paimon.disk.ExternalBuffer.BufferIterator
 
close() - Method in class org.apache.paimon.disk.FileChannelManagerImpl
Remove all the temp directories.
close() - Method in interface org.apache.paimon.disk.FileIOChannel
Closes the channel.
close() - Method in class org.apache.paimon.disk.IOManagerImpl
Removes all temporary files.
close() - Method in interface org.apache.paimon.disk.RowBuffer.RowBufferIterator
 
close() - Method in class org.apache.paimon.fileindex.FileIndexFormat.Reader
 
close() - Method in class org.apache.paimon.fileindex.FileIndexFormat.Writer
 
close() - Method in class org.apache.paimon.fileindex.FileIndexPredicate
 
close() - Method in class org.apache.paimon.flink.clone.CopyFileOperator
 
close() - Method in class org.apache.paimon.flink.clone.PickFilesForCloneOperator
 
close() - Method in class org.apache.paimon.flink.clone.SnapshotHintOperator
 
close() - Method in class org.apache.paimon.flink.compact.MultiTableScanBase
 
close() - Method in class org.apache.paimon.flink.compact.UnawareBucketCompactor
 
close() - Method in class org.apache.paimon.flink.FlinkCatalog
 
close() - Method in class org.apache.paimon.flink.FlinkGenericCatalog
 
close() - Method in class org.apache.paimon.flink.lookup.AsyncLookupFunctionWrapper
 
close() - Method in class org.apache.paimon.flink.lookup.FileStoreLookupFunction
 
close() - Method in class org.apache.paimon.flink.lookup.FullCacheLookupTable
 
close() - Method in class org.apache.paimon.flink.lookup.NewLookupFunction
 
close() - Method in class org.apache.paimon.flink.lookup.OldLookupFunction
 
close() - Method in class org.apache.paimon.flink.lookup.PrimaryKeyPartialLookupTable
 
close() - Method in class org.apache.paimon.flink.metrics.FlinkMetricGroup
 
close() - Method in class org.apache.paimon.flink.query.RemoteTableQuery
 
close() - Method in class org.apache.paimon.flink.service.QueryAddressRegister
 
close() - Method in class org.apache.paimon.flink.service.QueryExecutorOperator
 
close() - Method in class org.apache.paimon.flink.sink.AppendCompactWorkerOperator
 
close() - Method in class org.apache.paimon.flink.sink.AppendOnlyMultiTableCompactionWorkerOperator
 
close() - Method in class org.apache.paimon.flink.sink.AutoTagForSavepointCommitterOperator
 
close() - Method in class org.apache.paimon.flink.sink.BatchWriteGeneratorTagOperator
 
close() - Method in class org.apache.paimon.flink.sink.cdc.CdcDynamicTableParsingProcessFunction
 
close() - Method in class org.apache.paimon.flink.sink.cdc.CdcRecordStoreMultiWriteOperator
 
close() - Method in class org.apache.paimon.flink.sink.cdc.UpdatedDataFieldsProcessFunctionBase
 
close() - Method in class org.apache.paimon.flink.sink.CommitterOperator
 
close() - Method in class org.apache.paimon.flink.sink.index.GlobalIndexAssignerOperator
 
close() - Method in class org.apache.paimon.flink.sink.LocalMergeOperator
 
close() - Method in class org.apache.paimon.flink.sink.MultiTablesStoreCompactOperator
 
close() - Method in class org.apache.paimon.flink.sink.partition.PartitionMarkDone
 
close() - Method in class org.apache.paimon.flink.sink.PrepareCommitOperator
 
close() - Method in class org.apache.paimon.flink.sink.RowDataStoreWriteOperator
 
close() - Method in class org.apache.paimon.flink.sink.StoreCommitter
 
close() - Method in class org.apache.paimon.flink.sink.StoreCompactOperator
 
close() - Method in class org.apache.paimon.flink.sink.StoreMultiCommitter
 
close() - Method in interface org.apache.paimon.flink.sink.StoreSinkWrite
 
close() - Method in class org.apache.paimon.flink.sink.StoreSinkWriteImpl
 
close() - Method in class org.apache.paimon.flink.sink.TableWriteOperator
 
close() - Method in class org.apache.paimon.flink.sorter.SortOperator
 
close() - Method in class org.apache.paimon.flink.source.align.AlignedContinuousFileSplitEnumerator
 
close() - Method in class org.apache.paimon.flink.source.AppendBypassCoordinateOperator
 
close() - Method in class org.apache.paimon.flink.source.ContinuousFileSplitEnumerator
 
close() - Method in class org.apache.paimon.flink.source.FileStoreSourceReader
 
close() - Method in class org.apache.paimon.flink.source.FileStoreSourceSplitReader
 
close() - Method in class org.apache.paimon.flink.source.operator.CombinedAwareBatchSourceFunction
 
close() - Method in class org.apache.paimon.flink.source.operator.CombinedAwareStreamingSourceFunction
 
close() - Method in class org.apache.paimon.flink.source.operator.CombinedUnawareBatchSourceFunction
 
close() - Method in class org.apache.paimon.flink.source.operator.CombinedUnawareStreamingSourceFunction
 
close() - Method in class org.apache.paimon.flink.source.operator.MultiTablesReadOperator
 
close() - Method in class org.apache.paimon.flink.source.operator.MultiUnawareTablesReadOperator
 
close() - Method in class org.apache.paimon.flink.source.operator.ReadOperator
 
close() - Method in class org.apache.paimon.flink.source.StaticFileStoreSplitEnumerator
 
close() - Method in class org.apache.paimon.format.avro.AvroBulkWriter
 
close() - Method in class org.apache.paimon.format.avro.CloseShieldOutputStream
 
close() - Method in class org.apache.paimon.format.avro.SeekableInputStreamWrapper
 
close() - Method in class org.apache.paimon.format.fs.FSDataWrappedInputStream
 
close() - Method in class org.apache.paimon.format.orc.writer.OrcBulkWriter
 
close() - Method in class org.apache.paimon.format.parquet.writer.ParquetBulkWriter
 
close() - Method in class org.apache.paimon.fs.AsyncPositionOutputStream
 
close() - Method in class org.apache.paimon.fs.ByteArraySeekableStream
 
close() - Method in class org.apache.paimon.fs.local.LocalFileIO.LocalPositionOutputStream
 
close() - Method in class org.apache.paimon.fs.local.LocalFileIO.LocalSeekableInputStream
 
close() - Method in class org.apache.paimon.fs.PositionOutputStream
Closes the output stream.
close() - Method in class org.apache.paimon.fs.PositionOutputStreamWrapper
 
close() - Method in class org.apache.paimon.fs.SeekableInputStream
Closes this input stream and releases any system resources associated with the stream.
close() - Method in class org.apache.paimon.fs.SeekableInputStreamWrapper
 
close() - Method in class org.apache.paimon.hive.HiveCatalog
 
close() - Method in class org.apache.paimon.hive.HiveCatalogLock
 
close() - Method in class org.apache.paimon.hive.HiveMetastoreClient
 
close() - Method in class org.apache.paimon.hive.mapred.PaimonRecordReader
 
close(IMetaStoreClient) - Method in class org.apache.paimon.hive.pool.HiveClientPool
 
close() - Method in class org.apache.paimon.iceberg.AbstractIcebergCommitCallback
 
close() - Method in class org.apache.paimon.io.cache.FileBasedRandomInputView
 
close() - Method in class org.apache.paimon.io.CompressedPageFileInput
 
close() - Method in class org.apache.paimon.io.CompressedPageFileOutput
 
close() - Method in class org.apache.paimon.io.DataFileIndexWriter
 
close() - Method in class org.apache.paimon.io.FileRecordReader
 
close() - Method in class org.apache.paimon.io.KeyValueDataFileRecordReader
 
close() - Method in class org.apache.paimon.io.RollingFileWriter
 
close() - Method in class org.apache.paimon.io.RowDataFileWriter
 
close() - Method in class org.apache.paimon.io.SingleFileWriter
 
close() - Method in class org.apache.paimon.io.UncompressedPageFileInput
 
close() - Method in class org.apache.paimon.io.UncompressedPageFileOutput
 
close() - Method in class org.apache.paimon.jdbc.JdbcCatalog
 
close() - Method in class org.apache.paimon.jdbc.JdbcCatalogLock
 
close(Connection) - Method in class org.apache.paimon.jdbc.JdbcClientPool
 
close() - Method in class org.apache.paimon.lookup.hash.HashLookupStoreReader
 
close() - Method in class org.apache.paimon.lookup.hash.HashLookupStoreWriter
 
close() - Method in interface org.apache.paimon.lookup.LookupStoreWriter
 
close() - Method in class org.apache.paimon.lookup.RocksDBStateFactory
 
close() - Method in class org.apache.paimon.lookup.sort.SortLookupStoreReader
 
close() - Method in class org.apache.paimon.lookup.sort.SortLookupStoreWriter
 
close() - Method in class org.apache.paimon.mergetree.compact.AbstractCompactRewriter
 
close() - Method in class org.apache.paimon.mergetree.compact.ConcatRecordReader
 
close() - Method in class org.apache.paimon.mergetree.compact.FullChangelogMergeTreeCompactRewriter
 
close() - Method in class org.apache.paimon.mergetree.compact.LookupMergeTreeCompactRewriter
 
close() - Method in class org.apache.paimon.mergetree.compact.LoserTree
 
close() - Method in class org.apache.paimon.mergetree.compact.MergeTreeCompactManager
 
close() - Method in class org.apache.paimon.mergetree.compact.SortMergeReaderWithLoserTree
 
close() - Method in class org.apache.paimon.mergetree.compact.SortMergeReaderWithMinHeap
 
close() - Method in class org.apache.paimon.mergetree.DataFileReader
 
close() - Method in class org.apache.paimon.mergetree.DropDeleteReader
 
close(RemovalCause) - Method in class org.apache.paimon.mergetree.LookupFile
 
close() - Method in class org.apache.paimon.mergetree.LookupLevels
 
close() - Method in class org.apache.paimon.mergetree.MergeTreeWriter
 
close() - Method in class org.apache.paimon.metastore.AddPartitionCommitCallback
 
close() - Method in class org.apache.paimon.metastore.AddPartitionTagCallback
 
close() - Method in class org.apache.paimon.metastore.TagPreviewCommitCallback
 
close() - Method in interface org.apache.paimon.metrics.MetricGroup
Close the metric group and release related resources.
close() - Method in class org.apache.paimon.metrics.MetricGroupImpl
 
close() - Method in class org.apache.paimon.operation.AbstractFileStoreWrite
 
close() - Method in interface org.apache.paimon.operation.FileStoreCommit
 
close() - Method in class org.apache.paimon.operation.FileStoreCommitImpl
 
close() - Method in interface org.apache.paimon.operation.FileStoreWrite
Close the writer.
close() - Method in class org.apache.paimon.operation.KeyValueFileStoreWrite
 
close() - Method in class org.apache.paimon.operation.Lock.CatalogLockImpl
 
close() - Method in class org.apache.paimon.operation.Lock.EmptyLock
 
close() - Method in class org.apache.paimon.operation.MemoryFileStoreWrite
 
close() - Method in class org.apache.paimon.operation.metrics.CompactionMetrics
 
close() - Method in class org.apache.paimon.operation.metrics.WriterBufferMetric
 
close() - Method in class org.apache.paimon.operation.ReverseReader
 
close() - Method in class org.apache.paimon.partition.actions.AddDonePartitionAction
 
close() - Method in class org.apache.paimon.partition.actions.MarkPartitionDoneEventAction
 
close() - Method in class org.apache.paimon.partition.actions.SuccessFileMarkDoneAction
 
close() - Method in class org.apache.paimon.reader.EmptyRecordReader
 
close() - Method in interface org.apache.paimon.reader.RecordReader
Closes the reader and should release all resources.
close() - Method in class org.apache.paimon.reader.RecordReaderIterator
 
close() - Method in class org.apache.paimon.service.network.ChunkedByteBuf
 
close() - Method in class org.apache.paimon.sort.AbstractBinaryExternalMerger
 
close() - Method in class org.apache.paimon.sort.SpillChannelManager
 
close() - Method in class org.apache.paimon.table.query.LocalTableQuery
 
close() - Method in class org.apache.paimon.table.sink.TableCommitImpl
 
close() - Method in class org.apache.paimon.table.sink.TableWriteImpl
 
close() - Method in class org.apache.paimon.utils.AsyncRecordReader
 
close() - Method in class org.apache.paimon.utils.CloseableIterator.IteratorAdapter
 
close() - Method in class org.apache.paimon.utils.IteratorRecordReader
 
close() - Method in class org.apache.paimon.utils.ParallelExecution
 
close() - Method in interface org.apache.paimon.utils.RecordWriter
Close this writer, the call will delete newly generated but not committed files.
close() - Method in class org.apache.parquet.hadoop.ParquetFileReader
 
close() - Method in class org.apache.parquet.hadoop.ParquetWriter
 
CloseableIterator<T> - Interface in org.apache.paimon.utils
This interface represents an Iterator that is also AutoCloseable.
CloseableIterator.IteratorAdapter<E> - Class in org.apache.paimon.utils
Adapter from Iterator to CloseableIterator.
closeAll(AutoCloseable...) - Static method in class org.apache.paimon.utils.IOUtils
 
closeAll(Iterable<? extends AutoCloseable>) - Static method in class org.apache.paimon.utils.IOUtils
Closes all AutoCloseable objects in the parameter, suppressing exceptions.
closeAll(Iterable<? extends AutoCloseable>, Class<T>) - Static method in class org.apache.paimon.utils.IOUtils
Closes all AutoCloseable objects in the parameter, suppressing exceptions.
closeAllQuietly(Iterable<? extends AutoCloseable>) - Static method in class org.apache.paimon.utils.IOUtils
Closes all AutoCloseable objects in the parameter quietly.
closeAndDelete() - Method in class org.apache.paimon.disk.AbstractFileIOChannel
 
closeAndDelete() - Method in class org.apache.paimon.disk.ChannelWriterOutputView
 
closeAndDelete() - Method in interface org.apache.paimon.disk.FileIOChannel
Closes the channel and deletes the underlying file.
closed - Variable in class org.apache.paimon.io.SingleFileWriter
 
closeQuietly(AutoCloseable) - Static method in class org.apache.paimon.utils.IOUtils
Closes the given AutoCloseable.
closeReader(Reader) - Method in class org.apache.paimon.benchmark.metric.cpu.SysInfoLinux
 
CloseShieldOutputStream - Class in org.apache.paimon.format.avro
A proxy output stream that prevents the underlying output stream from being closed.
CloseShieldOutputStream(OutputStream) - Constructor for class org.apache.paimon.format.avro.CloseShieldOutputStream
 
CLUSTERING_COLUMNS - Static variable in class org.apache.paimon.flink.FlinkConnectorOptions
 
CLUSTERING_SAMPLE_FACTOR - Static variable in class org.apache.paimon.flink.FlinkConnectorOptions
 
CLUSTERING_SORT_IN_CLUSTER - Static variable in class org.apache.paimon.flink.FlinkConnectorOptions
 
CLUSTERING_STRATEGY - Static variable in class org.apache.paimon.flink.FlinkConnectorOptions
 
clusteringIfPossible(String, String, boolean, int) - Method in class org.apache.paimon.flink.sink.FlinkSinkBuilder
Clustering the input data if possible.
coalesce(T, T) - Static method in class org.apache.paimon.utils.ObjectUtils
 
code(String) - Static method in class org.apache.paimon.options.description.TextElement
Creates a block of text formatted as code.
CodeGenerator - Interface in org.apache.paimon.codegen
GeneratedClass generator.
CodeGeneratorImpl - Class in org.apache.paimon.codegen
Default implementation of CodeGenerator.
CodeGeneratorImpl() - Constructor for class org.apache.paimon.codegen.CodeGeneratorImpl
 
CodeGenLoader - Class in org.apache.paimon.codegen
Loader to load codegen classes.
CodeGenLoader() - Constructor for class org.apache.paimon.codegen.CodeGenLoader
 
CodeGenUtils - Class in org.apache.paimon.codegen
Utils for code generations.
CodeGenUtils() - Constructor for class org.apache.paimon.codegen.CodeGenUtils
 
CodeRewriter - Interface in org.apache.paimon.codegen.codesplit
Interface for Java code rewriter.
CodeSplitUtil - Class in org.apache.paimon.codegen.codesplit
Utils for rewriters.
CodeSplitUtil() - Constructor for class org.apache.paimon.codegen.codesplit.CodeSplitUtil
 
colId() - Method in class org.apache.paimon.stats.ColStats
 
collect(InternalRow) - Method in class org.apache.paimon.format.SimpleStatsCollector
Update the statistics with a new row data.
collect(Object, Serializer<Object>) - Method in class org.apache.paimon.statistics.CountsSimpleColStatsCollector
 
collect(Object, Serializer<Object>) - Method in class org.apache.paimon.statistics.FullSimpleColStatsCollector
 
collect(Object, Serializer<Object>) - Method in class org.apache.paimon.statistics.NoneSimpleColStatsCollector
 
collect(Object, Serializer<Object>) - Method in interface org.apache.paimon.statistics.SimpleColStatsCollector
collect stats from the field.
collect(Object, Serializer<Object>) - Method in class org.apache.paimon.statistics.TruncateSimpleColStatsCollector
 
collectFieldIds(Set<Integer>) - Method in class org.apache.paimon.types.ArrayType
 
collectFieldIds(Set<Integer>) - Method in class org.apache.paimon.types.DataType
 
collectFieldIds(Set<Integer>) - Method in class org.apache.paimon.types.MapType
 
collectFieldIds(Set<Integer>) - Method in class org.apache.paimon.types.MultisetType
 
collectFieldIds(Set<Integer>) - Method in class org.apache.paimon.types.RowType
 
collectFiles(DataFilePathFactory) - Method in class org.apache.paimon.io.DataFileMeta
 
CollectionPosition - Class in org.apache.paimon.format.parquet.position
To represent collection's position in repeated type.
CollectionPosition(boolean[], long[], long[], int) - Constructor for class org.apache.paimon.format.parquet.position.CollectionPosition
 
COLON - Static variable in class org.apache.paimon.codegen.codesplit.JavaLexer
 
COLON - Static variable in class org.apache.paimon.codegen.codesplit.JavaLexer
 
COLON - Static variable in class org.apache.paimon.codegen.codesplit.JavaParser
 
COLON - Static variable in class org.apache.paimon.codegen.codesplit.JavaParser
 
COLON() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.EnhancedForControlContext
 
COLON() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.EnhancedForControlContext
 
COLON() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ExpressionContext
 
COLON() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ExpressionContext
 
COLON() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.StatementContext
 
COLON() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.StatementContext
 
COLON() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.SwitchLabelContext
 
COLON() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.SwitchLabelContext
 
COLONCOLON - Static variable in class org.apache.paimon.codegen.codesplit.JavaLexer
 
COLONCOLON - Static variable in class org.apache.paimon.codegen.codesplit.JavaLexer
 
COLONCOLON - Static variable in class org.apache.paimon.codegen.codesplit.JavaParser
 
COLONCOLON - Static variable in class org.apache.paimon.codegen.codesplit.JavaParser
 
COLONCOLON() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ExpressionContext
 
COLONCOLON() - Method in class org.apache.paimon.codegen.codesplit.JavaParser.ExpressionContext
 
ColStats<T> - Class in org.apache.paimon.stats
Col stats, supports the following stats.
ColStats(int, Long, String, String, Long, Long, Long) - Constructor for class org.apache.paimon.stats.ColStats
 
colStats() - Method in class org.apache.paimon.stats.Statistics
 
column() - Method in exception org.apache.paimon.catalog.Catalog.ColumnAlreadyExistException
 
column() - Method in exception org.apache.paimon.catalog.Catalog.ColumnNotExistException
 
Column(String) - Constructor for class org.apache.paimon.fileindex.FileIndexOptions.Column
 
Column(String, String) - Constructor for class org.apache.paimon.fileindex.FileIndexOptions.Column
 
column(String, DataType) - Method in class org.apache.paimon.schema.Schema.Builder
Declares a column that is appended to this schema.
column(String, DataType, String) - Method in class org.apache.paimon.schema.Schema.Builder
Declares a column that is appended to this schema.
ColumnAlreadyExistException(Identifier, String) - Constructor for exception org.apache.paimon.catalog.Catalog.ColumnAlreadyExistException
 
ColumnAlreadyExistException(Identifier, String, Throwable) - Constructor for exception org.apache.paimon.catalog.Catalog.ColumnAlreadyExistException
 
ColumnarArray - Class in org.apache.paimon.data.columnar
Columnar array to support access to vector column data.
ColumnarArray(ColumnVector, int, int) - Constructor for class org.apache.paimon.data.columnar.ColumnarArray
 
ColumnarMap - Class in org.apache.paimon.data.columnar
Columnar map to support access to vector column data.
ColumnarMap(ColumnVector, ColumnVector, int, int) - Constructor for class org.apache.paimon.data.columnar.ColumnarMap
 
ColumnarRow - Class in org.apache.paimon.data.columnar
Columnar row to support access to vector column data.
ColumnarRow() - Constructor for class org.apache.paimon.data.columnar.ColumnarRow
 
ColumnarRow(VectorizedColumnBatch) - Constructor for class org.apache.paimon.data.columnar.ColumnarRow
 
ColumnarRow(VectorizedColumnBatch, int) - Constructor for class org.apache.paimon.data.columnar.ColumnarRow
 
ColumnarRowIterator - Class in org.apache.paimon.data.columnar
A RecordReader.RecordIterator that returns InternalRows.
ColumnarRowIterator(Path, ColumnarRow, Runnable) - Constructor for class org.apache.paimon.data.columnar.ColumnarRowIterator
 
columnFamily - Variable in class org.apache.paimon.lookup.RocksDBState
 
columnName() - Method in interface org.apache.paimon.flink.action.cdc.CdcMetadataConverter
 
columnName() - Method in class org.apache.paimon.flink.action.cdc.CdcMetadataConverter.DatabaseNameConverter
 
columnName() - Method in class org.apache.paimon.flink.action.cdc.CdcMetadataConverter.OpTsConverter
 
columnName() - Method in class org.apache.paimon.flink.action.cdc.CdcMetadataConverter.SchemaNameConverter
 
columnName() - Method in class org.apache.paimon.flink.action.cdc.CdcMetadataConverter.TableNameConverter
 
columnName() - Method in class org.apache.paimon.flink.action.cdc.ComputedColumn
 
ColumnNotExistException(Identifier, String) - Constructor for exception org.apache.paimon.catalog.Catalog.ColumnNotExistException
 
ColumnNotExistException(Identifier, String, Throwable) - Constructor for exception org.apache.paimon.catalog.Catalog.ColumnNotExistException
 
ColumnReader<VECTOR extends WritableColumnVector> - Interface in org.apache.paimon.format.parquet.reader
Read a batch of records for a column to WritableColumnVector from parquet data file.
COLUMNS - Static variable in class org.apache.paimon.CoreOptions
 
columns - Variable in class org.apache.paimon.data.columnar.VectorizedColumnBatch
 
COLUMNS - Static variable in class org.apache.paimon.fileindex.FileIndexOptions
 
columnType() - Method in class org.apache.paimon.flink.action.cdc.ComputedColumn
 
ColumnVector - Interface in org.apache.paimon.data.columnar
Nullable column vector.
com.amazonaws.services.s3.model.transform - package com.amazonaws.services.s3.model.transform
 
combine(long, long, List<CommitT>) - Method in interface org.apache.paimon.flink.sink.Committer
Compute an aggregated committable from a list of committables.
combine(long, long, GlobalCommitT, List<CommitT>) - Method in interface org.apache.paimon.flink.sink.Committer
 
combine(long, long, List<Committable>) - Method in class org.apache.paimon.flink.sink.StoreCommitter
 
combine(long, long, ManifestCommittable, List<Committable>) - Method in class org.apache.paimon.flink.sink.StoreCommitter
 
combine(long, long, List<MultiTableCommittable>) - Method in class org.apache.paimon.flink.sink.StoreMultiCommitter
 
combine(long, long, WrappedManifestCommittable, List<MultiTableCommittable>) - Method in class org.apache.paimon.flink.sink.StoreMultiCommitter
 
CombinedAwareBatchSourceFunction - Class in org.apache.paimon.flink.source.operator
It is responsible for monitoring compactor source of aware bucket table in batch mode.
CombinedAwareBatchSourceFunction(Catalog.Loader, Pattern, Pattern, Pattern) - Constructor for class org.apache.paimon.flink.source.operator.CombinedAwareBatchSourceFunction
 
CombinedAwareStreamingSourceFunction - Class in org.apache.paimon.flink.source.operator
It is responsible for monitoring compactor source of multi bucket table in stream mode.
CombinedAwareStreamingSourceFunction(Catalog.Loader, Pattern, Pattern, Pattern, long) - Constructor for class org.apache.paimon.flink.source.operator.CombinedAwareStreamingSourceFunction
 
CombinedCompactorSourceFunction<T> - Class in org.apache.paimon.flink.source.operator
This is the single (non-parallel) monitoring task, it is responsible for: Monitoring snapshots of the Paimon table.
CombinedCompactorSourceFunction(Catalog.Loader, Pattern, Pattern, Pattern, boolean) - Constructor for class org.apache.paimon.flink.source.operator.CombinedCompactorSourceFunction
 
combinedModeTableList(String, String, List<Identifier>) - Static method in class org.apache.paimon.flink.action.cdc.CdcActionCommonUtils
 
combinedMultiComacptionWriteOperator(CheckpointConfig, boolean, String) - Method in class org.apache.paimon.flink.sink.CombinedTableCompactorSink
 
CombinedTableCompactorSink - Class in org.apache.paimon.flink.sink
A sink for processing multi-tables in dedicated compaction job.
CombinedTableCompactorSink(Catalog.Loader, Options) - Constructor for class org.apache.paimon.flink.sink.CombinedTableCompactorSink
 
CombinedTableCompactorSourceBuilder - Class in org.apache.paimon.flink.source
source builder to build a Flink compactor source for multi-tables.
CombinedTableCompactorSourceBuilder(Catalog.Loader, Pattern, Pattern, Pattern, long) - Constructor for class org.apache.paimon.flink.source.CombinedTableCompactorSourceBuilder
 
CombinedUnawareBatchSourceFunction - Class in org.apache.paimon.flink.source.operator
It is responsible for the batch compactor source of the table with unaware bucket in combined mode.
CombinedUnawareBatchSourceFunction(Catalog.Loader, Pattern, Patter