Skip to content

Commit a633bce

Browse files
committed
Merge remote-tracking branch 'apache-github/branch-0.9' into branch-0.9-fix
2 parents 9b043cc + 72875b2 commit a633bce

File tree

4 files changed

+8
-2
lines changed

4 files changed

+8
-2
lines changed

core/src/main/scala/org/apache/spark/rdd/PairRDDFunctions.scala

Lines changed: 2 additions & 0 deletions
Original file line numberDiff line numberDiff line change
@@ -44,6 +44,7 @@ import com.clearspring.analytics.stream.cardinality.HyperLogLog
4444
import org.apache.hadoop.mapred.SparkHadoopWriter
4545
import org.apache.hadoop.mapreduce.SparkHadoopMapReduceUtil
4646
import org.apache.spark._
47+
import org.apache.spark.deploy.SparkHadoopUtil
4748
import org.apache.spark.SparkContext._
4849
import org.apache.spark.partial.{BoundedDouble, PartialResult}
4950
import org.apache.spark.Partitioner.defaultPartitioner
@@ -710,6 +711,7 @@ class PairRDDFunctions[K: ClassTag, V: ClassTag](self: RDD[(K, V)])
710711
if (valueClass == null) {
711712
throw new SparkException("Output value class not set")
712713
}
714+
SparkHadoopUtil.get.addCredentials(conf)
713715

714716
logDebug("Saving as hadoop file of type (" + keyClass.getSimpleName + ", " +
715717
valueClass.getSimpleName+ ")")

core/src/main/scala/org/apache/spark/ui/jobs/StageTable.scala

Lines changed: 3 additions & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -106,7 +106,9 @@ private[spark] class StageTable(val stages: Seq[StageInfo], val parent: JobProgr
106106
val description = listener.stageIdToDescription.get(s.stageId)
107107
.map(d => <div><em>{d}</em></div><div>{nameLink}</div>).getOrElse(nameLink)
108108
val finishTime = s.completionTime.getOrElse(System.currentTimeMillis())
109-
val duration = s.submissionTime.map(t => finishTime - t)
109+
val duration = s.submissionTime.map { t =>
110+
if (finishTime > t) finishTime - t else System.currentTimeMillis - t
111+
}
110112

111113
<tr>
112114
<td>{s.stageId}</td>

dev/merge_spark_pr.py

Lines changed: 2 additions & 0 deletions
Original file line numberDiff line numberDiff line change
@@ -38,6 +38,8 @@
3838
# Remote name which points to Apache git
3939
PUSH_REMOTE_NAME = os.environ.get("PUSH_REMOTE_NAME", "apache")
4040

41+
print "%s" % PUSH_REMOTE_NAME
42+
4143
GIT_API_BASE = "https://api.github.com/repos/apache/spark"
4244
# Prefix added to temporary branches
4345
BRANCH_PREFIX = "PR_TOOL"

yarn/alpha/pom.xml

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -20,7 +20,7 @@
2020
<parent>
2121
<groupId>org.apache.spark</groupId>
2222
<artifactId>yarn-parent_2.10</artifactId>
23-
<version>0.9.0-incubating</version>
23+
<version>0.9.1-incubating-SNAPSHOT</version>
2424
<relativePath>../pom.xml</relativePath>
2525
</parent>
2626

0 commit comments

Comments
 (0)