You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@iota.apache.org by to...@apache.org on 2016/10/19 18:44:00 UTC

[1/8] incubator-iota git commit: Added the play-netty dependencies

Repository: incubator-iota
Updated Branches:
  refs/heads/master 76cf4616f -> e08e775e5


Added the play-netty dependencies


Project: http://git-wip-us.apache.org/repos/asf/incubator-iota/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-iota/commit/d2f10b70
Tree: http://git-wip-us.apache.org/repos/asf/incubator-iota/tree/d2f10b70
Diff: http://git-wip-us.apache.org/repos/asf/incubator-iota/diff/d2f10b70

Branch: refs/heads/master
Commit: d2f10b70612de0ceeaec18f341fe485b399b9fe9
Parents: 9b61962
Author: Shivansh <sh...@gmail.com>
Authored: Wed Sep 28 09:34:56 2016 +0530
Committer: Shivansh <sh...@gmail.com>
Committed: Wed Sep 28 09:34:56 2016 +0530

----------------------------------------------------------------------
 project/Dependencies.scala | 1 +
 1 file changed, 1 insertion(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-iota/blob/d2f10b70/project/Dependencies.scala
----------------------------------------------------------------------
diff --git a/project/Dependencies.scala b/project/Dependencies.scala
index 49c9e3d..63cdce1 100644
--- a/project/Dependencies.scala
+++ b/project/Dependencies.scala
@@ -33,6 +33,7 @@ object Dependencies {
   val typesafe_config = "com.typesafe"        %  "config"                     % "1.3.0"
 
   val playJson        = "com.typesafe.play"   %% "play-json"                  % "2.5.3"
+  val playNetty = "com.typesafe.play" %% "play-netty-server" % "2.5.3"
   val jsonValidator   = "com.eclipsesource"   %% "play-json-schema-validator" % "0.7.0"
 
   //Logger


[6/8] incubator-iota git commit: Fix the type of the content shown on the monitoring event routes

Posted by to...@apache.org.
Fix the type of the content shown on the monitoring event routes


Project: http://git-wip-us.apache.org/repos/asf/incubator-iota/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-iota/commit/17c643c7
Tree: http://git-wip-us.apache.org/repos/asf/incubator-iota/tree/17c643c7
Diff: http://git-wip-us.apache.org/repos/asf/incubator-iota/diff/17c643c7

Branch: refs/heads/master
Commit: 17c643c7591fe8ab05cd1b5c42a2635ccb1fae2d
Parents: 1bc453c
Author: Shivansh <sh...@gmail.com>
Authored: Thu Sep 29 10:12:01 2016 +0530
Committer: Shivansh <sh...@gmail.com>
Committed: Thu Sep 29 10:12:01 2016 +0530

----------------------------------------------------------------------
 fey-core/src/main/scala/org/apache/iota/fey/FeyUIService.scala | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-iota/blob/17c643c7/fey-core/src/main/scala/org/apache/iota/fey/FeyUIService.scala
----------------------------------------------------------------------
diff --git a/fey-core/src/main/scala/org/apache/iota/fey/FeyUIService.scala b/fey-core/src/main/scala/org/apache/iota/fey/FeyUIService.scala
index f08790a..6fa7a3c 100644
--- a/fey-core/src/main/scala/org/apache/iota/fey/FeyUIService.scala
+++ b/fey-core/src/main/scala/org/apache/iota/fey/FeyUIService.scala
@@ -61,7 +61,7 @@ class FeyUIService(urlPath: String, port: Int) extends NettyServerComponents wit
       } catch {
         case e: Exception => ""
       }
-      Results.Ok(returnValue).as("application/json")
+      Results.Ok(returnValue).as("text/html")
     }
   }
 


[8/8] incubator-iota git commit: Merge branch 'IOTA-23' of https://github.com/shiv4nsh/incubator-iota

Posted by to...@apache.org.
Merge branch 'IOTA-23' of https://github.com/shiv4nsh/incubator-iota


Project: http://git-wip-us.apache.org/repos/asf/incubator-iota/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-iota/commit/e08e775e
Tree: http://git-wip-us.apache.org/repos/asf/incubator-iota/tree/e08e775e
Diff: http://git-wip-us.apache.org/repos/asf/incubator-iota/diff/e08e775e

Branch: refs/heads/master
Commit: e08e775e59a7735fc83347a8208a3c3d7e600fe2
Parents: 76cf461 b746c38
Author: tonyfaustini <to...@yahoo.com>
Authored: Wed Oct 19 11:42:55 2016 -0700
Committer: tonyfaustini <to...@yahoo.com>
Committed: Wed Oct 19 11:42:55 2016 -0700

----------------------------------------------------------------------
 fey-core/src/main/resources/application.conf    | 10 ++-
 .../scala/org/apache/iota/fey/Application.scala | 13 +--
 .../org/apache/iota/fey/FeyUIService.scala      | 78 +++++++++++++++++
 .../scala/org/apache/iota/fey/MyService.scala   | 88 --------------------
 .../main/scala/org/apache/iota/fey/Utils.scala  |  7 +-
 project/Build.scala                             |  2 +-
 project/Dependencies.scala                      |  1 +
 7 files changed, 94 insertions(+), 105 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-iota/blob/e08e775e/fey-core/src/main/scala/org/apache/iota/fey/Utils.scala
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-iota/blob/e08e775e/project/Build.scala
----------------------------------------------------------------------


[3/8] incubator-iota git commit: converted the spray framework routes to the play routes

Posted by to...@apache.org.
converted the spray framework routes to the play routes


Project: http://git-wip-us.apache.org/repos/asf/incubator-iota/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-iota/commit/fe606d70
Tree: http://git-wip-us.apache.org/repos/asf/incubator-iota/tree/fe606d70
Diff: http://git-wip-us.apache.org/repos/asf/incubator-iota/diff/fe606d70

Branch: refs/heads/master
Commit: fe606d70daf76f3de761223b3d44dcb9ab11f172
Parents: ba8eb4d
Author: Shivansh <sh...@gmail.com>
Authored: Wed Sep 28 12:08:20 2016 +0530
Committer: Shivansh <sh...@gmail.com>
Committed: Wed Sep 28 12:08:20 2016 +0530

----------------------------------------------------------------------
 .../org/apache/iota/fey/FeyUIService.scala      | 79 ++++++++++++++++++
 .../scala/org/apache/iota/fey/MyService.scala   | 88 --------------------
 2 files changed, 79 insertions(+), 88 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-iota/blob/fe606d70/fey-core/src/main/scala/org/apache/iota/fey/FeyUIService.scala
----------------------------------------------------------------------
diff --git a/fey-core/src/main/scala/org/apache/iota/fey/FeyUIService.scala b/fey-core/src/main/scala/org/apache/iota/fey/FeyUIService.scala
new file mode 100644
index 0000000..f08790a
--- /dev/null
+++ b/fey-core/src/main/scala/org/apache/iota/fey/FeyUIService.scala
@@ -0,0 +1,79 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *    http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+package org.apache.iota.fey
+
+import com.typesafe.config.ConfigFactory
+import org.apache.iota.fey.FeyCore.JSON_TREE
+import play.api.BuiltInComponents
+import play.api.http.DefaultHttpErrorHandler
+import play.api.libs.json.Json
+import play.api.mvc._
+import play.api.routing.Router
+import play.api.routing.sird._
+import play.core.server._
+
+import scala.concurrent.Future
+
+object FeyUIService {
+  val config = ConfigFactory.load()
+  val port = config.getInt("port")
+  val urlPath = config.getString("urlPath")
+  val components = new FeyUIService(urlPath, port)
+  val server = components.server
+}
+
+class FeyUIService(urlPath: String, port: Int) extends NettyServerComponents with BuiltInComponents {
+
+  lazy val router = Router.from {
+    case GET(p"/fey/activeactors") => Action {
+      FEY_CORE_ACTOR.actorRef ! JSON_TREE
+      Thread.sleep(2000)
+      val json = IdentifyFeyActors.generateTreeJson()
+      val jsonTree: String = IdentifyFeyActors.getHTMLTree(json)
+      Results.Ok(jsonTree).as("text/html")
+    }
+    case GET(p"/fey/actorslifecycle") => Action {
+      val jsonTree = Json.stringify(Monitor.events.printWithEvents)
+      Results.Ok(jsonTree).as("application/json")
+    }
+    case GET(p"/fey/monitoringevents") => Action {
+      val returnValue: String = try {
+        if (CONFIG.MONITORING_TYPE == "COMPLETE") {
+          Monitor.getHTMLevents
+        } else {
+          Monitor.getSimpleHTMLEvents
+        }
+      } catch {
+        case e: Exception => ""
+      }
+      Results.Ok(returnValue).as("application/json")
+    }
+  }
+
+  override lazy val serverConfig = ServerConfig(
+    port = Some(port),
+    address = urlPath
+  )
+  override lazy val httpErrorHandler = new DefaultHttpErrorHandler(environment,
+    configuration, sourceMapper, Some(router)) {
+
+    override protected def onNotFound(request: RequestHeader, message: String) = {
+      Future.successful(Results.NotFound("NO_DATA_FOUND"))
+    }
+  }
+}

http://git-wip-us.apache.org/repos/asf/incubator-iota/blob/fe606d70/fey-core/src/main/scala/org/apache/iota/fey/MyService.scala
----------------------------------------------------------------------
diff --git a/fey-core/src/main/scala/org/apache/iota/fey/MyService.scala b/fey-core/src/main/scala/org/apache/iota/fey/MyService.scala
deleted file mode 100644
index f686321..0000000
--- a/fey-core/src/main/scala/org/apache/iota/fey/MyService.scala
+++ /dev/null
@@ -1,88 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *    http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-package org.apache.iota.fey
-
-import akka.actor.Actor
-import org.apache.iota.fey.FeyCore.JSON_TREE
-import play.api.libs.json.Json
-import spray.http.MediaTypes._
-import spray.routing._
-
-class MyServiceActor extends Actor with MyService {
-
-  // the HttpService trait defines only one abstract member, which
-  // connects the services environment to the enclosing actor or test
-  def actorRefFactory = context
-
-  // this actor only runs our route, but you could add
-  // other things here, like request stream processing
-  // or timeout handling
-  def receive = runRoute(myRoute)
-}
-
-sealed trait MyService extends HttpService {
-
-  val home = pathPrefix("fey")
-  val activeActors = path("activeactors")
-  val actorLifecycle = path("actorslifecycle")
-  val eventsTable = path("monitoringevents")
-  val test = path("test")
-
-  val myRoute =
-    home {
-      activeActors {
-        get{
-          respondWithMediaType(`text/html`) {
-            complete {
-              FEY_CORE_ACTOR.actorRef ! JSON_TREE
-              Thread.sleep(2000)
-              val json = IdentifyFeyActors.generateTreeJson()
-              IdentifyFeyActors.getHTMLTree(json)
-            }
-          }
-        }
-      } ~
-      actorLifecycle {
-        get{
-          respondWithMediaType(`application/json`) {
-            complete {
-              Json.stringify(Monitor.events.printWithEvents)
-            }
-          }
-        }
-      } ~
-        eventsTable {
-        get{
-          respondWithMediaType(`text/html`) {
-            complete {
-              try {
-                if(CONFIG.MONITORING_TYPE == "COMPLETE") {
-                  Monitor.getHTMLevents
-                }else{
-                  Monitor.getSimpleHTMLEvents
-                }
-              }catch {
-                case e: Exception => ""
-              }
-            }
-          }
-        }
-      }
-    }
-
-}
\ No newline at end of file


[7/8] incubator-iota git commit: Refactored the code and moved the config to the util.scala

Posted by to...@apache.org.
Refactored the code and moved the config to the util.scala


Project: http://git-wip-us.apache.org/repos/asf/incubator-iota/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-iota/commit/b746c388
Tree: http://git-wip-us.apache.org/repos/asf/incubator-iota/tree/b746c388
Diff: http://git-wip-us.apache.org/repos/asf/incubator-iota/diff/b746c388

Branch: refs/heads/master
Commit: b746c38803dc5c5d830dc67462018981e60e8bf9
Parents: 17c643c
Author: Shivansh <sh...@gmail.com>
Authored: Wed Oct 12 07:55:05 2016 +0530
Committer: Shivansh <sh...@gmail.com>
Committed: Wed Oct 12 07:55:05 2016 +0530

----------------------------------------------------------------------
 fey-core/src/main/resources/application.conf                | 6 +++---
 .../src/main/scala/org/apache/iota/fey/Application.scala    | 8 --------
 .../src/main/scala/org/apache/iota/fey/FeyUIService.scala   | 9 ++++-----
 fey-core/src/main/scala/org/apache/iota/fey/Utils.scala     | 7 +++++--
 4 files changed, 12 insertions(+), 18 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-iota/blob/b746c388/fey-core/src/main/resources/application.conf
----------------------------------------------------------------------
diff --git a/fey-core/src/main/resources/application.conf b/fey-core/src/main/resources/application.conf
index 9f5bce3..e732880 100644
--- a/fey-core/src/main/resources/application.conf
+++ b/fey-core/src/main/resources/application.conf
@@ -93,7 +93,8 @@ fey-global-configuration{
     enable = true,
     type = "COMPLETE"
   }
-
+  port = 16666
+  urlPath = "127.0.0.1"
 }
 
 // Fey akka configuration. Can not be overwritten by user
@@ -110,7 +111,6 @@ akka {
 }
 
 //Configuration for rest Api .
-port = 16666
-urlPath = "127.0.0.1"
+
 play.crypto.secret = "apacheiota"
 play.crypto.secret = ${?APPLICATION_SECRET}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-iota/blob/b746c388/fey-core/src/main/scala/org/apache/iota/fey/Application.scala
----------------------------------------------------------------------
diff --git a/fey-core/src/main/scala/org/apache/iota/fey/Application.scala b/fey-core/src/main/scala/org/apache/iota/fey/Application.scala
index 11c8cd2..34bbc29 100644
--- a/fey-core/src/main/scala/org/apache/iota/fey/Application.scala
+++ b/fey-core/src/main/scala/org/apache/iota/fey/Application.scala
@@ -18,13 +18,7 @@
 package org.apache.iota.fey
 
 import akka.actor.{ActorSystem, Props}
-import akka.io.IO
-import akka.pattern.ask
-import akka.util.Timeout
 import com.typesafe.config.ConfigFactory
-import spray.can.Http
-
-import scala.concurrent.duration._
 
 object Application extends App {
 
@@ -40,8 +34,6 @@ object FEY_SYSTEM{
 
 object SYSTEM_ACTORS{
 
-  import FEY_SYSTEM._
-
   FEY_CORE_ACTOR
 
   FEY_CORE_ACTOR.actorRef ! FeyCore.START

http://git-wip-us.apache.org/repos/asf/incubator-iota/blob/b746c388/fey-core/src/main/scala/org/apache/iota/fey/FeyUIService.scala
----------------------------------------------------------------------
diff --git a/fey-core/src/main/scala/org/apache/iota/fey/FeyUIService.scala b/fey-core/src/main/scala/org/apache/iota/fey/FeyUIService.scala
index 6fa7a3c..cb48192 100644
--- a/fey-core/src/main/scala/org/apache/iota/fey/FeyUIService.scala
+++ b/fey-core/src/main/scala/org/apache/iota/fey/FeyUIService.scala
@@ -17,7 +17,6 @@
 
 package org.apache.iota.fey
 
-import com.typesafe.config.ConfigFactory
 import org.apache.iota.fey.FeyCore.JSON_TREE
 import play.api.BuiltInComponents
 import play.api.http.DefaultHttpErrorHandler
@@ -26,14 +25,14 @@ import play.api.mvc._
 import play.api.routing.Router
 import play.api.routing.sird._
 import play.core.server._
+import CONFIG._
 
 import scala.concurrent.Future
 
 object FeyUIService {
-  val config = ConfigFactory.load()
-  val port = config.getInt("port")
-  val urlPath = config.getString("urlPath")
-  val components = new FeyUIService(urlPath, port)
+
+
+  val components = new FeyUIService(URL_PATH, PORT)
   val server = components.server
 }
 

http://git-wip-us.apache.org/repos/asf/incubator-iota/blob/b746c388/fey-core/src/main/scala/org/apache/iota/fey/Utils.scala
----------------------------------------------------------------------
diff --git a/fey-core/src/main/scala/org/apache/iota/fey/Utils.scala b/fey-core/src/main/scala/org/apache/iota/fey/Utils.scala
index d4f3210..8ac18cf 100644
--- a/fey-core/src/main/scala/org/apache/iota/fey/Utils.scala
+++ b/fey-core/src/main/scala/org/apache/iota/fey/Utils.scala
@@ -220,12 +220,13 @@ object CONFIG{
   var CUSTOM_DISPATCHERS: ConfigValue = null
   var MONITORING_ENABLED: Boolean = true
   var MONITORING_TYPE: String = "COMPLETE"
+  var PORT = 8080
+  var URL_PATH = "localhost"
 
   def loadUserConfiguration(path: String) : Unit = {
-
     val app = {
       if(path != "" && Files.exists(Paths.get(path))) {
-          ConfigFactory.parseFile(new File(path)).withFallback(ConfigFactory.load())
+        ConfigFactory.parseFile(new File(path)).withFallback(ConfigFactory.load())
       }else {
           log.info("Using Fey Default Configuration")
           log.warn(s"No user configuration defined. Check if your configuration path $path is right.")
@@ -246,6 +247,8 @@ object CONFIG{
     CUSTOM_DISPATCHERS = app.getValue("custom-dispatchers")
     MONITORING_ENABLED = app.getBoolean("monitoring.enable")
     MONITORING_TYPE = app.getString("monitoring.type").toUpperCase()
+    PORT = app.getInt("port")
+    URL_PATH = app.getString("urlPath")
 
     setLogbackConfiguration()
   }


[5/8] incubator-iota git commit: Refactored the code for the calling of FeyUIService

Posted by to...@apache.org.
Refactored the code for the calling of FeyUIService


Project: http://git-wip-us.apache.org/repos/asf/incubator-iota/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-iota/commit/1bc453c4
Tree: http://git-wip-us.apache.org/repos/asf/incubator-iota/tree/1bc453c4
Diff: http://git-wip-us.apache.org/repos/asf/incubator-iota/diff/1bc453c4

Branch: refs/heads/master
Commit: 1bc453c44aea315d72c38c5ffc70f73301e5b59b
Parents: c9bf447
Author: Shivansh <sh...@gmail.com>
Authored: Wed Sep 28 12:09:34 2016 +0530
Committer: Shivansh <sh...@gmail.com>
Committed: Wed Sep 28 12:09:34 2016 +0530

----------------------------------------------------------------------
 fey-core/src/main/scala/org/apache/iota/fey/Application.scala | 5 +----
 1 file changed, 1 insertion(+), 4 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-iota/blob/1bc453c4/fey-core/src/main/scala/org/apache/iota/fey/Application.scala
----------------------------------------------------------------------
diff --git a/fey-core/src/main/scala/org/apache/iota/fey/Application.scala b/fey-core/src/main/scala/org/apache/iota/fey/Application.scala
index d62c418..11c8cd2 100644
--- a/fey-core/src/main/scala/org/apache/iota/fey/Application.scala
+++ b/fey-core/src/main/scala/org/apache/iota/fey/Application.scala
@@ -46,10 +46,7 @@ object SYSTEM_ACTORS{
 
   FEY_CORE_ACTOR.actorRef ! FeyCore.START
 
-  val service = system.actorOf(Props[MyServiceActor], name = "FEY_REST_API")
-
-  implicit val timeout = Timeout(800.seconds)
-  IO(Http) ? Http.Bind(SYSTEM_ACTORS.service, interface = "0.0.0.0", port = 16666)
+  FeyUIService
 
 }
 


[2/8] incubator-iota git commit: Added the play dependency to the fey core

Posted by to...@apache.org.
Added the play dependency to the fey core


Project: http://git-wip-us.apache.org/repos/asf/incubator-iota/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-iota/commit/ba8eb4d2
Tree: http://git-wip-us.apache.org/repos/asf/incubator-iota/tree/ba8eb4d2
Diff: http://git-wip-us.apache.org/repos/asf/incubator-iota/diff/ba8eb4d2

Branch: refs/heads/master
Commit: ba8eb4d2c12257bdaceaa2d3b3251d50c690398f
Parents: d2f10b7
Author: Shivansh <sh...@gmail.com>
Authored: Wed Sep 28 09:35:30 2016 +0530
Committer: Shivansh <sh...@gmail.com>
Committed: Wed Sep 28 09:35:30 2016 +0530

----------------------------------------------------------------------
 project/Build.scala | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-iota/blob/ba8eb4d2/project/Build.scala
----------------------------------------------------------------------
diff --git a/project/Build.scala b/project/Build.scala
index 8bff270..4444c59 100644
--- a/project/Build.scala
+++ b/project/Build.scala
@@ -22,7 +22,7 @@ object ModuleDependencies {
 
   import Dependencies._
   val FeyDependencies           = compile(akka_actor,typesafe_config,playJson,slf4j,log4jbind,sprayCan,
-                                            sprayRouting,jsonValidator,javaFilter,codec,apacheIO) ++ test(akka_testkit, scala_test)
+                                            sprayRouting,jsonValidator,javaFilter,codec,apacheIO,playNetty) ++ test(akka_testkit, scala_test)
   val StreamDependencies        = provided(akka_actor, fey)
   val ZMQDependencies           = provided(akka_actor,  fey) ++ compile(zmq)
   val VirtualSensorDependencies = provided(akka_actor,  fey) ++ compile(math3)


[4/8] incubator-iota git commit: Added the configuration settings for the port and the URL

Posted by to...@apache.org.
Added the configuration settings for the port and the URL


Project: http://git-wip-us.apache.org/repos/asf/incubator-iota/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-iota/commit/c9bf4474
Tree: http://git-wip-us.apache.org/repos/asf/incubator-iota/tree/c9bf4474
Diff: http://git-wip-us.apache.org/repos/asf/incubator-iota/diff/c9bf4474

Branch: refs/heads/master
Commit: c9bf4474c608e1b2d091e018027bd865ab444abd
Parents: fe606d7
Author: Shivansh <sh...@gmail.com>
Authored: Wed Sep 28 12:08:58 2016 +0530
Committer: Shivansh <sh...@gmail.com>
Committed: Wed Sep 28 12:08:58 2016 +0530

----------------------------------------------------------------------
 fey-core/src/main/resources/application.conf | 8 +++++++-
 1 file changed, 7 insertions(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-iota/blob/c9bf4474/fey-core/src/main/resources/application.conf
----------------------------------------------------------------------
diff --git a/fey-core/src/main/resources/application.conf b/fey-core/src/main/resources/application.conf
index a80f13e..9f5bce3 100644
--- a/fey-core/src/main/resources/application.conf
+++ b/fey-core/src/main/resources/application.conf
@@ -107,4 +107,10 @@ akka {
       mailbox-type = "akka.dispatch.UnboundedControlAwareMailbox"
     }
   }
-}
\ No newline at end of file
+}
+
+//Configuration for rest Api .
+port = 16666
+urlPath = "127.0.0.1"
+play.crypto.secret = "apacheiota"
+play.crypto.secret = ${?APPLICATION_SECRET}
\ No newline at end of file