Modifier and Type | Method and Description |
---|---|
String |
FileSinkProgram.KeyBucketAssigner.getBucketId(Tuple2<Integer,Integer> element,
BucketAssigner.Context context) |
Modifier and Type | Method and Description |
---|---|
void |
FileSinkProgram.Generator.run(SourceFunction.SourceContext<Tuple2<Integer,Integer>> ctx) |
Modifier and Type | Method and Description |
---|---|
static List<Tuple2<String,DistributedCache.DistributedCacheEntry>> |
DistributedCache.parseCachedFilesFromString(List<String> files)
Parses a list of distributed cache entries encoded in a string.
|
Modifier and Type | Method and Description |
---|---|
Tuple2<Long,Long> |
BinaryInputFormat.getCurrentState() |
Modifier and Type | Method and Description |
---|---|
void |
BinaryInputFormat.reopen(FileInputSplit split,
Tuple2<Long,Long> state) |
Modifier and Type | Method and Description |
---|---|
Tuple2<TypeSerializer<?>,TypeSerializerSnapshot<?>> |
CompositeTypeSerializerConfigSnapshot.getSingleNestedSerializerAndConfig() |
Modifier and Type | Method and Description |
---|---|
List<Tuple2<TypeSerializer<?>,TypeSerializerSnapshot<?>>> |
CompositeTypeSerializerConfigSnapshot.getNestedSerializersAndConfigs() |
static List<Tuple2<TypeSerializer<?>,TypeSerializerSnapshot<?>>> |
TypeSerializerSerializationUtil.readSerializersAndConfigsWithResilience(DataInputView in,
ClassLoader userCodeClassLoader)
Deprecated.
Reads from a data input view a list of serializers and their corresponding config snapshots
written using
TypeSerializerSerializationUtil.writeSerializersAndConfigsWithResilience(DataOutputView, List) . |
Modifier and Type | Method and Description |
---|---|
static void |
TypeSerializerSerializationUtil.writeSerializersAndConfigsWithResilience(DataOutputView out,
List<Tuple2<TypeSerializer<?>,TypeSerializerSnapshot<?>>> serializersAndConfigs)
Deprecated.
Write a list of serializers and their corresponding config snapshots to the provided data
output view.
|
Modifier and Type | Method and Description |
---|---|
Tuple2<K,V> |
HadoopInputFormat.nextRecord(Tuple2<K,V> record) |
Modifier and Type | Method and Description |
---|---|
TypeInformation<Tuple2<K,V>> |
HadoopInputFormat.getProducedType() |
Modifier and Type | Method and Description |
---|---|
Tuple2<K,V> |
HadoopInputFormat.nextRecord(Tuple2<K,V> record) |
void |
HadoopOutputFormat.writeRecord(Tuple2<K,V> record) |
Modifier and Type | Method and Description |
---|---|
Tuple2<K,V> |
HadoopInputFormat.nextRecord(Tuple2<K,V> record) |
Modifier and Type | Method and Description |
---|---|
TypeInformation<Tuple2<K,V>> |
HadoopInputFormat.getProducedType() |
Modifier and Type | Method and Description |
---|---|
Tuple2<K,V> |
HadoopInputFormat.nextRecord(Tuple2<K,V> record) |
void |
HadoopOutputFormat.writeRecord(Tuple2<K,V> record) |
Modifier and Type | Method and Description |
---|---|
<T0,T1> DataSource<Tuple2<T0,T1>> |
CsvReader.types(Class<T0> type0,
Class<T1> type1)
Specifies the types for the CSV fields.
|
Modifier and Type | Method and Description |
---|---|
static <T,K> Operator<Tuple2<K,T>> |
KeyFunctions.appendKeyExtractor(Operator<T> input,
Keys.SelectorFunctionKeys<T,K> key) |
static <T,K> TypeInformation<Tuple2<K,T>> |
KeyFunctions.createTypeWithKey(Keys.SelectorFunctionKeys<T,K> key) |
<T0,T1> CrossOperator.ProjectCross<I1,I2,Tuple2<T0,T1>> |
CrossOperator.CrossProjection.projectTuple2()
Projects a pair of crossed elements to a
Tuple with the previously selected
fields. |
<T0,T1> ProjectOperator<T,Tuple2<T0,T1>> |
ProjectOperator.Projection.projectTuple2()
|
Modifier and Type | Method and Description |
---|---|
static <T,K> SingleInputOperator<?,T,?> |
KeyFunctions.appendKeyRemover(Operator<Tuple2<K,T>> inputWithKey,
Keys.SelectorFunctionKeys<T,K> key) |
Modifier and Type | Method and Description |
---|---|
Tuple2<K,T> |
KeyExtractingMapper.map(T value) |
Modifier and Type | Method and Description |
---|---|
void |
TupleRightUnwrappingJoiner.join(I1 value1,
Tuple2<K,I2> value2,
Collector<OUT> collector) |
void |
TupleLeftUnwrappingJoiner.join(Tuple2<K,I1> value1,
I2 value2,
Collector<OUT> collector) |
void |
TupleUnwrappingJoiner.join(Tuple2<K,I1> value1,
Tuple2<K,I2> value2,
Collector<OUT> collector) |
void |
TupleUnwrappingJoiner.join(Tuple2<K,I1> value1,
Tuple2<K,I2> value2,
Collector<OUT> collector) |
T |
KeyRemovingMapper.map(Tuple2<K,T> value) |
Modifier and Type | Method and Description |
---|---|
void |
TupleWrappingCollector.set(Collector<Tuple2<K,IN>> wrappedCollector) |
void |
TupleUnwrappingIterator.set(Iterator<Tuple2<K,T>> iterator) |
Modifier and Type | Method and Description |
---|---|
Tuple2<T0,T1> |
Tuple2.copy()
Shallow tuple copy.
|
static <T0,T1> Tuple2<T0,T1> |
Tuple2.of(T0 f0,
T1 f1)
Creates a new tuple and assigns the given values to the tuple's fields.
|
Tuple2<T1,T0> |
Tuple2.swap()
Returns a shallow copy of the tuple with swapped values.
|
Modifier and Type | Method and Description |
---|---|
Tuple2<T0,T1>[] |
Tuple2Builder.build() |
Modifier and Type | Method and Description |
---|---|
LinkedHashMap<String,Tuple2<TypeSerializer<?>,TypeSerializerSnapshot<?>>> |
PojoSerializer.PojoSerializerConfigSnapshot.getFieldToSerializerConfigSnapshot()
Deprecated.
|
HashMap<Class<?>,Tuple2<TypeSerializer<?>,TypeSerializerSnapshot<?>>> |
PojoSerializer.PojoSerializerConfigSnapshot.getNonRegisteredSubclassesToSerializerConfigSnapshots()
Deprecated.
|
LinkedHashMap<Class<?>,Tuple2<TypeSerializer<?>,TypeSerializerSnapshot<?>>> |
PojoSerializer.PojoSerializerConfigSnapshot.getRegisteredSubclassesToSerializerConfigSnapshots()
Deprecated.
|
Constructor and Description |
---|
PojoSerializerConfigSnapshot(Class<T> pojoType,
LinkedHashMap<String,Tuple2<TypeSerializer<?>,TypeSerializerSnapshot<?>>> fieldToSerializerConfigSnapshot,
LinkedHashMap<Class<?>,Tuple2<TypeSerializer<?>,TypeSerializerSnapshot<?>>> registeredSubclassesToSerializerConfigSnapshots,
HashMap<Class<?>,Tuple2<TypeSerializer<?>,TypeSerializerSnapshot<?>>> nonRegisteredSubclassesToSerializerConfigSnapshots)
Deprecated.
|
PojoSerializerConfigSnapshot(Class<T> pojoType,
LinkedHashMap<String,Tuple2<TypeSerializer<?>,TypeSerializerSnapshot<?>>> fieldToSerializerConfigSnapshot,
LinkedHashMap<Class<?>,Tuple2<TypeSerializer<?>,TypeSerializerSnapshot<?>>> registeredSubclassesToSerializerConfigSnapshots,
HashMap<Class<?>,Tuple2<TypeSerializer<?>,TypeSerializerSnapshot<?>>> nonRegisteredSubclassesToSerializerConfigSnapshots)
Deprecated.
|
PojoSerializerConfigSnapshot(Class<T> pojoType,
LinkedHashMap<String,Tuple2<TypeSerializer<?>,TypeSerializerSnapshot<?>>> fieldToSerializerConfigSnapshot,
LinkedHashMap<Class<?>,Tuple2<TypeSerializer<?>,TypeSerializerSnapshot<?>>> registeredSubclassesToSerializerConfigSnapshots,
HashMap<Class<?>,Tuple2<TypeSerializer<?>,TypeSerializerSnapshot<?>>> nonRegisteredSubclassesToSerializerConfigSnapshots)
Deprecated.
|
PojoSerializerConfigSnapshot(Class<T> pojoType,
LinkedHashMap<String,Tuple2<TypeSerializer<?>,TypeSerializerSnapshot<?>>> fieldToSerializerConfigSnapshot,
LinkedHashMap<Class<?>,Tuple2<TypeSerializer<?>,TypeSerializerSnapshot<?>>> registeredSubclassesToSerializerConfigSnapshots,
HashMap<Class<?>,Tuple2<TypeSerializer<?>,TypeSerializerSnapshot<?>>> nonRegisteredSubclassesToSerializerConfigSnapshots,
boolean ignoreTypeSerializerSerialization)
Deprecated.
|
PojoSerializerConfigSnapshot(Class<T> pojoType,
LinkedHashMap<String,Tuple2<TypeSerializer<?>,TypeSerializerSnapshot<?>>> fieldToSerializerConfigSnapshot,
LinkedHashMap<Class<?>,Tuple2<TypeSerializer<?>,TypeSerializerSnapshot<?>>> registeredSubclassesToSerializerConfigSnapshots,
HashMap<Class<?>,Tuple2<TypeSerializer<?>,TypeSerializerSnapshot<?>>> nonRegisteredSubclassesToSerializerConfigSnapshots,
boolean ignoreTypeSerializerSerialization)
Deprecated.
|
PojoSerializerConfigSnapshot(Class<T> pojoType,
LinkedHashMap<String,Tuple2<TypeSerializer<?>,TypeSerializerSnapshot<?>>> fieldToSerializerConfigSnapshot,
LinkedHashMap<Class<?>,Tuple2<TypeSerializer<?>,TypeSerializerSnapshot<?>>> registeredSubclassesToSerializerConfigSnapshots,
HashMap<Class<?>,Tuple2<TypeSerializer<?>,TypeSerializerSnapshot<?>>> nonRegisteredSubclassesToSerializerConfigSnapshots,
boolean ignoreTypeSerializerSerialization)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
static <T> DataSet<Tuple2<Integer,Long>> |
DataSetUtils.countElementsPerPartition(DataSet<T> input)
Method that goes over all the elements in each partition in order to retrieve the total
number of elements.
|
static <T> DataSet<Tuple2<Long,T>> |
DataSetUtils.zipWithIndex(DataSet<T> input)
Method that assigns a unique
Long value to all elements in the input data set. |
static <T> DataSet<Tuple2<Long,T>> |
DataSetUtils.zipWithUniqueId(DataSet<T> input)
Method that assigns a unique
Long value to all elements in the input data set as
described below. |
Constructor and Description |
---|
PlanGenerator(List<DataSink<?>> sinks,
ExecutionConfig config,
int defaultParallelism,
List<Tuple2<String,DistributedCache.DistributedCacheEntry>> cacheFile,
String jobName) |
Modifier and Type | Method and Description |
---|---|
Tuple2<String,Integer> |
Generator.nextRecord(Tuple2<String,Integer> reuse) |
Modifier and Type | Method and Description |
---|---|
Tuple2<String,Integer> |
Generator.nextRecord(Tuple2<String,Integer> reuse) |
Modifier and Type | Method and Description |
---|---|
Collection<Tuple2<Map<String,List<T>>,Long>> |
NFA.advanceTime(SharedBufferAccessor<T> sharedBufferAccessor,
NFAState nfaState,
long timestamp)
Prunes states assuming there will be no events with timestamp lower than the given
one.
|
Constructor and Description |
---|
SharedBuffer(Map<EventId,Lockable<V>> eventsBuffer,
Map<NodeId,Lockable<SharedBufferNode>> pages,
Map<Tuple2<String,org.apache.flink.cep.nfa.SharedBuffer.ValueTimeWrapper<V>>,NodeId> mappingContext,
Map<Integer,EventId> starters)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
JdbcOutputFormat<Tuple2<Boolean,Row>,Row,JdbcBatchStatementExecutor<Row>> |
JdbcOutputFormat.Builder.build()
Finalizes the configuration and checks validity.
|
Modifier and Type | Method and Description |
---|---|
TableSink<Tuple2<Boolean,Row>> |
JdbcUpsertTableSink.configure(String[] fieldNames,
TypeInformation<?>[] fieldTypes) |
StreamTableSink<Tuple2<Boolean,Row>> |
JdbcTableSourceSinkFactory.createStreamTableSink(Map<String,String> properties) |
TypeInformation<Tuple2<Boolean,Row>> |
JdbcUpsertTableSink.getOutputType() |
Modifier and Type | Method and Description |
---|---|
DataStreamSink<?> |
JdbcUpsertTableSink.consumeDataStream(DataStream<Tuple2<Boolean,Row>> dataStream) |
Modifier and Type | Method and Description |
---|---|
List<Tuple2<org.apache.hadoop.hive.metastore.api.Partition,T>> |
HiveContinuousPartitionFetcher.fetchPartitions(ContinuousPartitionFetcher.Context<org.apache.hadoop.hive.metastore.api.Partition,T> context,
T previousOffset) |
Modifier and Type | Method and Description |
---|---|
<N> java.util.stream.Stream<Tuple2<K,N>> |
RocksDBKeyedStateBackend.getKeysAndNamespaces(String state) |
Modifier and Type | Method and Description |
---|---|
Tuple2<K,N> |
RocksStateKeysAndNamespaceIterator.next() |
Constructor and Description |
---|
RocksStatesPerKeyGroupMergeIterator(CloseableRegistry closeableRegistry,
List<Tuple2<RocksIteratorWrapper,Integer>> kvStateIterators,
List<SingleStateIterator> heapPriorityQueueIterators,
int keyGroupPrefixByteCount)
Creates a new
RocksStatesPerKeyGroupMergeIterator . |
Modifier and Type | Method and Description |
---|---|
Tuple2<Integer,KMeans.Point> |
KMeans.SelectNearestCenter.map(KMeans.Point p) |
Modifier and Type | Method and Description |
---|---|
Tuple3<Integer,KMeans.Point,Long> |
KMeans.CountAppender.map(Tuple2<Integer,KMeans.Point> t) |
Modifier and Type | Method and Description |
---|---|
Tuple2<Long,Long> |
ConnectedComponents.NeighborWithComponentIDJoin.join(Tuple2<Long,Long> vertexWithComponent,
Tuple2<Long,Long> edge) |
Tuple2<Long,Double> |
PageRank.RankAssigner.map(Long page) |
Tuple2<T,T> |
ConnectedComponents.DuplicateValue.map(T vertex) |
Tuple2<Long,Double> |
PageRank.Dampener.map(Tuple2<Long,Double> value) |
Modifier and Type | Method and Description |
---|---|
boolean |
PageRank.EpsilonFilter.filter(Tuple2<Tuple2<Long,Double>,Tuple2<Long,Double>> value) |
void |
ConnectedComponents.UndirectEdge.flatMap(Tuple2<Long,Long> edge,
Collector<Tuple2<Long,Long>> out) |
void |
PageRank.JoinVertexWithEdgesMatch.flatMap(Tuple2<Tuple2<Long,Double>,Tuple2<Long,Long[]>> value,
Collector<Tuple2<Long,Double>> out) |
Tuple2<Long,Long> |
ConnectedComponents.NeighborWithComponentIDJoin.join(Tuple2<Long,Long> vertexWithComponent,
Tuple2<Long,Long> edge) |
Tuple2<Long,Long> |
ConnectedComponents.NeighborWithComponentIDJoin.join(Tuple2<Long,Long> vertexWithComponent,
Tuple2<Long,Long> edge) |
void |
ConnectedComponents.ComponentIdFilter.join(Tuple2<Long,Long> candidate,
Tuple2<Long,Long> old,
Collector<Tuple2<Long,Long>> out) |
void |
ConnectedComponents.ComponentIdFilter.join(Tuple2<Long,Long> candidate,
Tuple2<Long,Long> old,
Collector<Tuple2<Long,Long>> out) |
EnumTrianglesDataTypes.Edge |
EnumTriangles.TupleEdgeConverter.map(Tuple2<Integer,Integer> t) |
Tuple2<Long,Double> |
PageRank.Dampener.map(Tuple2<Long,Double> value) |
Modifier and Type | Method and Description |
---|---|
boolean |
PageRank.EpsilonFilter.filter(Tuple2<Tuple2<Long,Double>,Tuple2<Long,Double>> value) |
boolean |
PageRank.EpsilonFilter.filter(Tuple2<Tuple2<Long,Double>,Tuple2<Long,Double>> value) |
void |
ConnectedComponents.UndirectEdge.flatMap(Tuple2<Long,Long> edge,
Collector<Tuple2<Long,Long>> out) |
void |
PageRank.JoinVertexWithEdgesMatch.flatMap(Tuple2<Tuple2<Long,Double>,Tuple2<Long,Long[]>> value,
Collector<Tuple2<Long,Double>> out) |
void |
PageRank.JoinVertexWithEdgesMatch.flatMap(Tuple2<Tuple2<Long,Double>,Tuple2<Long,Long[]>> value,
Collector<Tuple2<Long,Double>> out) |
void |
PageRank.JoinVertexWithEdgesMatch.flatMap(Tuple2<Tuple2<Long,Double>,Tuple2<Long,Long[]>> value,
Collector<Tuple2<Long,Double>> out) |
void |
ConnectedComponents.ComponentIdFilter.join(Tuple2<Long,Long> candidate,
Tuple2<Long,Long> old,
Collector<Tuple2<Long,Long>> out) |
void |
PageRank.BuildOutgoingEdgeList.reduce(Iterable<Tuple2<Long,Long>> values,
Collector<Tuple2<Long,Long[]>> out) |
void |
PageRank.BuildOutgoingEdgeList.reduce(Iterable<Tuple2<Long,Long>> values,
Collector<Tuple2<Long,Long[]>> out) |
Modifier and Type | Class and Description |
---|---|
static class |
EnumTrianglesDataTypes.Edge
A POJO storing two vertex IDs.
|
Modifier and Type | Method and Description |
---|---|
static DataSet<Tuple2<Long,Long>> |
PageRankData.getDefaultEdgeDataSet(ExecutionEnvironment env) |
static DataSet<Tuple2<Long,Long>> |
ConnectedComponentsData.getDefaultEdgeDataSet(ExecutionEnvironment env) |
Modifier and Type | Method and Description |
---|---|
void |
EnumTrianglesDataTypes.Edge.copyVerticesFromTuple2(Tuple2<Integer,Integer> t) |
Modifier and Type | Class and Description |
---|---|
static class |
TPCHQuery3.Customer
Customer.
|
Modifier and Type | Method and Description |
---|---|
boolean |
WebLogAnalysis.FilterDocByKeyWords.filter(Tuple2<String,String> value)
Filters for documents that contain all of the given keywords and projects the records on
the URL field.
|
boolean |
WebLogAnalysis.FilterVisitsByDate.filter(Tuple2<String,String> value)
Filters for records of the visits relation where the year of visit is equal to a
specified value.
|
Modifier and Type | Method and Description |
---|---|
static DataSet<Tuple2<String,String>> |
WebLogData.getDocumentDataSet(ExecutionEnvironment env) |
static DataSet<Tuple2<String,String>> |
WebLogData.getVisitDataSet(ExecutionEnvironment env) |
Modifier and Type | Method and Description |
---|---|
void |
WordCount.Tokenizer.flatMap(String value,
Collector<Tuple2<String,Integer>> out) |
Modifier and Type | Method and Description |
---|---|
Tuple2<Long,Long> |
AvroInputFormat.getCurrentState() |
Modifier and Type | Method and Description |
---|---|
void |
AvroInputFormat.reopen(FileInputSplit split,
Tuple2<Long,Long> state) |
Modifier and Type | Method and Description |
---|---|
void |
SequenceFileWriter.addElement(Tuple2<K,V> element) |
Modifier and Type | Class and Description |
---|---|
class |
Vertex<K,V>
Represents the graph's nodes.
|
Modifier and Type | Method and Description |
---|---|
DataSet<Tuple2<K,LongValue>> |
Graph.getDegrees()
Return the degree of all vertices in the graph.
|
DataSet<Tuple2<K,K>> |
Graph.getEdgeIds() |
DataSet<Tuple2<K,VV>> |
Graph.getVerticesAsTuple2() |
DataSet<Tuple2<K,LongValue>> |
Graph.inDegrees()
Return the in-degree of all vertices in the graph.
|
DataSet<Tuple2<K,LongValue>> |
Graph.outDegrees()
Return the out-degree of all vertices in the graph.
|
DataSet<Tuple2<K,EV>> |
Graph.reduceOnEdges(ReduceEdgesFunction<EV> reduceEdgesFunction,
EdgeDirection direction)
Compute a reduce transformation over the edge values of each vertex.
|
DataSet<Tuple2<K,VV>> |
Graph.reduceOnNeighbors(ReduceNeighborsFunction<VV> reduceNeighborsFunction,
EdgeDirection direction)
Compute a reduce transformation over the neighbors' vertex values of each vertex.
|
Modifier and Type | Method and Description |
---|---|
static <K> Graph<K,NullValue,NullValue> |
Graph.fromTuple2DataSet(DataSet<Tuple2<K,K>> edges,
ExecutionEnvironment context)
Creates a graph from a DataSet of Tuple2 objects for edges.
|
static <K,VV> Graph<K,VV,NullValue> |
Graph.fromTuple2DataSet(DataSet<Tuple2<K,K>> edges,
MapFunction<K,VV> vertexValueInitializer,
ExecutionEnvironment context)
Creates a graph from a DataSet of Tuple2 objects for edges.
|
static <K,VV,EV> Graph<K,VV,EV> |
Graph.fromTupleDataSet(DataSet<Tuple2<K,VV>> vertices,
DataSet<Tuple3<K,K,EV>> edges,
ExecutionEnvironment context)
Creates a graph from a DataSet of Tuple2 objects for vertices and Tuple3 objects for edges.
|
void |
EdgesFunction.iterateEdges(Iterable<Tuple2<K,Edge<K,EV>>> edges,
Collector<O> out)
This method is called per vertex and can iterate over all of its neighboring edges with the
specified direction.
|
void |
NeighborsFunctionWithVertexValue.iterateNeighbors(Vertex<K,VV> vertex,
Iterable<Tuple2<Edge<K,EV>,Vertex<K,VV>>> neighbors,
Collector<O> out)
This method is called per vertex and can iterate over all of its neighbors with the specified
direction.
|
<T> Graph<K,VV,EV> |
Graph.joinWithEdgesOnSource(DataSet<Tuple2<K,T>> inputDataSet,
EdgeJoinFunction<EV,T> edgeJoinFunction)
Joins the edge DataSet with an input Tuple2 DataSet and applies a user-defined transformation
on the values of the matched records.
|
<T> Graph<K,VV,EV> |
Graph.joinWithEdgesOnTarget(DataSet<Tuple2<K,T>> inputDataSet,
EdgeJoinFunction<EV,T> edgeJoinFunction)
Joins the edge DataSet with an input Tuple2 DataSet and applies a user-defined transformation
on the values of the matched records.
|
<T> Graph<K,VV,EV> |
Graph.joinWithVertices(DataSet<Tuple2<K,T>> inputDataSet,
VertexJoinFunction<VV,T> vertexJoinFunction)
Joins the vertex DataSet of this graph with an input Tuple2 DataSet and applies a
user-defined transformation on the values of the matched records.
|
Modifier and Type | Method and Description |
---|---|
Edge<K,Tuple2<EV,D>> |
DegreeAnnotationFunctions.JoinEdgeWithVertexDegree.join(Edge<K,EV> edge,
Vertex<K,D> vertex) |
Modifier and Type | Method and Description |
---|---|
Edge<K,Tuple3<EV,D,D>> |
DegreeAnnotationFunctions.JoinEdgeDegreeWithVertexDegree.join(Edge<K,Tuple2<EV,D>> edge,
Vertex<K,D> vertex) |
Modifier and Type | Method and Description |
---|---|
DataSet<Edge<K,Tuple2<EV,VertexDegrees.Degrees>>> |
EdgeTargetDegrees.runInternal(Graph<K,VV,EV> input) |
DataSet<Edge<K,Tuple2<EV,VertexDegrees.Degrees>>> |
EdgeSourceDegrees.runInternal(Graph<K,VV,EV> input) |
Modifier and Type | Method and Description |
---|---|
DataSet<Edge<K,Tuple2<EV,LongValue>>> |
EdgeTargetDegree.runInternal(Graph<K,VV,EV> input) |
DataSet<Edge<K,Tuple2<EV,LongValue>>> |
EdgeSourceDegree.runInternal(Graph<K,VV,EV> input) |
Modifier and Type | Method and Description |
---|---|
Graph<KB,VVB,Tuple2<EV,EV>> |
BipartiteGraph.projectionBottomSimple()
Convert a bipartite graph into an undirected graph that contains only bottom vertices.
|
Graph<KT,VVT,Tuple2<EV,EV>> |
BipartiteGraph.projectionTopSimple()
Convert a bipartite graph into an undirected graph that contains only top vertices.
|
Modifier and Type | Class and Description |
---|---|
class |
Neighbor<VV,EV>
This class represents a
<sourceVertex, edge> pair. |
Modifier and Type | Method and Description |
---|---|
List<Tuple2<String,DataSet<?>>> |
GSAConfiguration.getApplyBcastVars()
Get the broadcast variables of the ApplyFunction.
|
List<Tuple2<String,DataSet<?>>> |
GSAConfiguration.getGatherBcastVars()
Get the broadcast variables of the GatherFunction.
|
List<Tuple2<String,DataSet<?>>> |
GSAConfiguration.getSumBcastVars()
Get the broadcast variables of the SumFunction.
|
Modifier and Type | Class and Description |
---|---|
static class |
Summarization.EdgeValue<EV>
Value that is stored at a summarized edge.
|
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.
|
Modifier and Type | Method and Description |
---|---|
List<Tuple2<String,DataSet<?>>> |
VertexCentricConfiguration.getBcastVars()
Get the broadcast variables of the compute function.
|
Modifier and Type | Method and Description |
---|---|
List<Tuple2<String,DataSet<?>>> |
ScatterGatherConfiguration.getGatherBcastVars()
Get the broadcast variables of the GatherFunction.
|
List<Tuple2<String,DataSet<?>>> |
ScatterGatherConfiguration.getScatterBcastVars()
Get the broadcast variables of the ScatterFunction.
|
Modifier and Type | Method and Description |
---|---|
Tuple2<K,K> |
EdgeToTuple2Map.map(Edge<K,EV> edge) |
Tuple2<K,VV> |
VertexToTuple2Map.map(Vertex<K,VV> vertex) |
Modifier and Type | Method and Description |
---|---|
Edge<K,NullValue> |
Tuple2ToEdgeMap.map(Tuple2<K,K> tuple) |
Vertex<K,VV> |
Tuple2ToVertexMap.map(Tuple2<K,VV> tuple) |
Modifier and Type | Method and Description |
---|---|
TypeInformation<Tuple2<KEYOUT,VALUEOUT>> |
HadoopReduceCombineFunction.getProducedType() |
TypeInformation<Tuple2<KEYOUT,VALUEOUT>> |
HadoopMapFunction.getProducedType() |
TypeInformation<Tuple2<KEYOUT,VALUEOUT>> |
HadoopReduceFunction.getProducedType() |
Modifier and Type | Method and Description |
---|---|
void |
HadoopMapFunction.flatMap(Tuple2<KEYIN,VALUEIN> value,
Collector<Tuple2<KEYOUT,VALUEOUT>> out) |
Modifier and Type | Method and Description |
---|---|
void |
HadoopReduceCombineFunction.combine(Iterable<Tuple2<KEYIN,VALUEIN>> values,
Collector<Tuple2<KEYIN,VALUEIN>> out) |
void |
HadoopReduceCombineFunction.combine(Iterable<Tuple2<KEYIN,VALUEIN>> values,
Collector<Tuple2<KEYIN,VALUEIN>> out) |
void |
HadoopMapFunction.flatMap(Tuple2<KEYIN,VALUEIN> value,
Collector<Tuple2<KEYOUT,VALUEOUT>> out) |
void |
HadoopReduceCombineFunction.reduce(Iterable<Tuple2<KEYIN,VALUEIN>> values,
Collector<Tuple2<KEYOUT,VALUEOUT>> out) |
void |
HadoopReduceCombineFunction.reduce(Iterable<Tuple2<KEYIN,VALUEIN>> values,
Collector<Tuple2<KEYOUT,VALUEOUT>> out) |
void |
HadoopReduceFunction.reduce(Iterable<Tuple2<KEYIN,VALUEIN>> values,
Collector<Tuple2<KEYOUT,VALUEOUT>> out) |
void |
HadoopReduceFunction.reduce(Iterable<Tuple2<KEYIN,VALUEIN>> values,
Collector<Tuple2<KEYOUT,VALUEOUT>> out) |
Modifier and Type | Method and Description |
---|---|
void |
HadoopTupleUnwrappingIterator.set(Iterator<Tuple2<KEY,VALUE>> iterator)
Set the Flink iterator to wrap.
|
void |
HadoopOutputCollector.setFlinkCollector(Collector<Tuple2<KEY,VALUE>> flinkCollector)
Set the wrapped Flink collector.
|
Modifier and Type | Method and Description |
---|---|
List<Tuple2<RetrievableStateHandle<T>,String>> |
KubernetesStateHandleStore.getAllAndLock()
Gets all available state handles from Kubernetes.
|
Modifier and Type | Method and Description |
---|---|
static Tuple2<Long,Long> |
OrcShimV200.getOffsetAndLengthForSplit(long splitStart,
long splitLength,
List<org.apache.orc.StripeInformation> stripes) |
Modifier and Type | Method and Description |
---|---|
Tuple2<byte[],Integer> |
PythonFunctionRunner.pollResult()
Retrieves the Python function result.
|
Tuple2<byte[],Integer> |
PythonFunctionRunner.takeResult()
Retrieves the Python function result, waiting if necessary until an element becomes
available.
|
Modifier and Type | Method and Description |
---|---|
static Tuple2<List<Transformation<?>>,Transformation<?>> |
PythonOperatorChainingOptimizer.optimize(List<Transformation<?>> transformations,
Transformation<?> targetTransformation)
Perform chaining optimization.
|
Modifier and Type | Method and Description |
---|---|
static Configuration |
PythonDependencyUtils.configurePythonDependencies(List<Tuple2<String,DistributedCache.DistributedCacheEntry>> cachedFiles,
Configuration config)
Adds python dependencies to registered cache file list according to given configuration and
returns a new configuration which contains the metadata of the registered python
dependencies.
|
Modifier and Type | Method and Description |
---|---|
static <K,N> Tuple2<K,N> |
KvStateSerializer.deserializeKeyAndNamespace(byte[] serializedKeyAndNamespace,
TypeSerializer<K> keySerializer,
TypeSerializer<N> namespaceSerializer)
Deserializes the key and namespace into a
Tuple2 . |
Modifier and Type | Method and Description |
---|---|
List<Tuple2<JobID,BlobKey>> |
BlobCacheSizeTracker.checkLimit(long size)
Check the size limit and return the BLOBs to delete.
|
Modifier and Type | Method and Description |
---|---|
void |
BlobCacheSizeTracker.untrack(Tuple2<JobID,BlobKey> key)
Remove the BLOB from the tracker.
|
Modifier and Type | Method and Description |
---|---|
static void |
ClientUtils.uploadJobGraphFiles(JobGraph jobGraph,
Collection<Path> userJars,
Collection<Tuple2<String,Path>> userArtifacts,
SupplierWithException<BlobClient,IOException> clientSupplier)
Uploads the given jars and artifacts required for the execution of the given
JobGraph
using the BlobClient from the given Supplier . |
Modifier and Type | Method and Description |
---|---|
protected List<Tuple2<RestHandlerSpecification,org.apache.flink.shaded.netty4.io.netty.channel.ChannelInboundHandler>> |
DispatcherRestEndpoint.initializeHandlers(CompletableFuture<String> localAddressFuture) |
protected Collection<Tuple2<RestHandlerSpecification,org.apache.flink.shaded.netty4.io.netty.channel.ChannelInboundHandler>> |
DispatcherRestEndpoint.initializeWebSubmissionHandlers(CompletableFuture<String> localAddressFuture) |
CompletableFuture<Collection<Tuple2<ResourceID,String>>> |
Dispatcher.requestTaskManagerMetricQueryServiceAddresses(Time timeout) |
Modifier and Type | Method and Description |
---|---|
static Tuple2<String,Integer> |
HighAvailabilityServicesUtils.getJobManagerAddress(Configuration configuration)
Returns the JobManager's hostname and port extracted from the given
Configuration . |
Modifier and Type | Method and Description |
---|---|
static Tuple2<TaskManagerMetricGroup,MetricGroup> |
MetricUtils.instantiateTaskManagerMetricGroup(MetricRegistry metricRegistry,
String hostName,
ResourceID resourceID,
Optional<Time> systemResourceProbeInterval) |
Modifier and Type | Method and Description |
---|---|
T |
RemoveRangeIndex.map(Tuple2<Integer,T> value) |
Modifier and Type | Method and Description |
---|---|
void |
AssignRangeIndex.mapPartition(Iterable<IN> values,
Collector<Tuple2<Integer,IN>> out) |
Modifier and Type | Method and Description |
---|---|
List<Tuple2<RetrievableStateHandle<T>,String>> |
StateHandleStore.getAllAndLock()
Gets all available state handles from the storage.
|
Modifier and Type | Method and Description |
---|---|
CompletableFuture<Collection<Tuple2<ResourceID,String>>> |
ResourceManagerGateway.requestTaskManagerMetricQueryServiceAddresses(Time timeout)
Requests the paths for the TaskManager's
MetricQueryService to query. |
CompletableFuture<Collection<Tuple2<ResourceID,String>>> |
ResourceManager.requestTaskManagerMetricQueryServiceAddresses(Time timeout) |
Modifier and Type | Method and Description |
---|---|
protected abstract List<Tuple2<RestHandlerSpecification,org.apache.flink.shaded.netty4.io.netty.channel.ChannelInboundHandler>> |
RestServerEndpoint.initializeHandlers(CompletableFuture<String> localAddressFuture)
This method is called at the beginning of
RestServerEndpoint.start() to setup all handlers that the
REST server endpoint implementation requires. |
Modifier and Type | Method and Description |
---|---|
int |
RestServerEndpoint.RestHandlerUrlComparator.compare(Tuple2<RestHandlerSpecification,org.apache.flink.shaded.netty4.io.netty.channel.ChannelInboundHandler> o1,
Tuple2<RestHandlerSpecification,org.apache.flink.shaded.netty4.io.netty.channel.ChannelInboundHandler> o2) |
int |
RestServerEndpoint.RestHandlerUrlComparator.compare(Tuple2<RestHandlerSpecification,org.apache.flink.shaded.netty4.io.netty.channel.ChannelInboundHandler> o1,
Tuple2<RestHandlerSpecification,org.apache.flink.shaded.netty4.io.netty.channel.ChannelInboundHandler> o2) |
Modifier and Type | Method and Description |
---|---|
protected CompletableFuture<TransientBlobKey> |
TaskManagerCustomLogHandler.requestFileUpload(ResourceManagerGateway resourceManagerGateway,
Tuple2<ResourceID,String> taskManagerIdAndFileName) |
protected abstract CompletableFuture<TransientBlobKey> |
AbstractTaskManagerFileHandler.requestFileUpload(ResourceManagerGateway resourceManagerGateway,
Tuple2<ResourceID,String> taskManagerIdAndFileName) |
protected CompletableFuture<TransientBlobKey> |
TaskManagerStdoutFileHandler.requestFileUpload(ResourceManagerGateway resourceManagerGateway,
Tuple2<ResourceID,String> taskManagerIdAndFileName) |
protected CompletableFuture<TransientBlobKey> |
TaskManagerLogFileHandler.requestFileUpload(ResourceManagerGateway resourceManagerGateway,
Tuple2<ResourceID,String> taskManagerIdAndFileName) |
Modifier and Type | Method and Description |
---|---|
<N> java.util.stream.Stream<Tuple2<K,N>> |
KeyedStateBackend.getKeysAndNamespaces(String state) |
Iterator<Tuple2<Integer,Long>> |
KeyGroupRangeOffsets.iterator() |
Modifier and Type | Method and Description |
---|---|
List<Tuple2<StreamStateHandle,Long>> |
ChangelogStateHandleStreamImpl.getHandlesAndOffsets() |
Constructor and Description |
---|
ChangelogStateHandleStreamImpl(List<Tuple2<StreamStateHandle,Long>> handlesAndOffsets,
KeyGroupRange keyGroupRange,
long size) |
Modifier and Type | Method and Description |
---|---|
java.util.stream.Stream<Tuple2<K,N>> |
StateTable.getKeysAndNamespaces() |
<N> java.util.stream.Stream<Tuple2<K,N>> |
HeapKeyedStateBackend.getKeysAndNamespaces(String state) |
Modifier and Type | Method and Description |
---|---|
Collection<Tuple2<RestHandlerSpecification,org.apache.flink.shaded.netty4.io.netty.channel.ChannelInboundHandler>> |
WebSubmissionExtension.getHandlers() |
Collection<Tuple2<RestHandlerSpecification,org.apache.flink.shaded.netty4.io.netty.channel.ChannelInboundHandler>> |
WebMonitorExtension.getHandlers()
Gets the collection of extension handlers to register at the
WebMonitorEndpoint . |
Collection<Tuple2<RestHandlerSpecification,org.apache.flink.shaded.netty4.io.netty.channel.ChannelInboundHandler>> |
WebMonitorExtension.EmptyWebMonitorExtension.getHandlers() |
protected List<Tuple2<RestHandlerSpecification,org.apache.flink.shaded.netty4.io.netty.channel.ChannelInboundHandler>> |
WebMonitorEndpoint.initializeHandlers(CompletableFuture<String> localAddressFuture) |
protected Collection<Tuple2<RestHandlerSpecification,org.apache.flink.shaded.netty4.io.netty.channel.ChannelInboundHandler>> |
WebMonitorEndpoint.initializeWebSubmissionHandlers(CompletableFuture<String> localAddressFuture) |
CompletableFuture<Collection<Tuple2<ResourceID,String>>> |
RestfulGateway.requestTaskManagerMetricQueryServiceAddresses(Time timeout)
Requests the addresses for the TaskManagers'
MetricQueryService to query. |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<Tuple2<String,UUID>> |
LeaderRetriever.getLeaderFuture()
Returns the current JobManagerGateway future.
|
Optional<Tuple2<String,UUID>> |
LeaderRetriever.getLeaderNow()
Returns the current leader information if available.
|
Modifier and Type | Method and Description |
---|---|
protected abstract CompletableFuture<T> |
LeaderGatewayRetriever.createGateway(CompletableFuture<Tuple2<String,UUID>> leaderFuture) |
protected void |
LeaderRetriever.notifyNewLeaderAddress(CompletableFuture<Tuple2<String,UUID>> newLeaderAddressFuture) |
void |
LeaderGatewayRetriever.notifyNewLeaderAddress(CompletableFuture<Tuple2<String,UUID>> newLeaderAddressFuture) |
Modifier and Type | Method and Description |
---|---|
protected CompletableFuture<T> |
RpcGatewayRetriever.createGateway(CompletableFuture<Tuple2<String,UUID>> leaderFuture) |
Modifier and Type | Method and Description |
---|---|
List<Tuple2<RetrievableStateHandle<T>,String>> |
ZooKeeperStateHandleStore.getAllAndLock()
Gets all available state handles from ZooKeeper and locks the respective state nodes.
|
Modifier and Type | Method and Description |
---|---|
<K,V> DataSource<Tuple2<K,V>> |
ExistingSavepoint.readBroadcastState(String uid,
String name,
TypeInformation<K> keyTypeInfo,
TypeInformation<V> valueTypeInfo)
Read operator
BroadcastState from a Savepoint . |
<K,V> DataSource<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 . |
Modifier and Type | Method and Description |
---|---|
protected Iterable<Tuple2<K,V>> |
BroadcastStateInputFormat.getElements(OperatorStateBackend restoredBackend) |
Modifier and Type | Method and Description |
---|---|
CloseableIterator<Tuple2<KEY,VoidNamespace>> |
KeyedStateReaderOperator.getKeysAndNamespaces(SavepointRuntimeContext ctx) |
abstract CloseableIterator<Tuple2<KEY,N>> |
StateReaderOperator.getKeysAndNamespaces(SavepointRuntimeContext ctx) |
CloseableIterator<Tuple2<KEY,W>> |
WindowReaderOperator.getKeysAndNamespaces(SavepointRuntimeContext ctx) |
Modifier and Type | Method and Description |
---|---|
<N> java.util.stream.Stream<Tuple2<K,N>> |
ChangelogKeyedStateBackend.getKeysAndNamespaces(String state) |
Modifier and Type | Method and Description |
---|---|
<T0,T1> SingleOutputStreamOperator<Tuple2<T0,T1>> |
StreamProjection.projectTuple2()
Projects a
Tuple DataStream to the previously selected fields. |
Modifier and Type | Field and Description |
---|---|
protected List<Tuple2<String,DistributedCache.DistributedCacheEntry>> |
StreamExecutionEnvironment.cacheFile |
Modifier and Type | Method and Description |
---|---|
List<Tuple2<String,DistributedCache.DistributedCacheEntry>> |
StreamExecutionEnvironment.getCachedFiles()
Get the list of cached files that were registered for distribution among the task managers.
|
Modifier and Type | Method and Description |
---|---|
long |
CustomTimestampAssigner.extractTimestamp(Tuple2<T,Long> element,
long recordTimestamp) |
T |
RemoveTimestampMapFunction.map(Tuple2<T,Long> value) |
Modifier and Type | Field and Description |
---|---|
protected ArrayDeque<Tuple2<Long,Set<UId>>> |
MessageAcknowledgingSourceBase.pendingCheckpoints
The list with IDs from checkpoints that were triggered, but not yet completed or notified of
completion.
|
protected Deque<Tuple2<Long,List<SessionId>>> |
MultipleIdsMessageAcknowledgingSourceBase.sessionIdsPerSnapshot |
Modifier and Type | Method and Description |
---|---|
Tuple2<StreamNode,StreamNode> |
StreamGraph.createIterationSourceAndSink(int loopId,
int sourceId,
int sinkId,
long timeout,
int parallelism,
int maxParallelism,
ResourceSpec minResources,
ResourceSpec preferredResources) |
Modifier and Type | Method and Description |
---|---|
Set<Tuple2<Integer,StreamOperatorFactory<?>>> |
StreamGraph.getAllOperatorFactory() |
Set<Tuple2<StreamNode,StreamNode>> |
StreamGraph.getIterationSourceSinkPairs() |
Collection<Tuple2<String,DistributedCache.DistributedCacheEntry>> |
StreamGraph.getUserArtifacts() |
Modifier and Type | Method and Description |
---|---|
void |
StreamGraph.setUserArtifacts(Collection<Tuple2<String,DistributedCache.DistributedCacheEntry>> userArtifacts) |
StreamGraphGenerator |
StreamGraphGenerator.setUserArtifacts(Collection<Tuple2<String,DistributedCache.DistributedCacheEntry>> userArtifacts) |
Modifier and Type | Method and Description |
---|---|
static <OUT,OP extends StreamOperator<OUT>> |
StreamOperatorFactoryUtil.createOperator(StreamOperatorFactory<OUT> operatorFactory,
StreamTask<OUT,?> containingTask,
StreamConfig configuration,
Output<StreamRecord<OUT>> output,
OperatorEventDispatcher operatorEventDispatcher)
Creates a new operator using a factory and makes sure that all special factory traits are
properly handled.
|
Modifier and Type | Method and Description |
---|---|
static Tuple2<Long,CollectCoordinationResponse> |
CollectSinkFunction.deserializeAccumulatorResult(byte[] serializedAccResults) |
Modifier and Type | Method and Description |
---|---|
void |
AbstractOneInputPythonFunctionOperator.emitResult(Tuple2<byte[],Integer> resultTuple) |
void |
AbstractTwoInputPythonFunctionOperator.emitResult(Tuple2<byte[],Integer> resultTuple) |
abstract void |
AbstractPythonFunctionOperator.emitResult(Tuple2<byte[],Integer> resultTuple)
Sends the execution result to the downstream operator.
|
Modifier and Type | Method and Description |
---|---|
<N> java.util.stream.Stream<Tuple2<K,N>> |
BatchExecutionKeyedStateBackend.getKeysAndNamespaces(String state) |
Modifier and Type | Method and Description |
---|---|
Tuple2<byte[],Integer> |
BeamPythonFunctionRunner.pollResult() |
Tuple2<byte[],Integer> |
BeamPythonFunctionRunner.takeResult() |
Modifier and Type | Method and Description |
---|---|
Tuple2<Tuple2<Integer,Integer>,Integer> |
IterateExample.OutputMap.map(Tuple5<Integer,Integer,Integer,Integer,Integer> value) |
Modifier and Type | Method and Description |
---|---|
Tuple2<Tuple2<Integer,Integer>,Integer> |
IterateExample.OutputMap.map(Tuple5<Integer,Integer,Integer,Integer,Integer> value) |
Modifier and Type | Method and Description |
---|---|
Tuple5<Integer,Integer,Integer,Integer,Integer> |
IterateExample.InputMap.map(Tuple2<Integer,Integer> value) |
Modifier and Type | Method and Description |
---|---|
Tuple2<String,Integer> |
WindowJoinSampleData.GradeSource.next() |
Tuple2<String,Integer> |
WindowJoinSampleData.SalarySource.next() |
Modifier and Type | Method and Description |
---|---|
static DataStream<Tuple2<String,Integer>> |
WindowJoinSampleData.GradeSource.getSource(StreamExecutionEnvironment env,
long rate) |
static DataStream<Tuple2<String,Integer>> |
WindowJoinSampleData.SalarySource.getSource(StreamExecutionEnvironment env,
long rate) |
Modifier and Type | Method and Description |
---|---|
static DataStream<Tuple3<String,Integer,Integer>> |
WindowJoin.runWindowJoin(DataStream<Tuple2<String,Integer>> grades,
DataStream<Tuple2<String,Integer>> salaries,
long windowSize) |
static DataStream<Tuple3<String,Integer,Integer>> |
WindowJoin.runWindowJoin(DataStream<Tuple2<String,Integer>> grades,
DataStream<Tuple2<String,Integer>> salaries,
long windowSize) |
Modifier and Type | Method and Description |
---|---|
void |
SideOutputExample.Tokenizer.processElement(String value,
ProcessFunction.Context ctx,
Collector<Tuple2<String,Integer>> out) |
Modifier and Type | Method and Description |
---|---|
void |
TwitterExample.SelectEnglishAndTokenizeFlatMap.flatMap(String value,
Collector<Tuple2<String,Integer>> out)
Select the language from the incoming JSON text.
|
Modifier and Type | Method and Description |
---|---|
void |
WordCount.Tokenizer.flatMap(String value,
Collector<Tuple2<String,Integer>> out) |
Constructor and Description |
---|
MergingWindowSet(MergingWindowAssigner<?,W> windowAssigner,
ListState<Tuple2<W,W>> state)
Restores a
MergingWindowSet from the given state. |
Modifier and Type | Method and Description |
---|---|
void |
SlidingWindowCheckMapper.flatMap(Tuple2<Integer,List<Event>> value,
Collector<String> out) |
Modifier and Type | Method and Description |
---|---|
Tuple2<K,V> |
TypeInformationKeyValueSerializationSchema.deserialize(org.apache.kafka.clients.consumer.ConsumerRecord<byte[],byte[]> record) |
Modifier and Type | Method and Description |
---|---|
TypeInformation<Tuple2<K,V>> |
TypeInformationKeyValueSerializationSchema.getProducedType() |
Modifier and Type | Method and Description |
---|---|
String |
TypeInformationKeyValueSerializationSchema.getTargetTopic(Tuple2<K,V> element) |
boolean |
TypeInformationKeyValueSerializationSchema.isEndOfStream(Tuple2<K,V> nextElement)
This schema never considers an element to signal end-of-stream, so this method returns always
false.
|
byte[] |
TypeInformationKeyValueSerializationSchema.serializeKey(Tuple2<K,V> element) |
byte[] |
TypeInformationKeyValueSerializationSchema.serializeValue(Tuple2<K,V> element) |
Modifier and Type | Method and Description |
---|---|
<T> DataStream<Tuple2<Boolean,T>> |
StreamTableEnvironment.toRetractStream(Table table,
Class<T> clazz)
Deprecated.
Use
StreamTableEnvironment.toChangelogStream(Table, Schema) instead. It integrates with the new
type system and supports all kinds of DataTypes and every ChangelogMode
that the table runtime can produce. |
<T> DataStream<Tuple2<Boolean,T>> |
StreamTableEnvironment.toRetractStream(Table table,
TypeInformation<T> typeInfo)
Deprecated.
Use
StreamTableEnvironment.toChangelogStream(Table, Schema) instead. It integrates with the new
type system and supports all kinds of DataTypes and every ChangelogMode
that the table runtime can produce. |
Modifier and Type | Method and Description |
---|---|
<T> DataStream<Tuple2<Boolean,T>> |
StreamTableEnvironmentImpl.toRetractStream(Table table,
Class<T> clazz) |
<T> DataStream<Tuple2<Boolean,T>> |
StreamTableEnvironmentImpl.toRetractStream(Table table,
TypeInformation<T> typeInfo) |
Modifier and Type | Field and Description |
---|---|
protected static List<Tuple2<String,Long>> |
CliResultView.REFRESH_INTERVALS |
Modifier and Type | Method and Description |
---|---|
static List<org.jline.utils.AttributedString> |
CliUtils.formatTwoLineHelpOptions(int width,
List<Tuple2<String,String>> options) |
Modifier and Type | Method and Description |
---|---|
static Optional<Tuple2<TimestampExtractor,WatermarkStrategy>> |
RowtimeValidator.getRowtimeComponents(DescriptorProperties properties,
String prefix)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
List<Tuple2<P,T>> |
ContinuousPartitionFetcher.fetchPartitions(ContinuousPartitionFetcher.Context<P,T> context,
T previousOffset)
Fetch partitions by previous partition offset (Including).
|
Modifier and Type | Method and Description |
---|---|
static Tuple2<String,String> |
HiveParserBaseSemanticAnalyzer.charSetString(String charSetName,
String charSetString) |
Modifier and Type | Method and Description |
---|---|
static Tuple2<Pattern<RowData,RowData>,List<String>> |
StreamExecMatch.translatePattern(MatchSpec matchSpec,
TableConfig config,
org.apache.calcite.tools.RelBuilder relBuilder,
RowType inputRowType) |
Modifier and Type | Method and Description |
---|---|
static Tuple2<PythonAggregateFunctionInfo[],DataViewUtils.DataViewSpec[][]> |
CommonPythonUtil.extractPythonAggregateFunctionInfos(org.apache.flink.table.planner.plan.utils.AggregateInfoList pythonAggregateInfoList,
org.apache.calcite.rel.core.AggregateCall[] aggCalls) |
static Tuple2<int[],PythonFunctionInfo[]> |
CommonPythonUtil.extractPythonAggregateFunctionInfosFromAggregateCall(org.apache.calcite.rel.core.AggregateCall[] aggCalls) |
Modifier and Type | Method and Description |
---|---|
List<Tuple2<String,DistributedCache.DistributedCacheEntry>> |
DummyStreamExecutionEnvironment.getCachedFiles() |
Modifier and Type | Method and Description |
---|---|
Iterable<Tuple2<RowData,Integer>> |
OuterJoinRecordStateView.getRecordsAndNumOfAssociations()
Gets all the records and number of associations under the current context (i.e.
|
Modifier and Type | Method and Description |
---|---|
void |
PythonStreamGroupWindowAggregateOperator.emitResult(Tuple2<byte[],Integer> resultTuple) |
void |
AbstractPythonStreamGroupAggregateOperator.emitResult(Tuple2<byte[],Integer> resultTuple) |
Modifier and Type | Method and Description |
---|---|
void |
BatchArrowPythonGroupWindowAggregateFunctionOperator.emitResult(Tuple2<byte[],Integer> resultTuple) |
void |
BatchArrowPythonGroupAggregateFunctionOperator.emitResult(Tuple2<byte[],Integer> resultTuple) |
void |
BatchArrowPythonOverWindowAggregateFunctionOperator.emitResult(Tuple2<byte[],Integer> resultTuple) |
Modifier and Type | Method and Description |
---|---|
void |
StreamArrowPythonGroupWindowAggregateFunctionOperator.emitResult(Tuple2<byte[],Integer> resultTuple) |
void |
AbstractStreamArrowPythonBoundedRowsOperator.emitResult(Tuple2<byte[],Integer> resultTuple) |
void |
AbstractStreamArrowPythonBoundedRangeOperator.emitResult(Tuple2<byte[],Integer> resultTuple) |
Modifier and Type | Method and Description |
---|---|
void |
PythonScalarFunctionOperator.emitResult(Tuple2<byte[],Integer> resultTuple) |
Modifier and Type | Method and Description |
---|---|
void |
ArrowPythonScalarFunctionOperator.emitResult(Tuple2<byte[],Integer> resultTuple) |
Modifier and Type | Method and Description |
---|---|
void |
PythonTableFunctionOperator.emitResult(Tuple2<byte[],Integer> resultTuple) |
Modifier and Type | Method and Description |
---|---|
Tuple2<K,V> |
ChannelReaderKVInputViewIterator.next() |
Tuple2<K,V> |
ChannelReaderKVInputViewIterator.next(Tuple2<K,V> kvPair) |
Modifier and Type | Method and Description |
---|---|
protected MutableObjectIterator<Tuple2<BinaryRowData,BinaryRowData>> |
BinaryKVExternalMerger.channelReaderInputViewIterator(AbstractChannelReaderInputView inView) |
MutableObjectIterator<Tuple2<BinaryRowData,BinaryRowData>> |
BinaryKVInMemorySortBuffer.getIterator()
Gets an iterator over all KV records in this buffer in their logical order.
|
MutableObjectIterator<Tuple2<BinaryRowData,BinaryRowData>> |
BufferedKVExternalSorter.getKVIterator() |
protected Comparator<Tuple2<BinaryRowData,BinaryRowData>> |
BinaryKVExternalMerger.mergeComparator() |
protected List<Tuple2<BinaryRowData,BinaryRowData>> |
BinaryKVExternalMerger.mergeReusedEntries(int size) |
Modifier and Type | Method and Description |
---|---|
Tuple2<K,V> |
ChannelReaderKVInputViewIterator.next(Tuple2<K,V> kvPair) |
Modifier and Type | Method and Description |
---|---|
protected void |
BinaryKVExternalMerger.writeMergingOutput(MutableObjectIterator<Tuple2<BinaryRowData,BinaryRowData>> mergeIterator,
AbstractPagedOutputView output) |
Modifier and Type | Method and Description |
---|---|
default TypeInformation<Tuple2<Boolean,T>> |
RetractStreamTableSink.getOutputType()
Deprecated.
|
default TypeInformation<Tuple2<Boolean,T>> |
UpsertStreamTableSink.getOutputType()
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
static List<Tuple2<LinkedHashMap<String,String>,Path>> |
PartitionPathUtils.searchPartSpecAndPaths(FileSystem fs,
Path path,
int partitionNumber)
Search all partitions in this path.
|
Modifier and Type | Method and Description |
---|---|
static void |
ConnectedComponentsData.checkOddEvenResult(List<Tuple2<Long,Long>> lines) |
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.