Package | Description |
---|---|
org.apache.flink.orc | |
org.apache.flink.orc.nohive | |
org.apache.flink.orc.nohive.shim | |
org.apache.flink.orc.shim |
Modifier and Type | Class and Description |
---|---|
static class |
OrcFilters.And
An AND predicate that can be evaluated by the OrcInputFormat.
|
static class |
OrcFilters.Between
An BETWEEN predicate that can be evaluated by the OrcInputFormat.
|
static class |
OrcFilters.Equals
An EQUALS predicate that can be evaluated by the OrcInputFormat.
|
static class |
OrcFilters.In
An IN predicate that can be evaluated by the OrcInputFormat.
|
static class |
OrcFilters.IsNull
An IS_NULL predicate that can be evaluated by the OrcInputFormat.
|
static class |
OrcFilters.LessThan
A LESS_THAN predicate that can be evaluated by the OrcInputFormat.
|
static class |
OrcFilters.LessThanEquals
A LESS_THAN_EQUALS predicate that can be evaluated by the OrcInputFormat.
|
static class |
OrcFilters.Not
A NOT predicate to negate a predicate that can be evaluated by the OrcInputFormat.
|
static class |
OrcFilters.NullSafeEquals
An EQUALS predicate that can be evaluated with Null safety by the OrcInputFormat.
|
static class |
OrcFilters.Or
An OR predicate that can be evaluated by the OrcInputFormat.
|
Modifier and Type | Field and Description |
---|---|
protected List<OrcFilters.Predicate> |
AbstractOrcFileInputFormat.conjunctPredicates |
Modifier and Type | Method and Description |
---|---|
protected OrcFilters.Predicate |
OrcFilters.Not.child() |
static OrcFilters.Predicate |
OrcFilters.convertBinary(CallExpression callExp,
TriFunction<String,org.apache.hadoop.hive.ql.io.sarg.PredicateLeaf.Type,Serializable,OrcFilters.Predicate> func,
TriFunction<String,org.apache.hadoop.hive.ql.io.sarg.PredicateLeaf.Type,Serializable,OrcFilters.Predicate> reverseFunc) |
static OrcFilters.Predicate |
OrcFilters.toOrcPredicate(Expression expression) |
Modifier and Type | Method and Description |
---|---|
protected Iterable<OrcFilters.Predicate> |
OrcFilters.Or.children() |
Modifier and Type | Method and Description |
---|---|
static OrcFilters.Predicate |
OrcFilters.convertBinary(CallExpression callExp,
TriFunction<String,org.apache.hadoop.hive.ql.io.sarg.PredicateLeaf.Type,Serializable,OrcFilters.Predicate> func,
TriFunction<String,org.apache.hadoop.hive.ql.io.sarg.PredicateLeaf.Type,Serializable,OrcFilters.Predicate> reverseFunc) |
static OrcFilters.Predicate |
OrcFilters.convertBinary(CallExpression callExp,
TriFunction<String,org.apache.hadoop.hive.ql.io.sarg.PredicateLeaf.Type,Serializable,OrcFilters.Predicate> func,
TriFunction<String,org.apache.hadoop.hive.ql.io.sarg.PredicateLeaf.Type,Serializable,OrcFilters.Predicate> reverseFunc) |
static <SplitT extends FileSourceSplit> |
OrcColumnarRowInputFormat.createPartitionedFormat(OrcShim<org.apache.hadoop.hive.ql.exec.vector.VectorizedRowBatch> shim,
org.apache.hadoop.conf.Configuration hadoopConfig,
RowType tableType,
List<String> partitionKeys,
PartitionFieldExtractor<SplitT> extractor,
int[] selectedFields,
List<OrcFilters.Predicate> conjunctPredicates,
int batchSize,
Function<RowType,TypeInformation<RowData>> rowTypeInfoFactory)
Create a partitioned
OrcColumnarRowInputFormat , the partition columns can be
generated by split. |
static OrcColumnarRowSplitReader<org.apache.hadoop.hive.ql.exec.vector.VectorizedRowBatch> |
OrcSplitReaderUtil.genPartColumnarRowReader(String hiveVersion,
org.apache.hadoop.conf.Configuration conf,
String[] fullFieldNames,
DataType[] fullFieldTypes,
Map<String,Object> partitionSpec,
int[] selectedFields,
List<OrcFilters.Predicate> conjunctPredicates,
int batchSize,
Path path,
long splitStart,
long splitLength)
Util for generating partitioned
OrcColumnarRowSplitReader . |
Constructor and Description |
---|
And(OrcFilters.Predicate... predicates)
Creates an AND predicate.
|
Not(OrcFilters.Predicate predicate)
Creates a NOT predicate.
|
Or(OrcFilters.Predicate... predicates)
Creates an OR predicate.
|
Constructor and Description |
---|
AbstractOrcFileInputFormat(OrcShim<BatchT> shim,
org.apache.hadoop.conf.Configuration hadoopConfig,
org.apache.orc.TypeDescription schema,
int[] selectedFields,
List<OrcFilters.Predicate> conjunctPredicates,
int batchSize) |
OrcColumnarRowInputFormat(OrcShim<BatchT> shim,
org.apache.hadoop.conf.Configuration hadoopConfig,
org.apache.orc.TypeDescription schema,
int[] selectedFields,
List<OrcFilters.Predicate> conjunctPredicates,
int batchSize,
ColumnBatchFactory<BatchT,SplitT> batchFactory,
TypeInformation<RowData> producedTypeInfo) |
OrcColumnarRowSplitReader(OrcShim<BATCH> shim,
org.apache.hadoop.conf.Configuration conf,
org.apache.orc.TypeDescription schema,
int[] selectedFields,
OrcColumnarRowSplitReader.ColumnBatchGenerator<BATCH> batchGenerator,
List<OrcFilters.Predicate> conjunctPredicates,
int batchSize,
Path path,
long splitStart,
long splitLength) |
OrcSplitReader(OrcShim<BATCH> shim,
org.apache.hadoop.conf.Configuration conf,
org.apache.orc.TypeDescription schema,
int[] selectedFields,
List<OrcFilters.Predicate> conjunctPredicates,
int batchSize,
Path path,
long splitStart,
long splitLength) |
Modifier and Type | Method and Description |
---|---|
static <SplitT extends FileSourceSplit> |
OrcNoHiveColumnarRowInputFormat.createPartitionedFormat(org.apache.hadoop.conf.Configuration hadoopConfig,
RowType tableType,
List<String> partitionKeys,
PartitionFieldExtractor<SplitT> extractor,
int[] selectedFields,
List<OrcFilters.Predicate> conjunctPredicates,
int batchSize,
Function<RowType,TypeInformation<RowData>> rowTypeInfoFactory)
Create a partitioned
OrcColumnarRowInputFormat , the partition columns can be
generated by split. |
static OrcColumnarRowSplitReader<?> |
OrcNoHiveSplitReaderUtil.genPartColumnarRowReader(org.apache.hadoop.conf.Configuration conf,
String[] fullFieldNames,
DataType[] fullFieldTypes,
Map<String,Object> partitionSpec,
int[] selectedFields,
List<OrcFilters.Predicate> conjunctPredicates,
int batchSize,
Path path,
long splitStart,
long splitLength)
Util for generating partitioned
OrcColumnarRowSplitReader . |
Modifier and Type | Method and Description |
---|---|
org.apache.orc.RecordReader |
OrcNoHiveShim.createRecordReader(org.apache.hadoop.conf.Configuration conf,
org.apache.orc.TypeDescription schema,
int[] selectedFields,
List<OrcFilters.Predicate> conjunctPredicates,
Path path,
long splitStart,
long splitLength) |
Modifier and Type | Method and Description |
---|---|
org.apache.orc.RecordReader |
OrcShimV200.createRecordReader(org.apache.hadoop.conf.Configuration conf,
org.apache.orc.TypeDescription schema,
int[] selectedFields,
List<OrcFilters.Predicate> conjunctPredicates,
Path path,
long splitStart,
long splitLength) |
org.apache.orc.RecordReader |
OrcShim.createRecordReader(org.apache.hadoop.conf.Configuration conf,
org.apache.orc.TypeDescription schema,
int[] selectedFields,
List<OrcFilters.Predicate> conjunctPredicates,
Path path,
long splitStart,
long splitLength)
Create orc
RecordReader from conf, schema and etc... |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.