Interface StoreTypes.ApplicationInfoOrBuilder

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

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

    • hasId

      boolean hasId()
      optional string id = 1;
      Returns:
      Whether the id field is set.
    • getId

      String getId()
      optional string id = 1;
      Returns:
      The id.
    • getIdBytes

      com.google.protobuf.ByteString getIdBytes()
      optional string id = 1;
      Returns:
      The bytes for id.
    • hasName

      boolean hasName()
      optional string name = 2;
      Returns:
      Whether the name field is set.
    • getName

      String getName()
      optional string name = 2;
      Returns:
      The name.
    • getNameBytes

      com.google.protobuf.ByteString getNameBytes()
      optional string name = 2;
      Returns:
      The bytes for name.
    • hasCoresGranted

      boolean hasCoresGranted()
      optional int32 cores_granted = 3;
      Returns:
      Whether the coresGranted field is set.
    • getCoresGranted

      int getCoresGranted()
      optional int32 cores_granted = 3;
      Returns:
      The coresGranted.
    • hasMaxCores

      boolean hasMaxCores()
      optional int32 max_cores = 4;
      Returns:
      Whether the maxCores field is set.
    • getMaxCores

      int getMaxCores()
      optional int32 max_cores = 4;
      Returns:
      The maxCores.
    • hasCoresPerExecutor

      boolean hasCoresPerExecutor()
      optional int32 cores_per_executor = 5;
      Returns:
      Whether the coresPerExecutor field is set.
    • getCoresPerExecutor

      int getCoresPerExecutor()
      optional int32 cores_per_executor = 5;
      Returns:
      The coresPerExecutor.
    • hasMemoryPerExecutorMb

      boolean hasMemoryPerExecutorMb()
      optional int32 memory_per_executor_mb = 6;
      Returns:
      Whether the memoryPerExecutorMb field is set.
    • getMemoryPerExecutorMb

      int getMemoryPerExecutorMb()
      optional int32 memory_per_executor_mb = 6;
      Returns:
      The memoryPerExecutorMb.
    • getAttemptsList

      repeated .org.apache.spark.status.protobuf.ApplicationAttemptInfo attempts = 7;
    • getAttempts

      StoreTypes.ApplicationAttemptInfo getAttempts(int index)
      repeated .org.apache.spark.status.protobuf.ApplicationAttemptInfo attempts = 7;
    • getAttemptsCount

      int getAttemptsCount()
      repeated .org.apache.spark.status.protobuf.ApplicationAttemptInfo attempts = 7;
    • getAttemptsOrBuilderList

      List<? extends StoreTypes.ApplicationAttemptInfoOrBuilder> getAttemptsOrBuilderList()
      repeated .org.apache.spark.status.protobuf.ApplicationAttemptInfo attempts = 7;
    • getAttemptsOrBuilder

      StoreTypes.ApplicationAttemptInfoOrBuilder getAttemptsOrBuilder(int index)
      repeated .org.apache.spark.status.protobuf.ApplicationAttemptInfo attempts = 7;