You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@trafficcontrol.apache.org by ra...@apache.org on 2022/03/22 15:07:50 UTC

[trafficcontrol] branch master updated: T3C integration tests - Remove RIAK and use Postgres for TV (#6679)

This is an automated email from the ASF dual-hosted git repository.

rawlin pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/trafficcontrol.git


The following commit(s) were added to refs/heads/master by this push:
     new d43dfb2  T3C integration tests - Remove RIAK and use Postgres for TV (#6679)
d43dfb2 is described below

commit d43dfb2851e65eb1cdbf6a1791fed5123fc1a438
Author: Taylor Clayton Frey <ta...@gmail.com>
AuthorDate: Tue Mar 22 09:07:34 2022 -0600

    T3C integration tests - Remove RIAK and use Postgres for TV (#6679)
    
    * T3C tests - Remove RIAK and use Postgres for TV
    
    * Add newline to shell script file for db init.
    
    Co-authored-by: Taylor Frey <ta...@comcast.com>
---
 cache-config/testing/docker/db_init/Dockerfile     |   6 +
 cache-config/testing/docker/db_init/dbInit.sh      |   2 +
 cache-config/testing/docker/docker-compose.yml     |  14 -
 cache-config/testing/docker/traffic_ops/run.sh     |  53 +-
 .../testing/docker/traffic_vault/Dockerfile        |  40 --
 .../testing/docker/traffic_vault/functions         | 707 ---------------------
 .../poststart.d/00-enable-security.sh              |  48 --
 .../poststart.d/01-add-search-group.sh             |  27 -
 .../poststart.d/02-add-search-schema.sh            |  29 -
 .../docker/traffic_vault/prestart.d/00-config.sh   |  40 --
 cache-config/testing/docker/traffic_vault/run.sh   |  39 --
 .../testing/docker/traffic_vault/sslkeys.xml       |  55 --
 cache-config/testing/docker/variables.env          |  16 +-
 13 files changed, 50 insertions(+), 1026 deletions(-)

diff --git a/cache-config/testing/docker/db_init/Dockerfile b/cache-config/testing/docker/db_init/Dockerfile
index 33e57cd..2712c6c 100644
--- a/cache-config/testing/docker/db_init/Dockerfile
+++ b/cache-config/testing/docker/db_init/Dockerfile
@@ -37,5 +37,11 @@ ENV DB_USER_PASS $DB_USER_PASS
 ENV DB_SERVER $DB_SERVER
 ENV DB_PORT $DB_PORT
 
+# Uses the same DB server/port
+ENV TV_DB_NAME $TV_DB_NAME
+ENV TV_USER $TV_USER
+ENV TV_USER_PASS $TV_USER_PASS
+ENV TV_SERVER $TV_SERVER
+
 ADD db_init/dbInit.sh /
 CMD /dbInit.sh
diff --git a/cache-config/testing/docker/db_init/dbInit.sh b/cache-config/testing/docker/db_init/dbInit.sh
index f4392d4..536ab7a 100755
--- a/cache-config/testing/docker/db_init/dbInit.sh
+++ b/cache-config/testing/docker/db_init/dbInit.sh
@@ -27,4 +27,6 @@ while ! nc $DB_SERVER $DB_PORT </dev/null; do # &>/dev/null; do
         sleep 3
 done
 psql -h $DB_SERVER -U postgres -c "CREATE USER $DB_USER WITH ENCRYPTED PASSWORD '$DB_USER_PASS'"
+psql -h $DB_SERVER -U postgres -c "CREATE USER $TV_USER WITH ENCRYPTED PASSWORD '$TV_USER_PASS'"
 createdb $DB_NAME -h $DB_SERVER -U postgres --owner $DB_USER
+createdb $TV_DB_NAME -h $DB_SERVER -U postgres --owner $TV_USER
diff --git a/cache-config/testing/docker/docker-compose.yml b/cache-config/testing/docker/docker-compose.yml
index 1996c47..b7580c6 100644
--- a/cache-config/testing/docker/docker-compose.yml
+++ b/cache-config/testing/docker/docker-compose.yml
@@ -67,19 +67,6 @@ services:
     depends_on:
       - db_init
 
-  traffic_vault:
-    env_file:
-      - variables.env
-    ports:
-      - "8087:8087"
-      - "8088:8088"
-      - "8098:8098"
-    build:
-      context: .
-      dockerfile: traffic_vault/Dockerfile
-    depends_on:
-      - to_server
-
   ort_test:
     env_file:
       - variables.env
@@ -93,7 +80,6 @@ services:
     depends_on:
       - yumserver
       - to_server
-      - traffic_vault
     volumes:
       - ../../..:/root/go/src/github.com/apache/trafficcontrol
       - ./yumserver:/yumserver
diff --git a/cache-config/testing/docker/traffic_ops/run.sh b/cache-config/testing/docker/traffic_ops/run.sh
index e423587..649d0ef 100755
--- a/cache-config/testing/docker/traffic_ops/run.sh
+++ b/cache-config/testing/docker/traffic_ops/run.sh
@@ -37,29 +37,33 @@
 # TRAFFIC_VAULT_PASS
 
 # Check that env vars are set
-envvars=( DB_SERVER DB_PORT DB_ROOT_PASS DB_USER DB_USER_PASS TO_ADMIN_USER TO_ADMIN_PASS CERT_COUNTRY CERT_STATE CERT_CITY CERT_COMPANY TO_DOMAIN)
+envvars=( DB_SERVER DB_PORT DB_ROOT_PASS DB_USER DB_USER_PASS DB_NAME TO_ADMIN_USER TO_ADMIN_PASS CERT_COUNTRY CERT_STATE CERT_CITY CERT_COMPANY TO_DOMAIN TV_DB_NAME TV_SERVER TV_PORT TV_USER TV_USER_PASS TV_AES_KEY_LOCATION)
 for v in $envvars
 do
 	if [[ -z $$v ]]; then echo "$v is unset"; exit 1; fi
 done
 
 start() {
-  traffic_ops_golang_command=(./bin/traffic_ops_golang -cfg "$CDNCONF" -dbcfg "$DATABASECONF" -riakcfg "$RIAKCONF");
+  traffic_ops_golang_command=(./bin/traffic_ops_golang -cfg "$CDNCONF" -dbcfg "$DATABASECONF" );
   "${traffic_ops_golang_command[@]}" &
 	exec tail -f $TO_LOG
 }
 
-# generates and saves SSL certificates, database and RIAK config files.
+# generates and saves SSL certificates, database (TO and TV) config files.
 init() {
   # install certificates for TO
   openssl req -newkey rsa:2048 -nodes -keyout /etc/pki/tls/private/localhost.key -x509 -days 365 \
     -out /etc/pki/tls/certs/localhost.crt -subj "/C=$CERT_COUNTRY/ST=$CERT_STATE/L=$CERT_CITY/O=$CERT_COMPANY"
   cp /etc/pki/tls/certs/localhost.crt /etc/pki/tls/certs/ca-bundle.crt
+  openssl rand -base64 32 > $TV_AES_KEY_LOCATION
+  chown trafops:trafops $TV_AES_KEY_LOCATION
 
   # update the base_url in cdn.conf
   sed -i -e "s#http://localhost\:3000#http://${TO_HOSTNAME}\:443#" $CDNCONF
 	sed -i -e 's#https://\[::\]#https://127\.0\.0\.1#' $CDNCONF
   sed -i -e 's#"use_ims": false,#"use_ims": true,#' $CDNCONF
+  sed -i -e 's#"traffic_vault_backend": "",#"traffic_vault_backend": "postgres",#' $CDNCONF
+  sed -i -e "s#\"traffic_vault_config\": {},#\"traffic_vault_config\": {\n            \"dbname\": \"$TV_DB_NAME\",\n            \"hostname\": \"$TV_SERVER\",\n            \"user\": \"$TV_USER\",\n            \"password\": \"$TV_USER_PASS\",\n            \"port\": $TV_PORT,\n            \"ssl\": false,\n            \"conn_max_lifetime_seconds\": 60,\n            \"max_connections\": 20,\n            \"max_idle_connections\": 15,\n            \"query_timeout_seconds\": 10,\n            \"a [...]
   #
   cat > $DATABASECONF << EOM
 {
@@ -73,36 +77,47 @@ init() {
 }
 EOM
 
-  cat > $RIAKCONF << EOM
-{
-  "user": "riakuser",
-  "password": "$RIAK_USER_PASS",
-  "MaxTLSVersion": "1.1",
-  "tlsConfig": {
-    "insecureSkipVerify": true
-  }
-}
+  cat > $DBCONF << EOM
+version: "1.0"
+name: dbconf.yml
+
+development:
+  driver: postgres
+  open: host=$DB_SERVER port=$DB_PORT user=$DB_USER password=$DB_USER_PASS dbname=to_development sslmode=disable
+
+test:
+  driver: postgres
+  open: host=$DB_SERVER port=$DB_PORT user=$DB_USER password=$DB_USER_PASS dbname=to_test sslmode=disable
+
+integration:
+  driver: postgres
+  open: host=$DB_SERVER port=$DB_PORT user=$DB_USER password=$DB_USER_PASS dbname=to_integration sslmode=disable
+
+production:
+  driver: postgres
+  open: host=$DB_SERVER port=$DB_PORT user=$DB_USER password=$DB_USER_PASS dbname=$DB_NAME sslmode=disable
 EOM
 
-  cat > $DBCONF << EOM
+
+  cat > $TVCONF << EOM
 version: "1.0"
 name: dbconf.yml
 
 development:
   driver: postgres
-  open: host=$DB_SERVER port=5432 user=traffic_ops password=$DB_USER_PASS dbname=to_development sslmode=disable
+  open: host=$TV_SERVER port=$TV_PORT user=$TV_USER password=$TV_USER_PASS dbname=tv_development sslmode=disable
 
 test:
   driver: postgres
-  open: host=$DB_SERVER port=5432 user=traffic_ops password=$DB_USER_PASS dbname=to_test sslmode=disable
+  open: host=$TV_SERVER port=$TV_PORT user=$TV_USER password=$TV_USER_PASS dbname=tv_test sslmode=disable
 
 integration:
   driver: postgres
-  open: host=$DB_SERVER port=5432 user=traffic_ops password=$DB_USER_PASS dbname=to_integration sslmode=disable
+  open: host=$TV_SERVER port=$TV_PORT user=$TV_USER password=$TV_USER_PASS dbname=tv_integration sslmode=disable
 
 production:
   driver: postgres
-  open: host=$DB_SERVER port=5432 user=traffic_ops password=$DB_USER_PASS dbname=traffic_ops sslmode=disable
+  open: host=$TV_SERVER port=$TV_PORT user=$TV_USER password=$TV_USER_PASS dbname=$TV_DB_NAME sslmode=disable
 EOM
 
   touch $LOG_DEBUG $LOG_ERROR $LOG_EVENT $LOG_INFO $LOG_WARN $TO_LOG
@@ -112,7 +127,9 @@ source /etc/environment
 if [ -z "$INITIALIZED" ]; then init; fi
 
 # create the 'traffic_ops' database, tables and runs migrations
-(cd /opt/traffic_ops/app && db/admin --env=production reset > /admin.log 2>&1)
+(mkdir -p /var/log/traffic_ops/)
+(cd /opt/traffic_ops/app && db/admin --env=production reset > /var/log/traffic_ops/to_admin.log 2>&1)
+(cd /opt/traffic_ops/app && db/admin --trafficvault --env=production reset > /var/log/traffic_ops/tv_admin.log 2>&1)
 
 # start traffic_ops
 start
diff --git a/cache-config/testing/docker/traffic_vault/Dockerfile b/cache-config/testing/docker/traffic_vault/Dockerfile
deleted file mode 100644
index 7ac6fa1..0000000
--- a/cache-config/testing/docker/traffic_vault/Dockerfile
+++ /dev/null
@@ -1,40 +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.
-############################################################
-# Dockerfile to build Riak container images
-#   as Traffic Vault for Traffic Control 1.6.0
-# Based on CentOS 6.6
-############################################################
-
-FROM basho/riak-kv:ubuntu-2.2.3
-
-EXPOSE 8087 8088 8098
-
-RUN rm -rfv /etc/riak/prestart.d/* /etc/riak/poststart.d/*
-
-RUN echo 'APT::Install-Recommends 0;' >> /etc/apt/apt.conf.d/01norecommends \
- && echo 'APT::Install-Suggests 0;' >> /etc/apt/apt.conf.d/01norecommends \
- && rm /etc/apt/sources.list.d/basho_riak.list \
- && apt-get update \
- && DEBIAN_FRONTEND=noninteractive apt-get install -y net-tools ca-certificates dnsutils gettext-base \
- && rm -rf /var/lib/apt/lists/* && rm -rf /etc/apt/apt.conf.d/docker-gzip-indexes
-
-ADD traffic_vault/prestart.d/* /etc/riak/prestart.d/
-ADD traffic_vault/poststart.d/* /etc/riak/poststart.d/
-ADD traffic_vault/run.sh traffic_vault/sslkeys.xml /
-
-CMD /run.sh
diff --git a/cache-config/testing/docker/traffic_vault/functions b/cache-config/testing/docker/traffic_vault/functions
deleted file mode 100644
index 5ae8ba2..0000000
--- a/cache-config/testing/docker/traffic_vault/functions
+++ /dev/null
@@ -1,707 +0,0 @@
-# -*-Shell-script-*-
-# 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.
-#
-# functions This file contains functions to be used by most or all
-#       shell scripts in the /etc/init.d directory.
-#
-
-TEXTDOMAIN=initscripts
-
-# Make sure umask is sane
-umask 022
-
-# Set up a default search path.
-PATH="/sbin:/usr/sbin:/bin:/usr/bin"
-export PATH
-
-if [ $PPID -ne 1 -a -z "$SYSTEMCTL_SKIP_REDIRECT" ] && \
-        [ -d /run/systemd/system ] ; then
-    case "$0" in
-    /etc/init.d/*|/etc/rc.d/init.d/*)
-        _use_systemctl=1
-        ;;
-    esac
-fi
-
-systemctl_redirect () {
-    local s
-    local prog=${1##*/}
-    local command=$2
-    local options=""
-
-    case "$command" in
-    start)
-        s="Starting $prog (via systemctl): "
-        ;;
-    stop)
-        s="Stopping $prog (via systemctl): "
-        ;;
-    reload|try-reload)
-        s="Reloading $prog configuration (via systemctl): "
-        ;;
-    restart|try-restart|condrestart)
-        s="Restarting $prog (via systemctl): "
-        ;;
-    esac
-
-    if [ -n "$SYSTEMCTL_IGNORE_DEPENDENCIES" ] ; then
-        options="--ignore-dependencies"
-    fi
-
-    if ! systemctl show "$prog.service" > /dev/null 2>&1 || \
-            systemctl show -p LoadState "$prog.service" | grep -q 'not-found' ; then
-        action $"Reloading systemd: " /bin/systemctl daemon-reload
-    fi
-
-    action "$s" /bin/systemctl $options $command "$prog.service"
-}
-
-# Get a sane screen width
-[ -z "${COLUMNS:-}" ] && COLUMNS=80
-
-if [ -z "${CONSOLETYPE:-}" ]; then
-    if [ -c "/dev/stderr" -a -r "/dev/stderr" ]; then
-        CONSOLETYPE="$(/sbin/consoletype < /dev/stderr 2>/dev/null)"
-    else
-        CONSOLETYPE="serial"
-    fi
-fi
-
-if [ -z "${NOLOCALE:-}" ] && [ -z "${LANGSH_SOURCED:-}" ] && \
-        [ -f /etc/sysconfig/i18n -o -f /etc/locale.conf ] ; then
-    . /etc/profile.d/lang.sh 2>/dev/null
-    # avoid propagating LANGSH_SOURCED any further
-    unset LANGSH_SOURCED
-fi
-
-# Read in our configuration
-if [ -z "${BOOTUP:-}" ]; then
-    if [ -f /etc/sysconfig/init ]; then
-        . /etc/sysconfig/init
-    else
-        # This all seem confusing? Look in /etc/sysconfig/init,
-        # or in /usr/share/doc/initscripts-*/sysconfig.txt
-        BOOTUP=color
-        RES_COL=60
-        MOVE_TO_COL="echo -en \\033[${RES_COL}G"
-        SETCOLOR_SUCCESS="echo -en \\033[1;32m"
-        SETCOLOR_FAILURE="echo -en \\033[1;31m"
-        SETCOLOR_WARNING="echo -en \\033[1;33m"
-        SETCOLOR_NORMAL="echo -en \\033[0;39m"
-        LOGLEVEL=1
-    fi
-    if [ "$CONSOLETYPE" = "serial" ]; then
-        BOOTUP=serial
-        MOVE_TO_COL=
-        SETCOLOR_SUCCESS=
-        SETCOLOR_FAILURE=
-        SETCOLOR_WARNING=
-        SETCOLOR_NORMAL=
-    fi
-fi
-
-# Check if any of $pid (could be plural) are running
-checkpid() {
-    local i
-
-    for i in $* ; do
-        [ -d "/proc/$i" ] && return 0
-    done
-    return 1
-}
-
-__kill_pids_term_kill_checkpids() {
-    local base_stime=$1
-    shift 1
-    local pid=
-    local pids=$*
-    local remaining=
-    local stat=
-    local stime=
-
-    for pid in $pids ; do
-        [ ! -e  "/proc/$pid" ] && continue
-        read -r line < "/proc/$pid/stat" 2> /dev/null
-
-        stat=($line)
-        stime=${stat[21]}
-
-        [ -n "$stime" ] && [ "$base_stime" -lt "$stime" ] && continue
-        remaining+="$pid "
-    done
-
-    echo "$remaining"
-    [ -n "$remaining" ] && return 1
-
-    return 0
-}
-
-__kill_pids_term_kill() {
-    local try=0
-    local delay=3;
-    local pid=
-    local stat=($(< /proc/self/stat))
-    local base_stime=${stat[21]}
-
-    if [ "$1" = "-d" ]; then
-        delay=$2
-        shift 2
-    fi
-
-    local kill_list=$*
-
-    kill_list=$(__kill_pids_term_kill_checkpids $base_stime $kill_list)
-
-    [ -z "$kill_list" ] && return 0
-
-    kill -TERM $kill_list >/dev/null 2>&1
-    usleep 100000
-
-    kill_list=$(__kill_pids_term_kill_checkpids $base_stime $kill_list)
-    if [ -n "$kill_list" ] ; then
-        while [ $try -lt $delay ] ; do
-            sleep 1
-            kill_list=$(__kill_pids_term_kill_checkpids $base_stime $kill_list)
-            [ -z "$kill_list" ] && break
-            let try+=1
-        done
-        if [ -n "$kill_list" ] ; then
-            kill -KILL $kill_list >/dev/null 2>&1
-            usleep 100000
-            kill_list=$(__kill_pids_term_kill_checkpids $base_stime $kill_list)
-        fi
-    fi
-
-    [ -n "$kill_list" ] && return 1
-    return 0
-}
-
-# __proc_pids {program} [pidfile]
-# Set $pid to pids from /var/run* for {program}.  $pid should be declared
-# local in the caller.
-# Returns LSB exit code for the 'status' action.
-__pids_var_run() {
-    local base=${1##*/}
-    local pid_file=${2:-/var/run/$base.pid}
-    local pid_dir=$(/usr/bin/dirname $pid_file > /dev/null)
-    local binary=$3
-
-    [ -d "$pid_dir" -a ! -r "$pid_dir" ] && return 4
-
-    pid=
-    if [ -f "$pid_file" ] ; then
-            local line p
-
-        [ ! -r "$pid_file" ] && return 4 # "user had insufficient privilege"
-        while : ; do
-            read line
-            [ -z "$line" ] && break
-            for p in $line ; do
-                if [ -z "${p//[0-9]/}" ] && [ -d "/proc/$p" ] ; then
-                    if [ -n "$binary" ] ; then
-                        local b=$(readlink /proc/$p/exe | sed -e 's/\s*(deleted)$//')
-                        [ "$b" != "$binary" ] && continue
-                    fi
-                    pid="$pid $p"
-                fi
-            done
-        done < "$pid_file"
-
-            if [ -n "$pid" ]; then
-                    return 0
-            fi
-        return 1 # "Program is dead and /var/run pid file exists"
-    fi
-    return 3 # "Program is not running"
-}
-
-# Output PIDs of matching processes, found using pidof
-__pids_pidof() {
-    pidof -c -m -o $$ -o $PPID -o %PPID -x "$1" || \
-        pidof -c -m -o $$ -o $PPID -o %PPID -x "${1##*/}"
-}
-
-
-# A function to start a program.
-daemon() {
-    # Test syntax.
-    local gotbase= force= nicelevel corelimit
-    local pid base= user= nice= bg= pid_file=
-    local cgroup=
-    nicelevel=0
-    while [ "$1" != "${1##[-+]}" ]; do
-        case $1 in
-        '')
-            echo $"$0: Usage: daemon [+/-nicelevel] {program}" "[arg1]..."
-            return 1
-            ;;
-        --check)
-            base=$2
-            gotbase="yes"
-            shift 2
-            ;;
-        --check=?*)
-            base=${1#--check=}
-            gotbase="yes"
-            shift
-            ;;
-        --user)
-            user=$2
-            shift 2
-            ;;
-        --user=?*)
-            user=${1#--user=}
-            shift
-            ;;
-        --pidfile)
-            pid_file=$2
-            shift 2
-            ;;
-        --pidfile=?*)
-            pid_file=${1#--pidfile=}
-            shift
-            ;;
-        --force)
-            force="force"
-            shift
-            ;;
-        [-+][0-9]*)
-            nice="nice -n $1"
-            shift
-            ;;
-        *)
-            echo $"$0: Usage: daemon [+/-nicelevel] {program}" "[arg1]..."
-            return 1
-            ;;
-      esac
-    done
-
-    # Save basename.
-    [ -z "$gotbase" ] && base=${1##*/}
-
-    # See if it's already running. Look *only* at the pid file.
-    __pids_var_run "$base" "$pid_file"
-
-    [ -n "$pid" -a -z "$force" ] && return
-
-    # make sure it doesn't core dump anywhere unless requested
-    corelimit="ulimit -S -c ${DAEMON_COREFILE_LIMIT:-0}"
-
-    # if they set NICELEVEL in /etc/sysconfig/foo, honor it
-    [ -n "${NICELEVEL:-}" ] && nice="nice -n $NICELEVEL"
-
-    # if they set CGROUP_DAEMON in /etc/sysconfig/foo, honor it
-    if [ -n "${CGROUP_DAEMON}" ]; then
-        if [ ! -x /bin/cgexec ]; then
-            echo -n "Cgroups not installed"; warning
-            echo
-        else
-            cgroup="/bin/cgexec";
-            for i in $CGROUP_DAEMON; do
-                cgroup="$cgroup -g $i";
-            done
-        fi
-    fi
-
-    # Echo daemon
-    [ "${BOOTUP:-}" = "verbose" -a -z "${LSB:-}" ] && echo -n " $base"
-
-    # And start it up.
-    if [ -z "$user" ]; then
-       $cgroup $nice /bin/bash -c "$corelimit >/dev/null 2>&1 ; $*"
-    else
-       $cgroup $nice runuser -s /bin/bash $user -c "$corelimit >/dev/null 2>&1 ; $*"
-    fi
-
-    [ "$?" -eq 0 ] && success $"$base startup" || failure $"$base startup"
-}
-
-# A function to stop a program.
-killproc() {
-    local RC killlevel= base pid pid_file= delay try binary=
-
-    RC=0; delay=3; try=0
-    # Test syntax.
-    if [ "$#" -eq 0 ]; then
-        echo $"Usage: killproc [-p pidfile] [ -d delay] {program} [-signal]"
-        return 1
-    fi
-    if [ "$1" = "-p" ]; then
-        pid_file=$2
-        shift 2
-    fi
-    if [ "$1" = "-b" ]; then
-        if [ -z $pid_file ]; then
-            echo $"-b option can be used only with -p"
-            echo $"Usage: killproc -p pidfile -b binary program"
-            return 1
-        fi
-        binary=$2
-        shift 2
-    fi
-    if [ "$1" = "-d" ]; then
-        delay=$(echo $2 | awk -v RS=' ' -v IGNORECASE=1 '{if($1!~/^[0-9.]+[smhd]?$/) exit 1;d=$1~/s$|^[0-9.]*$/?1:$1~/m$/?60:$1~/h$/?60*60:$1~/d$/?24*60*60:-1;if(d==-1) exit 1;delay+=d*$1} END {printf("%d",delay+0.5)}')
-        if [ "$?" -eq 1 ]; then
-            echo $"Usage: killproc [-p pidfile] [ -d delay] {program} [-signal]"
-            return 1
-        fi
-        shift 2
-    fi
-
-
-    # check for second arg to be kill level
-    [ -n "${2:-}" ] && killlevel=$2
-
-    # Save basename.
-    base=${1##*/}
-
-    # Find pid.
-    __pids_var_run "$1" "$pid_file" "$binary"
-    RC=$?
-    if [ -z "$pid" ]; then
-        if [ -z "$pid_file" ]; then
-            pid="$(__pids_pidof "$1")"
-        else
-            [ "$RC" = "4" ] && { failure $"$base shutdown" ; return $RC ;}
-        fi
-    fi
-
-    # Kill it.
-    if [ -n "$pid" ] ; then
-        [ "$BOOTUP" = "verbose" -a -z "${LSB:-}" ] && echo -n "$base "
-        if [ -z "$killlevel" ] ; then
-            __kill_pids_term_kill -d $delay $pid
-            RC=$?
-            [ "$RC" -eq 0 ] && success $"$base shutdown" || failure $"$base shutdown"
-        # use specified level only
-        else
-            if checkpid $pid; then
-                kill $killlevel $pid >/dev/null 2>&1
-                RC=$?
-                [ "$RC" -eq 0 ] && success $"$base $killlevel" || failure $"$base $killlevel"
-            elif [ -n "${LSB:-}" ]; then
-                RC=7 # Program is not running
-            fi
-        fi
-    else
-        if [ -n "${LSB:-}" -a -n "$killlevel" ]; then
-            RC=7 # Program is not running
-        else
-            failure $"$base shutdown"
-            RC=0
-        fi
-    fi
-
-    # Remove pid file if any.
-    if [ -z "$killlevel" ]; then
-        rm -f "${pid_file:-/var/run/$base.pid}"
-    fi
-    return $RC
-}
-
-# A function to find the pid of a program. Looks *only* at the pidfile
-pidfileofproc() {
-    local pid
-
-    # Test syntax.
-    if [ "$#" = 0 ] ; then
-        echo $"Usage: pidfileofproc {program}"
-        return 1
-    fi
-
-    __pids_var_run "$1"
-    [ -n "$pid" ] && echo $pid
-    return 0
-}
-
-# A function to find the pid of a program.
-pidofproc() {
-    local RC pid pid_file=
-
-    # Test syntax.
-    if [ "$#" = 0 ]; then
-        echo $"Usage: pidofproc [-p pidfile] {program}"
-        return 1
-    fi
-    if [ "$1" = "-p" ]; then
-        pid_file=$2
-        shift 2
-    fi
-    fail_code=3 # "Program is not running"
-
-    # First try "/var/run/*.pid" files
-    __pids_var_run "$1" "$pid_file"
-    RC=$?
-    if [ -n "$pid" ]; then
-        echo $pid
-        return 0
-    fi
-
-    [ -n "$pid_file" ] && return $RC
-    __pids_pidof "$1" || return $RC
-}
-
-status() {
-    local base pid lock_file= pid_file= binary=
-
-    # Test syntax.
-    if [ "$#" = 0 ] ; then
-        echo $"Usage: status [-p pidfile] {program}"
-        return 1
-    fi
-    if [ "$1" = "-p" ]; then
-        pid_file=$2
-        shift 2
-    fi
-    if [ "$1" = "-l" ]; then
-        lock_file=$2
-        shift 2
-    fi
-    if [ "$1" = "-b" ]; then
-        if [ -z $pid_file ]; then
-            echo $"-b option can be used only with -p"
-            echo $"Usage: status -p pidfile -b binary program"
-            return 1
-        fi
-        binary=$2
-        shift 2
-    fi
-    base=${1##*/}
-
-    if [ "$_use_systemctl" = "1" ]; then
-        systemctl status ${0##*/}.service
-        ret=$?
-        # LSB daemons that dies abnormally in systemd looks alive in systemd's eyes due to RemainAfterExit=yes
-        # lets adjust the reality a little bit
-        if systemctl show -p ActiveState ${0##*/}.service | grep -q '=active$' && \
-        systemctl show -p SubState ${0##*/}.service | grep -q '=exited$' ; then
-            ret=3
-        fi
-        return $ret
-    fi
-
-    # First try "pidof"
-    __pids_var_run "$1" "$pid_file" "$binary"
-    RC=$?
-    if [ -z "$pid_file" -a -z "$pid" ]; then
-        pid="$(__pids_pidof "$1")"
-    fi
-    if [ -n "$pid" ]; then
-        echo $"${base} (pid $pid) is running..."
-        return 0
-    fi
-
-    case "$RC" in
-    0)
-        echo $"${base} (pid $pid) is running..."
-        return 0
-        ;;
-    1)
-        echo $"${base} dead but pid file exists"
-        return 1
-        ;;
-    4)
-        echo $"${base} status unknown due to insufficient privileges."
-        return 4
-        ;;
-    esac
-    if [ -z "${lock_file}" ]; then
-        lock_file=${base}
-    fi
-    # See if /var/lock/subsys/${lock_file} exists
-    if [ -f /var/lock/subsys/${lock_file} ]; then
-        echo $"${base} dead but subsys locked"
-        return 2
-    fi
-    echo $"${base} is stopped"
-    return 3
-}
-
-echo_success() {
-    [ "$BOOTUP" = "color" ] && $MOVE_TO_COL
-    echo -n "["
-    [ "$BOOTUP" = "color" ] && $SETCOLOR_SUCCESS
-    echo -n $"  OK  "
-    [ "$BOOTUP" = "color" ] && $SETCOLOR_NORMAL
-    echo -n "]"
-    echo -ne "\r"
-    return 0
-}
-
-echo_failure() {
-    [ "$BOOTUP" = "color" ] && $MOVE_TO_COL
-    echo -n "["
-    [ "$BOOTUP" = "color" ] && $SETCOLOR_FAILURE
-    echo -n $"FAILED"
-    [ "$BOOTUP" = "color" ] && $SETCOLOR_NORMAL
-    echo -n "]"
-    echo -ne "\r"
-    return 1
-}
-
-echo_passed() {
-    [ "$BOOTUP" = "color" ] && $MOVE_TO_COL
-    echo -n "["
-    [ "$BOOTUP" = "color" ] && $SETCOLOR_WARNING
-    echo -n $"PASSED"
-    [ "$BOOTUP" = "color" ] && $SETCOLOR_NORMAL
-    echo -n "]"
-    echo -ne "\r"
-    return 1
-}
-
-echo_warning() {
-    [ "$BOOTUP" = "color" ] && $MOVE_TO_COL
-    echo -n "["
-    [ "$BOOTUP" = "color" ] && $SETCOLOR_WARNING
-    echo -n $"WARNING"
-    [ "$BOOTUP" = "color" ] && $SETCOLOR_NORMAL
-    echo -n "]"
-    echo -ne "\r"
-    return 1
-}
-
-# Inform the graphical boot of our current state
-update_boot_stage() {
-    if [ -x /bin/plymouth ]; then
-        /bin/plymouth --update="$1"
-    fi
-    return 0
-}
-
-# Log that something succeeded
-success() {
-    [ "$BOOTUP" != "verbose" -a -z "${LSB:-}" ] && echo_success
-    return 0
-}
-
-# Log that something failed
-failure() {
-    local rc=$?
-    [ "$BOOTUP" != "verbose" -a -z "${LSB:-}" ] && echo_failure
-    [ -x /bin/plymouth ] && /bin/plymouth --details
-    return $rc
-}
-
-# Log that something passed, but may have had errors. Useful for fsck
-passed() {
-    local rc=$?
-    [ "$BOOTUP" != "verbose" -a -z "${LSB:-}" ] && echo_passed
-    return $rc
-}
-
-# Log a warning
-warning() {
-    local rc=$?
-    [ "$BOOTUP" != "verbose" -a -z "${LSB:-}" ] && echo_warning
-    return $rc
-}
-
-# Run some action. Log its output.
-action() {
-    local STRING rc
-
-    STRING=$1
-    echo -n "$STRING "
-    shift
-    "$@" && success $"$STRING" || failure $"$STRING"
-    rc=$?
-    echo
-    return $rc
-}
-
-# returns OK if $1 contains $2
-strstr() {
-    [ "${1#*$2*}" = "$1" ] && return 1
-    return 0
-}
-
-# Check whether file $1 is a backup or rpm-generated file and should be ignored
-is_ignored_file() {
-    case "$1" in
-    *~ | *.bak | *.orig | *.rpmnew | *.rpmorig | *.rpmsave)
-        return 0
-        ;;
-    esac
-    return 1
-}
-
-# Evaluate shvar-style booleans
-is_true() {
-    case "$1" in
-    [tT] | [yY] | [yY][eE][sS] | [tT][rR][uU][eE] | 1)
-        return 0
-        ;;
-    esac
-    return 1
-}
-
-# Evaluate shvar-style booleans
-is_false() {
-    case "$1" in
-    [fF] | [nN] | [nN][oO] | [fF][aA][lL][sS][eE] | 0)
-        return 0
-        ;;
-    esac
-    return 1
-}
-
-# Apply sysctl settings, including files in /etc/sysctl.d
-apply_sysctl() {
-    if [ -x /lib/systemd/systemd-sysctl ]; then
-    /lib/systemd/systemd-sysctl
-    else
-        for file in /usr/lib/sysctl.d/*.conf ; do
-            is_ignored_file "$file" && continue
-            [ -f /run/sysctl.d/${file##*/} ] && continue
-            [ -f /etc/sysctl.d/${file##*/} ] && continue
-            test -f "$file" && sysctl -e -p "$file" >/dev/null 2>&1
-        done
-        for file in /run/sysctl.d/*.conf ; do
-            is_ignored_file "$file" && continue
-            [ -f /etc/sysctl.d/${file##*/} ] && continue
-            test -f "$file" && sysctl -e -p "$file" >/dev/null 2>&1
-        done
-        for file in /etc/sysctl.d/*.conf ; do
-            is_ignored_file "$file" && continue
-            test -f "$file" && sysctl -e -p "$file" >/dev/null 2>&1
-        done
-        sysctl -e -p /etc/sysctl.conf >/dev/null 2>&1
-    fi
-}
-
-# A sed expression to filter out the files that is_ignored_file recognizes
-__sed_discard_ignored_files='/\(~\|\.bak\|\.orig\|\.rpmnew\|\.rpmorig\|\.rpmsave\)$/d'
-
-if [ "$_use_systemctl" = "1" ]; then
-        if  [ "x$1" = xstart -o \
-              "x$1" = xstop -o \
-              "x$1" = xrestart -o \
-              "x$1" = xreload -o \
-              "x$1" = xtry-restart -o \
-              "x$1" = xforce-reload -o \
-              "x$1" = xcondrestart ] ; then
-
-        systemctl_redirect $0 $1
-        exit $?
-    fi
-fi
-
-strstr "$(cat /proc/cmdline)" "rc.debug" && set -x
-return 0
-
diff --git a/cache-config/testing/docker/traffic_vault/poststart.d/00-enable-security.sh b/cache-config/testing/docker/traffic_vault/poststart.d/00-enable-security.sh
deleted file mode 100755
index 8a96dae..0000000
--- a/cache-config/testing/docker/traffic_vault/poststart.d/00-enable-security.sh
+++ /dev/null
@@ -1,48 +0,0 @@
-#!/bin/bash 
-# 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.
-set -x 
-
-# The following environment variables are required, see 'riak-cluster.sh':
-# RIAK_ADMIN
-
-# The following environment variables are required, see 'variables.env':
-# TV_ADMIN_USER
-# TV_ADMIN_PASSWORD
-# TV_RIAK_USER
-# TV_RIAK_PASSWORD
-
-# Enable Security
-$RIAK_ADMIN security enable
-$RIAK_ADMIN security add-group admins
-$RIAK_ADMIN security add-group keysusers
-
-# Add users
-$RIAK_ADMIN security add-user "$TV_ADMIN_USER" password="$TV_ADMIN_PASSWORD" groups=admins
-$RIAK_ADMIN security add-user "$TV_RIAK_USER" password="$TV_RIAK_PASSWORD" groups=keysusers
-$RIAK_ADMIN security add-source "$TV_ADMIN_USER" 0.0.0.0/0 password
-$RIAK_ADMIN security add-source "$TV_RIAK_USER" 0.0.0.0/0 password
-
-# Grant privs to admins for everything
-$RIAK_ADMIN security grant riak_kv.list_buckets,riak_kv.list_keys,riak_kv.get,riak_kv.put,riak_kv.delete on any to admins
-
-# Grant privs to keysuser for ssl, dnssec, and url_sig_keys buckets only
-$RIAK_ADMIN security grant riak_kv.get,riak_kv.put,riak_kv.delete on default ssl to keysusers
-$RIAK_ADMIN security grant riak_kv.get,riak_kv.put,riak_kv.delete on default dnssec to keysusers
-$RIAK_ADMIN security grant riak_kv.get,riak_kv.put,riak_kv.delete on default url_sig_keys to keysusers
-$RIAK_ADMIN security grant riak_kv.get,riak_kv.put,riak_kv.delete on default cdn_uri_sig_keys  to keysusers
-
diff --git a/cache-config/testing/docker/traffic_vault/poststart.d/01-add-search-group.sh b/cache-config/testing/docker/traffic_vault/poststart.d/01-add-search-group.sh
deleted file mode 100755
index dfd2093..0000000
--- a/cache-config/testing/docker/traffic_vault/poststart.d/01-add-search-group.sh
+++ /dev/null
@@ -1,27 +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.
-
-# The following environment variables are required, see 'riak-cluster.sh'
-# RIAK_ADMIN
-
-$RIAK_ADMIN security grant search.admin on schema to admin
-$RIAK_ADMIN security grant search.admin on index to admin
-$RIAK_ADMIN security grant search.query on index to admin
-$RIAK_ADMIN security grant search.query on index sslkeys to admin
-$RIAK_ADMIN security grant search.query on index to riakuser
-$RIAK_ADMIN security grant search.query on index sslkeys to riakuser
-$RIAK_ADMIN security grant riak_core.set_bucket on any to admin
diff --git a/cache-config/testing/docker/traffic_vault/poststart.d/02-add-search-schema.sh b/cache-config/testing/docker/traffic_vault/poststart.d/02-add-search-schema.sh
deleted file mode 100755
index 8d44e6d..0000000
--- a/cache-config/testing/docker/traffic_vault/poststart.d/02-add-search-schema.sh
+++ /dev/null
@@ -1,29 +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.
-
-# The following environment variables are required, see 'variables.env':
-# TV_ADMIN_USER
-# TV_ADMIN_PASSWORD
-# TV_FQDN
-# TV_HTTPS_PORT
-
-curl -kvs -XPUT -H 'Content-Type:application/xml' "https://$TV_ADMIN_USER:$TV_ADMIN_PASSWORD@$TV_FQDN:$TV_HTTPS_PORT/search/schema/sslkeys" -d @/sslkeys.xml 
-
-curl -kvs -XPUT -H 'Content-Type:application/json' "https://$TV_ADMIN_USER:$TV_ADMIN_PASSWORD@$TV_FQDN:$TV_HTTPS_PORT/search/index/sslkeys" -d '{"schema":"sslkeys"}'
-
-curl -kvs -XPUT -H 'Content-Type:application/json' "https://$TV_ADMIN_USER:$TV_ADMIN_PASSWORD@$TV_FQDN:$TV_HTTPS_PORT/buckets/ssl/props" -d'{"props":{"search_index":"sslkeys"}}'
-
diff --git a/cache-config/testing/docker/traffic_vault/prestart.d/00-config.sh b/cache-config/testing/docker/traffic_vault/prestart.d/00-config.sh
deleted file mode 100755
index cc4c9f2..0000000
--- a/cache-config/testing/docker/traffic_vault/prestart.d/00-config.sh
+++ /dev/null
@@ -1,40 +0,0 @@
-#!/bin/bash
-# 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.
-
-# The following environment variables must be set, see 'variables.env'
-# CERT_CITY
-# CERT_COMPANY
-# CERT_COUNTRY
-# CERT_STATE
-
-# Set the Riak certs in the config (this cert+key will be created in the run.sh script
-sed -i -- 's/## ssl.certfile = $(platform_etc_dir)\/cert.pem/ssl.certfile = \/etc\/riak\/certs\/server.crt/g' /etc/riak/riak.conf
-sed -i -- 's/## ssl.keyfile = $(platform_etc_dir)\/key.pem/ssl.keyfile = \/etc\/riak\/certs\/server.key/g' /etc/riak/riak.conf
-sed -i -- 's/## ssl.cacertfile = $(platform_etc_dir)\/cacertfile.pem/ssl.cacertfile = \/etc\/riak\/certs\/ca-bundle.crt/g' /etc/riak/riak.conf
-sed -i -- "s/nodename = riak@127.0.0.1/nodename = riak@0.0.0.0/g" /etc/riak/riak.conf
-sed -i -- "s/listener.http.internal = 127.0.0.1:8098/listener.http.internal = 0.0.0.0:8098/g" /etc/riak/riak.conf
-sed -i -- "s/listener.protobuf.internal = 127.0.0.1:8087/listener.protobuf.internal = 0.0.0.0:8087/g" /etc/riak/riak.conf
-sed -i -- "s/## listener.https.internal = 127.0.0.1:8098/listener.https.internal = 0.0.0.0:8088/g" /etc/riak/riak.conf
-sed -i -- "s/search = off/search = on/g" /etc/riak/riak.conf
-
-echo "tls_protocols.tlsv1.1 = on" >> /etc/riak/riak.conf
-
-mkdir /etc/riak/certs
-
-openssl req -newkey rsa:2048 -nodes -keyout /etc/riak/certs/server.key -x509 -days 365 -out /etc/riak/certs/server.crt -subj "/C=$CERT_COUNTRY/ST=$CERT_STATE/L=$CERT_CITY/O=$CERT_COMPANY"
-cp /etc/riak/certs/server.crt /etc/riak/certs/ca-bundle.crt
diff --git a/cache-config/testing/docker/traffic_vault/run.sh b/cache-config/testing/docker/traffic_vault/run.sh
deleted file mode 100755
index aa6c7e4..0000000
--- a/cache-config/testing/docker/traffic_vault/run.sh
+++ /dev/null
@@ -1,39 +0,0 @@
-#!/bin/bash
-# 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.
-
-# Script for running the Dockerfile for Traffic Vault.
-# The Dockerfile sets up a Docker image which can be used for any new container;
-# This script, which should be run when the container is run (it's the ENTRYPOINT), will configure the container.
-#
-# The following environment variables must be set (ordinarily by `docker run -e` arguments):
-# TV_ADMIN_PASS
-# RIAK_USER_PASS
-# CERT_COUNTRY
-# CERT_STATE
-# CERT_CITY
-# CERT_COMPANY
-# TO_URI
-# TO_USER
-# TO_PASS
-# TV_DOMAIN
-# IP
-# GATEWAY
-# CREATE_TO_DB_ENTRY (If set to yes, create the TO db entry for this server if set to no, assume it it already there)
-
-/usr/lib/riak/riak-cluster.sh
-
diff --git a/cache-config/testing/docker/traffic_vault/sslkeys.xml b/cache-config/testing/docker/traffic_vault/sslkeys.xml
deleted file mode 100644
index 245b8bc..0000000
--- a/cache-config/testing/docker/traffic_vault/sslkeys.xml
+++ /dev/null
@@ -1,55 +0,0 @@
-<?xml version="1.0" encoding="UTF-8" ?>
-
-<!--
-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.
--->
-
-<schema name="schedule" version="1.5">
- <fields>
-   <field name="cdn"   type="string"  indexed="true" stored="true" />
-   <field name="deliveryservice"   type="string"  indexed="true" stored="true" />
-   <field name="hostname"    type="string"     indexed="true" stored="true" />
-   <field name="certificate.crt" type="string" indexed="false" stored="true" />
-   <field name="certificate.key" type="string" indexed="false" stored="true" />
-
-   <!-- All of these fields are required by Riak Search -->
-   <field name="_yz_id"   type="_yz_str" indexed="true" stored="true"  multiValued="false" required="true"/>
-   <field name="_yz_ed"   type="_yz_str" indexed="true" stored="false" multiValued="false"/>
-   <field name="_yz_pn"   type="_yz_str" indexed="true" stored="false" multiValued="false"/>
-   <field name="_yz_fpn"  type="_yz_str" indexed="true" stored="false" multiValued="false"/>
-   <field name="_yz_vtag" type="_yz_str" indexed="true" stored="false" multiValued="false"/>
-   <field name="_yz_rk"   type="_yz_str" indexed="true" stored="true"  multiValued="false"/>
-   <field name="_yz_rt"   type="_yz_str" indexed="true" stored="true"  multiValued="false"/>
-   <field name="_yz_rb"   type="_yz_str" indexed="true" stored="true"  multiValued="false"/>
-   <field name="_yz_err"  type="_yz_str" indexed="true" stored="false" multiValued="false"/>
-
-   <!--catch all field-->
-   <dynamicField name="*" type="ignored"  />
-
- </fields>
-
- <uniqueKey>_yz_id</uniqueKey>
-
- <types>
-    <fieldType name="string" class="solr.StrField" sortMissingLast="true" />
-    <!-- YZ String: Used for non-analyzed fields -->
-    <fieldType name="_yz_str" class="solr.StrField" sortMissingLast="true" />
-    <!-- Used for the catch all field -->
-    <fieldtype name="ignored" stored="false" indexed="false" multiValued="true" class="solr.StrField" />
- </types>
-</schema>
diff --git a/cache-config/testing/docker/variables.env b/cache-config/testing/docker/variables.env
index 7493fb8..dba5e97 100644
--- a/cache-config/testing/docker/variables.env
+++ b/cache-config/testing/docker/variables.env
@@ -40,23 +40,21 @@ LOG_ERROR=/var/log/traffic_ops/error.log
 LOG_EVENT=/var/log/traffic_ops/event.log
 LOG_INFO=/var/log/traffic_ops/info.log
 LOG_WARN=/var/log/traffic_ops/warn
-RIAK_USER_PASS=tvsecret
-RIAKCONF=/opt/traffic_ops/app/conf/production/riak.conf
 TO_ADMIN_USER=admin
 TO_ADMIN_PASS=twelve
 TO_HOSTNAME=to_server
 TO_LOG=/var/log/traffic_ops/traffic_ops.log
 TO_DOMAIN=trafficops_default
 TO_URI=https://to_server:443
-TV_ADMIN_USER=admin
-TV_ADMIN_PASSWORD=tvsecret
-TV_FQDN=localhost
+TV_AES_KEY_LOCATION=/opt/traffic_ops/app/conf/aes.key
+TVCONF=/opt/traffic_ops/app/db/trafficvault/dbconf.yml
+TV_DB_NAME=traffic_vault
+TV_SERVER=db
+TV_PORT=5432
+TV_USER=traffic_vault
+TV_USER_PASS=twelve
 X509_CA_PERSIST_DIR=/ca
 X509_CA_PERSIST_ENV_FILE=/ca/environment
-TV_HTTPS_PORT=8088
-TV_RIAK_USER=riakuser
-TV_RIAK_PASSWORD=tvsecret
-TV_DOMAIN=local
 # trafficserver build variables
 ATS_VERSION=8.1.x
 CJOSE_URL=https://github.com/cisco/cjose