K
- ID typeVV
- vertex value typeEV
- edge value typepublic class VertexDegree<K,VV,EV> extends GraphAlgorithmWrappingDataSet<K,VV,EV,Vertex<K,LongValue>>
parallelism
Constructor and Description |
---|
VertexDegree() |
Modifier and Type | Method and Description |
---|---|
protected boolean |
canMergeConfigurationWith(GraphAlgorithmWrappingBase other)
First test whether the algorithm configurations can be merged before the
call to
GraphAlgorithmWrappingBase.mergeConfiguration(org.apache.flink.graph.utils.proxy.GraphAlgorithmWrappingBase) . |
protected void |
mergeConfiguration(GraphAlgorithmWrappingBase other)
Merge the other configuration into this algorithm's after the call to
GraphAlgorithmWrappingBase.canMergeConfigurationWith(org.apache.flink.graph.utils.proxy.GraphAlgorithmWrappingBase) has checked that the configurations
can be merged. |
DataSet<Vertex<K,LongValue>> |
runInternal(Graph<K,VV,EV> input)
The implementation of the algorithm, renamed from
GraphAlgorithm.run(Graph) . |
VertexDegree<K,VV,EV> |
setIncludeZeroDegreeVertices(boolean includeZeroDegreeVertices)
By default only the edge set is processed for the computation of degree.
|
VertexDegree<K,VV,EV> |
setReduceOnTargetId(boolean reduceOnTargetId)
The degree can be counted from either the edge source or target IDs.
|
equals, hashCode, run
getAlgorithmName, setParallelism
public VertexDegree<K,VV,EV> setIncludeZeroDegreeVertices(boolean includeZeroDegreeVertices)
includeZeroDegreeVertices
- whether to output vertices with a
degree of zeropublic VertexDegree<K,VV,EV> setReduceOnTargetId(boolean reduceOnTargetId)
reduceOnTargetId
- set to true
if the input edge list
is sorted by target IDprotected boolean canMergeConfigurationWith(GraphAlgorithmWrappingBase other)
GraphAlgorithmWrappingBase
GraphAlgorithmWrappingBase.mergeConfiguration(org.apache.flink.graph.utils.proxy.GraphAlgorithmWrappingBase)
.canMergeConfigurationWith
in class GraphAlgorithmWrappingBase<K,VV,EV,DataSet<Vertex<K,LongValue>>>
other
- the algorithm with which to compare configurationGraphAlgorithmWrappingBase.mergeConfiguration(GraphAlgorithmWrappingBase)
protected void mergeConfiguration(GraphAlgorithmWrappingBase other)
GraphAlgorithmWrappingBase
GraphAlgorithmWrappingBase.canMergeConfigurationWith(org.apache.flink.graph.utils.proxy.GraphAlgorithmWrappingBase)
has checked that the configurations
can be merged.mergeConfiguration
in class GraphAlgorithmWrappingBase<K,VV,EV,DataSet<Vertex<K,LongValue>>>
other
- the algorithm from which to merge configurationGraphAlgorithmWrappingBase.canMergeConfigurationWith(GraphAlgorithmWrappingBase)
public DataSet<Vertex<K,LongValue>> runInternal(Graph<K,VV,EV> input) throws Exception
GraphAlgorithmWrappingDataSet
GraphAlgorithm.run(Graph)
.runInternal
in class GraphAlgorithmWrappingDataSet<K,VV,EV,Vertex<K,LongValue>>
input
- the input graphException
Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.