removed deprecated DSL*.scala files
authorProdromos Gerakios <pgerakios@grnet.gr>
Mon, 9 Jul 2012 13:41:30 +0000 (16:41 +0300)
committerProdromos Gerakios <pgerakios@grnet.gr>
Mon, 9 Jul 2012 13:41:30 +0000 (16:41 +0300)
src/main/scala/gr/grnet/aquarium/logic/accounting/dsl/DSLCronSpec.scala [deleted file]
src/main/scala/gr/grnet/aquarium/logic/accounting/dsl/DSLTimeBoundedItem.scala [deleted file]
src/main/scala/gr/grnet/aquarium/logic/accounting/dsl/DSLTimeFrame.scala [deleted file]
src/main/scala/gr/grnet/aquarium/logic/accounting/dsl/DSLTimeFrameRepeat.scala [deleted file]
src/main/scala/gr/grnet/aquarium/logic/accounting/dsl/DSLUtils.scala [deleted file]
src/main/scala/gr/grnet/aquarium/policy/EffectiveUnitPrice.scala

diff --git a/src/main/scala/gr/grnet/aquarium/logic/accounting/dsl/DSLCronSpec.scala b/src/main/scala/gr/grnet/aquarium/logic/accounting/dsl/DSLCronSpec.scala
deleted file mode 100644 (file)
index 18864b7..0000000
+++ /dev/null
@@ -1,132 +0,0 @@
-/*
- * Copyright 2011-2012 GRNET S.A. All rights reserved.
- *
- * Redistribution and use in source and binary forms, with or
- * without modification, are permitted provided that the following
- * conditions are met:
- *
- *   1. Redistributions of source code must retain the above
- *      copyright notice, this list of conditions and the following
- *      disclaimer.
- *
- *   2. Redistributions in binary form must reproduce the above
- *      copyright notice, this list of conditions and the following
- *      disclaimer in the documentation and/or other materials
- *      provided with the distribution.
- *
- * THIS SOFTWARE IS PROVIDED BY GRNET S.A. ``AS IS'' AND ANY EXPRESS
- * OR IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED
- * WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A PARTICULAR
- * PURPOSE ARE DISCLAIMED. IN NO EVENT SHALL GRNET S.A OR
- * CONTRIBUTORS BE LIABLE FOR ANY DIRECT, INDIRECT, INCIDENTAL,
- * SPECIAL, EXEMPLARY, OR CONSEQUENTIAL DAMAGES (INCLUDING, BUT NOT
- * LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR SERVICES; LOSS OF
- * USE, DATA, OR PROFITS; OR BUSINESS INTERRUPTION) HOWEVER CAUSED
- * AND ON ANY THEORY OF LIABILITY, WHETHER IN CONTRACT, STRICT
- * LIABILITY, OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) ARISING IN
- * ANY WAY OUT OF THE USE OF THIS SOFTWARE, EVEN IF ADVISED OF THE
- * POSSIBILITY OF SUCH DAMAGE.
- *
- * The views and conclusions contained in the software and
- * documentation are those of the authors and should not be
- * interpreted as representing official policies, either expressed
- * or implied, of GRNET S.A.
- */
-
-package gr.grnet.aquarium.logic.accounting.dsl
-
-import org.quartz.CronExpression
-import java.util.Date
-
-/**
- * @author Prodromos Gerakios <pgerakios@grnet.gr>
- */
-
-case class DSLCronSpec(cronSpec: String) {
-
-    private val cronExpr = {
-      val e = "00 " + cronSpec.trim //IMPORTANT: WE DO NOT CARE ABOUT SECONDS!!!
-      val l = e.split(" ")
-      assert(l.size == 6,"Invalid cron specification")
-      //for {ll <- l } Console.err.println(ll)
-      (l(3),l(5))  match {
-        case ("?",_) | (_,"?") => ()
-        case (_,"*") => l.update(5,"?")
-        case ("*",_) => l.update(3,"?")
-      }
-      val e1 = l.foldLeft("") { (s,elt) => s + " " + elt}
-      //Console.err.println("e = " + e + " and e1 = " + e1)
-      new CronExpression(e1)
-    }
-
-    def includes(d:Date) : Boolean =
-      cronExpr isSatisfiedBy d
-
-  /* the next valid date cannot outlive (min,max)*/
-  def nextValidDate(min0:Date,max0:Date,d:Date) : Option[Date] =
-    (cronExpr getNextValidTimeAfter d) match {
-      case null =>
-        None
-      case d1 =>
-        val (min,max,e) = (min0.getTime,max0.getTime,d1.getTime)
-        if(e < min || e>max)
-          None
-        else
-          Some({assert(d1.getTime>=d.getTime);d1})
-    }
-
-  /*def nextValidDate(d:Date) : Date = {
-   val ret = cronExpr getNextValidTimeAfter d
-   ret
- } */
-
-  /*def nextContinuousValidDate(d:Date) : Date = {
-      val d1 = cronExpr getNextInvalidTimeAfter d
-      if (d1 != null)
-        d1.setTime(d1.getTime - 1000) /* 1 sec before was valid so return this*/
-      d1
-    }
-
-
-    def getMaxValidBeforeDate(min0:Date , max0:Date,d:Date) : Option[Date] ={
-      val (min,max,e) = (min0.getTime,max0.getTime,d.getTime)
-      if(min > e || max < e) None
-      else if(includes(d)) Some(d)
-      else {
-        var end = e
-        var start = min //0L
-        var best:Date = null
-        var iterations=0L
-        val tmp = new Date(0L)
-        val step = 10000L * 60L // 1 minute
-        while(start < end) {
-          iterations += 1
-          val pivot = (end - start) / 2 + start
-          tmp.setTime(pivot)
-          val next = nextValidDate(tmp)
-          if(next == null){ /* no valid time after pivot*/
-            end = pivot-step; // pivot minus one
-          } else {
-            val p = next.getTime()
-            if(p < e) { /* next date occurs before e*/
-              val post =  next.getTime < d.getTime
-              assert(post,"BUG!!!")
-              best = next
-              start = p + step
-            } else if( p > e) { /* next date occurs after e*/
-              end = pivot-step
-            }
-            else assert(false,"This should not happen")
-          }
-        //  System.err.println("Start: " + new Date(start) + " end: " + new Date(end));
-        }
-        System.err.println("Iterations " + iterations);
-        if(best!=null) Some(best) else None
-      }
-    }
-    */
-}
-
-object DSLCronSpec {
-  val emptyCronSpec = new DSLCronSpec("? ? ? ? ?")
-}
\ No newline at end of file
diff --git a/src/main/scala/gr/grnet/aquarium/logic/accounting/dsl/DSLTimeBoundedItem.scala b/src/main/scala/gr/grnet/aquarium/logic/accounting/dsl/DSLTimeBoundedItem.scala
deleted file mode 100644 (file)
index 7b1c043..0000000
+++ /dev/null
@@ -1,51 +0,0 @@
-/*
- * Copyright 2011-2012 GRNET S.A. All rights reserved.
- *
- * Redistribution and use in source and binary forms, with or
- * without modification, are permitted provided that the following
- * conditions are met:
- *
- *   1. Redistributions of source code must retain the above
- *      copyright notice, this list of conditions and the following
- *      disclaimer.
- *
- *   2. Redistributions in binary form must reproduce the above
- *      copyright notice, this list of conditions and the following
- *      disclaimer in the documentation and/or other materials
- *      provided with the distribution.
- *
- * THIS SOFTWARE IS PROVIDED BY GRNET S.A. ``AS IS'' AND ANY EXPRESS
- * OR IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED
- * WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A PARTICULAR
- * PURPOSE ARE DISCLAIMED. IN NO EVENT SHALL GRNET S.A OR
- * CONTRIBUTORS BE LIABLE FOR ANY DIRECT, INDIRECT, INCIDENTAL,
- * SPECIAL, EXEMPLARY, OR CONSEQUENTIAL DAMAGES (INCLUDING, BUT NOT
- * LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR SERVICES; LOSS OF
- * USE, DATA, OR PROFITS; OR BUSINESS INTERRUPTION) HOWEVER CAUSED
- * AND ON ANY THEORY OF LIABILITY, WHETHER IN CONTRACT, STRICT
- * LIABILITY, OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) ARISING IN
- * ANY WAY OUT OF THE USE OF THIS SOFTWARE, EVEN IF ADVISED OF THE
- * POSSIBILITY OF SUCH DAMAGE.
- *
- * The views and conclusions contained in the software and
- * documentation are those of the authors and should not be
- * interpreted as representing official policies, either expressed
- * or implied, of GRNET S.A.
- */
-
-package gr.grnet.aquarium.logic.accounting.dsl
-
-import java.util.Date
-
-/**
- * A DSL time bounded item whose effectivity is constrained by well defined time bounds.
- * All time bounded items also support inheritance.
- *
- * @author Georgios Gousios <gousiosg@gmail.com>
- */
-abstract class DSLTimeBoundedItem[T <: DSLTimeBoundedItem[T]](val name: String,
-                                                              val overrides: Option[T],
-                                                              val effective: DSLTimeFrame) {
-
-  def toTimeslot : Timeslot = Timeslot(effective.from,effective.to.getOrElse(new Date(Long.MaxValue)))
-}
diff --git a/src/main/scala/gr/grnet/aquarium/logic/accounting/dsl/DSLTimeFrame.scala b/src/main/scala/gr/grnet/aquarium/logic/accounting/dsl/DSLTimeFrame.scala
deleted file mode 100644 (file)
index 31d7b89..0000000
+++ /dev/null
@@ -1,287 +0,0 @@
-/*
- * Copyright 2011-2012 GRNET S.A. All rights reserved.
- *
- * Redistribution and use in source and binary forms, with or
- * without modification, are permitted provided that the following
- * conditions are met:
- *
- *   1. Redistributions of source code must retain the above
- *      copyright notice, this list of conditions and the following
- *      disclaimer.
- *
- *   2. Redistributions in binary form must reproduce the above
- *      copyright notice, this list of conditions and the following
- *      disclaimer in the documentation and/or other materials
- *      provided with the distribution.
- *
- * THIS SOFTWARE IS PROVIDED BY GRNET S.A. ``AS IS'' AND ANY EXPRESS
- * OR IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED
- * WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A PARTICULAR
- * PURPOSE ARE DISCLAIMED. IN NO EVENT SHALL GRNET S.A OR
- * CONTRIBUTORS BE LIABLE FOR ANY DIRECT, INDIRECT, INCIDENTAL,
- * SPECIAL, EXEMPLARY, OR CONSEQUENTIAL DAMAGES (INCLUDING, BUT NOT
- * LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR SERVICES; LOSS OF
- * USE, DATA, OR PROFITS; OR BUSINESS INTERRUPTION) HOWEVER CAUSED
- * AND ON ANY THEORY OF LIABILITY, WHETHER IN CONTRACT, STRICT
- * LIABILITY, OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) ARISING IN
- * ANY WAY OUT OF THE USE OF THIS SOFTWARE, EVEN IF ADVISED OF THE
- * POSSIBILITY OF SUCH DAMAGE.
- *
- * The views and conclusions contained in the software and
- * documentation are those of the authors and should not be
- * interpreted as representing official policies, either expressed
- * or implied, of GRNET S.A.
- */
-
-package gr.grnet.aquarium.logic.accounting.dsl
-
-import gr.grnet.aquarium.util.shortNameOfClass
-
-import java.util.Date
-import gr.grnet.aquarium.util.date.MutableDateCalc
-import collection.mutable
-
-/**
- * Represents an effectivity timeframe.
- *
- * @author Georgios Gousios <gousiosg@gmail.com>
- */
-case class DSLTimeFrame (
-  from: Date,
-  to: Option[Date],
-  repeat: List[DSLTimeFrameRepeat] /*,
-  cronRepeat: List[DSLCronSpec]*/
-) {
-
-  to match {
-    case Some(x) =>
-      assert(x.after(from), "Time frame to (%s) must be after from (%s)"
-        .format(x.getTime, from.getTime))
-    case None =>
-  }
-
-  private val start = from.getTime
-  private val infinity = new Date(Long.MaxValue)
-  private val end = to.getOrElse(infinity).getTime
-
-  /*
-   *  Given the timeslot "t" and the timeslot of this frame (start,end)
-   *  compute the intersection of the two timeslots (return a list of common intervals)
-   *  which satisfy the cron expressions. If no expressions are present which just
-   *  take the intersection. If there exist cron specs (cron,start) we compute the
-   *  intersection between "t" and the fine-grained subtimeslots (of this time frame).
-   *
-   *  */
-  def intervalsOf(t:Timeslot) : List[Timeslot]=
-    if(repeat.isEmpty)
-      List(t) // .overlappingTimeslots(List(Timeslot(start,end)))
-    else {
-      val result = new mutable.ListBuffer[Timeslot]()
-      var offset = t.from
-      firstValidTimeslot(t.from) match {
-        case None => ()
-        case Some(t) =>
-          result += t
-          offset = t.to
-      }
-      val step = 1000L*60L // +1 minute step
-      var continue = true
-      while(continue)
-        minValidAfter(t,offset) match {
-          case None =>
-            continue = false
-          case Some(next_timeslot) =>
-            result += next_timeslot
-            offset =  next_timeslot.to
-        }
-      result.toList
-    }
-    /*nextValidAfter(t.from) match {
-      case None =>
-        val ret = addRest(t.from)
-        ret
-      case Some(d_next) =>
-        if(d_next.after(t.to)){
-          if(repeat.isEmpty)
-            List(t)
-          else
-            Nil
-        }
-        else {
-          val ret =  Timeslot(t.from,d_next) :: addRest(d_next)
-          ret
-        }
-    } */
-
-  /*
-   * Find the first smallest (smallest here means with the least "end" timestamp) timeslot
-   * from beginning "offset" and ending at "d_end".
-   *
-   * Return None if "offset" is not bounded in this time frame and is not bounded by
-   * a valid "start" / "end" cron spec.
-   *
-   * */
-   private def firstValidTimeslot(offset:Date) : Option[Timeslot] = {
-    def minimum (min:Option[Timeslot],d_start:Date,d_end:Date) : Option[Timeslot] = {
-      min match {
-        case None =>
-          Some(Timeslot(d_start,d_end))
-        case Some(Timeslot(_,d_min)) =>
-          if(d_min.getTime < d_start.getTime)
-            min
-          else
-            Some(Timeslot(d_start,d_end))
-      }
-    }
-    val to = this.to.getOrElse(infinity)
-    repeat.foldLeft (None:Option[Timeslot]) {
-      (min,r)  =>
-        r.getEnd.nextValidDate(from,to,offset) match {
-          case None =>
-            min
-          case Some(d_end) =>
-            r.getStart.nextValidDate(from,to,from) match {
-              case None => /* there is no valid starting date in the entire interval!*/
-                  min
-              case Some(_) =>  /**/
-                r.getStart.nextValidDate(from,to,offset) match {
-                  case None => /* so there is at least one starting date before offset
-                                  and there are no starting dates after. So we are inside
-                                  an interval*/
-                    if(from.getTime <= offset.getTime && offset.getTime <= to.getTime)
-                       minimum(min,offset,d_end)
-                    else
-                       min
-                  case Some(d_start) =>
-                     if(d_start.getTime > d_end.getTime) {
-                        /* there is another starting date which occurs after the ending date.
-                        *  So we are within the interval*/
-                       minimum(min,offset,d_end)
-                     } else { /* we are outside the interval*/
-                       min
-                     }
-                }
-            }
-     }
-   }
-  }
-
-
-  private def minValidAfter(t:Timeslot,offset:Date) : Option[Timeslot] =
-       repeat.foldLeft  (None:Option[Timeslot]) {
-        (min,r)  =>
-          r.getStart.nextValidDate(t.from,t.to,offset) match {
-            case None =>
-              min
-            case Some(d_start) =>
-              r.getEnd.nextValidDate(t.from,t.to,d_start) match {
-                case None =>
-                  min
-                case Some(d_end) =>
-                  min match {
-                    case None =>
-                      Some(Timeslot(d_start,d_end))
-                    case Some(Timeslot(d_min,_)) =>
-                      if(d_min.getTime < d_start.getTime)
-                        min
-                      else
-                        Some(Timeslot(d_start,d_end))
-                  }
-              }
-          }
-     }
-
-
-  override def toString =
-    //"%s(%s, %s,\n %s\n || cron: %s)".format(
-    "%s(%s, %s,%s)".format(
-    shortNameOfClass(classOf[DSLTimeFrame]),
-    new MutableDateCalc(from).toString,
-    to.map(t => new MutableDateCalc(t)),
-    repeat /*,
-    cronRepeat*/
-  )
-
-  /*def includes(d :Date) : Boolean = {
-    val now = d.getTime
-    start <= now && now <= end && (cronRepeat.isEmpty || (cronRepeat.exists {_ occurs d}))
-  } */
-
-  /*/*  Return the next VALID, MAXIMUM and CONTINUOUS date after "d" for this time frame.
-   *  The *returned time* is the end of the time frame if there exist no cron specs.
-   *  Otherwise, the returned time is maximum of the dates that
-   *  1. are continuous (no interruptions) from "d"
-   *  2. occur after "d"
-   *  3. belong in the time frame
-   *
-   *  The input parameter "d" must occur within the time frame. If there exist
-   *  cron specs "d" must belong in the time spec specified by cron.
-   */
-  def nextValidAfter1(d: Date) : Option[Date] = {
-    val now = d.getTime
-    if (now < start || now > end) None /* undefined valid is date not contained here*/
-    else if (cronRepeat.isEmpty) Some(to.getOrElse(infinity)) /* No specs! The next valid date is the end of time frame*/
-    else {
-      /* filter out cron specs that DO NOT contain d */
-      val includes_d = cronRepeat filter { _ includes d }
-    /* get the next CONTINUOUS valid date from "d" using the DSLCronSpec class */
-      val next_cont_d =  includes_d  map {_ nextContinuousValidDate d}
-      /* filter the resulting dates "d1" so that they occur after "d" and are within the timeframe bounds*/
-      val filter_invalid = next_cont_d filter {d1:Date =>  d1 != null &&
-                                                           d1.getTime > now &&
-                                                           start <= d1.getTime &&
-                                                           d1.getTime <= end}
-      /* sort the next dates and select the MAXIMUM one*/
-      val sorted = filter_invalid  sortWith {_.getTime > _.getTime}
-      sorted match {
-        case Nil => None /* Nothing interesting was found*/
-        case hd::_ => if(hd!=null) Some(hd) else None  /* the MAXIMAL next date */
-      }
-    }
-  }
-  var time_var : List[Long] = Nil
-  private def time[R](block: => R): R = {
-    val t0 = System.nanoTime()
-    val result = block    // call-by-name
-    val t1 = System.nanoTime()
-    time_var =  ((t1-t0)/1000000L) :: time_var
-    //Console.err.println("Time__xxxx: " + time_var)
-    result
-  } */
-  /*/* the nextValidDate cannot be outside the end limit of this time frame
-     Description: given date "d" get the nextValidDate after "d"
-   * */
-  def nextValidAfter(d:Date) : Option[Date] = {
-     def nextDate(r:DSLTimeFrameRepeat) : Option[Date] =
-       time(r.getStart.getMaxValidBeforeDate(from,to.getOrElse(infinity),d)) match {
-         case None =>
-           None
-         case Some(min) =>
-           r.getEnd.nextValidDate(from,to.getOrElse(infinity),min) match {
-             case None =>
-               None
-             case Some(d_max) =>
-               if(d_max.getTime < d.getTime)
-                 None
-               else
-                 Some(d_max)
-           }
-
-       }
-    if(repeat.isEmpty){
-      val d_time = d.getTime
-      if(d_time < start || d_time > end) None
-      else Some(to.getOrElse(infinity))
-    }
-    else {
-      var tmpDate : Option[Date] = null
-      repeat.collectFirst {
-        case r  if({tmpDate=nextDate(r);tmpDate} != None) => tmpDate.get
-      }
-    }
-  }*/
-}
-
-object DSLTimeFrame{
-  val emptyTimeFrame = DSLTimeFrame(new Date(0), None, List())//,List())
-}
\ No newline at end of file
diff --git a/src/main/scala/gr/grnet/aquarium/logic/accounting/dsl/DSLTimeFrameRepeat.scala b/src/main/scala/gr/grnet/aquarium/logic/accounting/dsl/DSLTimeFrameRepeat.scala
deleted file mode 100644 (file)
index c0f84ce..0000000
+++ /dev/null
@@ -1,88 +0,0 @@
-/*
- * Copyright 2011-2012 GRNET S.A. All rights reserved.
- *
- * Redistribution and use in source and binary forms, with or
- * without modification, are permitted provided that the following
- * conditions are met:
- *
- *   1. Redistributions of source code must retain the above
- *      copyright notice, this list of conditions and the following
- *      disclaimer.
- *
- *   2. Redistributions in binary form must reproduce the above
- *      copyright notice, this list of conditions and the following
- *      disclaimer in the documentation and/or other materials
- *      provided with the distribution.
- *
- * THIS SOFTWARE IS PROVIDED BY GRNET S.A. ``AS IS'' AND ANY EXPRESS
- * OR IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED
- * WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A PARTICULAR
- * PURPOSE ARE DISCLAIMED. IN NO EVENT SHALL GRNET S.A OR
- * CONTRIBUTORS BE LIABLE FOR ANY DIRECT, INDIRECT, INCIDENTAL,
- * SPECIAL, EXEMPLARY, OR CONSEQUENTIAL DAMAGES (INCLUDING, BUT NOT
- * LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR SERVICES; LOSS OF
- * USE, DATA, OR PROFITS; OR BUSINESS INTERRUPTION) HOWEVER CAUSED
- * AND ON ANY THEORY OF LIABILITY, WHETHER IN CONTRACT, STRICT
- * LIABILITY, OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) ARISING IN
- * ANY WAY OUT OF THE USE OF THIS SOFTWARE, EVEN IF ADVISED OF THE
- * POSSIBILITY OF SUCH DAMAGE.
- *
- * The views and conclusions contained in the software and
- * documentation are those of the authors and should not be
- * interpreted as representing official policies, either expressed
- * or implied, of GRNET S.A.
- */
-
-package gr.grnet.aquarium.logic.accounting.dsl
-
-import org.quartz.CronExpression
-import java.util.Date
-
-/**
- * Encapsulates a repeating item
- *
- * @author Georgios Gousios <gousiosg@gmail.com>
- */
-case class DSLTimeFrameRepeat (
-//  start: List[DSLTimeSpec],
-//  end: List[DSLTimeSpec],
-  startCron: String,
-  endCron: String
-) {
-
-//  private def makeCronExpression(s: String) : CronExpression  = {
-//    val e = "0 " + s.trim
-//    val l = e.split(" ")
-//    (l(3),l(5))  match {
-//      case ("?",_) | (_,"?") => ()
-//      case (_,"*") => l.update(5,"?")
-//      case ("*",_) => l.update(3,"?")
-//    }
-//    val e1 = l.foldLeft("") { (s,elt) => s + " " + elt}
-//    new CronExpression(e1)
-//  }
-  val getStart = DSLCronSpec(startCron)
-  val getEnd =  DSLCronSpec(endCron)
-
-//  assert(start.size == end.size,
-//    ("start (%s) and end (%s) cron-like specs do not expand to equal" +
-//      " number of repetition definitions").format(startCron, endCron))
-//
-//  //Ensures that fields that have repeating entries, do so in both patterns
-//  start.zip(end).foreach {
-//    x =>
-//      assert((x._1.dom == -1 && x._2.dom == -1) ||
-//        (x._1.dom != -1 && x._2.dom != -1))
-//
-//      assert((x._1.mon == -1 && x._2.mon == -1) ||
-//        (x._1.mon != -1 && x._2.mon != -1))
-//
-//      assert((x._1.dow == -1 && x._2.dow == -1) ||
-//        (x._1.dow != -1 && x._2.dow != -1))
-//  }
-
-}
-
-object DSLTimeFrameRepeat {
-  val emptyTimeFramRepeat = DSLTimeFrameRepeat(/*List(), List(), */"", "")
-}
\ No newline at end of file
diff --git a/src/main/scala/gr/grnet/aquarium/logic/accounting/dsl/DSLUtils.scala b/src/main/scala/gr/grnet/aquarium/logic/accounting/dsl/DSLUtils.scala
deleted file mode 100644 (file)
index 1251885..0000000
+++ /dev/null
@@ -1,53 +0,0 @@
-/*
- * Copyright 2011-2012 GRNET S.A. All rights reserved.
- *
- * Redistribution and use in source and binary forms, with or
- * without modification, are permitted provided that the following
- * conditions are met:
- *
- *   1. Redistributions of source code must retain the above
- *      copyright notice, this list of conditions and the following
- *      disclaimer.
- *
- *   2. Redistributions in binary form must reproduce the above
- *      copyright notice, this list of conditions and the following
- *      disclaimer in the documentation and/or other materials
- *      provided with the distribution.
- *
- * THIS SOFTWARE IS PROVIDED BY GRNET S.A. ``AS IS'' AND ANY EXPRESS
- * OR IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED
- * WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A PARTICULAR
- * PURPOSE ARE DISCLAIMED. IN NO EVENT SHALL GRNET S.A OR
- * CONTRIBUTORS BE LIABLE FOR ANY DIRECT, INDIRECT, INCIDENTAL,
- * SPECIAL, EXEMPLARY, OR CONSEQUENTIAL DAMAGES (INCLUDING, BUT NOT
- * LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR SERVICES; LOSS OF
- * USE, DATA, OR PROFITS; OR BUSINESS INTERRUPTION) HOWEVER CAUSED
- * AND ON ANY THEORY OF LIABILITY, WHETHER IN CONTRACT, STRICT
- * LIABILITY, OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) ARISING IN
- * ANY WAY OUT OF THE USE OF THIS SOFTWARE, EVEN IF ADVISED OF THE
- * POSSIBILITY OF SUCH DAMAGE.
- *
- * The views and conclusions contained in the software and
- * documentation are those of the authors and should not be
- * interpreted as representing official policies, either expressed
- * or implied, of GRNET S.A.
- */
-
-package gr.grnet.aquarium.logic.accounting.dsl
-
-import java.util.{Date}
-import scala.collection.immutable
-import gr.grnet.aquarium.policy.{EffectiveUnitPrice, AdHocFullPriceTableRef, PolicyDefinedFullPriceTableRef, PolicyModel, ResourceType, EffectivePriceTable, UserAgreementModel}
-import gr.grnet.aquarium.AquariumInternalError
-
-/**
- * Utility functions to use when working with DSL types.
- *
- * @author Georgios Gousios <gousiosg@gmail.com>
- */
-
-trait DSLUtils {
-
- //TODO pgerakios: REMOVE THIS FILE
-
-}
index 7bc0807..6de41bb 100644 (file)
@@ -35,7 +35,7 @@
 
 package gr.grnet.aquarium.policy
 
-import gr.grnet.aquarium.logic.accounting.dsl.{Timeslot, DSLCronSpec, DSLTimeFrame}
+import gr.grnet.aquarium.logic.accounting.dsl.Timeslot
 import collection.mutable
 
 /**