InnerNodeDownUpTraverserImpl

scalax.collection.GraphTraversalImpl.InnerNodeDownUpTraverserImpl
protected case class InnerNodeDownUpTraverserImpl(root: NodeT, parameters: Parameters, subgraphNodes: NodePredicate, subgraphEdges: EdgePredicate, ordering: ElemOrdering, maxWeight: Option[Weight]) extends InnerNodeDownUpTraverser, DownUpTraverser[(Boolean, NodeT), InnerNodeDownUpTraverserImpl]

Attributes

Graph
Supertypes

Members list

Type members

Inherited classlikes

final protected class Runner[U]

Contains algorithms and local values to be used by the algorithms. Last target reusability and best possible run-time performance.

Contains algorithms and local values to be used by the algorithms. Last target reusability and best possible run-time performance.

Value parameters

stopAt

node predicate marking an end condition for the search

Attributes

Inherited from:
Impl (hidden)
Supertypes
class Object
trait Matchable
class Any
abstract protected class StopCondition extends (NodeT, Int, Int) => Boolean

Attributes

Inherited from:
Impl (hidden)
Supertypes
trait (NodeT, Int, Int) => Boolean
class Object
trait Matchable
class Any
protected object StopCondition

Attributes

Inherited from:
Impl (hidden)
Supertypes
class Object
trait Matchable
class Any

Value members

Inherited methods

final def ++[B >: (Boolean, NodeT)](suffix: IterableOnce[B]): CC[B]

Attributes

Inherited from:
IterableOps
final override def addString(b: StringBuilder, start: String, sep: String, end: String): StringBuilder

Attributes

Definition Classes
Inherited from:
ForeachBasedDetachingIterable

Attributes

Inherited from:
IterableOnceOps

Attributes

Inherited from:
IterableOnceOps
final protected def apply[U](pred: NodePredicate, visitor: ((Boolean, NodeT)) => U): Option[NodeT]

Attributes

Inherited from:
Impl (hidden)
final override def collect[B](pf: PartialFunction[(Boolean, NodeT), B]): Iterable[B]

Attributes

Definition Classes
Inherited from:
ForeachBasedDetachingIterable
final override def collectFirst[B](pf: PartialFunction[(Boolean, NodeT), B]): Option[B]

Attributes

Definition Classes
Inherited from:
ForeachBasedDetachingIterable
def concat[B >: (Boolean, NodeT)](suffix: IterableOnce[B]): CC[B]

Attributes

Inherited from:
IterableOps
def copyToArray[B >: (Boolean, NodeT)](xs: Array[B], start: Int, len: Int): Int

Attributes

Inherited from:
IterableOnceOps
def copyToArray[B >: (Boolean, NodeT)](xs: Array[B], start: Int): Int

Attributes

Inherited from:
IterableOnceOps
def copyToArray[B >: (Boolean, NodeT)](xs: Array[B]): Int

Attributes

Inherited from:
IterableOnceOps

Attributes

Inherited from:
IterableOnceOps
final override def count(p: ((Boolean, NodeT)) => Boolean): Int

Attributes

Definition Classes
Inherited from:
ForeachBasedDetachingIterable
final protected def downUpForeach[U](down: ((Boolean, NodeT)) => Unit, up: NodeT => Unit): Unit

Attributes

Inherited from:
DownUpTraverser
final override def drop(n: Int): Vector[A]

Attributes

Definition Classes
Inherited from:
ForeachBasedDetachingIterable
def dropRight(n: Int): C

Attributes

Inherited from:
IterableOps
final override def dropWhile(p: ((Boolean, NodeT)) => Boolean): Vector[A]

Attributes

Definition Classes
Inherited from:
ForeachBasedDetachingIterable
final protected def edgeVisitor[U](f: ((Boolean, NodeT)) => U): EdgeT => U

Attributes

Inherited from:
DownUpTraverser
override def empty: CC[A]

Attributes

Definition Classes
Inherited from:
IterableFactoryDefaults
final override def exists(p: ((Boolean, NodeT)) => Boolean): Boolean

Attributes

Definition Classes
Inherited from:
ForeachBasedDetachingIterable
final def fUnit[U](f: ((Boolean, NodeT)) => U): A => Unit

Attributes

Inherited from:
DownUpTraverser
final override def filter(p: ((Boolean, NodeT)) => Boolean): Vector[A]

Attributes

Definition Classes
Inherited from:
ForeachBasedDetachingIterable
final override def filterNot(p: ((Boolean, NodeT)) => Boolean): Vector[A]

Attributes

Definition Classes
Inherited from:
ForeachBasedDetachingIterable
final override def find(p: ((Boolean, NodeT)) => Boolean): Option[A]

Attributes

Definition Classes
Inherited from:
ForeachBasedDetachingIterable
final def findConnected[U](pred: NodePredicate)(implicit visitor: ((Boolean, NodeT)) => U): Option[NodeT]

Finds a node connected with root by any number of edges with any direction for which the predicate pred holds considering all traversal properties passed to the traverser factory method like scalax.collection.GraphTraversal#innerNodeTraverser or altered by any with* method. For directed or mixed graphs the node to be found is weakly connected with this node. root itself does not count as a match. This is also true if it has a hook. If several connected nodes exist with pred the algorithm selects any one of these.

Finds a node connected with root by any number of edges with any direction for which the predicate pred holds considering all traversal properties passed to the traverser factory method like scalax.collection.GraphTraversal#innerNodeTraverser or altered by any with* method. For directed or mixed graphs the node to be found is weakly connected with this node. root itself does not count as a match. This is also true if it has a hook. If several connected nodes exist with pred the algorithm selects any one of these.

Value parameters

pred

The predicate which must hold true for the resulting node.

visitor

An optional function that is applied for its side-effect to every element visited during graph traversal.

Attributes

Returns

A node with the predicate pred or None if either a. there is no node with pred or a. there exists no connection to such a node or a. there exists a connection to such a node but due to withSubgraph settings this path was out of scope.

Inherited from:
TraverserMethods (hidden)
final def findCycle[U](implicit visitor: ((Boolean, NodeT)) => U): Option[Cycle]

Finds a cycle starting the search at root $INTOACC, if any. The resulting cycle may start at any node connected with this node.

Finds a cycle starting the search at root $INTOACC, if any. The resulting cycle may start at any node connected with this node.

Value parameters

visitor

$OPTVISITOR

Attributes

Returns

A cycle or None if either a. there exists no cycle in the component depicting by root or a. there exists a cycle in the component but due to withSubgraph settings this path was out of scope.

Inherited from:
Impl (hidden)
final def findPredecessor[U](pred: NodePredicate)(implicit visitor: ((Boolean, NodeT)) => U): Option[NodeT]

Finds a predecessor of root for which the predicate pred holds considering all traversal properties passed to the traverser factory method like scalax.collection.GraphTraversal#innerNodeTraverser or altered by any with* method. root itself does not count as a match. This is also true if it has a hook. If several predecessors exist the algorithm selects the first of them found.

Finds a predecessor of root for which the predicate pred holds considering all traversal properties passed to the traverser factory method like scalax.collection.GraphTraversal#innerNodeTraverser or altered by any with* method. root itself does not count as a match. This is also true if it has a hook. If several predecessors exist the algorithm selects the first of them found.

Value parameters

pred

The predicate which must hold true for the resulting node.

visitor

An optional function that is applied for its side-effect to every element visited during graph traversal.

Attributes

Returns

A node with the predicate pred or None if either a. there is no node with pred or a. there exists no path from such a node to this node or a. there exists a path from such a node to root but due to withSubgraph settings this path was out of scope.

Inherited from:
TraverserMethods (hidden)
final def findSuccessor[U](pred: NodePredicate)(implicit visitor: ((Boolean, NodeT)) => U): Option[NodeT]

Finds a successor of root for which the predicate pred holds considering all traversal properties passed to the traverser factory method like scalax.collection.GraphTraversal#innerNodeTraverser or altered by any with* method. root itself does not count as a match. This is also true if it has a hook. If several successors holding pred exist any one of them may be returned.

Finds a successor of root for which the predicate pred holds considering all traversal properties passed to the traverser factory method like scalax.collection.GraphTraversal#innerNodeTraverser or altered by any with* method. root itself does not count as a match. This is also true if it has a hook. If several successors holding pred exist any one of them may be returned.

Value parameters

pred

The predicate which must hold for the resulting node.

visitor

An optional function that is applied for its side-effect to every element visited during graph traversal.

Attributes

Returns

A node with the predicate pred or None if either a. there is no node with pred or a. there exists no path to such a node or a. there exists a path to such a node but due to withSubgraph settings this path was out of scope.

Inherited from:
TraverserMethods (hidden)
final override def flatMap[B](f: ((Boolean, NodeT)) => IterableOnce[B]): Iterable[B]

Attributes

Definition Classes
Inherited from:
ForeachBasedDetachingIterable
def flatten[B](implicit asIterable: ((Boolean, NodeT)) => IterableOnce[B]): CC[B]

Attributes

Inherited from:
IterableOps
def fold[A1 >: (Boolean, NodeT)](z: A1)(op: (A1, A1) => A1): A1

Attributes

Inherited from:
IterableOnceOps
final override def foldLeft[B](z: B)(op: (B, (Boolean, NodeT)) => B): B

Attributes

Definition Classes
Inherited from:
ForeachBasedDetachingIterable
def foldRight[B](z: B)(op: ((Boolean, NodeT), B) => B): B

Attributes

Inherited from:
IterableOnceOps
final override def forall(p: ((Boolean, NodeT)) => Boolean): Boolean

Attributes

Definition Classes
Inherited from:
ForeachBasedDetachingIterable
final override def foreach[U](f: ((Boolean, NodeT)) => U): Unit

Attributes

Definition Classes
Inherited from:
ForeachBasedDetachingIterable
protected def fromSpecific(coll: IterableOnce[(Boolean, NodeT)]): CC[A]

Attributes

Inherited from:
IterableFactoryDefaults
def groupBy[K](f: ((Boolean, NodeT)) => K): Map[K, C]

Attributes

Inherited from:
IterableOps
def groupMap[K, B](key: ((Boolean, NodeT)) => K)(f: ((Boolean, NodeT)) => B): Map[K, CC[B]]

Attributes

Inherited from:
IterableOps
def groupMapReduce[K, B](key: ((Boolean, NodeT)) => K)(f: ((Boolean, NodeT)) => B)(reduce: (B, B) => B): Map[K, B]

Attributes

Inherited from:
IterableOps
def grouped(size: Int): Iterator[C]

Attributes

Inherited from:
IterableOps
final def hasPredecessor[U](potentialPredecessor: NodeT)(implicit visitor: ((Boolean, NodeT)) => U): Boolean

Checks whether potentialPredecessor is a predecessor of root considering all traversal properties passed to the traverser factory method like scalax.collection.GraphTraversal#innerNodeTraverser or altered by any with* method. Same as isSuccessorOf.

Checks whether potentialPredecessor is a predecessor of root considering all traversal properties passed to the traverser factory method like scalax.collection.GraphTraversal#innerNodeTraverser or altered by any with* method. Same as isSuccessorOf.

Value parameters

potentialPredecessor

The node which is potentially a predecessor of root.

visitor

An optional function that is applied for its side-effect to every element visited during graph traversal.

Attributes

Returns

true if a path exists from potentialPredecessor to root and it had not to be excluded due to subgraph properties.

Inherited from:
TraverserMethods (hidden)
final def hasSuccessor[U](potentialSuccessor: NodeT)(implicit visitor: ((Boolean, NodeT)) => U): Boolean

Checks whether potentialSuccessor is a successor of this node considering all traversal properties passed to the traverser factory method like scalax.collection.GraphTraversal#innerNodeTraverser or altered by any with* method. Same as isPredecessorOf.

Checks whether potentialSuccessor is a successor of this node considering all traversal properties passed to the traverser factory method like scalax.collection.GraphTraversal#innerNodeTraverser or altered by any with* method. Same as isPredecessorOf.

Value parameters

potentialSuccessor

The node which is potentially a successor of this node.

visitor

An optional function that is applied for its side-effect to every element visited during graph traversal.

Attributes

Returns

true if a path exists from this node to potentialSuccessor and it had not to be excluded due to a subgraph* restriction.

Inherited from:
TraverserMethods (hidden)
final override def head: A

Attributes

Definition Classes
Inherited from:
ForeachBasedDetachingIterable
final override def headOption: Option[A]

Attributes

Definition Classes
Inherited from:
ForeachBasedDetachingIterable
def init: C

Attributes

Inherited from:
IterableOps
def inits: Iterator[C]

Attributes

Inherited from:
IterableOps
final def isConnectedWith[U](potentialConnected: NodeT)(implicit visitor: ((Boolean, NodeT)) => U): Boolean

Checks whether potentialConnected is a node (not necessarily directly) connected with root by any number of edges with any direction considering all traversal properties passed to the traverser factory method like scalax.collection.GraphTraversal#innerNodeTraverser or altered by any with* method. For directed or mixed graphs it is satisfactory that potentialConnected is weakly connected with root.

Checks whether potentialConnected is a node (not necessarily directly) connected with root by any number of edges with any direction considering all traversal properties passed to the traverser factory method like scalax.collection.GraphTraversal#innerNodeTraverser or altered by any with* method. For directed or mixed graphs it is satisfactory that potentialConnected is weakly connected with root.

Value parameters

potentialConnected

The node which is potentially connected with root.

visitor

An optional function that is applied for its side-effect to every element visited during graph traversal.

Attributes

Returns

true if a path exists from this node to potentialConnected and it had not to be excluded due to subgraph properties.

Inherited from:
TraverserMethods (hidden)
final override def isEmpty: Boolean

Attributes

Definition Classes
Inherited from:
ForeachBasedDetachingIterable
final def isPredecessorOf[U](potentialSuccessor: NodeT)(implicit visitor: ((Boolean, NodeT)) => U): Boolean

Same as hasSuccessor.

Same as hasSuccessor.

Attributes

Inherited from:
TraverserMethods (hidden)
final def isSuccessorOf[U](potentialPredecessor: NodeT)(implicit visitor: ((Boolean, NodeT)) => U): Boolean

Same as hasPredecessor.

Same as hasPredecessor.

Attributes

Inherited from:
TraverserMethods (hidden)
override def isTraversableAgain: Boolean

Attributes

Definition Classes
Inherited from:
IterableOps
def iterator: Iterator[A]

Attributes

Inherited from:
ForeachBasedDetachingIterable
def knownSize: Int

Attributes

Inherited from:
IterableOnce
def last: A

Attributes

Inherited from:
IterableOps
def lastOption: Option[A]

Attributes

Inherited from:
IterableOps

Attributes

Inherited from:
Iterable
final override def map[B](f: ((Boolean, NodeT)) => B): Iterable[B]

Attributes

Definition Classes
Inherited from:
ForeachBasedDetachingIterable
final override def max[B >: (Boolean, NodeT)](implicit ord: Ordering[B]): A

Attributes

Definition Classes
Inherited from:
ForeachBasedDetachingIterable
final override def maxBy[B](f: ((Boolean, NodeT)) => B)(implicit cmp: Ordering[B]): A

Attributes

Definition Classes
Inherited from:
ForeachBasedDetachingIterable
final override def maxByOption[B](f: ((Boolean, NodeT)) => B)(implicit cmp: Ordering[B]): Option[A]

Attributes

Definition Classes
Inherited from:
ForeachBasedDetachingIterable
final override def maxOption[B >: (Boolean, NodeT)](implicit ord: Ordering[B]): Option[A]

Attributes

Definition Classes
Inherited from:
ForeachBasedDetachingIterable
final override def min[B >: (Boolean, NodeT)](implicit ord: Ordering[B]): A

Attributes

Definition Classes
Inherited from:
ForeachBasedDetachingIterable
final override def minBy[B](f: ((Boolean, NodeT)) => B)(implicit cmp: Ordering[B]): A

Attributes

Definition Classes
Inherited from:
ForeachBasedDetachingIterable
final override def minByOption[B](f: ((Boolean, NodeT)) => B)(implicit cmp: Ordering[B]): Option[A]

Attributes

Definition Classes
Inherited from:
ForeachBasedDetachingIterable
final override def minOption[B >: (Boolean, NodeT)](implicit ord: Ordering[B]): Option[A]

Attributes

Definition Classes
Inherited from:
ForeachBasedDetachingIterable
final def mkString: String

Attributes

Inherited from:
IterableOnceOps
final def mkString(sep: String): String

Attributes

Inherited from:
IterableOnceOps

Attributes

Inherited from:
IterableOnceOps
protected def newSpecificBuilder: Builder[A, CC[A]]

Attributes

Inherited from:
IterableFactoryDefaults

Attributes

Inherited from:
IterableOnceOps
final protected def nonOverflowingOrderMultipliedBy_2: Int

Attributes

Inherited from:
Traverser
final def partOfCycle[U](implicit visitor: ((Boolean, NodeT)) => U): Option[Cycle]

Finds a cycle that contains root $INTOACC. Irrespective of the current setting for kind, DepthFirst is used internally.

Finds a cycle that contains root $INTOACC. Irrespective of the current setting for kind, DepthFirst is used internally.

Value parameters

visitor

$OPTVISITOR

Attributes

Returns

A cycle containing root or None if either a. there exists no cycle containing root or a. there exists such a cycle but due to withSubgraph settings this path was out of scope.

Inherited from:
Impl (hidden)
def partition(p: ((Boolean, NodeT)) => Boolean): (C, C)

Attributes

Inherited from:
IterableOps
def partitionMap[A1, A2](f: ((Boolean, NodeT)) => Either[A1, A2]): (CC[A1], CC[A2])

Attributes

Inherited from:
IterableOps
final def pathTo[U](potentialSuccessor: NodeT)(implicit visitor: ((Boolean, NodeT)) => U): Option[Path]

Finds a path from root to potentialSuccessor considering all traversal properties passed to the traverser factory method like scalax.collection.GraphTraversal#innerNodeTraverser or altered by any with* method.

Finds a path from root to potentialSuccessor considering all traversal properties passed to the traverser factory method like scalax.collection.GraphTraversal#innerNodeTraverser or altered by any with* method.

Value parameters

potentialSuccessor

The node a path is to be found to.

visitor

An optional function that is applied for its side-effect to every element visited during graph traversal.

Attributes

Returns

A path to potentialSuccessor or None if either a. there is no node with pred or a. there exists no path to such a node

Inherited from:
TraverserMethods (hidden)
final def pathUntil[U](pred: NodePredicate)(implicit visitor: ((Boolean, NodeT)) => U): Option[Path]

Finds a path from root to a successor of root for which pred holds $CONSIDERING root itself does not count as a match. This is also true if it has a hook. If several successors exist the algorithm selects any one of these.

Finds a path from root to a successor of root for which pred holds $CONSIDERING root itself does not count as a match. This is also true if it has a hook. If several successors exist the algorithm selects any one of these.

Value parameters

pred

The predicate which must hold true for the successor.

visitor

$OPTVISITOR

Attributes

Returns

A path to a node with the predicate pred or None if either a. there is no node with pred or a. there exists no path to such a node or a. there exists a path to such a node but due to withSubgraph settings this path was out of scope.

Inherited from:
Impl (hidden)
final override def product[B >: (Boolean, NodeT)](implicit num: Numeric[B]): B

Attributes

Definition Classes
Inherited from:
ForeachBasedDetachingIterable

Attributes

Inherited from:
Product

Attributes

Inherited from:
Product
final override def reduce[B >: (Boolean, NodeT)](op: (B, B) => B): B

Attributes

Definition Classes
Inherited from:
ForeachBasedDetachingIterable
final override def reduceLeft[B >: (Boolean, NodeT)](op: (B, (Boolean, NodeT)) => B): B

Attributes

Definition Classes
Inherited from:
ForeachBasedDetachingIterable
final override def reduceLeftOption[B >: (Boolean, NodeT)](op: (B, (Boolean, NodeT)) => B): Option[B]

Attributes

Definition Classes
Inherited from:
ForeachBasedDetachingIterable
final override def reduceOption[B >: (Boolean, NodeT)](op: (B, B) => B): Option[B]

Attributes

Definition Classes
Inherited from:
ForeachBasedDetachingIterable
def reduceRight[B >: (Boolean, NodeT)](op: ((Boolean, NodeT), B) => B): B

Attributes

Inherited from:
IterableOnceOps
def reduceRightOption[B >: (Boolean, NodeT)](op: ((Boolean, NodeT), B) => B): Option[B]

Attributes

Inherited from:
IterableOnceOps
final protected def requireSuccessors[A](block: => A): A

Attributes

Inherited from:
TraverserMethods (hidden)
protected def reversed: Iterable[A]

Attributes

Inherited from:
IterableOnceOps
def scan[B >: (Boolean, NodeT)](z: B)(op: (B, B) => B): CC[B]

Attributes

Inherited from:
IterableOps
final override def scanLeft[B](z: B)(op: (B, (Boolean, NodeT)) => B): Vector[B]

Attributes

Definition Classes
Inherited from:
ForeachBasedDetachingIterable
def scanRight[B](z: B)(op: ((Boolean, NodeT), B) => B): CC[B]

Attributes

Inherited from:
IterableOps
final def shortestPathTo[T : Numeric, U](potentialSuccessor: NodeT, weight: EdgeT => T, visitor: ((Boolean, NodeT)) => U): Option[Path]

Finds the shortest path from root to potentialSuccessor $CONSIDERING The calculation is based on the weight of the edges on the path. Edges have a default weight of 1L that can be overridden by custom edges. A weight function yielding any numeric type may also be passed to shortestPathTo.

Finds the shortest path from root to potentialSuccessor $CONSIDERING The calculation is based on the weight of the edges on the path. Edges have a default weight of 1L that can be overridden by custom edges. A weight function yielding any numeric type may also be passed to shortestPathTo.

Value parameters

potentialSuccessor

The node the shortest path is to be found to.

visitor

$OPTVISITOR

weight

Function to determine the weight of edges. If supplied, this function takes precedence over edge weights.

Attributes

Returns

The shortest path to potentialSuccessor or None if either a. there exists no path to potentialSuccessor or a. there exists a path to potentialSuccessor but due to withSubgraph settings this path was out of scope.

Inherited from:
Impl (hidden)
final def shortestPathTo[T : Numeric](potentialSuccessor: NodeT, weight: EdgeT => T): Option[Path]

Finds the shortest path from root to potentialSuccessor considering all traversal properties passed to the traverser factory method like scalax.collection.GraphTraversal#innerNodeTraverser or altered by any with* method. The calculation is based on the weight of the edges on the path. Edges have a default weight of 1L that can be overridden by custom edges. A weight function yielding any numeric type may also be passed to shortestPathTo.

Finds the shortest path from root to potentialSuccessor considering all traversal properties passed to the traverser factory method like scalax.collection.GraphTraversal#innerNodeTraverser or altered by any with* method. The calculation is based on the weight of the edges on the path. Edges have a default weight of 1L that can be overridden by custom edges. A weight function yielding any numeric type may also be passed to shortestPathTo.

Value parameters

potentialSuccessor

The node the shortest path is to be found to.

weight

Function to determine the weight of edges. If supplied, this function takes precedence over edge weights.

Attributes

Returns

The shortest path to potentialSuccessor or None if either a. there exists no path to potentialSuccessor or a. there exists a path to potentialSuccessor but due to withSubgraph settings this path was out of scope.

Inherited from:
TraverserMethods (hidden)
final def shortestPathTo[U](potentialSuccessor: NodeT)(implicit visitor: ((Boolean, NodeT)) => U): Option[Path]

Finds the shortest path from root to potentialSuccessor considering all traversal properties passed to the traverser factory method like scalax.collection.GraphTraversal#innerNodeTraverser or altered by any with* method. The calculation is based on the weight of the edges on the path. Edges have a default weight of 1L that can be overridden by custom edges. A weight function yielding any numeric type may also be passed to shortestPathTo.

Finds the shortest path from root to potentialSuccessor considering all traversal properties passed to the traverser factory method like scalax.collection.GraphTraversal#innerNodeTraverser or altered by any with* method. The calculation is based on the weight of the edges on the path. Edges have a default weight of 1L that can be overridden by custom edges. A weight function yielding any numeric type may also be passed to shortestPathTo.

Value parameters

potentialSuccessor

The node the shortest path is to be found to.

visitor

An optional function that is applied for its side-effect to every element visited during graph traversal.

Attributes

Returns

The shortest path to potentialSuccessor or None if either a. there exists no path to potentialSuccessor or a. there exists a path to potentialSuccessor but due to withSubgraph settings this path was out of scope.

Inherited from:
TraverserMethods (hidden)
final override def size: Int

Attributes

Definition Classes
Inherited from:
ForeachBasedDetachingIterable

Attributes

Inherited from:
IterableOps

Attributes

Inherited from:
IterableOps
final protected def sizeHint: Int

Attributes

Inherited from:
InnerNodeDownUpTraverser
final def sizeIs: SizeCompareOps

Attributes

Inherited from:
IterableOps
final override def slice(from: Int, until: Int): Vector[A]

Attributes

Definition Classes
Inherited from:
ForeachBasedDetachingIterable

Attributes

Inherited from:
IterableOps
def sliding(size: Int): Iterator[C]

Attributes

Inherited from:
IterableOps
final override def span(p: ((Boolean, NodeT)) => Boolean): (Vector[A], Vector[A])

Attributes

Definition Classes
Inherited from:
ForeachBasedDetachingIterable
final override def splitAt(n: Int): (Vector[A], Vector[A])

Attributes

Definition Classes
Inherited from:
ForeachBasedDetachingIterable
def stepper[S <: Stepper[_]](implicit shape: StepperShape[(Boolean, NodeT), S]): S

Attributes

Inherited from:
IterableOnce
final def strongComponents[U](implicit visitor: ((Boolean, NodeT)) => U): Iterable[Component]

Finds all strongly connected components reachable from this node. $SEEFLUENT

Finds all strongly connected components reachable from this node. $SEEFLUENT

Value parameters

visitor

Function to be called for each inner node or inner edge visited during the search.

Attributes

Inherited from:
Impl (hidden)
final override def sum[B >: (Boolean, NodeT)](implicit num: Numeric[B]): B

Attributes

Definition Classes
Inherited from:
ForeachBasedDetachingIterable
def tail: C

Attributes

Inherited from:
IterableOps
def tails: Iterator[C]

Attributes

Inherited from:
IterableOps
final override def take(n: Int): Iterable[A]

Attributes

Definition Classes
Inherited from:
ForeachBasedDetachingIterable
def takeRight(n: Int): C

Attributes

Inherited from:
IterableOps
final override def takeWhile(p: ((Boolean, NodeT)) => Boolean): Vector[A]

Attributes

Definition Classes
Inherited from:
ForeachBasedDetachingIterable
override def tapEach[U](f: ((Boolean, NodeT)) => U): C

Attributes

Definition Classes
Inherited from:
IterableOps
final def to[CC <: ([N, E <: Edge[N]] =>> AnyGraph[N, E] & GraphLike[N, E, LazyRef(...)])](factory: GenericGraphCoreFactory[CC]): CC[N, E]

Completes a traversal and creates a new connected graph populated with the elements visited.

Completes a traversal and creates a new connected graph populated with the elements visited.

Attributes

Inherited from:
Traverser
final override def to[C1](factory: Factory[(Boolean, NodeT), C1]): C1

Attributes

Definition Classes
Inherited from:
ForeachBasedDetachingIterable
def toArray[B >: (Boolean, NodeT) : ClassTag]: Array[B]

Attributes

Inherited from:
IterableOnceOps
final def toBuffer[B >: (Boolean, NodeT)]: Buffer[B]

Attributes

Inherited from:
IterableOnceOps

Attributes

Inherited from:
IterableOnceOps
final def toInnerElemTraverser(root: NodeT): InnerElemTraverser

Attributes

Inherited from:
FluentProperties (hidden)
def toList: List[A]

Attributes

Inherited from:
IterableOnceOps
def toMap[K, V](implicit ev: (Boolean, NodeT) <:< (K, V)): Map[K, V]

Attributes

Inherited from:
IterableOnceOps
def toSeq: Seq[A]

Attributes

Inherited from:
IterableOnceOps
def toSet[B >: (Boolean, NodeT)]: Set[B]

Attributes

Inherited from:
IterableOnceOps
override def toString(): String

Returns a string representation of the object.

Returns a string representation of the object.

The default representation is platform dependent.

Attributes

Returns

a string representation of the object.

Definition Classes
Iterable -> Any
Inherited from:
Iterable
def toVector: Vector[A]

Attributes

Inherited from:
IterableOnceOps
final def topologicalSort[U](ignorePredecessors: Boolean)(implicit visitor: InnerElem => U): TopologicalSort

Sorts the component designated by this node topologically. Only nodes connected with this node will be included in the resulting topological order. If the graph is known to be connected choose GraphTraversal#topologicalSort instead. $SEEFLUENT

Sorts the component designated by this node topologically. Only nodes connected with this node will be included in the resulting topological order. If the graph is known to be connected choose GraphTraversal#topologicalSort instead. $SEEFLUENT

Value parameters

ignorePredecessors

If true, the topological sort will be partial in that it will only include successors of root. withSubgraph restricts the successor nodes to be included but not predecessors that will be excluded in total.

visitor

Function to be called for each inner node or inner edge visited during the sort.

Attributes

Inherited from:
Impl (hidden)
def transpose[B](implicit asIterable: ((Boolean, NodeT)) => Iterable[B]): CC[CC[B]]

Attributes

Inherited from:
IterableOps
def unzip[A1, A2](implicit asPair: ((Boolean, NodeT)) => (A1, A2)): (CC[A1], CC[A2])

Attributes

Inherited from:
IterableOps
def unzip3[A1, A2, A3](implicit asTriple: ((Boolean, NodeT)) => (A1, A2, A3)): (CC[A1], CC[A2], CC[A3])

Attributes

Inherited from:
IterableOps
def view: View[A]

Attributes

Inherited from:
IterableOps
final def weakComponent[U](implicit visitor: ((Boolean, NodeT)) => U): Component

Determines the weak component that contains this node. $SEEFLUENT

Determines the weak component that contains this node. $SEEFLUENT

Value parameters

visitor

Function to be called for each inner node or inner edge visited during the search.

Attributes

Inherited from:
Impl (hidden)
final def withDirection(direction: Direction): C

Creates a new FluentProperties based on this except for an updated direction. Note that methods returning a Cycle or Path accept only Successors.

Creates a new FluentProperties based on this except for an updated direction. Note that methods returning a Cycle or Path accept only Successors.

Attributes

Inherited from:
FluentProperties (hidden)
def withFilter(p: ((Boolean, NodeT)) => Boolean): WithFilter[A, CC]

Attributes

Inherited from:
IterableOps
final def withKind(kind: Kind): C

Creates a new FluentProperties based on this except for an updated kind.

Creates a new FluentProperties based on this except for an updated kind.

Attributes

Inherited from:
FluentProperties (hidden)
final def withMaxDepth(maxDepth: Int): C

Creates a new FluentProperties based on this except for an updated maxDepth.

Creates a new FluentProperties based on this except for an updated maxDepth.

Attributes

Inherited from:
FluentProperties (hidden)
final def withMaxWeight(max: Long): C

Creates a new FluentProperties based on this except for an updated maxWeight having the given max and the default weight function returning edge.weight.

Creates a new FluentProperties based on this except for an updated maxWeight having the given max and the default weight function returning edge.weight.

Attributes

Inherited from:
FluentProperties (hidden)
final def withMaxWeight[W : Numeric](max: W, edgeWeight: EdgeT => W): C

Creates a new FluentProperties based on this except for an updated maxWeight having the given max value and the given weight function.

Creates a new FluentProperties based on this except for an updated maxWeight having the given max value and the given weight function.

Attributes

Inherited from:
FluentProperties (hidden)
def withMaxWeight(maxWeight: Option[Weight]): C

Creates a new FluentProperties based on this except for an updated maxWeight.

Creates a new FluentProperties based on this except for an updated maxWeight.

Attributes

Inherited from:
FluentProperties (hidden)
final def withOrdering(ordering: ElemOrdering): C

Creates a new FluentProperties based on this except for an updated ordering.

Creates a new FluentProperties based on this except for an updated ordering.

Attributes

Inherited from:
FluentProperties (hidden)
final def withParameters(parameters: Parameters): C

Creates a new FluentProperties based on this except for an updated parameters.

Creates a new FluentProperties based on this except for an updated parameters.

Attributes

Inherited from:
FluentProperties (hidden)
final def withRoot(root: NodeT): CC

Creates a new FluentProperties based on this except for an updated root.

Creates a new FluentProperties based on this except for an updated root.

Attributes

Inherited from:
TraverserMethods (hidden)
final def withSubgraph(nodes: NodePredicate, edges: EdgePredicate): C

Creates a new FluentProperties based on this except for an updated subgraphNodes and/or subgraphEdges.

Creates a new FluentProperties based on this except for an updated subgraphNodes and/or subgraphEdges.

Attributes

Inherited from:
FluentProperties (hidden)
def zip[B](that: IterableOnce[B]): CC[(A, B)]

Attributes

Inherited from:
IterableOps
def zipAll[A1 >: (Boolean, NodeT), B](that: Iterable[B], thisElem: A1, thatElem: B): CC[(A1, B)]

Attributes

Inherited from:
IterableOps
final override def zipWithIndex: Vector[(A, Int)]

Attributes

Definition Classes
Inherited from:
ForeachBasedDetachingIterable

Deprecated and Inherited methods

def ++:[B >: (Boolean, NodeT)](that: IterableOnce[B]): CC[B]

Attributes

Deprecated
[Since version 2.13.0] Use ++ instead of ++: for collections of type Iterable
Inherited from:
IterableOps
final def /:[B](z: B)(op: (B, (Boolean, NodeT)) => B): B

Attributes

Deprecated
[Since version 2.13.0] Use foldLeft instead of /:
Inherited from:
IterableOnceOps
final def :\[B](z: B)(op: ((Boolean, NodeT), B) => B): B

Attributes

Deprecated
[Since version 2.13.0] Use foldRight instead of :\\
Inherited from:
IterableOnceOps
def aggregate[B](z: => B)(seqop: (B, (Boolean, NodeT)) => B, combop: (B, B) => B): B

Attributes

Deprecated
[Since version 2.13.0] `aggregate` is not relevant for sequential collections. Use `foldLeft(z)(seqop)` instead.
Inherited from:
IterableOnceOps

Attributes

Deprecated
[Since version 2.13.0] Use iterableFactory instead
Inherited from:
IterableOps
final def copyToBuffer[B >: (Boolean, NodeT)](dest: Buffer[B]): Unit

Attributes

Deprecated
[Since version 2.13.0] Use `dest ++= coll` instead
Inherited from:
IterableOnceOps

Attributes

Deprecated
[Since version 2.13.0] Check .knownSize instead of .hasDefiniteSize for more actionable information (see scaladoc for details)
Inherited from:
IterableOnceOps
final def repr: C

Attributes

Deprecated
[Since version 2.13.0] Use coll instead of repr in a collection implementation, use the collection value itself from the outside
Inherited from:
IterableOps
def seq: Iterable.this.type

Attributes

Deprecated
[Since version 2.13.0] Iterable.seq always returns the iterable itself
Inherited from:
Iterable
final def toIterable: Iterable.this.type

Attributes

Deprecated
[Since version 2.13.7] toIterable is internal and will be made protected; its name is similar to `toList` or `toSeq`, but it doesn\'t copy non-immutable collections
Inherited from:
Iterable
final def toIterator: Iterator[A]

Attributes

Deprecated
[Since version 2.13.0] Use .iterator instead of .toIterator
Inherited from:
IterableOnceOps
final def toStream: Stream[A]

Attributes

Deprecated
[Since version 2.13.0] Use .to(LazyList) instead of .toStream
Inherited from:
IterableOnceOps
final def toTraversable: Iterable[A]

Attributes

Deprecated
[Since version 2.13.0] toTraversable is internal and will be made protected; its name is similar to `toList` or `toSeq`, but it doesn\'t copy non-immutable collections
Inherited from:
IterableOps
def view(from: Int, until: Int): View[A]

Attributes

Deprecated
[Since version 2.13.0] Use .view.slice(from, until) instead of .view(from, until)
Inherited from:
IterableOps