Modifier and Type | Method and Description |
---|---|
TypeInformation[] |
DataDistribution.getKeyTypes()
Gets the type of the key by which the dataSet is partitioned.
|
Modifier and Type | Field and Description |
---|---|
protected TypeInformation<IN> |
UnaryOperatorInformation.inputType
Input Type of the operator
|
protected TypeInformation<IN1> |
BinaryOperatorInformation.inputType1
Input type of the first input
|
protected TypeInformation<IN2> |
BinaryOperatorInformation.inputType2
Input type of the second input
|
protected TypeInformation<OUT> |
OperatorInformation.outputType
Output type of the operator
|
Modifier and Type | Method and Description |
---|---|
TypeInformation<IN1> |
BinaryOperatorInformation.getFirstInputType() |
TypeInformation<T> |
Keys.SelectorFunctionKeys.getInputType() |
TypeInformation<IN> |
UnaryOperatorInformation.getInputType() |
abstract TypeInformation<?>[] |
Keys.getKeyFieldTypes() |
TypeInformation<?>[] |
Keys.SelectorFunctionKeys.getKeyFieldTypes() |
TypeInformation<?>[] |
Keys.ExpressionKeys.getKeyFieldTypes() |
TypeInformation<K> |
Keys.SelectorFunctionKeys.getKeyType() |
abstract TypeInformation<?>[] |
Keys.getOriginalKeyFieldTypes() |
TypeInformation<?>[] |
Keys.SelectorFunctionKeys.getOriginalKeyFieldTypes() |
TypeInformation<?>[] |
Keys.ExpressionKeys.getOriginalKeyFieldTypes() |
TypeInformation<OUT> |
OperatorInformation.getOutputType()
Gets the return type of the user code function.
|
TypeInformation<IN2> |
BinaryOperatorInformation.getSecondInputType() |
Modifier and Type | Method and Description |
---|---|
static boolean |
Keys.ExpressionKeys.isSortKey(int fieldPos,
TypeInformation<?> type) |
static boolean |
Keys.ExpressionKeys.isSortKey(String fieldExpr,
TypeInformation<?> type) |
abstract <E> void |
Keys.validateCustomPartitioner(Partitioner<E> partitioner,
TypeInformation<E> typeInfo) |
<E> void |
Keys.SelectorFunctionKeys.validateCustomPartitioner(Partitioner<E> partitioner,
TypeInformation<E> typeInfo) |
<E> void |
Keys.ExpressionKeys.validateCustomPartitioner(Partitioner<E> partitioner,
TypeInformation<E> typeInfo) |
Constructor and Description |
---|
BinaryOperatorInformation(TypeInformation<IN1> inputType1,
TypeInformation<IN2> inputType2,
TypeInformation<OUT> outputType) |
BinaryOperatorInformation(TypeInformation<IN1> inputType1,
TypeInformation<IN2> inputType2,
TypeInformation<OUT> outputType) |
BinaryOperatorInformation(TypeInformation<IN1> inputType1,
TypeInformation<IN2> inputType2,
TypeInformation<OUT> outputType) |
ExpressionKeys(int[] keyPositions,
TypeInformation<T> type)
Create int-based (non-nested) field position keys on a tuple type.
|
ExpressionKeys(int[] keyPositions,
TypeInformation<T> type,
boolean allowEmpty)
Create int-based (non-nested) field position keys on a tuple type.
|
ExpressionKeys(int keyPosition,
TypeInformation<T> type)
Create int-based (non-nested) field position keys on a tuple type.
|
ExpressionKeys(String[] keyExpressions,
TypeInformation<T> type)
Create String-based (nested) field expression keys on a composite type.
|
ExpressionKeys(String keyExpression,
TypeInformation<T> type)
Create String-based (nested) field expression keys on a composite type.
|
ExpressionKeys(TypeInformation<T> type)
ExpressionKeys that is defined by the full data type.
|
IncompatibleKeysException(TypeInformation<?> typeInformation,
TypeInformation<?> typeInformation2) |
IncompatibleKeysException(TypeInformation<?> typeInformation,
TypeInformation<?> typeInformation2) |
OperatorInformation(TypeInformation<OUT> outputType) |
SelectorFunctionKeys(KeySelector<T,K> keyExtractor,
TypeInformation<T> inputType,
TypeInformation<K> keyType) |
SelectorFunctionKeys(KeySelector<T,K> keyExtractor,
TypeInformation<T> inputType,
TypeInformation<K> keyType) |
UnaryOperatorInformation(TypeInformation<IN> inputType,
TypeInformation<OUT> outputType) |
UnaryOperatorInformation(TypeInformation<IN> inputType,
TypeInformation<OUT> outputType) |
Modifier and Type | Method and Description |
---|---|
TypeInformation<T> |
AbstractDeserializationSchema.getProducedType()
Gets the type produced by this deserializer.
|
TypeInformation<String> |
SimpleStringSchema.getProducedType() |
TypeInformation<T> |
TypeInformationSerializationSchema.getProducedType() |
Constructor and Description |
---|
AbstractDeserializationSchema(TypeInformation<T> typeInfo)
Creates an AbstractDeserializationSchema that returns the given TypeInformation for the
produced type.
|
TypeInformationSerializationSchema(TypeInformation<T> typeInfo,
ExecutionConfig ec)
Creates a new de-/serialization schema for the given type.
|
TypeInformationSerializationSchema(TypeInformation<T> typeInfo,
TypeSerializer<T> serializer)
Creates a new de-/serialization schema for the given type.
|
Constructor and Description |
---|
AggregatingStateDescriptor(String name,
AggregateFunction<IN,ACC,OUT> aggFunction,
TypeInformation<ACC> stateType)
Creates a new
ReducingStateDescriptor with the given name and default value. |
ListStateDescriptor(String name,
TypeInformation<T> elementTypeInfo)
Creates a new
ListStateDescriptor with the given name and list element type. |
MapStateDescriptor(String name,
TypeInformation<UK> keyTypeInfo,
TypeInformation<UV> valueTypeInfo)
Create a new
MapStateDescriptor with the given name and the given type information. |
MapStateDescriptor(String name,
TypeInformation<UK> keyTypeInfo,
TypeInformation<UV> valueTypeInfo)
Create a new
MapStateDescriptor with the given name and the given type information. |
ReducingStateDescriptor(String name,
ReduceFunction<T> reduceFunction,
TypeInformation<T> typeInfo)
Creates a new
ReducingStateDescriptor with the given name and default value. |
StateDescriptor(String name,
TypeInformation<T> typeInfo,
T defaultValue)
Create a new
StateDescriptor with the given name and the given type information. |
ValueStateDescriptor(String name,
TypeInformation<T> typeInfo)
Creates a new
ValueStateDescriptor with the given name and type. |
ValueStateDescriptor(String name,
TypeInformation<T> typeInfo,
T defaultValue)
Deprecated.
Use
ValueStateDescriptor.ValueStateDescriptor(String, TypeInformation) instead and manually
manage the default value by checking whether the contents of the state is null . |
Modifier and Type | Class and Description |
---|---|
class |
BasicArrayTypeInfo<T,C>
Type information for arrays boxed primitive types.
|
class |
BasicTypeInfo<T>
Type information for primitive types (int, long, double, byte, ...), String, Date, Void,
BigInteger, and BigDecimal.
|
class |
FractionalTypeInfo<T>
Type information for numeric fractional primitive types (double, float).
|
class |
IntegerTypeInfo<T>
Type information for numeric integer primitive types: int, long, byte, short, character.
|
class |
LocalTimeTypeInfo<T extends java.time.temporal.Temporal>
Type information for Java LocalDate/LocalTime/LocalDateTime.
|
class |
NothingTypeInfo
Placeholder type information for the
Nothing type. |
class |
NumericTypeInfo<T>
Type information for numeric primitive types: int, long, double, byte, short, float, char.
|
class |
PrimitiveArrayTypeInfo<T>
A
TypeInformation for arrays of primitive types (int, long, double, ...). |
class |
SqlTimeTypeInfo<T>
Type information for Java SQL Date/Time/Timestamp.
|
Modifier and Type | Field and Description |
---|---|
static TypeInformation<BigDecimal> |
Types.BIG_DEC
Returns type information for
BigDecimal . |
static TypeInformation<BigInteger> |
Types.BIG_INT
Returns type information for
BigInteger . |
static TypeInformation<Boolean> |
Types.BOOLEAN
Returns type information for both a primitive
boolean and Boolean . |
static TypeInformation<Byte> |
Types.BYTE
Returns type information for both a primitive
byte and Byte . |
static TypeInformation<Character> |
Types.CHAR
Returns type information for both a primitive
char and Character . |
static TypeInformation<Double> |
Types.DOUBLE
Returns type information for both a primitive
double and Double . |
static TypeInformation<Float> |
Types.FLOAT
Returns type information for both a primitive
float and Float . |
static TypeInformation<java.time.Instant> |
Types.INSTANT
Returns type information for
Instant . |
static TypeInformation<Integer> |
Types.INT
Returns type information for both a primitive
int and Integer . |
static TypeInformation<java.time.LocalDate> |
Types.LOCAL_DATE
Returns type information for
LocalDate . |
static TypeInformation<java.time.LocalDateTime> |
Types.LOCAL_DATE_TIME
Returns type information for
LocalDateTime . |
static TypeInformation<java.time.LocalTime> |
Types.LOCAL_TIME
Returns type information for
LocalTime . |
static TypeInformation<Long> |
Types.LONG
Returns type information for both a primitive
long and Long . |
static TypeInformation<Short> |
Types.SHORT
Returns type information for both a primitive
short and Short . |
static TypeInformation<Date> |
Types.SQL_DATE
Returns type information for
Date . |
static TypeInformation<Time> |
Types.SQL_TIME
Returns type information for
Time . |
static TypeInformation<Timestamp> |
Types.SQL_TIMESTAMP
Returns type information for
Timestamp . |
static TypeInformation<String> |
Types.STRING
Returns type information for
String . |
static TypeInformation<Void> |
Types.VOID
Returns type information for
Void . |
Modifier and Type | Method and Description |
---|---|
abstract TypeInformation<T> |
TypeInfoFactory.createTypeInfo(Type t,
Map<String,TypeInformation<?>> genericParameters)
Creates type information for the type the factory is targeted for.
|
static <L,R> TypeInformation<Either<L,R>> |
Types.EITHER(TypeInformation<L> leftType,
TypeInformation<R> rightType)
Returns type information for Flink's
Either type. |
static <E extends Enum<E>> |
Types.ENUM(Class<E> enumType)
Returns type information for Java enumerations.
|
static <T> TypeInformation<T> |
Types.GENERIC(Class<T> genericClass)
Returns generic type information for any Java object.
|
TypeInformation<C> |
BasicArrayTypeInfo.getComponentInfo() |
TypeInformation<?> |
PrimitiveArrayTypeInfo.getComponentType()
Gets the type information of the component type.
|
TypeInformation<T> |
TypeHint.getTypeInfo()
Gets the type information described by this TypeHint.
|
static <E> TypeInformation<List<E>> |
Types.LIST(TypeInformation<E> elementType)
Returns type information for a Java
List . |
static <K,V> TypeInformation<Map<K,V>> |
Types.MAP(TypeInformation<K> keyType,
TypeInformation<V> valueType)
Returns type information for a Java
Map . |
static <E> TypeInformation<E[]> |
Types.OBJECT_ARRAY(TypeInformation<E> elementType)
Returns type information for Java arrays of object types (such as
String[] ,
Integer[] ). |
static <T> TypeInformation<T> |
TypeInformation.of(Class<T> typeClass)
Creates a TypeInformation for the type described by the given class.
|
static <T> TypeInformation<T> |
TypeInformation.of(TypeHint<T> typeHint)
Creates a TypeInformation for a generic type via a utility "type hint".
|
static <T> TypeInformation<T> |
Types.POJO(Class<T> pojoClass)
Returns type information for a POJO (Plain Old Java Object).
|
static <T> TypeInformation<T> |
Types.POJO(Class<T> pojoClass,
Map<String,TypeInformation<?>> fields)
Returns type information for a POJO (Plain Old Java Object) and allows to specify all fields
manually.
|
static TypeInformation<?> |
Types.PRIMITIVE_ARRAY(TypeInformation<?> elementType)
Returns type information for Java arrays of primitive type (such as
byte[] ). |
static TypeInformation<Row> |
Types.ROW_NAMED(String[] fieldNames,
TypeInformation<?>... types)
Returns type information for
Row with fields of the given
types and with given names. |
static TypeInformation<Row> |
Types.ROW(TypeInformation<?>... types)
Returns type information for
Row with fields of the given
types. |
static <T extends Tuple> |
Types.TUPLE(Class<T> tupleSubclass)
Returns type information for typed subclasses of Flink's
Tuple . |
static <T extends Tuple> |
Types.TUPLE(TypeInformation<?>... types)
|
static <V extends Value> |
Types.VALUE(Class<V> valueType)
Returns type information for Flink value types (classes that implement
Value ). |
Modifier and Type | Method and Description |
---|---|
Map<String,TypeInformation<?>> |
TypeInformation.getGenericParameters()
Optional method for giving Flink's type extraction system information about the mapping of a
generic type parameter to the type information of a subtype.
|
Modifier and Type | Method and Description |
---|---|
static <L,R> TypeInformation<Either<L,R>> |
Types.EITHER(TypeInformation<L> leftType,
TypeInformation<R> rightType)
Returns type information for Flink's
Either type. |
static <L,R> TypeInformation<Either<L,R>> |
Types.EITHER(TypeInformation<L> leftType,
TypeInformation<R> rightType)
Returns type information for Flink's
Either type. |
static <E> TypeInformation<List<E>> |
Types.LIST(TypeInformation<E> elementType)
Returns type information for a Java
List . |
static <K,V> TypeInformation<Map<K,V>> |
Types.MAP(TypeInformation<K> keyType,
TypeInformation<V> valueType)
Returns type information for a Java
Map . |
static <K,V> TypeInformation<Map<K,V>> |
Types.MAP(TypeInformation<K> keyType,
TypeInformation<V> valueType)
Returns type information for a Java
Map . |
static <E> TypeInformation<E[]> |
Types.OBJECT_ARRAY(TypeInformation<E> elementType)
Returns type information for Java arrays of object types (such as
String[] ,
Integer[] ). |
static TypeInformation<?> |
Types.PRIMITIVE_ARRAY(TypeInformation<?> elementType)
Returns type information for Java arrays of primitive type (such as
byte[] ). |
static TypeInformation<Row> |
Types.ROW_NAMED(String[] fieldNames,
TypeInformation<?>... types)
Returns type information for
Row with fields of the given
types and with given names. |
static TypeInformation<Row> |
Types.ROW(TypeInformation<?>... types)
Returns type information for
Row with fields of the given
types. |
static <T extends Tuple> |
Types.TUPLE(TypeInformation<?>... types)
|
Modifier and Type | Method and Description |
---|---|
abstract TypeInformation<T> |
TypeInfoFactory.createTypeInfo(Type t,
Map<String,TypeInformation<?>> genericParameters)
Creates type information for the type the factory is targeted for.
|
static <T> TypeInformation<T> |
Types.POJO(Class<T> pojoClass,
Map<String,TypeInformation<?>> fields)
Returns type information for a POJO (Plain Old Java Object) and allows to specify all fields
manually.
|
Modifier and Type | Class and Description |
---|---|
class |
CompositeType<T>
Base type information class for Tuple and Pojo types
|
Modifier and Type | Method and Description |
---|---|
TypeInformation<?> |
CompositeType.FlatFieldDescriptor.getType() |
abstract <X> TypeInformation<X> |
CompositeType.getTypeAt(int pos)
Returns the type of the (unnested) field at the given field position.
|
abstract <X> TypeInformation<X> |
CompositeType.getTypeAt(String fieldExpression)
Returns the type of the (nested) field at the given field expression position.
|
Constructor and Description |
---|
FlatFieldDescriptor(int keyPosition,
TypeInformation<?> type) |
Modifier and Type | Method and Description |
---|---|
TypeInformation<Long> |
NumberSequenceSource.getProducedType() |
Modifier and Type | Field and Description |
---|---|
protected TypeInformation<T> |
Transformation.outputType |
Modifier and Type | Method and Description |
---|---|
TypeInformation<T> |
Transformation.getOutputType()
Returns the output type of this
Transformation as a TypeInformation . |
Modifier and Type | Method and Description |
---|---|
void |
Transformation.setOutputType(TypeInformation<T> outputType)
Tries to fill in the type information.
|
Constructor and Description |
---|
Transformation(String name,
TypeInformation<T> outputType,
int parallelism)
Creates a new
Transformation with the given name, output type and parallelism. |
Modifier and Type | Method and Description |
---|---|
TypeInformation<T> |
DataSet.getType()
Returns the
TypeInformation for the type of this DataSet. |
Modifier and Type | Method and Description |
---|---|
<X> DataSource<X> |
ExecutionEnvironment.createInput(InputFormat<X,?> inputFormat,
TypeInformation<X> producedType)
Generic method to create an input DataSet with in
InputFormat . |
protected void |
DataSet.fillInType(TypeInformation<T> typeInfo)
Tries to fill in the type information.
|
<X> DataSource<X> |
ExecutionEnvironment.fromCollection(Collection<X> data,
TypeInformation<X> type)
Creates a DataSet from the given non-empty collection.
|
<X> DataSource<X> |
ExecutionEnvironment.fromCollection(Iterator<X> data,
TypeInformation<X> type)
Creates a DataSet from the given iterator.
|
<X> DataSource<X> |
ExecutionEnvironment.fromParallelCollection(SplittableIterator<X> iterator,
TypeInformation<X> type)
Creates a new data set that contains elements in the iterator.
|
static <T> String |
Utils.getSerializerTree(TypeInformation<T> ti)
Debugging utility to understand the hierarchy of serializers created by the Java API.
|
Constructor and Description |
---|
DataSet(ExecutionEnvironment context,
TypeInformation<T> typeInfo) |
Modifier and Type | Method and Description |
---|---|
static DualInputSemanticProperties |
SemanticPropUtil.createProjectionPropertiesDual(int[] fields,
boolean[] isFromFirst,
TypeInformation<?> inType1,
TypeInformation<?> inType2) |
static DualInputSemanticProperties |
SemanticPropUtil.createProjectionPropertiesDual(int[] fields,
boolean[] isFromFirst,
TypeInformation<?> inType1,
TypeInformation<?> inType2) |
static DualInputSemanticProperties |
SemanticPropUtil.getSemanticPropsDual(Set<Annotation> set,
TypeInformation<?> inType1,
TypeInformation<?> inType2,
TypeInformation<?> outType) |
static DualInputSemanticProperties |
SemanticPropUtil.getSemanticPropsDual(Set<Annotation> set,
TypeInformation<?> inType1,
TypeInformation<?> inType2,
TypeInformation<?> outType) |
static DualInputSemanticProperties |
SemanticPropUtil.getSemanticPropsDual(Set<Annotation> set,
TypeInformation<?> inType1,
TypeInformation<?> inType2,
TypeInformation<?> outType) |
static void |
SemanticPropUtil.getSemanticPropsDualFromString(DualInputSemanticProperties result,
String[] forwardedFirst,
String[] forwardedSecond,
String[] nonForwardedFirst,
String[] nonForwardedSecond,
String[] readFieldsFirst,
String[] readFieldsSecond,
TypeInformation<?> inType1,
TypeInformation<?> inType2,
TypeInformation<?> outType) |
static void |
SemanticPropUtil.getSemanticPropsDualFromString(DualInputSemanticProperties result,
String[] forwardedFirst,
String[] forwardedSecond,
String[] nonForwardedFirst,
String[] nonForwardedSecond,
String[] readFieldsFirst,
String[] readFieldsSecond,
TypeInformation<?> inType1,
TypeInformation<?> inType2,
TypeInformation<?> outType) |
static void |
SemanticPropUtil.getSemanticPropsDualFromString(DualInputSemanticProperties result,
String[] forwardedFirst,
String[] forwardedSecond,
String[] nonForwardedFirst,
String[] nonForwardedSecond,
String[] readFieldsFirst,
String[] readFieldsSecond,
TypeInformation<?> inType1,
TypeInformation<?> inType2,
TypeInformation<?> outType) |
static void |
SemanticPropUtil.getSemanticPropsDualFromString(DualInputSemanticProperties result,
String[] forwardedFirst,
String[] forwardedSecond,
String[] nonForwardedFirst,
String[] nonForwardedSecond,
String[] readFieldsFirst,
String[] readFieldsSecond,
TypeInformation<?> inType1,
TypeInformation<?> inType2,
TypeInformation<?> outType,
boolean skipIncompatibleTypes) |
static void |
SemanticPropUtil.getSemanticPropsDualFromString(DualInputSemanticProperties result,
String[] forwardedFirst,
String[] forwardedSecond,
String[] nonForwardedFirst,
String[] nonForwardedSecond,
String[] readFieldsFirst,
String[] readFieldsSecond,
TypeInformation<?> inType1,
TypeInformation<?> inType2,
TypeInformation<?> outType,
boolean skipIncompatibleTypes) |
static void |
SemanticPropUtil.getSemanticPropsDualFromString(DualInputSemanticProperties result,
String[] forwardedFirst,
String[] forwardedSecond,
String[] nonForwardedFirst,
String[] nonForwardedSecond,
String[] readFieldsFirst,
String[] readFieldsSecond,
TypeInformation<?> inType1,
TypeInformation<?> inType2,
TypeInformation<?> outType,
boolean skipIncompatibleTypes) |
static SingleInputSemanticProperties |
SemanticPropUtil.getSemanticPropsSingle(Set<Annotation> set,
TypeInformation<?> inType,
TypeInformation<?> outType) |
static SingleInputSemanticProperties |
SemanticPropUtil.getSemanticPropsSingle(Set<Annotation> set,
TypeInformation<?> inType,
TypeInformation<?> outType) |
static void |
SemanticPropUtil.getSemanticPropsSingleFromString(SingleInputSemanticProperties result,
String[] forwarded,
String[] nonForwarded,
String[] readSet,
TypeInformation<?> inType,
TypeInformation<?> outType) |
static void |
SemanticPropUtil.getSemanticPropsSingleFromString(SingleInputSemanticProperties result,
String[] forwarded,
String[] nonForwarded,
String[] readSet,
TypeInformation<?> inType,
TypeInformation<?> outType) |
static void |
SemanticPropUtil.getSemanticPropsSingleFromString(SingleInputSemanticProperties result,
String[] forwarded,
String[] nonForwarded,
String[] readSet,
TypeInformation<?> inType,
TypeInformation<?> outType,
boolean skipIncompatibleTypes) |
static void |
SemanticPropUtil.getSemanticPropsSingleFromString(SingleInputSemanticProperties result,
String[] forwarded,
String[] nonForwarded,
String[] readSet,
TypeInformation<?> inType,
TypeInformation<?> outType,
boolean skipIncompatibleTypes) |
Modifier and Type | Method and Description |
---|---|
TypeInformation<Tuple2<K,V>> |
HadoopInputFormat.getProducedType() |
Modifier and Type | Method and Description |
---|---|
TypeInformation<Tuple2<K,V>> |
HadoopInputFormat.getProducedType() |
Modifier and Type | Method and Description |
---|---|
TypeInformation<T> |
TypeSerializerInputFormat.getProducedType() |
TypeInformation<Row> |
RowCsvInputFormat.getProducedType() |
Modifier and Type | Method and Description |
---|---|
void |
CsvOutputFormat.setInputType(TypeInformation<?> type,
ExecutionConfig executionConfig)
The purpose of this method is solely to check whether the data type to be processed is in
fact a tuple type.
|
void |
TypeSerializerOutputFormat.setInputType(TypeInformation<?> type,
ExecutionConfig executionConfig) |
void |
LocalCollectionOutputFormat.setInputType(TypeInformation<?> type,
ExecutionConfig executionConfig) |
Constructor and Description |
---|
RowCsvInputFormat(Path filePath,
TypeInformation[] fieldTypes) |
RowCsvInputFormat(Path filePath,
TypeInformation[] fieldTypes,
boolean emptyColumnAsNull) |
RowCsvInputFormat(Path filePath,
TypeInformation[] fieldTypes,
int[] selectedFields) |
RowCsvInputFormat(Path filePath,
TypeInformation[] fieldTypes,
String lineDelimiter,
String fieldDelimiter) |
RowCsvInputFormat(Path filePath,
TypeInformation[] fieldTypes,
String lineDelimiter,
String fieldDelimiter,
int[] selectedFields) |
RowCsvInputFormat(Path filePath,
TypeInformation[] fieldTypeInfos,
String lineDelimiter,
String fieldDelimiter,
int[] selectedFields,
boolean emptyColumnAsNull) |
SplitDataProperties(TypeInformation<T> type)
Creates SplitDataProperties for the given data types.
|
TypeSerializerInputFormat(TypeInformation<T> resultType) |
Modifier and Type | Method and Description |
---|---|
static <T,K> TypeInformation<Tuple2<K,T>> |
KeyFunctions.createTypeWithKey(Keys.SelectorFunctionKeys<T,K> key) |
static <T,K1,K2> TypeInformation<Tuple3<K1,K2,T>> |
KeyFunctions.createTypeWithKey(Keys.SelectorFunctionKeys<T,K1> key1,
Keys.SelectorFunctionKeys<T,K2> key2) |
TypeInformation<IN1> |
TwoInputOperator.getInput1Type()
Gets the type information of the data type of the first input data set.
|
TypeInformation<IN2> |
TwoInputOperator.getInput2Type()
Gets the type information of the data type of the second input data set.
|
TypeInformation<IN> |
SingleInputOperator.getInputType()
Gets the type information of the data type of the input data set.
|
TypeInformation<OUT> |
Operator.getResultType()
Returns the type of the result of this operator.
|
TypeInformation<T> |
DataSink.getType() |
TypeInformation<WT> |
DeltaIterationResultSet.getWorksetType() |
Modifier and Type | Method and Description |
---|---|
O |
TwoInputUdfOperator.returns(TypeInformation<OUT> typeInfo)
Adds a type information hint about the return type of this operator.
|
O |
SingleInputUdfOperator.returns(TypeInformation<OUT> typeInfo)
Adds a type information hint about the return type of this operator.
|
Constructor and Description |
---|
CoGroupOperator(DataSet<I1> input1,
DataSet<I2> input2,
Keys<I1> keys1,
Keys<I2> keys2,
CoGroupFunction<I1,I2,OUT> function,
TypeInformation<OUT> returnType,
List<org.apache.commons.lang3.tuple.Pair<Integer,Order>> groupSortKeyOrderFirst,
List<org.apache.commons.lang3.tuple.Pair<Integer,Order>> groupSortKeyOrderSecond,
Partitioner<?> customPartitioner,
String defaultName) |
CoGroupOperator(DataSet<I1> input1,
DataSet<I2> input2,
Keys<I1> keys1,
Keys<I2> keys2,
CoGroupFunction<I1,I2,OUT> function,
TypeInformation<OUT> returnType,
Partitioner<?> customPartitioner,
String defaultName) |
CoGroupRawOperator(DataSet<I1> input1,
DataSet<I2> input2,
Keys<I1> keys1,
Keys<I2> keys2,
CoGroupFunction<I1,I2,OUT> function,
TypeInformation<OUT> returnType,
String defaultName) |
CrossOperator(DataSet<I1> input1,
DataSet<I2> input2,
CrossFunction<I1,I2,OUT> function,
TypeInformation<OUT> returnType,
CrossOperatorBase.CrossHint hint,
String defaultName) |
DataSink(DataSet<T> data,
OutputFormat<T> format,
TypeInformation<T> type) |
DataSource(ExecutionEnvironment context,
InputFormat<OUT,?> inputFormat,
TypeInformation<OUT> type,
String dataSourceLocationName)
Creates a new data source.
|
DeltaIteration(ExecutionEnvironment context,
TypeInformation<ST> type,
DataSet<ST> solutionSet,
DataSet<WT> workset,
Keys<ST> keys,
int maxIterations) |
EquiJoin(DataSet<I1> input1,
DataSet<I2> input2,
Keys<I1> keys1,
Keys<I2> keys2,
FlatJoinFunction<I1,I2,OUT> generatedFunction,
JoinFunction<I1,I2,OUT> function,
TypeInformation<OUT> returnType,
JoinOperatorBase.JoinHint hint,
String joinLocationName) |
EquiJoin(DataSet<I1> input1,
DataSet<I2> input2,
Keys<I1> keys1,
Keys<I2> keys2,
FlatJoinFunction<I1,I2,OUT> generatedFunction,
JoinFunction<I1,I2,OUT> function,
TypeInformation<OUT> returnType,
JoinOperatorBase.JoinHint hint,
String joinLocationName,
JoinType type) |
EquiJoin(DataSet<I1> input1,
DataSet<I2> input2,
Keys<I1> keys1,
Keys<I2> keys2,
FlatJoinFunction<I1,I2,OUT> function,
TypeInformation<OUT> returnType,
JoinOperatorBase.JoinHint hint,
String joinLocationName) |
EquiJoin(DataSet<I1> input1,
DataSet<I2> input2,
Keys<I1> keys1,
Keys<I2> keys2,
FlatJoinFunction<I1,I2,OUT> function,
TypeInformation<OUT> returnType,
JoinOperatorBase.JoinHint hint,
String joinLocationName,
JoinType type) |
FlatMapOperator(DataSet<IN> input,
TypeInformation<OUT> resultType,
FlatMapFunction<IN,OUT> function,
String defaultName) |
GroupCombineOperator(DataSet<IN> input,
TypeInformation<OUT> resultType,
GroupCombineFunction<IN,OUT> function,
String defaultName)
Constructor for a non-grouped reduce (all reduce).
|
GroupCombineOperator(Grouping<IN> input,
TypeInformation<OUT> resultType,
GroupCombineFunction<IN,OUT> function,
String defaultName)
Constructor for a grouped reduce.
|
GroupReduceOperator(DataSet<IN> input,
TypeInformation<OUT> resultType,
GroupReduceFunction<IN,OUT> function,
String defaultName)
Constructor for a non-grouped reduce (all reduce).
|
GroupReduceOperator(Grouping<IN> input,
TypeInformation<OUT> resultType,
GroupReduceFunction<IN,OUT> function,
String defaultName)
Constructor for a grouped reduce.
|
IterativeDataSet(ExecutionEnvironment context,
TypeInformation<T> type,
DataSet<T> input,
int maxIterations) |
JoinOperator(DataSet<I1> input1,
DataSet<I2> input2,
Keys<I1> keys1,
Keys<I2> keys2,
TypeInformation<OUT> returnType,
JoinOperatorBase.JoinHint hint,
JoinType type) |
MapOperator(DataSet<IN> input,
TypeInformation<OUT> resultType,
MapFunction<IN,OUT> function,
String defaultName) |
MapPartitionOperator(DataSet<IN> input,
TypeInformation<OUT> resultType,
MapPartitionFunction<IN,OUT> function,
String defaultName) |
NoOpOperator(DataSet<IN> input,
TypeInformation<IN> resultType) |
Operator(ExecutionEnvironment context,
TypeInformation<OUT> resultType) |
PartitionOperator(DataSet<T> input,
Keys<T> pKeys,
Partitioner<P> customPartitioner,
TypeInformation<P> partitionerTypeInfo,
String partitionLocationName) |
SingleInputOperator(DataSet<IN> input,
TypeInformation<OUT> resultType) |
SingleInputUdfOperator(DataSet<IN> input,
TypeInformation<OUT> resultType)
Creates a new operators with the given data set as input.
|
TwoInputOperator(DataSet<IN1> input1,
DataSet<IN2> input2,
TypeInformation<OUT> resultType) |
TwoInputUdfOperator(DataSet<IN1> input1,
DataSet<IN2> input2,
TypeInformation<OUT> resultType)
Creates a new operators with the two given data sets as inputs.
|
Modifier and Type | Class and Description |
---|---|
class |
EitherTypeInfo<L,R>
A
TypeInformation for the Either type of the Java API. |
class |
EnumTypeInfo<T extends Enum<T>>
A
TypeInformation for java enumeration types. |
class |
GenericTypeInfo<T> |
class |
ListTypeInfo<T>
A
TypeInformation for the list types of the Java API. |
class |
MapTypeInfo<K,V>
Special
TypeInformation used by MapStateDescriptor . |
class |
MissingTypeInfo
A special type information signifying that the type extraction failed.
|
class |
MultisetTypeInfo<T>
A
TypeInformation for the Multiset types of the Java API. |
class |
ObjectArrayTypeInfo<T,C> |
class |
PojoTypeInfo<T>
TypeInformation for "Java Beans"-style types.
|
class |
RowTypeInfo
TypeInformation for Row . |
class |
TupleTypeInfo<T extends Tuple>
A
TypeInformation for the tuple types of the Java API. |
class |
TupleTypeInfoBase<T> |
class |
ValueTypeInfo<T extends Value>
Type information for data types that extend the
Value interface. |
class |
WritableTypeInfo<T extends org.apache.hadoop.io.Writable>
Type information for data types that extend Hadoop's
Writable interface. |
Modifier and Type | Field and Description |
---|---|
protected TypeInformation<?>[] |
TupleTypeInfoBase.types |
Modifier and Type | Method and Description |
---|---|
protected <OUT,IN1,IN2> |
TypeExtractor.analyzePojo(Type type,
List<Type> typeHierarchy,
TypeInformation<IN1> in1Type,
TypeInformation<IN2> in2Type) |
abstract <T> TypeInformation<T> |
AvroUtils.createAvroTypeInfo(Class<T> type)
Creates an
AvroTypeInfo if flink-avro is present, otherwise throws an exception. |
static <T> TypeInformation<T> |
TypeExtractor.createHadoopWritableTypeInfo(Class<T> clazz) |
static <IN1,IN2,OUT> |
TypeExtractor.createTypeInfo(Class<?> baseClass,
Class<?> clazz,
int returnParamPos,
TypeInformation<IN1> in1Type,
TypeInformation<IN2> in2Type) |
static <T> TypeInformation<T> |
TypeExtractor.createTypeInfo(Class<T> type) |
static <OUT> TypeInformation<OUT> |
TypeExtractor.createTypeInfo(Object instance,
Class<?> baseClass,
Class<?> clazz,
int returnParamPos)
Creates a
TypeInformation from the given parameters. |
static TypeInformation<?> |
TypeExtractor.createTypeInfo(Type t) |
TypeInformation<Either<L,R>> |
EitherTypeInfoFactory.createTypeInfo(Type t,
Map<String,TypeInformation<?>> genericParameters) |
static <IN,ACC> TypeInformation<ACC> |
TypeExtractor.getAggregateFunctionAccumulatorType(AggregateFunction<IN,ACC,?> function,
TypeInformation<IN> inType,
String functionName,
boolean allowMissing) |
static <IN,OUT> TypeInformation<OUT> |
TypeExtractor.getAggregateFunctionReturnType(AggregateFunction<IN,?,OUT> function,
TypeInformation<IN> inType,
String functionName,
boolean allowMissing) |
static <IN1,IN2,OUT> |
TypeExtractor.getBinaryOperatorReturnType(Function function,
Class<?> baseClass,
int input1TypeArgumentIndex,
int input2TypeArgumentIndex,
int outputTypeArgumentIndex,
int[] lambdaOutputTypeArgumentIndices,
TypeInformation<IN1> in1Type,
TypeInformation<IN2> in2Type,
String functionName,
boolean allowMissing)
Returns the binary operator's return type.
|
static <IN1,IN2,OUT> |
TypeExtractor.getCoGroupReturnTypes(CoGroupFunction<IN1,IN2,OUT> coGroupInterface,
TypeInformation<IN1> in1Type,
TypeInformation<IN2> in2Type) |
static <IN1,IN2,OUT> |
TypeExtractor.getCoGroupReturnTypes(CoGroupFunction<IN1,IN2,OUT> coGroupInterface,
TypeInformation<IN1> in1Type,
TypeInformation<IN2> in2Type,
String functionName,
boolean allowMissing) |
TypeInformation<C> |
ObjectArrayTypeInfo.getComponentInfo() |
static <IN1,IN2,OUT> |
TypeExtractor.getCrossReturnTypes(CrossFunction<IN1,IN2,OUT> crossInterface,
TypeInformation<IN1> in1Type,
TypeInformation<IN2> in2Type) |
static <IN1,IN2,OUT> |
TypeExtractor.getCrossReturnTypes(CrossFunction<IN1,IN2,OUT> crossInterface,
TypeInformation<IN1> in1Type,
TypeInformation<IN2> in2Type,
String functionName,
boolean allowMissing) |
TypeInformation<T> |
ListTypeInfo.getElementTypeInfo()
Gets the type information for the elements contained in the list
|
TypeInformation<T> |
MultisetTypeInfo.getElementTypeInfo()
Gets the type information for the elements contained in the Multiset
|
TypeInformation<?>[] |
RowTypeInfo.getFieldTypes()
Returns the field types of the row.
|
static <IN1,IN2,OUT> |
TypeExtractor.getFlatJoinReturnTypes(FlatJoinFunction<IN1,IN2,OUT> joinInterface,
TypeInformation<IN1> in1Type,
TypeInformation<IN2> in2Type) |
static <IN1,IN2,OUT> |
TypeExtractor.getFlatJoinReturnTypes(FlatJoinFunction<IN1,IN2,OUT> joinInterface,
TypeInformation<IN1> in1Type,
TypeInformation<IN2> in2Type,
String functionName,
boolean allowMissing) |
static <IN,OUT> TypeInformation<OUT> |
TypeExtractor.getFlatMapReturnTypes(FlatMapFunction<IN,OUT> flatMapInterface,
TypeInformation<IN> inType) |
static <IN,OUT> TypeInformation<OUT> |
TypeExtractor.getFlatMapReturnTypes(FlatMapFunction<IN,OUT> flatMapInterface,
TypeInformation<IN> inType,
String functionName,
boolean allowMissing) |
static <X> TypeInformation<X> |
TypeExtractor.getForClass(Class<X> clazz)
Creates type information from a given Class such as Integer, String[] or POJOs.
|
static <X> TypeInformation<X> |
TypeExtractor.getForObject(X value) |
static <IN,OUT> TypeInformation<OUT> |
TypeExtractor.getGroupCombineReturnTypes(GroupCombineFunction<IN,OUT> combineInterface,
TypeInformation<IN> inType) |
static <IN,OUT> TypeInformation<OUT> |
TypeExtractor.getGroupCombineReturnTypes(GroupCombineFunction<IN,OUT> combineInterface,
TypeInformation<IN> inType,
String functionName,
boolean allowMissing) |
static <IN,OUT> TypeInformation<OUT> |
TypeExtractor.getGroupReduceReturnTypes(GroupReduceFunction<IN,OUT> groupReduceInterface,
TypeInformation<IN> inType) |
static <IN,OUT> TypeInformation<OUT> |
TypeExtractor.getGroupReduceReturnTypes(GroupReduceFunction<IN,OUT> groupReduceInterface,
TypeInformation<IN> inType,
String functionName,
boolean allowMissing) |
static <IN> TypeInformation<IN> |
TypeExtractor.getInputFormatTypes(InputFormat<IN,?> inputFormatInterface) |
static <IN1,IN2,OUT> |
TypeExtractor.getJoinReturnTypes(JoinFunction<IN1,IN2,OUT> joinInterface,
TypeInformation<IN1> in1Type,
TypeInformation<IN2> in2Type) |
static <IN1,IN2,OUT> |
TypeExtractor.getJoinReturnTypes(JoinFunction<IN1,IN2,OUT> joinInterface,
TypeInformation<IN1> in1Type,
TypeInformation<IN2> in2Type,
String functionName,
boolean allowMissing) |
static <IN,OUT> TypeInformation<OUT> |
TypeExtractor.getKeySelectorTypes(KeySelector<IN,OUT> selectorInterface,
TypeInformation<IN> inType) |
static <IN,OUT> TypeInformation<OUT> |
TypeExtractor.getKeySelectorTypes(KeySelector<IN,OUT> selectorInterface,
TypeInformation<IN> inType,
String functionName,
boolean allowMissing) |
TypeInformation<K> |
MapTypeInfo.getKeyTypeInfo()
Gets the type information for the keys in the map
|
TypeInformation<L> |
EitherTypeInfo.getLeftType() |
static <IN,OUT> TypeInformation<OUT> |
TypeExtractor.getMapPartitionReturnTypes(MapPartitionFunction<IN,OUT> mapPartitionInterface,
TypeInformation<IN> inType) |
static <IN,OUT> TypeInformation<OUT> |
TypeExtractor.getMapPartitionReturnTypes(MapPartitionFunction<IN,OUT> mapPartitionInterface,
TypeInformation<IN> inType,
String functionName,
boolean allowMissing) |
static <IN,OUT> TypeInformation<OUT> |
TypeExtractor.getMapReturnTypes(MapFunction<IN,OUT> mapInterface,
TypeInformation<IN> inType) |
static <IN,OUT> TypeInformation<OUT> |
TypeExtractor.getMapReturnTypes(MapFunction<IN,OUT> mapInterface,
TypeInformation<IN> inType,
String functionName,
boolean allowMissing) |
static <T> TypeInformation<T> |
TypeExtractor.getPartitionerTypes(Partitioner<T> partitioner) |
static <T> TypeInformation<T> |
TypeExtractor.getPartitionerTypes(Partitioner<T> partitioner,
String functionName,
boolean allowMissing) |
TypeInformation<T> |
ResultTypeQueryable.getProducedType()
Gets the data type (as a
TypeInformation ) produced by this function or input format. |
TypeInformation<R> |
EitherTypeInfo.getRightType() |
<X> TypeInformation<X> |
TupleTypeInfoBase.getTypeAt(int pos) |
<X> TypeInformation<X> |
PojoTypeInfo.getTypeAt(int pos) |
<X> TypeInformation<X> |
TupleTypeInfoBase.getTypeAt(String fieldExpression) |
<X> TypeInformation<X> |
RowTypeInfo.getTypeAt(String fieldExpression) |
<X> TypeInformation<X> |
PojoTypeInfo.getTypeAt(String fieldExpression) |
TypeInformation<?> |
PojoField.getTypeInformation() |
static <IN,OUT> TypeInformation<OUT> |
TypeExtractor.getUnaryOperatorReturnType(Function function,
Class<?> baseClass,
int inputTypeArgumentIndex,
int outputTypeArgumentIndex,
int[] lambdaOutputTypeArgumentIndices,
TypeInformation<IN> inType,
String functionName,
boolean allowMissing)
Returns the unary operator's return type.
|
TypeInformation<V> |
MapTypeInfo.getValueTypeInfo()
Gets the type information for the values in the map
|
Modifier and Type | Method and Description |
---|---|
Map<String,TypeInformation<?>> |
EitherTypeInfo.getGenericParameters() |
Map<String,TypeInformation<?>> |
TupleTypeInfo.getGenericParameters() |
Modifier and Type | Method and Description |
---|---|
protected <OUT,IN1,IN2> |
TypeExtractor.analyzePojo(Type type,
List<Type> typeHierarchy,
TypeInformation<IN1> in1Type,
TypeInformation<IN2> in2Type) |
protected <OUT,IN1,IN2> |
TypeExtractor.analyzePojo(Type type,
List<Type> typeHierarchy,
TypeInformation<IN1> in1Type,
TypeInformation<IN2> in2Type) |
static <IN1,IN2,OUT> |
TypeExtractor.createTypeInfo(Class<?> baseClass,
Class<?> clazz,
int returnParamPos,
TypeInformation<IN1> in1Type,
TypeInformation<IN2> in2Type) |
static <IN1,IN2,OUT> |
TypeExtractor.createTypeInfo(Class<?> baseClass,
Class<?> clazz,
int returnParamPos,
TypeInformation<IN1> in1Type,
TypeInformation<IN2> in2Type) |
static <IN,ACC> TypeInformation<ACC> |
TypeExtractor.getAggregateFunctionAccumulatorType(AggregateFunction<IN,ACC,?> function,
TypeInformation<IN> inType,
String functionName,
boolean allowMissing) |
static <IN,OUT> TypeInformation<OUT> |
TypeExtractor.getAggregateFunctionReturnType(AggregateFunction<IN,?,OUT> function,
TypeInformation<IN> inType,
String functionName,
boolean allowMissing) |
static <IN1,IN2,OUT> |
TypeExtractor.getBinaryOperatorReturnType(Function function,
Class<?> baseClass,
int input1TypeArgumentIndex,
int input2TypeArgumentIndex,
int outputTypeArgumentIndex,
int[] lambdaOutputTypeArgumentIndices,
TypeInformation<IN1> in1Type,
TypeInformation<IN2> in2Type,
String functionName,
boolean allowMissing)
Returns the binary operator's return type.
|
static <IN1,IN2,OUT> |
TypeExtractor.getBinaryOperatorReturnType(Function function,
Class<?> baseClass,
int input1TypeArgumentIndex,
int input2TypeArgumentIndex,
int outputTypeArgumentIndex,
int[] lambdaOutputTypeArgumentIndices,
TypeInformation<IN1> in1Type,
TypeInformation<IN2> in2Type,
String functionName,
boolean allowMissing)
Returns the binary operator's return type.
|
static <IN1,IN2,OUT> |
TypeExtractor.getCoGroupReturnTypes(CoGroupFunction<IN1,IN2,OUT> coGroupInterface,
TypeInformation<IN1> in1Type,
TypeInformation<IN2> in2Type) |
static <IN1,IN2,OUT> |
TypeExtractor.getCoGroupReturnTypes(CoGroupFunction<IN1,IN2,OUT> coGroupInterface,
TypeInformation<IN1> in1Type,
TypeInformation<IN2> in2Type) |
static <IN1,IN2,OUT> |
TypeExtractor.getCoGroupReturnTypes(CoGroupFunction<IN1,IN2,OUT> coGroupInterface,
TypeInformation<IN1> in1Type,
TypeInformation<IN2> in2Type,
String functionName,
boolean allowMissing) |
static <IN1,IN2,OUT> |
TypeExtractor.getCoGroupReturnTypes(CoGroupFunction<IN1,IN2,OUT> coGroupInterface,
TypeInformation<IN1> in1Type,
TypeInformation<IN2> in2Type,
String functionName,
boolean allowMissing) |
static <IN1,IN2,OUT> |
TypeExtractor.getCrossReturnTypes(CrossFunction<IN1,IN2,OUT> crossInterface,
TypeInformation<IN1> in1Type,
TypeInformation<IN2> in2Type) |
static <IN1,IN2,OUT> |
TypeExtractor.getCrossReturnTypes(CrossFunction<IN1,IN2,OUT> crossInterface,
TypeInformation<IN1> in1Type,
TypeInformation<IN2> in2Type) |
static <IN1,IN2,OUT> |
TypeExtractor.getCrossReturnTypes(CrossFunction<IN1,IN2,OUT> crossInterface,
TypeInformation<IN1> in1Type,
TypeInformation<IN2> in2Type,
String functionName,
boolean allowMissing) |
static <IN1,IN2,OUT> |
TypeExtractor.getCrossReturnTypes(CrossFunction<IN1,IN2,OUT> crossInterface,
TypeInformation<IN1> in1Type,
TypeInformation<IN2> in2Type,
String functionName,
boolean allowMissing) |
static <IN1,IN2,OUT> |
TypeExtractor.getFlatJoinReturnTypes(FlatJoinFunction<IN1,IN2,OUT> joinInterface,
TypeInformation<IN1> in1Type,
TypeInformation<IN2> in2Type) |
static <IN1,IN2,OUT> |
TypeExtractor.getFlatJoinReturnTypes(FlatJoinFunction<IN1,IN2,OUT> joinInterface,
TypeInformation<IN1> in1Type,
TypeInformation<IN2> in2Type) |
static <IN1,IN2,OUT> |
TypeExtractor.getFlatJoinReturnTypes(FlatJoinFunction<IN1,IN2,OUT> joinInterface,
TypeInformation<IN1> in1Type,
TypeInformation<IN2> in2Type,
String functionName,
boolean allowMissing) |
static <IN1,IN2,OUT> |
TypeExtractor.getFlatJoinReturnTypes(FlatJoinFunction<IN1,IN2,OUT> joinInterface,
TypeInformation<IN1> in1Type,
TypeInformation<IN2> in2Type,
String functionName,
boolean allowMissing) |
static <IN,OUT> TypeInformation<OUT> |
TypeExtractor.getFlatMapReturnTypes(FlatMapFunction<IN,OUT> flatMapInterface,
TypeInformation<IN> inType) |
static <IN,OUT> TypeInformation<OUT> |
TypeExtractor.getFlatMapReturnTypes(FlatMapFunction<IN,OUT> flatMapInterface,
TypeInformation<IN> inType,
String functionName,
boolean allowMissing) |
static <IN,OUT> TypeInformation<OUT> |
TypeExtractor.getGroupCombineReturnTypes(GroupCombineFunction<IN,OUT> combineInterface,
TypeInformation<IN> inType) |
static <IN,OUT> TypeInformation<OUT> |
TypeExtractor.getGroupCombineReturnTypes(GroupCombineFunction<IN,OUT> combineInterface,
TypeInformation<IN> inType,
String functionName,
boolean allowMissing) |
static <IN,OUT> TypeInformation<OUT> |
TypeExtractor.getGroupReduceReturnTypes(GroupReduceFunction<IN,OUT> groupReduceInterface,
TypeInformation<IN> inType) |
static <IN,OUT> TypeInformation<OUT> |
TypeExtractor.getGroupReduceReturnTypes(GroupReduceFunction<IN,OUT> groupReduceInterface,
TypeInformation<IN> inType,
String functionName,
boolean allowMissing) |
static <T,C> ObjectArrayTypeInfo<T,C> |
ObjectArrayTypeInfo.getInfoFor(Class<T> arrayClass,
TypeInformation<C> componentInfo) |
static <C> MultisetTypeInfo<C> |
MultisetTypeInfo.getInfoFor(TypeInformation<C> componentInfo) |
static <T,C> ObjectArrayTypeInfo<T,C> |
ObjectArrayTypeInfo.getInfoFor(TypeInformation<C> componentInfo)
Creates a new
ObjectArrayTypeInfo from a TypeInformation for the component type. |
static <IN1,IN2,OUT> |
TypeExtractor.getJoinReturnTypes(JoinFunction<IN1,IN2,OUT> joinInterface,
TypeInformation<IN1> in1Type,
TypeInformation<IN2> in2Type) |
static <IN1,IN2,OUT> |
TypeExtractor.getJoinReturnTypes(JoinFunction<IN1,IN2,OUT> joinInterface,
TypeInformation<IN1> in1Type,
TypeInformation<IN2> in2Type) |
static <IN1,IN2,OUT> |
TypeExtractor.getJoinReturnTypes(JoinFunction<IN1,IN2,OUT> joinInterface,
TypeInformation<IN1> in1Type,
TypeInformation<IN2> in2Type,
String functionName,
boolean allowMissing) |
static <IN1,IN2,OUT> |
TypeExtractor.getJoinReturnTypes(JoinFunction<IN1,IN2,OUT> joinInterface,
TypeInformation<IN1> in1Type,
TypeInformation<IN2> in2Type,
String functionName,
boolean allowMissing) |
static <IN,OUT> TypeInformation<OUT> |
TypeExtractor.getKeySelectorTypes(KeySelector<IN,OUT> selectorInterface,
TypeInformation<IN> inType) |
static <IN,OUT> TypeInformation<OUT> |
TypeExtractor.getKeySelectorTypes(KeySelector<IN,OUT> selectorInterface,
TypeInformation<IN> inType,
String functionName,
boolean allowMissing) |
static <IN,OUT> TypeInformation<OUT> |
TypeExtractor.getMapPartitionReturnTypes(MapPartitionFunction<IN,OUT> mapPartitionInterface,
TypeInformation<IN> inType) |
static <IN,OUT> TypeInformation<OUT> |
TypeExtractor.getMapPartitionReturnTypes(MapPartitionFunction<IN,OUT> mapPartitionInterface,
TypeInformation<IN> inType,
String functionName,
boolean allowMissing) |
static <IN,OUT> TypeInformation<OUT> |
TypeExtractor.getMapReturnTypes(MapFunction<IN,OUT> mapInterface,
TypeInformation<IN> inType) |
static <IN,OUT> TypeInformation<OUT> |
TypeExtractor.getMapReturnTypes(MapFunction<IN,OUT> mapInterface,
TypeInformation<IN> inType,
String functionName,
boolean allowMissing) |
static <IN,OUT> TypeInformation<OUT> |
TypeExtractor.getUnaryOperatorReturnType(Function function,
Class<?> baseClass,
int inputTypeArgumentIndex,
int outputTypeArgumentIndex,
int[] lambdaOutputTypeArgumentIndices,
TypeInformation<IN> inType,
String functionName,
boolean allowMissing)
Returns the unary operator's return type.
|
void |
InputTypeConfigurable.setInputType(TypeInformation<?> type,
ExecutionConfig executionConfig)
Method that is called on an
OutputFormat when it is
passed to the DataSet's output method. |
Modifier and Type | Method and Description |
---|---|
TypeInformation<Either<L,R>> |
EitherTypeInfoFactory.createTypeInfo(Type t,
Map<String,TypeInformation<?>> genericParameters) |
Constructor and Description |
---|
EitherTypeInfo(TypeInformation<L> leftType,
TypeInformation<R> rightType) |
EitherTypeInfo(TypeInformation<L> leftType,
TypeInformation<R> rightType) |
ListTypeInfo(TypeInformation<T> elementTypeInfo) |
MapTypeInfo(TypeInformation<K> keyTypeInfo,
TypeInformation<V> valueTypeInfo) |
MapTypeInfo(TypeInformation<K> keyTypeInfo,
TypeInformation<V> valueTypeInfo) |
MultisetTypeInfo(TypeInformation<T> elementTypeInfo) |
NamedFlatFieldDescriptor(String name,
int keyPosition,
TypeInformation<?> type) |
PojoField(Field field,
TypeInformation<?> type) |
RowTypeInfo(TypeInformation<?>... types) |
RowTypeInfo(TypeInformation<?>[] types,
String[] fieldNames) |
TupleTypeInfo(Class<T> tupleType,
TypeInformation<?>... types) |
TupleTypeInfo(TypeInformation<?>... types) |
TupleTypeInfoBase(Class<T> tupleType,
TypeInformation<?>... types) |
Modifier and Type | Method and Description |
---|---|
static void |
Serializers.recursivelyRegisterType(TypeInformation<?> typeInfo,
ExecutionConfig config,
Set<Class<?>> alreadySeen) |
Modifier and Type | Method and Description |
---|---|
void |
ScalaCsvOutputFormat.setInputType(TypeInformation<?> type,
ExecutionConfig executionConfig)
The purpose of this method is solely to check whether the data type to be processed is in
fact a tuple type.
|
Modifier and Type | Method and Description |
---|---|
<L,R> SingleOutputStreamOperator<R> |
PatternStream.flatSelect(OutputTag<L> timedOutPartialMatchesTag,
PatternFlatTimeoutFunction<T,L> patternFlatTimeoutFunction,
TypeInformation<R> outTypeInfo,
PatternFlatSelectFunction<T,R> patternFlatSelectFunction)
Applies a flat select function to the detected pattern sequence.
|
<R> SingleOutputStreamOperator<R> |
PatternStream.flatSelect(PatternFlatSelectFunction<T,R> patternFlatSelectFunction,
TypeInformation<R> outTypeInfo)
Applies a flat select function to the detected pattern sequence.
|
<R> SingleOutputStreamOperator<R> |
PatternStream.process(PatternProcessFunction<T,R> patternProcessFunction,
TypeInformation<R> outTypeInfo)
Applies a process function to the detected pattern sequence.
|
<L,R> SingleOutputStreamOperator<R> |
PatternStream.select(OutputTag<L> timedOutPartialMatchesTag,
PatternTimeoutFunction<T,L> patternTimeoutFunction,
TypeInformation<R> outTypeInfo,
PatternSelectFunction<T,R> patternSelectFunction)
Applies a select function to the detected pattern sequence.
|
<R> SingleOutputStreamOperator<R> |
PatternStream.select(PatternSelectFunction<T,R> patternSelectFunction,
TypeInformation<R> outTypeInfo)
Applies a select function to the detected pattern sequence.
|
Modifier and Type | Method and Description |
---|---|
TypeInformation<T> |
AbstractFileSource.getProducedType() |
Modifier and Type | Method and Description |
---|---|
TypeInformation<T> |
StreamFormatAdapter.getProducedType() |
TypeInformation<T> |
FileRecordFormatAdapter.getProducedType() |
Modifier and Type | Method and Description |
---|---|
abstract TypeInformation<T> |
SimpleStreamFormat.getProducedType()
Gets the type produced by this format.
|
TypeInformation<T> |
StreamFormat.getProducedType()
Gets the type produced by this format.
|
TypeInformation<T> |
FileRecordFormat.getProducedType()
Gets the type produced by this format.
|
TypeInformation<String> |
TextLineFormat.getProducedType() |
TypeInformation<T> |
BulkFormat.getProducedType()
Gets the type produced by this format.
|
Modifier and Type | Method and Description |
---|---|
TypeInformation<Row> |
HBaseLookupFunction.getResultType() |
TypeInformation<Row> |
AbstractHBaseTableSource.getReturnType() |
Modifier and Type | Method and Description |
---|---|
TypeInformation<?>[] |
HBaseTableSchema.getQualifierTypes(String family)
Returns the types of all registered column qualifiers of a specific column family.
|
Modifier and Type | Method and Description |
---|---|
Optional<TypeInformation<?>> |
HBaseTableSchema.getRowKeyTypeInfo()
Returns the optional type information of row key.
|
Modifier and Type | Method and Description |
---|---|
static int |
HBaseTypeUtils.getTypeIndex(TypeInformation typeInfo)
Gets the type index (type representation in HBase connector) from the
TypeInformation . |
Modifier and Type | Method and Description |
---|---|
TypeInformation<Row> |
HBaseUpsertTableSink.getRecordType() |
Modifier and Type | Method and Description |
---|---|
TableSink<Tuple2<Boolean,Row>> |
HBaseUpsertTableSink.configure(String[] fieldNames,
TypeInformation<?>[] fieldTypes) |
Modifier and Type | Method and Description |
---|---|
TypeInformation<Row> |
HBaseRowInputFormat.getProducedType() |
Modifier and Type | Method and Description |
---|---|
TypeInformation<Row> |
HBaseUpsertTableSink.getRecordType() |
Modifier and Type | Method and Description |
---|---|
TableSink<Tuple2<Boolean,Row>> |
HBaseUpsertTableSink.configure(String[] fieldNames,
TypeInformation<?>[] fieldTypes) |
Modifier and Type | Method and Description |
---|---|
TypeInformation<Row> |
HBaseRowInputFormat.getProducedType() |
Modifier and Type | Field and Description |
---|---|
protected TypeInformation[] |
JdbcLookupFunction.Builder.fieldTypes |
Modifier and Type | Method and Description |
---|---|
TypeInformation<?>[] |
JdbcUpsertTableSink.getFieldTypes() |
TypeInformation<Tuple2<Boolean,Row>> |
JdbcUpsertTableSink.getOutputType() |
TypeInformation<?>[] |
JdbcLookupFunction.getParameterTypes(Class<?>[] signature) |
TypeInformation<RowData> |
JdbcRowDataInputFormat.getProducedType() |
TypeInformation<Row> |
JdbcUpsertTableSink.getRecordType() |
TypeInformation<Row> |
JdbcLookupFunction.getResultType() |
Modifier and Type | Method and Description |
---|---|
TableSink<Tuple2<Boolean,Row>> |
JdbcUpsertTableSink.configure(String[] fieldNames,
TypeInformation<?>[] fieldTypes) |
JdbcLookupFunction.Builder |
JdbcLookupFunction.Builder.setFieldTypes(TypeInformation[] fieldTypes)
required, field types of this jdbc table.
|
JdbcDynamicOutputFormatBuilder |
JdbcDynamicOutputFormatBuilder.setRowDataTypeInfo(TypeInformation<RowData> rowDataTypeInfo) |
JdbcRowDataInputFormat.Builder |
JdbcRowDataInputFormat.Builder.setRowDataTypeInfo(TypeInformation<RowData> rowDataTypeInfo) |
Constructor and Description |
---|
JdbcLookupFunction(JdbcOptions options,
JdbcLookupOptions lookupOptions,
String[] fieldNames,
TypeInformation[] fieldTypes,
String[] keyNames) |
Modifier and Type | Method and Description |
---|---|
static String |
JdbcTypeUtil.getTypeName(TypeInformation<?> type) |
static int |
JdbcTypeUtil.typeInformationToSqlType(TypeInformation<?> type) |
Modifier and Type | Method and Description |
---|---|
TypeInformation<OUT> |
KafkaSource.getProducedType() |
Modifier and Type | Method and Description |
---|---|
TypeInformation<RowData> |
HiveBulkFormatAdapter.getProducedType() |
Modifier and Type | Method and Description |
---|---|
TypeInformation<T> |
AvroDeserializationSchema.getProducedType() |
TypeInformation<E> |
AvroInputFormat.getProducedType() |
TypeInformation<Row> |
AvroRowDeserializationSchema.getProducedType() |
TypeInformation<RowData> |
AvroRowDataDeserializationSchema.getProducedType() |
Constructor and Description |
---|
AvroRowDataDeserializationSchema(DeserializationSchema<org.apache.avro.generic.GenericRecord> nestedSchema,
AvroToRowDataConverters.AvroToRowDataConverter runtimeConverter,
TypeInformation<RowData> typeInfo)
Creates a Avro deserialization schema for the given logical type.
|
AvroRowDataDeserializationSchema(RowType rowType,
TypeInformation<RowData> typeInfo)
Creates a Avro deserialization schema for the given logical type.
|
Modifier and Type | Method and Description |
---|---|
TypeInformation<RowData> |
DebeziumAvroDeserializationSchema.getProducedType() |
Constructor and Description |
---|
DebeziumAvroDeserializationSchema(RowType rowType,
TypeInformation<RowData> producedTypeInfo,
String schemaRegistryUrl) |
DebeziumAvroDeserializationSchema(RowType rowType,
TypeInformation<RowData> producedTypeInfo,
String schemaRegistryUrl,
Map<String,?> registryConfigs) |
Modifier and Type | Class and Description |
---|---|
class |
AvroTypeInfo<T extends org.apache.avro.specific.SpecificRecordBase>
Special type information to generate a special AvroTypeInfo for Avro POJOs (implementing
SpecificRecordBase, the typed Avro POJOs)
|
class |
GenericRecordAvroTypeInfo
TypeInformation for
GenericRecord . |
Modifier and Type | Method and Description |
---|---|
static <T extends org.apache.avro.specific.SpecificRecord> |
AvroSchemaConverter.convertToTypeInfo(Class<T> avroClass)
Converts an Avro class into a nested row structure with deterministic field order and data
types that are compatible with Flink's Table & SQL API.
|
static <T> TypeInformation<T> |
AvroSchemaConverter.convertToTypeInfo(String avroSchemaString)
Converts an Avro schema string into a nested row structure with deterministic field order and
data types that are compatible with Flink's Table & SQL API.
|
Modifier and Type | Method and Description |
---|---|
<T> TypeInformation<T> |
AvroKryoSerializerUtils.createAvroTypeInfo(Class<T> type) |
Modifier and Type | Method and Description |
---|---|
TypeInformation<RowData> |
CsvRowDataDeserializationSchema.getProducedType() |
TypeInformation<Row> |
CsvRowDeserializationSchema.getProducedType() |
Modifier and Type | Method and Description |
---|---|
static RowCsvInputFormat.Builder |
RowCsvInputFormat.builder(TypeInformation<Row> typeInfo,
Path... filePaths)
Create a builder.
|
Constructor and Description |
---|
Builder(RowType rowType,
TypeInformation<RowData> resultTypeInfo)
Creates a CSV deserialization schema for the given
TypeInformation with optional
parameters. |
Builder(TypeInformation<Row> typeInfo)
Creates a
CsvRowSerializationSchema expecting the given TypeInformation . |
Builder(TypeInformation<Row> typeInfo)
Creates a CSV deserialization schema for the given
TypeInformation with optional
parameters. |
Modifier and Type | Method and Description |
---|---|
static <T> TypeInformation<T> |
JsonRowSchemaConverter.convert(String jsonSchema)
Converts a JSON schema into Flink's type information.
|
TypeInformation<Row> |
JsonRowDeserializationSchema.getProducedType() |
TypeInformation<RowData> |
JsonRowDataDeserializationSchema.getProducedType() |
Modifier and Type | Method and Description |
---|---|
JsonRowSerializationSchema.Builder |
JsonRowSerializationSchema.Builder.withTypeInfo(TypeInformation<Row> typeInfo)
Sets type information for JSON serialization schema.
|
Constructor and Description |
---|
Builder(TypeInformation<Row> typeInfo)
Creates a JSON deserialization schema for the given type information.
|
Builder(TypeInformation<Row> typeInfo)
Deprecated.
Use
JsonRowSerializationSchema.builder() instead. |
JsonRowDataDeserializationSchema(RowType rowType,
TypeInformation<RowData> resultTypeInfo,
boolean failOnMissingField,
boolean ignoreParseErrors,
TimestampFormat timestampFormat) |
JsonRowDeserializationSchema(TypeInformation<Row> typeInfo)
Deprecated.
Use the provided
JsonRowDeserializationSchema.Builder instead. |
Modifier and Type | Method and Description |
---|---|
TypeInformation<RowData> |
CanalJsonDeserializationSchema.getProducedType() |
Modifier and Type | Method and Description |
---|---|
static CanalJsonDeserializationSchema.Builder |
CanalJsonDeserializationSchema.builder(RowType rowType,
TypeInformation<RowData> resultTypeInfo)
Creates A builder for building a
CanalJsonDeserializationSchema . |
Modifier and Type | Method and Description |
---|---|
TypeInformation<RowData> |
DebeziumJsonDeserializationSchema.getProducedType() |
Constructor and Description |
---|
DebeziumJsonDeserializationSchema(DataType physicalDataType,
List<org.apache.flink.formats.json.debezium.DebeziumJsonDecodingFormat.ReadableMetadata> requestedMetadata,
TypeInformation<RowData> producedTypeInfo,
boolean schemaInclude,
boolean ignoreParseErrors,
TimestampFormat timestampFormat) |
Modifier and Type | Method and Description |
---|---|
TypeInformation<RowData> |
MaxwellJsonDeserializationSchema.getProducedType() |
Constructor and Description |
---|
MaxwellJsonDeserializationSchema(RowType rowType,
TypeInformation<RowData> resultTypeInfo,
boolean ignoreParseErrors,
TimestampFormat timestampFormatOption) |
Modifier and Type | Method and Description |
---|---|
protected TypeInformation[] |
ParquetInputFormat.getFieldTypes()
Get field types of read result.
|
TypeInformation<Row> |
ParquetRowInputFormat.getProducedType() |
TypeInformation<RowData> |
ParquetColumnarRowInputFormat.getProducedType() |
TypeInformation<Row> |
ParquetTableSource.getReturnType() |
Modifier and Type | Method and Description |
---|---|
static TypeInformation<?> |
ParquetSchemaConverter.convertFields(List<org.apache.parquet.schema.Type> parquetFields) |
static TypeInformation<?> |
ParquetSchemaConverter.convertParquetTypeToTypeInfo(org.apache.parquet.schema.Type fieldType) |
static TypeInformation<?> |
ParquetSchemaConverter.fromParquetType(org.apache.parquet.schema.MessageType type)
Converts Parquet schema to Flink Internal Type.
|
Modifier and Type | Method and Description |
---|---|
static org.apache.parquet.schema.MessageType |
ParquetSchemaConverter.toParquetType(TypeInformation<?> typeInformation,
boolean legacyMode)
Converts Flink Internal Type to Parquet schema.
|
Constructor and Description |
---|
RowConverter(org.apache.parquet.schema.GroupType schema,
TypeInformation<?> typeInfo,
ParentDataHolder parent,
int pos) |
RowConverter(org.apache.parquet.schema.MessageType messageType,
TypeInformation<?> typeInfo) |
RowMaterializer(org.apache.parquet.schema.MessageType messageType,
TypeInformation<?> rowTypeInfo) |
Modifier and Type | Method and Description |
---|---|
<T> DataSet<T> |
Graph.groupReduceOnEdges(EdgesFunction<K,EV,T> edgesFunction,
EdgeDirection direction,
TypeInformation<T> typeInfo)
Groups by vertex and computes a GroupReduce transformation over the edge values of each
vertex.
|
<T> DataSet<T> |
Graph.groupReduceOnEdges(EdgesFunctionWithVertexValue<K,VV,EV,T> edgesFunction,
EdgeDirection direction,
TypeInformation<T> typeInfo)
Groups by vertex and computes a GroupReduce transformation over the edge values of each
vertex.
|
<T> DataSet<T> |
Graph.groupReduceOnNeighbors(NeighborsFunction<K,VV,EV,T> neighborsFunction,
EdgeDirection direction,
TypeInformation<T> typeInfo)
Groups by vertex and computes a GroupReduce transformation over the neighbors (both edges and
vertices) of each vertex.
|
<T> DataSet<T> |
Graph.groupReduceOnNeighbors(NeighborsFunctionWithVertexValue<K,VV,EV,T> neighborsFunction,
EdgeDirection direction,
TypeInformation<T> typeInfo)
Groups by vertex and computes a GroupReduce transformation over the neighbors (both edges and
vertices) of each vertex.
|
<NV> Graph<K,VV,NV> |
Graph.mapEdges(MapFunction<Edge<K,EV>,NV> mapper,
TypeInformation<Edge<K,NV>> returnType)
Apply a function to the attribute of each edge in the graph.
|
<NV> Graph<K,NV,EV> |
Graph.mapVertices(MapFunction<Vertex<K,VV>,NV> mapper,
TypeInformation<Vertex<K,NV>> returnType)
Apply a function to the attribute of each vertex in the graph.
|
Modifier and Type | Class and Description |
---|---|
static class |
LongValueWithProperHashCode.LongValueWithProperHashCodeTypeInfo
A
TypeInformation for the LongValueWithProperHashCode type. |
Modifier and Type | Method and Description |
---|---|
TypeInformation<LongValueWithProperHashCode> |
LongValueWithProperHashCode.LongValueWithProperHashCodeTypeInfoFactory.createTypeInfo(Type t,
Map<String,TypeInformation<?>> genericParameters) |
Modifier and Type | Method and Description |
---|---|
Map<String,TypeInformation<?>> |
LongValueWithProperHashCode.LongValueWithProperHashCodeTypeInfo.getGenericParameters() |
Modifier and Type | Method and Description |
---|---|
TypeInformation<LongValueWithProperHashCode> |
LongValueWithProperHashCode.LongValueWithProperHashCodeTypeInfoFactory.createTypeInfo(Type t,
Map<String,TypeInformation<?>> genericParameters) |
Modifier and Type | Method and Description |
---|---|
TypeInformation<VV> |
LabelPropagation.SendNewLabelToNeighbors.getProducedType() |
TypeInformation<VV> |
ConnectedComponents.CCMessenger.getProducedType() |
Constructor and Description |
---|
CCMessenger(TypeInformation<VV> typeInformation) |
SendNewLabelToNeighbors(TypeInformation<VV> typeInformation) |
Modifier and Type | Class and Description |
---|---|
class |
ValueArrayTypeInfo<T>
A
TypeInformation for the ValueArray type. |
Modifier and Type | Method and Description |
---|---|
TypeInformation<ValueArray<T>> |
ValueArrayTypeInfoFactory.createTypeInfo(Type t,
Map<String,TypeInformation<?>> genericParameters) |
Modifier and Type | Method and Description |
---|---|
Map<String,TypeInformation<?>> |
ValueArrayTypeInfo.getGenericParameters() |
Modifier and Type | Method and Description |
---|---|
TypeInformation<ValueArray<T>> |
ValueArrayTypeInfoFactory.createTypeInfo(Type t,
Map<String,TypeInformation<?>> genericParameters) |
Constructor and Description |
---|
ValueArrayTypeInfo(TypeInformation<T> valueType) |
Modifier and Type | Method and Description |
---|---|
TypeInformation<O> |
GraphUtils.MapTo.getProducedType() |
Modifier and Type | Method and Description |
---|---|
TypeInformation<Tuple2<KEYOUT,VALUEOUT>> |
HadoopMapFunction.getProducedType() |
TypeInformation<Tuple2<KEYOUT,VALUEOUT>> |
HadoopReduceFunction.getProducedType() |
TypeInformation<Tuple2<KEYOUT,VALUEOUT>> |
HadoopReduceCombineFunction.getProducedType() |
Modifier and Type | Method and Description |
---|---|
TypeInformation<T> |
HCatInputFormatBase.getProducedType() |
Modifier and Type | Field and Description |
---|---|
static TypeInformation<DenseVector> |
VectorTypes.DENSE_VECTOR
DenseVector type information. |
static TypeInformation<SparseVector> |
VectorTypes.SPARSE_VECTOR
SparseVector type information. |
static TypeInformation<Vector> |
VectorTypes.VECTOR
Vector type information. |
Modifier and Type | Method and Description |
---|---|
static TypeInformation<?> |
TableUtil.findColType(TableSchema tableSchema,
String targetCol)
Find the type of the
targetCol . |
static TypeInformation<?>[] |
TableUtil.findColTypes(TableSchema tableSchema,
String[] targetCols)
Find the types of the
targetCols . |
Modifier and Type | Method and Description |
---|---|
static boolean |
TableUtil.isString(TypeInformation<?> dataType)
Determine whether it is a string type.
|
static boolean |
TableUtil.isSupportedNumericType(TypeInformation<?> dataType)
Determine whether it is number type, number type includes double, long, byte, int, float and
short.
|
static boolean |
TableUtil.isVector(TypeInformation<?> dataType)
Determine whether it is a vector type.
|
static Table |
DataSetConversionUtil.toTable(Long sessionId,
DataSet<Row> data,
String[] colNames,
TypeInformation<?>[] colTypes)
Convert the given DataSet into a Table with specified colNames and colTypes.
|
static Table |
DataStreamConversionUtil.toTable(Long sessionId,
DataStream<Row> data,
String[] colNames,
TypeInformation<?>[] colTypes)
Convert the given DataStream to Table with specified colNames and colTypes.
|
static Table |
DataSetConversionUtil.toTable(MLEnvironment session,
DataSet<Row> data,
String[] colNames,
TypeInformation<?>[] colTypes)
Convert the given DataSet into a Table with specified colNames and colTypes.
|
static Table |
DataStreamConversionUtil.toTable(MLEnvironment session,
DataStream<Row> data,
String[] colNames,
TypeInformation<?>[] colTypes)
Convert the given DataStream to Table with specified colNames and colTypes.
|
Constructor and Description |
---|
OutputColsHelper(TableSchema inputSchema,
String[] outputColNames,
TypeInformation<?>[] outputColTypes) |
OutputColsHelper(TableSchema inputSchema,
String[] outputColNames,
TypeInformation<?>[] outputColTypes,
String[] reservedColNames)
The constructor.
|
OutputColsHelper(TableSchema inputSchema,
String outputColName,
TypeInformation<?> outputColType) |
OutputColsHelper(TableSchema inputSchema,
String outputColName,
TypeInformation<?> outputColType,
String[] reservedColNames) |
Modifier and Type | Method and Description |
---|---|
TypeInformation<?>[] |
AlgoOperator.getColTypes()
Returns the column types of the output table.
|
TypeInformation<?>[] |
AlgoOperator.getSideOutputColTypes(int index)
Get the column types of the specified side-output table.
|
Constructor and Description |
---|
NoOpBinaryUdfOp(TypeInformation<OUT> type) |
Modifier and Type | Method and Description |
---|---|
TypeInformation<Row> |
OrcRowInputFormat.getProducedType() |
TypeInformation<RowData> |
OrcColumnarRowFileInputFormat.getProducedType() |
abstract TypeInformation<T> |
AbstractOrcFileInputFormat.getProducedType()
Gets the type produced by this format.
|
TypeInformation<Row> |
OrcTableSource.getReturnType() |
Modifier and Type | Class and Description |
---|---|
class |
VoidNamespaceTypeInfo
|
Modifier and Type | Method and Description |
---|---|
<K,S extends State,V> |
QueryableStateClient.getKvState(JobID jobId,
String queryableStateName,
K key,
TypeInformation<K> keyTypeInfo,
StateDescriptor<S,V> stateDescriptor)
Returns a future holding the request result.
|
Modifier and Type | Method and Description |
---|---|
TypeInformation<Row> |
StreamSQLTestProgram.Generator.getProducedType() |
TypeInformation |
StreamSQLTestProgram.KillMapper.getProducedType() |
TypeInformation<Row> |
StreamSQLTestProgram.GeneratorTableSource.getReturnType() |
Modifier and Type | Method and Description |
---|---|
<ACC,R> BootstrapTransformation<T> |
WindowedOperatorTransformation.aggregate(AggregateFunction<T,ACC,R> function,
TypeInformation<ACC> accumulatorType)
Applies the given aggregation function to each window.
|
<ACC,V,R> BootstrapTransformation<T> |
WindowedOperatorTransformation.aggregate(AggregateFunction<T,ACC,V> aggregateFunction,
ProcessWindowFunction<V,R,K,W> windowFunction,
TypeInformation<ACC> accumulatorType)
Applies the given window function to each window.
|
<ACC,V,R> BootstrapTransformation<T> |
WindowedOperatorTransformation.aggregate(AggregateFunction<T,ACC,V> aggregateFunction,
WindowFunction<V,R,K,W> windowFunction,
TypeInformation<ACC> accumulatorType)
Applies the given window function to each window.
|
<K,T,ACC,R> |
WindowReader.aggregate(String uid,
AggregateFunction<T,ACC,R> aggregateFunction,
TypeInformation<K> keyType,
TypeInformation<ACC> accType,
TypeInformation<R> outputType)
Reads window state generated using an
AggregateFunction . |
<K,T,ACC,R> |
WindowReader.aggregate(String uid,
AggregateFunction<T,ACC,R> aggregateFunction,
TypeInformation<K> keyType,
TypeInformation<ACC> accType,
TypeInformation<R> outputType)
Reads window state generated using an
AggregateFunction . |
<K,T,ACC,R> |
WindowReader.aggregate(String uid,
AggregateFunction<T,ACC,R> aggregateFunction,
TypeInformation<K> keyType,
TypeInformation<ACC> accType,
TypeInformation<R> outputType)
Reads window state generated using an
AggregateFunction . |
<K,T,ACC,R> |
EvictingWindowReader.aggregate(String uid,
AggregateFunction<T,ACC,R> aggregateFunction,
TypeInformation<K> keyType,
TypeInformation<T> inputType,
TypeInformation<R> outputType)
Reads window state generated using an
AggregateFunction . |
<K,T,ACC,R> |
EvictingWindowReader.aggregate(String uid,
AggregateFunction<T,ACC,R> aggregateFunction,
TypeInformation<K> keyType,
TypeInformation<T> inputType,
TypeInformation<R> outputType)
Reads window state generated using an
AggregateFunction . |
<K,T,ACC,R> |
EvictingWindowReader.aggregate(String uid,
AggregateFunction<T,ACC,R> aggregateFunction,
TypeInformation<K> keyType,
TypeInformation<T> inputType,
TypeInformation<R> outputType)
Reads window state generated using an
AggregateFunction . |
<K,T,ACC,R,OUT> |
WindowReader.aggregate(String uid,
AggregateFunction<T,ACC,R> aggregateFunction,
WindowReaderFunction<R,OUT,K,W> readerFunction,
TypeInformation<K> keyType,
TypeInformation<ACC> accType,
TypeInformation<OUT> outputType)
Reads window state generated using an
AggregateFunction . |
<K,T,ACC,R,OUT> |
WindowReader.aggregate(String uid,
AggregateFunction<T,ACC,R> aggregateFunction,
WindowReaderFunction<R,OUT,K,W> readerFunction,
TypeInformation<K> keyType,
TypeInformation<ACC> accType,
TypeInformation<OUT> outputType)
Reads window state generated using an
AggregateFunction . |
<K,T,ACC,R,OUT> |
WindowReader.aggregate(String uid,
AggregateFunction<T,ACC,R> aggregateFunction,
WindowReaderFunction<R,OUT,K,W> readerFunction,
TypeInformation<K> keyType,
TypeInformation<ACC> accType,
TypeInformation<OUT> outputType)
Reads window state generated using an
AggregateFunction . |
<K,T,ACC,R,OUT> |
EvictingWindowReader.aggregate(String uid,
AggregateFunction<T,ACC,R> aggregateFunction,
WindowReaderFunction<R,OUT,K,W> readerFunction,
TypeInformation<K> keyType,
TypeInformation<T> inputType,
TypeInformation<OUT> outputType)
Reads window state generated using an
AggregateFunction . |
<K,T,ACC,R,OUT> |
EvictingWindowReader.aggregate(String uid,
AggregateFunction<T,ACC,R> aggregateFunction,
WindowReaderFunction<R,OUT,K,W> readerFunction,
TypeInformation<K> keyType,
TypeInformation<T> inputType,
TypeInformation<OUT> outputType)
Reads window state generated using an
AggregateFunction . |
<K,T,ACC,R,OUT> |
EvictingWindowReader.aggregate(String uid,
AggregateFunction<T,ACC,R> aggregateFunction,
WindowReaderFunction<R,OUT,K,W> readerFunction,
TypeInformation<K> keyType,
TypeInformation<T> inputType,
TypeInformation<OUT> outputType)
Reads window state generated using an
AggregateFunction . |
<R> BootstrapTransformation<T> |
WindowedOperatorTransformation.apply(WindowFunction<T,R,K,W> function,
TypeInformation<R> resultType)
Applies the given window function to each window.
|
<K> KeyedOperatorTransformation<K,T> |
OneInputOperatorTransformation.keyBy(KeySelector<T,K> keySelector,
TypeInformation<K> keyType)
It creates a new
KeyedOperatorTransformation that uses the provided key with explicit
type information for partitioning its operator states. |
<K,T,OUT> DataSet<OUT> |
EvictingWindowReader.process(String uid,
WindowReaderFunction<T,OUT,K,W> readerFunction,
TypeInformation<K> keyType,
TypeInformation<T> stateType,
TypeInformation<OUT> outputType)
Reads window state generated without any preaggregation such as
WindowedStream#apply
and WindowedStream#process . |
<K,T,OUT> DataSet<OUT> |
EvictingWindowReader.process(String uid,
WindowReaderFunction<T,OUT,K,W> readerFunction,
TypeInformation<K> keyType,
TypeInformation<T> stateType,
TypeInformation<OUT> outputType)
Reads window state generated without any preaggregation such as
WindowedStream#apply
and WindowedStream#process . |
<K,T,OUT> DataSet<OUT> |
EvictingWindowReader.process(String uid,
WindowReaderFunction<T,OUT,K,W> readerFunction,
TypeInformation<K> keyType,
TypeInformation<T> stateType,
TypeInformation<OUT> outputType)
Reads window state generated without any preaggregation such as
WindowedStream#apply
and WindowedStream#process . |
<K,T,OUT> DataSet<OUT> |
WindowReader.process(String uid,
WindowReaderFunction<T,OUT,K,W> readerFunction,
TypeInformation<K> keyType,
TypeInformation<T> stateType,
TypeInformation<OUT> outputType)
Reads window state generated without any preaggregation such as
WindowedStream#apply
and WindowedStream#process . |
<K,T,OUT> DataSet<OUT> |
WindowReader.process(String uid,
WindowReaderFunction<T,OUT,K,W> readerFunction,
TypeInformation<K> keyType,
TypeInformation<T> stateType,
TypeInformation<OUT> outputType)
Reads window state generated without any preaggregation such as
WindowedStream#apply
and WindowedStream#process . |
<K,T,OUT> DataSet<OUT> |
WindowReader.process(String uid,
WindowReaderFunction<T,OUT,K,W> readerFunction,
TypeInformation<K> keyType,
TypeInformation<T> stateType,
TypeInformation<OUT> outputType)
Reads window state generated without any preaggregation such as
WindowedStream#apply
and WindowedStream#process . |
<K,V> DataSet<Tuple2<K,V>> |
ExistingSavepoint.readBroadcastState(String uid,
String name,
TypeInformation<K> keyTypeInfo,
TypeInformation<V> valueTypeInfo)
Read operator
BroadcastState from a Savepoint . |
<K,V> DataSet<Tuple2<K,V>> |
ExistingSavepoint.readBroadcastState(String uid,
String name,
TypeInformation<K> keyTypeInfo,
TypeInformation<V> valueTypeInfo)
Read operator
BroadcastState from a Savepoint . |
<K,V> DataSet<Tuple2<K,V>> |
ExistingSavepoint.readBroadcastState(String uid,
String name,
TypeInformation<K> keyTypeInfo,
TypeInformation<V> valueTypeInfo,
TypeSerializer<K> keySerializer,
TypeSerializer<V> valueSerializer)
Read operator
BroadcastState from a Savepoint when a custom serializer was
used; e.g., a different serializer than the one returned by TypeInformation#createSerializer . |
<K,V> DataSet<Tuple2<K,V>> |
ExistingSavepoint.readBroadcastState(String uid,
String name,
TypeInformation<K> keyTypeInfo,
TypeInformation<V> valueTypeInfo,
TypeSerializer<K> keySerializer,
TypeSerializer<V> valueSerializer)
Read operator
BroadcastState from a Savepoint when a custom serializer was
used; e.g., a different serializer than the one returned by TypeInformation#createSerializer . |
<K,OUT> DataSet<OUT> |
ExistingSavepoint.readKeyedState(String uid,
KeyedStateReaderFunction<K,OUT> function,
TypeInformation<K> keyTypeInfo,
TypeInformation<OUT> outTypeInfo)
Read keyed state from an operator in a
Savepoint . |
<K,OUT> DataSet<OUT> |
ExistingSavepoint.readKeyedState(String uid,
KeyedStateReaderFunction<K,OUT> function,
TypeInformation<K> keyTypeInfo,
TypeInformation<OUT> outTypeInfo)
Read keyed state from an operator in a
Savepoint . |
<T> DataSet<T> |
ExistingSavepoint.readListState(String uid,
String name,
TypeInformation<T> typeInfo)
Read operator
ListState from a Savepoint . |
<T> DataSet<T> |
ExistingSavepoint.readListState(String uid,
String name,
TypeInformation<T> typeInfo,
TypeSerializer<T> serializer)
Read operator
ListState from a Savepoint when a custom serializer was used;
e.g., a different serializer than the one returned by TypeInformation#createSerializer . |
<T> DataSet<T> |
ExistingSavepoint.readUnionState(String uid,
String name,
TypeInformation<T> typeInfo)
Read operator
UnionState from a Savepoint . |
<T> DataSet<T> |
ExistingSavepoint.readUnionState(String uid,
String name,
TypeInformation<T> typeInfo,
TypeSerializer<T> serializer)
Read operator
UnionState from a Savepoint when a custom serializer was used;
e.g., a different serializer than the one returned by TypeInformation#createSerializer . |
<T,K> DataSet<T> |
EvictingWindowReader.reduce(String uid,
ReduceFunction<T> function,
TypeInformation<K> keyType,
TypeInformation<T> reduceType)
Reads window state generated using a
ReduceFunction . |
<T,K> DataSet<T> |
EvictingWindowReader.reduce(String uid,
ReduceFunction<T> function,
TypeInformation<K> keyType,
TypeInformation<T> reduceType)
Reads window state generated using a
ReduceFunction . |
<T,K> DataSet<T> |
WindowReader.reduce(String uid,
ReduceFunction<T> function,
TypeInformation<K> keyType,
TypeInformation<T> reduceType)
Reads window state generated using a
ReduceFunction . |
<T,K> DataSet<T> |
WindowReader.reduce(String uid,
ReduceFunction<T> function,
TypeInformation<K> keyType,
TypeInformation<T> reduceType)
Reads window state generated using a
ReduceFunction . |
<K,T,OUT> DataSet<OUT> |
EvictingWindowReader.reduce(String uid,
ReduceFunction<T> function,
WindowReaderFunction<T,OUT,K,W> readerFunction,
TypeInformation<K> keyType,
TypeInformation<T> reduceType,
TypeInformation<OUT> outputType)
Reads window state generated using a
ReduceFunction . |
<K,T,OUT> DataSet<OUT> |
EvictingWindowReader.reduce(String uid,
ReduceFunction<T> function,
WindowReaderFunction<T,OUT,K,W> readerFunction,
TypeInformation<K> keyType,
TypeInformation<T> reduceType,
TypeInformation<OUT> outputType)
Reads window state generated using a
ReduceFunction . |
<K,T,OUT> DataSet<OUT> |
EvictingWindowReader.reduce(String uid,
ReduceFunction<T> function,
WindowReaderFunction<T,OUT,K,W> readerFunction,
TypeInformation<K> keyType,
TypeInformation<T> reduceType,
TypeInformation<OUT> outputType)
Reads window state generated using a
ReduceFunction . |
<K,T,OUT> DataSet<OUT> |
WindowReader.reduce(String uid,
ReduceFunction<T> function,
WindowReaderFunction<T,OUT,K,W> readerFunction,
TypeInformation<K> keyType,
TypeInformation<T> reduceType,
TypeInformation<OUT> outputType)
Reads window state generated using a
ReduceFunction . |
<K,T,OUT> DataSet<OUT> |
WindowReader.reduce(String uid,
ReduceFunction<T> function,
WindowReaderFunction<T,OUT,K,W> readerFunction,
TypeInformation<K> keyType,
TypeInformation<T> reduceType,
TypeInformation<OUT> outputType)
Reads window state generated using a
ReduceFunction . |
<K,T,OUT> DataSet<OUT> |
WindowReader.reduce(String uid,
ReduceFunction<T> function,
WindowReaderFunction<T,OUT,K,W> readerFunction,
TypeInformation<K> keyType,
TypeInformation<T> reduceType,
TypeInformation<OUT> outputType)
Reads window state generated using a
ReduceFunction . |
Modifier and Type | Method and Description |
---|---|
TypeInformation<KEY> |
StateReaderOperator.getKeyType() |
Modifier and Type | Method and Description |
---|---|
static <KEY,T,ACC,R,OUT,W extends Window> |
WindowReaderOperator.aggregate(AggregateFunction<T,ACC,R> function,
WindowReaderFunction<R,OUT,KEY,W> readerFunction,
TypeInformation<KEY> keyType,
TypeSerializer<W> windowSerializer,
TypeInformation<ACC> accumulatorType) |
static <KEY,T,ACC,R,OUT,W extends Window> |
WindowReaderOperator.aggregate(AggregateFunction<T,ACC,R> function,
WindowReaderFunction<R,OUT,KEY,W> readerFunction,
TypeInformation<KEY> keyType,
TypeSerializer<W> windowSerializer,
TypeInformation<ACC> accumulatorType) |
static <KEY,T,W extends Window,OUT> |
WindowReaderOperator.evictingWindow(WindowReaderFunction<StreamRecord<T>,OUT,KEY,W> readerFunction,
TypeInformation<KEY> keyType,
TypeSerializer<W> windowSerializer,
TypeInformation<T> stateType,
ExecutionConfig config) |
static <KEY,T,W extends Window,OUT> |
WindowReaderOperator.evictingWindow(WindowReaderFunction<StreamRecord<T>,OUT,KEY,W> readerFunction,
TypeInformation<KEY> keyType,
TypeSerializer<W> windowSerializer,
TypeInformation<T> stateType,
ExecutionConfig config) |
static <KEY,T,W extends Window,OUT> |
WindowReaderOperator.process(WindowReaderFunction<T,OUT,KEY,W> readerFunction,
TypeInformation<KEY> keyType,
TypeSerializer<W> windowSerializer,
TypeInformation<T> stateType) |
static <KEY,T,W extends Window,OUT> |
WindowReaderOperator.process(WindowReaderFunction<T,OUT,KEY,W> readerFunction,
TypeInformation<KEY> keyType,
TypeSerializer<W> windowSerializer,
TypeInformation<T> stateType) |
static <KEY,T,W extends Window,OUT> |
WindowReaderOperator.reduce(ReduceFunction<T> function,
WindowReaderFunction<T,OUT,KEY,W> reader,
TypeInformation<KEY> keyType,
TypeSerializer<W> windowSerializer,
TypeInformation<T> inputType) |
static <KEY,T,W extends Window,OUT> |
WindowReaderOperator.reduce(ReduceFunction<T> function,
WindowReaderFunction<T,OUT,KEY,W> reader,
TypeInformation<KEY> keyType,
TypeSerializer<W> windowSerializer,
TypeInformation<T> inputType) |
Constructor and Description |
---|
KeyedStateReaderOperator(KeyedStateReaderFunction<KEY,OUT> function,
TypeInformation<KEY> keyType) |
StateReaderOperator(F function,
TypeInformation<KEY> keyType,
TypeSerializer<N> namespaceSerializer) |
Modifier and Type | Method and Description |
---|---|
static TypeInformation<?>[] |
StreamProjection.extractFieldTypes(int[] fields,
TypeInformation<?> inType) |
TypeInformation<T> |
WindowedStream.getInputType() |
TypeInformation<T> |
AllWindowedStream.getInputType() |
TypeInformation<KEY> |
KeyedStream.getKeyType()
Gets the type of the key by which the stream is partitioned.
|
TypeInformation<T> |
BroadcastStream.getType() |
TypeInformation<T> |
DataStream.getType()
Gets the type of the stream.
|
TypeInformation<IN1> |
ConnectedStreams.getType1()
Gets the type of the first input.
|
TypeInformation<IN1> |
BroadcastConnectedStream.getType1()
Gets the type of the first input.
|
TypeInformation<IN2> |
ConnectedStreams.getType2()
Gets the type of the second input.
|
TypeInformation<IN2> |
BroadcastConnectedStream.getType2()
Gets the type of the second input.
|
Modifier and Type | Method and Description |
---|---|
<ACC,R> SingleOutputStreamOperator<R> |
WindowedStream.aggregate(AggregateFunction<T,ACC,R> function,
TypeInformation<ACC> accumulatorType,
TypeInformation<R> resultType)
Applies the given aggregation function to each window.
|
<ACC,R> SingleOutputStreamOperator<R> |
WindowedStream.aggregate(AggregateFunction<T,ACC,R> function,
TypeInformation<ACC> accumulatorType,
TypeInformation<R> resultType)
Applies the given aggregation function to each window.
|
<ACC,R> SingleOutputStreamOperator<R> |
AllWindowedStream.aggregate(AggregateFunction<T,ACC,R> function,
TypeInformation<ACC> accumulatorType,
TypeInformation<R> resultType)
Applies the given
AggregateFunction to each window. |
<ACC,R> SingleOutputStreamOperator<R> |
AllWindowedStream.aggregate(AggregateFunction<T,ACC,R> function,
TypeInformation<ACC> accumulatorType,
TypeInformation<R> resultType)
Applies the given
AggregateFunction to each window. |
<ACC,V,R> SingleOutputStreamOperator<R> |
AllWindowedStream.aggregate(AggregateFunction<T,ACC,V> aggregateFunction,
AllWindowFunction<V,R,W> windowFunction,
TypeInformation<ACC> accumulatorType,
TypeInformation<R> resultType)
Applies the given window function to each window.
|
<ACC,V,R> SingleOutputStreamOperator<R> |
AllWindowedStream.aggregate(AggregateFunction<T,ACC,V> aggregateFunction,
AllWindowFunction<V,R,W> windowFunction,
TypeInformation<ACC> accumulatorType,
TypeInformation<R> resultType)
Applies the given window function to each window.
|
<ACC,V,R> SingleOutputStreamOperator<R> |
AllWindowedStream.aggregate(AggregateFunction<T,ACC,V> aggregateFunction,
ProcessAllWindowFunction<V,R,W> windowFunction,
TypeInformation<ACC> accumulatorType,
TypeInformation<V> aggregateResultType,
TypeInformation<R> resultType)
Applies the given window function to each window.
|
<ACC,V,R> SingleOutputStreamOperator<R> |
AllWindowedStream.aggregate(AggregateFunction<T,ACC,V> aggregateFunction,
ProcessAllWindowFunction<V,R,W> windowFunction,
TypeInformation<ACC> accumulatorType,
TypeInformation<V> aggregateResultType,
TypeInformation<R> resultType)
Applies the given window function to each window.
|
<ACC,V,R> SingleOutputStreamOperator<R> |
AllWindowedStream.aggregate(AggregateFunction<T,ACC,V> aggregateFunction,
ProcessAllWindowFunction<V,R,W> windowFunction,
TypeInformation<ACC> accumulatorType,
TypeInformation<V> aggregateResultType,
TypeInformation<R> resultType)
Applies the given window function to each window.
|
<ACC,V,R> SingleOutputStreamOperator<R> |
WindowedStream.aggregate(AggregateFunction<T,ACC,V> aggregateFunction,
ProcessWindowFunction<V,R,K,W> windowFunction,
TypeInformation<ACC> accumulatorType,
TypeInformation<V> aggregateResultType,
TypeInformation<R> resultType)
Applies the given window function to each window.
|
<ACC,V,R> SingleOutputStreamOperator<R> |
WindowedStream.aggregate(AggregateFunction<T,ACC,V> aggregateFunction,
ProcessWindowFunction<V,R,K,W> windowFunction,
TypeInformation<ACC> accumulatorType,
TypeInformation<V> aggregateResultType,
TypeInformation<R> resultType)
Applies the given window function to each window.
|
<ACC,V,R> SingleOutputStreamOperator<R> |
WindowedStream.aggregate(AggregateFunction<T,ACC,V> aggregateFunction,
ProcessWindowFunction<V,R,K,W> windowFunction,
TypeInformation<ACC> accumulatorType,
TypeInformation<V> aggregateResultType,
TypeInformation<R> resultType)
Applies the given window function to each window.
|
<ACC,V,R> SingleOutputStreamOperator<R> |
WindowedStream.aggregate(AggregateFunction<T,ACC,V> aggregateFunction,
WindowFunction<V,R,K,W> windowFunction,
TypeInformation<ACC> accumulatorType,
TypeInformation<R> resultType)
Applies the given window function to each window.
|
<ACC,V,R> SingleOutputStreamOperator<R> |
WindowedStream.aggregate(AggregateFunction<T,ACC,V> aggregateFunction,
WindowFunction<V,R,K,W> windowFunction,
TypeInformation<ACC> accumulatorType,
TypeInformation<R> resultType)
Applies the given window function to each window.
|
<R> SingleOutputStreamOperator<R> |
AllWindowedStream.apply(AllWindowFunction<T,R,W> function,
TypeInformation<R> resultType)
Applies the given window function to each window.
|
<T> DataStream<T> |
CoGroupedStreams.WithWindow.apply(CoGroupFunction<T1,T2,T> function,
TypeInformation<T> resultType)
Completes the co-group operation with the user function that is executed for windowed
groups.
|
<T> DataStream<T> |
JoinedStreams.WithWindow.apply(FlatJoinFunction<T1,T2,T> function,
TypeInformation<T> resultType)
Completes the join operation with the user function that is executed for each combination
of elements with the same key in a window.
|
<T> DataStream<T> |
JoinedStreams.WithWindow.apply(JoinFunction<T1,T2,T> function,
TypeInformation<T> resultType)
Completes the join operation with the user function that is executed for each combination
of elements with the same key in a window.
|
<R> SingleOutputStreamOperator<R> |
AllWindowedStream.apply(ReduceFunction<T> reduceFunction,
AllWindowFunction<T,R,W> function,
TypeInformation<R> resultType)
Deprecated.
|
<R> SingleOutputStreamOperator<R> |
WindowedStream.apply(ReduceFunction<T> reduceFunction,
WindowFunction<T,R,K,W> function,
TypeInformation<R> resultType)
Deprecated.
|
<R> SingleOutputStreamOperator<R> |
WindowedStream.apply(WindowFunction<T,R,K,W> function,
TypeInformation<R> resultType)
Applies the given window function to each window.
|
protected <R> SingleOutputStreamOperator<R> |
KeyedStream.doTransform(String operatorName,
TypeInformation<R> outTypeInfo,
StreamOperatorFactory<R> operatorFactory) |
protected <R> SingleOutputStreamOperator<R> |
DataStream.doTransform(String operatorName,
TypeInformation<R> outTypeInfo,
StreamOperatorFactory<R> operatorFactory) |
CoGroupedStreams.Where.EqualTo |
CoGroupedStreams.Where.equalTo(KeySelector<T2,KEY> keySelector,
TypeInformation<KEY> keyType)
Specifies a
KeySelector for elements from the second input with explicit type
information for the key type. |
JoinedStreams.Where.EqualTo |
JoinedStreams.Where.equalTo(KeySelector<T2,KEY> keySelector,
TypeInformation<KEY> keyType)
Specifies a
KeySelector for elements from the second input with explicit type
information for the key type. |
static TypeInformation<?>[] |
StreamProjection.extractFieldTypes(int[] fields,
TypeInformation<?> inType) |
<R> SingleOutputStreamOperator<R> |
ConnectedStreams.flatMap(CoFlatMapFunction<IN1,IN2,R> coFlatMapper,
TypeInformation<R> outputType)
Applies a CoFlatMap transformation on a
ConnectedStreams and maps the output to a
common type. |
<R> SingleOutputStreamOperator<R> |
DataStream.flatMap(FlatMapFunction<T,R> flatMapper,
TypeInformation<R> outputType)
Applies a FlatMap transformation on a
DataStream . |
<KEY> ConnectedStreams<I,F> |
IterativeStream.ConnectedIterativeStreams.keyBy(KeySelector<I,KEY> keySelector1,
KeySelector<F,KEY> keySelector2,
TypeInformation<KEY> keyType) |
<KEY> ConnectedStreams<IN1,IN2> |
ConnectedStreams.keyBy(KeySelector<IN1,KEY> keySelector1,
KeySelector<IN2,KEY> keySelector2,
TypeInformation<KEY> keyType)
KeyBy operation for connected data stream.
|
<K> KeyedStream<T,K> |
DataStream.keyBy(KeySelector<T,K> key,
TypeInformation<K> keyType)
It creates a new
KeyedStream that uses the provided key with explicit type
information for partitioning its operator states. |
<R> SingleOutputStreamOperator<R> |
ConnectedStreams.map(CoMapFunction<IN1,IN2,R> coMapper,
TypeInformation<R> outputType)
Applies a CoMap transformation on a
ConnectedStreams and maps the output to a common
type. |
<R> SingleOutputStreamOperator<R> |
DataStream.map(MapFunction<T,R> mapper,
TypeInformation<R> outputType)
Applies a Map transformation on a
DataStream . |
<OUT> SingleOutputStreamOperator<OUT> |
BroadcastConnectedStream.process(BroadcastProcessFunction<IN1,IN2,OUT> function,
TypeInformation<OUT> outTypeInfo)
Assumes as inputs a
BroadcastStream and a non-keyed DataStream and applies
the given BroadcastProcessFunction on them, thereby creating a transformed output
stream. |
<R> SingleOutputStreamOperator<R> |
ConnectedStreams.process(CoProcessFunction<IN1,IN2,R> coProcessFunction,
TypeInformation<R> outputType)
Applies the given
CoProcessFunction on the connected input streams, thereby creating
a transformed output stream. |
<KEY,OUT> SingleOutputStreamOperator<OUT> |
BroadcastConnectedStream.process(KeyedBroadcastProcessFunction<KEY,IN1,IN2,OUT> function,
TypeInformation<OUT> outTypeInfo)
Assumes as inputs a
BroadcastStream and a KeyedStream and applies the given
KeyedBroadcastProcessFunction on them, thereby creating a transformed output stream. |
<K,R> SingleOutputStreamOperator<R> |
ConnectedStreams.process(KeyedCoProcessFunction<K,IN1,IN2,R> keyedCoProcessFunction,
TypeInformation<R> outputType)
Applies the given
KeyedCoProcessFunction on the connected input streams, thereby
creating a transformed output stream. |
<R> SingleOutputStreamOperator<R> |
KeyedStream.process(KeyedProcessFunction<KEY,T,R> keyedProcessFunction,
TypeInformation<R> outputType)
Applies the given
KeyedProcessFunction on the input stream, thereby creating a
transformed output stream. |
<R> SingleOutputStreamOperator<R> |
AllWindowedStream.process(ProcessAllWindowFunction<T,R,W> function,
TypeInformation<R> resultType)
Applies the given window function to each window.
|
<R> SingleOutputStreamOperator<R> |
KeyedStream.process(ProcessFunction<T,R> processFunction,
TypeInformation<R> outputType)
Deprecated.
|
<R> SingleOutputStreamOperator<R> |
DataStream.process(ProcessFunction<T,R> processFunction,
TypeInformation<R> outputType)
Applies the given
ProcessFunction on the input stream, thereby creating a transformed
output stream. |
<OUT> SingleOutputStreamOperator<OUT> |
KeyedStream.IntervalJoined.process(ProcessJoinFunction<IN1,IN2,OUT> processJoinFunction,
TypeInformation<OUT> outputType)
Completes the join operation with the given user function that is executed for each
joined pair of elements.
|
<R> SingleOutputStreamOperator<R> |
WindowedStream.process(ProcessWindowFunction<T,R,K,W> function,
TypeInformation<R> resultType)
Applies the given window function to each window.
|
<R> SingleOutputStreamOperator<R> |
AllWindowedStream.reduce(ReduceFunction<T> reduceFunction,
AllWindowFunction<T,R,W> function,
TypeInformation<R> resultType)
Applies the given window function to each window.
|
<R> SingleOutputStreamOperator<R> |
AllWindowedStream.reduce(ReduceFunction<T> reduceFunction,
ProcessAllWindowFunction<T,R,W> function,
TypeInformation<R> resultType)
Applies the given window function to each window.
|
<R> SingleOutputStreamOperator<R> |
WindowedStream.reduce(ReduceFunction<T> reduceFunction,
ProcessWindowFunction<T,R,K,W> function,
TypeInformation<R> resultType)
Applies the given window function to each window.
|
<R> SingleOutputStreamOperator<R> |
WindowedStream.reduce(ReduceFunction<T> reduceFunction,
WindowFunction<T,R,K,W> function,
TypeInformation<R> resultType)
Applies the given window function to each window.
|
static <T,K> KeyedStream<T,K> |
DataStreamUtils.reinterpretAsKeyedStream(DataStream<T> stream,
KeySelector<T,K> keySelector,
TypeInformation<K> typeInfo)
|
SingleOutputStreamOperator<T> |
SingleOutputStreamOperator.returns(TypeInformation<T> typeInfo)
Adds a type information hint about the return type of this operator.
|
<R> SingleOutputStreamOperator<R> |
DataStream.transform(String operatorName,
TypeInformation<R> outTypeInfo,
OneInputStreamOperator<T,R> operator)
Method for passing user defined operators along with the type information that will transform
the DataStream.
|
<R> SingleOutputStreamOperator<R> |
DataStream.transform(String operatorName,
TypeInformation<R> outTypeInfo,
OneInputStreamOperatorFactory<T,R> operatorFactory)
Method for passing user defined operators created by the given factory along with the type
information that will transform the DataStream.
|
<R> SingleOutputStreamOperator<R> |
ConnectedStreams.transform(String functionName,
TypeInformation<R> outTypeInfo,
TwoInputStreamOperator<IN1,IN2,R> operator) |
<KEY> CoGroupedStreams.Where<KEY> |
CoGroupedStreams.where(KeySelector<T1,KEY> keySelector,
TypeInformation<KEY> keyType)
Specifies a
KeySelector for elements from the first input with explicit type
information. |
<KEY> JoinedStreams.Where<KEY> |
JoinedStreams.where(KeySelector<T1,KEY> keySelector,
TypeInformation<KEY> keyType)
Specifies a
KeySelector for elements from the first input with explicit type
information for the key type. |
<T> SingleOutputStreamOperator<T> |
CoGroupedStreams.WithWindow.with(CoGroupFunction<T1,T2,T> function,
TypeInformation<T> resultType)
Deprecated.
This method will be removed once the
CoGroupedStreams.WithWindow.apply(CoGroupFunction,
TypeInformation) method is fixed in the next major version of Flink (2.0). |
<T> SingleOutputStreamOperator<T> |
JoinedStreams.WithWindow.with(FlatJoinFunction<T1,T2,T> function,
TypeInformation<T> resultType)
Deprecated.
This method will be replaced by
JoinedStreams.WithWindow.apply(FlatJoinFunction,
TypeInformation) in Flink 2.0. So use the JoinedStreams.WithWindow.apply(FlatJoinFunction,
TypeInformation) in the future. |
<T> SingleOutputStreamOperator<T> |
JoinedStreams.WithWindow.with(JoinFunction<T1,T2,T> function,
TypeInformation<T> resultType)
Deprecated.
This method will be removed once the
JoinedStreams.WithWindow.apply(JoinFunction,
TypeInformation) method is fixed in the next major version of Flink (2.0). |
<F> IterativeStream.ConnectedIterativeStreams<T,F> |
IterativeStream.withFeedbackType(TypeInformation<F> feedbackType)
Changes the feedback type of the iteration and allows the user to apply co-transformations on
the input and feedback stream, as in a
ConnectedStreams . |
Constructor and Description |
---|
ConnectedIterativeStreams(DataStream<I> input,
TypeInformation<F> feedbackType,
long waitTime) |
DataStreamSource(StreamExecutionEnvironment environment,
Source<T,?,?> source,
WatermarkStrategy<T> watermarkStrategy,
TypeInformation<T> outTypeInfo,
String sourceName)
Constructor for new Sources (FLIP-27).
|
DataStreamSource(StreamExecutionEnvironment environment,
TypeInformation<T> outTypeInfo,
StreamSource<T,?> operator,
boolean isParallel,
String sourceName) |
DataStreamSource(StreamExecutionEnvironment environment,
TypeInformation<T> outTypeInfo,
StreamSource<T,?> operator,
boolean isParallel,
String sourceName,
Boundedness boundedness)
The constructor used to create legacy sources.
|
KeyedStream(DataStream<T> dataStream,
KeySelector<T,KEY> keySelector,
TypeInformation<KEY> keyType)
Creates a new
KeyedStream using the given KeySelector to partition operator
state by key. |
WithWindow(DataStream<T1> input1,
DataStream<T2> input2,
KeySelector<T1,KEY> keySelector1,
KeySelector<T2,KEY> keySelector2,
TypeInformation<KEY> keyType,
WindowAssigner<? super CoGroupedStreams.TaggedUnion<T1,T2>,W> windowAssigner,
Trigger<? super CoGroupedStreams.TaggedUnion<T1,T2>,? super W> trigger,
Evictor<? super CoGroupedStreams.TaggedUnion<T1,T2>,? super W> evictor,
Time allowedLateness) |
WithWindow(DataStream<T1> input1,
DataStream<T2> input2,
KeySelector<T1,KEY> keySelector1,
KeySelector<T2,KEY> keySelector2,
TypeInformation<KEY> keyType,
WindowAssigner<? super CoGroupedStreams.TaggedUnion<T1,T2>,W> windowAssigner,
Trigger<? super CoGroupedStreams.TaggedUnion<T1,T2>,? super W> trigger,
Evictor<? super CoGroupedStreams.TaggedUnion<T1,T2>,? super W> evictor,
Time allowedLateness) |
Modifier and Type | Method and Description |
---|---|
<OUT> DataStreamSource<OUT> |
StreamExecutionEnvironment.addSource(SourceFunction<OUT> function,
String sourceName,
TypeInformation<OUT> typeInfo)
Ads a data source with a custom type information thus opening a
DataStream . |
<OUT> DataStreamSource<OUT> |
StreamExecutionEnvironment.addSource(SourceFunction<OUT> function,
TypeInformation<OUT> typeInfo)
Ads a data source with a custom type information thus opening a
DataStream . |
<OUT> DataStreamSource<OUT> |
StreamExecutionEnvironment.createInput(InputFormat<OUT,?> inputFormat,
TypeInformation<OUT> typeInfo)
Generic method to create an input data stream with
InputFormat . |
<OUT> DataStreamSource<OUT> |
StreamExecutionEnvironment.fromCollection(Collection<OUT> data,
TypeInformation<OUT> typeInfo)
Creates a data stream from the given non-empty collection.
|
<OUT> DataStreamSource<OUT> |
StreamExecutionEnvironment.fromCollection(Iterator<OUT> data,
TypeInformation<OUT> typeInfo)
Creates a data stream from the given iterator.
|
<OUT> DataStreamSource<OUT> |
StreamExecutionEnvironment.fromParallelCollection(SplittableIterator<OUT> iterator,
TypeInformation<OUT> typeInfo)
Creates a new data stream that contains elements in the iterator.
|
<OUT> DataStreamSource<OUT> |
StreamExecutionEnvironment.fromSource(Source<OUT,?,?> source,
WatermarkStrategy<OUT> timestampsAndWatermarks,
String sourceName,
TypeInformation<OUT> typeInfo)
Adds a data
Source to the environment to get a DataStream . |
<OUT> DataStreamSource<OUT> |
StreamExecutionEnvironment.readFile(FileInputFormat<OUT> inputFormat,
String filePath,
FileProcessingMode watchType,
long interval,
TypeInformation<OUT> typeInformation)
Reads the contents of the user-specified
filePath based on the given FileInputFormat . |
Constructor and Description |
---|
ComparableAggregator(int positionToAggregate,
TypeInformation<T> typeInfo,
AggregationFunction.AggregationType aggregationType,
boolean first,
ExecutionConfig config) |
ComparableAggregator(int positionToAggregate,
TypeInformation<T> typeInfo,
AggregationFunction.AggregationType aggregationType,
ExecutionConfig config) |
ComparableAggregator(String field,
TypeInformation<T> typeInfo,
AggregationFunction.AggregationType aggregationType,
boolean first,
ExecutionConfig config) |
SumAggregator(int pos,
TypeInformation<T> typeInfo,
ExecutionConfig config) |
SumAggregator(String field,
TypeInformation<T> typeInfo,
ExecutionConfig config) |
Modifier and Type | Method and Description |
---|---|
void |
OutputFormatSinkFunction.setInputType(TypeInformation<?> type,
ExecutionConfig executionConfig)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
void |
ContinuousFileReaderOperator.setOutputType(TypeInformation<OUT> outTypeInfo,
ExecutionConfig executionConfig) |
void |
ContinuousFileReaderOperatorFactory.setOutputType(TypeInformation<OUT> type,
ExecutionConfig executionConfig) |
Constructor and Description |
---|
ContinuousFileReaderOperatorFactory(InputFormat<OUT,? super T> inputFormat,
TypeInformation<OUT> type,
ExecutionConfig executionConfig) |
InputFormatSourceFunction(InputFormat<OUT,?> format,
TypeInformation<OUT> typeInfo) |
MessageAcknowledgingSourceBase(TypeInformation<UId> idTypeInfo)
Creates a new MessageAcknowledgingSourceBase for IDs of the given type.
|
MultipleIdsMessageAcknowledgingSourceBase(TypeInformation<UId> idTypeInfo)
Creates a new MessageAcknowledgingSourceBase for IDs of the given type.
|
Modifier and Type | Method and Description |
---|---|
<IN1,IN2,OUT> |
StreamGraph.addCoOperator(Integer vertexID,
String slotSharingGroup,
String coLocationGroup,
StreamOperatorFactory<OUT> taskOperatorFactory,
TypeInformation<IN1> in1TypeInfo,
TypeInformation<IN2> in2TypeInfo,
TypeInformation<OUT> outTypeInfo,
String operatorName) |
<IN1,IN2,OUT> |
StreamGraph.addCoOperator(Integer vertexID,
String slotSharingGroup,
String coLocationGroup,
StreamOperatorFactory<OUT> taskOperatorFactory,
TypeInformation<IN1> in1TypeInfo,
TypeInformation<IN2> in2TypeInfo,
TypeInformation<OUT> outTypeInfo,
String operatorName) |
<IN1,IN2,OUT> |
StreamGraph.addCoOperator(Integer vertexID,
String slotSharingGroup,
String coLocationGroup,
StreamOperatorFactory<OUT> taskOperatorFactory,
TypeInformation<IN1> in1TypeInfo,
TypeInformation<IN2> in2TypeInfo,
TypeInformation<OUT> outTypeInfo,
String operatorName) |
<IN,OUT> void |
StreamGraph.addLegacySource(Integer vertexID,
String slotSharingGroup,
String coLocationGroup,
StreamOperatorFactory<OUT> operatorFactory,
TypeInformation<IN> inTypeInfo,
TypeInformation<OUT> outTypeInfo,
String operatorName) |
<IN,OUT> void |
StreamGraph.addLegacySource(Integer vertexID,
String slotSharingGroup,
String coLocationGroup,
StreamOperatorFactory<OUT> operatorFactory,
TypeInformation<IN> inTypeInfo,
TypeInformation<OUT> outTypeInfo,
String operatorName) |
<OUT> void |
StreamGraph.addMultipleInputOperator(Integer vertexID,
String slotSharingGroup,
String coLocationGroup,
StreamOperatorFactory<OUT> operatorFactory,
List<TypeInformation<?>> inTypeInfos,
TypeInformation<OUT> outTypeInfo,
String operatorName) |
<IN,OUT> void |
StreamGraph.addOperator(Integer vertexID,
String slotSharingGroup,
String coLocationGroup,
StreamOperatorFactory<OUT> operatorFactory,
TypeInformation<IN> inTypeInfo,
TypeInformation<OUT> outTypeInfo,
String operatorName) |
<IN,OUT> void |
StreamGraph.addOperator(Integer vertexID,
String slotSharingGroup,
String coLocationGroup,
StreamOperatorFactory<OUT> operatorFactory,
TypeInformation<IN> inTypeInfo,
TypeInformation<OUT> outTypeInfo,
String operatorName) |
<IN,OUT> void |
StreamGraph.addSink(Integer vertexID,
String slotSharingGroup,
String coLocationGroup,
StreamOperatorFactory<OUT> operatorFactory,
TypeInformation<IN> inTypeInfo,
TypeInformation<OUT> outTypeInfo,
String operatorName) |
<IN,OUT> void |
StreamGraph.addSink(Integer vertexID,
String slotSharingGroup,
String coLocationGroup,
StreamOperatorFactory<OUT> operatorFactory,
TypeInformation<IN> inTypeInfo,
TypeInformation<OUT> outTypeInfo,
String operatorName) |
<IN,OUT> void |
StreamGraph.addSource(Integer vertexID,
String slotSharingGroup,
String coLocationGroup,
SourceOperatorFactory<OUT> operatorFactory,
TypeInformation<IN> inTypeInfo,
TypeInformation<OUT> outTypeInfo,
String operatorName) |
<IN,OUT> void |
StreamGraph.addSource(Integer vertexID,
String slotSharingGroup,
String coLocationGroup,
SourceOperatorFactory<OUT> operatorFactory,
TypeInformation<IN> inTypeInfo,
TypeInformation<OUT> outTypeInfo,
String operatorName) |
<OUT> void |
StreamGraph.setOutType(Integer vertexID,
TypeInformation<OUT> outType) |
Modifier and Type | Method and Description |
---|---|
<OUT> void |
StreamGraph.addMultipleInputOperator(Integer vertexID,
String slotSharingGroup,
String coLocationGroup,
StreamOperatorFactory<OUT> operatorFactory,
List<TypeInformation<?>> inTypeInfos,
TypeInformation<OUT> outTypeInfo,
String operatorName) |
Modifier and Type | Method and Description |
---|---|
TypeInformation<OUT> |
PythonKeyedProcessOperator.getProducedType() |
Constructor and Description |
---|
BeamDataStreamPythonFunctionRunner(String taskName,
PythonEnvironmentManager environmentManager,
TypeInformation inputType,
TypeInformation outputType,
String functionUrn,
FlinkFnApi.UserDefinedDataStreamFunction userDefinedDataStreamFunction,
String coderUrn,
Map<String,String> jobOptions,
FlinkMetricContainer flinkMetricContainer,
KeyedStateBackend stateBackend,
TypeSerializer keySerializer,
MemoryManager memoryManager,
double managedMemoryFraction) |
BeamDataStreamPythonFunctionRunner(String taskName,
PythonEnvironmentManager environmentManager,
TypeInformation inputType,
TypeInformation outputType,
String functionUrn,
FlinkFnApi.UserDefinedDataStreamFunction userDefinedDataStreamFunction,
String coderUrn,
Map<String,String> jobOptions,
FlinkMetricContainer flinkMetricContainer,
KeyedStateBackend stateBackend,
TypeSerializer keySerializer,
MemoryManager memoryManager,
double managedMemoryFraction) |
Modifier and Type | Field and Description |
---|---|
protected TypeInformation<?> |
KeyedMultipleInputTransformation.stateKeyType |
Modifier and Type | Method and Description |
---|---|
TypeInformation<IN> |
ReduceTransformation.getInputType()
Returns the
TypeInformation for the elements of the input. |
TypeInformation<IN> |
TimestampsAndWatermarksTransformation.getInputType()
Returns the
TypeInformation for the elements of the input. |
TypeInformation<IN> |
OneInputTransformation.getInputType()
Returns the
TypeInformation for the elements of the input. |
TypeInformation<IN1> |
TwoInputTransformation.getInputType1()
Returns the
TypeInformation for the elements from the first input. |
TypeInformation<IN2> |
TwoInputTransformation.getInputType2()
Returns the
TypeInformation for the elements from the second input. |
TypeInformation<K> |
ReduceTransformation.getKeyTypeInfo() |
TypeInformation<?> |
KeyedMultipleInputTransformation.getStateKeyType() |
TypeInformation<?> |
TwoInputTransformation.getStateKeyType() |
TypeInformation<?> |
OneInputTransformation.getStateKeyType() |
TypeInformation<?> |
LegacySinkTransformation.getStateKeyType() |
TypeInformation<KEY> |
KeyedBroadcastStateTransformation.getStateKeyType() |
Modifier and Type | Method and Description |
---|---|
List<TypeInformation<?>> |
AbstractMultipleInputTransformation.getInputTypes()
Returns the
TypeInformation for the elements from the inputs. |
Modifier and Type | Method and Description |
---|---|
void |
TwoInputTransformation.setStateKeyType(TypeInformation<?> stateKeyType) |
void |
OneInputTransformation.
|