Modifier and Type | Class and Description |
---|---|
class |
TableInputFormat<T extends Tuple>
Deprecated.
please use
HBaseInputFormat . |
Modifier and Type | Method and Description |
---|---|
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)
|
Modifier and Type | Method and Description |
---|---|
<OUT extends Tuple> |
DataSet.project(int... fieldIndexes)
|
Modifier and Type | Class and Description |
---|---|
class |
SelectByMaxFunction<T extends Tuple>
Function that enables selection by maximal value of a field.
|
class |
SelectByMinFunction<T extends Tuple>
Function that enables selection by minimal value of a field.
|
Modifier and Type | Class and Description |
---|---|
class |
CsvOutputFormat<T extends Tuple>
This is an OutputFormat to serialize
Tuple s to text. |
Modifier and Type | Method and Description |
---|---|
<T extends Tuple> |
CsvReader.tupleType(Class<T> targetType)
Configures the reader to read the CSV data and parse it to the given type.
|
Modifier and Type | Class and Description |
---|---|
static class |
CrossOperator.ProjectCross<I1,I2,OUT extends Tuple>
|
static class |
CrossOperator.ProjectCrossFunction<T1,T2,R extends Tuple> |
static class |
JoinOperator.ProjectJoin<I1,I2,OUT extends Tuple>
|
class |
ProjectOperator<IN,OUT extends Tuple>
This operator represents the application of a projection operation on a data set, and the result
data set produced by the function.
|
Modifier and Type | Method and Description |
---|---|
<OUT extends Tuple> |
JoinOperator.DefaultJoin.projectFirst(int... firstFieldIndexes)
Applies a ProjectJoin transformation and projects the first join input
|
<OUT extends Tuple> |
JoinOperator.ProjectJoin.projectFirst(int... firstFieldIndexes)
Continues a ProjectJoin transformation and adds fields of the first join input to the
projection.
|
<OUT extends Tuple> |
CrossOperator.DefaultCross.projectFirst(int... firstFieldIndexes)
Initiates a ProjectCross transformation and projects the first cross input.
|
<OUT extends Tuple> |
CrossOperator.ProjectCross.projectFirst(int... firstFieldIndexes)
Continues a ProjectCross transformation and adds fields of the first cross input to the
projection.
|
<OUT extends Tuple> |
JoinOperator.DefaultJoin.projectSecond(int... secondFieldIndexes)
Applies a ProjectJoin transformation and projects the second join input
|
<OUT extends Tuple> |
JoinOperator.ProjectJoin.projectSecond(int... secondFieldIndexes)
Continues a ProjectJoin transformation and adds fields of the second join input to the
projection.
|
<OUT extends Tuple> |
CrossOperator.DefaultCross.projectSecond(int... secondFieldIndexes)
Initiates a ProjectCross transformation and projects the second cross input.
|
<OUT extends Tuple> |
CrossOperator.ProjectCross.projectSecond(int... secondFieldIndexes)
Continues a ProjectCross transformation and adds fields of the second cross input to the
projection.
|
<OUT extends Tuple> |
ProjectOperator.Projection.projectTupleX()
Chooses a projectTupleX according to the length of
ProjectOperator.Projection.fieldIndexes . |
<OUT extends Tuple> |
CrossOperator.CrossProjection.projectTupleX()
Chooses a projectTupleX according to the length of
CrossOperator.CrossProjection.fieldIndexes . |
<OUT extends Tuple> |
JoinOperator.ProjectJoin.types(Class<?>... types)
Deprecated.
Deprecated method only kept for compatibility.
|
<OUT extends Tuple> |
CrossOperator.ProjectCross.types(Class<?>... types)
Deprecated.
Deprecated method only kept for compatibility.
|
<R extends Tuple> |
ProjectOperator.types(Class<?>... types)
Deprecated.
Deprecated method only kept for compatibility.
|
Modifier and Type | Class and Description |
---|---|
class |
PlanProjectOperator<T,R extends Tuple>
A map operator that retains a subset of fields from incoming tuples.
|
Modifier and Type | Class and Description |
---|---|
class |
TupleSummaryAggregator<R extends Tuple>
Aggregate tuples using an array of aggregators, one for each "column" or position within the
Tuple.
|
Modifier and Type | Method and Description |
---|---|
static <R extends Tuple> |
SummaryAggregatorFactory.create(TupleTypeInfoBase<?> inType) |
Modifier and Type | Method and Description |
---|---|
void |
TupleSummaryAggregator.aggregate(Tuple value) |
Modifier and Type | Method and Description |
---|---|
void |
TupleSummaryAggregator.combine(Aggregator<Tuple,R> other) |
Modifier and Type | Class and Description |
---|---|
class |
Tuple0
A tuple with 0 fields.
|
class |
Tuple1<T0>
A tuple with 1 fields.
|
class |
Tuple10<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9>
A tuple with 10 fields.
|
class |
Tuple11<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10>
A tuple with 11 fields.
|
class |
Tuple12<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11>
A tuple with 12 fields.
|
class |
Tuple13<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12>
A tuple with 13 fields.
|
class |
Tuple14<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13>
A tuple with 14 fields.
|
class |
Tuple15<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14>
A tuple with 15 fields.
|
class |
Tuple16<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15>
A tuple with 16 fields.
|
class |
Tuple17<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16>
A tuple with 17 fields.
|
class |
Tuple18<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17>
A tuple with 18 fields.
|
class |
Tuple19<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18>
A tuple with 19 fields.
|
class |
Tuple2<T0,T1>
A tuple with 2 fields.
|
class |
Tuple20<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19>
A tuple with 20 fields.
|
class |
Tuple21<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20>
A tuple with 21 fields.
|
class |
Tuple22<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21>
A tuple with 22 fields.
|
class |
Tuple23<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21,T22>
A tuple with 23 fields.
|
class |
Tuple24<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21,T22,T23>
A tuple with 24 fields.
|
class |
Tuple25<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21,T22,T23,T24>
A tuple with 25 fields.
|
class |
Tuple3<T0,T1,T2>
A tuple with 3 fields.
|
class |
Tuple4<T0,T1,T2,T3>
A tuple with 4 fields.
|
class |
Tuple5<T0,T1,T2,T3,T4>
A tuple with 5 fields.
|
class |
Tuple6<T0,T1,T2,T3,T4,T5>
A tuple with 6 fields.
|
class |
Tuple7<T0,T1,T2,T3,T4,T5,T6>
A tuple with 7 fields.
|
class |
Tuple8<T0,T1,T2,T3,T4,T5,T6,T7>
A tuple with 8 fields.
|
class |
Tuple9<T0,T1,T2,T3,T4,T5,T6,T7,T8>
A tuple with 9 fields.
|
Modifier and Type | Method and Description |
---|---|
abstract <T extends Tuple> |
Tuple.copy()
Shallow tuple copy.
|
Modifier and Type | Method and Description |
---|---|
static Tuple |
Tuple.newInstance(int arity) |
Modifier and Type | Method and Description |
---|---|
static Class<? extends Tuple> |
Tuple.getTupleClass(int arity)
Gets the class corresponding to the tuple of the given arity (dimensions).
|
Modifier and Type | Class and Description |
---|---|
class |
TupleTypeInfo<T extends Tuple>
A
TypeInformation for the tuple types of the Java API. |
Modifier and Type | Method and Description |
---|---|
static <X extends Tuple> |
TupleTypeInfo.getBasicAndBasicValueTupleTypeInfo(Class<?>... basicTypes) |
static <X extends Tuple> |
TupleTypeInfo.getBasicTupleTypeInfo(Class<?>... basicTypes) |
Modifier and Type | Class and Description |
---|---|
class |
TupleComparator<T extends Tuple> |
class |
TupleSerializer<T extends Tuple> |
class |
TupleSerializerSnapshot<T extends Tuple>
Snapshot of a tuple serializer's configuration.
|
Modifier and Type | Method and Description |
---|---|
static <R extends Tuple,T extends Tuple> |
DataSetUtils.summarize(DataSet<T> input)
Summarize a DataSet of Tuples by collecting single pass statistics for all columns.
|
static <R extends Tuple,T extends Tuple> |
DataSetUtils.summarize(DataSet<T> input)
Summarize a DataSet of Tuples by collecting single pass statistics for all columns.
|
Modifier and Type | Class and Description |
---|---|
class |
CassandraInputFormat<OUT extends Tuple>
InputFormat to read data from Apache Cassandra and generate $
Tuple . |
class |
CassandraOutputFormat<OUT extends Tuple>
Deprecated.
Please use CassandraTupleOutputFormat instead.
|
class |
CassandraTupleOutputFormat<OUT extends Tuple>
OutputFormat to write Flink
Tuple s into a Cassandra cluster. |
Modifier and Type | Class and Description |
---|---|
class |
HBaseInputFormat<T extends Tuple>
InputFormat subclass that wraps the access for HTables. |
Modifier and Type | Class and Description |
---|---|
class |
HBaseInputFormat<T extends Tuple>
InputFormat subclass that wraps the access for HTables. |
Modifier and Type | Class and Description |
---|---|
static class |
EnumTrianglesDataTypes.Edge
A POJO storing two vertex IDs.
|
static class |
EnumTrianglesDataTypes.EdgeWithDegrees
A POJO storing two vertex IDs with degree.
|
static class |
EnumTrianglesDataTypes.Triad
A POJO storing three vertex IDs.
|
Modifier and Type | Class and Description |
---|---|
static class |
EmptyFieldsCountAccumulator.StringTriple
It is recommended to use POJOs (Plain old Java objects) instead of TupleX for data types with
many fields.
|
static class |
TPCHQuery3.Customer
Customer.
|
static class |
TPCHQuery3.Lineitem
Lineitem.
|
static class |
TPCHQuery3.Order
Order.
|
static class |
TPCHQuery3.ShippingPriorityItem
ShippingPriorityItem.
|
Modifier and Type | Class and Description |
---|---|
class |
Edge<K,V>
An Edge represents a link between two
vertices , the source and the target and can
carry an attached value. |
class |
Triplet<K,VV,EV>
A Triplet stores and retrieves the edges along with their corresponding source and target
vertices.
|
class |
Vertex<K,V>
Represents the graph's nodes.
|
Modifier and Type | Class and Description |
---|---|
static class |
VertexDegrees.Degrees
Wraps the vertex degree, out-degree, and in-degree.
|
Modifier and Type | Class and Description |
---|---|
class |
BipartiteEdge<KT,KB,EV>
A BipartiteEdge represents a link between top and bottom vertices in a
BipartiteGraph . |
class |
Projection<KC,VVC,VV,EV>
The edge value of a full bipartite projection.
|
Modifier and Type | Class and Description |
---|---|
class |
Neighbor<VV,EV>
This class represents a
<sourceVertex, edge> pair. |
Modifier and Type | Class and Description |
---|---|
static class |
Summarization.EdgeValue<EV>
Value that is stored at a summarized edge.
|
static class |
Summarization.VertexGroupItem<K,VGV>
Represents a single vertex in a vertex group.
|
static class |
Summarization.VertexValue<VV>
Value that is stored at a summarized vertex.
|
static class |
Summarization.VertexWithRepresentative<K>
Represents a vertex identifier and its corresponding vertex group identifier.
|
static class |
TriangleEnumerator.EdgeWithDegrees<K>
POJO storing two vertex IDs with degree.
|
static class |
TriangleEnumerator.Triad<K>
Tuple storing three vertex IDs.
|
Modifier and Type | Method and Description |
---|---|
KeyedOperatorTransformation<Tuple,T> |
OneInputOperatorTransformation.keyBy(int... fields)
Partitions the operator state of a
OperatorTransformation by the given key positions. |
KeyedOperatorTransformation<Tuple,T> |
OneInputOperatorTransformation.keyBy(String... fields)
Partitions the operator state of a
OperatorTransformation using field expressions. |
Modifier and Type | Method and Description |
---|---|
<R extends Tuple> |
DataStream.project(int... fieldIndexes)
Initiates a Project transformation on a
Tuple DataStream .Note: Only Tuple DataStreams can be projected. |
<OUT extends Tuple> |
StreamProjection.projectTupleX()
Chooses a projectTupleX according to the length of
StreamProjection.fieldIndexes . |
<X extends Tuple> |
DataStream.writeAsCsv(String path,
FileSystem.WriteMode writeMode,
String rowDelimiter,
String fieldDelimiter)
Deprecated.
Please use the
StreamingFileSink explicitly
using the DataStream.addSink(SinkFunction) method. |
Modifier and Type | Method and Description |
---|---|
KeyedStream<T,Tuple> |
DataStream.keyBy(int... fields)
Deprecated.
|
KeyedStream<T,Tuple> |
DataStream.keyBy(String... fields)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
OUT |
FieldFromTuple.extract(Tuple in) |
Object[] |
ArrayFromTuple.extract(Tuple in) |
double[] |
FieldsFromTuple.extract(Tuple in) |
Modifier and Type | Class and Description |
---|---|
class |
StreamProject<IN,OUT extends Tuple>
A
StreamOperator for executing projections on streams. |
Modifier and Type | Class and Description |
---|---|
static class |
CassandraSink.CassandraTupleSinkBuilder<IN extends Tuple>
Builder for a
CassandraTupleSink . |
class |
CassandraTupleSink<IN extends Tuple>
Sink to write Flink
Tuple s into a Cassandra cluster. |
class |
CassandraTupleWriteAheadSink<IN extends Tuple>
Sink that emits its input elements into a Cassandra database.
|
Modifier and Type | Method and Description |
---|---|
static <T> KeyedStream<T,Tuple> |
FlinkKafkaShuffle.persistentKeyBy(DataStream<T> dataStream,
String topic,
int producerParallelism,
int numberOfPartitions,
Properties properties,
int... fields)
Uses Kafka as a message bus to persist keyBy shuffle.
|
Modifier and Type | Method and Description |
---|---|
TypeInformation<Tuple> |
PeriodicStreamingJob.PeriodicSourceGenerator.getProducedType() |
Modifier and Type | Method and Description |
---|---|
void |
PeriodicStreamingJob.PeriodicSourceGenerator.run(SourceFunction.SourceContext<Tuple> ctx) |
Modifier and Type | Method and Description |
---|---|
Tuple |
KeySelectorUtil.ComparableKeySelector.getKey(IN value) |
Tuple |
KeySelectorUtil.ArrayKeySelector.getKey(IN value) |
Modifier and Type | Method and Description |
---|---|
TypeInformation<Tuple> |
KeySelectorUtil.ComparableKeySelector.getProducedType() |
TypeInformation<Tuple> |
KeySelectorUtil.ArrayKeySelector.getProducedType() |
static <X> KeySelector<X,Tuple> |
KeySelectorUtil.getSelectorForKeys(Keys<X> keys,
TypeInformation<X> typeInfo,
ExecutionConfig executionConfig) |
Constructor and Description |
---|
TupleConverter(Class<Tuple> clazz,
DataType[] fieldTypes) |
Modifier and Type | Class and Description |
---|---|
static class |
TestBaseUtils.TupleComparator<T extends Tuple>
Comparator for comparable Tuples.
|
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.