Modifier and Type | Method and Description |
---|---|
Options |
CoreOptions.toConfiguration() |
Modifier and Type | Method and Description |
---|---|
static String |
CoreOptions.createCommitUser(Options options) |
static FileFormat |
CoreOptions.createFileFormat(Options options,
ConfigOption<String> formatOption) |
static Path |
CoreOptions.path(Options options) |
static void |
CoreOptions.setDefaultValues(Options options)
Set the default values of the
CoreOptions via the given Options . |
static CoreOptions.StartupMode |
CoreOptions.startupMode(Options options) |
static CoreOptions.StreamingReadMode |
CoreOptions.streamReadType(Options options) |
Constructor and Description |
---|
CoreOptions(Options options) |
Modifier and Type | Field and Description |
---|---|
protected Options |
AbstractCatalog.catalogOptions |
Modifier and Type | Method and Description |
---|---|
Options |
CatalogLockContext.options() |
Options |
CatalogContext.options() |
Modifier and Type | Method and Description |
---|---|
static CatalogContext |
CatalogContext.create(Options options) |
static CatalogContext |
CatalogContext.create(Options options,
org.apache.hadoop.conf.Configuration hadoopConf) |
static CatalogContext |
CatalogContext.create(Options options,
org.apache.hadoop.conf.Configuration hadoopConf,
FileIOLoader preferIOLoader,
FileIOLoader fallbackIOLoader) |
static CatalogContext |
CatalogContext.create(Options options,
FileIOLoader fallbackIOLoader) |
static CatalogContext |
CatalogContext.create(Options options,
FileIOLoader preferIOLoader,
FileIOLoader fallbackIOLoader) |
static CatalogLockContext |
CatalogLockContext.fromOptions(Options options) |
static Catalog |
CachingCatalog.tryToCreate(Catalog catalog,
Options options) |
Constructor and Description |
---|
AbstractCatalog(FileIO fileIO,
Options options) |
FileSystemCatalog(FileIO fileIO,
Path warehouse,
Options options) |
Modifier and Type | Method and Description |
---|---|
Options |
FileIndexOptions.getMapTopLevelOptions(String column,
String indexType) |
Modifier and Type | Method and Description |
---|---|
Set<Map.Entry<FileIndexOptions.Column,Map<String,Options>>> |
FileIndexOptions.entrySet() |
Modifier and Type | Method and Description |
---|---|
FileIndexer |
FileIndexerFactory.create(DataType type,
Options options) |
static FileIndexer |
FileIndexer.create(String type,
DataType dataType,
Options options) |
Modifier and Type | Method and Description |
---|---|
FileIndexer |
BitmapFileIndexFactory.create(DataType dataType,
Options options) |
Constructor and Description |
---|
BitmapFileIndex(DataType dataType,
Options options) |
Modifier and Type | Method and Description |
---|---|
FileIndexer |
BloomFilterFileIndexFactory.create(DataType type,
Options options) |
Constructor and Description |
---|
BloomFilterFileIndex(DataType dataType,
Options options) |
Modifier and Type | Method and Description |
---|---|
FileIndexer |
BitSliceIndexBitmapFileIndexFactory.create(DataType dataType,
Options options) |
Constructor and Description |
---|
BitSliceIndexBitmapFileIndex(DataType dataType,
Options options) |
Modifier and Type | Method and Description |
---|---|
static FlinkCatalog |
FlinkCatalogFactory.createCatalog(String catalogName,
Catalog catalog,
Options options) |
static Catalog |
FlinkCatalogFactory.createPaimonCatalog(Options catalogOptions) |
Constructor and Description |
---|
FlinkCatalog(Catalog catalog,
String name,
String defaultDatabase,
ClassLoader classLoader,
Options options) |
Modifier and Type | Field and Description |
---|---|
protected Options |
ActionBase.catalogOptions |
Modifier and Type | Method and Description |
---|---|
static Properties |
KafkaLogStoreFactory.toKafkaProperties(Options options) |
Modifier and Type | Method and Description |
---|---|
Options |
LogStoreTableFactory.RegisterContext.getOptions()
Options for the table.
|
Modifier and Type | Method and Description |
---|---|
static LogStoreRegister |
LogStoreRegister.getLogStoreRegister(Identifier identifier,
ClassLoader classLoader,
Options tableOptions,
String logStore) |
Constructor and Description |
---|
AppendOnlyMultiTableCompactionWorkerOperator(Catalog.Loader catalogLoader,
String commitUser,
Options options) |
CombinedTableCompactorSink(Catalog.Loader catalogLoader,
Options options) |
MultiTablesStoreCompactOperator(Catalog.Loader catalogLoader,
String initialCommitUser,
org.apache.flink.streaming.api.environment.CheckpointConfig checkpointConfig,
boolean isStreaming,
boolean ignorePreviousFiles,
Options options) |
PrepareCommitOperator(Options options) |
Modifier and Type | Method and Description |
---|---|
FlinkCdcSyncDatabaseSinkBuilder<T> |
FlinkCdcSyncDatabaseSinkBuilder.withTableOptions(Options options) |
Constructor and Description |
---|
CdcRecordStoreMultiWriteOperator(Catalog.Loader catalogLoader,
StoreSinkWrite.WithWriteBufferProvider storeSinkWriteProvider,
String initialCommitUser,
Options options) |
Modifier and Type | Method and Description |
---|---|
protected Options |
FileFormat.getIdentifierPrefixOptions(Options options) |
Options |
FileFormatFactory.FormatContext.options() |
Modifier and Type | Method and Description |
---|---|
static FileFormat |
FileFormat.fromIdentifier(String identifier,
Options options) |
protected Options |
FileFormat.getIdentifierPrefixOptions(Options options) |
Constructor and Description |
---|
FormatContext(Options options,
int readBatchSize,
int writeBatchSize) |
FormatContext(Options options,
int readBatchSize,
int writeBatchSize,
int zstdLevel,
MemorySize blockSize) |
Constructor and Description |
---|
ParquetReaderFactory(Options conf,
RowType projectedType,
int batchSize,
org.apache.parquet.filter2.compat.FilterCompat.Filter filter) |
Constructor and Description |
---|
RowDataParquetBuilder(RowType rowType,
Options options) |
Modifier and Type | Field and Description |
---|---|
protected Options |
PluginFileIO.options |
Modifier and Type | Method and Description |
---|---|
Options |
HiveCatalogLockContext.options() |
Modifier and Type | Method and Description |
---|---|
static ClientPool<org.apache.hadoop.hive.metastore.IMetaStoreClient,org.apache.thrift.TException> |
HiveCatalogLock.createClients(org.apache.hadoop.hive.conf.HiveConf conf,
Options options,
String clientClassName) |
Constructor and Description |
---|
Factory(Identifier identifier,
TableSchema schema,
org.apache.hadoop.hive.conf.HiveConf hiveConf,
String clientClassName,
Options options) |
HiveCatalog(FileIO fileIO,
org.apache.hadoop.hive.conf.HiveConf hiveConf,
String clientClassName,
Options options,
String warehouse) |
HiveCatalogLockContext(SerializableHiveConf hiveConf,
String clientClassName,
Options options) |
Constructor and Description |
---|
CachedClientPool(org.apache.hadoop.conf.Configuration conf,
Options options,
String clientClassName) |
Modifier and Type | Method and Description |
---|---|
static Options |
HiveUtils.extractCatalogConfig(org.apache.hadoop.conf.Configuration hiveConf)
Extract paimon catalog conf from Hive conf.
|
Modifier and Type | Method and Description |
---|---|
Options |
JdbcCatalogLockContext.options() |
Modifier and Type | Method and Description |
---|---|
static void |
JdbcUtils.createDistributedLockTable(JdbcClientPool connections,
Options options) |
void |
AbstractDistributedLockDialect.createTable(JdbcClientPool connections,
Options options) |
void |
JdbcDistributedLockDialect.createTable(JdbcClientPool connections,
Options options) |
Constructor and Description |
---|
JdbcCatalog(FileIO fileIO,
String catalogKey,
Options options,
String warehouse) |
JdbcCatalogLockContext(String catalogKey,
Options options) |
Modifier and Type | Method and Description |
---|---|
Options |
LineageMetaFactory.LineageMetaContext.options() |
Modifier and Type | Method and Description |
---|---|
static java.util.function.Function<Long,BloomFilter.Builder> |
LookupStoreFactory.bfGenerator(Options options) |
static org.rocksdb.ColumnFamilyOptions |
RocksDBOptions.createColumnOptions(org.rocksdb.ColumnFamilyOptions currentOptions,
Options options) |
static org.rocksdb.DBOptions |
RocksDBOptions.createDBOptions(org.rocksdb.DBOptions currentOptions,
Options options) |
Constructor and Description |
---|
RocksDBStateFactory(String path,
Options conf,
java.time.Duration ttlSecs) |
Modifier and Type | Method and Description |
---|---|
static MergeFunctionFactory<KeyValue> |
DeduplicateMergeFunction.factory(Options options) |
static MergeFunctionFactory<KeyValue> |
PartialUpdateMergeFunction.factory(Options options,
RowType rowType,
List<String> primaryKeys) |
static MergeFunctionFactory<KeyValue> |
FirstRowMergeFunction.factory(Options options,
RowType keyType,
RowType valueType) |
Modifier and Type | Method and Description |
---|---|
static MergeFunctionFactory<KeyValue> |
AggregateMergeFunction.factory(Options conf,
List<String> tableNames,
List<DataType> tableTypes,
List<String> primaryKeys) |
Modifier and Type | Method and Description |
---|---|
static Options |
Options.fromMap(Map<String,String> map) |
Options |
Options.removePrefix(String prefix) |
<T> Options |
Options.set(ConfigOption<T> option,
T value) |
Modifier and Type | Method and Description |
---|---|
static Catalog |
PrivilegedCatalog.tryToCreate(Catalog catalog,
Options options) |
Modifier and Type | Method and Description |
---|---|
Options |
SecurityConfiguration.getOptions() |
Modifier and Type | Method and Description |
---|---|
static void |
SecurityContext.install(Options options)
Installs security configuration by
Options . |
Constructor and Description |
---|
KerberosLoginProvider(Options options) |
SecurityConfiguration(Options options) |
Modifier and Type | Method and Description |
---|---|
static FileStoreTable |
FileStoreTableFactory.create(FileIO fileIO,
Options options) |
static FileStoreTable |
FileStoreTableFactory.create(FileIO fileIO,
Path tablePath,
TableSchema tableSchema,
Options dynamicOptions,
CatalogEnvironment catalogEnvironment) |
static FileStoreTable |
FileStoreTableFactory.createWithoutFallbackBranch(FileIO fileIO,
Path tablePath,
TableSchema tableSchema,
Options dynamicOptions,
CatalogEnvironment catalogEnvironment) |
Modifier and Type | Field and Description |
---|---|
protected Options |
TableLineageTable.options |
Modifier and Type | Method and Description |
---|---|
static Table |
SystemTableLoader.loadGlobal(String tableName,
FileIO fileIO,
java.util.function.Supplier<Map<String,Map<String,Path>>> allTablePaths,
Options catalogOptions,
LineageMetaFactory lineageMetaFactory) |
Constructor and Description |
---|
CatalogOptionsTable(Options catalogOptions) |
SinkTableLineageTable(LineageMetaFactory lineageMetaFactory,
Options options) |
SourceTableLineageTable(LineageMetaFactory lineageMetaFactory,
Options options) |
TableLineageRead(LineageMetaFactory lineageMetaFactory,
Options options,
java.util.function.BiFunction<LineageMeta,Predicate,Iterator<TableLineageEntity>> tableLineageQuery) |
TableLineageTable(LineageMetaFactory lineageMetaFactory,
Options options) |
Modifier and Type | Method and Description |
---|---|
static boolean |
HadoopUtils.addHadoopConfIfFound(org.apache.hadoop.conf.Configuration configuration,
String possibleHadoopConfPath,
Options options)
Search Hadoop configuration files in the given path, and add them to the configuration if
found.
|
static org.apache.hadoop.conf.Configuration |
HadoopUtils.getHadoopConfiguration(Options options) |
Copyright © 2023–2024 The Apache Software Foundation. All rights reserved.