You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@aurora.apache.org by wf...@apache.org on 2014/05/21 23:32:08 UTC

git commit: Use rsync instead of git to copy code into vagrant, simplify end-to-end tests.

Repository: incubator-aurora
Updated Branches:
  refs/heads/master 2fb6b7dc8 -> 0df27d7ae


Use rsync instead of git to copy code into vagrant, simplify end-to-end tests.

Bugs closed: AURORA-452

Reviewed at https://reviews.apache.org/r/21740/


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

Branch: refs/heads/master
Commit: 0df27d7ae34b90adc3328d21f20fa5676bf395e8
Parents: 2fb6b7d
Author: Bill Farner <wf...@apache.org>
Authored: Wed May 21 14:08:18 2014 -0700
Committer: Bill Farner <wf...@apache.org>
Committed: Wed May 21 14:08:18 2014 -0700

----------------------------------------------------------------------
 examples/vagrant/provision-dev-cluster.sh       | 15 +++--
 src/test/sh/org/apache/aurora/e2e/flask/BUILD   | 22 -------
 .../aurora/e2e/flask/flask_example.aurora       | 36 -----------
 .../apache/aurora/e2e/flask/flask_example.py    | 28 ---------
 .../e2e/flask/flask_example_updated.aurora      | 36 -----------
 .../apache/aurora/e2e/http/http_example.aurora  | 32 ++++++++++
 .../aurora/e2e/http/http_example_updated.aurora | 32 ++++++++++
 .../sh/org/apache/aurora/e2e/http_example.py    | 30 ++++++++++
 .../sh/org/apache/aurora/e2e/test_common.sh     | 12 +---
 .../sh/org/apache/aurora/e2e/test_end_to_end.sh | 59 +++++-------------
 .../org/apache/aurora/e2e/test_end_to_end_v2.sh | 63 +++++---------------
 11 files changed, 134 insertions(+), 231 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-aurora/blob/0df27d7a/examples/vagrant/provision-dev-cluster.sh
----------------------------------------------------------------------
diff --git a/examples/vagrant/provision-dev-cluster.sh b/examples/vagrant/provision-dev-cluster.sh
index 97bb877..e9066e9 100755
--- a/examples/vagrant/provision-dev-cluster.sh
+++ b/examples/vagrant/provision-dev-cluster.sh
@@ -33,10 +33,14 @@ update-alternatives --set java /usr/lib/jvm/java-7-openjdk-amd64/jre/bin/java
 hostname 192.168.33.7
 
 function build_all() {
-  if [ ! -d aurora ]; then
-    echo Cloning aurora repo
-    git clone /vagrant aurora
-  fi
+  echo Copying aurora source code
+  rsync -urzvh /vagrant/ aurora \
+      --exclude '.gradle' \
+      --exclude '.pants.d' \
+      --exclude 'dist/*' \
+      --exclude 'build-support/*.venv' \
+      --exclude 'build-support/thrift/thrift-*' \
+      --exclude '*.pyc'
 
   pushd aurora
     # fetch the mesos egg, needed to build python components
@@ -45,7 +49,6 @@ function build_all() {
       wget -c http://downloads.mesosphere.io/master/ubuntu/12.04/mesos_0.18.0_amd64.egg \
         -O mesos-0.18.0-py2.7-linux-x86_64.egg
     popd
-    git pull
 
     # install thrift, needed for code generation in the scheduler build
     # TODO(wfarner): Move deb file out of jfarrell's individual hosting.
@@ -59,6 +62,7 @@ function build_all() {
     # build clients
     ./pants src/main/python/apache/aurora/client/bin:aurora_admin
     ./pants src/main/python/apache/aurora/client/bin:aurora_client
+    ./pants src/main/python/apache/aurora/client/cli:aurora2
 
     # build executors/observers
     ./pants src/main/python/apache/aurora/executor/bin:gc_executor
@@ -101,6 +105,7 @@ function install_aurora {
 
   # Ensure clients are in the default PATH.
   ln -s $DIST_DIR/aurora_client.pex /usr/local/bin/aurora
+  ln -s $DIST_DIR/aurora2.pex /usr/local/bin/aurora2
   ln -s $DIST_DIR/aurora_admin.pex /usr/local/bin/aurora_admin
 
   mkdir -p /etc/aurora

http://git-wip-us.apache.org/repos/asf/incubator-aurora/blob/0df27d7a/src/test/sh/org/apache/aurora/e2e/flask/BUILD
----------------------------------------------------------------------
diff --git a/src/test/sh/org/apache/aurora/e2e/flask/BUILD b/src/test/sh/org/apache/aurora/e2e/flask/BUILD
deleted file mode 100644
index eaadcfc..0000000
--- a/src/test/sh/org/apache/aurora/e2e/flask/BUILD
+++ /dev/null
@@ -1,22 +0,0 @@
-#
-# Copyright 2014 Apache Software Foundation
-#
-# Licensed 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.
-#
-python_binary(
-  name = 'flask_example',
-  source = 'flask_example.py',
-  dependencies = [
-    pants('3rdparty/python:Flask')
-  ]
-)

http://git-wip-us.apache.org/repos/asf/incubator-aurora/blob/0df27d7a/src/test/sh/org/apache/aurora/e2e/flask/flask_example.aurora
----------------------------------------------------------------------
diff --git a/src/test/sh/org/apache/aurora/e2e/flask/flask_example.aurora b/src/test/sh/org/apache/aurora/e2e/flask/flask_example.aurora
deleted file mode 100644
index ad5aafe..0000000
--- a/src/test/sh/org/apache/aurora/e2e/flask/flask_example.aurora
+++ /dev/null
@@ -1,36 +0,0 @@
-import getpass
-
-run_server = Process(
-  name = 'run_server',
-  cmdline = '''
-    chmod +x ./flask_example.pex &&
-      ./flask_example.pex {{thermos.ports[http]}}
-  ''')
-
-stage_server = Process(
-  name = 'stage_server',
-  cmdline = "cp /vagrant/deploy_test/flask_example.pex ."
-)
-
-test_task = Task(
-  name = 'flask_example',
-  resources = Resources(cpu=1.0, ram=64*MB, disk=64*MB),
-  processes = [stage_server, run_server],
-  constraints = order(stage_server, run_server))
-
-job = Job(
-  name = 'flask_example',
-  cluster = 'devcluster',
-  instances = 2,
-  task = test_task,
-  role = getpass.getuser(),
-  environment = 'test',
-  contact = '{{role}}@localhost',
-  # Since there is only one slave in devcluster allow both instances to run there.
-  constraints = {
-    'host': 'limit:2',
-  },
-)
-
-jobs = [ job ]
-

http://git-wip-us.apache.org/repos/asf/incubator-aurora/blob/0df27d7a/src/test/sh/org/apache/aurora/e2e/flask/flask_example.py
----------------------------------------------------------------------
diff --git a/src/test/sh/org/apache/aurora/e2e/flask/flask_example.py b/src/test/sh/org/apache/aurora/e2e/flask/flask_example.py
deleted file mode 100644
index 0a01c00..0000000
--- a/src/test/sh/org/apache/aurora/e2e/flask/flask_example.py
+++ /dev/null
@@ -1,28 +0,0 @@
-#
-# Copyright 2014 Apache Software Foundation
-#
-# Licensed 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.
-#
-from sys import argv
-
-from flask import Flask
-
-app = Flask(__name__)
-
-@app.route("/")
-def hello():
-  return "Hello Twitter"
-
-app.run(
-  host="0.0.0.0",
-  port=int(argv[1]))

http://git-wip-us.apache.org/repos/asf/incubator-aurora/blob/0df27d7a/src/test/sh/org/apache/aurora/e2e/flask/flask_example_updated.aurora
----------------------------------------------------------------------
diff --git a/src/test/sh/org/apache/aurora/e2e/flask/flask_example_updated.aurora b/src/test/sh/org/apache/aurora/e2e/flask/flask_example_updated.aurora
deleted file mode 100644
index 6d54463..0000000
--- a/src/test/sh/org/apache/aurora/e2e/flask/flask_example_updated.aurora
+++ /dev/null
@@ -1,36 +0,0 @@
-import getpass
-
-run_server = Process(
-  name = 'run_server',
-  cmdline = '''
-    chmod +x ./flask_example.pex &&
-      ./flask_example.pex {{thermos.ports[http]}}
-  ''')
-
-stage_server = Process(
-  name = 'stage_server',
-  cmdline = "cp /vagrant/deploy_test/flask_example.pex ."
-)
-
-test_task = Task(
-  name = 'flask_example',
-  resources = Resources(cpu=1.0, ram=64*MB, disk=96*MB),
-  processes = [stage_server, run_server],
-  constraints = order(stage_server, run_server))
-
-job = Job(
-  name = 'flask_example',
-  cluster = 'devcluster',
-  instances = 2,
-  task = test_task,
-  role = getpass.getuser(),
-  environment = 'test',
-  contact = '{{role}}@localhost',
-  # Since there is only one slave in devcluster allow both instances to run there.
-  constraints = {
-    'host': 'limit:2',
-  },
-)
-
-jobs = [ job ]
-

http://git-wip-us.apache.org/repos/asf/incubator-aurora/blob/0df27d7a/src/test/sh/org/apache/aurora/e2e/http/http_example.aurora
----------------------------------------------------------------------
diff --git a/src/test/sh/org/apache/aurora/e2e/http/http_example.aurora b/src/test/sh/org/apache/aurora/e2e/http/http_example.aurora
new file mode 100644
index 0000000..8087127
--- /dev/null
+++ b/src/test/sh/org/apache/aurora/e2e/http/http_example.aurora
@@ -0,0 +1,32 @@
+import getpass
+
+run_server = Process(
+  name = 'run_server',
+  cmdline = 'python http_example.py {{thermos.ports[http]}}')
+
+stage_server = Process(
+  name = 'stage_server',
+  cmdline = "cp /vagrant/src/test/sh/org/apache/aurora/e2e/http_example.py ."
+)
+
+test_task = Task(
+  name = 'http_example',
+  resources = Resources(cpu=1.0, ram=64*MB, disk=64*MB),
+  processes = [stage_server, run_server],
+  constraints = order(stage_server, run_server))
+
+job = Job(
+  name = 'http_example',
+  cluster = 'devcluster',
+  instances = 2,
+  task = test_task,
+  role = getpass.getuser(),
+  environment = 'test',
+  contact = '{{role}}@localhost',
+  # Since there is only one slave in devcluster allow both instances to run there.
+  constraints = {
+    'host': 'limit:2',
+  },
+)
+
+jobs = [ job ]

http://git-wip-us.apache.org/repos/asf/incubator-aurora/blob/0df27d7a/src/test/sh/org/apache/aurora/e2e/http/http_example_updated.aurora
----------------------------------------------------------------------
diff --git a/src/test/sh/org/apache/aurora/e2e/http/http_example_updated.aurora b/src/test/sh/org/apache/aurora/e2e/http/http_example_updated.aurora
new file mode 100644
index 0000000..fc723cf
--- /dev/null
+++ b/src/test/sh/org/apache/aurora/e2e/http/http_example_updated.aurora
@@ -0,0 +1,32 @@
+import getpass
+
+run_server = Process(
+  name = 'run_server',
+  cmdline = 'python http_example.py {{thermos.ports[http]}}')
+
+stage_server = Process(
+  name = 'stage_server',
+  cmdline = "cp /vagrant/src/test/sh/org/apache/aurora/e2e/http_example.py ."
+)
+
+test_task = Task(
+  name = 'http_example',
+  resources = Resources(cpu=1.0, ram=64*MB, disk=96*MB),
+  processes = [stage_server, run_server],
+  constraints = order(stage_server, run_server))
+
+job = Job(
+  name = 'http_example',
+  cluster = 'devcluster',
+  instances = 2,
+  task = test_task,
+  role = getpass.getuser(),
+  environment = 'test',
+  contact = '{{role}}@localhost',
+  # Since there is only one slave in devcluster allow both instances to run there.
+  constraints = {
+    'host': 'limit:2',
+  },
+)
+
+jobs = [ job ]

http://git-wip-us.apache.org/repos/asf/incubator-aurora/blob/0df27d7a/src/test/sh/org/apache/aurora/e2e/http_example.py
----------------------------------------------------------------------
diff --git a/src/test/sh/org/apache/aurora/e2e/http_example.py b/src/test/sh/org/apache/aurora/e2e/http_example.py
new file mode 100644
index 0000000..cedba70
--- /dev/null
+++ b/src/test/sh/org/apache/aurora/e2e/http_example.py
@@ -0,0 +1,30 @@
+#
+# Copyright 2014 Apache Software Foundation
+#
+# Licensed 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.
+#
+from __future__ import print_function
+from sys import argv
+from BaseHTTPServer import BaseHTTPRequestHandler, HTTPServer
+
+class RequestHandler(BaseHTTPRequestHandler):
+  def do_GET(self):
+    self.send_response(200)
+    self.send_header('Content-Type', 'text/plain')
+    self.end_headers()
+    self.wfile.write('Hello!\n')
+
+
+server = HTTPServer(('', int(argv[1])), RequestHandler)
+print('Listening on port %s' % argv[1])
+server.serve_forever()
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-aurora/blob/0df27d7a/src/test/sh/org/apache/aurora/e2e/test_common.sh
----------------------------------------------------------------------
diff --git a/src/test/sh/org/apache/aurora/e2e/test_common.sh b/src/test/sh/org/apache/aurora/e2e/test_common.sh
index 1328ac5..e4a2e50 100644
--- a/src/test/sh/org/apache/aurora/e2e/test_common.sh
+++ b/src/test/sh/org/apache/aurora/e2e/test_common.sh
@@ -21,16 +21,6 @@
 # Preserve original stderr so output from signal handlers doesn't get redirected to /dev/null.
 exec 4>&2
 
-_aurora_built=false
-aurora() {
-  if ! $_aurora_built
-  then
-    ./pants src/main/python/apache/aurora/client/bin:aurora_client
-    _aurora_built=true
-  fi
-  ./dist/aurora_client.pex "$@"
-}
-
 _curl() { curl --silent --fail --retry 4 --retry-delay 10 "$@" ; }
 
 collect_result() {
@@ -48,7 +38,7 @@ collect_result() {
       echo "with your code. Either way, this script DNR merging to master. Note you may need to"
       echo "reconcile state manually."
       echo "!!!"
-      vagrant ssh devcluster -c "aurora killall devcluster/vagrant/test/flask_example"
+      vagrant ssh -c "aurora killall devcluster/vagrant/test/http_example"
     fi
     exit $RETCODE
   ) >&4 # Send to the stderr we had at startup.

http://git-wip-us.apache.org/repos/asf/incubator-aurora/blob/0df27d7a/src/test/sh/org/apache/aurora/e2e/test_end_to_end.sh
----------------------------------------------------------------------
diff --git a/src/test/sh/org/apache/aurora/e2e/test_end_to_end.sh b/src/test/sh/org/apache/aurora/e2e/test_end_to_end.sh
index c8fa07a..2b546f1 100755
--- a/src/test/sh/org/apache/aurora/e2e/test_end_to_end.sh
+++ b/src/test/sh/org/apache/aurora/e2e/test_end_to_end.sh
@@ -26,39 +26,13 @@ set -u -e -x
 
 . src/test/sh/org/apache/aurora/e2e/test_common.sh
 
-function run_dev() {
-  vagrant ssh devcluster -c "$1"
-}
-
-function run_sched() {
-  vagrant ssh devcluster -c "$1"
-}
-
-devtools_setup() {
-  local _testdir=$1
-  # grab the current branch name, and create a workspace using the same branch in vagrant.
-  branch=$(git rev-parse --abbrev-ref HEAD)
-  run_dev "if [ ! -d ~/test_dev ]; then git clone /vagrant ~/test_dev; fi"
-  # Clean out any lingering build products; we want fresh.
-  run_dev "rm -rf ~/.pex"
-  run_dev "cd ~/test_dev; git reset --hard; git clean -fdx"
-  run_dev "cd ~/test_dev; git checkout $branch; git pull"
-  run_dev "cd ~/test_dev; ./pants src/main/python/apache/aurora/client/bin:aurora_client"
-  run_dev "cd ~/test_dev; ./pants src/test/sh/org/apache/aurora/e2e/flask:flask_example"
-  if [ ! -d $_testdir ]
-    then
-      mkdir $_testdir
-    fi
-  run_dev "cd ~/test_dev; cp dist/flask_example.pex /vagrant/$_testdir"
-  run_dev "cd ~/test_dev; cp dist/aurora_client.pex /vagrant/$_testdir"
-}
-
-test_flask_example() {
-  local _cluster=$1 _role=$2 _env=$3 _job=$4 _testdir=$5 _sched_ip=$6
-  local _base_config=$7 _updated_config=$8
+test_http_example() {
+  local _cluster=$1 _role=$2 _env=$3 _job=$4 _sched_ip=$5
+  local _base_config=$6 _updated_config=$7
   jobkey="$_cluster/$_role/$_env/$_job"
+
   echo '== Creating job'
-  run_sched "/vagrant/$_testdir/aurora_client.pex create $jobkey $_base_config"
+  vagrant ssh -c "aurora create $jobkey $_base_config"
 
   # Check that scheduler /vars being exported
   base_url="http://$_sched_ip:8081"
@@ -66,45 +40,40 @@ test_flask_example() {
   test $uptime -eq 1
 
   echo '== Updating test job'
-  run_sched "/vagrant/$_testdir/aurora_client.pex update $jobkey $_updated_config"
+  vagrant ssh -c "aurora update $jobkey $_updated_config"
 
   #echo "== Probing job via 'aurora run'"
   # TODO(mchucarroll): Get "run" working: the vagrant configuration currently doesn't set up ssh
   # to allow automatic logins to the slaves. "aurora run" therefore tries to prompt the user for
   # a password, finds that it's not running in a TTY, and aborts.
-  runlen=$(run_sched "/vagrant/$_testdir/aurora_client.pex run $jobkey 'pwd'" | wc -l)
+  runlen=$(vagrant ssh -c "aurora run $jobkey 'pwd'" | wc -l)
   test $runlen -eq 2
 
-  run_sched "/vagrant/$_testdir/aurora_client.pex get_quota --cluster=$_cluster $_role"
-
-  run_sched "/vagrant/$_testdir/aurora_client.pex killall  $jobkey"
+  vagrant ssh -c "aurora get_quota --cluster=$_cluster $_role"
+  vagrant ssh -c "aurora killall  $jobkey"
 }
 
 RETCODE=1
 # Set up shorthands for test
-export EXAMPLE_DIR=/vagrant/src/test/sh/org/apache/aurora/e2e/flask
-TEST_DIR=deploy_test
+export EXAMPLE_DIR=/vagrant/src/test/sh/org/apache/aurora/e2e/http
 TEST_CLUSTER=devcluster
 TEST_ROLE=vagrant
 TEST_ENV=test
-TEST_JOB=flask_example
+TEST_JOB=http_example
 TEST_SCHEDULER_IP=192.168.33.7
 TEST_ARGS=(
   $TEST_CLUSTER
   $TEST_ROLE
   $TEST_ENV
   $TEST_JOB
-  $TEST_DIR
   $TEST_SCHEDULER_IP
-  $EXAMPLE_DIR/flask_example.aurora
-  $EXAMPLE_DIR/flask_example_updated.aurora
+  $EXAMPLE_DIR/http_example.aurora
+  $EXAMPLE_DIR/http_example_updated.aurora
   )
 
 trap collect_result EXIT
 vagrant up
 # wipe the pseudo-deploy dir, and then create it fresh, to guarantee that the
 # test runs clean.
-rm -rf $TEST_DIR
-devtools_setup $TEST_DIR
-test_flask_example "${TEST_ARGS[@]}"
+test_http_example "${TEST_ARGS[@]}"
 RETCODE=0

http://git-wip-us.apache.org/repos/asf/incubator-aurora/blob/0df27d7a/src/test/sh/org/apache/aurora/e2e/test_end_to_end_v2.sh
----------------------------------------------------------------------
diff --git a/src/test/sh/org/apache/aurora/e2e/test_end_to_end_v2.sh b/src/test/sh/org/apache/aurora/e2e/test_end_to_end_v2.sh
index 3c4165c..9b4a00b 100755
--- a/src/test/sh/org/apache/aurora/e2e/test_end_to_end_v2.sh
+++ b/src/test/sh/org/apache/aurora/e2e/test_end_to_end_v2.sh
@@ -27,43 +27,16 @@ set -u -e -x
 . src/test/sh/org/apache/aurora/e2e/test_common.sh
 
 
-function run_dev() {
-  vagrant ssh devtools -c "$1"
-}
-
-function run_sched() {
-  vagrant ssh aurora-scheduler -c "$1"
-}
-
 function check_url_live() {
   test $(curl -sL -w '%{http_code}' $1 -o /dev/null) == 200
-
-}
-
-devtools_setup() {
-  local _testdir=$1
-  # grab the current branch name, and create a workspace using the same branch in vagrant.
-  branch=$(git rev-parse --abbrev-ref HEAD)
-  run_dev "if [ ! -d ~/test_dev ]; then git clone /vagrant ~/test_dev; fi"
-  # Clean out any lingering build products; we want fresh.
-  run_dev "cd ~/test_dev; git reset --hard; git clean -fdx"
-  run_dev "cd ~/test_dev ; git checkout $branch; git pull"
-  run_dev "cd ~/test_dev; ./pants src/main/python/apache/aurora/client/cli:aurora2"
-  run_dev "cd ~/test_dev; ./pants src/test/sh/org/apache/aurora/e2e/flask:flask_example"
-  if [ ! -d $_testdir ]
-    then
-      mkdir $_testdir
-    fi
-  run_dev "cd ~/test_dev; cp dist/flask_example.pex /vagrant/$_testdir"
-  run_dev "cd ~/test_dev; cp dist/$CLIENT_NAME /vagrant/$_testdir"
 }
 
-test_flask_example() {
-  local _cluster=$1 _role=$2 _env=$3 _job=$4 _testdir=$5 _sched_ip=$6
-  local _base_config=$7 _updated_config=$8
+test_http_example() {
+  local _cluster=$1 _role=$2 _env=$3 _job=$4 _sched_ip=$5
+  local _base_config=$6 _updated_config=$7
   jobkey="$_cluster/$_role/$_env/$_job"
   echo '== Creating job'
-  run_sched "/vagrant/$_testdir/$CLIENT_NAME job create $jobkey $_base_config"
+  vagrant ssh -c "aurora2 job create $jobkey $_base_config"
 
   # Check that scheduler UI pages shown
   base_url="http://$_sched_ip:8081"
@@ -72,38 +45,34 @@ test_flask_example() {
   check_url_live "$base_url/scheduler/$_role/$_env/$_job"
 
   echo '== Updating test job'
-  run_sched "/vagrant/$_testdir/$CLIENT_NAME job update $jobkey $_updated_config"
+  vagrant ssh -c "aurora2 job update $jobkey $_updated_config"
 
   # TODO(mchucarroll): Get "run" working: the vagrant configuration currently doesn't set up ssh
   # to allow automatic logins to the slaves. "aurora run" therefore tries to prompt the user for
   # a password, finds that it's not running in a TTY, and aborts.
-  runlen=$(run_sched "/vagrant/$_testdir/$CLIENT_NAME task run $jobkey 'pwd'" | wc -l)
+  runlen=$(vagrant ssh -c "aurora2 task run $jobkey 'pwd'" | wc -l)
   test $runlen -eq 2
 
-  run_sched "/vagrant/$_testdir/$CLIENT_NAME quota get $_cluster/$_role"
-
-  run_sched "/vagrant/$_testdir/$CLIENT_NAME job killall  $jobkey"
+  vagrant ssh -c "aurora2 quota get $_cluster/$_role"
+  vagrant ssh -c "aurora2 job killall  $jobkey"
 }
 
 RETCODE=1
 # Set up shorthands for test
-export CLIENT_NAME=aurora2.pex
-export EXAMPLE_DIR=/vagrant/src/test/sh/org/apache/aurora/e2e/flask
-TEST_DIR=deploy_test
-TEST_CLUSTER=example
+export EXAMPLE_DIR=/vagrant/src/test/sh/org/apache/aurora/e2e/http
+TEST_CLUSTER=devcluster
 TEST_ROLE=vagrant
 TEST_ENV=test
-TEST_JOB=flask_example
-TEST_SCHEDULER_IP=192.168.33.6
+TEST_JOB=http_example
+TEST_SCHEDULER_IP=192.168.33.7
 TEST_ARGS=(
   $TEST_CLUSTER
   $TEST_ROLE
   $TEST_ENV
   $TEST_JOB
-  $TEST_DIR
   $TEST_SCHEDULER_IP
-  $EXAMPLE_DIR/flask_example.aurora
-  $EXAMPLE_DIR/flask_example_updated.aurora
+  $EXAMPLE_DIR/http_example.aurora
+  $EXAMPLE_DIR/http_example_updated.aurora
   )
 
 trap collect_result EXIT
@@ -112,7 +81,5 @@ vagrant up
 
 # wipe the pseudo-deploy dir, and then create it fresh, to guarantee that the
 # test runs clean.
-rm -rf $TEST_DIR
-devtools_setup $TEST_DIR
-test_flask_example "${TEST_ARGS[@]}"
+test_http_example "${TEST_ARGS[@]}"
 RETCODE=0