Constructor and Description |
---|
UnawareAppendTableCompactionCoordinator(FileStoreTable table,
boolean isStreaming,
Predicate filter) |
Modifier and Type | Method and Description |
---|---|
boolean |
FileIndexPredicate.testPredicate(Predicate filePredicate) |
Modifier and Type | Method and Description |
---|---|
Predicate |
PredicateConverter.visit(org.apache.flink.table.expressions.CallExpression call) |
Predicate |
PredicateConverter.visit(org.apache.flink.table.expressions.Expression expression) |
Predicate |
PredicateConverter.visit(org.apache.flink.table.expressions.FieldReferenceExpression fieldReferenceExpression) |
Predicate |
PredicateConverter.visit(org.apache.flink.table.expressions.TypeLiteralExpression typeLiteralExpression) |
Predicate |
PredicateConverter.visit(org.apache.flink.table.expressions.ValueLiteralExpression valueLiteralExpression) |
Modifier and Type | Method and Description |
---|---|
static Optional<Predicate> |
PredicateConverter.convert(org.apache.flink.table.types.logical.RowType rowType,
org.apache.flink.table.expressions.ResolvedExpression filter)
Try best to convert a
ResolvedExpression to Predicate . |
Modifier and Type | Method and Description |
---|---|
protected Predicate |
CompactAction.getPredicate() |
Modifier and Type | Method and Description |
---|---|
void |
UnawareBucketCompactionTopoBuilder.withPartitionPredicate(Predicate predicate) |
Modifier and Type | Method and Description |
---|---|
FormatReaderFactory |
CompactedChangelogReadOnlyFormat.createReaderFactory(RowType projectedRowType,
List<Predicate> filters) |
Modifier and Type | Field and Description |
---|---|
Predicate |
FullCacheLookupTable.Context.projectedPredicate |
Predicate |
FullCacheLookupTable.Context.tablePredicate |
Modifier and Type | Method and Description |
---|---|
Predicate |
FullCacheLookupTable.projectedPredicate() |
Modifier and Type | Method and Description |
---|---|
protected InnerTableRead |
LookupCompactDiffRead.innerWithFilter(Predicate predicate) |
protected void |
NoPrimaryKeyLookupTable.refreshRow(InternalRow row,
Predicate predicate) |
protected void |
PrimaryKeyLookupTable.refreshRow(InternalRow row,
Predicate predicate) |
protected abstract void |
FullCacheLookupTable.refreshRow(InternalRow row,
Predicate predicate) |
protected void |
SecondaryIndexLookupTable.refreshRow(InternalRow row,
Predicate predicate) |
void |
FullCacheLookupTable.specificPartitionFilter(Predicate filter) |
void |
PrimaryKeyPartialLookupTable.specificPartitionFilter(Predicate filter) |
void |
LookupTable.specificPartitionFilter(Predicate filter) |
Constructor and Description |
---|
Context(FileStoreTable table,
int[] projection,
Predicate tablePredicate,
Predicate projectedPredicate,
File tempPath,
List<String> joinKey,
Set<Integer> requiredCachedBucketIds) |
FileStoreLookupFunction(Table table,
int[] projection,
int[] joinKeyIndex,
Predicate predicate) |
LookupStreamingReader(LookupFileStoreTable table,
int[] projection,
Predicate predicate,
Set<Integer> requireCachedBucketIds,
Filter<InternalRow> cacheRowFilter) |
Modifier and Type | Method and Description |
---|---|
Predicate |
SimpleSqlPredicateConvertor.convert(Object sqlBasicCall) |
Predicate |
SimpleSqlPredicateConvertor.convertSqlToPredicate(String whereSql) |
Predicate |
SimpleSqlPredicateConvertor.visitBiFunction(Object left,
Object right,
java.util.function.BiFunction<Integer,Object,Predicate> visitLeft,
java.util.function.BiFunction<Integer,Object,Predicate> visitRight) |
Modifier and Type | Method and Description |
---|---|
Predicate |
SimpleSqlPredicateConvertor.visitBiFunction(Object left,
Object right,
java.util.function.BiFunction<Integer,Object,Predicate> visitLeft,
java.util.function.BiFunction<Integer,Object,Predicate> visitRight) |
Predicate |
SimpleSqlPredicateConvertor.visitBiFunction(Object left,
Object right,
java.util.function.BiFunction<Integer,Object,Predicate> visitLeft,
java.util.function.BiFunction<Integer,Object,Predicate> visitRight) |
Modifier and Type | Field and Description |
---|---|
protected Predicate |
SupportsRowLevelOperationFlinkTableSink.deletePredicate |
Modifier and Type | Field and Description |
---|---|
protected Predicate |
FlinkTableSource.predicate |
Modifier and Type | Method and Description |
---|---|
static FlinkSource |
LogHybridSourceFactory.buildHybridFirstSource(Table table,
int[][] projectedFields,
Predicate predicate) |
FlinkSourceBuilder |
FlinkSourceBuilder.predicate(Predicate predicate) |
CompactorSourceBuilder |
CompactorSourceBuilder.withPartitionPredicate(Predicate partitionPredicate) |
Constructor and Description |
---|
BaseDataTableSource(org.apache.flink.table.catalog.ObjectIdentifier tableIdentifier,
Table table,
boolean streaming,
org.apache.flink.table.factories.DynamicTableFactory.Context context,
LogStoreTableFactory logStoreTableFactory,
Predicate predicate,
int[][] projectFields,
Long limit,
org.apache.flink.api.common.eventtime.WatermarkStrategy<org.apache.flink.table.data.RowData> watermarkStrategy,
boolean isBatchCountStar) |
BucketUnawareCompactSource(FileStoreTable table,
boolean isStreaming,
long scanInterval,
Predicate filter) |
DataTableSource(org.apache.flink.table.catalog.ObjectIdentifier tableIdentifier,
Table table,
boolean streaming,
org.apache.flink.table.factories.DynamicTableFactory.Context context,
LogStoreTableFactory logStoreTableFactory,
Predicate predicate,
int[][] projectFields,
Long limit,
org.apache.flink.api.common.eventtime.WatermarkStrategy<org.apache.flink.table.data.RowData> watermarkStrategy,
List<String> dynamicPartitionFilteringFields,
boolean isBatchCountStar) |
FlinkTableSource(Table table,
Predicate predicate,
int[][] projectFields,
Long limit) |
RewriteFileIndexSource(FileStoreTable table,
Predicate partitionPredicate) |
SystemTableSource(Table table,
boolean isStreamingMode,
Predicate predicate,
int[][] projectFields,
Long limit,
int splitBatchSize,
FlinkConnectorOptions.SplitAssignMode splitAssignMode,
org.apache.flink.table.catalog.ObjectIdentifier tableIdentifier) |
Modifier and Type | Method and Description |
---|---|
abstract FormatReaderFactory |
FileFormat.createReaderFactory(RowType projectedRowType,
List<Predicate> filters)
Create a
FormatReaderFactory from the type, with projection pushed down. |
Modifier and Type | Method and Description |
---|---|
FormatReaderFactory |
AvroFileFormat.createReaderFactory(RowType projectedRowType,
List<Predicate> filters) |
Modifier and Type | Method and Description |
---|---|
FormatReaderFactory |
OrcFileFormat.createReaderFactory(RowType projectedRowType,
List<Predicate> filters) |
Modifier and Type | Method and Description |
---|---|
FormatReaderFactory |
ParquetFileFormat.createReaderFactory(RowType projectedRowType,
List<Predicate> filters) |
Modifier and Type | Method and Description |
---|---|
Optional<Predicate> |
SearchArgumentToPredicateConverter.convert() |
Modifier and Type | Method and Description |
---|---|
static Optional<Predicate> |
HiveUtils.createPredicate(TableSchema tableSchema,
org.apache.hadoop.mapred.JobConf jobConf,
boolean limitToReadColumnNames) |
Modifier and Type | Method and Description |
---|---|
KeyValueFileReaderFactory |
KeyValueFileReaderFactory.Builder.build(BinaryRow partition,
int bucket,
DeletionVector.Factory dvFactory,
boolean projectKeys,
List<Predicate> filters) |
static boolean |
FileIndexSkipper.skip(FileIO fileIO,
TableSchema dataSchema,
List<Predicate> dataFilter,
DataFilePathFactory dataFilePathFactory,
DataFileMeta file) |
Modifier and Type | Method and Description |
---|---|
Iterator<DataLineageEntity> |
LineageMeta.sinkDataLineages(Predicate predicate)
Get sink data and job lineages.
|
Iterator<TableLineageEntity> |
LineageMeta.sinkTableLineages(Predicate predicate)
Get sink table and job lineages.
|
Iterator<DataLineageEntity> |
LineageMeta.sourceDataLineages(Predicate predicate)
Get source data and job lineages.
|
Iterator<TableLineageEntity> |
LineageMeta.sourceTableLineages(Predicate predicate)
Get source table and job lineages.
|
Modifier and Type | Method and Description |
---|---|
Predicate |
DefaultValueAssigner.handlePredicate(Predicate filters) |
Modifier and Type | Method and Description |
---|---|
static Predicate |
PartitionPredicate.createPartitionPredicate(List<Map<String,String>> partitions,
RowType rowType,
String defaultPartValue) |
static Predicate |
PartitionPredicate.createPartitionPredicate(Map<String,String> spec,
RowType rowType,
String defaultPartValue) |
static Predicate |
PartitionPredicate.createPartitionPredicate(RowType partitionType,
BinaryRow partition) |
static Predicate |
PartitionPredicate.createPartitionPredicate(RowType rowType,
Map<String,Object> partition) |
static Predicate |
PartitionPredicate.createPartitionPredicate(RowType partitionType,
Object[] partition) |
Modifier and Type | Method and Description |
---|---|
static PartitionPredicate |
PartitionPredicate.fromPredicate(RowType partitionType,
Predicate predicate)
Compared to the multiple method, this approach can accept filtering of partially partitioned
fields.
|
Modifier and Type | Class and Description |
---|---|
class |
CompoundPredicate
Non-leaf node in a
Predicate tree. |
class |
LeafPredicate
Leaf node of a
Predicate tree. |
Modifier and Type | Method and Description |
---|---|
static Predicate |
PredicateBuilder.and(List<Predicate> predicates) |
static Predicate |
PredicateBuilder.and(Predicate... predicates) |
static Predicate |
PredicateBuilder.andNullable(List<Predicate> predicates) |
static Predicate |
PredicateBuilder.andNullable(Predicate... predicates) |
Predicate |
PredicateBuilder.between(int idx,
Object includedLowerBound,
Object includedUpperBound) |
Predicate |
PredicateBuilder.contains(int idx,
Object patternLiteral) |
Predicate |
PredicateBuilder.endsWith(int idx,
Object patternLiteral) |
Predicate |
PredicateBuilder.equal(int idx,
Object literal) |
Predicate |
PredicateBuilder.greaterOrEqual(int idx,
Object literal) |
Predicate |
PredicateBuilder.greaterThan(int idx,
Object literal) |
Predicate |
PredicateBuilder.in(int idx,
List<Object> literals) |
Predicate |
PredicateBuilder.isNotNull(int idx) |
Predicate |
PredicateBuilder.isNull(int idx) |
Predicate |
PredicateBuilder.leaf(LeafUnaryFunction function,
int idx) |
Predicate |
PredicateBuilder.leaf(NullFalseLeafBinaryFunction function,
int idx,
Object literal) |
Predicate |
PredicateBuilder.lessOrEqual(int idx,
Object literal) |
Predicate |
PredicateBuilder.lessThan(int idx,
Object literal) |
Predicate |
PredicateBuilder.notEqual(int idx,
Object literal) |
Predicate |
PredicateBuilder.notIn(int idx,
List<Object> literals) |
static Predicate |
PredicateBuilder.or(List<Predicate> predicates) |
static Predicate |
PredicateBuilder.or(Predicate... predicates) |
static Predicate |
PredicateBuilder.partition(Map<String,String> map,
RowType rowType,
String defaultPartValue) |
static Predicate |
PredicateBuilder.partitions(List<Map<String,String>> partitions,
RowType rowType,
String defaultPartValue) |
Predicate |
PredicateBuilder.startsWith(int idx,
Object patternLiteral) |
Modifier and Type | Method and Description |
---|---|
List<Predicate> |
CompoundPredicate.children() |
static List<Predicate> |
PredicateBuilder.excludePredicateWithFields(List<Predicate> predicates,
Set<String> fields) |
Optional<Predicate> |
CompoundPredicate.negate() |
Optional<Predicate> |
Predicate.negate() |
Optional<Predicate> |
LeafPredicate.negate() |
abstract Optional<Predicate> |
CompoundPredicate.Function.negate(List<Predicate> children) |
Optional<Predicate> |
And.negate(List<Predicate> children) |
Optional<Predicate> |
Or.negate(List<Predicate> children) |
static List<Predicate> |
PredicateBuilder.pickTransformFieldMapping(List<Predicate> predicates,
int[] fieldIdxMapping) |
static List<Predicate> |
PredicateBuilder.pickTransformFieldMapping(List<Predicate> predicates,
List<String> inputFields,
List<String> pickedFields) |
static List<Predicate> |
PredicateBuilder.splitAnd(Predicate predicate) |
static List<Predicate> |
PredicateBuilder.splitOr(Predicate predicate) |
static Optional<Predicate> |
PredicateBuilder.transformFieldMapping(Predicate predicate,
int[] fieldIdxMapping) |
default Optional<Predicate> |
PredicateReplaceVisitor.visit(CompoundPredicate predicate) |
Optional<Predicate> |
PredicateProjectionConverter.visit(CompoundPredicate predicate) |
Optional<Predicate> |
PredicateProjectionConverter.visit(LeafPredicate predicate) |
Modifier and Type | Method and Description |
---|---|
static Predicate |
PredicateBuilder.and(Predicate... predicates) |
static Predicate |
PredicateBuilder.andNullable(Predicate... predicates) |
static boolean |
PredicateBuilder.containsFields(Predicate predicate,
Set<String> fields) |
static Predicate |
PredicateBuilder.or(Predicate... predicates) |
static List<Predicate> |
PredicateBuilder.splitAnd(Predicate predicate) |
static List<Predicate> |
PredicateBuilder.splitOr(Predicate predicate) |
static Optional<Predicate> |
PredicateBuilder.transformFieldMapping(Predicate predicate,
int[] fieldIdxMapping) |
Modifier and Type | Method and Description |
---|---|
static Predicate |
PredicateBuilder.and(List<Predicate> predicates) |
static Predicate |
PredicateBuilder.andNullable(List<Predicate> predicates) |
static List<Predicate> |
PredicateBuilder.excludePredicateWithFields(List<Predicate> predicates,
Set<String> fields) |
abstract Optional<Predicate> |
CompoundPredicate.Function.negate(List<Predicate> children) |
Optional<Predicate> |
And.negate(List<Predicate> children) |
Optional<Predicate> |
Or.negate(List<Predicate> children) |
static Predicate |
PredicateBuilder.or(List<Predicate> predicates) |
static List<Predicate> |
PredicateBuilder.pickTransformFieldMapping(List<Predicate> predicates,
int[] fieldIdxMapping) |
static List<Predicate> |
PredicateBuilder.pickTransformFieldMapping(List<Predicate> predicates,
List<String> inputFields,
List<String> pickedFields) |
abstract boolean |
CompoundPredicate.Function.test(InternalRow row,
List<Predicate> children) |
boolean |
And.test(InternalRow row,
List<Predicate> children) |
boolean |
Or.test(InternalRow row,
List<Predicate> children) |
abstract boolean |
CompoundPredicate.Function.test(long rowCount,
InternalRow minValues,
InternalRow maxValues,
InternalArray nullCounts,
List<Predicate> children) |
boolean |
And.test(long rowCount,
InternalRow minValues,
InternalRow maxValues,
InternalArray nullCounts,
List<Predicate> children) |
boolean |
Or.test(long rowCount,
InternalRow minValues,
InternalRow maxValues,
InternalArray nullCounts,
List<Predicate> children) |
Constructor and Description |
---|
CompoundPredicate(CompoundPredicate.Function function,
List<Predicate> children) |
Modifier and Type | Method and Description |
---|---|
static List<Predicate> |
SchemaEvolutionUtil.createDataFilters(List<DataField> tableFields,
List<DataField> dataFields,
List<Predicate> filters)
Create predicate list from data fields.
|
Modifier and Type | Method and Description |
---|---|
static List<Predicate> |
SchemaEvolutionUtil.createDataFilters(List<DataField> tableFields,
List<DataField> dataFields,
List<Predicate> filters)
Create predicate list from data fields.
|
Modifier and Type | Method and Description |
---|---|
Predicate |
SparkFilterConverter.convert(org.apache.spark.sql.sources.Filter filter) |
Predicate |
SparkFilterConverter.convertIgnoreFailure(org.apache.spark.sql.sources.Filter filter) |
Modifier and Type | Method and Description |
---|---|
Predicate |
SimpleStatsEvolutions.convertFilter(long dataSchemaId,
Predicate filter) |
Modifier and Type | Method and Description |
---|---|
Predicate |
SimpleStatsEvolutions.convertFilter(long dataSchemaId,
Predicate filter) |
Modifier and Type | Method and Description |
---|---|
protected InnerTableRead |
KeyValueTableRead.innerWithFilter(Predicate predicate) |
protected abstract InnerTableRead |
AbstractDataTableRead.innerWithFilter(Predicate predicate) |
InnerTableScan |
InnerTableScan.withFilter(Predicate predicate) |
ReadBuilder |
ReadBuilderImpl.withFilter(Predicate filter) |
DataTableStreamScan |
DataTableStreamScan.withFilter(Predicate predicate) |
InnerTableRead |
AbstractDataTableRead.withFilter(Predicate predicate) |
InnerTableRead |
InnerTableRead.withFilter(Predicate predicate) |
InnerTableScan |
DataTableBatchScan.withFilter(Predicate predicate) |
ReadBuilder |
ReadBuilder.withFilter(Predicate predicate)
Push filters, will filter the data as much as possible, but it is not guaranteed that it is a
complete filter.
|
Modifier and Type | Method and Description |
---|---|
default InnerTableRead |
InnerTableRead.withFilter(List<Predicate> predicates) |
default ReadBuilder |
ReadBuilder.withFilter(List<Predicate> predicates)
Apply filters to the readers to decrease the number of produced records.
|
Modifier and Type | Method and Description |
---|---|
SnapshotReader |
SnapshotReader.withFilter(Predicate predicate) |
SnapshotReader |
SnapshotReaderImpl.withFilter(Predicate predicate) |
SnapshotReader |
SnapshotReader.withPartitionFilter(Predicate predicate) |
SnapshotReader |
SnapshotReaderImpl.withPartitionFilter(Predicate predicate) |
Constructor and Description |
---|
SnapshotReaderImpl(FileStoreScan scan,
TableSchema tableSchema,
CoreOptions options,
SnapshotManager snapshotManager,
SplitGenerator splitGenerator,
java.util.function.BiConsumer<FileStoreScan,Predicate> nonPartitionFilterConsumer,
DefaultValueAssigner defaultValueAssigner,
FileStorePathFactory pathFactory,
String tableName,
IndexFileHandler indexFileHandler) |
Modifier and Type | Method and Description |
---|---|
SplitRead<InternalRow> |
IncrementalDiffSplitRead.withFilter(Predicate predicate) |
Modifier and Type | Method and Description |
---|---|
InnerTableRead |
TableLineageTable.TableLineageRead.withFilter(Predicate predicate) |
Constructor and Description |
---|
TableLineageRead(LineageMetaFactory lineageMetaFactory,
Options options,
java.util.function.BiFunction<LineageMeta,Predicate,Iterator<TableLineageEntity>> tableLineageQuery) |
Modifier and Type | Method and Description |
---|---|
List<Predicate> |
BulkFormatMapping.getDataFilters() |
Constructor and Description |
---|
BulkFormatMapping(int[] indexMapping,
CastFieldGetter[] castMapping,
Pair<int[],RowType> partitionPair,
FormatReaderFactory bulkFormat,
TableSchema dataSchema,
List<Predicate> dataFilters) |
BulkFormatMappingBuilder(FileFormatDiscover formatDiscover,
List<DataField> readTableFields,
java.util.function.Function<TableSchema,List<DataField>> fieldsExtractor,
List<Predicate> filters) |
Modifier and Type | Method and Description |
---|---|
static org.apache.parquet.filter2.compat.FilterCompat.Filter |
ParquetFilters.convert(List<Predicate> predicates) |
Copyright © 2023–2024 The Apache Software Foundation. All rights reserved.