Package org.apache.spark.status
Class LiveEntityHelpers
Object
org.apache.spark.status.LiveEntityHelpers
-
Constructor Summary
-
Method Summary
Modifier and TypeMethodDescriptionstatic TaskMetrics
addMetrics
(TaskMetrics m1, TaskMetrics m2) Add m2 values to m1.static TaskMetrics
createMetrics
(long default_) static TaskMetrics
createMetrics
(long executorDeserializeTime, long executorDeserializeCpuTime, long executorRunTime, long executorCpuTime, long resultSize, long jvmGcTime, long resultSerializationTime, long memoryBytesSpilled, long diskBytesSpilled, long peakExecutionMemory, long inputBytesRead, long inputRecordsRead, long outputBytesWritten, long outputRecordsWritten, long shuffleRemoteBlocksFetched, long shuffleLocalBlocksFetched, long shuffleFetchWaitTime, long shuffleRemoteBytesRead, long shuffleRemoteBytesReadToDisk, long shuffleLocalBytesRead, long shuffleRecordsRead, long shuffleCorruptMergedBlockChunks, long shuffleMergedFetchFallbackCount, long shuffleMergedRemoteBlocksFetched, long shuffleMergedLocalBlocksFetched, long shuffleMergedRemoteChunksFetched, long shuffleMergedLocalChunksFetched, long shuffleMergedRemoteBytesRead, long shuffleMergedLocalBytesRead, long shuffleRemoteReqsDuration, long shuffleMergedRemoteReqsDuration, long shuffleBytesWritten, long shuffleWriteTime, long shuffleRecordsWritten) static TaskMetrics
Convert all the metric values to negative as well as handle zero values.static scala.collection.immutable.Seq<AccumulableInfo>
newAccumulatorInfos
(scala.collection.Iterable<AccumulableInfo> accums) static TaskMetrics
subtractMetrics
(TaskMetrics m1, TaskMetrics m2) Subtract m2 values from m1.
-
Constructor Details
-
LiveEntityHelpers
public LiveEntityHelpers()
-
-
Method Details
-
newAccumulatorInfos
public static scala.collection.immutable.Seq<AccumulableInfo> newAccumulatorInfos(scala.collection.Iterable<AccumulableInfo> accums) -
createMetrics
public static TaskMetrics createMetrics(long executorDeserializeTime, long executorDeserializeCpuTime, long executorRunTime, long executorCpuTime, long resultSize, long jvmGcTime, long resultSerializationTime, long memoryBytesSpilled, long diskBytesSpilled, long peakExecutionMemory, long inputBytesRead, long inputRecordsRead, long outputBytesWritten, long outputRecordsWritten, long shuffleRemoteBlocksFetched, long shuffleLocalBlocksFetched, long shuffleFetchWaitTime, long shuffleRemoteBytesRead, long shuffleRemoteBytesReadToDisk, long shuffleLocalBytesRead, long shuffleRecordsRead, long shuffleCorruptMergedBlockChunks, long shuffleMergedFetchFallbackCount, long shuffleMergedRemoteBlocksFetched, long shuffleMergedLocalBlocksFetched, long shuffleMergedRemoteChunksFetched, long shuffleMergedLocalChunksFetched, long shuffleMergedRemoteBytesRead, long shuffleMergedLocalBytesRead, long shuffleRemoteReqsDuration, long shuffleMergedRemoteReqsDuration, long shuffleBytesWritten, long shuffleWriteTime, long shuffleRecordsWritten) -
createMetrics
-
addMetrics
Add m2 values to m1. -
subtractMetrics
Subtract m2 values from m1. -
makeNegative
Convert all the metric values to negative as well as handle zero values. This method assumes that all the metric values are greater than or equal to zero- Parameters:
m
- (undocumented)- Returns:
- (undocumented)
-