Uploaded image for project: 'SystemDS'
  1. SystemDS
  2. SYSTEMDS-1135

Remove unused enum constants from project

    XMLWordPrintableJSON

Details

    • Improvement
    • Status: Closed
    • Major
    • Resolution: Fixed
    • None
    • SystemML 0.12
    • Runtime
    • None

    Description

      Unused (unreferenced) enum constants should be removed from the project because they are misleading.

      Here is a list of unused enum constants in the project:

      org.apache.sysml.hops.BinaryOp.AppendMethod.CP_APPEND
      org.apache.sysml.hops.cost.CostEstimationWrapper.CostType.DYNAMIC
      org.apache.sysml.hops.globalopt.GlobalOptimizerWrapper.GlobalOptimizerType.TRANSFORM
      org.apache.sysml.hops.globalopt.InterestingProperties.Format.BINARY_CELL
      org.apache.sysml.hops.globalopt.InterestingProperties.Format.TEXT_CSV
      org.apache.sysml.hops.globalopt.InterestingProperties.Format.TEXT_MM
      org.apache.sysml.hops.globalopt.InterestingProperties.Location.HDFS_CACHE
      org.apache.sysml.hops.globalopt.InterestingProperties.Partitioning.ROW_WISE
      org.apache.sysml.hops.Hop.OpOp3.INVALID
      org.apache.sysml.hops.Hop.OpOp4.INVALID
      org.apache.sysml.hops.Hop.VisitStatus.VISITING
      org.apache.sysml.lops.BinaryScalar.OperationTypes.Over
      org.apache.sysml.lops.BinaryScalar.OperationTypes.SUBTRACTRIGHT
      org.apache.sysml.lops.CombineTernary.OperationTypes.PreGroupedAggWeighted
      org.apache.sysml.lops.Lop.SimpleInstType.File
      org.apache.sysml.lops.Lop.SimpleInstType.Variable
      org.apache.sysml.lops.Lop.Type.ConvolutionTransform
      org.apache.sysml.lops.Lop.VisitStatus.VISITING
      org.apache.sysml.lops.ParameterizedBuiltin.OperationTypes.INVALID
      org.apache.sysml.lops.ParameterizedBuiltin.OperationTypes.PCHISQ
      org.apache.sysml.lops.ParameterizedBuiltin.OperationTypes.PEXP
      org.apache.sysml.lops.ParameterizedBuiltin.OperationTypes.PF
      org.apache.sysml.lops.ParameterizedBuiltin.OperationTypes.PNORM
      org.apache.sysml.lops.ParameterizedBuiltin.OperationTypes.PT
      org.apache.sysml.lops.ParameterizedBuiltin.OperationTypes.QCHISQ
      org.apache.sysml.lops.ParameterizedBuiltin.OperationTypes.QEXP
      org.apache.sysml.lops.ParameterizedBuiltin.OperationTypes.QF
      org.apache.sysml.lops.ParameterizedBuiltin.OperationTypes.QNORM
      org.apache.sysml.lops.ParameterizedBuiltin.OperationTypes.QT
      org.apache.sysml.lops.UnaryCP.OperationTypes.NOTSUPPORTED
      org.apache.sysml.parser.Expression.BuiltinFunctionOp.AVG
      org.apache.sysml.parser.Expression.DataOp.INVALID
      org.apache.sysml.parser.Expression.FormatType.UNKNOWN
      org.apache.sysml.parser.Expression.Kind.ExtBuiltinFunctionOp
      org.apache.sysml.parser.Expression.Kind.Literal
      org.apache.sysml.parser.Expression.Kind.UnaryOp
      org.apache.sysml.runtime.controlprogram.parfor.opt.OptNode.ParamType.OPTYPE
      org.apache.sysml.runtime.controlprogram.parfor.opt.PerfTestTool.InternalTestVariable.NUM_MAPPERS
      org.apache.sysml.runtime.controlprogram.parfor.opt.PerfTestTool.InternalTestVariable.NUM_REDUCERS
      org.apache.sysml.runtime.controlprogram.parfor.opt.PerfTestTool.InternalTestVariable.NUM_THREADS
      org.apache.sysml.runtime.controlprogram.parfor.opt.PerfTestTool.IOSchema.UNARY_NONE
      org.apache.sysml.runtime.controlprogram.parfor.stat.Stat.PARSE_T
      org.apache.sysml.runtime.controlprogram.ParForProgramBlock.PDataPartitionFormat.UNSPECIFIED
      org.apache.sysml.runtime.functionobjects.Builtin.BuiltinCode.INVALID
      org.apache.sysml.runtime.functionobjects.ParameterizedBuiltin.ParameterizedBuiltinCode.INVALID
      org.apache.sysml.runtime.instructions.Instruction.INSTRUCTION_TYPE.EXTERNAL_LIBRARY
      org.apache.sysml.runtime.instructions.mr.MRInstruction.MRINSTRUCTION_TYPE.Combine
      org.apache.sysml.runtime.instructions.spark.utils.RDDConverterUtilsExt.RDDConverterTypes.ROW_TO_DOUBLEARR
      org.apache.sysml.runtime.instructions.spark.utils.RDDConverterUtilsExt.RDDConverterTypes.TEXT_TO_DOUBLEARR
      org.apache.sysml.runtime.instructions.spark.utils.RDDConverterUtilsExt.RDDConverterTypes.VECTOR_TO_DOUBLEARR
      org.apache.sysml.runtime.matrix.data.FileFormatProperties.FileFormat.PARTITIONED
      org.apache.sysml.runtime.matrix.operators.CMOperator.AggregateOperationTypes.CM
      org.apache.sysml.runtime.matrix.operators.CMOperator.AggregateOperationTypes.NORM
      org.apache.sysml.runtime.transform.TfUtils.ColumnTypes.INVALID
      org.apache.sysml.udf.Matrix.ValueType.Integer
      

      Attachments

        Issue Links

          Activity

            People

              deron Jon Deron Eriksson
              deron Jon Deron Eriksson
              Votes:
              0 Vote for this issue
              Watchers:
              1 Start watching this issue

              Dates

                Created:
                Updated:
                Resolved: