Modifier and Type | Method and Description |
---|---|
LongValue |
LongSumAggregator.getAggregate() |
Modifier and Type | Method and Description |
---|---|
void |
LongSumAggregator.aggregate(LongValue element) |
boolean |
LongZeroConvergence.isConverged(int iteration,
LongValue value)
Returns true, if the aggregator value is zero, false otherwise.
|
Modifier and Type | Method and Description |
---|---|
LongValue |
BulkIterationBase.TerminationCriterionAggregator.getAggregate() |
Modifier and Type | Method and Description |
---|---|
void |
BulkIterationBase.TerminationCriterionAggregator.aggregate(LongValue count) |
boolean |
BulkIterationBase.TerminationCriterionAggregationConvergence.isConverged(int iteration,
LongValue countAggregate) |
Modifier and Type | Method and Description |
---|---|
LongValue |
LongValueSerializer.copy(LongValue from) |
LongValue |
LongValueSerializer.copy(LongValue from,
LongValue reuse) |
LongValue |
LongValueSerializer.createInstance() |
LongValue |
LongValueSerializer.deserialize(DataInputView source) |
LongValue |
LongValueSerializer.deserialize(LongValue reuse,
DataInputView source) |
LongValue |
LongValueComparator.readWithKeyDenormalization(LongValue reuse,
DataInputView source) |
Modifier and Type | Method and Description |
---|---|
TypeComparator<LongValue> |
LongValueComparator.duplicate() |
TypeSerializerSnapshot<LongValue> |
LongValueSerializer.snapshotConfiguration() |
Modifier and Type | Method and Description |
---|---|
int |
LongValueComparator.compare(LongValue first,
LongValue second) |
LongValue |
LongValueSerializer.copy(LongValue from) |
LongValue |
LongValueSerializer.copy(LongValue from,
LongValue reuse) |
LongValue |
LongValueSerializer.deserialize(LongValue reuse,
DataInputView source) |
boolean |
LongValueComparator.equalToReference(LongValue candidate) |
int |
LongValueComparator.hash(LongValue record) |
void |
LongValueComparator.putNormalizedKey(LongValue record,
MemorySegment target,
int offset,
int numBytes) |
LongValue |
LongValueComparator.readWithKeyDenormalization(LongValue reuse,
DataInputView source) |
void |
LongValueSerializer.serialize(LongValue record,
DataOutputView target) |
void |
LongValueComparator.setReference(LongValue toCompare) |
void |
LongValueComparator.writeWithKeyNormalization(LongValue record,
DataOutputView target) |
Modifier and Type | Method and Description |
---|---|
int |
LongValueComparator.compareToReference(TypeComparator<LongValue> referencedComparator) |
Modifier and Type | Method and Description |
---|---|
protected Long |
ValueSummaryAggregator.LongValueSummaryAggregator.getValue(LongValue value) |
Modifier and Type | Field and Description |
---|---|
static ValueTypeInfo<LongValue> |
ValueTypeInfo.LONG_VALUE_TYPE_INFO |
Modifier and Type | Method and Description |
---|---|
DataSet<Tuple2<K,LongValue>> |
Graph.getDegrees()
Return the degree of all vertices in the graph.
|
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.
|
Modifier and Type | Method and Description |
---|---|
Vertex<K,LongValue> |
DegreeAnnotationFunctions.JoinVertexWithVertexDegree.join(Vertex<K,VV> vertex,
Vertex<K,LongValue> vertexDegree) |
Vertex<K,LongValue> |
DegreeAnnotationFunctions.MapEdgeToSourceId.map(Edge<K,EV> value) |
Vertex<K,LongValue> |
DegreeAnnotationFunctions.MapEdgeToTargetId.map(Edge<K,EV> value) |
Vertex<K,LongValue> |
DegreeAnnotationFunctions.DegreeCount.reduce(Vertex<K,LongValue> left,
Vertex<K,LongValue> right) |
Modifier and Type | Method and Description |
---|---|
Vertex<K,LongValue> |
DegreeAnnotationFunctions.JoinVertexWithVertexDegree.join(Vertex<K,VV> vertex,
Vertex<K,LongValue> vertexDegree) |
Vertex<K,LongValue> |
DegreeAnnotationFunctions.DegreeCount.reduce(Vertex<K,LongValue> left,
Vertex<K,LongValue> right) |
Vertex<K,LongValue> |
DegreeAnnotationFunctions.DegreeCount.reduce(Vertex<K,LongValue> left,
Vertex<K,LongValue> right) |
Modifier and Type | Method and Description |
---|---|
LongValue |
VertexDegrees.Degrees.getDegree() |
LongValue |
VertexDegrees.Degrees.getInDegree() |
LongValue |
VertexDegrees.Degrees.getOutDegree() |
Modifier and Type | Method and Description |
---|---|
DataSet<Vertex<K,LongValue>> |
VertexInDegree.runInternal(Graph<K,VV,EV> input) |
DataSet<Vertex<K,LongValue>> |
VertexOutDegree.runInternal(Graph<K,VV,EV> input) |
Constructor and Description |
---|
Degrees(LongValue value0,
LongValue value1,
LongValue value2) |
Modifier and Type | Method and Description |
---|---|
DataSet<Edge<K,Tuple2<EV,LongValue>>> |
EdgeTargetDegree.runInternal(Graph<K,VV,EV> input) |
DataSet<Edge<K,Tuple3<EV,LongValue,LongValue>>> |
EdgeDegreePair.runInternal(Graph<K,VV,EV> input) |
DataSet<Edge<K,Tuple3<EV,LongValue,LongValue>>> |
EdgeDegreePair.runInternal(Graph<K,VV,EV> input) |
DataSet<Vertex<K,LongValue>> |
VertexDegree.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 |
---|---|
LongValue |
LongToLongValue.translate(Long value,
LongValue reuse) |
LongValue |
LongValueAddOffset.translate(LongValue value,
LongValue reuse) |
Modifier and Type | Method and Description |
---|---|
LongValue |
LongToLongValue.translate(Long value,
LongValue reuse) |
IntValue |
LongValueToSignedIntValue.translate(LongValue value,
IntValue reuse) |
IntValue |
LongValueToUnsignedIntValue.translate(LongValue value,
IntValue reuse) |
LongValue |
LongValueAddOffset.translate(LongValue value,
LongValue reuse) |
StringValue |
LongValueToStringValue.translate(LongValue value,
StringValue reuse) |
Modifier and Type | Class and Description |
---|---|
class |
LongValueWithProperHashCode
Fix for
hashCode() . |
Modifier and Type | Method and Description |
---|---|
Graph<?,VV,EV> |
GraphKeyTypeTransform.transformInput(Graph<LongValue,VV,EV> input) |
Modifier and Type | Method and Description |
---|---|
Graph<LongValue,NullValue,NullValue> |
EchoGraph.generate() |
Graph<LongValue,NullValue,NullValue> |
StarGraph.generate() |
Graph<LongValue,NullValue,NullValue> |
RMatGraph.generate() |
Graph<LongValue,NullValue,NullValue> |
HypercubeGraph.generate() |
Graph<LongValue,NullValue,NullValue> |
CompleteGraph.generate() |
Graph<LongValue,NullValue,NullValue> |
CycleGraph.generate() |
Graph<LongValue,NullValue,NullValue> |
SingletonEdgeGraph.generate() |
Graph<LongValue,NullValue,NullValue> |
EmptyGraph.generate() |
Graph<LongValue,NullValue,NullValue> |
PathGraph.generate() |
Graph<LongValue,NullValue,NullValue> |
GridGraph.generate() |
Graph<LongValue,NullValue,NullValue> |
CirculantGraph.generate() |
static DataSet<Vertex<LongValue,NullValue>> |
GraphGeneratorUtils.vertexSequence(ExecutionEnvironment env,
int parallelism,
long vertexCount)
Generates
Vertices with sequential, numerical labels. |
Modifier and Type | Method and Description |
---|---|
LongValue |
LocalClusteringCoefficient.Result.getDegree()
Get the vertex degree.
|
LongValue |
LocalClusteringCoefficient.Result.getTriangleCount()
Get the number of triangles containing this vertex; equivalently,
this is the number of edges between neighbors of this vertex.
|
Modifier and Type | Method and Description |
---|---|
void |
LocalClusteringCoefficient.Result.setDegree(LongValue degree)
Set the vertex degree.
|
void |
LocalClusteringCoefficient.Result.setTriangleCount(LongValue triangleCount)
Set the number of triangles containing this vertex; equivalently,
this is the number of edges between neighbors of this vertex.
|
Modifier and Type | Method and Description |
---|---|
LongValue |
LocalClusteringCoefficient.Result.getDegree()
Get the vertex degree.
|
LongValue |
LocalClusteringCoefficient.Result.getTriangleCount()
Get the number of triangles containing this vertex; equivalently,
this is the number of edges between neighbors of this vertex.
|
Modifier and Type | Method and Description |
---|---|
void |
LocalClusteringCoefficient.Result.setDegree(LongValue degree)
Set the vertex degree.
|
void |
LocalClusteringCoefficient.Result.setTriangleCount(LongValue triangleCount)
Set the number of triangles containing this vertex; equivalently,
this is the number of edges between neighbors of this vertex.
|
Modifier and Type | Field and Description |
---|---|
static ValueArrayTypeInfo<LongValue> |
ValueArrayTypeInfo.LONG_VALUE_ARRAY_TYPE_INFO |
Modifier and Type | Method and Description |
---|---|
ValueArray<LongValue> |
LongValueArray.copy() |
Iterator<LongValue> |
LongValueArray.iterator() |
Modifier and Type | Method and Description |
---|---|
boolean |
LongValueArray.add(LongValue value) |
Modifier and Type | Method and Description |
---|---|
boolean |
LongValueArray.addAll(ValueArray<LongValue> other) |
int |
LongValueArray.compareTo(ValueArray<LongValue> o) |
void |
LongValueArray.copyTo(ValueArray<LongValue> target) |
void |
LongValueArray.setValue(ValueArray<LongValue> value) |
Modifier and Type | Method and Description |
---|---|
LongValue |
GraphUtils.AddLongValue.reduce(LongValue value1,
LongValue value2) |
Modifier and Type | Method and Description |
---|---|
static <T> DataSet<LongValue> |
GraphUtils.count(DataSet<T> input)
Count the number of elements in a DataSet.
|
Modifier and Type | Method and Description |
---|---|
LongValue |
GraphUtils.AddLongValue.reduce(LongValue value1,
LongValue value2) |
Modifier and Type | Method and Description |
---|---|
boolean |
WorksetEmptyConvergenceCriterion.isConverged(int iteration,
LongValue value) |
Modifier and Type | Method and Description |
---|---|
LongValue |
LongValue.copy() |
Modifier and Type | Method and Description |
---|---|
int |
LongValue.compareTo(LongValue o) |
void |
LongValue.copyTo(LongValue target) |
void |
LongValue.setValue(LongValue value) |
Modifier and Type | Method and Description |
---|---|
LongValue |
LongValueParser.createValue() |
LongValue |
LongValueParser.getLastResult() |
Modifier and Type | Method and Description |
---|---|
int |
LongValueParser.parseField(byte[] bytes,
int startPos,
int limit,
byte[] delimiter,
LongValue reusable) |
Modifier and Type | Method and Description |
---|---|
LongValue |
LongValueSequenceIterator.next() |
Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.