Modifier and Type | Method and Description |
---|---|
NullValue |
NullValueSerializer.copy(NullValue from) |
NullValue |
NullValueSerializer.copy(NullValue from,
NullValue reuse) |
NullValue |
NullValueSerializer.createInstance() |
NullValue |
NullValueSerializer.deserialize(DataInputView source) |
NullValue |
NullValueSerializer.deserialize(NullValue reuse,
DataInputView source) |
NullValue |
NullValueComparator.readWithKeyDenormalization(NullValue reuse,
DataInputView source) |
Modifier and Type | Method and Description |
---|---|
TypeComparator<NullValue> |
NullValueComparator.duplicate() |
TypeSerializerSnapshot<NullValue> |
NullValueSerializer.snapshotConfiguration() |
Modifier and Type | Method and Description |
---|---|
int |
NullValueComparator.compare(NullValue first,
NullValue second) |
NullValue |
NullValueSerializer.copy(NullValue from) |
NullValue |
NullValueSerializer.copy(NullValue from,
NullValue reuse) |
NullValue |
NullValueSerializer.deserialize(NullValue reuse,
DataInputView source) |
boolean |
NullValueComparator.equalToReference(NullValue candidate) |
int |
NullValueComparator.hash(NullValue record) |
void |
NullValueComparator.putNormalizedKey(NullValue record,
MemorySegment target,
int offset,
int numBytes) |
NullValue |
NullValueComparator.readWithKeyDenormalization(NullValue reuse,
DataInputView source) |
void |
NullValueSerializer.serialize(NullValue record,
DataOutputView target) |
void |
NullValueComparator.setReference(NullValue toCompare) |
void |
NullValueComparator.writeWithKeyNormalization(NullValue record,
DataOutputView target) |
Modifier and Type | Method and Description |
---|---|
int |
NullValueComparator.compareToReference(TypeComparator<NullValue> referencedComparator) |
Modifier and Type | Field and Description |
---|---|
static ValueTypeInfo<NullValue> |
ValueTypeInfo.NULL_VALUE_TYPE_INFO |
Modifier and Type | Method and Description |
---|---|
<K,EV> Graph<K,NullValue,EV> |
GraphCsvReader.edgeTypes(Class<K> vertexKey,
Class<EV> edgeValue)
Creates a Graph from CSV input with edge values, but without vertex values.
|
static <K,EV> Graph<K,NullValue,EV> |
Graph.fromCollection(Collection<Edge<K,EV>> edges,
ExecutionEnvironment context)
Creates a graph from a Collection of edges.
|
static <K,EV> Graph<K,NullValue,EV> |
Graph.fromDataSet(DataSet<Edge<K,EV>> edges,
ExecutionEnvironment context)
Creates a graph from a DataSet of edges.
|
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> 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,EV> Graph<K,NullValue,EV> |
Graph.fromTupleDataSet(DataSet<Tuple3<K,K,EV>> edges,
ExecutionEnvironment context)
Creates a graph from a DataSet of Tuple3 objects for edges.
|
Graph<K,NullValue,EV> |
Graph.intersect(Graph<K,VV,EV> graph,
boolean distinctEdges)
Performs intersect on the edge sets of the input graphs.
|
<K> Graph<K,NullValue,NullValue> |
GraphCsvReader.keyType(Class<K> vertexKey)
Creates a Graph from CSV input without vertex values or edge values.
|
<K> Graph<K,NullValue,NullValue> |
GraphCsvReader.keyType(Class<K> vertexKey)
Creates a Graph from CSV input without vertex values or edge values.
|
<K,VV> Graph<K,VV,NullValue> |
GraphCsvReader.vertexTypes(Class<K> vertexKey,
Class<VV> vertexValue)
Creates a Graph from CSV input without edge values.
|
Modifier and Type | Method and Description |
---|---|
NullValue |
ToNullValue.translate(T value,
NullValue reuse) |
Modifier and Type | Method and Description |
---|---|
NullValue |
ToNullValue.translate(T value,
NullValue reuse) |
Modifier and Type | Method and Description |
---|---|
<T extends Comparable<T>> |
Simplify.simplify(Graph<T,NullValue,NullValue> graph,
int parallelism)
Simplify the given graph based on the configured value.
|
<T extends Comparable<T>> |
Simplify.simplify(Graph<T,NullValue,NullValue> graph,
int parallelism)
Simplify the given graph based on the configured value.
|
Modifier and Type | Method and Description |
---|---|
<T extends Comparable<T>> |
Simplify.simplify(Graph<T,NullValue,NullValue> graph,
int parallelism)
Simplify the given graph based on the configured value.
|
<T extends Comparable<T>> |
Simplify.simplify(Graph<T,NullValue,NullValue> graph,
int parallelism)
Simplify the given graph based on the configured value.
|
Modifier and Type | Method and Description |
---|---|
static DataSet<Edge<Long,NullValue>> |
ConnectedComponentsDefaultData.getDefaultEdgeDataSet(ExecutionEnvironment env) |
static DataSet<Edge<Long,NullValue>> |
TriangleCountData.getDefaultEdgeDataSet(ExecutionEnvironment env) |
static DataSet<Edge<Long,NullValue>> |
LabelPropagationData.getDefaultEdgeDataSet(ExecutionEnvironment env) |
static DataSet<Edge<Long,NullValue>> |
LabelPropagationData.getTieEdgeDataSet(ExecutionEnvironment env) |
Modifier and Type | Field and Description |
---|---|
static ValueArrayTypeInfo<NullValue> |
ValueArrayTypeInfo.NULL_VALUE_ARRAY_TYPE_INFO |
Modifier and Type | Method and Description |
---|---|
ValueArray<NullValue> |
NullValueArray.copy() |
Iterator<NullValue> |
NullValueArray.iterator() |
Modifier and Type | Method and Description |
---|---|
boolean |
NullValueArray.add(NullValue value) |
Modifier and Type | Method and Description |
---|---|
boolean |
NullValueArray.addAll(ValueArray<NullValue> other) |
int |
NullValueArray.compareTo(ValueArray<NullValue> o) |
void |
NullValueArray.copyTo(ValueArray<NullValue> target) |
void |
NullValueArray.setValue(ValueArray<NullValue> value) |
Modifier and Type | Method and Description |
---|---|
Edge<K,NullValue> |
Tuple2ToEdgeMap.map(Tuple2<K,K> tuple) |
Modifier and Type | Method and Description |
---|---|
NullValue |
NullValue.copy() |
static NullValue |
NullValue.getInstance()
Returns the NullValue singleton instance.
|
Modifier and Type | Method and Description |
---|---|
int |
NullValue.compareTo(NullValue o) |
void |
NullValue.copyTo(NullValue target) |
Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.