Skip to content

Commit

Permalink
Small fixes
Browse files Browse the repository at this point in the history
  • Loading branch information
pwendell committed Mar 31, 2014
1 parent cf23ec6 commit 542a736
Show file tree
Hide file tree
Showing 3 changed files with 4 additions and 4 deletions.
2 changes: 1 addition & 1 deletion core/src/main/scala/org/apache/spark/SparkEnv.scala
Original file line number Diff line number Diff line change
Expand Up @@ -41,7 +41,7 @@ import org.apache.spark.util.{AkkaUtils, Utils}
* objects needs to have the right SparkEnv set. You can get the current environment with
* SparkEnv.get (e.g. after creating a SparkContext) and set it with SparkEnv.set.
*/
private[spark] class SparkEnv private[spark] (
private[spark] class SparkEnv (
val executorId: String,
val actorSystem: ActorSystem,
val serializer: Serializer,
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -38,8 +38,8 @@ import org.apache.spark.util._
private[spark] sealed trait Values

private[spark] case class ByteBufferValues(buffer: ByteBuffer) extends Values
private[spark]case class IteratorValues(iterator: Iterator[Any]) extends Values
private[spark]case class ArrayBufferValues(buffer: ArrayBuffer[Any]) extends Values
private[spark] case class IteratorValues(iterator: Iterator[Any]) extends Values
private[spark] case class ArrayBufferValues(buffer: ArrayBuffer[Any]) extends Values

private[spark] class BlockManager(
executorId: String,
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -70,7 +70,7 @@ class BernoulliSampler[T](lb: Double, ub: Double, complement: Boolean = false)
override def clone = new BernoulliSampler[T](lb, ub)
}

/** Ps
/**
* <span class="badge badge-red" style="float: right;">DEVELOPER API - UNSTABLE</span>
*
* A sampler based on values drawn from Poisson distribution.
Expand Down

0 comments on commit 542a736

Please sign in to comment.