Package | Description |
---|---|
org.apache.flink.api.common.functions | |
org.apache.flink.api.java.operators | |
org.apache.flink.api.java.operators.join | |
org.apache.flink.api.java.typeutils | |
org.apache.flink.examples.java.graph | |
org.apache.flink.graph.asm.degree.annotate |
The degree annotation package provides a collection of edge-centric graph
algorithms for counting the vertex degree of directed and undirected graphs.
|
org.apache.flink.streaming.api.datastream | |
org.apache.flink.streaming.tests.artificialstate.builder |
Modifier and Type | Class and Description |
---|---|
class |
RichJoinFunction<IN1,IN2,OUT>
Rich variant of the
JoinFunction . |
Modifier and Type | Method and Description |
---|---|
<R> JoinOperator.EquiJoin<I1,I2,R> |
JoinOperator.DefaultJoin.with(JoinFunction<I1,I2,R> function) |
Constructor and Description |
---|
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) |
WrappingFlatJoinFunction(JoinFunction<IN1,IN2,OUT> wrappedFunction) |
Modifier and Type | Method and Description |
---|---|
<R> JoinOperator<I1,I2,R> |
JoinFunctionAssigner.with(JoinFunction<I1,I2,R> joinFunction) |
Modifier and Type | Method and Description |
---|---|
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) |
Modifier and Type | Class and Description |
---|---|
static class |
ConnectedComponents.NeighborWithComponentIDJoin
UDF that joins a (Vertex-ID, Component-ID) pair that represents the current component that
a vertex is associated with, with a (Source-Vertex-ID, Target-VertexID) edge.
|
Modifier and Type | Class and Description |
---|---|
static class |
DegreeAnnotationFunctions.JoinEdgeDegreeWithVertexDegree<K,EV,D>
Composes the vertex degree with this edge value.
|
static class |
DegreeAnnotationFunctions.JoinEdgeWithVertexDegree<K,EV,D>
Assigns the vertex degree to this edge value.
|
static class |
DegreeAnnotationFunctions.JoinVertexWithVertexDegree<K,VV>
Performs a left outer join to apply a zero count for vertices with
out- or in-degree of zero.
|
Modifier and Type | Method and Description |
---|---|
<T> DataStream<T> |
JoinedStreams.WithWindow.apply(JoinFunction<T1,T2,T> function)
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.
|
<T> SingleOutputStreamOperator<T> |
JoinedStreams.WithWindow.with(JoinFunction<T1,T2,T> function)
Deprecated.
This method will be removed once the
JoinedStreams.WithWindow.apply(JoinFunction) method is fixed
in the next major version of Flink (2.0). |
<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). |
Constructor and Description |
---|
ArtificialListStateBuilder(String stateName,
JoinFunction<IN,Iterable<STATE>,List<STATE>> keyedStateGenerator,
JoinFunction<IN,Iterable<STATE>,List<STATE>> operatorStateGenerator,
TypeSerializer<STATE> typeSerializer) |
ArtificialListStateBuilder(String stateName,
JoinFunction<IN,Iterable<STATE>,List<STATE>> keyedStateGenerator,
JoinFunction<IN,Iterable<STATE>,List<STATE>> operatorStateGenerator,
TypeSerializer<STATE> typeSerializer) |
ArtificialMapStateBuilder(String stateName,
JoinFunction<IN,Iterator<Map.Entry<K,V>>,Iterator<Map.Entry<K,V>>> stateValueGenerator,
TypeSerializer<K> keySerializer,
TypeSerializer<V> valueSerializer) |
ArtificialValueStateBuilder(String stateName,
JoinFunction<IN,STATE,STATE> stateValueGenerator,
TypeSerializer<STATE> typeSerializer) |
Copyright © 2014–2019 The Apache Software Foundation. All rights reserved.