Interface StoreTypes.TaskDataWrapperOrBuilder

All Superinterfaces:
com.google.protobuf.MessageLiteOrBuilder, com.google.protobuf.MessageOrBuilder
All Known Implementing Classes:
StoreTypes.TaskDataWrapper, StoreTypes.TaskDataWrapper.Builder
Enclosing class:
StoreTypes

public static interface StoreTypes.TaskDataWrapperOrBuilder extends com.google.protobuf.MessageOrBuilder
  • Method Details

    • getTaskId

      long getTaskId()
      int64 task_id = 1;
      Returns:
      The taskId.
    • getIndex

      int getIndex()
      int32 index = 2;
      Returns:
      The index.
    • getAttempt

      int getAttempt()
      int32 attempt = 3;
      Returns:
      The attempt.
    • getPartitionId

      int getPartitionId()
      int32 partition_id = 4;
      Returns:
      The partitionId.
    • getLaunchTime

      long getLaunchTime()
      int64 launch_time = 5;
      Returns:
      The launchTime.
    • getResultFetchStart

      long getResultFetchStart()
      int64 result_fetch_start = 6;
      Returns:
      The resultFetchStart.
    • getDuration

      long getDuration()
      int64 duration = 7;
      Returns:
      The duration.
    • hasExecutorId

      boolean hasExecutorId()
      optional string executor_id = 8;
      Returns:
      Whether the executorId field is set.
    • getExecutorId

      String getExecutorId()
      optional string executor_id = 8;
      Returns:
      The executorId.
    • getExecutorIdBytes

      com.google.protobuf.ByteString getExecutorIdBytes()
      optional string executor_id = 8;
      Returns:
      The bytes for executorId.
    • hasHost

      boolean hasHost()
      optional string host = 9;
      Returns:
      Whether the host field is set.
    • getHost

      String getHost()
      optional string host = 9;
      Returns:
      The host.
    • getHostBytes

      com.google.protobuf.ByteString getHostBytes()
      optional string host = 9;
      Returns:
      The bytes for host.
    • hasStatus

      boolean hasStatus()
      optional string status = 10;
      Returns:
      Whether the status field is set.
    • getStatus

      String getStatus()
      optional string status = 10;
      Returns:
      The status.
    • getStatusBytes

      com.google.protobuf.ByteString getStatusBytes()
      optional string status = 10;
      Returns:
      The bytes for status.
    • hasTaskLocality

      boolean hasTaskLocality()
      optional string task_locality = 11;
      Returns:
      Whether the taskLocality field is set.
    • getTaskLocality

      String getTaskLocality()
      optional string task_locality = 11;
      Returns:
      The taskLocality.
    • getTaskLocalityBytes

      com.google.protobuf.ByteString getTaskLocalityBytes()
      optional string task_locality = 11;
      Returns:
      The bytes for taskLocality.
    • getSpeculative

      boolean getSpeculative()
      bool speculative = 12;
      Returns:
      The speculative.
    • getAccumulatorUpdatesList

      List<StoreTypes.AccumulableInfo> getAccumulatorUpdatesList()
      repeated .org.apache.spark.status.protobuf.AccumulableInfo accumulator_updates = 13;
    • getAccumulatorUpdates

      StoreTypes.AccumulableInfo getAccumulatorUpdates(int index)
      repeated .org.apache.spark.status.protobuf.AccumulableInfo accumulator_updates = 13;
    • getAccumulatorUpdatesCount

      int getAccumulatorUpdatesCount()
      repeated .org.apache.spark.status.protobuf.AccumulableInfo accumulator_updates = 13;
    • getAccumulatorUpdatesOrBuilderList

      List<? extends StoreTypes.AccumulableInfoOrBuilder> getAccumulatorUpdatesOrBuilderList()
      repeated .org.apache.spark.status.protobuf.AccumulableInfo accumulator_updates = 13;
    • getAccumulatorUpdatesOrBuilder

      StoreTypes.AccumulableInfoOrBuilder getAccumulatorUpdatesOrBuilder(int index)
      repeated .org.apache.spark.status.protobuf.AccumulableInfo accumulator_updates = 13;
    • hasErrorMessage

      boolean hasErrorMessage()
      optional string error_message = 14;
      Returns:
      Whether the errorMessage field is set.
    • getErrorMessage

      String getErrorMessage()
      optional string error_message = 14;
      Returns:
      The errorMessage.
    • getErrorMessageBytes

      com.google.protobuf.ByteString getErrorMessageBytes()
      optional string error_message = 14;
      Returns:
      The bytes for errorMessage.
    • getHasMetrics

      boolean getHasMetrics()
      bool has_metrics = 15;
      Returns:
      The hasMetrics.
    • getExecutorDeserializeTime

      long getExecutorDeserializeTime()
      int64 executor_deserialize_time = 16;
      Returns:
      The executorDeserializeTime.
    • getExecutorDeserializeCpuTime

      long getExecutorDeserializeCpuTime()
      int64 executor_deserialize_cpu_time = 17;
      Returns:
      The executorDeserializeCpuTime.
    • getExecutorRunTime

      long getExecutorRunTime()
      int64 executor_run_time = 18;
      Returns:
      The executorRunTime.
    • getExecutorCpuTime

      long getExecutorCpuTime()
      int64 executor_cpu_time = 19;
      Returns:
      The executorCpuTime.
    • getResultSize

      long getResultSize()
      int64 result_size = 20;
      Returns:
      The resultSize.
    • getJvmGcTime

      long getJvmGcTime()
      int64 jvm_gc_time = 21;
      Returns:
      The jvmGcTime.
    • getResultSerializationTime

      long getResultSerializationTime()
      int64 result_serialization_time = 22;
      Returns:
      The resultSerializationTime.
    • getMemoryBytesSpilled

      long getMemoryBytesSpilled()
      int64 memory_bytes_spilled = 23;
      Returns:
      The memoryBytesSpilled.
    • getDiskBytesSpilled

      long getDiskBytesSpilled()
      int64 disk_bytes_spilled = 24;
      Returns:
      The diskBytesSpilled.
    • getPeakExecutionMemory

      long getPeakExecutionMemory()
      int64 peak_execution_memory = 25;
      Returns:
      The peakExecutionMemory.
    • getInputBytesRead

      long getInputBytesRead()
      int64 input_bytes_read = 26;
      Returns:
      The inputBytesRead.
    • getInputRecordsRead

      long getInputRecordsRead()
      int64 input_records_read = 27;
      Returns:
      The inputRecordsRead.
    • getOutputBytesWritten

      long getOutputBytesWritten()
      int64 output_bytes_written = 28;
      Returns:
      The outputBytesWritten.
    • getOutputRecordsWritten

      long getOutputRecordsWritten()
      int64 output_records_written = 29;
      Returns:
      The outputRecordsWritten.
    • getShuffleRemoteBlocksFetched

      long getShuffleRemoteBlocksFetched()
      int64 shuffle_remote_blocks_fetched = 30;
      Returns:
      The shuffleRemoteBlocksFetched.
    • getShuffleLocalBlocksFetched

      long getShuffleLocalBlocksFetched()
      int64 shuffle_local_blocks_fetched = 31;
      Returns:
      The shuffleLocalBlocksFetched.
    • getShuffleFetchWaitTime

      long getShuffleFetchWaitTime()
      int64 shuffle_fetch_wait_time = 32;
      Returns:
      The shuffleFetchWaitTime.
    • getShuffleRemoteBytesRead

      long getShuffleRemoteBytesRead()
      int64 shuffle_remote_bytes_read = 33;
      Returns:
      The shuffleRemoteBytesRead.
    • getShuffleRemoteBytesReadToDisk

      long getShuffleRemoteBytesReadToDisk()
      int64 shuffle_remote_bytes_read_to_disk = 34;
      Returns:
      The shuffleRemoteBytesReadToDisk.
    • getShuffleLocalBytesRead

      long getShuffleLocalBytesRead()
      int64 shuffle_local_bytes_read = 35;
      Returns:
      The shuffleLocalBytesRead.
    • getShuffleRecordsRead

      long getShuffleRecordsRead()
      int64 shuffle_records_read = 36;
      Returns:
      The shuffleRecordsRead.
    • getShuffleBytesWritten

      long getShuffleBytesWritten()
      int64 shuffle_bytes_written = 37;
      Returns:
      The shuffleBytesWritten.
    • getShuffleWriteTime

      long getShuffleWriteTime()
      int64 shuffle_write_time = 38;
      Returns:
      The shuffleWriteTime.
    • getShuffleRecordsWritten

      long getShuffleRecordsWritten()
      int64 shuffle_records_written = 39;
      Returns:
      The shuffleRecordsWritten.
    • getStageId

      long getStageId()
      int64 stage_id = 40;
      Returns:
      The stageId.
    • getStageAttemptId

      int getStageAttemptId()
      int32 stage_attempt_id = 41;
      Returns:
      The stageAttemptId.
    • getShuffleCorruptMergedBlockChunks

      long getShuffleCorruptMergedBlockChunks()
      int64 shuffle_corrupt_merged_block_chunks = 42;
      Returns:
      The shuffleCorruptMergedBlockChunks.
    • getShuffleMergedFetchFallbackCount

      long getShuffleMergedFetchFallbackCount()
      int64 shuffle_merged_fetch_fallback_count = 43;
      Returns:
      The shuffleMergedFetchFallbackCount.
    • getShuffleMergedRemoteBlocksFetched

      long getShuffleMergedRemoteBlocksFetched()
      int64 shuffle_merged_remote_blocks_fetched = 44;
      Returns:
      The shuffleMergedRemoteBlocksFetched.
    • getShuffleMergedLocalBlocksFetched

      long getShuffleMergedLocalBlocksFetched()
      int64 shuffle_merged_local_blocks_fetched = 45;
      Returns:
      The shuffleMergedLocalBlocksFetched.
    • getShuffleMergedRemoteChunksFetched

      long getShuffleMergedRemoteChunksFetched()
      int64 shuffle_merged_remote_chunks_fetched = 46;
      Returns:
      The shuffleMergedRemoteChunksFetched.
    • getShuffleMergedLocalChunksFetched

      long getShuffleMergedLocalChunksFetched()
      int64 shuffle_merged_local_chunks_fetched = 47;
      Returns:
      The shuffleMergedLocalChunksFetched.
    • getShuffleMergedRemoteBytesRead

      long getShuffleMergedRemoteBytesRead()
      int64 shuffle_merged_remote_bytes_read = 48;
      Returns:
      The shuffleMergedRemoteBytesRead.
    • getShuffleMergedLocalBytesRead

      long getShuffleMergedLocalBytesRead()
      int64 shuffle_merged_local_bytes_read = 49;
      Returns:
      The shuffleMergedLocalBytesRead.
    • getShuffleRemoteReqsDuration

      long getShuffleRemoteReqsDuration()
      int64 shuffle_remote_reqs_duration = 50;
      Returns:
      The shuffleRemoteReqsDuration.
    • getShuffleMergedRemoteReqDuration

      long getShuffleMergedRemoteReqDuration()
      int64 shuffle_merged_remote_req_duration = 51;
      Returns:
      The shuffleMergedRemoteReqDuration.