Home
last modified time | relevance | path

Searched refs:VertexId (Results 1 – 25 of 1012) sorted by relevance

12345678910>>...41

/dports/games/abstreet/abstreet-0.2.9-49-g74aca40c0/cargo-crates/lyon_tessellation-0.15.8/src/
H A Dmonotone.rs3 use crate::{FillGeometryBuilder, VertexId};
10 triangles: Vec<(VertexId, VertexId, VertexId)>,
16 id: VertexId,
28 id: VertexId(0), in new()
35 debug_assert!(id != VertexId::INVALID); in begin()
52 debug_assert!(id != VertexId::INVALID); in vertex()
117 debug_assert!(a.id != VertexId::INVALID); in push_triangle()
143 tess.end(point(1.0, 2.0), VertexId(2)); in test_monotone_tess()
153 tess.end(point(0.0, 5.0), VertexId(5)); in test_monotone_tess()
164 tess.end(point(0.0, 6.0), VertexId(6)); in test_monotone_tess()
[all …]
H A Dgeometry_builder.rs270 fn add_triangle(&mut self, a: VertexId, b: VertexId, c: VertexId); in add_triangle() argument
292 ) -> Result<VertexId, GeometryBuilderError>; in add_fill_vertex() argument
307 ) -> Result<VertexId, GeometryBuilderError>; in add_stroke_vertex() argument
500 OutputIndex: Add + From<VertexId> + MaxIndex,
519 fn add_triangle(&mut self, a: VertexId, b: VertexId, c: VertexId) { in add_triangle() argument
523 debug_assert!(a != VertexId::INVALID); in add_triangle()
524 debug_assert!(b != VertexId::INVALID); in add_triangle()
525 debug_assert!(c != VertexId::INVALID); in add_triangle()
536 OutputIndex: Add + From<VertexId> + MaxIndex,
600 OutputIndex: From<VertexId>,
[all …]
H A Dlib.rs666 impl VertexId { implementation
667 pub const INVALID: VertexId = VertexId(u32::MAX);
678 VertexId(v as Index) in from_usize()
682 impl Add<u32> for VertexId { implementation
689 impl Sub<u32> for VertexId { implementation
696 impl From<u16> for VertexId { implementation
698 VertexId(v as Index) in from()
701 impl From<u32> for VertexId { implementation
703 VertexId(v) in from()
706 impl From<i32> for VertexId { implementation
[all …]
/dports/misc/xgboost/xgboost-1.5.1/cub/experimental/defunct/
H A Dexample_coo_spmv.cu199 template <typename VertexId>
201 const VertexId& row_a, in operator ()()
202 const VertexId& row_b) in operator ()()
221 typename VertexId,
484 typename VertexId,
516 VertexId last_block_row;
782 VertexId *h_rows = new VertexId[num_edges]; in TestDevice()
783 VertexId *h_columns = new VertexId[num_edges]; in TestDevice()
979 VertexId width; in main()
986 VertexId width; in main()
[all …]
/dports/devel/spark/spark-2.1.1/graphx/src/main/scala/org/apache/spark/graphx/lib/
H A DLabelPropagation.scala45 def run[VD, ED: ClassTag](graph: Graph[VD, ED], maxSteps: Int): Graph[VertexId, ED] = {
49 def sendMessage(e: EdgeTriplet[VertexId, ED]): Iterator[(VertexId, Map[VertexId, Long])] = {
52 def mergeMessage(count1: Map[VertexId, Long], count2: Map[VertexId, Long])
53 : Map[VertexId, Long] = {
60 def vertexProgram(vid: VertexId, attr: Long, message: Map[VertexId, Long]): VertexId = {
63 val initialMessage = Map[VertexId, Long]()
H A DPageRank.scala107 srcId: Option[VertexId] = None): Graph[Double, Double] =
115 val src: VertexId = srcId.getOrElse(-1L)
131 def delta(u: VertexId, v: VertexId): Double = { if (u == v) 1.0 else 0.0 }
148 (src: VertexId, id: VertexId) => resetProb * delta(src, id)
150 (src: VertexId, id: VertexId) => resetProb
187 sources: Array[VertexId]): Graph[Vector, Double] = {
290 srcId: Option[VertexId] = None): Graph[Double, Double] =
297 val src: VertexId = srcId.getOrElse(-1L)
322 def personalizedVertexProgram(id: VertexId, attr: (Double, Double),
349 (id: VertexId, attr: (Double, Double), msgSum: Double) =>
[all …]
/dports/devel/spark/spark-2.1.1/graphx/src/main/scala/org/apache/spark/graphx/
H A DPartitionStrategy.scala26 def getPartition(src: VertexId, dst: VertexId, numParts: PartitionID): PartitionID
75 override def getPartition(src: VertexId, dst: VertexId, numParts: PartitionID): PartitionID = {
77 val mixingPrime: VertexId = 1125899906842597L
102 override def getPartition(src: VertexId, dst: VertexId, numParts: PartitionID): PartitionID = {
103 val mixingPrime: VertexId = 1125899906842597L
114 override def getPartition(src: VertexId, dst: VertexId, numParts: PartitionID): PartitionID = {
126 override def getPartition(src: VertexId, dst: VertexId, numParts: PartitionID): PartitionID = {
H A DGraphOps.scala91 graph.aggregateMessages[Array[VertexId]](
95 graph.aggregateMessages[Array[VertexId]](
99 graph.aggregateMessages[Array[VertexId]](
107 nbrsOpt.getOrElse(Array.empty[VertexId])
145 nbrsOpt.getOrElse(Array.empty[(VertexId, VD)])
223 def joinVertices[U: ClassTag](table: RDD[(VertexId, U)])(mapFunc: (VertexId, VD, U) => VD)
264 vpred: (VertexId, VD2) => Boolean = (v: VertexId, d: VD2) => true): Graph[VD, ED] = {
271 def pickRandomVertex(): VertexId = {
274 var retVal: VertexId = null.asInstanceOf[VertexId]
366 vprog: (VertexId, VD, A) => VD,
[all …]
H A DVertexRDD.scala57 deps: Seq[Dependency[_]]) extends RDD[(VertexId, VD)](sc, deps) {
120 def mapValues[VD2: ClassTag](f: (VertexId, VD) => VD2): VertexRDD[VD2]
128 def minus(other: RDD[(VertexId, VD)]): VertexRDD[VD]
145 def diff(other: RDD[(VertexId, VD)]): VertexRDD[VD]
190 (other: RDD[(VertexId, VD2)])
191 (f: (VertexId, VD, Option[VD2]) => VD3)
199 (f: (VertexId, VD, U) => VD2): VertexRDD[VD2]
212 def innerJoin[U: ClassTag, VD2: ClassTag](other: RDD[(VertexId, U)])
213 (f: (VertexId, VD, U) => VD2): VertexRDD[VD2]
276 val vPartitioned: RDD[(VertexId, VD)] = vertices.partitioner match {
[all …]
/dports/math/ignition-math/ignitionrobotics-ign-math-46f3dd24499c/include/ignition/math/graph/
H A DEdge.hh151 public: virtual VertexId From(const VertexId &_from) const = 0;
167 public: virtual VertexId To(const VertexId &_to) const = 0;
223 public: VertexId From(const VertexId &_from) const override in From()
238 public: VertexId To(const VertexId &_to) const override in To()
288 public: VertexId Tail() const in Tail()
296 public: VertexId Head() const in Head()
302 public: VertexId From(const VertexId &_from) const override in From()
311 public: VertexId To(const VertexId &_to) const override in To()
H A DGraphAlgorithms.hh43 using CostInfo = std::pair<double, VertexId>;
53 const VertexId &_from) in BreadthFirstSort()
67 std::vector<VertexId> visited; in BreadthFirstSort()
68 std::list<VertexId> pending = {_from}; in BreadthFirstSort()
105 const VertexId &_from) in DepthFirstSort()
119 std::vector<VertexId> visited; in DepthFirstSort()
120 std::stack<VertexId> pending({_from}); in DepthFirstSort()
214 const VertexId &_from, in Dijkstra()
240 std::map<VertexId, CostInfo> dist; in Dijkstra()
254 VertexId u = pq.top().second; in Dijkstra()
[all …]
H A DVertex.hh41 using VertexId = uint64_t; typedef
45 using VertexId_P = std::pair<VertexId, VertexId>;
48 static const VertexId kNullId = MAX_UI64;
65 const VertexId _id = kNullId) in Vertex()
88 public: VertexId Id() const in Id()
127 private: VertexId id = kNullId;
139 std::map<VertexId, std::reference_wrapper<const Vertex<V>>>;
H A DGraph.hh462 const VertexId &_vertex) const in IncidentsTo()
503 public: bool RemoveVertex(const VertexId &_vertex) in RemoveVertex()
622 public: Vertex<V> &VertexFromId(const VertexId &_id) in VertexFromId()
640 const VertexId _sourceId, const VertexId _destId) const in EdgeFromVertices()
694 private: VertexId &NextVertexId() in NextVertexId()
707 private: VertexId &NextEdgeId() in NextEdgeId()
719 protected: VertexId nextVertexId = 0u;
722 protected: VertexId nextEdgeId = 0u;
725 private: std::map<VertexId, Vertex<V>> vertices;
735 private: std::map<VertexId, EdgeId_S> adjList;
[all …]
/dports/graphics/R-cran-s2/s2/src/s2/
H A Ds2builderutil_find_polygon_degeneracies.cc45 using VertexId = Graph::VertexId; typedef
63 VertexId root;
85 Component BuildComponent(VertexId root);
86 bool CrossingParity(VertexId v0, VertexId v1, bool include_same) const;
87 VertexId FindUnbalancedVertex() const;
132 VertexId known_vertex = -1; in Run()
138 VertexId root = g_.edge(e).first; in Run()
217 vector<pair<VertexId, bool>> frontier; in BuildComponent()
221 VertexId v0 = frontier.back().first; in BuildComponent()
230 VertexId v1 = g_.edge(e).second; in BuildComponent()
[all …]
H A Ds2builder_graph.h53 using VertexId = int32;
56 using Edge = std::pair<VertexId, VertexId>;
117 VertexId num_vertices() const;
120 const S2Point& vertex(VertexId v) const;
218 int degree(VertexId v) const;
223 VertexOutEdges edges(VertexId v0, VertexId v1) const;
224 VertexOutEdgeIds edge_ids(VertexId v0, VertexId v1) const;
257 int degree(VertexId v) const;
618 std::vector<VertexId>* tmp);
697 S2Builder::Graph::VertexOutMap::edges(VertexId v0, VertexId v1) const { in edges()
[all …]
/dports/graphics/s2/s2geometry-0.9.0/src/s2/
H A Ds2builderutil_find_polygon_degeneracies.cc45 using VertexId = Graph::VertexId; typedef
63 VertexId root;
85 Component BuildComponent(VertexId root);
86 bool CrossingParity(VertexId v0, VertexId v1, bool include_same) const;
87 VertexId FindUnbalancedVertex() const;
132 VertexId known_vertex = -1; in Run()
138 VertexId root = g_.edge(e).first; in Run()
217 vector<pair<VertexId, bool>> frontier; in BuildComponent()
221 VertexId v0 = frontier.back().first; in BuildComponent()
230 VertexId v1 = g_.edge(e).second; in BuildComponent()
[all …]
H A Ds2builder_graph.h53 using VertexId = int32;
56 using Edge = std::pair<VertexId, VertexId>;
117 VertexId num_vertices() const;
120 const S2Point& vertex(VertexId v) const;
218 int degree(VertexId v) const;
223 VertexOutEdges edges(VertexId v0, VertexId v1) const;
224 VertexOutEdgeIds edge_ids(VertexId v0, VertexId v1) const;
257 int degree(VertexId v) const;
618 std::vector<VertexId>* tmp);
697 S2Builder::Graph::VertexOutMap::edges(VertexId v0, VertexId v1) const { in edges()
[all …]
/dports/graphics/py-s2/s2geometry-0.9.0/src/s2/
H A Ds2builderutil_find_polygon_degeneracies.cc45 using VertexId = Graph::VertexId; typedef
63 VertexId root;
85 Component BuildComponent(VertexId root);
86 bool CrossingParity(VertexId v0, VertexId v1, bool include_same) const;
87 VertexId FindUnbalancedVertex() const;
132 VertexId known_vertex = -1; in Run()
138 VertexId root = g_.edge(e).first; in Run()
217 vector<pair<VertexId, bool>> frontier; in BuildComponent()
221 VertexId v0 = frontier.back().first; in BuildComponent()
230 VertexId v1 = g_.edge(e).second; in BuildComponent()
[all …]
H A Ds2builder_graph.h53 using VertexId = int32;
56 using Edge = std::pair<VertexId, VertexId>;
117 VertexId num_vertices() const;
120 const S2Point& vertex(VertexId v) const;
218 int degree(VertexId v) const;
223 VertexOutEdges edges(VertexId v0, VertexId v1) const;
224 VertexOutEdgeIds edge_ids(VertexId v0, VertexId v1) const;
257 int degree(VertexId v) const;
618 std::vector<VertexId>* tmp);
697 S2Builder::Graph::VertexOutMap::edges(VertexId v0, VertexId v1) const { in edges()
[all …]
/dports/devel/pijul/pijul-1.0.0.a55/cargo-crates/libpijul-1.0.0-alpha.49/src/alive/
H A Dmod.rs21 pub extra: Vec<(Option<SerializedEdge>, VertexId)>,
33 pub struct VertexId(pub usize); struct
35 impl VertexId { impl
36 pub const DUMMY: VertexId = VertexId(0);
67 pub children: Vec<(Option<SerializedEdge>, VertexId)>,
80 impl std::ops::Index<VertexId> for Graph {
82 fn index(&self, idx: VertexId) -> &Self::Output { in index()
86 impl std::ops::IndexMut<VertexId> for Graph {
101 i: VertexId, in children() argument
109 fn child(&self, i: VertexId, j: usize) -> &(Option<SerializedEdge>, VertexId) { in child() argument
[all …]
/dports/devel/spark/spark-2.1.1/graphx/src/test/scala/org/apache/spark/graphx/
H A DGraphSuite.scala30 Graph.fromEdgeTuples(sc.parallelize((1 to n).map(x => (0: VertexId, x: VertexId)), 3), "v")
77 === (1 to n).map(x => (0: VertexId, x: VertexId, "v", "v")).toSet)
116 verts.withFilter(y => y % x == 0).map(y => (x: VertexId, y: VertexId))), p), 0)
250 val vertices = sc.parallelize((0 to n).map(x => (x: VertexId, x)))
277 List((0: VertexId, x: VertexId), (0: VertexId, x: VertexId))), 1), "v")
312 assert(neighborDegreeSums === Set((0: VertexId, n)) ++ (1 to n).map(x => (x: VertexId, 0)))
324 val verts = sc.parallelize(List((1: VertexId, "a"), (2: VertexId, "b")), 1)
330 Set((1: VertexId, 2: VertexId, "a", "b"), (2: VertexId, 1: VertexId, "b", "a")))
359 val verts = sc.parallelize(List((1: VertexId, "a"), (2: VertexId, "b")), 1)
379 val edges = sc.parallelize((1 to n).map(x => (x: VertexId, 0: VertexId)),
[all …]
H A DPregelSuite.scala27 val starEdges = (1 to n).map(x => (0: VertexId, x: VertexId))
41 sc.parallelize((1 until n).map(x => (x: VertexId, x + 1: VertexId)), 3),
43 assert(chain.vertices.collect.toSet === (1 to n).map(x => (x: VertexId, 0)).toSet)
46 Set((1: VertexId, 1)) ++ (2 to n).map(x => (x: VertexId, 0)).toSet)
/dports/devel/spark/spark-2.1.1/graphx/src/main/scala/org/apache/spark/graphx/impl/
H A DEdgePartitionBuilder.scala33 def add(src: VertexId, dst: VertexId, d: ED) {
44 val index = new GraphXPrimitiveKeyOpenHashMap[VertexId, Int]
45 val global2local = new GraphXPrimitiveKeyOpenHashMap[VertexId, Int]
46 val local2global = new PrimitiveVector[VertexId]
52 var currSrcId: VertexId = edgeArray(0).srcId
85 global2local: GraphXPrimitiveKeyOpenHashMap[VertexId, Int],
86 local2global: Array[VertexId],
93 def add(src: VertexId, dst: VertexId, localSrc: Int, localDst: Int, d: ED) {
104 val index = new GraphXPrimitiveKeyOpenHashMap[VertexId, Int]
109 var currSrcId: VertexId = edgeArray(0).srcId
[all …]
H A DEdgePartition.scala60 index: GraphXPrimitiveKeyOpenHashMap[VertexId, Int],
62 local2global: Array[VertexId],
113 def isActive(vid: VertexId): Boolean = {
239 var currSrcId: VertexId = null.asInstanceOf[VertexId]
240 var currDstId: VertexId = null.asInstanceOf[VertexId]
285 (f: (VertexId, VertexId, ED, ED2) => ED3): EdgePartition[ED3, VD] = {
486 private[this] var _srcId: VertexId = _
487 private[this] var _dstId: VertexId = _
495 srcId: VertexId, dstId: VertexId,
521 override def srcId: VertexId = _srcId
[all …]
/dports/math/dune-metagrid/dune-metagrid-45fe80d530d18d8b86e77f20e38865f2101e571a/dune/grid/cartesiangrid/
H A Ddgfparser.hh143 typedef unsigned int VertexId; typedef
146 VertexId counter_;
154 VertexId insertVertex ( const Vertex &vx, std::size_t globalId ) in insertVertex()
160 void insertElement ( GeometryType type, const std::vector< VertexId > &indices ) in insertElement()
191 typedef typename Factory::VertexId VertexId; typedef
265 typedef unsigned int VertexId; typedef
273 VertexId insertVertex( const VertexType &vx, const size_t globalId ) in insertVertex()
303 VertexId counter_;
326 typedef typename Factory::VertexId VertexId; in generate() typedef
335 std::vector< VertexId > vertexId( indexSet.size( dim ) ); in generate()
[all …]

12345678910>>...41