code
stringlengths 0
56.1M
| repo_name
stringclasses 515
values | path
stringlengths 2
147
| language
stringclasses 447
values | license
stringclasses 7
values | size
int64 0
56.8M
|
---|---|---|---|---|---|
/*
Copyright 2022 The Dapr Authors
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.
*/
import http from 'k6/http'
import { check } from 'k6'
import exec from 'k6/execution'
import { SharedArray } from 'k6/data'
const defaultMethod = 'default'
const actorsTypes = __ENV.ACTORS_TYPES
const actors = new SharedArray('actors types', function () {
return actorsTypes.split(',')
})
export const options = {
discardResponseBodies: true,
thresholds: {
checks: ['rate==1'],
http_req_duration: ['p(95)<90'], // 95% of requests should be below 90ms
},
scenarios: {
idStress: {
executor: 'ramping-vus',
startVUs: 0,
stages: [
{ duration: '2s', target: 100 },
{ duration: '2s', target: 300 },
{ duration: '4s', target: 500 },
],
gracefulRampDown: '0s',
},
},
}
const DAPR_ADDRESS = `http://127.0.0.1:${__ENV.DAPR_HTTP_PORT}/v1.0`
function callActorMethod(actor, id, method) {
return http.put(
`${DAPR_ADDRESS}/actors/${actor}/${id}/method/${method}`,
JSON.stringify({})
)
}
export default function () {
const result = callActorMethod(
actors[exec.scenario.iterationInTest % actors.length],
exec.scenario.iterationInTest,
defaultMethod
)
check(result, {
'response code was 2xx': (result) =>
result.status >= 200 && result.status < 300,
})
}
export function teardown(_) {
const shutdownResult = http.post(`${DAPR_ADDRESS}/shutdown`)
check(shutdownResult, {
'shutdown response status code is 2xx':
shutdownResult.status >= 200 && shutdownResult.status < 300,
})
}
export function handleSummary(data) {
return {
stdout: JSON.stringify(data),
}
}
|
mikeee/dapr
|
tests/perf/actor_type_scale/test.js
|
JavaScript
|
mit
| 2,306 |
//go:build perf
// +build perf
/*
Copyright 2023 The Dapr Authors
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.
*/
package configuration
import (
"encoding/json"
"fmt"
"os"
"strconv"
"testing"
"github.com/dapr/dapr/tests/perf/utils"
kube "github.com/dapr/dapr/tests/platforms/kubernetes"
"github.com/dapr/dapr/tests/runner"
"github.com/dapr/dapr/tests/runner/loadtest"
"github.com/dapr/dapr/tests/runner/summary"
"github.com/stretchr/testify/require"
)
var (
tr *runner.TestRunner
)
const (
numHealthChecks = 60 // Number of times to check for endpoint health per app.
defaultConfigGetThresholdMs = 60
defaultConfigSubscribeThresholdMs = 350
testAppName = "configurationapp"
)
type Item struct {
Value string `json:"value,omitempty"`
Version string `json:"version,omitempty"`
Metadata map[string]string `json:"metadata,omitempty"`
}
type appResponse struct {
Message string `json:"message,omitempty"`
StartTime int `json:"start_time,omitempty"`
EndTime int `json:"end_time,omitempty"`
}
func TestMain(m *testing.M) {
utils.SetupLogs("configuration_test")
testApps := []kube.AppDescription{
{
AppName: testAppName,
DaprEnabled: true,
ImageName: "perf-configuration",
Replicas: 1,
IngressEnabled: true,
MetricsEnabled: true,
DaprMemoryLimit: "200Mi",
DaprMemoryRequest: "100Mi",
AppMemoryLimit: "200Mi",
AppMemoryRequest: "100Mi",
},
}
tr = runner.NewTestRunner("configuration_http_test", testApps, nil, nil)
os.Exit(tr.Start(m))
}
func runk6test(t *testing.T, targetURL string, payload []byte, threshold int) *loadtest.K6RunnerMetricsSummary {
k6Test := loadtest.NewK6(
"./test.js",
loadtest.WithParallelism(1),
// loadtest.EnableLog(), // uncomment this to enable k6 logs, this however breaks reporting, only for debugging.
loadtest.WithRunnerEnvVar("TARGET_URL", targetURL),
loadtest.WithRunnerEnvVar("PAYLOAD", string(payload)),
loadtest.WithRunnerEnvVar("HTTP_REQ_DURATION_THRESHOLD", strconv.Itoa(threshold)),
)
defer k6Test.Dispose()
t.Log("running the k6 load test...")
require.NoError(t, tr.Platform.LoadTest(k6Test))
sm, err := loadtest.K6ResultDefault(k6Test)
require.NoError(t, err)
require.NotNil(t, sm)
bts, err := json.MarshalIndent(sm, "", " ")
require.NoError(t, err)
require.True(t, sm.Pass, fmt.Sprintf("test has not passed, results %s", string(bts)))
t.Logf("test summary `%s`", string(bts))
return sm.RunnersResults[0]
}
func subscribeTest(t *testing.T, externalURL string, test string, protocol string) *loadtest.K6RunnerMetricsSummary {
var appResp appResponse
items := map[string]*Item{
"key1": {
Value: "val1",
},
}
// Subscribe to key `key1` in config store
subscribeURL := fmt.Sprintf("http://%s/subscribe/%s/%s", externalURL, test, protocol)
payload, _ := json.Marshal([]string{"key1"})
resp, err := utils.HTTPPost(subscribeURL, payload)
err = json.Unmarshal(resp, &appResp)
require.NoError(t, err, "error unmarshalling response")
subscriptionID := appResp.Message
require.NoError(t, err, "error subscribing to configuration")
// Update a key and wait for subscriber to receive update
targetURL := fmt.Sprintf("http://%s/update/true", externalURL)
payload, _ = json.Marshal(items)
testResult := runk6test(t, targetURL, payload, defaultConfigSubscribeThresholdMs)
// Unsubscribe from key `key1` in config store
unsubscribeURL := fmt.Sprintf("http://%s/unsubscribe/%s/%s/%s", externalURL, test, protocol, string(subscriptionID))
_, err = utils.HTTPGet(unsubscribeURL)
require.NoError(t, err, "error unsubscribing from configuration")
return testResult
}
func printLatency(t *testing.T, testName string, baselineResult, daprResult *loadtest.K6RunnerMetricsSummary) {
dapr95latency := daprResult.HTTPReqDuration.Values.P95
baseline95latency := baselineResult.HTTPReqDuration.Values.P95
percentageIncrease := (dapr95latency - baseline95latency) / baseline95latency * 100
t.Logf("dapr p95 latency: %.2fms, baseline p95 latency: %.2fms", dapr95latency, baseline95latency)
t.Logf("added p95 latency: %.2fms(%.2f%%)", dapr95latency-baseline95latency, percentageIncrease)
dapravglatency := daprResult.HTTPReqDuration.Values.Avg
baselineavglatency := baselineResult.HTTPReqDuration.Values.Avg
percentageIncrease = (dapravglatency - baselineavglatency) / baselineavglatency * 100
t.Logf("dapr avg latency: %.2fms, baseline avg latency: %.2fms", dapravglatency, baselineavglatency)
t.Logf("added avg latency: %.2fms(%.2f%%)", dapravglatency-baselineavglatency, percentageIncrease)
appUsage, err := tr.Platform.GetAppUsage(testAppName)
require.NoError(t, err)
sidecarUsage, err := tr.Platform.GetSidecarUsage(testAppName)
require.NoError(t, err)
restarts, err := tr.Platform.GetTotalRestarts(testAppName)
require.NoError(t, err)
summary.ForTest(t).
Service(testName).
CPU(appUsage.CPUm).
Memory(appUsage.MemoryMb).
SidecarCPU(sidecarUsage.CPUm).
SidecarMemory(sidecarUsage.MemoryMb).
Restarts(restarts).
BaselineLatency(baselineavglatency).
DaprLatency(dapravglatency).
AddedLatency(dapravglatency - baselineavglatency).
OutputK6([]*loadtest.K6RunnerMetricsSummary{daprResult}).
Flush()
}
func TestConfigurationGetHTTPPerformance(t *testing.T) {
// Get the ingress external url of test app
externalURL := tr.Platform.AcquireAppExternalURL(testAppName)
require.NotEmpty(t, externalURL, "external URL must not be empty")
// Check if test app endpoint is available
_, err := utils.HTTPGetNTimes(externalURL, numHealthChecks)
require.NoError(t, err)
// Initialize the configuration updater
url := fmt.Sprintf("http://%s/initialize-updater", externalURL)
_, err = utils.HTTPGet(url)
require.NoError(t, err, "error initializing configuration updater")
// Add a key to the configuration store
items := map[string]*Item{
"key1": {
Value: "val1",
},
}
updateURL := fmt.Sprintf("http://%s/update/false", externalURL)
payload, _ := json.Marshal(items)
_, err = utils.HTTPPost(updateURL, payload)
require.NoError(t, err, "error adding key1 to store")
payload, _ = json.Marshal([]string{"key1"})
t.Logf("running baseline test")
targetURL := fmt.Sprintf("http://%s/get/baseline/http", externalURL)
baselineResult := runk6test(t, targetURL, payload, defaultConfigGetThresholdMs)
t.Logf("running dapr test")
targetURL = fmt.Sprintf("http://%s/get/dapr/http", externalURL)
daprResult := runk6test(t, targetURL, payload, defaultConfigGetThresholdMs)
printLatency(t, "perf-configuration-get-http", baselineResult, daprResult)
}
func TestConfigurationGetGRPCPerformance(t *testing.T) {
// Get the ingress external url of test app
externalURL := tr.Platform.AcquireAppExternalURL(testAppName)
require.NotEmpty(t, externalURL, "external URL must not be empty")
// Check if test app endpoint is available
_, err := utils.HTTPGetNTimes(externalURL, numHealthChecks)
require.NoError(t, err)
// Initialize the configuration updater
url := fmt.Sprintf("http://%s/initialize-updater", externalURL)
_, err = utils.HTTPGet(url)
require.NoError(t, err, "error initializing configuration updater")
// Add a key to the configuration store
items := map[string]*Item{
"key1": {
Value: "val1",
},
}
updateURL := fmt.Sprintf("http://%s/update/false", externalURL)
payload, _ := json.Marshal(items)
_, err = utils.HTTPPost(updateURL, payload)
require.NoError(t, err, "error adding key1 to store")
payload, _ = json.Marshal([]string{"key1"})
t.Logf("running baseline test")
targetURL := fmt.Sprintf("http://%s/get/baseline/grpc", externalURL)
baselineResult := runk6test(t, targetURL, payload, defaultConfigGetThresholdMs)
t.Logf("running dapr test")
targetURL = fmt.Sprintf("http://%s/get/dapr/grpc", externalURL)
daprResult := runk6test(t, targetURL, payload, defaultConfigGetThresholdMs)
printLatency(t, "perf-configuration-get-grpc", baselineResult, daprResult)
}
func TestConfigurationSubscribeHTTPPerformance(t *testing.T) {
// Get the ingress external url of test app
externalURL := tr.Platform.AcquireAppExternalURL(testAppName)
require.NotEmpty(t, externalURL, "external URL must not be empty")
// Check if test app endpoint is available
_, err := utils.HTTPGetNTimes(externalURL, numHealthChecks)
require.NoError(t, err)
// Initialize the configuration updater
url := fmt.Sprintf("http://%s/initialize-updater", externalURL)
_, err = utils.HTTPGet(url)
require.NoError(t, err, "error initializing configuration updater")
t.Logf("running baseline test")
baselineResult := subscribeTest(t, externalURL, "baseline", "http")
t.Logf("running dapr test")
daprResult := subscribeTest(t, externalURL, "dapr", "http")
printLatency(t, "perf-configuration-subscribe-http", baselineResult, daprResult)
}
func TestConfigurationSubscribeGRPCPerformance(t *testing.T) {
// Get the ingress external url of test app
externalURL := tr.Platform.AcquireAppExternalURL(testAppName)
require.NotEmpty(t, externalURL, "external URL must not be empty")
// Check if test app endpoint is available
_, err := utils.HTTPGetNTimes(externalURL, numHealthChecks)
require.NoError(t, err)
// Initialize the configuration updater
url := fmt.Sprintf("http://%s/initialize-updater", externalURL)
_, err = utils.HTTPGet(url)
require.NoError(t, err, "error initializing configuration updater")
t.Logf("running baseline test")
baselineResult := subscribeTest(t, externalURL, "baseline", "grpc")
t.Logf("running dapr test")
daprResult := subscribeTest(t, externalURL, "dapr", "grpc")
printLatency(t, "perf-configuration-subscribe-grpc", baselineResult, daprResult)
}
|
mikeee/dapr
|
tests/perf/configuration/configuration_test.go
|
GO
|
mit
| 10,209 |
/*
Copyright 2023 The Dapr Authors
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.
*/
import http from 'k6/http'
import { check } from 'k6'
const httpReqDurationThreshold = __ENV.HTTP_REQ_DURATION_THRESHOLD
export const options = {
discardResponseBodies: true,
thresholds: {
checks: ['rate==1'],
// Average of requests should be below HTTP_REQ_DURATION_THRESHOLD milliseconds
http_req_duration: ['avg<' + httpReqDurationThreshold],
},
scenarios: {
configGet: {
executor: 'ramping-vus',
startVUs: 0,
stages: [
{ duration: '2s', target: 100 },
{ duration: '3s', target: 300 },
{ duration: '4s', target: 500 },
],
gracefulRampDown: '0s',
},
},
}
const DAPR_ADDRESS = `http://127.0.0.1:${__ENV.DAPR_HTTP_PORT}`
function execute() {
return http.post(__ENV.TARGET_URL, __ENV.PAYLOAD, {
headers: { 'Content-Type': 'application/json' },
})
}
export default function () {
let result = execute()
console.log(result.json())
check(result, {
'response code was 2xx': (result) =>
result.status >= 200 && result.status < 300,
})
}
export function teardown(_) {
const shutdownResult = http.post(`${DAPR_ADDRESS}/v1.0/shutdown`)
check(shutdownResult, {
'shutdown response status code is 2xx':
shutdownResult.status >= 200 && shutdownResult.status < 300,
})
}
export function handleSummary(data) {
return {
stdout: JSON.stringify(data),
}
}
|
mikeee/dapr
|
tests/perf/configuration/test.js
|
JavaScript
|
mit
| 2,073 |
//go:build perf
// +build perf
/*
Copyright 2022 The Dapr Authors
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.
*/
package pubsub_bulk_publish
import (
"encoding/json"
"fmt"
"os"
"strconv"
"strings"
"testing"
"github.com/stretchr/testify/require"
"github.com/dapr/dapr/tests/perf"
"github.com/dapr/dapr/tests/perf/utils"
kube "github.com/dapr/dapr/tests/platforms/kubernetes"
"github.com/dapr/dapr/tests/runner"
"github.com/dapr/dapr/tests/runner/summary"
)
const (
// Number of times to check for endpoint health per app.
numHealthChecks = 60
numMessagesToPublish = 100
appName = "pubsub-perf-bulk-grpc"
)
var tr *runner.TestRunner
func TestMain(m *testing.M) {
utils.SetupLogs("pubsub_bulk_publish_grpc")
testApps := []kube.AppDescription{
{
AppName: appName,
DaprEnabled: true,
ImageName: "perf-tester",
Replicas: 1,
IngressEnabled: true,
MetricsEnabled: true,
AppPort: 3001,
DaprCPULimit: "4.0",
DaprCPURequest: "0.1",
DaprMemoryLimit: "512Mi",
DaprMemoryRequest: "250Mi",
AppCPULimit: "4.0",
AppCPURequest: "0.1",
AppMemoryLimit: "800Mi",
AppMemoryRequest: "2500Mi",
},
}
tr = runner.NewTestRunner("pubsub_bulk_publish_grpc", testApps, nil, nil)
os.Exit(tr.Start(m))
}
func TestBulkPubsubPublishGrpcPerformance(t *testing.T) {
tcs := []struct {
name string
pubsub string
isRawPayload bool
}{
{
name: "In-memory with with cloud event",
pubsub: "inmemorypubsub",
isRawPayload: false,
},
{
name: "In-memory without cloud event (raw payload)",
pubsub: "inmemorypubsub",
isRawPayload: true,
},
{
name: "Kafka with cloud event",
pubsub: "kafka-messagebus",
isRawPayload: false,
},
{
name: "Kafka without cloud event (raw payload)",
pubsub: "kafka-messagebus",
isRawPayload: true,
},
}
for _, tc := range tcs {
t.Run(tc.name, func(t *testing.T) {
p := perf.Params(
perf.WithQPS(200),
perf.WithConnections(16),
perf.WithDuration("1m"),
perf.WithPayloadSize(1024),
)
t.Logf("running pubsub bulk publish grpc test with params: qps=%v, connections=%v, duration=%s, payload size=%v, payload=%v", p.QPS, p.ClientConnections, p.TestDuration, p.PayloadSizeKB, p.Payload)
// Get the ingress external url of tester app
testerAppURL := tr.Platform.AcquireAppExternalURL(appName)
require.NotEmpty(t, testerAppURL, "tester app external URL must not be empty")
// Check if tester app endpoint is available
t.Logf("tester app url: %s", testerAppURL)
_, err := utils.HTTPGetNTimes(testerAppURL, numHealthChecks)
require.NoError(t, err)
// Perform baseline test - publish messages with individual Publish calls
p.Grpc = true
p.Dapr = fmt.Sprintf("capability=pubsub,target=dapr,method=publish,store=%s,topic=topic123,contenttype=text/plain,numevents=%d,rawpayload=%s", tc.pubsub, numMessagesToPublish, strconv.FormatBool(tc.isRawPayload))
p.TargetEndpoint = fmt.Sprintf("http://localhost:50001")
body, err := json.Marshal(&p)
require.NoError(t, err)
t.Log("running baseline test, publishing messages individually...")
baselineResp, err := utils.HTTPPost(fmt.Sprintf("%s/test", testerAppURL), body)
t.Logf("baseline test results: %s", string(baselineResp))
t.Log("checking err...")
require.NoError(t, err)
require.NotEmpty(t, baselineResp)
// fast fail if daprResp starts with error
require.False(t, strings.HasPrefix(string(baselineResp), "error"))
// Perform bulk test - publish messages with a single BulkPublish call
p.Dapr = fmt.Sprintf("capability=pubsub,target=dapr,method=bulkpublish,store=%s,topic=topic123,contenttype=text/plain,numevents=%d,rawpayload=%s", tc.pubsub, numMessagesToPublish, strconv.FormatBool(tc.isRawPayload))
p.TargetEndpoint = fmt.Sprintf("http://localhost:50001")
body, err = json.Marshal(&p)
require.NoError(t, err)
t.Log("running bulk test, publishing messages with bulk publish...")
bulkResp, err := utils.HTTPPost(fmt.Sprintf("%s/test", testerAppURL), body)
t.Logf("bulk test results: %s", string(bulkResp))
t.Log("checking err...")
require.NoError(t, err)
require.NotEmpty(t, bulkResp)
// fast fail if bulkResp starts with error
require.False(t, strings.HasPrefix(string(bulkResp), "error"))
sidecarUsage, err := tr.Platform.GetSidecarUsage(appName)
require.NoError(t, err)
appUsage, err := tr.Platform.GetAppUsage(appName)
require.NoError(t, err)
restarts, err := tr.Platform.GetTotalRestarts(appName)
require.NoError(t, err)
t.Logf("dapr sidecar consumed %vm Cpu and %vMb of Memory", sidecarUsage.CPUm, sidecarUsage.MemoryMb)
var bulkResult perf.TestResult
err = json.Unmarshal(bulkResp, &bulkResult)
require.NoError(t, err)
var baselineResult perf.TestResult
err = json.Unmarshal(baselineResp, &baselineResult)
require.NoError(t, err)
percentiles := []string{"50th", "75th", "90th", "99th"}
var tp90Latency float64
for k, v := range percentiles {
bulkValue := bulkResult.DurationHistogram.Percentiles[k].Value
baselineValue := baselineResult.DurationHistogram.Percentiles[k].Value
latency := (baselineValue - bulkValue) * 1000
if v == "90th" {
tp90Latency = latency
}
t.Logf("reduced latency for %s percentile: %sms", v, fmt.Sprintf("%.2f", latency))
}
avg := (baselineResult.DurationHistogram.Avg - bulkResult.DurationHistogram.Avg) * 1000
baselineLatency := baselineResult.DurationHistogram.Avg * 1000
bulkLatencyMS := fmt.Sprintf("%.2f", bulkResult.DurationHistogram.Avg*1000)
reducedLatencyMS := fmt.Sprintf("%.2f", avg)
t.Logf("baseline latency avg: %sms", fmt.Sprintf("%.2f", baselineLatency))
t.Logf("bulk latency avg: %sms", bulkLatencyMS)
t.Logf("reduced latency avg: %sms", reducedLatencyMS)
t.Logf("baseline QPS: %v", baselineResult.ActualQPS)
t.Logf("bulk QPS: %v", bulkResult.ActualQPS)
increaseQPS := (bulkResult.ActualQPS - baselineResult.ActualQPS) / baselineResult.ActualQPS * 100
t.Logf("increase in QPS: %v", increaseQPS)
summary.ForTest(t).
Service(appName).
CPU(appUsage.CPUm).
Memory(appUsage.MemoryMb).
SidecarCPU(sidecarUsage.CPUm).
SidecarMemory(sidecarUsage.MemoryMb).
Restarts(restarts).
BaselineLatency(baselineLatency).
Outputf("Bulk latency avg", "%sms", bulkLatencyMS).
Outputf("Reduced latency avg", "%sms", reducedLatencyMS).
OutputFloat64("Baseline QPS", baselineResult.ActualQPS).
OutputFloat64("Increase in QPS", increaseQPS).
ActualQPS(bulkResult.ActualQPS).
Params(p).
OutputFortio(bulkResult).
Flush()
require.Equal(t, 0, bulkResult.RetCodes.Num400)
require.Equal(t, 0, bulkResult.RetCodes.Num500)
require.Equal(t, 0, restarts)
require.True(t, bulkResult.ActualQPS > float64(p.QPS)*0.99)
require.Greater(t, tp90Latency, 0.0)
})
}
}
|
mikeee/dapr
|
tests/perf/pubsub_bulk_publish_grpc/pubsub_bulk_publish_grpc_test.go
|
GO
|
mit
| 7,510 |
//go:build perf
// +build perf
/*
Copyright 2023 The Dapr Authors
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.
*/
package pubsub_bulk_publish_http
import (
"encoding/json"
"fmt"
"os"
"strings"
"testing"
"github.com/dapr/dapr/tests/perf/utils"
kube "github.com/dapr/dapr/tests/platforms/kubernetes"
"github.com/dapr/dapr/tests/runner"
"github.com/dapr/dapr/tests/runner/loadtest"
"github.com/dapr/dapr/tests/runner/summary"
"github.com/stretchr/testify/require"
)
var (
tr *runner.TestRunner
)
const (
k6AppName = "k6-test-app"
topicName = "bulkpublishperftopic"
)
type testCase struct {
broker string
publishType string
topic string
bulkSize int
messageSizeKb int
durationMs int
numVus int
}
var brokers = []kube.ComponentDescription{
{
Name: "memory-broker",
Namespace: &kube.DaprTestNamespace,
TypeName: "pubsub.in-memory",
MetaData: map[string]kube.MetadataValue{},
Scopes: []string{k6AppName},
},
}
var brokersNames string
func init() {
brokersList := []string{}
for _, broker := range brokers {
brokersList = append(brokersList, broker.Name)
}
brokersNames = strings.Join(brokersList, ",")
}
func TestMain(m *testing.M) {
utils.SetupLogs("pubsub_bulk_publish_http_test")
tr = runner.NewTestRunner("pubsub_bulk_publish_http", []kube.AppDescription{}, brokers, nil)
os.Exit(tr.Start(m))
}
// TestPubsubBulkPublishHttpPerformance compares the performance of bulk publish vs normal publish
// for different brokers, bulk sizes and message sizes.
func TestPubsubBulkPublishHttpPerformance(t *testing.T) {
publishTypes := []string{"normal", "bulk"}
bulkSizes := []int{10, 100}
messageSizesKb := []int{1}
testcases := []testCase{}
for _, bulkSize := range bulkSizes {
for _, messageSizeKb := range messageSizesKb {
for _, broker := range brokers {
for _, publishType := range publishTypes {
testcases = append(testcases, testCase{
broker: broker.Name,
publishType: publishType,
topic: topicName,
bulkSize: bulkSize,
messageSizeKb: messageSizeKb,
durationMs: 30 * 1000,
numVus: 50,
})
}
}
}
}
for _, tc := range testcases {
testName := fmt.Sprintf("%s_b%d_s%dKB_%s", tc.broker, tc.bulkSize, tc.messageSizeKb, tc.publishType)
t.Run(testName, func(t *testing.T) {
runTest(t, tc)
})
}
}
func runTest(t *testing.T, tc testCase) {
t.Logf("Starting test: %s", t.Name())
k6Test := loadtest.NewK6(
"./test.js",
// loadtest.EnableLog(), // uncomment this to enable k6 logs, this however breaks reporting, only for debugging.
loadtest.WithAppID(k6AppName),
loadtest.WithName(k6AppName),
loadtest.WithRunnerEnvVar("PUBLISH_TYPE", tc.publishType),
loadtest.WithRunnerEnvVar("BROKER_NAME", tc.broker),
loadtest.WithRunnerEnvVar("TOPIC_NAME", tc.topic),
loadtest.WithRunnerEnvVar("BULK_SIZE", fmt.Sprintf("%d", tc.bulkSize)),
loadtest.WithRunnerEnvVar("MESSAGE_SIZE_KB", fmt.Sprintf("%d", tc.messageSizeKb)),
loadtest.WithRunnerEnvVar("DURATION_MS", fmt.Sprintf("%d", tc.durationMs)),
loadtest.WithRunnerEnvVar("NUM_VUS", fmt.Sprintf("%d", tc.numVus)),
)
defer k6Test.Dispose()
t.Log("running the k6 load test...")
require.NoError(t, tr.Platform.LoadTest(k6Test))
sm, err := loadtest.K6ResultDefault(k6Test)
require.NoError(t, err)
require.NotNil(t, sm)
summary.ForTest(t).
OutputK6(sm.RunnersResults).
Output("Broker", tc.broker).
Output("PublishType", tc.publishType).
Output("BulkSize", fmt.Sprintf("%d", tc.bulkSize)).
Output("MessageSizeKb", fmt.Sprintf("%d", tc.messageSizeKb)).
Flush()
bts, err := json.MarshalIndent(sm, "", " ")
require.NoError(t, err)
require.True(t, sm.Pass, fmt.Sprintf("test has not passed, results %s", string(bts)))
t.Logf("test summary `%s`", string(bts))
}
|
mikeee/dapr
|
tests/perf/pubsub_bulk_publish_http/pubsub_bulk_publish_http_test.go
|
GO
|
mit
| 4,321 |
/*
Copyright 2023 The Dapr Authors
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.
*/
import http from 'k6/http'
import { check } from 'k6'
import crypto from 'k6/crypto'
import { SharedArray } from 'k6/data'
const PUBLISH_TYPE_BULK = 'bulk'
const KB = 1024
const MAX_MS_ALLOWED = 500
// padd with leading 0 if <16
function i2hex(i) {
return ('0' + i.toString(16)).slice(-2)
}
function randomStringOfSize(size) {
const bytes = crypto.randomBytes(Math.round(size / 2)) // because of hex transformation
const view = new Uint8Array(bytes)
return view.reduce(function (memo, i) {
return memo + i2hex(i)
}, '')
}
/**
* Get the payload for a bulk publish request
* @param {number} numMsgs number of messages to publish at once
* @param {number} msgSize size of each message in KB
*/
function getBulkPublishPayload(numMsgs, msgSize) {
const entries = []
for (let i = 0; i < numMsgs; i++) {
const entry = {
entryId: `${i}`,
event: randomStringOfSize(msgSize * KB),
contentType: 'text/plain',
}
entries.push(entry)
}
return JSON.stringify(entries)
}
const data = new SharedArray('scenarios', function () {
let scenarios = {}
const thresholds = {
checks: ['rate==1'],
http_req_duration: [`avg<${MAX_MS_ALLOWED}`],
}
const brokerName = __ENV.BROKER_NAME
const publishType = __ENV.PUBLISH_TYPE
const bulkSize = parseInt(__ENV.BULK_SIZE)
const messageSizeKb = parseInt(__ENV.MESSAGE_SIZE_KB)
const durationMs = parseInt(__ENV.DURATION_MS)
const numVus = parseInt(__ENV.NUM_VUS)
let payload = ''
if (publishType == PUBLISH_TYPE_BULK) {
payload = getBulkPublishPayload(bulkSize, messageSizeKb)
} else {
payload = randomStringOfSize(messageSizeKb * KB)
}
const scenario = `${brokerName}_b${bulkSize}_s${messageSizeKb}KB_${publishType}`
scenarios[scenario] = Object.assign({
executor: 'constant-vus',
vus: numVus,
duration: `${durationMs}ms`,
env: {
PAYLOAD: payload,
},
})
return [{ scenarios, thresholds }] // must be an array
})
const { scenarios, thresholds } = data[0]
export const options = {
discardResponseBodies: true,
thresholds,
scenarios,
}
const DAPR_ADDRESS = `http://127.0.0.1:${__ENV.DAPR_HTTP_PORT}`
function bulkPublishRawMsgs(broker, topic, payload) {
const result = http.post(
`${DAPR_ADDRESS}/v1.0-alpha1/publish/bulk/${broker}/${topic}?metadata.rawPayload=true`,
payload
)
return result.status
}
function publishRawMsgs(broker, topic, payload, bulkSize) {
const statusCodes = []
for (let i = 0; i < bulkSize; i++) {
const result = http.post(
`${DAPR_ADDRESS}/v1.0/publish/${broker}/${topic}?metadata.rawPayload=true`,
payload
)
statusCodes.push(result.status)
}
return statusCodes
}
export default function () {
const publishType = __ENV.PUBLISH_TYPE
const statusCodes = []
if (publishType == PUBLISH_TYPE_BULK) {
// Do bulk publish
const statusCode = bulkPublishRawMsgs(
__ENV.BROKER_NAME,
__ENV.TOPIC_NAME,
__ENV.PAYLOAD
)
statusCodes.push(statusCode)
} else {
// Do normal publish
const _statusCodes = publishRawMsgs(
__ENV.BROKER_NAME,
__ENV.TOPIC_NAME,
__ENV.PAYLOAD,
__ENV.BULK_SIZE
)
statusCodes.push(..._statusCodes)
}
const failedStatusCodes = statusCodes.filter(
(statusCode) => statusCode < 200 || statusCode >= 300
)
if (failedStatusCodes.length > 0) {
console.log(`Publish failed: ${JSON.stringify(failedStatusCodes)}`)
}
check(failedStatusCodes, {
'publish response status code is 2xx': failedStatusCodes.length == 0,
})
}
export function teardown(_) {
const shutdownResult = http.post(`${DAPR_ADDRESS}/v1.0/shutdown`)
if (shutdownResult.status >= 300) {
console.log(`Shutdown failed: ${shutdownResult.status}`)
}
check(shutdownResult, {
'shutdown response status code is 2xx':
shutdownResult.status >= 200 && shutdownResult.status < 300,
})
}
export function handleSummary(data) {
return {
stdout: JSON.stringify(data),
}
}
|
mikeee/dapr
|
tests/perf/pubsub_bulk_publish_http/test.js
|
JavaScript
|
mit
| 4,882 |
//go:build perf
// +build perf
/*
Copyright 2021 The Dapr Authors
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.
*/
package pubsub_publish
import (
"encoding/json"
"fmt"
"os"
"strings"
"testing"
"github.com/stretchr/testify/require"
"github.com/dapr/dapr/tests/perf"
"github.com/dapr/dapr/tests/perf/utils"
kube "github.com/dapr/dapr/tests/platforms/kubernetes"
"github.com/dapr/dapr/tests/runner"
"github.com/dapr/dapr/tests/runner/summary"
)
const (
// Number of times to check for endpoint health per app.
numHealthChecks = 60
appName = "pubsub-perf-grpc"
)
var tr *runner.TestRunner
func TestMain(m *testing.M) {
utils.SetupLogs("pubsub_publish_grpc")
testApps := []kube.AppDescription{
{
AppName: appName,
DaprEnabled: true,
ImageName: "perf-tester",
Replicas: 1,
IngressEnabled: true,
MetricsEnabled: true,
AppPort: 3001,
DaprCPULimit: "4.0",
DaprCPURequest: "0.1",
DaprMemoryLimit: "512Mi",
DaprMemoryRequest: "250Mi",
AppCPULimit: "4.0",
AppCPURequest: "0.1",
AppMemoryLimit: "800Mi",
AppMemoryRequest: "2500Mi",
},
}
tr = runner.NewTestRunner("pubsub_publish_grpc", testApps, nil, nil)
os.Exit(tr.Start(m))
}
func TestPubsubPublishGrpcPerformance(t *testing.T) {
p := perf.Params(
perf.WithQPS(1000),
perf.WithConnections(16),
perf.WithDuration("1m"),
perf.WithPayloadSize(0),
)
t.Logf("running pubsub publish grpc test with params: qps=%v, connections=%v, duration=%s, payload size=%v, payload=%v", p.QPS, p.ClientConnections, p.TestDuration, p.PayloadSizeKB, p.Payload)
// Get the ingress external url of tester app
testerAppURL := tr.Platform.AcquireAppExternalURL(appName)
require.NotEmpty(t, testerAppURL, "tester app external URL must not be empty")
// Check if tester app endpoint is available
t.Logf("tester app url: %s", testerAppURL)
_, err := utils.HTTPGetNTimes(testerAppURL, numHealthChecks)
require.NoError(t, err)
// Perform baseline test
p.Grpc = true
p.Dapr = "capability=pubsub,target=noop"
p.TargetEndpoint = fmt.Sprintf("http://localhost:50001")
body, err := json.Marshal(&p)
require.NoError(t, err)
t.Log("running baseline test...")
baselineResp, err := utils.HTTPPost(fmt.Sprintf("%s/test", testerAppURL), body)
t.Logf("baseline test results: %s", string(baselineResp))
t.Log("checking err...")
require.NoError(t, err)
require.NotEmpty(t, baselineResp)
// fast fail if daprResp starts with error
require.False(t, strings.HasPrefix(string(baselineResp), "error"))
// Perform dapr test
p.Dapr = "capability=pubsub,target=dapr,method=publish,store=inmemorypubsub,topic=topic123,contenttype=text/plain"
p.TargetEndpoint = fmt.Sprintf("http://localhost:50001")
body, err = json.Marshal(&p)
require.NoError(t, err)
t.Log("running dapr test...")
daprResp, err := utils.HTTPPost(fmt.Sprintf("%s/test", testerAppURL), body)
t.Logf("dapr test results: %s", string(daprResp))
t.Log("checking err...")
require.NoError(t, err)
require.NotEmpty(t, daprResp)
// fast fail if daprResp starts with error
require.False(t, strings.HasPrefix(string(daprResp), "error"))
sidecarUsage, err := tr.Platform.GetSidecarUsage(appName)
require.NoError(t, err)
appUsage, err := tr.Platform.GetAppUsage(appName)
require.NoError(t, err)
restarts, err := tr.Platform.GetTotalRestarts(appName)
require.NoError(t, err)
t.Logf("dapr sidecar consumed %vm Cpu and %vMb of Memory", sidecarUsage.CPUm, sidecarUsage.MemoryMb)
var daprResult perf.TestResult
err = json.Unmarshal(daprResp, &daprResult)
require.NoError(t, err)
var baselineResult perf.TestResult
err = json.Unmarshal(baselineResp, &baselineResult)
require.NoError(t, err)
percentiles := []string{"50th", "75th", "90th", "99th"}
var tp90Latency float64
for k, v := range percentiles {
daprValue := daprResult.DurationHistogram.Percentiles[k].Value
baselineValue := baselineResult.DurationHistogram.Percentiles[k].Value
latency := (daprValue - baselineValue) * 1000
if v == "90th" {
tp90Latency = latency
}
t.Logf("added latency for %s percentile: %sms", v, fmt.Sprintf("%.2f", latency))
}
avg := (daprResult.DurationHistogram.Avg - baselineResult.DurationHistogram.Avg) * 1000
baselineLatency := baselineResult.DurationHistogram.Avg * 1000
daprLatency := daprResult.DurationHistogram.Avg * 1000
t.Logf("baseline latency avg: %sms", fmt.Sprintf("%.2f", baselineLatency))
t.Logf("dapr latency avg: %sms", fmt.Sprintf("%.2f", daprLatency))
t.Logf("added latency avg: %sms", fmt.Sprintf("%.2f", avg))
summary.ForTest(t).
Service(appName).
CPU(appUsage.CPUm).
Memory(appUsage.MemoryMb).
SidecarCPU(sidecarUsage.CPUm).
SidecarMemory(sidecarUsage.MemoryMb).
Restarts(restarts).
BaselineLatency(baselineLatency).
DaprLatency(daprLatency).
AddedLatency(avg).
ActualQPS(daprResult.ActualQPS).
Params(p).
OutputFortio(daprResult).
Flush()
require.Equal(t, 0, daprResult.RetCodes.Num400)
require.Equal(t, 0, daprResult.RetCodes.Num500)
require.Equal(t, 0, restarts)
require.True(t, daprResult.ActualQPS > float64(p.QPS)*0.99)
require.Greater(t, tp90Latency, 0.0)
require.LessOrEqual(t, tp90Latency, 2.0)
}
|
mikeee/dapr
|
tests/perf/pubsub_publish_grpc/pubsub_publish_grpc_test.go
|
GO
|
mit
| 5,716 |
//go:build perf
// +build perf
/*
Copyright 2022 The Dapr Authors
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.
*/
package pubsub_publish_http
import (
"encoding/json"
"fmt"
"os"
"strings"
"testing"
"github.com/dapr/dapr/tests/perf/utils"
kube "github.com/dapr/dapr/tests/platforms/kubernetes"
"github.com/dapr/dapr/tests/runner"
"github.com/dapr/dapr/tests/runner/loadtest"
"github.com/dapr/dapr/tests/runner/summary"
"github.com/stretchr/testify/require"
)
var (
tr *runner.TestRunner
)
const (
k6AppName = "k6-test-app"
brokersEnvVar = "BROKERS"
)
var brokers = []kube.ComponentDescription{
{
Name: "memory-broker",
Namespace: &kube.DaprTestNamespace,
TypeName: "pubsub.in-memory",
MetaData: map[string]kube.MetadataValue{},
Scopes: []string{k6AppName},
},
}
var brokersNames string
func init() {
brokersList := []string{}
for _, broker := range brokers {
brokersList = append(brokersList, broker.Name)
}
brokersNames = strings.Join(brokersList, ",")
}
func TestMain(m *testing.M) {
utils.SetupLogs("pubsub_publish_http_test")
tr = runner.NewTestRunner("pubsub_publish_http", []kube.AppDescription{}, brokers, nil)
os.Exit(tr.Start(m))
}
func TestPubsubPublishHttpPerformance(t *testing.T) {
k6Test := loadtest.NewK6(
"./test.js",
loadtest.WithAppID(k6AppName),
loadtest.WithName(k6AppName),
loadtest.WithRunnerEnvVar(brokersEnvVar, brokersNames),
)
defer k6Test.Dispose()
t.Log("running the k6 load test...")
require.NoError(t, tr.Platform.LoadTest(k6Test))
sm, err := loadtest.K6ResultDefault(k6Test)
require.NoError(t, err)
require.NotNil(t, sm)
summary.ForTest(t).
OutputK6(sm.RunnersResults).
Flush()
bts, err := json.MarshalIndent(sm, "", " ")
require.NoError(t, err)
require.True(t, sm.Pass, fmt.Sprintf("test has not passed, results %s", string(bts)))
t.Logf("test summary `%s`", string(bts))
}
|
mikeee/dapr
|
tests/perf/pubsub_publish_http/pubsub_publish_http_test.go
|
GO
|
mit
| 2,368 |
/*
Copyright 2022 The Dapr Authors
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.
*/
import http from 'k6/http'
import { check } from 'k6'
import crypto from 'k6/crypto'
import { SharedArray } from 'k6/data'
const KB = 1024
const MAX_MS_ALLOWED = 1
// padd with leading 0 if <16
function i2hex(i) {
return ('0' + i.toString(16)).slice(-2)
}
function randomStringOfSize(size) {
const bytes = crypto.randomBytes(Math.round(size / 2)) // because of hex transformation
const view = new Uint8Array(bytes)
return view.reduce(function (memo, i) {
return memo + i2hex(i)
}, '')
}
const data = new SharedArray('scenarios', function () {
const scenarioBase = {
executor: 'constant-arrival-rate',
rate: 1,
preAllocatedVUs: 2,
maxVUs: 50,
}
const delaysMs = [5, 50, 100, 1000]
const messageSizeKb = [2, 31]
const brokers = __ENV.BROKERS.split(',')
const samples = [200]
let scenarios = {}
let thresholds = {
checks: ['rate==1'],
}
let startTime = 0
for (const messageSizeKbIdx in messageSizeKb) {
const msgSize = messageSizeKb[messageSizeKbIdx]
const msgStr = randomStringOfSize(msgSize * KB)
for (const delayMsIdx in delaysMs) {
const delay = delaysMs[delayMsIdx]
for (const brokerIdx in brokers) {
const broker = brokers[brokerIdx]
for (const sampleIdx in samples) {
const sample = samples[sampleIdx]
const scenario = `${delay}ms_${msgSize}kb_${broker}_${sample}`
thresholds[`http_req_duration{scenario:${scenario}}`] = [
`avg<${MAX_MS_ALLOWED}`,
]
const duration = delay * sample
scenarios[scenario] = Object.assign(
{
timeUnit: `${delay}ms`,
duration: `${duration}ms`,
env: {
MSG: msgStr,
BROKER: broker,
TOPIC: 'my-topic',
},
startTime: `${startTime}ms`,
},
scenarioBase
)
startTime += duration
}
}
}
}
// more operations
return [{ scenarios, thresholds }] // must be an array
})
const { scenarios, thresholds } = data[0]
export const options = {
discardResponseBodies: true,
thresholds,
scenarios,
}
const DAPR_ADDRESS = `http://127.0.0.1:${__ENV.DAPR_HTTP_PORT}/v1.0`
function publishRawMsg(broker, topic, msg) {
return http.post(
`${DAPR_ADDRESS}/publish/${broker}/${topic}?metadata.rawPayload=true`,
msg
)
}
export default function () {
const result = publishRawMsg(__ENV.BROKER, __ENV.TOPIC, __ENV.MSG)
check(result, {
'response code was 2xx': (result) =>
result.status >= 200 && result.status < 300,
})
}
export function teardown(_) {
const shutdownResult = http.post(`${DAPR_ADDRESS}/shutdown`)
check(shutdownResult, {
'shutdown response status code is 2xx':
shutdownResult.status >= 200 && shutdownResult.status < 300,
})
}
export function handleSummary(data) {
return {
stdout: JSON.stringify(data),
}
}
|
mikeee/dapr
|
tests/perf/pubsub_publish_http/test.js
|
JavaScript
|
mit
| 3,940 |
//go:build perf
// +build perf
/*
Copyright 2023 The Dapr Authors
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.
*/
package pubsub_subscribe_http
type PubsubComponentConfig struct {
Name string `yaml:"name"`
Components []Component `yaml:"components"`
}
type Component struct {
Name string `yaml:"name"`
Topic string `yaml:"topic"`
Route string `yaml:"route"`
NumHealthChecks int `yaml:"numHealthChecks"`
TestAppName string `yaml:"testAppName"`
TestLabel string `yaml:"testLabel"`
SubscribeHTTPThresholdMs int `yaml:"subscribeHTTPThresholdMs"`
BulkSubscribeHTTPThresholdMs int `yaml:"bulkSubscribeHTTPThresholdMs"`
ImageName string `yaml:"imageName"`
Metadata map[string]string `yaml:"metadata,omitempty"`
Operations []string `yaml:"operations"`
}
|
mikeee/dapr
|
tests/perf/pubsub_subscribe_http/pubsub_component_config.go
|
GO
|
mit
| 1,547 |
//go:build perf
// +build perf
/*
Copyright 2023 The Dapr Authors
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.
*/
package pubsub_subscribe_http
import (
"encoding/json"
"fmt"
"os"
"strconv"
"testing"
"github.com/stretchr/testify/require"
"golang.org/x/exp/slices"
"gopkg.in/yaml.v3"
"github.com/dapr/dapr/tests/perf/utils"
kube "github.com/dapr/dapr/tests/platforms/kubernetes"
"github.com/dapr/dapr/tests/runner"
"github.com/dapr/dapr/tests/runner/loadtest"
"github.com/dapr/dapr/tests/runner/summary"
)
var (
tr *runner.TestRunner
actorsTypes string
configs PubsubComponentConfig
)
const (
testLabel = "pubsub_subscribe_test_label"
normalPubsubType = "normal"
bulkPubsubType = "bulk"
)
func getAppDescription(pubsubComponent Component, pubsubType string) kube.AppDescription {
appDescription := kube.AppDescription{
AppName: pubsubComponent.TestAppName + "-" + pubsubType,
DaprEnabled: true,
ImageName: pubsubComponent.ImageName,
Replicas: 1,
IngressEnabled: true,
MetricsEnabled: true,
AppPort: 3000,
AppProtocol: "http",
DaprCPULimit: "4.0",
DaprCPURequest: "0.1",
DaprMemoryLimit: "512Mi",
DaprMemoryRequest: "250Mi",
AppCPULimit: "4.0",
AppCPURequest: "0.1",
AppMemoryLimit: "800Mi",
AppMemoryRequest: "250Mi",
Labels: map[string]string{
"daprtest": pubsubComponent.TestLabel + "-" + pubsubType,
},
AppEnv: map[string]string{
"PERF_PUBSUB_HTTP_COMPONENT_NAME": pubsubComponent.Name,
"PERF_PUBSUB_HTTP_TOPIC_NAME": pubsubComponent.Topic,
"PERF_PUBSUB_HTTP_ROUTE_NAME": pubsubComponent.Route,
"SUBSCRIBE_TYPE": pubsubType,
},
}
return appDescription
}
func TestMain(m *testing.M) {
utils.SetupLogs(testLabel)
//Read env variable for pubsub test config file, this will decide whether to run single component or all the components.
pubsubTestConfigFileName := os.Getenv("DAPR_PERF_PUBSUB_SUBS_HTTP_TEST_CONFIG_FILE_NAME")
if pubsubTestConfigFileName == "" {
pubsubTestConfigFileName = "test_kafka.yaml"
}
//Read the config file for individual components
data, err := os.ReadFile(pubsubTestConfigFileName)
if err != nil {
fmt.Printf("error reading %v: %v\n", pubsubTestConfigFileName, err)
return
}
fmt.Println("pubsubTestConfigFileName: ", pubsubTestConfigFileName)
err = yaml.Unmarshal(data, &configs)
//set the configuration as environment variables for the test app.
var testApps []kube.AppDescription
for _, pubsubComponent := range configs.Components {
//normal pubsub app
if slices.Contains(pubsubComponent.Operations, normalPubsubType) {
fmt.Println("image used: ", pubsubComponent.ImageName, pubsubComponent.TestAppName, pubsubComponent.Name, normalPubsubType)
testApps = append(testApps, getAppDescription(pubsubComponent, normalPubsubType))
}
//bulk pubsub app
if slices.Contains(pubsubComponent.Operations, bulkPubsubType) {
fmt.Println("image used: ", pubsubComponent.ImageName, pubsubComponent.TestAppName, pubsubComponent.Name, bulkPubsubType)
testApps = append(testApps, getAppDescription(pubsubComponent, bulkPubsubType))
}
}
tr = runner.NewTestRunner(testLabel, testApps, nil, nil)
os.Exit(tr.Start(m))
}
func runTest(t *testing.T, testAppURL, publishType, subscribeType, httpReqDurationThresholdMs string, component Component) {
t.Logf("Starting test with subscribe type %s for component %s", subscribeType, component.Name)
k6Test := loadtest.NewK6("./test.js",
loadtest.WithParallelism(1),
loadtest.WithAppID("k6-tester-pubsub-subscribe-http"),
//loadtest.EnableLog(), // uncomment this to enable k6 logs, this however breaks reporting, only for debugging.
loadtest.WithRunnerEnvVar("TARGET_URL", testAppURL),
loadtest.WithRunnerEnvVar("PUBSUB_NAME", component.Name),
loadtest.WithRunnerEnvVar("PUBLISH_TYPE", publishType),
loadtest.WithRunnerEnvVar("SUBSCRIBE_TYPE", subscribeType),
loadtest.WithRunnerEnvVar("HTTP_REQ_DURATION_THRESHOLD", httpReqDurationThresholdMs),
loadtest.WithRunnerEnvVar("PERF_PUBSUB_HTTP_TOPIC_NAME", component.Topic),
)
defer k6Test.Dispose()
t.Log("running the k6 load test...")
require.NoError(t, tr.Platform.LoadTest(k6Test))
sm, err := loadtest.K6ResultDefault(k6Test)
require.NoError(t, err)
require.NotNil(t, sm)
var testAppName = component.TestAppName + "-" + subscribeType
appUsage, err := tr.Platform.GetAppUsage(testAppName)
require.NoError(t, err)
sidecarUsage, err := tr.Platform.GetSidecarUsage(testAppName)
require.NoError(t, err)
restarts, err := tr.Platform.GetTotalRestarts(testAppName)
require.NoError(t, err)
summary.ForTest(t).
Service(testAppName).
CPU(appUsage.CPUm).
Memory(appUsage.MemoryMb).
SidecarCPU(sidecarUsage.CPUm).
SidecarMemory(sidecarUsage.MemoryMb).
Restarts(restarts).
OutputK6(sm.RunnersResults).
Output("PUBLISH_TYPE", publishType).
Output("SUBSCRIBE_TYPE", subscribeType).
Output("HTTP_REQ_DURATION_THRESHOLD", httpReqDurationThresholdMs).
Flush()
t.Logf("target dapr app consumed %vm CPU and %vMb of Memory", appUsage.CPUm, appUsage.MemoryMb)
t.Logf("target dapr sidecar consumed %vm CPU and %vMb of Memory", sidecarUsage.CPUm, sidecarUsage.MemoryMb)
t.Logf("target dapr app or sidecar restarted %v times", restarts)
bts, err := json.MarshalIndent(sm, "", " ")
require.NoError(t, err)
require.True(t, sm.Pass, fmt.Sprintf("test has not passed, results %s", string(bts)))
t.Logf("test summary `%s`", string(bts))
require.Equal(t, 0, restarts)
}
func TestPubsubBulkPublishSubscribeHttpPerformance(t *testing.T) {
for _, component := range configs.Components {
if !slices.Contains(component.Operations, normalPubsubType) {
t.Logf("Normal pubsub test is not added in operations, skipping %s test for normal pubsub", component.Name)
continue
}
t.Run(component.Name, func(t *testing.T) {
t.Logf("Starting test with %s subscriber", component.Name)
// Get the ingress external url of test app
testAppURL := tr.Platform.AcquireAppExternalURL(component.TestAppName + "-" + normalPubsubType)
require.NotEmpty(t, testAppURL, "test app external URL must not be empty")
// Check if test app endpoint is available
t.Logf("test app: '%s' url: '%s'", component.TestAppName+"-"+normalPubsubType, testAppURL)
_, err := utils.HTTPGetNTimes(testAppURL+"/health", component.NumHealthChecks)
require.NoError(t, err)
threshold := os.Getenv("DAPR_PERF_PUBSUB_SUBSCRIBE_HTTP_THRESHOLD")
if threshold == "" {
threshold = strconv.Itoa(component.SubscribeHTTPThresholdMs)
}
runTest(t, testAppURL, bulkPubsubType, normalPubsubType, threshold, component)
})
}
}
func TestPubsubBulkPublishBulkSubscribeHttpPerformance(t *testing.T) {
for _, component := range configs.Components {
if !slices.Contains(component.Operations, bulkPubsubType) {
t.Logf("Bulk pubsub test is not added in operations, skipping %s test for bulk pubsub", component.Name)
continue
}
t.Run(component.Name, func(t *testing.T) {
// Get the ingress external url of test app
bulkTestAppURL := tr.Platform.AcquireAppExternalURL(component.TestAppName + "-" + bulkPubsubType)
require.NotEmpty(t, bulkTestAppURL, "test app external URL must not be empty")
// Check if test app endpoint is available
t.Logf("bulk test app: '%s' url: %s", component.TestAppName+"-"+bulkPubsubType, bulkTestAppURL)
_, err := utils.HTTPGetNTimes(bulkTestAppURL+"/health", component.NumHealthChecks)
require.NoError(t, err)
threshold := os.Getenv("DAPR_PERF_PUBSUB_BULK_SUBSCRIBE_HTTP_THRESHOLD")
if threshold == "" {
threshold = strconv.Itoa(component.BulkSubscribeHTTPThresholdMs)
}
runTest(t, bulkTestAppURL, bulkPubsubType, bulkPubsubType, threshold, component)
})
}
}
|
mikeee/dapr
|
tests/perf/pubsub_subscribe_http/pubsub_subscribe_test.go
|
GO
|
mit
| 8,313 |
/*
Copyright 2023 The Dapr Authors
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.
*/
import http from 'k6/http'
import { check } from 'k6'
import exec from 'k6/execution'
import ws from 'k6/ws'
import { Counter } from 'k6/metrics'
const targetUrl = __ENV.TARGET_URL
const pubsubName = __ENV.PUBSUB_NAME
const subscribeType = __ENV.SUBSCRIBE_TYPE
const publishType = __ENV.PUBLISH_TYPE || 'bulk'
const httpReqDurationThreshold = __ENV.HTTP_REQ_DURATION_THRESHOLD
const defaultTopic = __ENV.PERF_PUBSUB_HTTP_TOPIC_NAME
const defaultCount = 100
const hundredBytesMessage = 'a'.repeat(100)
const testTimeoutMs = 60 * 1000
const errCounter = new Counter('error_counter')
export const options = {
discardResponseBodies: true,
thresholds: {
checks: ['rate==1'],
// 95% of requests should be below HTTP_REQ_DURATION_THRESHOLD milliseconds
http_req_duration: ['p(95)<' + httpReqDurationThreshold],
error_counter: ['count==0'],
'error_counter{errType:timeout}': ['count==0'],
},
scenarios: {
bulkPSubscribe: {
executor: 'ramping-vus',
startVUs: 0,
stages: [
{ duration: '2s', target: 100 },
{ duration: '3s', target: 300 },
{ duration: '4s', target: 500 },
],
gracefulRampDown: '0s',
},
},
}
const DAPR_ADDRESS = `http://127.0.0.1:${__ENV.DAPR_HTTP_PORT}`
/**
* Publishes messages to a topic using the bulk publish API.
* @param {String} pubsub pubsub component name
* @param {String} topic topic name
* @param {String} message message to publish
* @param {Number} count number of messages to publish
* @returns
*/
function publishMessages(pubsub, topic, message, count) {
const bulkPublishBody = []
for (let i = 0; i < count; i++) {
bulkPublishBody.push({
entryId: exec.vu.idInTest + '-' + i, // unique id for the message
event: message,
contentType: 'text/plain',
})
}
return http.post(
`${DAPR_ADDRESS}/v1.0-alpha1/publish/bulk/${pubsub}/${topic}`,
JSON.stringify(bulkPublishBody),
{ headers: { 'Content-Type': 'application/json' } }
)
}
/**
* Publish a message to a topic using the publish API.
* @param {String} pubsub
* @param {String} topic
* @param {String} message
* @returns
*/
function publishMessage(pubsub, topic, message) {
return http.post(
`${DAPR_ADDRESS}/v1.0/publish/${pubsub}/${topic}`,
message,
{ headers: { 'Content-Type': 'text/plain' } }
)
}
export default function () {
const url = `ws://${targetUrl}/test`
const params = { tags: { subscribeType: subscribeType } }
let topic = defaultTopic
if (subscribeType === 'bulk') {
topic = `${defaultTopic}-bulk`
}
const res = ws.connect(url, params, (socket) => {
socket.on('open', () => {
// Publish messages to the topic
if (publishType === 'bulk') {
let publishResponse = publishMessages(
pubsubName,
topic,
hundredBytesMessage,
defaultCount
)
check(publishResponse, {
'bulk publish response status code is 2xx': (r) =>
r.status >= 200 && r.status < 300,
})
} else {
for (let i = 0; i < defaultCount; i++) {
const publishResponse = publishMessage(
pubsubName,
topic,
hundredBytesMessage
)
check(publishResponse, {
'publish response status code is 2xx': (r) =>
r.status >= 200 && r.status < 300,
})
}
}
})
socket.on('message', (data) => {
console.log('Received data: ' + data)
check(data, {
'completed with success': (d) => d === 'true',
})
})
socket.on('close', () => {
console.log('closed')
})
socket.on('error', (err) => {
if (err.error() != 'websocket: close sent') {
console.log('Error: ' + err.error())
errCounter.add(1)
}
})
socket.setTimeout(() => {
console.log('timeout reached, closing socket and failing test')
errCounter.add(1, { errType: 'timeout' })
socket.close()
}, testTimeoutMs)
})
check(res, { 'status is 101': (r) => r && r.status === 101 })
}
export function teardown(_) {
const shutdownResult = http.post(`${DAPR_ADDRESS}/v1.0/shutdown`)
check(shutdownResult, {
'shutdown response status code is 2xx': (r) =>
r.status >= 200 && r.status < 300,
})
}
export function handleSummary(data) {
return {
stdout: JSON.stringify(data),
}
}
|
mikeee/dapr
|
tests/perf/pubsub_subscribe_http/test.js
|
JavaScript
|
mit
| 5,525 |
#
# Copyright 2023 The Dapr Authors
# 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.
#
name: pubsub performance test
components:
- name: dapr-perf-test-kafka-pubsub-subs-http
topic: kafka-perf-test
route: kafka-perf-test
numHealthChecks: 60
testAppName: kafka-test-app
testLabel: pubsub_subscribe_kafka
subscribeHTTPThresholdMs: 1500
bulkSubscribeHTTPThresholdMs: 500
imageName: perf-pubsub_subscribe_http
operations: [bulk, normal]
- name: dapr-perf-test-rabbitmq-pubsub-subs-http
topic: rabbitmq-perf-test
route: rabbitmq-perf-test
numHealthChecks: 60
testAppName: rabbitmq-test-app
testLabel: pubsub_subscribe_rabbitmq
subscribeHTTPThresholdMs: 3000
bulkSubscribeHTTPThresholdMs: 500
imageName: perf-pubsub_subscribe_http
operations: [bulk, normal]
- name: dapr-perf-test-mqtt-pubsub-subs-http
topic: mqtt-perf-test
route: mqtt-perf-test
numHealthChecks: 60
testAppName: mqtt-test-app
testLabel: pubsub_subscribe_mqtt
subscribeHTTPThresholdMs: 1500
bulkSubscribeHTTPThresholdMs: 500
imageName: perf-pubsub_subscribe_http
operations: [bulk, normal]
- name: dapr-perf-test-pulsar-pubsub-subs-http
topic: pulsar-perf-test
route: pulsar-perf-test
numHealthChecks: 60
testAppName: pulsar-test-app
testLabel: pubsub_subscribe_pulsar
subscribeHTTPThresholdMs: 1500
bulkSubscribeHTTPThresholdMs: 500
imageName: perf-pubsub_subscribe_http
operations: [bulk, normal]
- name: dapr-perf-test-redis-pubsub-subs-http
topic: redis-perf-test
route: redis-perf-test
numHealthChecks: 60
testAppName: redis-test-app
testLabel: pubsub_subscribe_redis
subscribeHTTPThresholdMs: 1500
bulkSubscribeHTTPThresholdMs: 500
imageName: perf-pubsub_subscribe_http
operations: [bulk, normal]
|
mikeee/dapr
|
tests/perf/pubsub_subscribe_http/test_all.yaml
|
YAML
|
mit
| 2,349 |
#
# Copyright 2023 The Dapr Authors
# 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.
#
name: pubsub performance test
components:
- name: kafka-messagebus
topic: kafka-perf-test
route: kafka-perf-test
numHealthChecks: 60
testAppName: kafka-test-app
testLabel: pubsub_subscribe_kafka
subscribeHTTPThresholdMs: 1500
bulkSubscribeHTTPThresholdMs: 500
imageName: perf-pubsub_subscribe_http
operations: [bulk, normal]
|
mikeee/dapr
|
tests/perf/pubsub_subscribe_http/test_kafka.yaml
|
YAML
|
mit
| 941 |
//go:build perf
// +build perf
/*
Copyright 2021 The Dapr Authors
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.
*/
package service_invocation_grpc_perf
import (
"encoding/json"
"fmt"
"os"
"strings"
"testing"
"github.com/stretchr/testify/require"
"github.com/dapr/dapr/tests/perf"
"github.com/dapr/dapr/tests/perf/utils"
kube "github.com/dapr/dapr/tests/platforms/kubernetes"
"github.com/dapr/dapr/tests/runner"
"github.com/dapr/dapr/tests/runner/summary"
)
const numHealthChecks = 60 // Number of times to check for endpoint health per app.
const testLabel = "service-invocation-grpc"
var tr *runner.TestRunner
func TestMain(m *testing.M) {
utils.SetupLogs("service_invocation_grpc")
testApps := []kube.AppDescription{
{
AppName: "testapp",
DaprEnabled: true,
ImageName: "perf-service_invocation_grpc",
Replicas: 1,
IngressEnabled: true,
MetricsEnabled: true,
AppPort: 3000,
AppProtocol: "grpc",
DaprCPULimit: "4.0",
DaprCPURequest: "0.1",
DaprMemoryLimit: "512Mi",
DaprMemoryRequest: "250Mi",
AppCPULimit: "4.0",
AppCPURequest: "0.1",
AppMemoryLimit: "800Mi",
AppMemoryRequest: "2500Mi",
Labels: map[string]string{
"daprtest": testLabel + "-testapp",
},
},
{
AppName: "tester",
DaprEnabled: true,
ImageName: "perf-tester",
Replicas: 1,
IngressEnabled: true,
MetricsEnabled: true,
AppPort: 3001,
DaprCPULimit: "4.0",
DaprCPURequest: "0.1",
DaprMemoryLimit: "512Mi",
DaprMemoryRequest: "250Mi",
AppCPULimit: "4.0",
AppCPURequest: "0.1",
AppMemoryLimit: "800Mi",
AppMemoryRequest: "2500Mi",
Labels: map[string]string{
"daprtest": testLabel + "-tester",
},
PodAffinityLabels: map[string]string{
"daprtest": testLabel + "-testapp",
},
},
}
tr = runner.NewTestRunner("serviceinvocationgrpc", testApps, nil, nil)
os.Exit(tr.Start(m))
}
func TestServiceInvocationGrpcPerformance(t *testing.T) {
p := perf.Params(
perf.WithQPS(1000),
perf.WithConnections(16),
perf.WithDuration("1m"),
perf.WithPayloadSize(1024),
)
t.Logf("running service invocation grpc test with params: qps=%v, connections=%v, duration=%s, payload size=%v, payload=%v", p.QPS, p.ClientConnections, p.TestDuration, p.PayloadSizeKB, p.Payload)
// Get the ingress external url of test app
testAppURL := tr.Platform.AcquireAppExternalURL("testapp")
require.NotEmpty(t, testAppURL, "test app external URL must not be empty")
// Check if test app endpoint is available
t.Logf("Waiting until test app grpc service is available: %s", testAppURL)
_, err := utils.GrpcAccessNTimes(testAppURL, utils.GrpcServiceInvoke, numHealthChecks)
require.NoError(t, err)
// Get the ingress external url of tester app
testerAppURL := tr.Platform.AcquireAppExternalURL("tester")
require.NotEmpty(t, testerAppURL, "tester app external URL must not be empty")
// Check if tester app endpoint is available
t.Logf("teter app url: %s", testerAppURL)
_, err = utils.HTTPGetNTimes(testerAppURL, numHealthChecks)
require.NoError(t, err)
// Perform baseline test
p.Grpc = true
p.Dapr = "capability=invoke,target=appcallback,method=load"
p.TargetEndpoint = "http://testapp:3000"
body, err := json.Marshal(&p)
require.NoError(t, err)
t.Log("running baseline test...")
baselineResp, err := utils.HTTPPost(fmt.Sprintf("%s/test", testerAppURL), body)
t.Logf("baseline test results: %s", string(baselineResp))
t.Log("checking err...")
require.NoError(t, err)
require.NotEmpty(t, baselineResp)
// fast fail if daprResp starts with error
require.False(t, strings.HasPrefix(string(baselineResp), "error"))
// Perform an initial run with Dapr as warmup
warmup := perf.Params(
perf.WithQPS(100),
perf.WithConnections(16),
perf.WithDuration("10s"),
perf.WithPayloadSize(1024),
)
warmup.Grpc = true
warmup.Dapr = "capability=invoke,target=dapr,method=load,appid=testapp"
warmup.TargetEndpoint = "http://localhost:50001"
body, err = json.Marshal(warmup)
require.NoError(t, err)
t.Log("running warmup...")
warmupResp, err := utils.HTTPPost(fmt.Sprintf("%s/test", testerAppURL), body)
t.Logf("warmup results: %s", string(warmupResp))
require.NoError(t, err)
require.NotEmpty(t, warmupResp)
// fast fail if warmupResp starts with error
require.False(t, strings.HasPrefix(string(warmupResp), "error"))
// Perform dapr test
p.Grpc = true
p.Dapr = "capability=invoke,target=dapr,method=load,appid=testapp"
p.TargetEndpoint = "http://localhost:50001"
body, err = json.Marshal(p)
require.NoError(t, err)
t.Log("running dapr test...")
daprResp, err := utils.HTTPPost(fmt.Sprintf("%s/test", testerAppURL), body)
t.Logf("dapr test results: %s", string(daprResp))
t.Log("checking err...")
require.NoError(t, err)
require.NotEmpty(t, daprResp)
sidecarUsage, err := tr.Platform.GetSidecarUsage("testapp")
require.NoError(t, err)
appUsage, err := tr.Platform.GetAppUsage("testapp")
require.NoError(t, err)
restarts, err := tr.Platform.GetTotalRestarts("testapp")
require.NoError(t, err)
t.Logf("target dapr sidecar consumed %vm Cpu and %vMb of Memory", sidecarUsage.CPUm, sidecarUsage.MemoryMb)
var daprResult perf.TestResult
err = json.Unmarshal(daprResp, &daprResult)
require.NoError(t, err)
var baselineResult perf.TestResult
err = json.Unmarshal(baselineResp, &baselineResult)
require.NoError(t, err)
percentiles := []string{"50th", "75th", "90th", "99th"}
var tp90Latency float64
for k, v := range percentiles {
daprValue := daprResult.DurationHistogram.Percentiles[k].Value
baselineValue := baselineResult.DurationHistogram.Percentiles[k].Value
latency := (daprValue - baselineValue) * 1000
if v == "90th" {
tp90Latency = latency
}
t.Logf("added latency for %s percentile: %sms", v, fmt.Sprintf("%.2f", latency))
}
avg := (daprResult.DurationHistogram.Avg - baselineResult.DurationHistogram.Avg) * 1000
baselineLatency := baselineResult.DurationHistogram.Avg * 1000
daprLatency := daprResult.DurationHistogram.Avg * 1000
t.Logf("baseline latency avg: %sms", fmt.Sprintf("%.2f", baselineLatency))
t.Logf("dapr latency avg: %sms", fmt.Sprintf("%.2f", daprLatency))
t.Logf("added latency avg: %sms", fmt.Sprintf("%.2f", avg))
summary.ForTest(t).
Service("testapp").
CPU(appUsage.CPUm).
Memory(appUsage.MemoryMb).
SidecarCPU(sidecarUsage.CPUm).
SidecarMemory(sidecarUsage.MemoryMb).
Restarts(restarts).
BaselineLatency(baselineLatency).
DaprLatency(daprLatency).
AddedLatency(avg).
ActualQPS(daprResult.ActualQPS).
Params(p).
OutputFortio(daprResult).
Flush()
require.Equal(t, 0, daprResult.RetCodes.Num400)
require.Equal(t, 0, daprResult.RetCodes.Num500)
require.Equal(t, 0, restarts)
require.True(t, daprResult.ActualQPS > float64(p.QPS)*0.99)
require.Greater(t, tp90Latency, 0.0)
require.LessOrEqual(t, tp90Latency, 2.5)
}
|
mikeee/dapr
|
tests/perf/service_invocation_grpc/service_invocation_grpc_test.go
|
GO
|
mit
| 7,481 |
//go:build perf
// +build perf
/*
Copyright 2021 The Dapr Authors
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.
*/
package service_invocation_http_perf
import (
"encoding/json"
"fmt"
"os"
"strings"
"testing"
"github.com/dapr/dapr/tests/perf"
"github.com/dapr/dapr/tests/perf/utils"
kube "github.com/dapr/dapr/tests/platforms/kubernetes"
"github.com/dapr/dapr/tests/runner"
"github.com/dapr/dapr/tests/runner/summary"
"github.com/stretchr/testify/require"
)
const numHealthChecks = 60 // Number of times to check for endpoint health per app.
const testLabel = "service-invocation-http"
var tr *runner.TestRunner
func TestMain(m *testing.M) {
utils.SetupLogs("service_invocation_http")
testApps := []kube.AppDescription{
{
AppName: "testapp",
DaprEnabled: true,
ImageName: "perf-service_invocation_http",
Replicas: 1,
IngressEnabled: true,
MetricsEnabled: true,
DaprCPULimit: "4.0",
DaprCPURequest: "0.1",
DaprMemoryLimit: "512Mi",
DaprMemoryRequest: "250Mi",
AppCPULimit: "4.0",
AppCPURequest: "0.1",
AppMemoryLimit: "800Mi",
AppMemoryRequest: "2500Mi",
Labels: map[string]string{
"daprtest": testLabel + "-testapp",
},
},
{
AppName: "tester",
DaprEnabled: true,
ImageName: "perf-tester",
Replicas: 1,
IngressEnabled: true,
MetricsEnabled: true,
AppPort: 3001,
DaprCPULimit: "4.0",
DaprCPURequest: "0.1",
DaprMemoryLimit: "512Mi",
DaprMemoryRequest: "250Mi",
AppCPULimit: "4.0",
AppCPURequest: "0.1",
AppMemoryLimit: "800Mi",
AppMemoryRequest: "2500Mi",
Labels: map[string]string{
"daprtest": testLabel + "-tester",
},
PodAffinityLabels: map[string]string{
"daprtest": testLabel + "-testapp",
},
},
}
tr = runner.NewTestRunner("serviceinvocationhttp", testApps, nil, nil)
os.Exit(tr.Start(m))
}
func TestServiceInvocationHTTPPerformance(t *testing.T) {
p := perf.Params(
perf.WithQPS(1000),
perf.WithConnections(16),
perf.WithDuration("1m"),
perf.WithPayloadSize(1024),
)
t.Logf("running service invocation http test with params: qps=%v, connections=%v, duration=%s, payload size=%v, payload=%v", p.QPS, p.ClientConnections, p.TestDuration, p.PayloadSizeKB, p.Payload)
// Get the ingress external url of test app
testAppURL := tr.Platform.AcquireAppExternalURL("testapp")
require.NotEmpty(t, testAppURL, "test app external URL must not be empty")
// Check if test app endpoint is available
t.Logf("waiting until test app url is available: %s", testAppURL+"/test")
_, err := utils.HTTPGetNTimes(testAppURL+"/test", numHealthChecks)
require.NoError(t, err)
// Get the ingress external url of tester app
testerAppURL := tr.Platform.AcquireAppExternalURL("tester")
require.NotEmpty(t, testerAppURL, "tester app external URL must not be empty")
// Check if tester app endpoint is available
t.Logf("waiting until tester app url is available: %s", testerAppURL)
_, err = utils.HTTPGetNTimes(testerAppURL, numHealthChecks)
require.NoError(t, err)
// Perform baseline test
p.TargetEndpoint = "http://testapp:3000/test"
body, err := json.Marshal(&p)
require.NoError(t, err)
t.Log("running baseline test...")
baselineResp, err := utils.HTTPPost(fmt.Sprintf("%s/test", testerAppURL), body)
t.Logf("baseline test results: %s", string(baselineResp))
t.Log("checking err...")
require.NoError(t, err)
require.NotEmpty(t, baselineResp)
// fast fail if daprResp starts with error
require.False(t, strings.HasPrefix(string(baselineResp), "error"))
// Perform an initial run with Dapr as warmup
warmup := perf.Params(
perf.WithQPS(100),
perf.WithConnections(16),
perf.WithDuration("10s"),
perf.WithPayloadSize(1024),
)
warmup.TargetEndpoint = "http://127.0.0.1:3500/v1.0/invoke/testapp/method/test"
body, err = json.Marshal(warmup)
require.NoError(t, err)
t.Log("running warmup...")
warmupResp, err := utils.HTTPPost(fmt.Sprintf("%s/test", testerAppURL), body)
t.Logf("warmup results: %s", string(warmupResp))
require.NoError(t, err)
require.NotEmpty(t, warmupResp)
// fast fail if warmupResp starts with error
require.False(t, strings.HasPrefix(string(warmupResp), "error"))
// Perform dapr test
p.TargetEndpoint = "http://127.0.0.1:3500/v1.0/invoke/testapp/method/test"
body, err = json.Marshal(p)
require.NoError(t, err)
t.Log("running dapr test...")
daprResp, err := utils.HTTPPost(fmt.Sprintf("%s/test", testerAppURL), body)
t.Logf("dapr test results: %s", string(daprResp))
t.Log("checking err...")
require.NoError(t, err)
require.NotEmpty(t, daprResp)
// fast fail if daprResp starts with error
require.False(t, strings.HasPrefix(string(daprResp), "error"))
sidecarUsage, err := tr.Platform.GetSidecarUsage("testapp")
require.NoError(t, err)
appUsage, err := tr.Platform.GetAppUsage("testapp")
require.NoError(t, err)
restarts, err := tr.Platform.GetTotalRestarts("testapp")
require.NoError(t, err)
t.Logf("target dapr sidecar consumed %vm Cpu and %vMb of Memory", sidecarUsage.CPUm, sidecarUsage.MemoryMb)
var daprResult perf.TestResult
err = json.Unmarshal(daprResp, &daprResult)
require.NoError(t, err)
var baselineResult perf.TestResult
err = json.Unmarshal(baselineResp, &baselineResult)
require.NoError(t, err)
percentiles := []string{"50th", "75th", "90th", "99th"}
var tp90Latency float64
for k, v := range percentiles {
daprValue := daprResult.DurationHistogram.Percentiles[k].Value
baselineValue := baselineResult.DurationHistogram.Percentiles[k].Value
latency := (daprValue - baselineValue) * 1000
if v == "90th" {
tp90Latency = latency
}
t.Logf("added latency for %s percentile: %sms", v, fmt.Sprintf("%.2f", latency))
}
avg := (daprResult.DurationHistogram.Avg - baselineResult.DurationHistogram.Avg) * 1000
baselineLatency := baselineResult.DurationHistogram.Avg * 1000
daprLatency := daprResult.DurationHistogram.Avg * 1000
t.Logf("baseline latency avg: %sms", fmt.Sprintf("%.2f", baselineLatency))
t.Logf("dapr latency avg: %sms", fmt.Sprintf("%.2f", daprLatency))
t.Logf("added latency avg: %sms", fmt.Sprintf("%.2f", avg))
daprMetrics := utils.DaprMetrics{
BaselineLatency: baselineLatency,
DaprLatency: daprLatency,
AddedLatency: avg,
SidecarCPU: sidecarUsage.CPUm,
AppCPU: appUsage.CPUm,
SidecarMemory: sidecarUsage.MemoryMb,
AppMemory: appUsage.MemoryMb,
ApplicationThroughput: daprResult.ActualQPS,
}
utils.PushPrometheusMetrics(daprMetrics, testLabel, "")
summary.ForTest(t).
Service("testapp").
CPU(appUsage.CPUm).
Memory(appUsage.MemoryMb).
SidecarCPU(sidecarUsage.CPUm).
SidecarMemory(sidecarUsage.MemoryMb).
Restarts(restarts).
BaselineLatency(baselineLatency).
DaprLatency(daprLatency).
AddedLatency(avg).
ActualQPS(daprResult.ActualQPS).
Params(p).
OutputFortio(daprResult).
Flush()
require.Equal(t, 0, daprResult.RetCodes.Num400)
require.Equal(t, 0, daprResult.RetCodes.Num500)
require.Equal(t, 0, restarts)
require.True(t, daprResult.ActualQPS > float64(p.QPS)*0.99)
require.Greater(t, tp90Latency, 0.0)
require.LessOrEqual(t, tp90Latency, 2.0)
}
|
mikeee/dapr
|
tests/perf/service_invocation_http/service_invocation_http_test.go
|
GO
|
mit
| 7,782 |
//go:build perf
// +build perf
/*
Copyright 2021 The Dapr Authors
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.
*/
package state_get_grpc
import (
"encoding/json"
"fmt"
"os"
"strings"
"testing"
"github.com/stretchr/testify/require"
"github.com/dapr/dapr/tests/perf"
"github.com/dapr/dapr/tests/perf/utils"
kube "github.com/dapr/dapr/tests/platforms/kubernetes"
"github.com/dapr/dapr/tests/runner"
"github.com/dapr/dapr/tests/runner/summary"
)
const (
appName = "perfstategrpc"
// Number of times to check for endpoint health per app.
numHealthChecks = 60
)
var tr *runner.TestRunner
func TestMain(m *testing.M) {
utils.SetupLogs("state_get_grpc")
testApps := []kube.AppDescription{
{
AppName: appName,
DaprEnabled: true,
ImageName: "perf-tester",
Replicas: 1,
IngressEnabled: true,
MetricsEnabled: true,
AppPort: 3001,
DaprCPULimit: "4.0",
DaprCPURequest: "0.1",
DaprMemoryLimit: "512Mi",
DaprMemoryRequest: "250Mi",
AppCPULimit: "4.0",
AppCPURequest: "0.1",
AppMemoryLimit: "800Mi",
AppMemoryRequest: "2500Mi",
},
}
tr = runner.NewTestRunner("state_get_grpc", testApps, nil, nil)
os.Exit(tr.Start(m))
}
func TestStateGetGrpcPerformance(t *testing.T) {
p := perf.Params(
perf.WithQPS(1000),
perf.WithConnections(16),
perf.WithDuration("1m"),
perf.WithPayloadSize(0),
)
t.Logf("running state get grpc test with params: qps=%v, connections=%v, duration=%s, payload size=%v, payload=%v", p.QPS, p.ClientConnections, p.TestDuration, p.PayloadSizeKB, p.Payload)
// Get the ingress external url of tester app
testerAppURL := tr.Platform.AcquireAppExternalURL(appName)
require.NotEmpty(t, testerAppURL, "tester app external URL must not be empty")
// Check if tester app endpoint is available
t.Logf("tester app url: %s", testerAppURL)
_, err := utils.HTTPGetNTimes(testerAppURL, numHealthChecks)
require.NoError(t, err)
// Perform baseline test
p.Grpc = true
p.Dapr = "capability=state,target=noop"
p.TargetEndpoint = fmt.Sprintf("http://localhost:50001")
body, err := json.Marshal(&p)
require.NoError(t, err)
t.Log("running baseline test...")
baselineResp, err := utils.HTTPPost(fmt.Sprintf("%s/test", testerAppURL), body)
t.Logf("baseline test results: %s", string(baselineResp))
t.Log("checking err...")
require.NoError(t, err)
require.NotEmpty(t, baselineResp)
// fast fail if daprResp starts with error
require.False(t, strings.HasPrefix(string(baselineResp), "error"))
// Perform dapr test
p.Dapr = "capability=state,target=dapr,method=get,store=inmemorystate,key=abc123"
p.TargetEndpoint = fmt.Sprintf("http://localhost:50001")
body, err = json.Marshal(&p)
require.NoError(t, err)
t.Log("running dapr test...")
daprResp, err := utils.HTTPPost(fmt.Sprintf("%s/test", testerAppURL), body)
t.Logf("dapr test results: %s", string(daprResp))
t.Log("checking err...")
require.NoError(t, err)
require.NotEmpty(t, daprResp)
// fast fail if daprResp starts with error
require.False(t, strings.HasPrefix(string(baselineResp), "error"))
sidecarUsage, err := tr.Platform.GetSidecarUsage(appName)
require.NoError(t, err)
appUsage, err := tr.Platform.GetAppUsage(appName)
require.NoError(t, err)
restarts, err := tr.Platform.GetTotalRestarts(appName)
require.NoError(t, err)
t.Logf("dapr sidecar consumed %vm Cpu and %vMb of Memory", sidecarUsage.CPUm, sidecarUsage.MemoryMb)
var daprResult perf.TestResult
err = json.Unmarshal(daprResp, &daprResult)
require.NoError(t, err)
var baselineResult perf.TestResult
err = json.Unmarshal(baselineResp, &baselineResult)
require.NoError(t, err)
percentiles := []string{"50th", "75th", "90th", "99th"}
var tp90Latency float64
for k, v := range percentiles {
daprValue := daprResult.DurationHistogram.Percentiles[k].Value
baselineValue := baselineResult.DurationHistogram.Percentiles[k].Value
latency := (daprValue - baselineValue) * 1000
if v == "90th" {
tp90Latency = latency
}
t.Logf("added latency for %s percentile: %sms", v, fmt.Sprintf("%.2f", latency))
}
avg := (daprResult.DurationHistogram.Avg - baselineResult.DurationHistogram.Avg) * 1000
baselineLatency := baselineResult.DurationHistogram.Avg * 1000
daprLatency := daprResult.DurationHistogram.Avg * 1000
t.Logf("baseline latency avg: %sms", fmt.Sprintf("%.2f", baselineLatency))
t.Logf("dapr latency avg: %sms", fmt.Sprintf("%.2f", daprLatency))
t.Logf("added latency avg: %sms", fmt.Sprintf("%.2f", avg))
summary.ForTest(t).
Service(appName).
CPU(appUsage.CPUm).
Memory(appUsage.MemoryMb).
SidecarCPU(sidecarUsage.CPUm).
SidecarMemory(sidecarUsage.MemoryMb).
Restarts(restarts).
BaselineLatency(baselineLatency).
DaprLatency(daprLatency).
AddedLatency(avg).
ActualQPS(daprResult.ActualQPS).
Params(p).
OutputFortio(daprResult).
Flush()
require.Equal(t, 0, daprResult.RetCodes.Num400)
require.Equal(t, 0, daprResult.RetCodes.Num500)
require.Equal(t, 0, restarts)
require.True(t, daprResult.ActualQPS > float64(p.QPS)*0.99)
require.Greater(t, tp90Latency, 0.0)
require.LessOrEqual(t, tp90Latency, 2.0)
}
|
mikeee/dapr
|
tests/perf/state_get_grpc/state_get_grpc_test.go
|
GO
|
mit
| 5,655 |
//go:build perf
// +build perf
/*
Copyright 2021 The Dapr Authors
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.
*/
package state_get_http
import (
"encoding/json"
"fmt"
"os"
"strings"
"testing"
"github.com/stretchr/testify/require"
"github.com/dapr/dapr/tests/perf"
"github.com/dapr/dapr/tests/perf/utils"
kube "github.com/dapr/dapr/tests/platforms/kubernetes"
"github.com/dapr/dapr/tests/runner"
"github.com/dapr/dapr/tests/runner/summary"
)
const (
appName = "perfstategrpc"
// Number of times to check for endpoint health per app.
numHealthChecks = 60
testLabel = "state_get_http"
)
var tr *runner.TestRunner
func TestMain(m *testing.M) {
utils.SetupLogs("state_get_http")
testApps := []kube.AppDescription{
{
AppName: appName,
DaprEnabled: true,
ImageName: "perf-tester",
Replicas: 1,
IngressEnabled: true,
MetricsEnabled: true,
AppPort: 3001,
DaprCPULimit: "4.0",
DaprCPURequest: "0.1",
DaprMemoryLimit: "512Mi",
DaprMemoryRequest: "250Mi",
AppCPULimit: "4.0",
AppCPURequest: "0.1",
AppMemoryLimit: "800Mi",
AppMemoryRequest: "2500Mi",
},
}
tr = runner.NewTestRunner("state_get_http", testApps, nil, nil)
os.Exit(tr.Start(m))
}
func TestStateGetGrpcPerformance(t *testing.T) {
p := perf.Params(
perf.WithQPS(1000),
perf.WithConnections(16),
perf.WithDuration("1m"),
perf.WithPayloadSize(0),
)
t.Logf("running state get http test with params: qps=%v, connections=%v, duration=%s, payload size=%v, payload=%v", p.QPS, p.ClientConnections, p.TestDuration, p.PayloadSizeKB, p.Payload)
// Get the ingress external url of tester app
testerAppURL := tr.Platform.AcquireAppExternalURL(appName)
require.NotEmpty(t, testerAppURL, "tester app external URL must not be empty")
// Check if tester app endpoint is available
t.Logf("tester app url: %s", testerAppURL)
_, err := utils.HTTPGetNTimes(testerAppURL, numHealthChecks)
require.NoError(t, err)
// Perform baseline test
p.Grpc = true
p.Dapr = "capability=state,target=noop"
p.TargetEndpoint = fmt.Sprintf("http://localhost:50001")
body, err := json.Marshal(&p)
require.NoError(t, err)
t.Log("running baseline test...")
baselineResp, err := utils.HTTPPost(fmt.Sprintf("%s/test", testerAppURL), body)
t.Logf("baseline test results: %s", string(baselineResp))
t.Log("checking err...")
require.NoError(t, err)
require.NotEmpty(t, baselineResp)
// fast fail if daprResp starts with error
require.False(t, strings.HasPrefix(string(baselineResp), "error"))
// Perform dapr test
p.Grpc = false
p.Dapr = ""
p.TargetEndpoint = fmt.Sprintf("http://127.0.0.1:3500/v1.0/state/inmemorystate/abc123")
body, err = json.Marshal(&p)
require.NoError(t, err)
t.Log("running dapr test...")
daprResp, err := utils.HTTPPost(fmt.Sprintf("%s/test", testerAppURL), body)
t.Logf("dapr test results: %s", string(daprResp))
t.Log("checking err...")
require.NoError(t, err)
require.NotEmpty(t, daprResp)
// fast fail if daprResp starts with error
require.False(t, strings.HasPrefix(string(daprResp), "error"))
sidecarUsage, err := tr.Platform.GetSidecarUsage(appName)
require.NoError(t, err)
appUsage, err := tr.Platform.GetAppUsage(appName)
require.NoError(t, err)
restarts, err := tr.Platform.GetTotalRestarts(appName)
require.NoError(t, err)
t.Logf("dapr sidecar consumed %vm Cpu and %vMb of Memory", sidecarUsage.CPUm, sidecarUsage.MemoryMb)
var daprResult perf.TestResult
err = json.Unmarshal(daprResp, &daprResult)
require.NoError(t, err)
var baselineResult perf.TestResult
err = json.Unmarshal(baselineResp, &baselineResult)
require.NoError(t, err)
percentiles := []string{"50th", "75th", "90th", "99th"}
var tp90Latency float64
for k, v := range percentiles {
daprValue := daprResult.DurationHistogram.Percentiles[k].Value
baselineValue := baselineResult.DurationHistogram.Percentiles[k].Value
latency := (daprValue - baselineValue) * 1000
if v == "90th" {
tp90Latency = latency
}
t.Logf("added latency for %s percentile: %sms", v, fmt.Sprintf("%.2f", latency))
}
avg := (daprResult.DurationHistogram.Avg - baselineResult.DurationHistogram.Avg) * 1000
baselineLatency := baselineResult.DurationHistogram.Avg * 1000
daprLatency := daprResult.DurationHistogram.Avg * 1000
t.Logf("baseline latency avg: %sms", fmt.Sprintf("%.2f", baselineLatency))
t.Logf("dapr latency avg: %sms", fmt.Sprintf("%.2f", daprLatency))
t.Logf("added latency avg: %sms", fmt.Sprintf("%.2f", avg))
daprMetrics := utils.DaprMetrics{
BaselineLatency: baselineLatency,
DaprLatency: daprLatency,
AddedLatency: avg,
SidecarCPU: sidecarUsage.CPUm,
AppCPU: appUsage.CPUm,
SidecarMemory: sidecarUsage.MemoryMb,
AppMemory: appUsage.MemoryMb,
ApplicationThroughput: daprResult.ActualQPS,
}
utils.PushPrometheusMetrics(daprMetrics, testLabel, "inmemory")
summary.ForTest(t).
Service(appName).
CPU(appUsage.CPUm).
Memory(appUsage.MemoryMb).
SidecarCPU(sidecarUsage.CPUm).
SidecarMemory(sidecarUsage.MemoryMb).
Restarts(restarts).
BaselineLatency(baselineLatency).
DaprLatency(daprLatency).
AddedLatency(avg).
ActualQPS(daprResult.ActualQPS).
Params(p).
OutputFortio(daprResult).
Flush()
require.Equal(t, 0, daprResult.RetCodes.Num400)
require.Equal(t, 0, daprResult.RetCodes.Num500)
require.Equal(t, 0, restarts)
require.True(t, daprResult.ActualQPS > float64(p.QPS)*0.99)
require.Greater(t, tp90Latency, 0.0)
require.LessOrEqual(t, tp90Latency, 2.0)
}
|
mikeee/dapr
|
tests/perf/state_get_http/state_get_http_test.go
|
GO
|
mit
| 6,102 |
/*
Copyright 2022 The Dapr Authors
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.
*/
package perf
import (
"os"
"strconv"
)
const (
defaultQPS = 1
defaultClientConnections = 1
defaultPayloadSizeKB = 0
defaultPayload = ""
defaultTestDuration = "1m"
qpsEnvVar = "DAPR_PERF_QPS"
clientConnectionsEnvVar = "DAPR_PERF_CONNECTIONS"
testDurationEnvVar = "DAPR_TEST_DURATION"
payloadSizeEnvVar = "DAPR_PAYLOAD_SIZE"
payloadEnvVar = "DAPR_PAYLOAD"
)
type TestParameters struct {
QPS int `json:"qps"`
ClientConnections int `json:"clientConnections"`
TargetEndpoint string `json:"targetEndpoint"`
TestDuration string `json:"testDuration"`
PayloadSizeKB int `json:"payloadSizeKB"`
Payload string `json:"payload"`
StdClient bool `json:"stdClient"`
Grpc bool `json:"grpc"`
Dapr string `json:"dapr"`
}
type Opt = func(*TestParameters)
// WithQPS sets the test taget query per second.
func WithQPS(qps int) Opt {
return func(tp *TestParameters) {
tp.QPS = qps
}
}
// WithConnections set the total client connections.
func WithConnections(connections int) Opt {
return func(tp *TestParameters) {
tp.ClientConnections = connections
}
}
// WithDuration sets the total test duration.
// accepts the time notation `1m`, `10s`, etc.
func WithDuration(duration string) Opt {
return func(tp *TestParameters) {
tp.TestDuration = duration
}
}
// WithPayloadSize sets the test random payload size in KB.
func WithPayloadSize(sizeKB int) Opt {
return func(tp *TestParameters) {
tp.PayloadSizeKB = sizeKB
}
}
// WithPayload sets the test payload.
func WithPayload(payload string) Opt {
return func(tp *TestParameters) {
tp.Payload = payload
}
}
func noop(tp *TestParameters) {}
func Params(opts ...Opt) TestParameters {
params := TestParameters{
QPS: defaultQPS,
ClientConnections: defaultClientConnections,
TestDuration: defaultTestDuration,
Payload: defaultPayload,
PayloadSizeKB: defaultPayloadSizeKB,
}
for _, o := range append(opts, // set environment variables to have precedence over manually-set and default params.
useEnvVar(qpsEnvVar, toStrParam(WithQPS)),
useEnvVar(clientConnectionsEnvVar, toStrParam(WithConnections)),
useEnvVar(testDurationEnvVar, WithDuration),
useEnvVar(payloadEnvVar, WithPayload),
useEnvVar(payloadSizeEnvVar, toStrParam(WithPayloadSize)),
) {
o(¶ms)
}
return params
}
// toStrParam receives a function A that receives a int as a parameter and returns a function B
// that accepts a string. Applies the Atoi conversion on the given string from function B and if it fails it returns a no-op operation, otherwise the value
// is applied to the received function.
func toStrParam(opt func(value int) Opt) func(value string) Opt {
return func(value string) Opt {
val, err := strconv.Atoi(value)
if err != nil {
return noop
}
return opt(val)
}
}
// useEnvVar if the provided envVar exists it will be applied as a parameter of the `opt` function and returned as a Opt,
// otherwise it will return a no-op function.
func useEnvVar(envVar string, opt func(value string) Opt) Opt {
if val, ok := os.LookupEnv(envVar); ok && val != "" {
return opt(val)
}
return noop
}
|
mikeee/dapr
|
tests/perf/test_params.go
|
GO
|
mit
| 3,829 |
/*
Copyright 2022 The Dapr Authors
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.
*/
package perf
import (
"strconv"
"testing"
"github.com/stretchr/testify/assert"
)
func TestParamsOpts(t *testing.T) {
t.Run("default params should be used when env vars and params are absent", func(t *testing.T) {
p := Params()
assert.Equal(t, defaultClientConnections, p.ClientConnections)
assert.Equal(t, defaultPayload, p.Payload)
assert.Equal(t, defaultPayloadSizeKB, p.PayloadSizeKB)
assert.Equal(t, defaultQPS, p.QPS)
assert.Equal(t, defaultTestDuration, p.TestDuration)
})
t.Run("manually-set params should be used when specified", func(t *testing.T) {
clientConnections := defaultClientConnections + 1
payload := defaultPayload + "a"
payloadSizeKB := defaultPayloadSizeKB + 1
qps := defaultQPS + 1
duration := defaultTestDuration + "a"
p := Params(
WithConnections(clientConnections),
WithPayload(payload),
WithPayloadSize(payloadSizeKB),
WithQPS(qps),
WithDuration(duration),
)
assert.Equal(t, p.ClientConnections, clientConnections)
assert.Equal(t, p.Payload, payload)
assert.Equal(t, p.PayloadSizeKB, payloadSizeKB)
assert.Equal(t, p.QPS, qps)
assert.Equal(t, p.TestDuration, duration)
})
t.Run("environment variables should override manually set params", func(t *testing.T) {
clientConnections := defaultClientConnections + 1
t.Setenv(clientConnectionsEnvVar, strconv.Itoa(clientConnections))
payload := defaultPayload + "a"
t.Setenv(payloadEnvVar, payload)
payloadSizeKB := defaultPayloadSizeKB + 1
t.Setenv(payloadSizeEnvVar, strconv.Itoa(payloadSizeKB))
qps := defaultQPS + 1
t.Setenv(qpsEnvVar, strconv.Itoa(qps))
duration := defaultTestDuration + "a"
t.Setenv(testDurationEnvVar, duration)
p := Params(
WithConnections(clientConnections+1),
WithPayload(payload+"b"),
WithPayloadSize(payloadSizeKB+1),
WithQPS(qps+1),
WithDuration(duration+"a"),
)
assert.Equal(t, p.ClientConnections, clientConnections)
assert.Equal(t, p.Payload, payload)
assert.Equal(t, p.PayloadSizeKB, payloadSizeKB)
assert.Equal(t, p.QPS, qps)
assert.Equal(t, p.TestDuration, duration)
})
}
|
mikeee/dapr
|
tests/perf/test_params_test.go
|
GO
|
mit
| 2,653 |
/*
Copyright 2022 The Dapr Authors
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.
*/
package perf
import (
"os"
"time"
"github.com/dapr/dapr/tests/runner"
)
const (
githubRunID = "GITHUB_RUN_ID"
githubSHA = "GITHUB_SHA"
githubREF = "GITHUB_REF"
)
type TestResult struct {
RunType string `json:"RunType"`
Labels string `json:"Labels"`
StartTime time.Time `json:"StartTime"`
RequestedQPS string `json:"RequestedQPS"`
RequestedDuration string `json:"RequestedDuration"`
ActualQPS float64 `json:"ActualQPS"`
ActualDuration int64 `json:"ActualDuration"`
NumThreads int `json:"NumThreads"`
Version string `json:"Version"`
DurationHistogram struct {
Count int `json:"Count"`
Min float64 `json:"Min"`
Max float64 `json:"Max"`
Sum float64 `json:"Sum"`
Avg float64 `json:"Avg"`
StdDev float64 `json:"StdDev"`
Data []struct {
Start float64 `json:"Start"`
End float64 `json:"End"`
Percent float64 `json:"Percent"`
Count int `json:"Count"`
} `json:"Data"`
Percentiles []struct {
Percentile float64 `json:"Percentile"`
Value float64 `json:"Value"`
} `json:"Percentiles"`
} `json:"DurationHistogram"`
Exactly int `json:"Exactly"`
RetCodes struct {
Num200 int `json:"200"`
Num400 int `json:"400"`
Num500 int `json:"500"`
} `json:"RetCodes"`
Sizes struct {
Count int `json:"Count"`
Min int `json:"Min"`
Max int `json:"Max"`
Sum int `json:"Sum"`
Avg float64 `json:"Avg"`
StdDev float64 `json:"StdDev"`
Data []struct {
Start int `json:"Start"`
End int `json:"End"`
Percent float64 `json:"Percent"`
Count int `json:"Count"`
} `json:"Data"`
Percentiles interface{} `json:"Percentiles"`
} `json:"Sizes"`
HeaderSizes struct {
Count int `json:"Count"`
Min int `json:"Min"`
Max int `json:"Max"`
Sum int `json:"Sum"`
Avg float64 `json:"Avg"`
StdDev float64 `json:"StdDev"`
Data []struct {
Start int `json:"Start"`
End int `json:"End"`
Percent float64 `json:"Percent"`
Count int `json:"Count"`
} `json:"Data"`
Percentiles interface{} `json:"Percentiles"`
} `json:"HeaderSizes"`
URL string `json:"URL"`
SocketCount int `json:"SocketCount"`
AbortOn int `json:"AbortOn"`
}
type TestReport struct {
Results []TestResult `json:"Results"`
TestName string `json:"TestName"`
GitHubSHA string `json:"GitHubSHA,omitempty"`
GitHubREF string `json:"GitHubREF,omitempty"`
GitHubRunID string `json:"GitHubRunID,omitempty"`
Metrics resourceMetrics `json:"Metrics"`
TestMetrics map[string]interface{} `json:"TestMetrics"`
}
type resourceMetrics struct {
DaprConsumedCPUm int64 `json:"DaprConsumedCPUm"`
DaprConsumedMemoryMb float64 `json:"DaprConsumedMemoryMb"`
AppConsumedCPUm int64 `json:"AppConsumedCPUm"`
AppConsumedMemoryMb float64 `json:"AppConsumedMemoryMb"`
}
func NewTestReport(results []TestResult, name string, sidecarUsage, appUsage *runner.AppUsage) *TestReport {
return &TestReport{
Results: results,
TestName: name,
GitHubSHA: os.Getenv(githubSHA),
GitHubREF: os.Getenv(githubREF),
GitHubRunID: os.Getenv(githubRunID),
Metrics: resourceMetrics{
DaprConsumedCPUm: sidecarUsage.CPUm,
DaprConsumedMemoryMb: sidecarUsage.MemoryMb,
AppConsumedCPUm: appUsage.CPUm,
AppConsumedMemoryMb: appUsage.MemoryMb,
},
TestMetrics: map[string]interface{}{},
}
}
func (r *TestReport) SetTotalRestartCount(count int) {
r.TestMetrics["TotalRestartCount"] = count
}
|
mikeee/dapr
|
tests/perf/test_result.go
|
GO
|
mit
| 4,253 |
//go:build perf
// +build perf
/*
Copyright 2021 The Dapr Authors
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.
*/
package utils
import (
"context"
"time"
"google.golang.org/grpc"
"google.golang.org/grpc/credentials/insecure"
"google.golang.org/protobuf/types/known/anypb"
v1 "github.com/dapr/dapr/pkg/proto/common/v1"
runtimev1pb "github.com/dapr/dapr/pkg/proto/runtime/v1"
)
type GrpcAccessFunction = func(cc *grpc.ClientConn) ([]byte, error)
// GrpcAccessNTimes calls the method n times and returns the first success or last error.
func GrpcAccessNTimes(address string, f GrpcAccessFunction, n int) ([]byte, error) {
var res []byte
var err error
for i := n - 1; i >= 0; i-- {
res, err = GrpcAccess(address, f)
if i == 0 {
break
}
if err != nil {
println(err.Error())
time.Sleep(time.Second)
} else {
return res, nil
}
}
return res, err
}
// GrpcAccess is a helper to make gRPC call to the method.
func GrpcAccess(address string, f GrpcAccessFunction) ([]byte, error) {
cc, error := grpc.Dial(address, grpc.WithTransportCredentials(insecure.NewCredentials()))
if error != nil {
return nil, error
}
return f(cc)
}
// GrpcServiceInvoke call OnInvoke() of dapr AppCallback.
func GrpcServiceInvoke(cc *grpc.ClientConn) ([]byte, error) {
clientV1 := runtimev1pb.NewAppCallbackClient(cc)
response, error := clientV1.OnInvoke(context.Background(), &v1.InvokeRequest{
Method: "load",
Data: &anypb.Any{Value: []byte("")},
})
if error != nil {
return nil, error
}
if response.GetData() == nil {
return nil, nil
}
return response.GetData().Value, nil
}
|
mikeee/dapr
|
tests/perf/utils/grpc_helpers.go
|
GO
|
mit
| 2,095 |
//go:build perf
// +build perf
/*
Copyright 2021 The Dapr Authors
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.
*/
package utils
import (
"context"
"encoding/json"
"errors"
"fmt"
"os"
"time"
guuid "github.com/google/uuid"
"github.com/dapr/components-contrib/bindings"
"github.com/dapr/components-contrib/bindings/azure/blobstorage"
"github.com/dapr/components-contrib/metadata"
"github.com/dapr/dapr/tests/perf"
"github.com/dapr/kit/logger"
)
// Max number of healthcheck calls before starting tests.
const numHealthChecks = 60
// SimpleKeyValue can be used to simplify code, providing simple key-value pairs.
type SimpleKeyValue struct {
Key any
Value any
}
// GenerateRandomStringKeys generates random string keys (values are nil).
func GenerateRandomStringKeys(num int) []SimpleKeyValue {
if num < 0 {
return make([]SimpleKeyValue, 0)
}
output := make([]SimpleKeyValue, 0, num)
for i := 1; i <= num; i++ {
key := guuid.New().String()
output = append(output, SimpleKeyValue{key, nil})
}
return output
}
// GenerateRandomStringValues sets random string values for the keys passed in.
func GenerateRandomStringValues(keyValues []SimpleKeyValue) []SimpleKeyValue {
output := make([]SimpleKeyValue, 0, len(keyValues))
for i, keyValue := range keyValues {
key := keyValue.Key
value := fmt.Sprintf("Value for entry #%d with key %v.", i+1, key)
output = append(output, SimpleKeyValue{key, value})
}
return output
}
// GenerateRandomStringKeyValues generates random string key-values pairs.
func GenerateRandomStringKeyValues(num int) []SimpleKeyValue {
keys := GenerateRandomStringKeys(num)
return GenerateRandomStringValues(keys)
}
// UploadAzureBlob takes test output data and saves it to an Azure Blob Storage container
func UploadAzureBlob(report *perf.TestReport) error {
accountName, accountKey := os.Getenv("AZURE_STORAGE_ACCOUNT"), os.Getenv("AZURE_STORAGE_ACCESS_KEY")
if len(accountName) == 0 || len(accountKey) == 0 {
return nil
}
now := time.Now().UTC()
y := now.Year()
m := now.Month()
d := now.Day()
container := fmt.Sprintf("%v-%v-%v", int(m), d, y)
b, err := json.Marshal(report)
if err != nil {
return err
}
l := logger.NewLogger("dapr-perf-test")
azblob := blobstorage.NewAzureBlobStorage(l)
err = azblob.Init(context.Background(), bindings.Metadata{
Base: metadata.Base{
Properties: map[string]string{
"storageAccount": accountName,
"storageAccessKey": accountKey,
"container": container,
"publicAccessLevel": "container",
},
},
})
if err != nil {
return err
}
filename := fmt.Sprintf("%s-%v-%v-%v", report.TestName, now.Hour(), time.Hour.Minutes(), time.Hour.Seconds())
ctx, cancel := context.WithTimeout(context.Background(), 2*time.Minute)
defer cancel()
_, err = azblob.Invoke(ctx, &bindings.InvokeRequest{
Operation: bindings.CreateOperation,
Data: b,
Metadata: map[string]string{
"blobName": filename,
"ContentType": "application/json",
},
})
return err
}
// HealthCheckApps performs healthchecks for multiple apps, waiting for them to be ready.
func HealthCheckApps(urls ...string) error {
count := len(urls)
if count == 0 {
return nil
}
// Run the checks in parallel
errCh := make(chan error, count)
for _, u := range urls {
go func(u string) {
_, err := HTTPGetNTimes(u, numHealthChecks)
errCh <- err
}(u)
}
// Collect all errors
errs := make([]error, count)
for i := 0; i < count; i++ {
errs[i] = <-errCh
}
// Will be nil if no error
return errors.Join(errs...)
}
|
mikeee/dapr
|
tests/perf/utils/helpers.go
|
GO
|
mit
| 4,044 |
/*
Copyright 2021 The Dapr Authors
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.
*/
package utils
import (
"bytes"
"fmt"
"io"
"net"
"net/http"
"strings"
"time"
)
const (
// DefaultProbeTimeout is the a timeout used in HTTPGetNTimes() and
// HTTPGetRawNTimes() to avoid cases where early requests hang and
// block all subsequent requests.
DefaultProbeTimeout = 30 * time.Second
)
var httpClient *http.Client
func init() {
httpClient = &http.Client{
Transport: &http.Transport{
Dial: (&net.Dialer{
Timeout: DefaultProbeTimeout,
}).Dial,
},
}
}
// HTTPGetNTimes calls the url n times and returns the first success or last error.
func HTTPGetNTimes(url string, n int) ([]byte, error) {
var res []byte
var err error
for i := n - 1; i >= 0; i-- {
res, err = HTTPGet(url)
if err == nil {
return res, nil
}
if i == 0 {
break
}
time.Sleep(time.Second)
}
return res, err
}
// HTTPGet is a helper to make GET request call to url
func HTTPGet(url string) ([]byte, error) {
resp, err := httpClient.Get(sanitizeHTTPURL(url))
if err != nil {
return nil, err
}
defer resp.Body.Close()
return extractBody(resp.Body)
}
// HTTPPost is a helper to make POST request call to url
func HTTPPost(url string, data []byte) ([]byte, error) {
resp, err := httpClient.Post(sanitizeHTTPURL(url), "application/json", bytes.NewBuffer(data))
if err != nil {
return nil, err
}
defer resp.Body.Close()
return extractBody(resp.Body)
}
// HTTPDelete calls a given URL with the HTTP DELETE method.
func HTTPDelete(url string) ([]byte, error) {
req, err := http.NewRequest(http.MethodDelete, sanitizeHTTPURL(url), nil)
if err != nil {
return nil, err
}
res, err := httpClient.Do(req)
if err != nil {
return nil, err
}
defer res.Body.Close()
body, err := extractBody(res.Body)
if err != nil {
return nil, err
}
return body, nil
}
func sanitizeHTTPURL(url string) string {
if !strings.Contains(url, "http") {
url = fmt.Sprintf("http://%s", url)
}
return url
}
func extractBody(r io.ReadCloser) ([]byte, error) {
body, err := io.ReadAll(r)
if err != nil {
return nil, err
}
return body, nil
}
|
mikeee/dapr
|
tests/perf/utils/http.go
|
GO
|
mit
| 2,641 |
//go:build perf
// +build perf
/*
Copyright 2021 The Dapr Authors
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.
*/
package utils
import (
"io"
"log"
"os"
"path/filepath"
"time"
)
// SetupLogs sets up the target for the built-in "log" package.
// Logs are always written to STDOUT.
// If the DAPR_TEST_LOG_PATH environmental variable is set, logs are also written to a file in that folder.
func SetupLogs(testName string) {
logPath := os.Getenv("DAPR_TEST_LOG_PATH")
if logPath != "" {
err := os.MkdirAll(logPath, os.ModePerm)
if err != nil {
log.Printf("Failed to create output log directory '%s' Error was: '%s'", logPath, err)
return
}
date := time.Now().Format("20060102_150405")
target := filepath.Join(logPath, testName+"_"+date+".log")
logFile, err := os.OpenFile(target, os.O_CREATE|os.O_TRUNC|os.O_RDWR, 0o666)
if err != nil {
log.Printf("Failed to open log file '%s' Error was: '%s'", target, err)
return
}
log.Printf("Saving test %s logs to %s", testName, target)
log.SetOutput(io.MultiWriter(os.Stdout, logFile))
}
}
|
mikeee/dapr
|
tests/perf/utils/logging.go
|
GO
|
mit
| 1,549 |
//go:build perf
// +build perf
/*
Copyright 2023 The Dapr Authors
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.
*/
package utils
import (
"log"
"os"
"github.com/prometheus/client_golang/prometheus"
"github.com/prometheus/client_golang/prometheus/push"
)
type DaprMetrics struct {
BaselineLatency float64
DaprLatency float64
AddedLatency float64
SidecarCPU int64
AppCPU int64
SidecarMemory float64
AppMemory float64
ApplicationThroughput float64
}
// DAPR_PERF_METRICS_PROMETHEUS_PUSHGATEWAY_URL needs to be set
func PushPrometheusMetrics(metrics DaprMetrics, perfTest, component string) {
prometheusPushgatewayURL := os.Getenv("DAPR_PERF_METRICS_PROMETHEUS_PUSHGATEWAY_URL")
if prometheusPushgatewayURL == "" {
log.Println("DAPR_PERF_METRICS_PROMETHEUS_PUSHGATEWAY_URL is not set, skipping pushing perf test metrics to Prometheus Pushgateway")
return
}
// Create and register the dapr metrics required
baselineLatencyGauge := prometheus.NewGauge(prometheus.GaugeOpts{
Name: "BASELINE_RESPONSE_TIME",
Help: "Average Response Time of Baseline Test",
})
daprLatencyGauge := prometheus.NewGauge(prometheus.GaugeOpts{
Name: "DAPR_RESPONSE_TIME",
Help: "Average Respone Time of Dapr Test",
})
addedLatencyGauge := prometheus.NewGauge(prometheus.GaugeOpts{
Name: "LATENCY_BY_DAPR",
Help: "Added Latency by Dapr Sidecar",
})
appCpuGauge := prometheus.NewGauge(prometheus.GaugeOpts{
Name: "APP_CPU_USAGE",
Help: "CPU Usage by app",
})
sidecarCpuGauge := prometheus.NewGauge(prometheus.GaugeOpts{
Name: "DAPR_SIDECAR_CPU_USAGE",
Help: "CPU Usage by Dapr Sidecar",
})
appMemoryGauge := prometheus.NewGauge(prometheus.GaugeOpts{
Name: "APP_MEMORY_USAGE",
Help: "Memory Usage by app",
})
sidecarMemoryGauge := prometheus.NewGauge(prometheus.GaugeOpts{
Name: "DAPR_SIDECAR_MEMORY_USAGE",
Help: "Memory Usage by Dapr Sidecar",
})
applicationThroughputGauge := prometheus.NewGauge(prometheus.GaugeOpts{
Name: "APPLICATION_THROUGHPUT",
Help: "Actual QPS",
})
// Create a pusher to push metrics to the Prometheus Pushgateway
pusher := push.New(prometheusPushgatewayURL, perfTest).
Collector(baselineLatencyGauge).
Collector(daprLatencyGauge).
Collector(addedLatencyGauge).
Collector(appCpuGauge).
Collector(sidecarCpuGauge).
Collector(appMemoryGauge).
Collector(sidecarMemoryGauge).
Collector(applicationThroughputGauge).
Grouping("perf_test", perfTest)
// Add the component Grouping only if specified
if len(component) > 0 {
pusher.Grouping("component", component)
}
// Set username and password if specified
prometheusPushgatewayUsername := os.Getenv("DAPR_PERF_METRICS_PROMETHEUS_PUSHGATEWAY_USERNAME")
prometheusPushgatewayPassword := os.Getenv("DAPR_PERF_METRICS_PROMETHEUS_PUSHGATEWAY_PASSWORD")
if len(prometheusPushgatewayUsername) > 0 && len(prometheusPushgatewayPassword) > 0 {
pusher.BasicAuth(prometheusPushgatewayUsername, prometheusPushgatewayPassword)
}
// Set the dapr_metrics values to the Gauges created
baselineLatencyGauge.Set(metrics.BaselineLatency)
daprLatencyGauge.Set(metrics.DaprLatency)
addedLatencyGauge.Set(metrics.AddedLatency)
appCpuGauge.Set(float64(metrics.AppCPU))
sidecarCpuGauge.Set(float64(metrics.SidecarCPU))
appMemoryGauge.Set(metrics.AppMemory)
sidecarMemoryGauge.Set(metrics.SidecarMemory)
applicationThroughputGauge.Set(metrics.ApplicationThroughput)
// Push the metrics value to the Pushgateway
if err := pusher.Push(); err != nil {
log.Println("Failed to push perf test metrics to Prometheus Pushgateway:", err)
}
}
|
mikeee/dapr
|
tests/perf/utils/prometheus_metrics.go
|
GO
|
mit
| 4,117 |
# Dapr Workflows Performance Tests
This project aims to test the performance of Dapr workflows under various conditions.
## Glossary
VU (Virtual User): The number of concurrent workflows running at a time
Iterations: Total number of workflow runs
Req_Duration: Time taken to complete a workflow run.
Sidecar: Dapr Sidecar
## Test plan
For the test, a single instance of an application with Dapr sidecar was deployed on AKS and then different workflows were created using K6 framework. For each of the tests, app memory as well as Dapr sidecar memory limit was capped at 800 Mb.
### TestWorkflowWithConstantVUs
Workflow Description
* Contains 5 chained activities
* Each activity performs numeric calculation and the result is sent back to workflow
Test Description
* Run workflow with concurrency of 50 and total runs 500
* Calculate memory and cpu usage after the run
* Run the whole set again (total 5 times) without restarting the application
* Monitor sidecar memory and cpu usage after each set
### TestWorkflowWithConstantIterations
Workflow Description
* Contains 5 chained activities
* Each activity performs numeric calculation and the result is sent back to workflow.
Test Description
* Run workflow with concurrency of 50 and total runs 500
* Restart the application
* Run worklfow with concurrency of 100 and total runs 500
* Restart the application
* Run worklfow with concurrency of 150 and total runs 500
* Monitor memory/cpu usage as well as req_duration(time taken to complete a workflow) after each set
### TestSeriesWorkflowWithMaxVUs
Workflow Description
* Contains 5 chained activities
* Each activity performs numeric calculation and the result is sent back to workflow
Test Description
* Run workflow with concurrency of 500 and for total runs 3000
* Verify there are no errors and all workflow runs pass
* Monitor memory/cpu usage as well as req_duration(time taken to complete a workflow) after the run
### TestParallelWorkflowWithMaxVUs
Workflow Description
* Contains 5 activities in parallel
* Each activity performs numeric calculation and the result is aggregated at the workflow
Test Description
* Run workflow with concurrency of 110 and total runs 550
* Verify there are no errors and all workflow runs pass
* Monitor memory/cpu usage as well as req_duration(time taken to complete a workflow) after the run
### TestWorkflowWithDifferentPayloads
* Contains 3 activities in series
* Activity 1 saves data of given size in the configured statestore
* Activity 2 gets saved data from the statestore using key
* Activity 3 deletes data from the statestore
* Workflow takes data size as input and passes a string of that size as payload to the activity
Test Description
* Run workflow with payload size of 10KB with concurrency of 50 and total runs 500
* Restart the application
* Run workflow with payload size of 50KB with concurrency of 50 and total runs 500
* Restart the application
* Run workflow with payload size of 100KB with concurrency of 50 and total runs 500
* Monitor memory usage after each run
|
mikeee/dapr
|
tests/perf/workflows/README.md
|
Markdown
|
mit
| 3,068 |
/*
Copyright 2023 The Dapr Authors
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.
*/
import http from 'k6/http'
import exec from 'k6/execution'
import { check } from 'k6'
const possibleScenarios = {
t_30_300: {
executor: 'shared-iterations',
vus: 30,
iterations: 300,
maxDuration: '200s',
},
t_60_300: {
executor: 'shared-iterations',
vus: 60,
iterations: 300,
maxDuration: '380s',
},
t_90_300: {
executor: 'shared-iterations',
vus: 90,
iterations: 300,
maxDuration: '380s',
},
t_350_1400: {
executor: 'shared-iterations',
vus: 350,
iterations: 1400,
maxDuration: '1000s',
},
t_110_440: {
executor: 'shared-iterations',
vus: 110,
iterations: 440,
maxDuration: '450s',
},
t_80_800: {
executor: 'shared-iterations',
vus: 80,
iterations: 800,
maxDuration: '420s',
},
}
let enabledScenarios = {}
enabledScenarios[__ENV.SCENARIO] = possibleScenarios[__ENV.SCENARIO]
export const options = {
discardResponseBodies: true,
thresholds: {
checks: [__ENV.RATE_CHECK],
},
scenarios: enabledScenarios,
}
const DAPR_ADDRESS = `http://127.0.0.1:${__ENV.DAPR_HTTP_PORT}`
function execute() {
console.log(
'Executing the execute function with idInTest: ' +
`${exec.scenario.iterationInTest}`
)
let data = JSON.stringify({
workflow_name: __ENV.WORKFLOW_NAME,
workflow_input: __ENV.WORKFLOW_INPUT,
})
let params = {
headers: {
'Content-Type': 'application/json',
},
timeout: '250s',
}
const res = http.post(
`${__ENV.TARGET_URL}/${exec.scenario.iterationInTest}`,
data,
params
)
console.log('http response', JSON.stringify(res))
return res
}
export default function () {
let result = execute()
check(result, {
'response code was 2xx': (result) =>
result.status >= 200 && result.status < 300,
})
}
export function teardown(_) {
const shutdownResult = http.post(`${DAPR_ADDRESS}/v1.0/shutdown`)
check(shutdownResult, {
'shutdown response status code is 2xx':
shutdownResult.status >= 200 && shutdownResult.status < 300,
})
}
export function handleSummary(data) {
return {
stdout: JSON.stringify(data),
}
}
|
mikeee/dapr
|
tests/perf/workflows/test.js
|
JavaScript
|
mit
| 2,949 |
//go:build perf
// +build perf
/*
Copyright 2023 The Dapr Authors
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.
*/
package workflows
import (
"encoding/json"
"fmt"
"log"
"os"
"strconv"
"strings"
"testing"
"time"
"github.com/dapr/dapr/tests/perf/utils"
kube "github.com/dapr/dapr/tests/platforms/kubernetes"
"github.com/dapr/dapr/tests/runner"
"github.com/dapr/dapr/tests/runner/loadtest"
"github.com/dapr/dapr/tests/runner/summary"
"github.com/stretchr/testify/require"
)
var tr *runner.TestRunner
var appNamePrefix = "perf-workflowsapp"
type K6RunConfig struct {
TARGET_URL string
SCENARIO string
WORKFLOW_NAME string
WORKFLOW_INPUT string
RATE_CHECK string
}
func TestMain(m *testing.M) {
backend := os.Getenv("DAPR_PERF_WORKFLOW_BACKEND_NAME")
utils.SetupLogs("workflow_test")
testApps := []kube.AppDescription{
{
AppName: appNamePrefix + backend,
DaprEnabled: true,
ImageName: "perf-workflowsapp",
Replicas: 1,
IngressEnabled: true,
IngressPort: 3000,
MetricsEnabled: true,
DaprMemoryLimit: "800Mi",
DaprMemoryRequest: "800Mi",
AppMemoryLimit: "800Mi",
AppMemoryRequest: "800Mi",
AppPort: -1,
},
}
comps := []kube.ComponentDescription{}
if backend == "sqlite" {
comps = getSqliteBackendComp(comps, backend)
}
tr = runner.NewTestRunner("workflow_test", testApps, comps, nil)
os.Exit(tr.Start(m))
}
func getSqliteBackendComp(comps []kube.ComponentDescription, backend string) []kube.ComponentDescription {
comps = append(comps, kube.ComponentDescription{
Name: "sqlitebackend",
TypeName: "workflowbackend.sqlite",
MetaData: map[string]kube.MetadataValue{
"connectionString": {Raw: `""`},
},
Scopes: []string{appNamePrefix + backend},
})
return comps
}
func runk6test(t *testing.T, config K6RunConfig) *loadtest.K6RunnerMetricsSummary {
k6Test := loadtest.NewK6(
"./test.js",
loadtest.WithParallelism(1),
// loadtest.EnableLog(), // uncomment this to enable k6 logs, this however breaks reporting, only for debugging.
loadtest.WithRunnerEnvVar("TARGET_URL", config.TARGET_URL),
loadtest.WithRunnerEnvVar("SCENARIO", config.SCENARIO),
loadtest.WithRunnerEnvVar("WORKFLOW_NAME", config.WORKFLOW_NAME),
loadtest.WithRunnerEnvVar("WORKFLOW_INPUT", config.WORKFLOW_INPUT),
loadtest.WithRunnerEnvVar("RATE_CHECK", config.RATE_CHECK),
)
defer k6Test.Dispose()
t.Log("running the k6 load test...")
require.NoError(t, tr.Platform.LoadTest(k6Test))
sm, err := loadtest.K6ResultDefault(k6Test)
require.NoError(t, err)
require.NotNil(t, sm)
bts, err := json.MarshalIndent(sm, "", " ")
require.NoError(t, err)
require.True(t, sm.Pass, fmt.Sprintf("test has not passed, results %s", string(bts)))
t.Logf("test summary `%s`", string(bts))
return sm.RunnersResults[0]
}
func addTestResults(t *testing.T, testName string, testAppName string, result *loadtest.K6RunnerMetricsSummary, table *summary.Table) *summary.Table {
appUsage, err := tr.Platform.GetAppUsage(testAppName)
require.NoError(t, err)
sidecarUsage, err := tr.Platform.GetSidecarUsage(testAppName)
require.NoError(t, err)
restarts, err := tr.Platform.GetTotalRestarts(testAppName)
require.NoError(t, err)
return table.
OutputInt(testName+"VUs Max", result.VusMax.Values.Max).
OutputFloat64(testName+"Iterations Count", result.Iterations.Values.Count).
Outputf(testName+"App Memory", "%vMb", appUsage.MemoryMb).
Outputf(testName+"App CPU", "%vm", appUsage.CPUm).
Outputf(testName+"Sidecar Memory", "%vMb", sidecarUsage.MemoryMb).
Outputf(testName+"Sidecar CPU", "%vm", sidecarUsage.CPUm).
OutputInt(testName+"Restarts", restarts).
OutputK6Trend(testName+"Req Duration", "ms", result.HTTPReqDuration).
OutputK6Trend(testName+"Req Waiting", "ms", result.HTTPReqWaiting).
OutputK6Trend(testName+"Iteration Duration", "ms", result.IterationDuration)
}
// Runs the test for `workflowName` workflow with different inputs and different scenarios
// inputs are the different workflow inputs/payload_sizes for which workflows are run
// scenarios are the different combinations of {VU,iterations} for which tests are run
// rateChecks[index1][index2] represents the check required for the run with input=inputs[index1] and scenario=scenarios[index2]
func testWorkflow(t *testing.T, workflowName string, testAppName string, inputs []string, scenarios []string, rateChecks [][]string, restart bool, payloadTest bool) {
table := summary.ForTest(t)
for index1, input := range inputs {
for index2, scenario := range scenarios {
subTestName := "[" + strings.ToUpper(scenario) + "]: "
t.Run(subTestName, func(t *testing.T) {
// Re-starting the app to clear previous run's memory
if restart {
log.Printf("Restarting app %s", testAppName)
err := tr.Platform.Restart(testAppName)
require.NoError(t, err, "Error restarting the app")
}
// Get the ingress external url of test app
log.Println("acquiring app external URL")
externalURL := tr.Platform.AcquireAppExternalURL(testAppName)
require.NotEmpty(t, externalURL, "external URL must not be empty")
// Check if test app endpoint is available
require.NoError(t, utils.HealthCheckApps(externalURL))
time.Sleep(5 * time.Second)
// Initialize the workflow runtime
url := fmt.Sprintf("http://%s/start-workflow-runtime", externalURL)
// Calling start-workflow-runtime multiple times so that it is started in all app instances
_, err := utils.HTTPGet(url)
require.NoError(t, err, "error starting workflow runtime")
time.Sleep(5 * time.Second)
targetURL := fmt.Sprintf("http://%s/run-workflow", externalURL)
config := K6RunConfig{
TARGET_URL: targetURL,
SCENARIO: scenario,
WORKFLOW_NAME: workflowName,
WORKFLOW_INPUT: input,
RATE_CHECK: rateChecks[index1][index2],
}
testResult := runk6test(t, config)
if payloadTest {
payloadSize, _ := strconv.Atoi(input)
table = table.Outputf(subTestName+"Payload Size", "%dKB", int(payloadSize/1000))
}
table = addTestResults(t, subTestName, testAppName, testResult, table)
time.Sleep(5 * time.Second)
// Stop the workflow runtime
url = fmt.Sprintf("http://%s/shutdown-workflow-runtime", externalURL)
_, err = utils.HTTPGet(url)
require.NoError(t, err, "error shutdown workflow runtime")
})
}
}
err := table.Flush()
require.NoError(t, err, "error storing test results")
}
// Runs tests for `sum_series_wf` with constant VUs
func TestWorkflowWithConstantVUs(t *testing.T) {
workflowName := "sum_series_wf"
inputs := []string{"100"}
scenarios := []string{"t_30_300", "t_30_300", "t_30_300"}
rateChecks := [][]string{{"rate==1", "rate==1", "rate==1"}}
testWorkflow(t, workflowName, appNamePrefix, inputs, scenarios, rateChecks, false, false)
}
func TestWorkflowWithConstantIterations(t *testing.T) {
workflowName := "sum_series_wf"
inputs := []string{"100"}
scenarios := []string{"t_30_300", "t_60_300", "t_90_300"}
rateChecks := [][]string{{"rate==1", "rate==1", "rate==1"}}
testWorkflow(t, workflowName, appNamePrefix, inputs, scenarios, rateChecks, true, false)
}
// Runs tests for `sum_series_wf` with Max VUs
func TestSeriesWorkflowWithMaxVUs(t *testing.T) {
workflowName := "sum_series_wf"
inputs := []string{"100"}
scenarios := []string{"t_350_1400"}
rateChecks := [][]string{{"rate==1"}}
testWorkflow(t, workflowName, appNamePrefix, inputs, scenarios, rateChecks, true, false)
}
// Runs tests for `sum_parallel_wf` with Max VUs
func TestParallelWorkflowWithMaxVUs(t *testing.T) {
workflowName := "sum_parallel_wf"
inputs := []string{"100"}
scenarios := []string{"t_110_440"}
rateChecks := [][]string{{"rate==1"}}
testWorkflow(t, workflowName, appNamePrefix, inputs, scenarios, rateChecks, true, false)
}
// Runs tests for `state_wf` with different Payload
func TestWorkflowWithDifferentPayloads(t *testing.T) {
workflowName := "state_wf"
scenarios := []string{"t_30_300"}
inputs := []string{"10000", "50000", "100000"}
rateChecks := [][]string{{"rate==1"}, {"rate==1"}, {"rate==1"}}
testWorkflow(t, workflowName, appNamePrefix, inputs, scenarios, rateChecks, true, true)
}
|
mikeee/dapr
|
tests/perf/workflows/workflow_test.go
|
GO
|
mit
| 8,735 |
/*
Copyright 2021 The Dapr Authors
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.
*/
package kubernetes
import (
"encoding/json"
"os"
apiv1 "k8s.io/api/core/v1"
"github.com/dapr/kit/utils"
)
const (
// useServiceInternalIP is used to identify wether the connection between the kubernetes platform could be made using its internal ips.
useServiceInternalIP = "TEST_E2E_USE_INTERNAL_IP"
)
// AppDescription holds the deployment information of test app.
type AppDescription struct {
AppName string `json:",omitempty"`
AppPort int `json:",omitempty"`
AppProtocol string `json:",omitempty"`
AppEnv map[string]string `json:",omitempty"`
AppVolumeMounts []apiv1.VolumeMount `json:",omitempty"`
DaprEnabled bool `json:",omitempty"`
DebugLoggingEnabled bool `json:",omitempty"`
ImageName string `json:",omitempty"`
ImageSecret string `json:",omitempty"`
SidecarImage string `json:",omitempty"`
RegistryName string `json:",omitempty"`
Replicas int32 `json:",omitempty"`
IngressEnabled bool `json:",omitempty"`
IngressPort int `json:",omitempty"` // Defaults to AppPort if empty
MetricsEnabled bool `json:",omitempty"` // This controls the setting for the dapr.io/enable-metrics annotation
MetricsPort string `json:",omitempty"`
Config string `json:",omitempty"`
AppCPULimit string `json:",omitempty"`
AppCPURequest string `json:",omitempty"`
AppMemoryLimit string `json:",omitempty"`
AppMemoryRequest string `json:",omitempty"`
DaprCPULimit string `json:",omitempty"`
DaprCPURequest string `json:",omitempty"`
DaprMemoryLimit string `json:",omitempty"`
DaprMemoryRequest string `json:",omitempty"`
DaprEnv string `json:",omitempty"`
UnixDomainSocketPath string `json:",omitempty"`
Namespace *string `json:",omitempty"`
IsJob bool `json:",omitempty"`
SecretStoreDisable bool `json:",omitempty"`
DaprVolumeMounts string `json:",omitempty"`
Labels map[string]string `json:",omitempty"` // Adds custom labels to pods
PodAffinityLabels map[string]string `json:",omitempty"` // If set, adds a podAffinity rule matching those labels
Tolerations []apiv1.Toleration `json:",omitempty"` // If set, adds tolerations to the pod
NodeSelectors []apiv1.NodeSelectorRequirement `json:",omitempty"` // If set, adds additional node selector requirements to the pod (note that os/arch are set automatically)
Volumes []apiv1.Volume `json:",omitempty"`
InitContainers []apiv1.Container `json:",omitempty"`
PluggableComponents []apiv1.Container `json:",omitempty"`
InjectPluggableComponents bool `json:",omitempty"`
PlacementAddresses []string `json:",omitempty"`
EnableAppHealthCheck bool `json:",omitempty"`
AppHealthCheckPath string `json:",omitempty"`
AppHealthProbeInterval int `json:",omitempty"` // In seconds
AppHealthProbeTimeout int `json:",omitempty"` // In milliseconds
AppHealthThreshold int `json:",omitempty"`
AppChannelAddress string `json:",omitempty"`
MaxRequestSizeMB int `json:",omitempty"`
}
func (a AppDescription) String() string {
// AppDescription objects can contain credentials in ImageSecret which should not be exposed in logs.
// This method overrides the default stringifier to use the custom JSON stringifier which hides ImageSecret
j, _ := json.Marshal(a)
return string(j)
}
// ShouldBeExposed returns if the app should be exposed as a loadbalancer/nodeport service.
func (a AppDescription) ShouldBeExposed() bool {
return a.IngressEnabled && !utils.IsTruthy(os.Getenv(useServiceInternalIP))
}
func (a AppDescription) MarshalJSON() ([]byte, error) {
imageSecret := a.ImageSecret
if imageSecret != "" {
imageSecret = "***"
}
type Alias AppDescription
return json.Marshal(&struct {
ImageSecret string `json:",omitempty"`
*Alias
}{
Alias: (*Alias)(&a),
ImageSecret: imageSecret,
})
}
|
mikeee/dapr
|
tests/platforms/kubernetes/app_description.go
|
GO
|
mit
| 5,883 |
/*
Copyright 2021 The Dapr Authors
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.
*/
package kubernetes
import (
"os"
"reflect"
"testing"
)
func TestAppDescription_MarshalJSON(t *testing.T) {
t.Run("no secret", func(t *testing.T) {
a := AppDescription{
AppName: "testapp",
ImageSecret: "",
}
want := `{"AppName":"testapp"}`
res, err := a.MarshalJSON()
if err != nil {
t.Errorf("AppDescription.MarshalJSON() error = %v", err)
return
}
if !reflect.DeepEqual(string(res), want) {
t.Errorf("AppDescription.MarshalJSON() = %v, want %v", string(res), want)
}
})
t.Run("hide secret", func(t *testing.T) {
a := AppDescription{
AppName: "testapp",
ImageSecret: "SECRETVALUE",
}
want := `{"ImageSecret":"***","AppName":"testapp"}`
res, err := a.MarshalJSON()
if err != nil {
t.Errorf("AppDescription.MarshalJSON() error = %v", err)
return
}
if !reflect.DeepEqual(string(res), want) {
t.Errorf("AppDescription.MarshalJSON() = %v, want %v", string(res), want)
}
})
t.Run("use service internal ip", func(t *testing.T) {
defer os.Clearenv()
app := AppDescription{
IngressEnabled: true,
}
os.Setenv(useServiceInternalIP, "false")
if !app.ShouldBeExposed() {
t.Error("AppDescription.ShouldBeExposed() should evaluate to true when ingress is enabled and internal ip should not be used")
}
os.Setenv(useServiceInternalIP, "true")
if app.ShouldBeExposed() {
t.Error("AppDescription.ShouldBeExposed() should evaluate to false when internal ip should be used")
}
})
}
|
mikeee/dapr
|
tests/platforms/kubernetes/app_description_test.go
|
GO
|
mit
| 2,035 |
/*
Copyright 2021 The Dapr Authors
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.
*/
package kubernetes
import (
"context"
"encoding/json"
"fmt"
"log"
"os"
"time"
appsv1 "k8s.io/api/apps/v1"
batchv1 "k8s.io/api/batch/v1"
apiv1 "k8s.io/api/core/v1"
"k8s.io/apimachinery/pkg/api/errors"
"k8s.io/apimachinery/pkg/api/resource"
metav1 "k8s.io/apimachinery/pkg/apis/meta/v1"
"k8s.io/apimachinery/pkg/util/wait"
)
const (
// MiniKubeIPEnvVar is the environment variable name which will have Minikube node IP.
MiniKubeIPEnvVar = "DAPR_TEST_MINIKUBE_IP"
// ContainerLogPathEnvVar is the environment variable name which will have the container logs.
ContainerLogPathEnvVar = "DAPR_CONTAINER_LOG_PATH"
// ContainerLogDefaultPath.
ContainerLogDefaultPath = "./container_logs"
// PollInterval is how frequently e2e tests will poll for updates.
PollInterval = 1 * time.Second
// PollTimeout is how long e2e tests will wait for resource updates when polling.
PollTimeout = 8 * time.Minute
// maxReplicas is the maximum replicas of replica sets.
maxReplicas = 10
// maxSideCarDetectionRetries is the maximum number of retries to detect Dapr sidecar.
maxSideCarDetectionRetries = 3
)
// AppManager holds Kubernetes clients and namespace used for test apps
// and provides the helpers to manage the test apps.
type AppManager struct {
client *KubeClient
namespace string
app AppDescription
ctx context.Context
forwarder *PodPortForwarder
logPrefix string
}
// PodInfo holds information about a given pod.
type PodInfo struct {
Name string
IP string
}
// NewAppManager creates AppManager instance.
func NewAppManager(client *KubeClient, namespace string, app AppDescription) *AppManager {
return &AppManager{
client: client,
namespace: namespace,
app: app,
ctx: context.Background(),
}
}
// Name returns app name.
func (m *AppManager) Name() string {
return m.app.AppName
}
// App returns app description.
func (m *AppManager) App() AppDescription {
return m.app
}
// Init installs app by AppDescription.
func (m *AppManager) Init(runCtx context.Context) error {
m.ctx = runCtx
// TODO: Dispose app if option is required
if err := m.Dispose(true); err != nil {
return err
}
m.logPrefix = logPrefix
if err := os.MkdirAll(m.logPrefix, os.ModePerm); err != nil {
log.Printf("Failed to create output log directory '%s' Error was: '%s'. Container logs will be discarded", m.logPrefix, err)
m.logPrefix = ""
}
log.Printf("Deploying app %v ...", m.app.AppName)
if m.app.IsJob {
// Deploy app and wait until deployment is done
if _, err := m.ScheduleJob(); err != nil {
return err
}
// Wait until app is deployed completely
if _, err := m.WaitUntilJobState(m.IsJobCompleted); err != nil {
return err
}
} else {
// Deploy app and wait until deployment is done
if _, err := m.Deploy(); err != nil {
return err
}
// Wait until app is deployed completely
if _, err := m.WaitUntilDeploymentState(m.IsDeploymentDone); err != nil {
return err
}
}
log.Printf("App %v has been deployed.", m.app.AppName)
if m.logPrefix != "" {
if err := m.StreamContainerLogs(); err != nil {
log.Printf("Failed to retrieve container logs for %s. Error was: %s", m.app.AppName, err)
}
}
if !m.app.IsJob {
// Job cannot have side car validated because it is shutdown on successful completion.
if m.app.DaprEnabled {
log.Printf("Validating sidecar for app %v ....", m.app.AppName)
for i := 0; i <= maxSideCarDetectionRetries; i++ {
// Validate daprd side car is injected
if err := m.ValidateSidecar(); err != nil {
if i == maxSideCarDetectionRetries {
return err
}
log.Printf("Did not find sidecar for app %v error %s, retrying ....", m.app.AppName, err)
time.Sleep(10 * time.Second)
continue
}
break
}
log.Printf("Sidecar for app %v has been validated.", m.app.AppName)
}
// Create Ingress endpoint
log.Printf("Creating ingress for app %v ....", m.app.AppName)
if _, err := m.CreateIngressService(); err != nil {
return err
}
log.Printf("Ingress for app %v has been created.", m.app.AppName)
log.Printf("Creating pod port forwarder for app %v ....", m.app.AppName)
m.forwarder = NewPodPortForwarder(m.client, m.namespace)
log.Printf("Pod port forwarder for app %v has been created.", m.app.AppName)
}
return nil
}
// Dispose deletes deployment and service.
func (m *AppManager) Dispose(wait bool) error {
if m.app.IsJob {
if err := m.DeleteJob(true); err != nil {
return err
}
} else {
if err := m.DeleteDeployment(true); err != nil {
return err
}
}
if err := m.DeleteService(true); err != nil {
return err
}
if wait {
if m.app.IsJob {
if _, err := m.WaitUntilJobState(m.IsJobDeleted); err != nil {
return err
}
} else {
if _, err := m.WaitUntilDeploymentState(m.IsDeploymentDeleted); err != nil {
return err
}
}
if _, err := m.WaitUntilServiceState(m.app.AppName, m.IsServiceDeleted); err != nil {
return err
}
} else {
// Wait 2 seconds for logs to come in
time.Sleep(2 * time.Second)
}
if m.forwarder != nil {
m.forwarder.Close()
}
return nil
}
// ScheduleJob deploys job based on app description.
func (m *AppManager) ScheduleJob() (*batchv1.Job, error) {
jobsClient := m.client.Jobs(m.namespace)
obj := buildJobObject(m.namespace, m.app)
ctx, cancel := context.WithTimeout(m.ctx, time.Minute)
result, err := jobsClient.Create(ctx, obj, metav1.CreateOptions{})
cancel()
if err != nil {
return nil, err
}
return result, nil
}
// WaitUntilJobState waits until isState returns true.
func (m *AppManager) WaitUntilJobState(isState func(*batchv1.Job, error) bool) (*batchv1.Job, error) {
jobsClient := m.client.Jobs(m.namespace)
var lastJob *batchv1.Job
ctx, cancel := context.WithTimeout(m.ctx, PollTimeout)
defer cancel()
waitErr := wait.PollUntilContextCancel(ctx, PollInterval, true, func(ctx context.Context) (bool, error) {
var err error
lastJob, err = jobsClient.Get(ctx, m.app.AppName, metav1.GetOptions{})
done := isState(lastJob, err)
if !done && err != nil {
return true, err
}
return done, nil
})
if waitErr != nil {
// Try to get the logs from the containers that aren't starting, if we can get anything
// We ignore errors here
_ = m.StreamContainerLogs()
return nil, fmt.Errorf("job %q is not in desired state, received: %#v: %s", m.app.AppName, lastJob, waitErr)
}
return lastJob, nil
}
// Deploy deploys app based on app description.
func (m *AppManager) Deploy() (*appsv1.Deployment, error) {
deploymentsClient := m.client.Deployments(m.namespace)
obj := buildDeploymentObject(m.namespace, m.app)
ctx, cancel := context.WithTimeout(m.ctx, time.Minute)
result, err := deploymentsClient.Create(ctx, obj, metav1.CreateOptions{})
cancel()
if err != nil {
return nil, err
}
return result, nil
}
// WaitUntilDeploymentState waits until isState returns true.
func (m *AppManager) WaitUntilDeploymentState(isState func(*appsv1.Deployment, error) bool) (*appsv1.Deployment, error) {
deploymentsClient := m.client.Deployments(m.namespace)
var lastDeployment *appsv1.Deployment
ctx, cancel := context.WithTimeout(m.ctx, PollTimeout)
defer cancel()
waitErr := wait.PollUntilContextCancel(ctx, PollInterval, true, func(ctx context.Context) (bool, error) {
var err error
lastDeployment, err = deploymentsClient.Get(ctx, m.app.AppName, metav1.GetOptions{})
done := isState(lastDeployment, err)
if !done && err != nil {
return true, err
}
return done, nil
})
if waitErr != nil {
// get deployment's Pods detail status info
podClient := m.client.Pods(m.namespace)
// Filter only 'testapp=appName' labeled Pods
ctx, cancel := context.WithTimeout(m.ctx, 30*time.Second)
defer cancel()
podList, err := podClient.List(ctx, metav1.ListOptions{
LabelSelector: fmt.Sprintf("%s=%s", TestAppLabelKey, m.app.AppName),
})
// Reset Spec and ObjectMeta which could contain sensitive info like credentials
lastDeployment.Spec.Reset()
lastDeployment.ObjectMeta.Reset()
podStatus := map[string][]apiv1.ContainerStatus{}
if err == nil {
for i, pod := range podList.Items {
name := pod.Name
podStatus[name] = pod.Status.ContainerStatuses
request := podClient.GetLogs(name, &apiv1.PodLogOptions{
Container: DaprSideCarName,
Previous: true,
})
var body []byte
if body, err = request.DoRaw(context.Background()); err != nil {
log.Printf("(%s) get previous pod log failed. err: %s\n", name, err.Error())
}
log.Printf("previous pod: %s, logs: %s\n", name, string(body))
// Reset Spec and ObjectMeta which could contain sensitive info like credentials
pod.Spec.Reset()
pod.ObjectMeta.Reset()
podList.Items[i] = pod
}
j, _ := json.Marshal(podList)
log.Printf("deployment %s relate pods: %s", m.app.AppName, string(j))
} else {
log.Printf("Error list pod for deployment %s. Error was %s", m.app.AppName, err)
}
// Try to get the logs from the containers that aren't starting, if we can get anything
// We ignore errors here
_ = m.StreamContainerLogs()
return nil, fmt.Errorf("deployment %q is not in desired state, received: %#v pod status: %#v error: %s", m.app.AppName, lastDeployment, podStatus, waitErr)
}
return lastDeployment, nil
}
// WaitUntilSidecarPresent waits until Dapr sidecar is present.
func (m *AppManager) WaitUntilSidecarPresent() error {
ctx, cancel := context.WithTimeout(m.ctx, PollTimeout)
defer cancel()
waitErr := wait.PollUntilContextCancel(ctx, PollInterval, true, func(ctx context.Context) (bool, error) {
allDaprd, minContainerCount, maxContainerCount, err := m.getContainerInfo()
log.Printf(
"Checking if Dapr sidecar is present on app %s (minContainerCount=%d, maxContainerCount=%d, allDaprd=%v): %v ...",
m.app.AppName,
minContainerCount,
maxContainerCount,
allDaprd,
err)
return allDaprd, err
})
if waitErr != nil {
return fmt.Errorf("app %q does not contain Dapr sidecar", m.app.AppName)
}
return nil
}
// IsJobCompleted returns true if job object is complete.
func (m *AppManager) IsJobCompleted(job *batchv1.Job, err error) bool {
return err == nil && job.Status.Succeeded == 1 && job.Status.Failed == 0 && job.Status.Active == 0 && job.Status.CompletionTime != nil
}
// IsDeploymentDone returns true if deployment object completes pod deployments.
func (m *AppManager) IsDeploymentDone(deployment *appsv1.Deployment, err error) bool {
return err == nil &&
deployment.Generation == deployment.Status.ObservedGeneration &&
deployment.Status.ReadyReplicas == m.app.Replicas &&
deployment.Status.AvailableReplicas == m.app.Replicas
}
// IsJobDeleted returns true if job does not exist.
func (m *AppManager) IsJobDeleted(job *batchv1.Job, err error) bool {
return err != nil && errors.IsNotFound(err)
}
// IsDeploymentDeleted returns true if deployment does not exist or current pod replica is zero.
func (m *AppManager) IsDeploymentDeleted(deployment *appsv1.Deployment, err error) bool {
return err != nil && errors.IsNotFound(err)
}
// ValidateSidecar validates that dapr side car is running in dapr enabled pods.
func (m *AppManager) ValidateSidecar() error {
if !m.app.DaprEnabled {
return fmt.Errorf("dapr is not enabled for this app")
}
podClient := m.client.Pods(m.namespace)
// Filter only 'testapp=appName' labeled Pods
ctx, cancel := context.WithTimeout(m.ctx, 30*time.Second)
podList, err := podClient.List(ctx, metav1.ListOptions{
LabelSelector: fmt.Sprintf("%s=%s", TestAppLabelKey, m.app.AppName),
})
cancel()
if err != nil {
return err
}
if len(podList.Items) != int(m.app.Replicas) {
return fmt.Errorf("expected number of pods for %s: %d, received: %d", m.app.AppName, m.app.Replicas, len(podList.Items))
}
// Each pod must have daprd sidecar
for _, pod := range podList.Items {
daprdFound := false
for _, container := range pod.Spec.Containers {
if container.Name == DaprSideCarName {
daprdFound = true
break
}
}
if !daprdFound {
found, _ := json.Marshal(pod.Spec.Containers)
return fmt.Errorf("cannot find dapr sidecar in pod %s. Found containers=%v", pod.Name, string(found))
}
}
return nil
}
// getSidecarInfo returns if sidecar is present and how many containers there are.
func (m *AppManager) getContainerInfo() (bool, int, int, error) {
if !m.app.DaprEnabled {
return false, 0, 0, fmt.Errorf("dapr is not enabled for this app")
}
podClient := m.client.Pods(m.namespace)
// Filter only 'testapp=appName' labeled Pods
ctx, cancel := context.WithTimeout(m.ctx, 30*time.Second)
podList, err := podClient.List(ctx, metav1.ListOptions{
LabelSelector: fmt.Sprintf("%s=%s", TestAppLabelKey, m.app.AppName),
})
cancel()
if err != nil {
return false, 0, 0, err
}
// Each pod must have daprd sidecar
minContainerCount := -1
maxContainerCount := 0
allDaprd := true && (len(podList.Items) > 0)
for _, pod := range podList.Items {
daprdFound := false
containerCount := len(pod.Spec.Containers)
if containerCount < minContainerCount || minContainerCount == -1 {
minContainerCount = containerCount
}
if containerCount > maxContainerCount {
maxContainerCount = containerCount
}
for _, container := range pod.Spec.Containers {
if container.Name == DaprSideCarName {
daprdFound = true
}
}
if !daprdFound {
allDaprd = false
}
}
if minContainerCount < 0 {
minContainerCount = 0
}
return allDaprd, minContainerCount, maxContainerCount, nil
}
// DoPortForwarding performs port forwarding for given podname to access test apps in the cluster.
func (m *AppManager) DoPortForwarding(podName string, targetPorts ...int) ([]int, error) {
podClient := m.client.Pods(m.namespace)
// Filter only 'testapp=appName' labeled Pods
ctx, cancel := context.WithTimeout(m.ctx, 30*time.Second)
podList, err := podClient.List(ctx, metav1.ListOptions{
LabelSelector: fmt.Sprintf("%s=%s", TestAppLabelKey, m.app.AppName),
})
cancel()
if err != nil {
return nil, err
}
name := podName
// if given pod name is empty , pick the first matching pod name
if name == "" {
for _, pod := range podList.Items {
name = pod.Name
break
}
}
return m.forwarder.Connect(name, targetPorts...)
}
// ScaleDeploymentReplica scales the deployment.
func (m *AppManager) ScaleDeploymentReplica(replicas int32) error {
if replicas < 0 || replicas > maxReplicas {
return fmt.Errorf("%d is out of range", replicas)
}
deploymentsClient := m.client.Deployments(m.namespace)
ctx, cancel := context.WithTimeout(m.ctx, 30*time.Second)
scale, err := deploymentsClient.GetScale(ctx, m.app.AppName, metav1.GetOptions{})
cancel()
if err != nil {
return err
}
if scale.Spec.Replicas == replicas {
return nil
}
scale.Spec.Replicas = replicas
m.app.Replicas = replicas
ctx, cancel = context.WithTimeout(m.ctx, 30*time.Second)
_, err = deploymentsClient.UpdateScale(ctx, m.app.AppName, scale, metav1.UpdateOptions{})
cancel()
return err
}
// SetAppEnv sets an environment variable.
func (m *AppManager) SetAppEnv(key, value string) error {
deploymentsClient := m.client.Deployments(m.namespace)
ctx, cancel := context.WithTimeout(m.ctx, 30*time.Second)
deployment, err := deploymentsClient.Get(ctx, m.app.AppName, metav1.GetOptions{})
cancel()
if err != nil {
return err
}
for i, container := range deployment.Spec.Template.Spec.Containers {
if container.Name != DaprSideCarName {
found := false
for j, envName := range deployment.Spec.Template.Spec.Containers[i].Env {
if envName.Name == key {
deployment.Spec.Template.Spec.Containers[i].Env[j].Value = value
found = true
break
}
}
if !found {
deployment.Spec.Template.Spec.Containers[i].Env = append(
deployment.Spec.Template.Spec.Containers[i].Env,
apiv1.EnvVar{
Name: key,
Value: value,
},
)
}
break
}
}
ctx, cancel = context.WithTimeout(m.ctx, 30*time.Second)
_, err = deploymentsClient.Update(ctx, deployment, metav1.UpdateOptions{})
cancel()
return err
}
// CreateIngressService creates Ingress endpoint for test app.
func (m *AppManager) CreateIngressService() (*apiv1.Service, error) {
serviceClient := m.client.Services(m.namespace)
obj := buildServiceObject(m.namespace, m.app)
ctx, cancel := context.WithTimeout(m.ctx, 30*time.Second)
result, err := serviceClient.Create(ctx, obj, metav1.CreateOptions{})
cancel()
if err != nil {
return nil, err
}
return result, nil
}
// AcquireExternalURL gets external ingress endpoint from service when it is ready.
func (m *AppManager) AcquireExternalURL() string {
log.Printf("Waiting until service ingress is ready for %s...\n", m.app.AppName)
svc, err := m.WaitUntilServiceState(m.app.AppName, m.IsServiceIngressReady)
if err != nil {
log.Printf("Service ingress for %s is not ready: %s", m.app.AppName, err)
return ""
}
url := m.AcquireExternalURLFromService(svc)
log.Printf("Service ingress for %s is ready...: url=%s\n", m.app.AppName, url)
return url
}
// WaitUntilServiceState waits until isState returns true.
func (m *AppManager) WaitUntilServiceState(svcName string, isState func(*apiv1.Service, error) bool) (*apiv1.Service, error) {
serviceClient := m.client.Services(m.namespace)
var lastService *apiv1.Service
ctx, cancel := context.WithTimeout(m.ctx, PollTimeout)
defer cancel()
waitErr := wait.PollUntilContextCancel(ctx, PollInterval, true, func(ctx context.Context) (bool, error) {
var err error
lastService, err = serviceClient.Get(ctx, svcName, metav1.GetOptions{})
done := isState(lastService, err)
if !done && err != nil {
log.Printf("wait for %s: %s", svcName, err)
return true, err
}
return done, nil
})
if waitErr != nil {
return lastService, fmt.Errorf("service %q is not in desired state, received: %#v: %s", m.app.AppName, lastService, waitErr)
}
return lastService, nil
}
// AcquireExternalURLFromService gets external url from Service Object.
func (m *AppManager) AcquireExternalURLFromService(svc *apiv1.Service) string {
svcPorts := svc.Spec.Ports
if len(svcPorts) == 0 {
return ""
}
svcFstPort, svcIngress := svcPorts[0], svc.Status.LoadBalancer.Ingress
// the default service address is the internal one
address, port := svc.Spec.ClusterIP, svcFstPort.Port
if svcIngress != nil && len(svcIngress) > 0 {
if svcIngress[0].Hostname != "" {
address = svcIngress[0].Hostname
} else {
address = svcIngress[0].IP
}
// TODO: Support the other local k8s clusters
} else if minikubeExternalIP := m.minikubeNodeIP(); minikubeExternalIP != "" {
// if test cluster is minikube, external ip address is minikube node address
address, port = minikubeExternalIP, svcFstPort.NodePort
}
return fmt.Sprintf("%s:%d", address, port)
}
// IsServiceIngressReady returns true if external ip is available.
func (m *AppManager) IsServiceIngressReady(svc *apiv1.Service, err error) bool {
if err != nil || svc == nil {
return false
}
if svc.Status.LoadBalancer.Ingress != nil && len(svc.Status.LoadBalancer.Ingress) > 0 {
return true
}
if len(svc.Spec.Ports) > 0 {
// TODO: Support the other local k8s clusters
return m.minikubeNodeIP() != "" || !m.app.ShouldBeExposed()
}
return false
}
// IsServiceDeleted returns true if service does not exist.
func (m *AppManager) IsServiceDeleted(svc *apiv1.Service, err error) bool {
return err != nil && errors.IsNotFound(err)
}
func (m *AppManager) minikubeNodeIP() string {
// if you are running the test in minikube environment, DAPR_TEST_MINIKUBE_IP environment variable must be
// minikube cluster IP address from the output of `minikube ip` command
// TODO: Use the better way to get the node ip of minikube
return os.Getenv(MiniKubeIPEnvVar)
}
// DeleteJob deletes job for the test app.
func (m *AppManager) DeleteJob(ignoreNotFound bool) error {
jobsClient := m.client.Jobs(m.namespace)
deletePolicy := metav1.DeletePropagationForeground
ctx, cancel := context.WithTimeout(m.ctx, 30*time.Second)
defer cancel()
if err := jobsClient.Delete(ctx, m.app.AppName, metav1.DeleteOptions{
PropagationPolicy: &deletePolicy,
}); err != nil && (ignoreNotFound && !errors.IsNotFound(err)) {
return err
}
return nil
}
// DeleteDeployment deletes deployment for the test app.
func (m *AppManager) DeleteDeployment(ignoreNotFound bool) error {
deploymentsClient := m.client.Deployments(m.namespace)
deletePolicy := metav1.DeletePropagationForeground
ctx, cancel := context.WithTimeout(m.ctx, 30*time.Second)
defer cancel()
if err := deploymentsClient.Delete(ctx, m.app.AppName, metav1.DeleteOptions{
PropagationPolicy: &deletePolicy,
}); err != nil && (ignoreNotFound && !errors.IsNotFound(err)) {
return err
}
return nil
}
// DeleteService deletes service for the test app.
func (m *AppManager) DeleteService(ignoreNotFound bool) error {
serviceClient := m.client.Services(m.namespace)
deletePolicy := metav1.DeletePropagationForeground
ctx, cancel := context.WithTimeout(m.ctx, 30*time.Second)
defer cancel()
if err := serviceClient.Delete(ctx, m.app.AppName, metav1.DeleteOptions{
PropagationPolicy: &deletePolicy,
}); err != nil && (ignoreNotFound && !errors.IsNotFound(err)) {
return err
}
return nil
}
// GetHostDetails returns the name and IP address of the pods running the app.
func (m *AppManager) GetHostDetails() ([]PodInfo, error) {
if !m.app.DaprEnabled {
return nil, fmt.Errorf("dapr is not enabled for this app")
}
podClient := m.client.Pods(m.namespace)
// Filter only 'testapp=appName' labeled Pods
ctx, cancel := context.WithTimeout(m.ctx, 30*time.Second)
podList, err := podClient.List(ctx, metav1.ListOptions{
LabelSelector: fmt.Sprintf("%s=%s", TestAppLabelKey, m.app.AppName),
})
cancel()
if err != nil {
return nil, err
}
if len(podList.Items) != int(m.app.Replicas) {
return nil, fmt.Errorf("expected number of pods for %s: %d, received: %d", m.app.AppName, m.app.Replicas, len(podList.Items))
}
result := make([]PodInfo, 0, len(podList.Items))
for _, item := range podList.Items {
result = append(result, PodInfo{
Name: item.GetName(),
IP: item.Status.PodIP,
})
}
return result, nil
}
// StreamContainerLogs get container logs for all containers in the pod and saves them to disk.
func (m *AppManager) StreamContainerLogs() error {
return StreamContainerLogsToDisk(m.ctx, m.app.AppName, m.client.Pods(m.namespace))
}
// GetCPUAndMemory returns the Cpu and Memory usage for the dapr app or sidecar.
func (m *AppManager) GetCPUAndMemory(sidecar bool) (int64, float64, error) {
pods, err := m.GetHostDetails()
if err != nil {
return -1, -1, err
}
var maxCPU int64 = -1
var maxMemory float64 = -1
for _, pod := range pods {
podName := pod.Name
ctx, cancel := context.WithTimeout(m.ctx, 30*time.Second)
metrics, err := m.client.MetricsClient.MetricsV1beta1().PodMetricses(m.namespace).Get(ctx, podName, metav1.GetOptions{})
cancel()
if err != nil {
return -1, -1, err
}
for _, c := range metrics.Containers {
isSidecar := c.Name == DaprSideCarName
if isSidecar == sidecar {
mi, _ := c.Usage.Memory().AsInt64()
mb := float64((mi / 1024)) * 0.001024
cpu := c.Usage.Cpu().ScaledValue(resource.Milli)
if cpu > maxCPU {
maxCPU = cpu
}
if mb > maxMemory {
maxMemory = mb
}
}
}
}
if (maxCPU < 0) || (maxMemory < 0) {
return -1, -1, fmt.Errorf("container (sidecar=%v) not found in pods for app %s in namespace %s", sidecar, m.app.AppName, m.namespace)
}
return maxCPU, maxMemory, nil
}
// GetTotalRestarts returns the total number of restarts for the app or sidecar.
func (m *AppManager) GetTotalRestarts() (int, error) {
if !m.app.DaprEnabled {
return 0, fmt.Errorf("dapr is not enabled for this app")
}
podClient := m.client.Pods(m.namespace)
// Filter only 'testapp=appName' labeled Pods
ctx, cancel := context.WithTimeout(m.ctx, 30*time.Second)
podList, err := podClient.List(ctx, metav1.ListOptions{
LabelSelector: fmt.Sprintf("%s=%s", TestAppLabelKey, m.app.AppName),
})
cancel()
if err != nil {
return 0, err
}
restartCount := 0
for _, pod := range podList.Items {
ctx, cancel := context.WithTimeout(m.ctx, 30*time.Second)
pod, err := podClient.Get(ctx, pod.GetName(), metav1.GetOptions{})
cancel()
if err != nil {
return 0, err
}
for _, containerStatus := range pod.Status.ContainerStatuses {
restartCount += int(containerStatus.RestartCount)
}
}
return restartCount, nil
}
|
mikeee/dapr
|
tests/platforms/kubernetes/appmanager.go
|
GO
|
mit
| 25,139 |
/*
Copyright 2021 The Dapr Authors
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.
*/
package kubernetes
import (
"context"
"fmt"
"testing"
"github.com/stretchr/testify/assert"
"github.com/stretchr/testify/require"
autoscalingv1 "k8s.io/api/autoscaling/v1"
"k8s.io/apimachinery/pkg/api/errors"
metav1 "k8s.io/apimachinery/pkg/apis/meta/v1"
"k8s.io/apimachinery/pkg/runtime/schema"
appsv1 "k8s.io/api/apps/v1"
apiv1 "k8s.io/api/core/v1"
"k8s.io/apimachinery/pkg/runtime"
"k8s.io/client-go/kubernetes/fake"
core "k8s.io/client-go/testing"
)
const (
testNamespace = "apputil-test"
getVerb = "get"
createVerb = "create"
updateVerb = "update"
)
func newDefaultFakeClient() *KubeClient {
fakeclient := fake.NewSimpleClientset()
return &KubeClient{
ClientSet: fakeclient,
}
}
func newFakeKubeClient() *KubeClient {
return &KubeClient{
ClientSet: &fake.Clientset{},
}
}
func testAppDescription() AppDescription {
return AppDescription{
AppName: "testapp",
DaprEnabled: true,
ImageName: "helloworld",
RegistryName: "dapriotest",
Replicas: 1,
IngressEnabled: true,
MetricsEnabled: true,
}
}
func TestDeployApp(t *testing.T) {
client := newDefaultFakeClient()
testApp := testAppDescription()
appManager := NewAppManager(client, testNamespace, testApp)
// act
_, err := appManager.Deploy()
require.NoError(t, err)
// assert
deploymentClient := client.Deployments(testNamespace)
deployment, _ := deploymentClient.Get(context.TODO(), testApp.AppName, metav1.GetOptions{})
assert.NotNil(t, deployment)
assert.Equal(t, testApp.AppName, deployment.ObjectMeta.Name)
assert.Equal(t, testNamespace, deployment.ObjectMeta.Namespace)
assert.Equal(t, int32(1), *deployment.Spec.Replicas)
assert.Equal(t, testApp.AppName, deployment.Spec.Selector.MatchLabels["testapp"])
assert.Equal(t, "true", deployment.Spec.Template.ObjectMeta.Annotations["dapr.io/enabled"])
assert.Equal(t, testApp.AppName, deployment.Spec.Template.Spec.Containers[0].Name)
assert.Equal(t, "dapriotest/helloworld", deployment.Spec.Template.Spec.Containers[0].Image)
}
func TestWaitUntilDeploymentState(t *testing.T) {
testApp := testAppDescription()
var createdDeploymentObj *appsv1.Deployment
t.Run("deployment is in done state", func(t *testing.T) {
client := newFakeKubeClient()
getVerbCalled := 0
const expectedGetVerbCalled = 2
// Set up reactor to fake verb
client.ClientSet.(*fake.Clientset).AddReactor(
"*",
"deployments",
func(action core.Action) (bool, runtime.Object, error) {
ns := action.GetNamespace()
assert.Equal(t, testNamespace, ns)
switch action.GetVerb() {
case createVerb:
// return the same deployment object
createdDeploymentObj = action.(core.CreateAction).GetObject().(*appsv1.Deployment)
createdDeploymentObj.Status.ReadyReplicas = 0
createdDeploymentObj.Status.AvailableReplicas = 0
case getVerb:
// set Replicas to the target replicas when WaitUntilDeploymentState called
// get verb 'expectedGetVerbCalled' times
if getVerbCalled == expectedGetVerbCalled {
createdDeploymentObj.Status.ReadyReplicas = testApp.Replicas
createdDeploymentObj.Status.AvailableReplicas = testApp.Replicas
} else {
getVerbCalled++
}
}
return true, createdDeploymentObj, nil
})
appManager := NewAppManager(client, testNamespace, testApp)
// act
_, err := appManager.Deploy()
require.NoError(t, err)
// assert
d, err := appManager.WaitUntilDeploymentState(appManager.IsDeploymentDone)
require.NoError(t, err)
assert.Equal(t, testApp.Replicas, d.Status.ReadyReplicas)
assert.Equal(t, expectedGetVerbCalled, getVerbCalled)
})
t.Run("deployment is in deleted state", func(t *testing.T) {
client := newFakeKubeClient()
getVerbCalled := 0
const expectedGetVerbCalled = 2
// Set up reactor to fake verb
client.ClientSet.(*fake.Clientset).AddReactor(
"*",
"deployments",
func(action core.Action) (bool, runtime.Object, error) {
ns := action.GetNamespace()
assert.Equal(t, testNamespace, ns)
switch action.GetVerb() {
case createVerb:
// return the same deployment object
createdDeploymentObj = action.(core.CreateAction).GetObject().(*appsv1.Deployment)
createdDeploymentObj.Status.Replicas = testApp.Replicas
case getVerb:
// return notfound error when WaitUntilDeploymentState called
// get verb 'expectedGetVerbCalled' times
if getVerbCalled == expectedGetVerbCalled {
err := errors.NewNotFound(
schema.GroupResource{
Group: "fakeGroup",
Resource: "fakeResource",
},
"deployments")
return true, nil, err
}
getVerbCalled++
}
return true, createdDeploymentObj, nil
})
appManager := NewAppManager(client, testNamespace, testApp)
// act
_, err := appManager.Deploy()
require.NoError(t, err)
// assert
d, err := appManager.WaitUntilDeploymentState(appManager.IsDeploymentDeleted)
require.NoError(t, err)
assert.Nil(t, d)
assert.Equal(t, expectedGetVerbCalled, getVerbCalled)
})
}
func TestScaleDeploymentReplica(t *testing.T) {
testApp := testAppDescription()
client := newFakeKubeClient()
// Set up reactor to fake verb
client.ClientSet.(*fake.Clientset).AddReactor(
"*",
"deployments",
func(action core.Action) (bool, runtime.Object, error) {
ns := action.GetNamespace()
assert.Equal(t, testNamespace, ns)
subRs := action.GetSubresource()
assert.Equal(t, "scale", subRs)
var scaleObj *autoscalingv1.Scale
switch action.GetVerb() {
case getVerb:
scaleObj = &autoscalingv1.Scale{
Status: autoscalingv1.ScaleStatus{
Replicas: 1,
},
}
case updateVerb:
scaleObj = &autoscalingv1.Scale{
Status: autoscalingv1.ScaleStatus{
Replicas: 3,
},
}
}
return true, scaleObj, nil
})
appManager := NewAppManager(client, testNamespace, testApp)
t.Run("lower bound check", func(t *testing.T) {
err := appManager.ScaleDeploymentReplica(-1)
require.Error(t, err)
})
t.Run("upper bound check", func(t *testing.T) {
err := appManager.ScaleDeploymentReplica(maxReplicas + 1)
require.Error(t, err)
})
t.Run("same replicas", func(t *testing.T) {
err := appManager.ScaleDeploymentReplica(1)
require.NoError(t, err)
})
t.Run("new replicas", func(t *testing.T) {
err := appManager.ScaleDeploymentReplica(3)
require.NoError(t, err)
})
}
func TestValidateSidecar(t *testing.T) {
testApp := testAppDescription()
objMeta := metav1.ObjectMeta{
Name: testApp.AppName,
Namespace: testNamespace,
Labels: map[string]string{
TestAppLabelKey: testApp.AppName,
},
}
t.Run("Sidecar is injected", func(t *testing.T) {
client := newFakeKubeClient()
// Set up reactor to fake verb
client.ClientSet.(*fake.Clientset).AddReactor(
"list",
"pods",
func(action core.Action) (bool, runtime.Object, error) {
ns := action.GetNamespace()
assert.Equal(t, testNamespace, ns)
singlePod := apiv1.Pod{
ObjectMeta: objMeta,
Spec: apiv1.PodSpec{
Containers: []apiv1.Container{
{
Name: "daprd",
Image: "daprio/daprd:latest",
},
{
Name: testApp.AppName,
Image: fmt.Sprintf("%s/%s", testApp.RegistryName, testApp.ImageName),
},
},
},
}
podList := &apiv1.PodList{
Items: []apiv1.Pod{singlePod},
}
return true, podList, nil
})
appManager := NewAppManager(client, testNamespace, testApp)
err := appManager.ValidateSidecar()
require.NoError(t, err)
})
t.Run("Sidecar is not injected", func(t *testing.T) {
client := newFakeKubeClient()
// Set up reactor to fake verb
client.ClientSet.(*fake.Clientset).AddReactor(
"list",
"pods",
func(action core.Action) (bool, runtime.Object, error) {
ns := action.GetNamespace()
assert.Equal(t, testNamespace, ns)
singlePod := apiv1.Pod{
ObjectMeta: objMeta,
Spec: apiv1.PodSpec{
Containers: []apiv1.Container{
{
Name: testApp.AppName,
Image: fmt.Sprintf("%s/%s", testApp.RegistryName, testApp.ImageName),
},
},
},
}
podList := &apiv1.PodList{
Items: []apiv1.Pod{singlePod},
}
return true, podList, nil
})
appManager := NewAppManager(client, testNamespace, testApp)
err := appManager.ValidateSidecar()
require.Error(t, err)
})
t.Run("Pod is not found", func(t *testing.T) {
client := newFakeKubeClient()
// Set up reactor to fake verb
client.ClientSet.(*fake.Clientset).AddReactor(
"list",
"pods",
func(action core.Action) (bool, runtime.Object, error) {
ns := action.GetNamespace()
assert.Equal(t, testNamespace, ns)
podList := &apiv1.PodList{
Items: []apiv1.Pod{},
}
return true, podList, nil
})
appManager := NewAppManager(client, testNamespace, testApp)
err := appManager.ValidateSidecar()
require.Error(t, err)
})
}
func TestCreateIngressService(t *testing.T) {
testApp := testAppDescription()
t.Run("Ingress is disabled", func(t *testing.T) {
client := newDefaultFakeClient()
testApp.IngressEnabled = false
appManager := NewAppManager(client, testNamespace, testApp)
_, err := appManager.CreateIngressService()
require.NoError(t, err)
// assert
serviceClient := client.Services(testNamespace)
obj, _ := serviceClient.Get(context.TODO(), testApp.AppName, metav1.GetOptions{})
assert.NotNil(t, obj)
assert.Equal(t, testApp.AppName, obj.ObjectMeta.Name)
assert.Equal(t, testNamespace, obj.ObjectMeta.Namespace)
assert.Equal(t, apiv1.ServiceTypeClusterIP, obj.Spec.Type)
})
t.Run("Ingress is enabled", func(t *testing.T) {
client := newDefaultFakeClient()
testApp.IngressEnabled = true
appManager := NewAppManager(client, testNamespace, testApp)
_, err := appManager.CreateIngressService()
require.NoError(t, err)
// assert
serviceClient := client.Services(testNamespace)
obj, _ := serviceClient.Get(context.TODO(), testApp.AppName, metav1.GetOptions{})
assert.NotNil(t, obj)
assert.Equal(t, testApp.AppName, obj.ObjectMeta.Name)
assert.Equal(t, testNamespace, obj.ObjectMeta.Namespace)
assert.Equal(t, apiv1.ServiceTypeLoadBalancer, obj.Spec.Type)
})
}
func TestWaitUntilServiceStateAndGetExternalURL(t *testing.T) {
// fake test values
fakeMinikubeNodeIP := "192.168.0.12"
fakeNodePort := int32(3000)
fakeExternalIP := "10.10.10.100"
testApp := testAppDescription()
t.Run("Minikube environment", func(t *testing.T) {
t.Setenv(MiniKubeIPEnvVar, fakeMinikubeNodeIP)
client := newFakeKubeClient()
// Set up reactor to fake verb
client.ClientSet.(*fake.Clientset).AddReactor(
getVerb,
"services",
func(action core.Action) (bool, runtime.Object, error) {
ns := action.GetNamespace()
assert.Equal(t, testNamespace, ns)
obj := &apiv1.Service{
Spec: apiv1.ServiceSpec{
Ports: []apiv1.ServicePort{
{
NodePort: fakeNodePort,
},
},
},
}
return true, obj, nil
})
appManager := NewAppManager(client, testNamespace, testApp)
svcObj, err := appManager.WaitUntilServiceState(appManager.app.AppName, appManager.IsServiceIngressReady)
require.NoError(t, err)
externalURL := appManager.AcquireExternalURLFromService(svcObj)
assert.Equal(t, externalURL, fmt.Sprintf("%s:%d", fakeMinikubeNodeIP, fakeNodePort))
})
t.Run("Kubernetes environment", func(t *testing.T) {
getVerbCalled := 0
const expectedGetVerbCalled = 2
t.Setenv(MiniKubeIPEnvVar, "")
client := newFakeKubeClient()
// Set up reactor to fake verb
client.ClientSet.(*fake.Clientset).AddReactor(
getVerb,
"services",
func(action core.Action) (bool, runtime.Object, error) {
ns := action.GetNamespace()
assert.Equal(t, testNamespace, ns)
obj := &apiv1.Service{
Spec: apiv1.ServiceSpec{
Ports: []apiv1.ServicePort{},
},
Status: apiv1.ServiceStatus{
LoadBalancer: apiv1.LoadBalancerStatus{
Ingress: []apiv1.LoadBalancerIngress{},
},
},
}
if getVerbCalled == expectedGetVerbCalled {
obj.Status.LoadBalancer.Ingress = []apiv1.LoadBalancerIngress{
{
IP: fakeExternalIP,
},
}
obj.Spec.Ports = []apiv1.ServicePort{
{
Port: fakeNodePort,
},
}
} else {
getVerbCalled++
}
return true, obj, nil
})
appManager := NewAppManager(client, testNamespace, testApp)
svcObj, err := appManager.WaitUntilServiceState(appManager.app.AppName, appManager.IsServiceIngressReady)
require.NoError(t, err)
externalURL := appManager.AcquireExternalURLFromService(svcObj)
assert.Equal(t, fmt.Sprintf("%s:%d", fakeExternalIP, fakeNodePort), externalURL)
assert.Equal(t, expectedGetVerbCalled, getVerbCalled)
})
}
func TestWaitUntilServiceStateDeleted(t *testing.T) {
// fake test values
testApp := testAppDescription()
client := newFakeKubeClient()
// Set up reactor to fake verb
client.ClientSet.(*fake.Clientset).AddReactor(
getVerb,
"services",
func(action core.Action) (bool, runtime.Object, error) {
ns := action.GetNamespace()
assert.Equal(t, testNamespace, ns)
err := errors.NewNotFound(
schema.GroupResource{
Group: "fakeGroup",
Resource: "fakeResource",
},
"services")
return true, nil, err
})
appManager := NewAppManager(client, testNamespace, testApp)
svcObj, err := appManager.WaitUntilServiceState(appManager.app.AppName, appManager.IsServiceDeleted)
require.NoError(t, err)
assert.Nil(t, svcObj)
}
func TestDeleteDeployment(t *testing.T) {
testApp := testAppDescription()
testSets := []struct {
tc string
actionFunc func(action core.Action) (bool, runtime.Object, error)
}{
{
"deployment object exists",
func(action core.Action) (bool, runtime.Object, error) {
ns := action.GetNamespace()
assert.Equal(t, testNamespace, ns)
obj := &appsv1.Deployment{}
return true, obj, nil
},
},
{
"deployment object exists",
func(action core.Action) (bool, runtime.Object, error) {
err := errors.NewNotFound(
schema.GroupResource{
Group: "fakeGroup",
Resource: "fakeResource",
},
"deployments")
return true, nil, err
},
},
}
for _, tt := range testSets {
t.Run(tt.tc, func(t *testing.T) {
client := newFakeKubeClient()
// Set up reactor to fake verb
client.ClientSet.(*fake.Clientset).AddReactor("delete", "deployments", tt.actionFunc)
appManager := NewAppManager(client, testNamespace, testApp)
err := appManager.DeleteDeployment(false)
require.NoError(t, err)
})
}
}
func TestDeleteService(t *testing.T) {
testApp := testAppDescription()
testSets := []struct {
tc string
actionFunc func(action core.Action) (bool, runtime.Object, error)
}{
{
"Service object exists",
func(action core.Action) (bool, runtime.Object, error) {
ns := action.GetNamespace()
assert.Equal(t, testNamespace, ns)
obj := &apiv1.Service{}
return true, obj, nil
},
},
{
"Service object does not exist",
func(action core.Action) (bool, runtime.Object, error) {
err := errors.NewNotFound(
schema.GroupResource{
Group: "fakeGroup",
Resource: "fakeResource",
},
"service")
return true, nil, err
},
},
}
for _, tt := range testSets {
t.Run(tt.tc, func(t *testing.T) {
client := newFakeKubeClient()
// Set up reactor to fake verb
client.ClientSet.(*fake.Clientset).AddReactor("delete", "services", tt.actionFunc)
appManager := NewAppManager(client, testNamespace, testApp)
err := appManager.DeleteService(false)
require.NoError(t, err)
})
}
}
|
mikeee/dapr
|
tests/platforms/kubernetes/appmanager_test.go
|
GO
|
mit
| 16,261 |
/*
Copyright 2021 The Dapr Authors
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.
*/
package kubernetes
import (
"os"
"path/filepath"
"k8s.io/client-go/kubernetes"
appv1 "k8s.io/client-go/kubernetes/typed/apps/v1"
batchv1 "k8s.io/client-go/kubernetes/typed/batch/v1"
apiv1 "k8s.io/client-go/kubernetes/typed/core/v1"
"k8s.io/client-go/rest"
"k8s.io/client-go/tools/clientcmd"
"k8s.io/client-go/util/homedir"
metrics "k8s.io/metrics/pkg/client/clientset/versioned"
daprclient "github.com/dapr/dapr/pkg/client/clientset/versioned"
componentsv1alpha1 "github.com/dapr/dapr/pkg/client/clientset/versioned/typed/components/v1alpha1"
)
// KubeClient holds instances of Kubernetes clientset
// TODO: Add cluster management methods to clean up the old test apps.
type KubeClient struct {
ClientSet kubernetes.Interface
MetricsClient metrics.Interface
DaprClientSet daprclient.Interface
clientConfig *rest.Config
}
// NewKubeClient creates KubeClient instance.
func NewKubeClient(configPath string, clusterName string) (*KubeClient, error) {
config, err := clientConfig(configPath, clusterName)
if err != nil {
return nil, err
}
kubecs, err := kubernetes.NewForConfig(config)
if err != nil {
return nil, err
}
daprcs, err := daprclient.NewForConfig(config)
if err != nil {
return nil, err
}
metricscs, err := metrics.NewForConfig(config)
if err != nil {
return nil, err
}
return &KubeClient{ClientSet: kubecs, DaprClientSet: daprcs, clientConfig: config, MetricsClient: metricscs}, nil
}
func clientConfig(kubeConfigPath string, clusterName string) (*rest.Config, error) {
if kubeConfigPath == "" {
kubeConfigPath = os.Getenv("KUBECONFIG")
if home := homedir.HomeDir(); home != "" && kubeConfigPath == "" {
kubeConfigPath = filepath.Join(home, ".kube", "config")
}
}
overrides := clientcmd.ConfigOverrides{}
if clusterName != "" {
overrides.Context.Cluster = clusterName
}
config, err := clientcmd.NewNonInteractiveDeferredLoadingClientConfig(
&clientcmd.ClientConfigLoadingRules{ExplicitPath: kubeConfigPath},
&overrides).ClientConfig()
if err != nil {
return nil, err
}
// Reduce the QPS to avoid rate-limiting
config.QPS = 3
config.Burst = 5
return config, nil
}
// GetClientConfig returns client configuration.
func (c *KubeClient) GetClientConfig() *rest.Config {
return c.clientConfig
}
// Deployments gets Deployment client for namespace.
func (c *KubeClient) Deployments(namespace string) appv1.DeploymentInterface {
return c.ClientSet.AppsV1().Deployments(namespace)
}
// Jobs gets Jobs client for namespace.
func (c *KubeClient) Jobs(namespace string) batchv1.JobInterface {
return c.ClientSet.BatchV1().Jobs(namespace)
}
// Services gets Service client for namespace.
func (c *KubeClient) Services(namespace string) apiv1.ServiceInterface {
return c.ClientSet.CoreV1().Services(namespace)
}
// Pods gets Pod client for namespace.
func (c *KubeClient) Pods(namespace string) apiv1.PodInterface {
return c.ClientSet.CoreV1().Pods(namespace)
}
// Namespaces gets Namespace client.
func (c *KubeClient) Namespaces() apiv1.NamespaceInterface {
return c.ClientSet.CoreV1().Namespaces()
}
// DaprComponents gets Dapr component client for namespace.
func (c *KubeClient) DaprComponents(namespace string) componentsv1alpha1.ComponentInterface {
return c.DaprClientSet.ComponentsV1alpha1().Components(namespace)
}
|
mikeee/dapr
|
tests/platforms/kubernetes/client.go
|
GO
|
mit
| 3,881 |
/*
Copyright 2021 The Dapr Authors
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.
*/
package kubernetes
// SecretRef is a reference to a secret
type SecretRef struct {
Name string
Key string
}
// MetadataValue is either a raw string value or a secret ref
type MetadataValue struct {
Raw string
FromSecretRef *SecretRef
}
// ComponentDescription holds dapr component description.
type ComponentDescription struct {
// Name is the name of dapr component
Name string
// Namespace to deploy the component to
Namespace *string
// Type contains component types (<type>.<component_name>)
TypeName string
// MetaData contains the metadata for dapr component
MetaData map[string]MetadataValue
// Scopes is the list of target apps that should use this component
Scopes []string
// ContainerAsJSON is used for pluggable components
ContainerAsJSON string
}
|
mikeee/dapr
|
tests/platforms/kubernetes/component_description.go
|
GO
|
mit
| 1,351 |
/*
Copyright 2021 The Dapr Authors
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.
*/
package kubernetes
import (
"context"
"log"
v1 "k8s.io/apiextensions-apiserver/pkg/apis/apiextensions/v1"
metav1 "k8s.io/apimachinery/pkg/apis/meta/v1"
commonapi "github.com/dapr/dapr/pkg/apis/common"
v1alpha1 "github.com/dapr/dapr/pkg/apis/components/v1alpha1"
)
// DaprComponent holds kubernetes client and component information.
type DaprComponent struct {
namespace string
kubeClient *KubeClient
component ComponentDescription
}
// NewDaprComponent creates DaprComponent instance.
func NewDaprComponent(client *KubeClient, ns string, comp ComponentDescription) *DaprComponent {
return &DaprComponent{
namespace: ns,
kubeClient: client,
component: comp,
}
}
// toComponentSpec builds the componentSpec for the given ComponentDescription
func (do *DaprComponent) toComponentSpec() *v1alpha1.Component {
metadata := []commonapi.NameValuePair{}
for k, v := range do.component.MetaData {
var item commonapi.NameValuePair
if v.FromSecretRef == nil {
item = commonapi.NameValuePair{
Name: k,
Value: commonapi.DynamicValue{
JSON: v1.JSON{
Raw: []byte(v.Raw),
},
},
}
} else {
item = commonapi.NameValuePair{
Name: k,
SecretKeyRef: commonapi.SecretKeyRef{
Name: v.FromSecretRef.Name,
Key: v.FromSecretRef.Key,
},
}
}
metadata = append(metadata, item)
}
annotations := make(map[string]string)
if do.component.ContainerAsJSON != "" {
annotations["dapr.io/component-container"] = do.component.ContainerAsJSON
}
return buildDaprComponentObject(do.component.Name, do.component.TypeName, do.component.Scopes, annotations, metadata)
}
func (do *DaprComponent) addComponent() (*v1alpha1.Component, error) {
log.Printf("Adding component %q ...", do.Name())
return do.kubeClient.DaprComponents(do.namespace).Create(do.toComponentSpec())
}
func (do *DaprComponent) deleteComponent() error {
client := do.kubeClient.DaprComponents(do.namespace)
return client.Delete(do.component.Name, &metav1.DeleteOptions{})
}
func (do *DaprComponent) Name() string {
return do.component.Name
}
func (do *DaprComponent) Init(ctx context.Context) error {
// Ignore errors here as the component may not exist
_ = do.Dispose(true)
_, err := do.addComponent()
return err
}
func (do *DaprComponent) Dispose(wait bool) error {
return do.deleteComponent()
}
|
mikeee/dapr
|
tests/platforms/kubernetes/daprcomponent.go
|
GO
|
mit
| 2,909 |
/*
Copyright 2022 The Dapr Authors
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.
*/
package kubernetes
import (
"testing"
"github.com/stretchr/testify/assert"
)
func TestDaprComponentSpec(t *testing.T) {
t.Run("should set name when specified", func(t *testing.T) {
const testName = "fake-name"
daprComponent := DaprComponent{component: ComponentDescription{
Name: testName,
}}
assert.Equal(t, testName, daprComponent.toComponentSpec().Name)
})
t.Run("should set typename when specified", func(t *testing.T) {
const testTypeName = "state.redis"
daprComponent := DaprComponent{component: ComponentDescription{
TypeName: testTypeName,
}}
assert.Equal(t, testTypeName, daprComponent.toComponentSpec().Spec.Type)
})
t.Run("should add metadata when specified", func(t *testing.T) {
const testKey, testValue = "key", `"value"`
daprComponent := DaprComponent{component: ComponentDescription{
MetaData: map[string]MetadataValue{
testKey: {Raw: testValue},
},
}}
metadata := daprComponent.toComponentSpec().Spec.Metadata
assert.Len(t, metadata, 1)
assert.Equal(t, testKey, metadata[0].Name)
assert.Equal(t, metadata[0].Value.Raw, []byte(testValue))
})
t.Run("should add secretkeyref as metadata value when specified", func(t *testing.T) {
const testSecretKey, fromSecretName, fromSecretKey = "secretKey", "secretName", "secretKey"
daprComponent := DaprComponent{component: ComponentDescription{
MetaData: map[string]MetadataValue{
testSecretKey: {FromSecretRef: &SecretRef{
Name: fromSecretName,
Key: fromSecretKey,
}},
},
}}
metadata := daprComponent.toComponentSpec().Spec.Metadata
assert.Len(t, metadata, 1)
assert.Equal(t, testSecretKey, metadata[0].Name)
assert.Equal(t, fromSecretName, metadata[0].SecretKeyRef.Name)
assert.Equal(t, fromSecretKey, metadata[0].SecretKeyRef.Key)
})
t.Run("should add component annotations when container image is specified", func(t *testing.T) {
const testContainer = `{ "image":"test-image" }`
daprComponent := DaprComponent{component: ComponentDescription{
ContainerAsJSON: testContainer,
}}
annotations := daprComponent.toComponentSpec().ObjectMeta.Annotations
assert.Len(t, annotations, 1)
assert.Equal(t, testContainer, annotations["dapr.io/component-container"])
})
}
|
mikeee/dapr
|
tests/platforms/kubernetes/daprcomponent_test.go
|
GO
|
mit
| 2,802 |
/*
Copyright 2021 The Dapr Authors
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.
*/
package kubernetes
import (
"fmt"
"os"
"strconv"
"strings"
appsv1 "k8s.io/api/apps/v1"
batchv1 "k8s.io/api/batch/v1"
apiv1 "k8s.io/api/core/v1"
metav1 "k8s.io/apimachinery/pkg/apis/meta/v1"
"k8s.io/apimachinery/pkg/util/intstr"
commonapi "github.com/dapr/dapr/pkg/apis/common"
v1alpha1 "github.com/dapr/dapr/pkg/apis/components/v1alpha1"
"github.com/dapr/kit/utils"
)
const (
// TestAppLabelKey is the label key for Kubernetes label selector.
TestAppLabelKey = "testapp"
// DaprSideCarName is the Pod name of Dapr side car.
DaprSideCarName = "daprd"
// DefaultContainerPort is the default container port exposed from test app.
DefaultContainerPort = 3000
// DefaultExternalPort is the default external port exposed by load balancer ingress.
DefaultExternalPort = 3000
// DaprComponentsKind is component kind.
DaprComponentsKind = "components.dapr.io"
// DaprTestNamespaceEnvVar is the environment variable for setting the Kubernetes namespace for e2e tests.
DaprTestNamespaceEnvVar = "DAPR_TEST_NAMESPACE"
// TargetOsEnvVar Environment variable for setting Kubernetes node affinity OS.
TargetOsEnvVar = "TARGET_OS"
// TargetArchEnvVar Environment variable for setting Kubernetes node affinity ARCH.
TargetArchEnvVar = "TARGET_ARCH"
// Environmental variable to disable API logging
DisableAPILoggingEnvVar = "NO_API_LOGGING"
// Environmental variable to enable debug logging
DebugLoggingEnvVar = "DEBUG_LOGGING"
)
var (
// DaprTestNamespace is the default Kubernetes namespace for e2e tests.
DaprTestNamespace = "dapr-tests"
// TargetOs is default os affinity for Kubernetes nodes.
TargetOs = "linux"
// TargetArch is the default architecture affinity for Kubernetes nodes.
TargetArch = "amd64"
// Controls whether API logging is enabled
EnableAPILogging = true
// Controls whether debug logging is enabled
EnableDebugLogging = false
)
// buildDaprAnnotations creates the Kubernetes Annotations object for dapr test app.
func buildDaprAnnotations(appDesc AppDescription) map[string]string {
annotationObject := map[string]string{}
if appDesc.DaprEnabled {
annotationObject = map[string]string{
"dapr.io/enabled": "true",
"dapr.io/app-id": appDesc.AppName,
"dapr.io/sidecar-cpu-limit": appDesc.DaprCPULimit,
"dapr.io/sidecar-cpu-request": appDesc.DaprCPURequest,
"dapr.io/sidecar-memory-limit": appDesc.DaprMemoryLimit,
"dapr.io/sidecar-memory-request": appDesc.DaprMemoryRequest,
"dapr.io/sidecar-readiness-probe-threshold": "15",
"dapr.io/sidecar-liveness-probe-threshold": "15",
"dapr.io/enable-metrics": strconv.FormatBool(appDesc.MetricsEnabled),
"dapr.io/enable-api-logging": strconv.FormatBool(EnableAPILogging),
"dapr.io/disable-builtin-k8s-secret-store": strconv.FormatBool(appDesc.SecretStoreDisable),
}
if EnableDebugLogging || appDesc.DebugLoggingEnabled {
annotationObject["dapr.io/log-level"] = "debug"
}
if !appDesc.IsJob {
annotationObject["dapr.io/app-port"] = strconv.Itoa(appDesc.AppPort)
}
}
if appDesc.AppProtocol != "" {
annotationObject["dapr.io/app-protocol"] = appDesc.AppProtocol
}
if appDesc.MetricsPort != "" {
annotationObject["dapr.io/metrics-port"] = appDesc.MetricsPort
}
if appDesc.Config != "" {
annotationObject["dapr.io/config"] = appDesc.Config
}
if appDesc.DaprVolumeMounts != "" {
annotationObject["dapr.io/volume-mounts"] = appDesc.DaprVolumeMounts
}
if appDesc.DaprEnv != "" {
annotationObject["dapr.io/env"] = appDesc.DaprEnv
}
if appDesc.UnixDomainSocketPath != "" {
annotationObject["dapr.io/unix-domain-socket-path"] = appDesc.UnixDomainSocketPath
}
if appDesc.EnableAppHealthCheck {
annotationObject["dapr.io/enable-app-health-check"] = "true"
}
if appDesc.AppHealthCheckPath != "" {
annotationObject["dapr.io/app-health-check-path"] = appDesc.AppHealthCheckPath
}
if appDesc.AppHealthProbeInterval != 0 {
annotationObject["dapr.io/app-health-probe-interval"] = strconv.Itoa(appDesc.AppHealthProbeInterval)
}
if appDesc.AppHealthProbeTimeout != 0 {
annotationObject["dapr.io/app-health-probe-timeout"] = strconv.Itoa(appDesc.AppHealthProbeTimeout)
}
if appDesc.AppHealthThreshold != 0 {
annotationObject["dapr.io/app-health-threshold"] = strconv.Itoa(appDesc.AppHealthThreshold)
}
if appDesc.AppChannelAddress != "" {
annotationObject["dapr.io/app-channel-address"] = appDesc.AppChannelAddress
}
if len(appDesc.PluggableComponents) != 0 {
componentNames := make([]string, len(appDesc.PluggableComponents))
for idx, component := range appDesc.PluggableComponents {
componentNames[idx] = component.Name
}
annotationObject["dapr.io/pluggable-components"] = strings.Join(componentNames, ",")
}
if len(appDesc.PlacementAddresses) != 0 {
annotationObject["dapr.io/placement-host-address"] = strings.Join(appDesc.PlacementAddresses, ",")
}
if appDesc.InjectPluggableComponents {
annotationObject["dapr.io/inject-pluggable-components"] = "true"
}
if appDesc.SidecarImage != "" {
annotationObject["dapr.io/sidecar-image"] = appDesc.SidecarImage
}
if appDesc.MaxRequestSizeMB != 0 {
annotationObject["dapr.io/http-max-request-size"] = strconv.Itoa(appDesc.MaxRequestSizeMB)
}
return annotationObject
}
// buildPodTemplate creates the Kubernetes Pod Template object for dapr test app.
func buildPodTemplate(appDesc AppDescription) apiv1.PodTemplateSpec {
appEnv := []apiv1.EnvVar{}
if appDesc.AppEnv != nil {
for key, value := range appDesc.AppEnv {
appEnv = append(appEnv, apiv1.EnvVar{
Name: key,
Value: value,
})
}
}
labels := appDesc.Labels
if len(labels) == 0 {
labels = make(map[string]string, 1)
}
labels[TestAppLabelKey] = appDesc.AppName
var podAffinity *apiv1.PodAffinity
if len(appDesc.PodAffinityLabels) > 0 {
podAffinity = &apiv1.PodAffinity{
RequiredDuringSchedulingIgnoredDuringExecution: []apiv1.PodAffinityTerm{
{
LabelSelector: &metav1.LabelSelector{
MatchLabels: appDesc.PodAffinityLabels,
},
TopologyKey: "topology.kubernetes.io/zone",
},
},
}
}
containers := []apiv1.Container{{
Name: appDesc.AppName,
Image: fmt.Sprintf("%s/%s", appDesc.RegistryName, appDesc.ImageName),
ImagePullPolicy: apiv1.PullAlways,
Ports: []apiv1.ContainerPort{
{
Name: "http",
Protocol: apiv1.ProtocolTCP,
ContainerPort: DefaultContainerPort,
},
},
Env: appEnv,
VolumeMounts: appDesc.AppVolumeMounts,
}}
containers = append(containers, appDesc.PluggableComponents...)
nodeSelectorRequirements := appDesc.NodeSelectors
if nodeSelectorRequirements == nil {
nodeSelectorRequirements = []apiv1.NodeSelectorRequirement{}
}
nodeSelectorRequirements = append(nodeSelectorRequirements,
apiv1.NodeSelectorRequirement{
Key: "kubernetes.io/os",
Operator: "In",
Values: []string{TargetOs},
},
apiv1.NodeSelectorRequirement{
Key: "kubernetes.io/arch",
Operator: "In",
Values: []string{TargetArch},
},
)
imagePullSecrets := make([]apiv1.LocalObjectReference, 0, 1)
if appDesc.ImageSecret != "" {
imagePullSecrets = append(imagePullSecrets, apiv1.LocalObjectReference{
Name: appDesc.ImageSecret,
})
}
return apiv1.PodTemplateSpec{
ObjectMeta: metav1.ObjectMeta{
Labels: labels,
Annotations: buildDaprAnnotations(appDesc),
},
Spec: apiv1.PodSpec{
InitContainers: appDesc.InitContainers,
Containers: containers,
Affinity: &apiv1.Affinity{
NodeAffinity: &apiv1.NodeAffinity{
RequiredDuringSchedulingIgnoredDuringExecution: &apiv1.NodeSelector{
NodeSelectorTerms: []apiv1.NodeSelectorTerm{
{
MatchExpressions: nodeSelectorRequirements,
},
},
},
},
PodAffinity: podAffinity,
},
ImagePullSecrets: imagePullSecrets,
Volumes: appDesc.Volumes,
Tolerations: appDesc.Tolerations,
},
}
}
// buildDeploymentObject creates the Kubernetes Deployment object for dapr test app.
func buildDeploymentObject(namespace string, appDesc AppDescription) *appsv1.Deployment {
if appDesc.AppPort == 0 { // If AppPort is negative, assume this has been set explicitly
appDesc.AppPort = DefaultContainerPort
}
return &appsv1.Deployment{
ObjectMeta: metav1.ObjectMeta{
Name: appDesc.AppName,
Namespace: namespace,
},
Spec: appsv1.DeploymentSpec{
Replicas: int32Ptr(appDesc.Replicas),
Selector: &metav1.LabelSelector{
MatchLabels: map[string]string{
TestAppLabelKey: appDesc.AppName,
},
},
Template: buildPodTemplate(appDesc),
},
}
}
// buildJobObject creates the Kubernetes Job object for dapr test app.
func buildJobObject(namespace string, appDesc AppDescription) *batchv1.Job {
if appDesc.AppPort == 0 { // If AppPort is negative, assume this has been set explicitly
appDesc.AppPort = DefaultContainerPort
}
job := batchv1.Job{
ObjectMeta: metav1.ObjectMeta{
Name: appDesc.AppName,
Namespace: namespace,
},
Spec: batchv1.JobSpec{
Template: buildPodTemplate(appDesc),
},
}
job.Spec.Template.Spec.RestartPolicy = apiv1.RestartPolicyOnFailure
return &job
}
// buildServiceObject creates the Kubernetes Service Object for dapr test app.
func buildServiceObject(namespace string, appDesc AppDescription) *apiv1.Service {
serviceType := apiv1.ServiceTypeClusterIP
if appDesc.ShouldBeExposed() {
serviceType = apiv1.ServiceTypeLoadBalancer
}
targetPort := DefaultContainerPort
if appDesc.IngressPort > 0 {
targetPort = appDesc.IngressPort
} else if appDesc.AppPort > 0 {
targetPort = appDesc.AppPort
}
return &apiv1.Service{
ObjectMeta: metav1.ObjectMeta{
Name: appDesc.AppName,
Namespace: namespace,
Labels: map[string]string{
TestAppLabelKey: appDesc.AppName,
},
},
Spec: apiv1.ServiceSpec{
Selector: map[string]string{
TestAppLabelKey: appDesc.AppName,
},
Ports: []apiv1.ServicePort{
{
Protocol: apiv1.ProtocolTCP,
Port: DefaultExternalPort,
TargetPort: intstr.IntOrString{IntVal: int32(targetPort)},
},
},
Type: serviceType,
},
}
}
// buildDaprComponentObject creates dapr component object.
func buildDaprComponentObject(componentName string, typeName string, scopes []string, annotations map[string]string, metaData []commonapi.NameValuePair) *v1alpha1.Component {
return &v1alpha1.Component{
TypeMeta: metav1.TypeMeta{
Kind: DaprComponentsKind,
},
ObjectMeta: metav1.ObjectMeta{
Name: componentName,
Annotations: annotations,
},
Spec: v1alpha1.ComponentSpec{
Type: typeName,
Metadata: metaData,
},
Scoped: commonapi.Scoped{Scopes: scopes},
}
}
func int32Ptr(i int32) *int32 {
return &i
}
func init() {
if ns, ok := os.LookupEnv(DaprTestNamespaceEnvVar); ok {
DaprTestNamespace = ns
}
if os, ok := os.LookupEnv(TargetOsEnvVar); ok {
TargetOs = os
}
if arch, ok := os.LookupEnv(TargetArchEnvVar); ok {
TargetArch = arch
}
{
v, _ := os.LookupEnv(DisableAPILoggingEnvVar)
EnableAPILogging = !utils.IsTruthy(v)
}
EnableDebugLogging = utils.IsTruthy(os.Getenv(DebugLoggingEnvVar))
}
|
mikeee/dapr
|
tests/platforms/kubernetes/kubeobj.go
|
GO
|
mit
| 11,839 |
/*
Copyright 2021 The Dapr Authors
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.
*/
package kubernetes
import (
"testing"
"github.com/stretchr/testify/assert"
apiv1 "k8s.io/api/core/v1"
)
func TestBuildDeploymentObject(t *testing.T) {
testApp := AppDescription{
AppName: "testapp",
DaprEnabled: true,
ImageName: "helloworld",
RegistryName: "dariotest",
Replicas: 1,
IngressEnabled: true,
MetricsEnabled: true,
}
t.Run("Unix socket", func(t *testing.T) {
testApp.UnixDomainSocketPath = "/var/run"
defer func() {
testApp.UnixDomainSocketPath = "" // cleanup
}()
// act
obj := buildDeploymentObject("testNamespace", testApp)
// assert
assert.NotNil(t, obj)
assert.Equal(t, "/var/run", obj.Spec.Template.Annotations["dapr.io/unix-domain-socket-path"])
})
t.Run("Inject pluggable components", func(t *testing.T) {
// act
obj := buildDeploymentObject("testNamespace", AppDescription{
InjectPluggableComponents: true,
})
// assert
assert.NotNil(t, obj)
assert.Equal(t, "true", obj.Spec.Template.Annotations["dapr.io/inject-pluggable-components"])
})
t.Run("Dapr Enabled", func(t *testing.T) {
testApp.DaprEnabled = true
// act
obj := buildDeploymentObject("testNamespace", testApp)
// assert
assert.NotNil(t, obj)
assert.Equal(t, "true", obj.Spec.Template.Annotations["dapr.io/enabled"])
})
t.Run("Dapr disabled", func(t *testing.T) {
testApp.DaprEnabled = false
// act
obj := buildDeploymentObject("testNamespace", testApp)
// assert
assert.NotNil(t, obj)
assert.Empty(t, obj.Spec.Template.Annotations)
})
}
func TestBuildJobObject(t *testing.T) {
testApp := AppDescription{
AppName: "testapp",
DaprEnabled: true,
ImageName: "helloworld",
RegistryName: "dariotest",
Replicas: 1,
IngressEnabled: true,
}
t.Run("Dapr Enabled", func(t *testing.T) {
testApp.DaprEnabled = true
// act
obj := buildJobObject("testNamespace", testApp)
// assert
assert.NotNil(t, obj)
assert.Equal(t, "true", obj.Spec.Template.Annotations["dapr.io/enabled"])
})
t.Run("Dapr disabled", func(t *testing.T) {
testApp.DaprEnabled = false
// act
obj := buildJobObject("testNamespace", testApp)
// assert
assert.NotNil(t, obj)
assert.Empty(t, obj.Spec.Template.Annotations)
})
}
func TestBuildServiceObject(t *testing.T) {
testApp := AppDescription{
AppName: "testapp",
DaprEnabled: true,
ImageName: "helloworld",
RegistryName: "dariotest",
Replicas: 1,
IngressEnabled: true,
MetricsEnabled: true,
}
t.Run("Ingress is enabled", func(t *testing.T) {
testApp.IngressEnabled = true
// act
obj := buildServiceObject("testNamespace", testApp)
// assert
assert.NotNil(t, obj)
assert.Equal(t, apiv1.ServiceTypeLoadBalancer, obj.Spec.Type)
})
t.Run("Ingress is disabled", func(t *testing.T) {
testApp.IngressEnabled = false
// act
obj := buildServiceObject("testNamespace", testApp)
// assert
assert.NotNil(t, obj)
assert.Equal(t, apiv1.ServiceTypeClusterIP, obj.Spec.Type)
})
}
|
mikeee/dapr
|
tests/platforms/kubernetes/kubeobj_test.go
|
GO
|
mit
| 3,579 |
/*
Copyright 2023 The Dapr Authors
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.
*/
package kubernetes
import (
"context"
"errors"
"fmt"
"io"
"log"
"os"
"path/filepath"
"strings"
"time"
apiv1 "k8s.io/api/core/v1"
metav1 "k8s.io/apimachinery/pkg/apis/meta/v1"
v1 "k8s.io/client-go/kubernetes/typed/core/v1"
)
var logPrefix string
func init() {
logPrefix = os.Getenv(ContainerLogPathEnvVar)
if logPrefix == "" {
logPrefix = ContainerLogDefaultPath
}
}
// StreamContainerLogsToDisk streams all containers logs for the given selector to a given disk directory.
func StreamContainerLogsToDisk(ctx context.Context, appName string, podClient v1.PodInterface) error {
listCtx, cancel := context.WithTimeout(ctx, 30*time.Second)
podList, err := podClient.List(listCtx, metav1.ListOptions{
LabelSelector: fmt.Sprintf("%s=%s", TestAppLabelKey, appName),
})
cancel()
if err != nil {
return err
}
for _, pod := range podList.Items {
for _, container := range pod.Spec.Containers {
go func(pod, container string) {
loop:
for {
filename := filepath.Join(logPrefix, fmt.Sprintf("%s.%s.log", pod, container))
log.Printf("Streaming Kubernetes logs to %s", filename)
req := podClient.GetLogs(pod, &apiv1.PodLogOptions{
Container: container,
Follow: true,
})
stream, err := req.Stream(ctx)
if err != nil {
switch {
case errors.Is(err, context.Canceled):
log.Printf("Saved container logs to %s", filename)
return
case strings.Contains(err.Error(), "ContainerCreating"):
// Retry after a delay
time.Sleep(100 * time.Millisecond)
continue loop
default:
log.Printf("Error starting log stream for %s. Error was %v", filename, err)
return
}
}
defer stream.Close()
fh, err := os.Create(filename)
if err != nil {
log.Printf("Error creating %s. Error was %s", filename, err)
return
}
defer fh.Close()
_, err = io.Copy(fh, stream)
if err != nil {
switch {
case errors.Is(err, context.Canceled):
log.Printf("Saved container logs to %s", filename)
return
default:
log.Printf("Error copying log stream for %s. Error was %v", filename, err)
return
}
}
log.Printf("Saved container logs to %s", filename)
return
}
}(pod.GetName(), container.Name)
}
}
return nil
}
|
mikeee/dapr
|
tests/platforms/kubernetes/logs.go
|
GO
|
mit
| 2,910 |
package kubernetes
import (
"fmt"
"log"
"net/http"
"net/url"
"os"
"github.com/phayes/freeport"
apiv1 "k8s.io/api/core/v1"
metav1 "k8s.io/apimachinery/pkg/apis/meta/v1"
"k8s.io/cli-runtime/pkg/genericclioptions"
"k8s.io/client-go/rest"
"k8s.io/client-go/tools/portforward"
"k8s.io/client-go/transport/spdy"
)
// PodPortFowarder implements the PortForwarder interface for Kubernetes.
type PodPortForwarder struct {
// Kubernetes client
client *KubeClient
// Kubernetes namespace
namespace string
// stopChannel is the channel used to manage the port forward lifecycle
stopChannel chan struct{}
// readyChannel communicates when the tunnel is ready to receive traffic
readyChannel chan struct{}
}
// PortForwardRequest encapsulates data required to establish a Kuberentes tunnel.
type PortForwardRequest struct {
// restConfig is the kubernetes config
restConfig *rest.Config
// pod is the selected pod for this port forwarding
pod apiv1.Pod
// localPort is the local port that will be selected to forward the PodPort
localPorts []int
// podPort is the target port for the pod
podPorts []int
// streams configures where to write or read input from
streams genericclioptions.IOStreams
// stopChannel is the channel used to manage the port forward lifecycle
stopChannel chan struct{}
// stopChannel communicates when the tunnel is ready to receive traffic
readyChannel chan struct{}
}
// NewPodPortForwarder returns a new PodPortForwarder.
func NewPodPortForwarder(c *KubeClient, namespace string) *PodPortForwarder {
return &PodPortForwarder{
client: c,
namespace: namespace,
readyChannel: make(chan struct{}),
stopChannel: make(chan struct{}),
}
}
// Connect establishes a new connection to a given app on the provided target ports.
func (p *PodPortForwarder) Connect(name string, targetPorts ...int) ([]int, error) {
if name == "" {
return nil, fmt.Errorf("name must be set to establish connection")
}
if len(targetPorts) == 0 {
return nil, fmt.Errorf("cannot establish connection without target ports")
}
if p.namespace == "" {
return nil, fmt.Errorf("namespace must be set to establish connection")
}
if p.client == nil {
return nil, fmt.Errorf("client must be set to establish connection")
}
config := p.client.GetClientConfig()
var ports []int
for i := 0; i < len(targetPorts); i++ {
p, perr := freeport.GetFreePort()
if perr != nil {
return nil, perr
}
ports = append(ports, p)
}
streams := genericclioptions.IOStreams{
In: os.Stdin,
Out: os.Stdout,
ErrOut: os.Stderr,
}
err := startPortForwarding(PortForwardRequest{
restConfig: config,
pod: apiv1.Pod{
ObjectMeta: metav1.ObjectMeta{
Name: name,
Namespace: p.namespace,
},
},
localPorts: ports,
podPorts: targetPorts,
streams: streams,
stopChannel: p.stopChannel,
readyChannel: p.readyChannel,
})
if err != nil {
return nil, err
}
<-p.readyChannel
return ports, nil
}
func (p *PodPortForwarder) Close() error {
if p.stopChannel != nil {
close(p.stopChannel)
}
return nil
}
func startPortForwarding(req PortForwardRequest) error {
// create spdy roundtripper
roundTripper, upgrader, err := spdy.RoundTripperFor(req.restConfig)
if err != nil {
return err
}
path := fmt.Sprintf("/api/v1/namespaces/%s/pods/%s/portforward", req.pod.Namespace, req.pod.Name)
serverURL, _ := url.Parse(req.restConfig.Host)
serverURL.Scheme = "https"
serverURL.Path = path
dialer := spdy.NewDialer(upgrader, &http.Client{Transport: roundTripper}, http.MethodPost, serverURL)
var ports []string //nolint: prealloc
for i, p := range req.podPorts {
ports = append(ports, fmt.Sprintf("%d:%d", req.localPorts[i], p))
}
fw, err := portforward.New(dialer, ports, req.stopChannel, req.readyChannel, req.streams.Out, req.streams.ErrOut)
if err != nil {
return err
}
go func() {
if err = fw.ForwardPorts(); err != nil {
log.Printf("Error closing port fowarding: %+v", err)
// TODO: How to handle error?
}
log.Println("Closed port fowarding")
}()
return nil
}
|
mikeee/dapr
|
tests/platforms/kubernetes/portforward.go
|
GO
|
mit
| 4,093 |
/*
Copyright 2021 The Dapr Authors
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.
*/
package kubernetes
import (
"context"
"log"
"time"
corev1 "k8s.io/api/core/v1"
apierrors "k8s.io/apimachinery/pkg/api/errors"
metav1 "k8s.io/apimachinery/pkg/apis/meta/v1"
)
type SecretDescription struct {
Name string
Namespace string
Data map[string][]byte
}
// Secret holds kubernetes client and component information.
type Secret struct {
name string
namespace string
kubeClient *KubeClient
data map[string][]byte
}
// NewSecret creates Secret instance.
func NewSecret(client *KubeClient, ns, name string, data map[string][]byte) *Secret {
return &Secret{
name: name,
namespace: ns,
kubeClient: client,
data: data,
}
}
func (s *Secret) Init(ctx context.Context) error {
log.Printf("Adding secret %q ...", s.name)
if err := s.Dispose(false); err != nil {
return err
}
ctx, cancel := context.WithTimeout(ctx, time.Second*10)
defer cancel()
_, err := s.kubeClient.ClientSet.CoreV1().Secrets(s.namespace).Create(ctx, &corev1.Secret{
ObjectMeta: metav1.ObjectMeta{
Name: s.name,
Namespace: s.namespace,
},
Data: s.data,
}, metav1.CreateOptions{})
return err
}
func (s *Secret) Name() string {
return s.name
}
func (s *Secret) Dispose(wait bool) error {
log.Printf("Delete secret %q ...", s.name)
ctx, cancel := context.WithTimeout(context.Background(), time.Second*10)
defer cancel()
_, err := s.kubeClient.ClientSet.CoreV1().Secrets(s.namespace).Get(ctx, s.name, metav1.GetOptions{})
if apierrors.IsNotFound(err) {
return nil
}
if err != nil {
return err
}
return s.kubeClient.ClientSet.CoreV1().Secrets(s.namespace).Delete(context.TODO(), s.name, metav1.DeleteOptions{})
}
|
mikeee/dapr
|
tests/platforms/kubernetes/secret.go
|
GO
|
mit
| 2,244 |
/*
Copyright 2021 The Dapr Authors
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.
*/
package runner
import (
"context"
"fmt"
"log"
"os"
"strconv"
"time"
configurationv1alpha1 "github.com/dapr/dapr/pkg/apis/configuration/v1alpha1"
kube "github.com/dapr/dapr/tests/platforms/kubernetes"
corev1 "k8s.io/api/core/v1"
"k8s.io/apimachinery/pkg/api/errors"
metav1 "k8s.io/apimachinery/pkg/apis/meta/v1"
)
const (
disableTelemetryConfig = "disable-telemetry"
defaultSidecarCPULimit = "1.0"
defaultSidecarMemoryLimit = "256Mi"
defaultSidecarCPURequest = "0.1"
defaultSidecarMemoryRequest = "100Mi"
defaultAppCPULimit = "1.0"
defaultAppMemoryLimit = "300Mi"
defaultAppCPURequest = "0.1"
defaultAppMemoryRequest = "200Mi"
)
// KubeTestPlatform includes K8s client for testing cluster and kubernetes testing apps.
type KubeTestPlatform struct {
AppResources *TestResources
ComponentResources *TestResources
Secrets *TestResources
KubeClient *kube.KubeClient
}
// NewKubeTestPlatform creates KubeTestPlatform instance.
func NewKubeTestPlatform() *KubeTestPlatform {
return &KubeTestPlatform{
AppResources: new(TestResources),
ComponentResources: new(TestResources),
Secrets: new(TestResources),
}
}
func (c *KubeTestPlatform) Setup() (err error) {
// TODO: KubeClient will be properly configured by go test arguments
c.KubeClient, err = kube.NewKubeClient("", "")
return
}
func (c *KubeTestPlatform) TearDown() error {
if err := c.AppResources.tearDown(); err != nil {
fmt.Fprintf(os.Stderr, "failed to tear down AppResources. got: %q", err)
}
if err := c.ComponentResources.tearDown(); err != nil {
fmt.Fprintf(os.Stderr, "failed to tear down ComponentResources. got: %q", err)
}
if err := c.Secrets.tearDown(); err != nil {
fmt.Fprintf(os.Stderr, "failed to tear down Secrets. got: %q", err)
}
// TODO: clean up kube cluster
return nil
}
// addComponents adds component to disposable Resource queues.
func (c *KubeTestPlatform) AddComponents(comps []kube.ComponentDescription) error {
if c.KubeClient == nil {
return fmt.Errorf("kubernetes cluster needs to be setup")
}
for _, comp := range comps {
c.ComponentResources.Add(kube.NewDaprComponent(c.KubeClient, getNamespaceOrDefault(comp.Namespace), comp))
}
// setup component resources
if err := c.ComponentResources.setup(); err != nil {
return err
}
return nil
}
// AddSecrets adds secrets to disposable Resource queues.
func (c *KubeTestPlatform) AddSecrets(secrets []kube.SecretDescription) error {
if c.KubeClient == nil {
return fmt.Errorf("kubernetes cluster needs to be setup")
}
for _, secret := range secrets {
c.Secrets.Add(kube.NewSecret(c.KubeClient, secret.Namespace, secret.Name, secret.Data))
}
// setup secret resources
if err := c.Secrets.setup(); err != nil {
return err
}
return nil
}
// addApps adds test apps to disposable App Resource queues.
func (c *KubeTestPlatform) AddApps(apps []kube.AppDescription) error {
if c.KubeClient == nil {
return fmt.Errorf("kubernetes cluster needs to be setup before calling BuildAppResources")
}
dt := c.disableTelemetry()
namespaces := make(map[string]struct{}, 0)
for _, app := range apps {
if app.RegistryName == "" {
app.RegistryName = getTestImageRegistry()
}
if app.ImageSecret == "" {
app.ImageSecret = getTestImageSecret()
}
if app.ImageName == "" {
return fmt.Errorf("%s app doesn't have imagename property", app.AppName)
}
app.ImageName = fmt.Sprintf("%s:%s", app.ImageName, getTestImageTag())
if dt {
app.Config = disableTelemetryConfig
}
if app.DaprCPULimit == "" {
app.DaprCPULimit = c.sidecarCPULimit()
}
if app.DaprCPURequest == "" {
app.DaprCPURequest = c.sidecarCPURequest()
}
if app.DaprMemoryLimit == "" {
app.DaprMemoryLimit = c.sidecarMemoryLimit()
}
if app.DaprMemoryRequest == "" {
app.DaprMemoryRequest = c.sidecarMemoryRequest()
}
if app.AppCPULimit == "" {
app.AppCPULimit = c.appCPULimit()
}
if app.AppCPURequest == "" {
app.AppCPURequest = c.appCPURequest()
}
if app.AppMemoryLimit == "" {
app.AppMemoryLimit = c.appMemoryLimit()
}
if app.AppMemoryRequest == "" {
app.AppMemoryRequest = c.appMemoryRequest()
}
log.Printf("Adding app %v", app)
namespace := getNamespaceOrDefault(app.Namespace)
namespaces[namespace] = struct{}{}
c.AppResources.Add(kube.NewAppManager(c.KubeClient, namespace, app))
}
// Create all namespaces (if they don't already exist)
log.Print("Ensuring namespaces exist ...")
for namespace := range namespaces {
_, err := c.GetOrCreateNamespace(context.Background(), namespace)
if err != nil {
return fmt.Errorf("failed to create namespace %q: %w", namespace, err)
}
}
// installApps installs the apps in AppResource queue sequentially
log.Print("Installing apps ...")
if err := c.AppResources.setup(); err != nil {
return err
}
log.Print("Apps are installed.")
return nil
}
func (c *KubeTestPlatform) disableTelemetry() bool {
disableVal := os.Getenv("DAPR_DISABLE_TELEMETRY")
disable, err := strconv.ParseBool(disableVal)
if err != nil {
return false
}
return disable
}
func (c *KubeTestPlatform) sidecarCPULimit() string {
cpu := os.Getenv("DAPR_SIDECAR_CPU_LIMIT")
if cpu != "" {
return cpu
}
return defaultSidecarCPULimit
}
func (c *KubeTestPlatform) sidecarCPURequest() string {
cpu := os.Getenv("DAPR_SIDECAR_CPU_REQUEST")
if cpu != "" {
return cpu
}
return defaultSidecarCPURequest
}
func (c *KubeTestPlatform) sidecarMemoryRequest() string {
mem := os.Getenv("DAPR_SIDECAR_MEMORY_REQUEST")
if mem != "" {
return mem
}
return defaultSidecarMemoryRequest
}
func (c *KubeTestPlatform) sidecarMemoryLimit() string {
mem := os.Getenv("DAPR_SIDECAR_MEMORY_LIMIT")
if mem != "" {
return mem
}
return defaultSidecarMemoryLimit
}
func (c *KubeTestPlatform) appCPULimit() string {
cpu := os.Getenv("DAPR_APP_CPU_LIMIT")
if cpu != "" {
return cpu
}
return defaultAppCPULimit
}
func (c *KubeTestPlatform) appCPURequest() string {
cpu := os.Getenv("DAPR_APP_CPU_REQUEST")
if cpu != "" {
return cpu
}
return defaultAppCPURequest
}
func (c *KubeTestPlatform) appMemoryRequest() string {
mem := os.Getenv("DAPR_APP_MEMORY_REQUEST")
if mem != "" {
return mem
}
return defaultAppMemoryRequest
}
func (c *KubeTestPlatform) appMemoryLimit() string {
mem := os.Getenv("DAPR_APP_MEMORY_LIMIT")
if mem != "" {
return mem
}
return defaultAppMemoryLimit
}
// GetOrCreateNamespace gets or creates namespace unless namespace exists.
func (c *KubeTestPlatform) GetOrCreateNamespace(parentCtx context.Context, namespace string) (*corev1.Namespace, error) {
log.Printf("Checking namespace %q ...", namespace)
namespaceClient := c.KubeClient.Namespaces()
ctx, cancel := context.WithTimeout(parentCtx, 30*time.Second)
ns, err := namespaceClient.Get(ctx, namespace, metav1.GetOptions{})
cancel()
if err != nil && errors.IsNotFound(err) {
log.Printf("Creating namespace %q ...", namespace)
obj := &corev1.Namespace{ObjectMeta: metav1.ObjectMeta{Name: namespace}}
ctx, cancel = context.WithTimeout(parentCtx, 30*time.Second)
ns, err = namespaceClient.Create(ctx, obj, metav1.CreateOptions{})
cancel()
return ns, err
}
return ns, err
}
// AcquireAppExternalURL returns the external url for 'name'.
func (c *KubeTestPlatform) AcquireAppExternalURL(name string) string {
app := c.AppResources.FindActiveResource(name)
return app.(*kube.AppManager).AcquireExternalURL()
}
// GetAppHostDetails returns the name and IP address of the host(pod) running 'name'.
func (c *KubeTestPlatform) GetAppHostDetails(name string) (string, string, error) {
app := c.AppResources.FindActiveResource(name)
pods, err := app.(*kube.AppManager).GetHostDetails()
if err != nil {
return "", "", err
}
if len(pods) == 0 {
return "", "", fmt.Errorf("no pods found for app: %v", name)
}
return pods[0].Name, pods[0].IP, nil
}
// Scale changes the number of replicas of the app.
func (c *KubeTestPlatform) Scale(name string, replicas int32) error {
app := c.AppResources.FindActiveResource(name)
appManager := app.(*kube.AppManager)
if err := appManager.ScaleDeploymentReplica(replicas); err != nil {
return err
}
_, err := appManager.WaitUntilDeploymentState(appManager.IsDeploymentDone)
return err
}
// SetAppEnv sets the container environment variable.
func (c *KubeTestPlatform) SetAppEnv(name, key, value string) error {
app := c.AppResources.FindActiveResource(name)
appManager := app.(*kube.AppManager)
if err := appManager.SetAppEnv(key, value); err != nil {
return err
}
if _, err := appManager.WaitUntilDeploymentState(appManager.IsDeploymentDone); err != nil {
return err
}
appManager.StreamContainerLogs()
return nil
}
// Restart restarts all instances for the app.
func (c *KubeTestPlatform) Restart(name string) error {
// To minic the restart behavior, scale to 0 and then scale to the original replicas.
app := c.AppResources.FindActiveResource(name)
m := app.(*kube.AppManager)
originalReplicas := m.App().Replicas
if err := c.Scale(name, 0); err != nil {
return err
}
if err := c.Scale(name, originalReplicas); err != nil {
return err
}
m.StreamContainerLogs()
return nil
}
// PortForwardToApp opens a new connection to the app on a the target port and returns the local port or error.
func (c *KubeTestPlatform) PortForwardToApp(appName string, targetPorts ...int) ([]int, error) {
app := c.AppResources.FindActiveResource(appName)
appManager := app.(*kube.AppManager)
_, err := appManager.WaitUntilDeploymentState(appManager.IsDeploymentDone)
if err != nil {
return nil, err
}
if targetPorts == nil {
return nil, fmt.Errorf("cannot open connection with no target ports")
}
return appManager.DoPortForwarding("", targetPorts...)
}
// GetAppUsage returns the Cpu and Memory usage for the app container for a given app.
func (c *KubeTestPlatform) GetAppUsage(appName string) (*AppUsage, error) {
app := c.AppResources.FindActiveResource(appName)
appManager := app.(*kube.AppManager)
cpu, mem, err := appManager.GetCPUAndMemory(false)
if err != nil {
return nil, err
}
return &AppUsage{
CPUm: cpu,
MemoryMb: mem,
}, nil
}
// GetTotalRestarts returns the total of restarts across all pods and containers for an app.
func (c *KubeTestPlatform) GetTotalRestarts(appName string) (int, error) {
app := c.AppResources.FindActiveResource(appName)
appManager := app.(*kube.AppManager)
return appManager.GetTotalRestarts()
}
// GetSidecarUsage returns the Cpu and Memory usage for the dapr container for a given app.
func (c *KubeTestPlatform) GetSidecarUsage(appName string) (*AppUsage, error) {
app := c.AppResources.FindActiveResource(appName)
appManager := app.(*kube.AppManager)
cpu, mem, err := appManager.GetCPUAndMemory(true)
if err != nil {
return nil, err
}
return &AppUsage{
CPUm: cpu,
MemoryMb: mem,
}, nil
}
func getNamespaceOrDefault(namespace *string) string {
if namespace == nil {
return kube.DaprTestNamespace
}
return *namespace
}
// GetConfiguration returns configuration by name.
func (c *KubeTestPlatform) GetConfiguration(name string) (*configurationv1alpha1.Configuration, error) {
client := c.KubeClient.DaprClientSet.ConfigurationV1alpha1().Configurations(kube.DaprTestNamespace)
return client.Get(name, metav1.GetOptions{})
}
func (c *KubeTestPlatform) GetService(name string) (*corev1.Service, error) {
client := c.KubeClient.Services(kube.DaprTestNamespace)
return client.Get(context.Background(), name, metav1.GetOptions{})
}
func (c *KubeTestPlatform) LoadTest(loadtester LoadTester) error {
return loadtester.Run(c)
}
|
mikeee/dapr
|
tests/runner/kube_testplatform.go
|
GO
|
mit
| 12,264 |
/*
Copyright 2022 The Dapr Authors
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.
*/
package loadtest
import (
"encoding/json"
"errors"
"fmt"
"sync"
"github.com/dapr/dapr/tests/perf"
"github.com/dapr/dapr/tests/perf/utils"
"github.com/dapr/dapr/tests/platforms/kubernetes"
"github.com/dapr/dapr/tests/runner"
)
// Fortio is used for executing tests using the fortio load testing tool.
type Fortio struct {
testApp string
affinityLabel string
testerImage string
numHealthChecks int
params perf.TestParameters
result []byte
setupOnce *sync.Once
testerAppURL string
}
// Result get the load test result.
func (f *Fortio) Result() []byte {
return f.result
}
func (f *Fortio) setup(platform runner.PlatformInterface) error {
affinityLabels := map[string]string{}
if f.affinityLabel != "" {
affinityLabels["daprtest"] = f.affinityLabel
}
err := platform.AddApps([]kubernetes.AppDescription{{
AppName: f.testApp,
DaprEnabled: true,
ImageName: f.testerImage,
Replicas: 1,
IngressEnabled: true,
MetricsEnabled: true,
AppPort: 3001,
DaprCPULimit: "4.0",
DaprCPURequest: "0.1",
DaprMemoryLimit: "512Mi",
DaprMemoryRequest: "250Mi",
AppCPULimit: "4.0",
AppCPURequest: "0.1",
AppMemoryLimit: "800Mi",
AppMemoryRequest: "2500Mi",
Labels: map[string]string{
"daprtest": f.testApp,
},
PodAffinityLabels: affinityLabels,
}})
if err != nil {
return err
}
f.testerAppURL = platform.AcquireAppExternalURL(f.testApp)
if err = f.validate(); err != nil {
return err
}
_, err = utils.HTTPGetNTimes(f.testerAppURL, f.numHealthChecks)
return err
}
func (f *Fortio) validate() error {
if f.testerAppURL == "" {
return errors.New("tester app external URL must not be empty")
}
return nil
}
func (f *Fortio) Run(platform runner.PlatformInterface) error {
var err error
// this test is reusable.
f.setupOnce.Do(func() {
err = f.setup(platform)
})
if err != nil {
return err
}
if err = f.validate(); err != nil {
return err
}
body, err := json.Marshal(&f.params)
if err != nil {
return err
}
daprResp, err := utils.HTTPPost(fmt.Sprintf("%s/test", f.testerAppURL), body)
if err != nil {
return err
}
f.result = daprResp
return nil
}
// SetParams set test parameters.
func (f *Fortio) SetParams(params perf.TestParameters) *Fortio {
f.params = params
f.testerAppURL = ""
f.result = nil
return f
}
type Opt = func(*Fortio)
// WithTestAppName sets the app name to be used.
func WithTestAppName(testAppName string) Opt {
return func(f *Fortio) {
f.testApp = testAppName
}
}
// WithNumHealthChecks set the number of initial healthchecks that should be made before executing the test.
func WithNumHealthChecks(hc int) Opt {
return func(f *Fortio) {
f.numHealthChecks = hc
}
}
// WithParams set the test parameters.
func WithParams(params perf.TestParameters) Opt {
return func(f *Fortio) {
f.params = params
}
}
// WithTesterImage sets the tester image (defaults to perf-tester).
func WithTesterImage(image string) Opt {
return func(f *Fortio) {
f.testerImage = image
}
}
// WithAffinity sets the pod affinity for the fortio pod.
func WithAffinity(affinityLabel string) Opt {
return func(f *Fortio) {
f.affinityLabel = affinityLabel
}
}
// NewFortio returns a fortio load tester is on given options.
func NewFortio(options ...Opt) *Fortio {
fortioTester := &Fortio{
testApp: "tester",
testerImage: "perf-tester",
numHealthChecks: 60,
params: perf.TestParameters{},
setupOnce: &sync.Once{},
}
for _, opt := range options {
opt(fortioTester)
}
return fortioTester
}
|
mikeee/dapr
|
tests/runner/loadtest/fortio.go
|
GO
|
mit
| 4,213 |
/*
Copyright 2022 The Dapr Authors
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.
*/
package loadtest
import (
"errors"
"testing"
"github.com/stretchr/testify/assert"
"github.com/stretchr/testify/mock"
"github.com/stretchr/testify/require"
"github.com/dapr/dapr/tests/perf"
kube "github.com/dapr/dapr/tests/platforms/kubernetes"
"github.com/dapr/dapr/tests/runner"
)
// mockPlatform is the mock of Disposable interface.
type mockPlatform struct {
mock.Mock
runner.PlatformInterface
}
func (m *mockPlatform) AddApps(apps []kube.AppDescription) error {
args := m.Called(apps)
return args.Error(0)
}
func (m *mockPlatform) AcquireAppExternalURL(name string) string {
args := m.Called(name)
return args.String(0)
}
func TestFortio(t *testing.T) {
t.Run("WithAffinity should set test affinity", func(t *testing.T) {
const affinity = "test-affinity"
f := NewFortio(WithAffinity(affinity))
assert.Equal(t, affinity, f.affinityLabel)
})
t.Run("WithTesterImage should set test image", func(t *testing.T) {
const testerImage = "image"
f := NewFortio(WithTesterImage(testerImage))
assert.Equal(t, testerImage, f.testerImage)
})
t.Run("WithParams should set test params", func(t *testing.T) {
params := perf.TestParameters{}
f := NewFortio(WithParams(params))
assert.Equal(t, f.params, params)
})
t.Run("WithNumHealthChecks set the number of necessary healthchecks to consider app healthy", func(t *testing.T) {
const numHealthCheck = 2
f := NewFortio(WithNumHealthChecks(numHealthCheck))
assert.Equal(t, numHealthCheck, f.numHealthChecks)
})
t.Run("WithTestAppName should set test app name", func(t *testing.T) {
const appTestName = "test-app"
f := NewFortio(WithTestAppName(appTestName))
assert.Equal(t, appTestName, f.testApp)
})
t.Run("SetParams should set test params and result to nil", func(t *testing.T) {
params := perf.TestParameters{}
f := NewFortio(WithParams(params))
assert.Equal(t, f.params, params)
paramsOthers := perf.TestParameters{
QPS: 1,
}
f.SetParams(paramsOthers)
assert.Equal(t, f.params, paramsOthers)
})
t.Run("valiate should return error when apptesterurl is empty", func(t *testing.T) {
require.Error(t, NewFortio().validate())
})
t.Run("setup should return error if AddApps return an error", func(t *testing.T) {
errFake := errors.New("my-err")
mockPlatform := new(mockPlatform)
mockPlatform.On("AddApps", mock.Anything).Return(errFake)
f := NewFortio()
assert.Equal(t, f.setup(mockPlatform), errFake)
})
t.Run("setup should return error if validate returns an error", func(t *testing.T) {
const appName = "app-test"
mockPlatform := new(mockPlatform)
mockPlatform.On("AddApps", mock.Anything).Return(nil)
mockPlatform.On("AcquireAppExternalURL", appName).Return("")
f := NewFortio(WithTestAppName(appName))
setupErr := f.setup(mockPlatform)
require.Error(t, setupErr)
})
t.Run("Run should return error when validate return an error", func(t *testing.T) {
const appName = "app-test"
mockPlatform := new(mockPlatform)
mockPlatform.On("AddApps", mock.Anything).Return(nil)
mockPlatform.On("AcquireAppExternalURL", appName).Return("")
f := NewFortio(WithTestAppName(appName))
setupErr := f.Run(mockPlatform)
require.Error(t, setupErr)
mockPlatform.AssertNumberOfCalls(t, "AcquireAppExternalURL", 1)
require.Error(t, f.Run(mockPlatform))
mockPlatform.AssertNumberOfCalls(t, "AcquireAppExternalURL", 1)
})
}
|
mikeee/dapr
|
tests/runner/loadtest/fortio_test.go
|
GO
|
mit
| 3,930 |
/*
Copyright 2022 The Dapr Authors
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.
*/
package loadtest
import (
"bytes"
"context"
"encoding/json"
"fmt"
"io"
"log"
"os"
"sync"
"time"
guuid "github.com/google/uuid"
"github.com/dapr/dapr/pkg/injector/annotations"
testplatform "github.com/dapr/dapr/tests/platforms/kubernetes"
"github.com/dapr/dapr/tests/runner"
k6api "github.com/grafana/k6-operator/api/v1alpha1"
batchv1 "k8s.io/api/batch/v1"
corev1 "k8s.io/api/core/v1"
apierrors "k8s.io/apimachinery/pkg/api/errors"
"k8s.io/apimachinery/pkg/api/resource"
v1 "k8s.io/apimachinery/pkg/apis/meta/v1"
"k8s.io/apimachinery/pkg/util/wait"
"k8s.io/client-go/kubernetes"
)
const (
k6ConfigMapPrefix = "k6-tests"
scriptName = "test.js"
defaultK6ServiceAccount = "k6-sa"
// pollInterval is how frequently will poll for updates.
pollInterval = 5 * time.Second
// pollTimeout is how long the test should took.
pollTimeout = 20 * time.Minute
)
// k6ConfigMapFor builds a unique config map for each test being executed.
func k6ConfigMapFor(testName string) string {
return fmt.Sprintf("%s-%s", k6ConfigMapPrefix, testName)
}
// K6GaugeMetric is the representation of a k6 gauge
type K6GaugeMetric struct {
Type string `json:"type"`
Contains string `json:"contains"`
Values struct {
Max int `json:"max"`
P90 int `json:"p(90)"`
P95 int `json:"p(95)"`
Avg int `json:"avg"`
Min int `json:"min"`
Med int `json:"med"`
} `json:"values"`
}
// K6TrendMetric is the representation of a k6 trendmetric
type K6TrendMetric struct {
Type string `json:"type"`
Contains string `json:"contains"`
Values struct {
Max float64 `json:"max"`
P90 float64 `json:"p(90)"`
P95 float64 `json:"p(95)"`
Avg float64 `json:"avg"`
Min float64 `json:"min"`
Med float64 `json:"med"`
} `json:"values"`
}
// K6CounterMetric is a metric that has only count and rate
type K6CounterMetric struct {
Type string `json:"type"`
Contains string `json:"contains"`
Values struct {
Count float64 `json:"count"`
Rate float64 `json:"rate"`
} `json:"values"`
}
// K6Rate metric is the representation of a k6 rate metric
type K6RateMetric struct {
Type string `json:"type"`
Contains string `json:"contains"`
Values struct {
Rate float64 `json:"rate"`
Passes int `json:"passes"`
Fails int `json:"fails"`
} `json:"values"`
}
// K6RunnerMetricsSummary represents a single unit of testing result.
type K6RunnerMetricsSummary struct {
Iterations K6CounterMetric `json:"iterations"`
HTTPReqConnecting K6TrendMetric `json:"http_req_connecting"`
HTTPReqTLSHandshaking K6TrendMetric `json:"http_req_tls_handshaking"`
HTTPReqReceiving K6TrendMetric `json:"http_req_receiving"`
HTTPReqWaiting K6TrendMetric `json:"http_req_waiting"`
HTTPReqSending K6TrendMetric `json:"http_req_sending"`
Checks K6RateMetric `json:"checks"`
DataReceived K6CounterMetric `json:"data_received"`
VusMax K6GaugeMetric `json:"vus_max"`
HTTPReqDurationExpectedResponse *K6TrendMetric `json:"http_req_duration{expected_response:true}"`
HTTPReqDurationNonExpectedResponse *K6TrendMetric `json:"http_req_duration{expected_response:false}"`
Vus K6GaugeMetric `json:"vus"`
HTTPReqFailed K6RateMetric `json:"http_req_failed"`
IterationDuration K6TrendMetric `json:"iteration_duration"`
HTTPReqBlocked K6TrendMetric `json:"http_req_blocked"`
HTTPReqs K6CounterMetric `json:"http_http_reqs"`
DataSent K6CounterMetric `json:"data_sent"`
HTTPReqDuration K6TrendMetric `json:"http_req_duration"`
}
// K6TestSummary is the wrapped k6 results collected for all runners.
type K6TestSummary[T any] struct {
Pass bool `json:"pass"`
RunnersResults []*T `json:"runnersResults"`
}
type K6RunnerSummary[T any] struct {
Metrics T `json:"metrics"`
}
// K6 is used for executing tests using the k6 load testing tool.
type K6 struct {
name string
configName string
script string
appID string
parallelism int
runnerEnv []corev1.EnvVar
addDapr bool
runnerImage string
namespace string
kubeClient kubernetes.Interface
k6Client K6Interface
setupOnce *sync.Once
ctx context.Context
cancel context.CancelFunc
testMemoryLimit string
testMemoryRequest string
daprMemoryLimit string
daprMemoryRequest string
logEnabled bool
}
// collectResult read the pod logs and transform into json output.
func collectResult[T any](k6 *K6, podName string) (*T, error) {
if k6.logEnabled {
return nil, nil
}
req := k6.kubeClient.CoreV1().Pods(k6.namespace).GetLogs(podName, &corev1.PodLogOptions{
Container: "k6",
})
podLogs, err := req.Stream(k6.ctx)
if err != nil {
return nil, err
}
defer podLogs.Close()
buf := new(bytes.Buffer)
_, err = io.Copy(buf, podLogs)
if err != nil {
return nil, fmt.Errorf("unable to copy logs from the pod: %w", err)
}
bts := buf.Bytes()
if len(bts) == 0 {
return nil, nil
}
var k6Result K6RunnerSummary[T]
if err := json.Unmarshal(bts, &k6Result); err != nil {
// this shouldn't normally happen but if it does, let's log output by default
return nil, fmt.Errorf("unable to marshal `%s`: %w", string(bts), err)
}
return &k6Result.Metrics, nil
}
// setupClient setup the kubernetes client
func (k6 *K6) setupClient(k8s *runner.KubeTestPlatform) (err error) {
k6.kubeClient = k8s.KubeClient.ClientSet
crdConfig := *k8s.KubeClient.GetClientConfig()
k6.k6Client, err = newK6Client(&crdConfig, k6.namespace)
return
}
func (k6 *K6) createConfig(ctx context.Context) error {
scriptContent, err := os.ReadFile(k6.script)
if err != nil {
return err
}
configClient := k6.kubeClient.CoreV1().ConfigMaps(k6.namespace)
// ignore not found
if err = configClient.Delete(ctx, k6.configName, v1.DeleteOptions{}); err != nil && !apierrors.IsNotFound(err) {
return err
}
cm := corev1.ConfigMap{
TypeMeta: v1.TypeMeta{Kind: "ConfigMap", APIVersion: "v1"},
ObjectMeta: v1.ObjectMeta{Name: k6.configName, Namespace: k6.namespace},
Data: map[string]string{
scriptName: string(scriptContent),
},
}
_, err = configClient.Create(ctx, &cm, v1.CreateOptions{})
return err
}
// k8sRun run the load test for the given kubernetes platform.
func (k6 *K6) k8sRun(k8s *runner.KubeTestPlatform) error {
var err error
k6.setupOnce.Do(func() {
err = k6.setupClient(k8s)
})
if err != nil {
return err
}
if err = k6.createConfig(k6.ctx); err != nil {
return err
}
if err = k6.Dispose(); err != nil {
return err
}
runnerAnnotations := make(map[string]string)
if k6.addDapr {
runnerAnnotations[annotations.KeyEnabled] = "true"
runnerAnnotations[annotations.KeyAppID] = k6.appID
runnerAnnotations[annotations.KeyMemoryLimit] = k6.daprMemoryLimit
runnerAnnotations[annotations.KeyMemoryRequest] = k6.daprMemoryRequest
}
args := "--include-system-env-vars"
if !k6.logEnabled {
args += " --log-output=none"
}
labels := map[string]string{
testplatform.TestAppLabelKey: k6.name,
}
k6Test := k6api.K6{
TypeMeta: v1.TypeMeta{
Kind: "K6",
APIVersion: "k6.io/v1alpha1",
},
ObjectMeta: v1.ObjectMeta{
Name: k6.name,
Namespace: k6.namespace,
},
Spec: k6api.K6Spec{
Script: k6api.K6Script{
ConfigMap: k6api.K6Configmap{
Name: k6.configName,
File: scriptName,
},
},
Parallelism: int32(k6.parallelism),
Arguments: args,
Starter: k6api.Pod{
Metadata: k6api.PodMetadata{
Labels: labels,
},
},
Runner: k6api.Pod{
ServiceAccountName: defaultK6ServiceAccount,
Env: append(k6.runnerEnv, corev1.EnvVar{
Name: "TEST_NAMESPACE",
Value: k6.namespace,
}),
Image: runner.BuildTestImageName(k6.runnerImage),
Metadata: k6api.PodMetadata{
Annotations: runnerAnnotations,
Labels: labels,
},
Resources: corev1.ResourceRequirements{
Limits: map[corev1.ResourceName]resource.Quantity{
"memory": {
Format: resource.Format(k6.testMemoryLimit),
},
},
Requests: map[corev1.ResourceName]resource.Quantity{
"memory": {
Format: resource.Format(k6.daprMemoryRequest),
},
},
},
},
},
}
_, err = k6.k6Client.Create(k6.ctx, &k6Test)
if err != nil {
return err
}
if err = k6.waitForCompletion(); err != nil {
return err
}
return k6.streamLogs()
}
func (k6 *K6) streamLogs() error {
return testplatform.StreamContainerLogsToDisk(k6.ctx, k6.name, k6.kubeClient.CoreV1().Pods(k6.namespace))
}
// selector return the label selector for the k6 running pods and jobs.
func (k6 *K6) selector() string {
return fmt.Sprintf("k6_cr=%s,runner=true", k6.name)
}
// hasPassed returns true if all k6 related jobs has been succeeded
func (k6 *K6) hasPassed() (bool, error) {
jobsClient := k6.kubeClient.BatchV1().Jobs(k6.namespace)
ctx, cancel := context.WithTimeout(k6.ctx, time.Minute)
jobList, err := jobsClient.List(ctx, v1.ListOptions{
LabelSelector: k6.selector(),
})
cancel()
if err != nil {
return false, err
}
hasPassed := true
for _, job := range jobList.Items {
hasPassed = hasPassed && job.Status.Succeeded == 1
if !hasPassed {
return false, nil
}
}
return hasPassed, nil
}
// K6ResultDefault exports results to k6 default metrics.
func K6ResultDefault(k6 *K6) (*K6TestSummary[K6RunnerMetricsSummary], error) {
return K6Result[K6RunnerMetricsSummary](k6)
}
// K6Result extract the test summary results from pod logs.
func K6Result[T any](k6 *K6) (*K6TestSummary[T], error) {
pods, podErr := k6.kubeClient.CoreV1().Pods(k6.namespace).List(k6.ctx, v1.ListOptions{
LabelSelector: k6.selector(),
})
if podErr != nil {
return nil, podErr
}
runnersResults := make([]*T, 0)
for _, pod := range pods.Items {
runnerResult, err := collectResult[T](k6, pod.Name)
if err != nil {
return nil, err
}
runnersResults = append(runnersResults, runnerResult)
}
pass, err := k6.hasPassed()
if err != nil {
return nil, err
}
return &K6TestSummary[T]{
Pass: pass,
RunnersResults: runnersResults,
}, nil
}
// Run based on platform.
func (k6 *K6) Run(platform runner.PlatformInterface) error {
switch p := platform.(type) {
case *runner.KubeTestPlatform:
return k6.k8sRun(p)
default:
return fmt.Errorf("platform %T not supported", p)
}
}
// isJobCompleted returns true if job object is complete.
func isJobCompleted(job batchv1.Job) bool {
return job.Status.Succeeded+job.Status.Failed >= 1 && job.Status.Active == 0
}
// waitUntilJobsState wait until all jobs achieves the expected state.
func (k6 *K6) waitUntilJobsState(isState func(*batchv1.JobList, error) bool) error {
jobsClient := k6.kubeClient.BatchV1().Jobs(k6.namespace)
ctx, cancel := context.WithTimeout(k6.ctx, pollTimeout)
defer cancel()
waitErr := wait.PollUntilContextCancel(ctx, pollInterval, true, func(ctx context.Context) (bool, error) {
jobList, err := jobsClient.List(ctx, v1.ListOptions{
LabelSelector: k6.selector(),
})
done := isState(jobList, err)
if done {
return true, nil
}
return false, err
})
if waitErr != nil {
return fmt.Errorf("k6 %q is not in desired state, received: %s", k6.name, waitErr)
}
return nil
}
// waitForDeletion wait until all pods are deleted.
func (k6 *K6) waitForDeletion() error {
return k6.waitUntilJobsState(func(jobList *batchv1.JobList, err error) bool {
return (err != nil && apierrors.IsNotFound(err)) || (jobList != nil && len(jobList.Items) == 0)
})
}
// waitForCompletion for the tests until it finish.
func (k6 *K6) waitForCompletion() error {
return k6.waitUntilJobsState(func(jobList *batchv1.JobList, err error) bool {
if err != nil || jobList == nil || len(jobList.Items) < k6.parallelism {
return false
}
for _, job := range jobList.Items {
if !isJobCompleted(job) {
return false
}
}
return true
})
}
// Dispose deletes the test resource.
func (k6 *K6) Dispose() error {
if k6.k6Client == nil {
return nil
}
if err := k6.k6Client.Delete(k6.ctx, k6.name, v1.DeleteOptions{}); err != nil && !apierrors.IsNotFound(err) {
return err
}
return k6.waitForDeletion()
}
type K6Opt = func(*K6)
// WithMemoryLimits set app and dapr memory limits
func WithMemoryLimits(daprRequest, daprLimit, appRequest, appLimit string) K6Opt {
return func(k *K6) {
k.addDapr = true
k.daprMemoryLimit = daprLimit
k.daprMemoryRequest = daprRequest
k.testMemoryLimit = appLimit
k.testMemoryRequest = appRequest
}
}
// WithName sets the test name.
func WithName(name string) K6Opt {
return func(k *K6) {
k.name = name
}
}
// WithAppID sets the appID when dapr is enabled.
func WithAppID(appID string) K6Opt {
return func(k *K6) {
k.appID = appID
}
}
// WithScript set the test script.
func WithScript(script string) K6Opt {
return func(k *K6) {
k.script = script
}
}
// WithParallelism configures the number of parallel runners at once.
func WithParallelism(p int) K6Opt {
return func(k *K6) {
k.parallelism = p
}
}
// DisableDapr disable dapr on runner.
func DisableDapr() K6Opt {
return func(k *K6) {
k.addDapr = false
}
}
// WithRunnerImage sets the runner image, defaults to k6-custom.
func WithRunnerImage(image string) K6Opt {
return func(k *K6) {
k.runnerImage = image
}
}
// WithRunnerEnvVar adds a new env variable to the runner.
func WithRunnerEnvVar(name, value string) K6Opt {
return func(k *K6) {
k.runnerEnv = append(k.runnerEnv, corev1.EnvVar{
Name: name,
Value: value,
})
}
}
// WithNamespace sets the test namespace.
func WithNamespace(namespace string) K6Opt {
return func(k *K6) {
k.namespace = namespace
}
}
// WithCtx sets the test context.
func WithCtx(ctx context.Context) K6Opt {
return func(k *K6) {
mCtx, cancel := context.WithCancel(ctx)
k.ctx = mCtx
k.cancel = cancel
}
}
// EnableLog enables the console output debugging. This should be deactivated when running in production
// to avoid errors when parsing the test result.
func EnableLog() K6Opt {
return func(k *K6) {
k.logEnabled = true
}
}
// NewK6 creates a new k6 load testing with the given options.
func NewK6(scriptPath string, opts ...K6Opt) *K6 {
ctx, cancel := context.WithCancel(context.Background())
uniqueTestID := guuid.New().String()[:6] // to avoid name clash when a clean up is happening
log.Printf("starting %s k6 test", uniqueTestID)
k6Tester := &K6{
name: fmt.Sprintf("k6-test-%s", uniqueTestID),
appID: "k6-tester",
script: scriptPath,
parallelism: 1,
addDapr: true,
runnerImage: "perf-k6-custom",
namespace: testplatform.DaprTestNamespace,
setupOnce: &sync.Once{},
ctx: ctx,
cancel: cancel,
daprMemoryLimit: "512Mi",
daprMemoryRequest: "256Mi",
testMemoryLimit: "1024Mi",
testMemoryRequest: "256Mi",
runnerEnv: []corev1.EnvVar{},
}
for _, opt := range opts {
opt(k6Tester)
}
k6Tester.configName = k6ConfigMapFor(k6Tester.name)
return k6Tester
}
|
mikeee/dapr
|
tests/runner/loadtest/k6.go
|
GO
|
mit
| 15,945 |
/*
Copyright 2022 The Dapr Authors
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.
*/
package loadtest
import (
"context"
"time"
"github.com/dapr/dapr/pkg/client/clientset/versioned/scheme"
v1 "github.com/grafana/k6-operator/api/v1alpha1"
metav1 "k8s.io/apimachinery/pkg/apis/meta/v1"
"k8s.io/apimachinery/pkg/runtime/serializer"
"k8s.io/client-go/rest"
)
type K6Interface interface {
Create(ctx context.Context, k6 *v1.K6) (*v1.K6, error)
Delete(ctx context.Context, name string, opts metav1.DeleteOptions) error
Get(ctx context.Context, name string) (*v1.K6, error)
List(ctx context.Context, opts metav1.ListOptions) (result *v1.K6List, err error)
}
// k6 implements K6Interface
type k6 struct {
client rest.Interface
ns string
}
// newK6Client returns a k6
func newK6Client(crdConfig *rest.Config, namespace string) (*k6, error) {
v1.AddToScheme(scheme.Scheme)
crdConfig.ContentConfig.GroupVersion = &v1.GroupVersion
crdConfig.APIPath = "/apis"
crdConfig.NegotiatedSerializer = serializer.NewCodecFactory(scheme.Scheme)
crdConfig.UserAgent = rest.DefaultKubernetesUserAgent()
restClient, err := rest.RESTClientFor(crdConfig)
if err != nil {
return nil, err
}
return &k6{
client: restClient,
ns: namespace,
}, nil
}
// Delete takes name of the k6 and deletes it. Returns an error if one occurs.
func (c *k6) Delete(ctx context.Context, name string, opts metav1.DeleteOptions) error {
return c.client.Delete().
Namespace(c.ns).
Resource("k6s").
Name(name).
Body(&opts).
Do(ctx).
Error()
}
// Get takes name of the k6, and returns the corresponding k6 object, and an error if there is any.
func (c *k6) Get(ctx context.Context, name string) (result *v1.K6, err error) {
result = &v1.K6{}
err = c.client.Get().
Namespace(c.ns).
Resource("k6s").
Name(name).
Do(ctx).
Into(result)
return
}
// List takes label and field selectors, and returns the list of K6s that match those selectors.
func (c *k6) List(ctx context.Context, opts metav1.ListOptions) (result *v1.K6List, err error) {
var timeout time.Duration
if opts.TimeoutSeconds != nil {
timeout = time.Duration(*opts.TimeoutSeconds) * time.Second
}
result = &v1.K6List{}
err = c.client.Get().
Namespace(c.ns).
Resource("k6s").
VersionedParams(&opts, scheme.ParameterCodec).
Timeout(timeout).
Do(ctx).
Into(result)
return
}
// Create takes the representation of a k6 and creates it. Returns the server's representation of the k6, and an error, if there is any.
func (c *k6) Create(ctx context.Context, k6test *v1.K6) (result *v1.K6, err error) {
result = &v1.K6{}
err = c.client.Post().
Namespace(c.ns).
Resource("k6s").
Body(k6test).
Do(ctx).
Into(result)
return
}
|
mikeee/dapr
|
tests/runner/loadtest/k6_client.go
|
GO
|
mit
| 3,199 |
/*
Copyright 2022 The Dapr Authors
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.
*/
package loadtest
import (
"bytes"
"context"
"io"
"net/http"
"testing"
"github.com/dapr/dapr/pkg/client/clientset/versioned/scheme"
v1 "github.com/grafana/k6-operator/api/v1alpha1"
"github.com/stretchr/testify/assert"
"github.com/stretchr/testify/require"
metav1 "k8s.io/apimachinery/pkg/apis/meta/v1"
"k8s.io/apimachinery/pkg/runtime/serializer"
"k8s.io/client-go/rest"
"k8s.io/client-go/rest/fake"
)
func TestK6Client(t *testing.T) {
const (
fakeNamespace = "fake-namespace"
k6Name = "k6-test"
)
k6, err := newK6Client(&rest.Config{}, fakeNamespace)
require.NoError(t, err)
getClient := func(onRequest func(r *http.Request)) *fake.RESTClient {
return &fake.RESTClient{
Client: fake.CreateHTTPClient(func(r *http.Request) (*http.Response, error) {
onRequest(r)
return &http.Response{
Body: io.NopCloser(bytes.NewBufferString("{}")),
StatusCode: http.StatusOK,
}, nil
}),
GroupVersion: v1.GroupVersion,
VersionedAPIPath: "/apis",
NegotiatedSerializer: serializer.NewCodecFactory(scheme.Scheme),
}
}
t.Run("Delete should call rest DELETE", func(t *testing.T) {
called := 0
k6.client = getClient(func(r *http.Request) {
called++
assert.Equal(t, "DELETE", r.Method)
})
require.NoError(t, k6.Delete(context.Background(), k6Name, metav1.DeleteOptions{}))
assert.Equal(t, 1, called)
})
t.Run("Get should call rest GET", func(t *testing.T) {
called := 0
k6.client = getClient(func(r *http.Request) {
called++
assert.Equal(t, "GET", r.Method)
})
_, err = k6.Get(context.Background(), k6Name)
require.NoError(t, err)
assert.Equal(t, 1, called)
})
t.Run("Create should call rest POST", func(t *testing.T) {
called := 0
k6.client = getClient(func(r *http.Request) {
called++
assert.Equal(t, "POST", r.Method)
})
_, err = k6.Create(context.Background(), &v1.K6{})
require.NoError(t, err)
assert.Equal(t, 1, called)
})
t.Run("List should call rest GET with filters", func(t *testing.T) {
called := 0
k6.client = getClient(func(r *http.Request) {
called++
assert.Equal(t, "GET", r.Method)
})
_, err = k6.List(context.Background(), metav1.ListOptions{})
require.NoError(t, err)
assert.Equal(t, 1, called)
})
}
|
mikeee/dapr
|
tests/runner/loadtest/k6_client_test.go
|
GO
|
mit
| 2,827 |
/*
Copyright 2022 The Dapr Authors
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.
*/
package loadtest
import (
"bytes"
"context"
"errors"
"io"
"net/http"
"os"
"testing"
"github.com/dapr/dapr/tests/runner"
v1 "github.com/grafana/k6-operator/api/v1alpha1"
"github.com/stretchr/testify/assert"
"github.com/stretchr/testify/mock"
"github.com/stretchr/testify/require"
batchv1 "k8s.io/api/batch/v1"
corev1 "k8s.io/api/core/v1"
apierrors "k8s.io/apimachinery/pkg/api/errors"
metav1 "k8s.io/apimachinery/pkg/apis/meta/v1"
"k8s.io/apimachinery/pkg/runtime/schema"
"k8s.io/client-go/kubernetes"
clientBatchv1 "k8s.io/client-go/kubernetes/typed/batch/v1"
clientCoreV1 "k8s.io/client-go/kubernetes/typed/core/v1"
"k8s.io/client-go/rest"
"k8s.io/client-go/rest/fake"
)
type fakeK8sClient struct {
kubernetes.Interface
batchv1 clientBatchv1.BatchV1Interface
corev1 clientCoreV1.CoreV1Interface
}
func (f *fakeK8sClient) BatchV1() clientBatchv1.BatchV1Interface {
return f.batchv1
}
func (f *fakeK8sClient) CoreV1() clientCoreV1.CoreV1Interface {
return f.corev1
}
type fakeCoreV1Client struct {
clientCoreV1.CoreV1Interface
pods clientCoreV1.PodInterface
configMaps clientCoreV1.ConfigMapInterface
}
func (f *fakeCoreV1Client) Pods(namespace string) clientCoreV1.PodInterface {
return f.pods
}
func (f *fakeCoreV1Client) ConfigMaps(namespace string) clientCoreV1.ConfigMapInterface {
return f.configMaps
}
type fakeConfigMapClient struct {
clientCoreV1.ConfigMapInterface
mock.Mock
resp *corev1.ConfigMap
}
func (f *fakeConfigMapClient) Create(ctx context.Context, configMap *corev1.ConfigMap, opts metav1.CreateOptions) (*corev1.ConfigMap, error) {
args := f.Called(ctx, configMap, opts)
return f.resp, args.Error(0)
}
func (f *fakeConfigMapClient) Delete(ctx context.Context, name string, opts metav1.DeleteOptions) error {
args := f.Called(ctx, name, opts)
return args.Error(0)
}
type fakeBatchV1Client struct {
clientBatchv1.BatchV1Interface
jobs clientBatchv1.JobInterface
}
func (f *fakeBatchV1Client) Jobs(namespace string) clientBatchv1.JobInterface {
return f.jobs
}
type fakeJobClient struct {
clientBatchv1.JobInterface
mock.Mock
jobsResult *batchv1.JobList
jobsResultF func() *batchv1.JobList
}
func (f *fakeJobClient) List(ctx context.Context, opts metav1.ListOptions) (*batchv1.JobList, error) {
args := f.Called(ctx, opts)
result := f.jobsResult
if result == nil {
result = f.jobsResultF()
}
return result, args.Error(0)
}
type fakePodClient struct {
clientCoreV1.PodInterface
mock.Mock
listResult *corev1.PodList
request *rest.Request
}
func (f *fakePodClient) List(ctx context.Context, opts metav1.ListOptions) (*corev1.PodList, error) {
args := f.Called(ctx, opts)
return f.listResult, args.Error(0)
}
func (f *fakePodClient) GetLogs(name string, opts *corev1.PodLogOptions) *rest.Request {
return f.request
}
type fakeK6Client struct {
K6Interface
mock.Mock
}
func (f *fakeK6Client) Create(ctx context.Context, k6 *v1.K6) (*v1.K6, error) {
args := f.Called(ctx, k6)
return &v1.K6{}, args.Error(0)
}
func (f *fakeK6Client) Delete(ctx context.Context, name string, opts metav1.DeleteOptions) error {
args := f.Called(ctx, name, opts)
return args.Error(0)
}
func (f *fakeK6Client) Get(ctx context.Context, name string) (*v1.K6, error) {
args := f.Called(ctx, name)
return &v1.K6{}, args.Error(0)
}
func (f *fakeK6Client) List(ctx context.Context, opts metav1.ListOptions) (result *v1.K6List, err error) {
args := f.Called(ctx, opts)
return &v1.K6List{}, args.Error(0)
}
func TestK6(t *testing.T) {
const (
fakeNamespace = "fake"
script = "./fake.js"
)
t.Run("With-ish parameters should configure k6 tester", func(t *testing.T) {
const envVarKey, envVarValue, fakeImg, parallelism, fakeName = "key", "value", "img", 3, "name"
fakeCtx := context.TODO()
tester := NewK6(
script,
WithCtx(fakeCtx),
WithNamespace(fakeNamespace),
WithRunnerEnvVar(envVarKey, envVarValue),
WithRunnerImage(fakeImg),
DisableDapr(),
WithParallelism(parallelism),
WithName(fakeName),
)
assert.Equal(t, script, tester.script)
assert.Equal(t, fakeNamespace, tester.namespace)
assert.Len(t, tester.runnerEnv, 1)
assert.Equal(t, fakeImg, tester.runnerImage)
assert.False(t, tester.addDapr)
assert.Equal(t, parallelism, tester.parallelism)
assert.Equal(t, fakeName, tester.name)
})
t.Run("Dispose should return nil when not client was set", func(t *testing.T) {
require.NoError(t, NewK6("").Dispose())
})
t.Run("Dispose should return nil when delete does not returns an error", func(t *testing.T) {
jobs := new(fakeJobClient)
jobs.jobsResult = &batchv1.JobList{
Items: []batchv1.Job{},
}
kubeClient := &fakeK8sClient{
batchv1: &fakeBatchV1Client{
jobs: jobs,
},
}
jobs.On("List", mock.Anything, mock.Anything).Return(nil)
k6 := NewK6("")
k6.kubeClient = kubeClient
k6Client := new(fakeK6Client)
k6Client.On("Delete", mock.Anything, k6.name, mock.Anything).Return(nil)
k6.k6Client = k6Client
require.NoError(t, k6.Dispose())
k6Client.AssertNumberOfCalls(t, "Delete", 1)
jobs.AssertNumberOfCalls(t, "List", 1)
})
t.Run("Dispose should return nil when delete does returns not found", func(t *testing.T) {
jobs := new(fakeJobClient)
jobs.jobsResult = &batchv1.JobList{
Items: []batchv1.Job{},
}
kubeClient := &fakeK8sClient{
batchv1: &fakeBatchV1Client{
jobs: jobs,
},
}
jobs.On("List", mock.Anything, mock.Anything).Return(nil)
k6 := NewK6("")
k6.kubeClient = kubeClient
k6Client := new(fakeK6Client)
k6Client.On("Delete", mock.Anything, k6.name, mock.Anything).Return(apierrors.NewNotFound(schema.GroupResource{}, "k6"))
k6.k6Client = k6Client
require.NoError(t, k6.Dispose())
k6Client.AssertNumberOfCalls(t, "Delete", 1)
jobs.AssertNumberOfCalls(t, "List", 1)
})
t.Run("Wait should not retry when all jobs has successful finished", func(t *testing.T) {
k6 := NewK6("")
jobs := new(fakeJobClient)
jobs.jobsResult = &batchv1.JobList{
Items: []batchv1.Job{{
Status: batchv1.JobStatus{
Succeeded: 1,
Active: 0,
},
}},
}
kubeClient := &fakeK8sClient{
batchv1: &fakeBatchV1Client{
jobs: jobs,
},
}
k6.kubeClient = kubeClient
jobs.On("List", mock.Anything, mock.Anything).Return(nil)
require.NoError(t, k6.waitForCompletion())
jobs.AssertNumberOfCalls(t, "List", 1)
})
t.Run("Wait should not retry when all jobs has failed", func(t *testing.T) {
k6 := NewK6("")
jobs := new(fakeJobClient)
jobs.jobsResult = &batchv1.JobList{
Items: []batchv1.Job{{
Status: batchv1.JobStatus{
Succeeded: 0,
Failed: 1,
Active: 0,
},
}},
}
kubeClient := &fakeK8sClient{
batchv1: &fakeBatchV1Client{
jobs: jobs,
},
}
k6.kubeClient = kubeClient
jobs.On("List", mock.Anything, mock.Anything).Return(nil)
require.NoError(t, k6.waitForCompletion())
jobs.AssertNumberOfCalls(t, "List", 1)
})
t.Run("Result should return an error if pod list returns an error", func(t *testing.T) {
fakeErr := errors.New("fake")
k6 := NewK6("")
pods := new(fakePodClient)
kubeClient := &fakeK8sClient{
corev1: &fakeCoreV1Client{
pods: pods,
},
}
k6.kubeClient = kubeClient
pods.On("List", mock.Anything, mock.Anything).Return(fakeErr)
_, err := K6ResultDefault(k6)
assert.Equal(t, err, fakeErr)
pods.AssertNumberOfCalls(t, "List", 1)
})
t.Run("Result should not return an error if pod get logs returns pod logs", func(t *testing.T) {
k6 := NewK6("")
pods := new(fakePodClient)
called := 0
fakeClient := fake.CreateHTTPClient(func(r *http.Request) (*http.Response, error) {
called++
return &http.Response{
Body: io.NopCloser(bytes.NewBufferString("{}")),
StatusCode: http.StatusOK,
}, nil
})
pods.request = rest.NewRequestWithClient(nil, "", rest.ClientContentConfig{}, fakeClient)
pods.listResult = &corev1.PodList{
Items: []corev1.Pod{{}},
}
jobs := new(fakeJobClient)
jobs.jobsResult = &batchv1.JobList{
Items: []batchv1.Job{{
Status: batchv1.JobStatus{
Succeeded: 1,
Failed: 0,
Active: 0,
},
}},
}
jobs.On("List", mock.Anything, mock.Anything).Return(nil)
kubeClient := &fakeK8sClient{
corev1: &fakeCoreV1Client{
pods: pods,
},
batchv1: &fakeBatchV1Client{
jobs: jobs,
},
}
k6.kubeClient = kubeClient
pods.On("List", mock.Anything, mock.Anything).Return(nil)
summary, err := K6ResultDefault(k6)
require.NoError(t, err)
pods.AssertNumberOfCalls(t, "List", 1)
jobs.AssertNumberOfCalls(t, "List", 1)
assert.Equal(t, 1, called)
assert.True(t, summary.Pass)
})
t.Run("Result should return an error if pod get logs return an error", func(t *testing.T) {
k6 := NewK6("")
pods := new(fakePodClient)
called := 0
fakeClient := fake.CreateHTTPClient(func(r *http.Request) (*http.Response, error) {
called++
return &http.Response{
Body: io.NopCloser(bytes.NewBufferString("{}")),
StatusCode: http.StatusInternalServerError,
}, nil
})
pods.request = rest.NewRequestWithClient(nil, "", rest.ClientContentConfig{}, fakeClient)
pods.listResult = &corev1.PodList{
Items: []corev1.Pod{{}},
}
kubeClient := &fakeK8sClient{
corev1: &fakeCoreV1Client{
pods: pods,
},
}
k6.kubeClient = kubeClient
pods.On("List", mock.Anything, mock.Anything).Return(nil)
_, err := K6ResultDefault(k6)
require.Error(t, err)
pods.AssertNumberOfCalls(t, "List", 1)
assert.Equal(t, 1, called)
})
t.Run("k8sRun should return an error if file not exists", func(t *testing.T) {
const fileNotExists = "./not_exists.js"
k6 := NewK6(fileNotExists)
k6.setupOnce.Do(func() {}) // call once to avoid be called
require.Error(t, k6.k8sRun(&runner.KubeTestPlatform{}))
})
t.Run("k8sRun should return an error if createconfig returns an error", func(t *testing.T) {
deleteErr := errors.New("fake-delete")
const file = "./file_exists.js"
_, err := os.Create(file)
require.NoError(t, err)
defer os.RemoveAll(file)
k6 := NewK6(file)
k6.setupOnce.Do(func() {}) // call once to avoid be called
configMaps := new(fakeConfigMapClient)
configMaps.On("Delete", mock.Anything, mock.Anything, mock.Anything).Return(deleteErr)
k6.kubeClient = &fakeK8sClient{
corev1: &fakeCoreV1Client{
configMaps: configMaps,
},
}
assert.Equal(t, k6.k8sRun(&runner.KubeTestPlatform{}), deleteErr)
configMaps.AssertNumberOfCalls(t, "Delete", 1)
})
t.Run("k8sRun should call k6client delete and create", func(t *testing.T) {
jobs := new(fakeJobClient)
called := 0
jobs.jobsResultF = func() *batchv1.JobList {
called++
if called == 2 {
return &batchv1.JobList{
Items: []batchv1.Job{{
Status: batchv1.JobStatus{
Succeeded: 1,
Active: 0,
},
}},
}
}
return &batchv1.JobList{
Items: []batchv1.Job{},
}
}
jobs.On("List", mock.Anything, mock.Anything).Return(nil)
pods := &fakePodClient{
listResult: &corev1.PodList{
Items: []corev1.Pod{},
},
}
pods.On("List", mock.Anything, mock.Anything).Return(nil)
const file = "./file_exists.js"
_, err := os.Create(file)
require.NoError(t, err)
defer os.RemoveAll(file)
k6 := NewK6(file)
k6.setupOnce.Do(func() {}) // call once to avoid be called
configMaps := new(fakeConfigMapClient)
configMaps.On("Delete", mock.Anything, mock.Anything, mock.Anything).Return(nil)
configMaps.On("Create", mock.Anything, mock.Anything, mock.Anything).Return(nil)
k6.kubeClient = &fakeK8sClient{
corev1: &fakeCoreV1Client{
configMaps: configMaps,
pods: pods,
},
batchv1: &fakeBatchV1Client{
jobs: jobs,
},
}
k6Client := new(fakeK6Client)
k6Client.On("Delete", mock.Anything, k6.name, mock.Anything).Return(nil)
k6Client.On("Create", mock.Anything, mock.Anything).Return(nil)
k6.k6Client = k6Client
require.NoError(t, k6.k8sRun(&runner.KubeTestPlatform{}))
configMaps.AssertNumberOfCalls(t, "Delete", 1)
configMaps.AssertNumberOfCalls(t, "Create", 1)
k6Client.AssertNumberOfCalls(t, "Create", 1)
k6Client.AssertNumberOfCalls(t, "Delete", 1)
jobs.AssertNumberOfCalls(t, "List", 2)
pods.AssertNumberOfCalls(t, "List", 1)
})
}
|
mikeee/dapr
|
tests/runner/loadtest/k6_test.go
|
GO
|
mit
| 12,799 |
/*
Copyright 2023 The Dapr Authors
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.
*/
package summary
import (
"encoding/json"
"fmt"
"os"
"strconv"
"strings"
"testing"
"github.com/dapr/dapr/tests/perf"
"github.com/dapr/dapr/tests/runner/loadtest"
"github.com/dapr/kit/logger"
)
const (
// testNameSeparator is the default character used by go test to separate between suitecases under the same test func.
testNameSeparator = "/"
)
var log = logger.NewLogger("tests.runner.summary")
func sanitizeTestName(testName string) string {
return strings.ReplaceAll(testName, testNameSeparator, "_")
}
func filePath(prefix, testName string) string {
return fmt.Sprintf("%s_summary_table_%s.json", prefix, sanitizeTestName(testName))
}
// Table is primarily used as a source of arbitrary test output. Tests can send output to the summary table and later flush them.
// when flush is called so the table is serialized into a file that contains the test name on it, so you should use one table per test.
// the table output is typically used as a github enhanced job summary.
// see more: https://github.blog/2022-05-09-supercharging-github-actions-with-job-summaries/
type Table struct {
Test string `json:"test"`
Data [][2]string `json:"data"`
}
// Output adds a pair to the table data pairs.
func (t *Table) Output(header, value string) *Table {
t.Data = append(t.Data, [2]string{header, value})
return t
}
// OutputInt same as output but converts from int to string.
func (t *Table) OutputInt(header string, value int) *Table {
return t.Output(header, strconv.Itoa(value))
}
// OutputFloat64 same as output but converts from float64 to string.
func (t *Table) OutputFloat64(header string, value float64) *Table {
return t.Outputf(header, "%f", value)
}
// Outputf same as output but uses a formatter.
func (t *Table) Outputf(header, format string, params ...any) *Table {
return t.Output(header, fmt.Sprintf(format, params...))
}
// Service is a shortcut for .Output("Service")
func (t *Table) Service(serviceName string) *Table {
return t.Output("Service", serviceName)
}
// Service is a shortcut for .Output("Client")
func (t *Table) Client(clientName string) *Table {
return t.Output("Client", clientName)
}
// CPU is a shortcut for .Outputf("CPU", "%vm")
func (t *Table) CPU(cpu int64) *Table {
return t.Outputf("CPU", "%vm", cpu)
}
// Memory is a shortcut for .Outputf("Memory", "%vm")
func (t *Table) Memory(cpu float64) *Table {
return t.Outputf("Memory", "%vMb", cpu)
}
// SidecarCPU is a shortcut for .Outputf("Sidecar CPU", "%vm")
func (t *Table) SidecarCPU(cpu int64) *Table {
return t.Outputf("Sidecar CPU", "%vm", cpu)
}
// BaselineLatency is a shortcut for Outputf("Baseline latency avg", "%2.fms")
func (t *Table) BaselineLatency(latency float64) *Table {
return t.Outputf("Baseline latency avg", "%.2fms", latency)
}
// DaprLatency is a shortcut for Outputf("Dapr latency avg", "%2.fms")
func (t *Table) DaprLatency(latency float64) *Table {
return t.Outputf("Dapr latency avg", "%.2fms", latency)
}
// AddedLatency is a shortcut for Outputf("Added latency avg", "%2.fms")
func (t *Table) AddedLatency(latency float64) *Table {
return t.Outputf("Added latency avg", "%.2fms", latency)
}
// SidecarMemory is a shortcut for .Outputf("Sidecar Memory", "%vm")
func (t *Table) SidecarMemory(cpu float64) *Table {
return t.Outputf("Sidecar Memory", "%vMb", cpu)
}
// Restarts is a shortcut for .OutputInt("Restarts")
func (t *Table) Restarts(restarts int) *Table {
return t.OutputInt("Restarts", restarts)
}
// ActualQPS is a short for .Outputf("QPS", ".2f")
func (t *Table) ActualQPS(qps float64) *Table {
return t.Outputf("Actual QPS", "%.2f", qps)
}
// QPS is a short for .OutputInt("QPS")
func (t *Table) QPS(qps int) *Table {
return t.OutputInt("QPS", qps)
}
// P90 is a short for .Outputf("P90", "%2.fms")
func (t *Table) P90(p90 float64) *Table {
return t.Outputf("P90", "%.2fms", p90)
}
// P90 is a short for .Outputf("P90", "%2.fms")
func (t *Table) P99(p99 float64) *Table {
return t.Outputf("P99", "%.2fms", p99)
}
// QPS is a short for .OutputInt("QPS")
func (t *Table) Params(p perf.TestParameters) *Table {
return t.QPS(p.QPS).
OutputInt("Client connections", p.ClientConnections).
Output("Target endpoint", p.TargetEndpoint).
Output("Test duration", p.TestDuration).
OutputInt("PayloadSizeKB", p.PayloadSizeKB)
}
type unit string
const (
millisecond unit = "ms"
)
var unitFormats = map[unit]string{
millisecond: "%.2fms",
}
// OutputK6Trend outputs the given k6trend using the given prefix.
func (t *Table) OutputK6Trend(prefix string, unit unit, trend loadtest.K6TrendMetric) *Table {
t.Outputf(fmt.Sprintf("%s MAX", prefix), unitFormats[unit], trend.Values.Max)
t.Outputf(fmt.Sprintf("%s MIN", prefix), unitFormats[unit], trend.Values.Min)
t.Outputf(fmt.Sprintf("%s AVG", prefix), unitFormats[unit], trend.Values.Avg)
t.Outputf(fmt.Sprintf("%s MED", prefix), unitFormats[unit], trend.Values.Med)
t.Outputf(fmt.Sprintf("%s P90", prefix), unitFormats[unit], trend.Values.P90)
t.Outputf(fmt.Sprintf("%s P95", prefix), unitFormats[unit], trend.Values.P95)
return t
}
const (
p90Index = 2
p99Index = 3
)
const (
secondToMillisecond = 1000
)
// OutputFortio summarize the fortio results.
func (t *Table) OutputFortio(result perf.TestResult) *Table {
return t.
P90(result.DurationHistogram.Percentiles[p90Index].Value*secondToMillisecond).
P99(result.DurationHistogram.Percentiles[p99Index].Value*secondToMillisecond).
OutputInt("2xx", result.RetCodes.Num200).
OutputInt("4xx", result.RetCodes.Num400).
OutputInt("5xx", result.RetCodes.Num500)
}
// OutputK6 summarize the K6 results for each runner.
func (t *Table) OutputK6(k6results []*loadtest.K6RunnerMetricsSummary) *Table {
for i, result := range k6results {
t.OutputInt(fmt.Sprintf("[Runner %d]: VUs Max", i), result.Vus.Values.Max)
t.OutputFloat64(fmt.Sprintf("[Runner %d]: Iterations Count", i), result.Iterations.Values.Count)
t.OutputK6Trend(fmt.Sprintf("[Runner %d]: Req Duration", i), millisecond, result.HTTPReqDuration)
t.OutputK6Trend(fmt.Sprintf("[Runner %d]: Req Waiting", i), millisecond, result.HTTPReqWaiting)
t.OutputK6Trend(fmt.Sprintf("[Runner %d]: Iteration Duration", i), millisecond, result.IterationDuration)
}
return t
}
// Flush saves the summary into the disk using the desired format.
func (t *Table) Flush() error {
bts, err := json.Marshal(t)
if err != nil {
log.Errorf("error when marshalling table %s: %v", t.Test, err)
return err
}
filePrefixOutput, ok := os.LookupEnv("TEST_OUTPUT_FILE_PREFIX")
if !ok {
filePrefixOutput = "./test_report"
}
err = os.WriteFile(filePath(filePrefixOutput, t.Test), bts, os.ModePerm)
if err != nil {
log.Errorf("error when saving table %s: %v", t.Test, err)
return err
}
return nil
}
// ForTest returns a table ready to be written for the given test.
func ForTest(tst *testing.T) *Table {
return &Table{
Test: tst.Name(),
Data: [][2]string{},
}
}
|
mikeee/dapr
|
tests/runner/summary/summary.go
|
GO
|
mit
| 7,499 |
/*
Copyright 2023 The Dapr Authors
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.
*/
package summary
import (
"encoding/json"
"os"
"path"
"testing"
"github.com/stretchr/testify/assert"
"github.com/stretchr/testify/require"
)
func TestSummary(t *testing.T) {
t.Run("flush should save file", func(t *testing.T) {
dir := t.TempDir()
prefix := path.Join(dir, "test_report")
t.Setenv("TEST_OUTPUT_FILE_PREFIX", prefix)
summary := ForTest(t)
summary.Output("test", "test").OutputInt("test", 2).Outputf("test", "%s", "1")
require.NoError(t, summary.Flush())
f, err := os.ReadFile(filePath(prefix, t.Name()))
require.NoError(t, err)
tab := &Table{}
require.NoError(t, json.Unmarshal(f, &tab))
assert.Len(t, tab.Data, 3)
assert.Equal(t, tab.Test, t.Name())
})
}
|
mikeee/dapr
|
tests/runner/summary/summary_test.go
|
GO
|
mit
| 1,264 |
/*
Copyright 2022 The Dapr Authors
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.
*/
package runner
import (
"fmt"
"os"
)
const (
// defaultImageRegistry is the registry used by test apps by default.
defaultImageRegistry = "docker.io/dapriotest"
// defaultImageTag is the default image used for test apps.
defaultImageTag = "latest"
)
// getTestImageRegistry get the test image registry from the env var or uses the default value if not present or empty.
func getTestImageRegistry() string {
reg := os.Getenv("DAPR_TEST_REGISTRY")
if reg == "" {
return defaultImageRegistry
}
return reg
}
// getTestImageSecret get the test image secret from the env var or uses the default value if not present or empty.
func getTestImageSecret() string {
secret := os.Getenv("DAPR_TEST_REGISTRY_SECRET")
if secret == "" {
return ""
}
return secret
}
// getTestImageTag get the test image Tag from the env var or uses the default value if not present or empty.
func getTestImageTag() string {
tag := os.Getenv("DAPR_TEST_TAG")
if tag == "" {
return defaultImageTag
}
return tag
}
// BuildTestImage name uses the default registry and tag to build a image name for the given test app.
func BuildTestImageName(appName string) string {
return fmt.Sprintf("%s/%s:%s", getTestImageRegistry(), appName, getTestImageTag())
}
|
mikeee/dapr
|
tests/runner/test_registry.go
|
GO
|
mit
| 1,808 |
/*
Copyright 2022 The Dapr Authors
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.
*/
package runner
import (
"fmt"
"testing"
"github.com/stretchr/testify/assert"
)
func TestBuildImageName(t *testing.T) {
t.Run("build image name should use default values when none was set", func(t *testing.T) {
t.Setenv("DAPR_TEST_REGISTRY", "")
t.Setenv("DAPR_TEST_TAG", "")
const fakeApp = "fake"
image := BuildTestImageName(fakeApp)
assert.Equal(t, image, fmt.Sprintf("%s/%s:%s", defaultImageRegistry, fakeApp, defaultImageTag))
})
t.Run("build image name should use test image registry when set", func(t *testing.T) {
const fakeRegistry = "fake-registry"
t.Setenv("DAPR_TEST_REGISTRY", fakeRegistry)
t.Setenv("DAPR_TEST_TAG", "")
const fakeApp = "fake"
image := BuildTestImageName(fakeApp)
assert.Equal(t, image, fmt.Sprintf("%s/%s:%s", fakeRegistry, fakeApp, defaultImageTag))
})
t.Run("build image name should use test tag when set", func(t *testing.T) {
const fakeTag = "fake-tag"
t.Setenv("DAPR_TEST_REGISTRY", "")
t.Setenv("DAPR_TEST_TAG", fakeTag)
const fakeApp = "fake"
image := BuildTestImageName(fakeApp)
assert.Equal(t, image, fmt.Sprintf("%s/%s:%s", defaultImageRegistry, fakeApp, fakeTag))
})
}
|
mikeee/dapr
|
tests/runner/test_registry_test.go
|
GO
|
mit
| 1,720 |
/*
Copyright 2021 The Dapr Authors
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.
*/
package runner
import (
"context"
"errors"
"fmt"
"os"
"sync"
)
// Disposable is an interface representing the disposable test resources.
type Disposable interface {
Name() string
Init(ctx context.Context) error
Dispose(wait bool) error
}
// TestResources holds initial resources and active resources.
type TestResources struct {
resources []Disposable
resourcesLock sync.Mutex
activeResources []Disposable
activeResourcesLock sync.Mutex
ctx context.Context
cancel context.CancelFunc
}
// Add adds Disposable resource to resources queue.
func (r *TestResources) Add(dr Disposable) {
r.resourcesLock.Lock()
defer r.resourcesLock.Unlock()
r.resources = append(r.resources, dr)
}
// dequeueResource dequeues Disposable resource from resources queue.
func (r *TestResources) dequeueResource() Disposable {
r.resourcesLock.Lock()
defer r.resourcesLock.Unlock()
if len(r.resources) == 0 {
return nil
}
dr := r.resources[0]
r.resources = r.resources[1:]
return dr
}
// pushActiveResource pushes Disposable resource to ActiveResource stack.
func (r *TestResources) pushActiveResource(dr Disposable) {
r.activeResourcesLock.Lock()
defer r.activeResourcesLock.Unlock()
r.activeResources = append(r.activeResources, dr)
}
// popActiveResource pops Disposable resource from ActiveResource stack.
func (r *TestResources) popActiveResource() Disposable {
r.activeResourcesLock.Lock()
defer r.activeResourcesLock.Unlock()
if len(r.activeResources) == 0 {
return nil
}
dr := r.activeResources[len(r.activeResources)-1]
r.activeResources = r.activeResources[:len(r.activeResources)-1]
return dr
}
// FindActiveResource finds active resource by resource name.
func (r *TestResources) FindActiveResource(name string) Disposable {
for _, res := range r.activeResources {
if res.Name() == name {
return res
}
}
return nil
}
// Setup initializes the resources by calling Setup.
func (r *TestResources) setup() error {
r.ctx, r.cancel = context.WithCancel(context.Background())
resourceCount := 0
errs := make(chan error)
for {
dr := r.dequeueResource()
if dr == nil {
break
}
resourceCount++
go func() {
err := dr.Init(r.ctx)
r.pushActiveResource(dr)
errs <- err
}()
}
allErrs := make([]error, 0)
for i := 0; i < resourceCount; i++ {
err := <-errs
if err != nil {
allErrs = append(allErrs, err)
}
}
return errors.Join(allErrs...)
}
// TearDown initializes the resources by calling Dispose.
func (r *TestResources) tearDown() error {
resourceCount := 0
errs := make(chan error)
for {
dr := r.popActiveResource()
if dr == nil {
break
}
resourceCount++
go func() {
err := dr.Dispose(false)
if err != nil {
err = fmt.Errorf("failed to tear down %s. got: %w", dr.Name(), err)
}
errs <- err
}()
}
allErrs := make([]error, 0)
for i := 0; i < resourceCount; i++ {
err := <-errs
if err != nil {
os.Stderr.WriteString(err.Error() + "\n")
allErrs = append(allErrs, err)
}
}
if r.cancel != nil {
r.cancel()
r.cancel = nil
}
return errors.Join(allErrs...)
}
|
mikeee/dapr
|
tests/runner/testresource.go
|
GO
|
mit
| 3,697 |
/*
Copyright 2021 The Dapr Authors
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.
*/
package runner
import (
"context"
"fmt"
"testing"
"github.com/stretchr/testify/assert"
"github.com/stretchr/testify/mock"
"github.com/stretchr/testify/require"
"golang.org/x/exp/slices"
)
// MockDisposable is the mock of Disposable interface.
type MockDisposable struct {
mock.Mock
}
func (m *MockDisposable) Name() string {
args := m.Called()
return args.String(0)
}
func (m *MockDisposable) Init(ctx context.Context) error {
args := m.Called()
return args.Error(0)
}
func (m *MockDisposable) Dispose(wait bool) error {
args := m.Called()
return args.Error(0)
}
func TestAdd(t *testing.T) {
resource := new(TestResources)
for i := 0; i < 3; i++ {
r := new(MockDisposable)
r.On("Name").Return(fmt.Sprintf("resource - %d", i))
resource.Add(r)
}
for i, r := range resource.resources {
assert.Equal(t, fmt.Sprintf("resource - %d", i), r.Name())
}
}
func TestSetup(t *testing.T) {
t.Run("active all resources", func(t *testing.T) {
expect := []string{}
resource := new(TestResources)
for i := 0; i < 3; i++ {
name := fmt.Sprintf("resource - %d", i)
r := new(MockDisposable)
r.On("Name").Return(name)
r.On("Init").Return(nil)
resource.Add(r)
expect = append(expect, name)
}
err := resource.setup()
require.NoError(t, err)
found := []string{}
for i := 2; i >= 0; i-- {
r := resource.popActiveResource()
found = append(found, r.Name())
}
slices.Sort(expect)
slices.Sort(found)
assert.Equal(t, expect, found)
})
t.Run("fails to setup resources and stops the process", func(t *testing.T) {
expect := []string{}
resource := new(TestResources)
for i := 0; i < 3; i++ {
name := fmt.Sprintf("resource - %d", i)
r := new(MockDisposable)
r.On("Name").Return(name)
if i != 1 {
r.On("Init").Return(nil)
} else {
r.On("Init").Return(fmt.Errorf("setup error %d", i))
}
expect = append(expect, name)
resource.Add(r)
}
err := resource.setup()
require.Error(t, err)
found := []string{}
for i := 2; i >= 0; i-- {
r := resource.popActiveResource()
found = append(found, r.Name())
}
r := resource.popActiveResource()
assert.Nil(t, r)
slices.Sort(expect)
slices.Sort(found)
assert.Equal(t, expect, found)
})
}
func TestTearDown(t *testing.T) {
t.Run("tear down successfully", func(t *testing.T) {
// adding 3 mock resources
resource := new(TestResources)
for i := 0; i < 3; i++ {
r := new(MockDisposable)
r.On("Name").Return(fmt.Sprintf("resource - %d", i))
r.On("Init").Return(nil)
r.On("Dispose").Return(nil)
resource.Add(r)
}
// setup resources
err := resource.setup()
require.NoError(t, err)
// tear down all resources
err = resource.tearDown()
require.NoError(t, err)
r := resource.popActiveResource()
assert.Nil(t, r)
})
t.Run("ignore failures of disposing resources", func(t *testing.T) {
// adding 3 mock resources
resource := new(TestResources)
for i := 0; i < 3; i++ {
r := new(MockDisposable)
r.On("Name").Return(fmt.Sprintf("resource - %d", i))
r.On("Init").Return(nil)
if i == 1 {
r.On("Dispose").Return(fmt.Errorf("dispose error"))
} else {
r.On("Dispose").Return(nil)
}
resource.Add(r)
}
// setup resources
err := resource.setup()
require.NoError(t, err)
// tear down all resources
err = resource.tearDown()
require.Error(t, err)
r := resource.popActiveResource()
assert.Nil(t, r)
})
}
|
mikeee/dapr
|
tests/runner/testresource_test.go
|
GO
|
mit
| 4,003 |
/*
Copyright 2021 The Dapr Authors
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.
*/
package runner
import (
"fmt"
"log"
"os"
corev1 "k8s.io/api/core/v1"
configurationv1alpha1 "github.com/dapr/dapr/pkg/apis/configuration/v1alpha1"
kube "github.com/dapr/dapr/tests/platforms/kubernetes"
)
// runnerFailExitCode is the exit code when test runner setup is failed.
const runnerFailExitCode = 1
// runnable is an interface to implement testing.M.
type runnable interface {
Run() int
}
type LoadTester interface {
Run(platform PlatformInterface) error
}
// PlatformInterface defines the testing platform for test runner.
//
//nolint:interfacebloat
type PlatformInterface interface {
Setup() error
TearDown() error
AddComponents(comps []kube.ComponentDescription) error
AddApps(apps []kube.AppDescription) error
AddSecrets(secrets []kube.SecretDescription) error
AcquireAppExternalURL(name string) string
GetAppHostDetails(name string) (string, string, error)
Restart(name string) error
Scale(name string, replicas int32) error
PortForwardToApp(appName string, targetPort ...int) ([]int, error)
SetAppEnv(appName, key, value string) error
GetAppUsage(appName string) (*AppUsage, error)
GetSidecarUsage(appName string) (*AppUsage, error)
GetTotalRestarts(appname string) (int, error)
GetConfiguration(name string) (*configurationv1alpha1.Configuration, error)
GetService(name string) (*corev1.Service, error)
LoadTest(loadtester LoadTester) error
}
// AppUsage holds the CPU and Memory information for the application.
type AppUsage struct {
CPUm int64
MemoryMb float64
}
// TestRunner holds initial test apps and testing platform instance
// maintains apps and platform for e2e test.
type TestRunner struct {
// id is test runner id which will be used for logging
id string
components []kube.ComponentDescription
// Initialization apps to be deployed before the test apps
initApps []kube.AppDescription
// TODO: Needs to define kube.AppDescription more general struct for Dapr app
testApps []kube.AppDescription
// secrets is the list of secrets to be created in the cluster
secrets []kube.SecretDescription
// Platform is the testing platform instances
Platform PlatformInterface
}
// NewTestRunner returns TestRunner instance for e2e test.
func NewTestRunner(id string, apps []kube.AppDescription,
comps []kube.ComponentDescription,
initApps []kube.AppDescription,
) *TestRunner {
return &TestRunner{
id: id,
components: comps,
initApps: initApps,
testApps: apps,
Platform: NewKubeTestPlatform(),
}
}
func (tr *TestRunner) AddSecrets(secrets []kube.SecretDescription) {
tr.secrets = secrets
}
// Start is the entry point of Dapr test runner.
func (tr *TestRunner) Start(m runnable) int {
// TODO: Add logging and reporting initialization
// Setup testing platform
log.Println("Running setup...")
err := tr.Platform.Setup()
defer func() {
log.Println("Running teardown...")
tr.TearDown()
}()
if err != nil {
fmt.Fprintf(os.Stderr, "Failed Platform.setup(), %s", err.Error())
return runnerFailExitCode
}
if tr.secrets != nil && len(tr.secrets) > 0 {
if err := tr.Platform.AddSecrets(tr.secrets); err != nil {
fmt.Fprintf(os.Stderr, "Failed Platform.addSecrets(), %s", err.Error())
return runnerFailExitCode
}
}
// Install components.
if tr.components != nil && len(tr.components) > 0 {
log.Println("Installing components...")
if err := tr.Platform.AddComponents(tr.components); err != nil {
fmt.Fprintf(os.Stderr, "Failed Platform.addComponents(), %s", err.Error())
return runnerFailExitCode
}
}
// Install init apps. Init apps will be deployed before the main
// test apps and can be used to initialize components and perform
// other setup work.
if tr.initApps != nil && len(tr.initApps) > 0 {
log.Println("Installing init apps...")
if err := tr.Platform.AddApps(tr.initApps); err != nil {
fmt.Fprintf(os.Stderr, "Failed Platform.addInitApps(), %s", err.Error())
return runnerFailExitCode
}
}
// Install test apps. These are the main apps that provide the actual testing.
if tr.testApps != nil && len(tr.testApps) > 0 {
log.Println("Installing test apps...")
if err := tr.Platform.AddApps(tr.testApps); err != nil {
fmt.Fprintf(os.Stderr, "Failed Platform.addApps(), %s", err.Error())
return runnerFailExitCode
}
}
// Executes Test* methods in *_test.go
log.Println("Running tests...")
return m.Run()
}
func (tr *TestRunner) TearDown() {
// Tearing down platform
tr.Platform.TearDown()
// TODO: Add the resources which will be tearing down
}
|
mikeee/dapr
|
tests/runner/testrunner.go
|
GO
|
mit
| 5,091 |
/*
Copyright 2021 The Dapr Authors
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.
*/
package runner
import (
"fmt"
"testing"
"github.com/stretchr/testify/assert"
"github.com/stretchr/testify/mock"
corev1 "k8s.io/api/core/v1"
configurationv1alpha1 "github.com/dapr/dapr/pkg/apis/configuration/v1alpha1"
kube "github.com/dapr/dapr/tests/platforms/kubernetes"
)
type fakeTestingM struct{}
func (f *fakeTestingM) Run() int {
return 0
}
// MockPlatform is the mock of Disposable interface.
type MockPlatform struct {
mock.Mock
}
func (m *MockPlatform) Setup() error {
args := m.Called()
return args.Error(0)
}
func (m *MockPlatform) TearDown() error {
args := m.Called()
return args.Error(0)
}
func (m *MockPlatform) AcquireAppExternalURL(name string) string {
args := m.Called(name)
return args.String(0)
}
func (m *MockPlatform) GetAppHostDetails(name string) (string, string, error) {
args := m.Called(name)
return args.String(0), args.String(0), args.Error(0)
}
func (m *MockPlatform) AddComponents(comps []kube.ComponentDescription) error {
args := m.Called(comps)
return args.Error(0)
}
func (m *MockPlatform) AddApps(apps []kube.AppDescription) error {
args := m.Called(apps)
return args.Error(0)
}
func (m *MockPlatform) Scale(name string, replicas int32) error {
args := m.Called(replicas)
return args.Error(0)
}
func (m *MockPlatform) SetAppEnv(name, key, value string) error {
args := m.Called(key)
return args.Error(0)
}
func (m *MockPlatform) Restart(name string) error {
args := m.Called(name)
return args.Error(0)
}
func (m *MockPlatform) PortForwardToApp(appName string, targetPort ...int) ([]int, error) {
args := m.Called(appName)
return []int{}, args.Error(0)
}
func (m *MockPlatform) GetAppUsage(appName string) (*AppUsage, error) {
args := m.Called(appName)
return &AppUsage{}, args.Error(0)
}
func (m *MockPlatform) GetSidecarUsage(appName string) (*AppUsage, error) {
args := m.Called(appName)
return &AppUsage{}, args.Error(0)
}
func (m *MockPlatform) GetTotalRestarts(appName string) (int, error) {
args := m.Called(appName)
return 0, args.Error(0)
}
func (m *MockPlatform) GetConfiguration(name string) (*configurationv1alpha1.Configuration, error) {
args := m.Called(name)
return &configurationv1alpha1.Configuration{}, args.Error(0)
}
func (m *MockPlatform) GetService(name string) (*corev1.Service, error) {
args := m.Called(name)
return &corev1.Service{}, args.Error(0)
}
func (m *MockPlatform) LoadTest(loadtester LoadTester) error {
args := m.Called(loadtester)
return args.Error(0)
}
func (m *MockPlatform) AddSecrets(secrets []kube.SecretDescription) error {
args := m.Called(secrets)
return args.Error(0)
}
func TestStartRunner(t *testing.T) {
fakeTestApps := []kube.AppDescription{
{
AppName: "fakeapp",
DaprEnabled: true,
ImageName: "fakeapp",
RegistryName: "fakeregistry",
Replicas: 1,
IngressEnabled: true,
MetricsEnabled: true,
},
{
AppName: "fakeapp1",
DaprEnabled: true,
ImageName: "fakeapp",
RegistryName: "fakeregistry",
Replicas: 1,
IngressEnabled: true,
MetricsEnabled: true,
},
}
fakeComps := []kube.ComponentDescription{
{
Name: "statestore",
TypeName: "state.fake",
MetaData: map[string]kube.MetadataValue{
"address": {Raw: "localhost"},
"password": {Raw: "fakepassword"},
},
},
}
t.Run("Run Runner successfully", func(t *testing.T) {
mockPlatform := new(MockPlatform)
mockPlatform.On("TearDown").Return(nil)
mockPlatform.On("Setup").Return(nil)
mockPlatform.On("AddApps", fakeTestApps).Return(nil)
mockPlatform.On("AddComponents", fakeComps).Return(nil)
fakeRunner := &TestRunner{
id: "fakeRunner",
components: fakeComps,
testApps: fakeTestApps,
Platform: mockPlatform,
}
ret := fakeRunner.Start(&fakeTestingM{})
assert.Equal(t, 0, ret)
mockPlatform.AssertNumberOfCalls(t, "Setup", 1)
mockPlatform.AssertNumberOfCalls(t, "TearDown", 1)
mockPlatform.AssertNumberOfCalls(t, "AddApps", 1)
mockPlatform.AssertNumberOfCalls(t, "AddComponents", 1)
})
t.Run("setup is failed, but teardown is called", func(t *testing.T) {
mockPlatform := new(MockPlatform)
mockPlatform.On("Setup").Return(fmt.Errorf("setup is failed"))
mockPlatform.On("TearDown").Return(nil)
mockPlatform.On("AddApps", fakeTestApps).Return(nil)
mockPlatform.On("AddComponents", fakeComps).Return(nil)
fakeRunner := &TestRunner{
id: "fakeRunner",
components: fakeComps,
testApps: fakeTestApps,
Platform: mockPlatform,
}
ret := fakeRunner.Start(&fakeTestingM{})
assert.Equal(t, 1, ret)
mockPlatform.AssertNumberOfCalls(t, "Setup", 1)
mockPlatform.AssertNumberOfCalls(t, "TearDown", 1)
mockPlatform.AssertNumberOfCalls(t, "AddApps", 0)
mockPlatform.AssertNumberOfCalls(t, "AddComponents", 0)
})
}
|
mikeee/dapr
|
tests/runner/testrunner_test.go
|
GO
|
mit
| 5,384 |
#!/bin/bash
set -e
DAPR_TEST_NAMESPACE=${DAPR_TEST_NAMESPACE:-dapr-tests}
TAILSCALE_NAMESPACE=${TAILSCALE_NAMESPACE:-dapr-tests}
# Pod and service cidr used by tailscale subnet router
POD_CIDR=$(kubectl cluster-info dump | grep -m 1 cluster-cidr |grep -E -o "([0-9]{1,3}[\.]){3}[0-9]{1,3}/[0-9]{1,3}")
SERVICE_CIDR=$(echo '{"apiVersion":"v1","kind":"Service","metadata":{"name":"tst"},"spec":{"clusterIP":"1.1.1.1","ports":[{"port":443}]}}' | kubectl apply -f - 2>&1 | sed 's/.*valid IPs is //')
# Setup tailscale manifests
kubectl apply -f ./tests/config/tailscale_role.yaml --namespace $TAILSCALE_NAMESPACE
kubectl apply -f ./tests/config/tailscale_rolebinding.yaml --namespace $TAILSCALE_NAMESPACE
kubectl apply -f ./tests/config/tailscale_sa.yaml --namespace $TAILSCALE_NAMESPACE
sed -e "s;{{TS_AUTH_KEY}};$TAILSCALE_AUTH_KEY;g" ./tests/config/tailscale_key.yaml | kubectl apply --namespace $TAILSCALE_NAMESPACE -f -
# Set service CIDR and pod CIDR for the tailscale subrouter
sed -e "s;{{TS_ROUTES}};$SERVICE_CIDR,$POD_CIDR;g" ./tests/config/tailscale_subnet_router.yaml | kubectl apply --namespace $TAILSCALE_NAMESPACE -f -
# Wait for tailscale pod to be ready
for i in 1 2 3 4 5; do
echo "waiting for the tailscale pod" && [[ $(kubectl get pods -l app=tailscale-subnet-router -n $TAILSCALE_NAMESPACE -o 'jsonpath={..status.conditions[?(@.type=="Ready")].status}') == "True" ]] && break || sleep 10
done
if [[ $(kubectl get pods -l app=tailscale-subnet-router -n $TAILSCALE_NAMESPACE -o 'jsonpath={..status.conditions[?(@.type=="Ready")].status}') != "True" ]]; then
echo "tailscale pod couldn't be ready"
exit 1
fi
echo "tailscale pod is now ready"
sleep 5
kubectl logs -l app=tailscale-subnet-router -n $TAILSCALE_NAMESPACE
|
mikeee/dapr
|
tests/setup_tailscale.sh
|
Shell
|
mit
| 1,753 |
/*
Copyright 2021 The Dapr Authors
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.
*/
@description('Name for the resources')
param name string
@description('Location of the resources')
param location string = resourceGroup().location
resource logAnalyticsWorkspace 'Microsoft.OperationalInsights/workspaces@2020-08-01' = {
name: '${name}la'
location: location
properties: {
sku: {
name: 'PerGB2018'
}
retentionInDays: 30
workspaceCapping: {
dailyQuotaGb: 7
}
}
}
resource storageAccount 'Microsoft.Storage/storageAccounts@2021-08-01' = {
name: '${name}sa'
location: location
sku: {
name: 'Standard_LRS'
}
kind: 'StorageV2'
properties: {
accessTier: 'Hot'
}
}
resource storageManagementPolicies 'Microsoft.Storage/storageAccounts/managementPolicies@2023-01-01' = {
name: 'blobPolicy'
parent: storageAccount
properties: {
policy: {
rules: [
{
enabled: true
name: 'Delete blob after 15 days'
type: 'Lifecycle'
definition: {
actions: {
baseBlob: {
delete: {
daysAfterModificationGreaterThan: 15
}
}
}
}
}
]
}
}
}
output diagLogAnalyticsWorkspaceResourceId string = logAnalyticsWorkspace.id
output diagStorageResourceId string = storageAccount.id
|
mikeee/dapr
|
tests/test-infra/azure-aks-diagnostic.bicep
|
bicep
|
mit
| 1,894 |
/*
Copyright 2021 The Dapr Authors
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.
*/
@description('Prefix for all the resources')
param namePrefix string
@description('The location of the resources')
param location string = resourceGroup().location
@description('If enabled, add a ARM64 pool')
param enableArm bool = false
@description('If enabled, add a Windows pool')
param enableWindows bool = false
@description('VM size to use for Linux nodes (agent pool)')
param linuxVMSize string = 'Standard_DS2_v2'
@description('VM size to use for Windows nodes, if enabled')
param windowsVMSize string = 'Standard_DS3_v2'
@description('VM size to use for ARM64 nodes if enabled')
param armVMSize string = 'Standard_D2ps_v5'
@description('If set, sends certain diagnostic logs to Log Analytics')
param diagLogAnalyticsWorkspaceResourceId string = ''
@description('If set, sends certain diagnostic logs to Azure Storage')
param diagStorageResourceId string = ''
// Disk size (in GB) for each of the agent pool nodes
// 0 applies the default
var osDiskSizeGB = 0
// Version of Kubernetes
var kubernetesVersion = '1.27'
resource containerRegistry 'Microsoft.ContainerRegistry/registries@2019-05-01' = {
name: '${namePrefix}acr'
location: location
sku: {
name: 'Standard'
}
properties: {
adminUserEnabled: true
}
tags: {}
}
resource roleAssignContainerRegistry 'Microsoft.Authorization/roleAssignments@2020-04-01-preview' = {
name: guid(containerRegistry.id, '${namePrefix}-aks', 'b24988ac-6180-42a0-ab88-20f7382dd24c')
properties: {
roleDefinitionId: '/subscriptions/${subscription().subscriptionId}/providers/Microsoft.Authorization/roleDefinitions/b24988ac-6180-42a0-ab88-20f7382dd24c'
principalId: reference('${namePrefix}-aks', '2021-07-01').identityProfile.kubeletidentity.objectId
}
scope: containerRegistry
dependsOn: [
aks
]
}
// Network profile when the cluster has Windows nodes
var networkProfileWindows = {
networkPlugin: 'azure'
serviceCidr: '10.0.0.0/16'
dnsServiceIP: '10.0.0.10'
dockerBridgeCidr: '172.17.0.1/16'
}
// Network profile when the cluster has only Linux nodes
var networkProfileLinux = {
networkPlugin: 'kubenet'
}
resource aks 'Microsoft.ContainerService/managedClusters@2023-05-01' = {
location: location
name: '${namePrefix}-aks'
properties: {
kubernetesVersion: kubernetesVersion
enableRBAC: true
dnsPrefix: '${namePrefix}-dns'
agentPoolProfiles: concat([
{
name: 'agentpool'
osDiskSizeGB: osDiskSizeGB
enableAutoScaling: false
count: 3
vmSize: linuxVMSize
osType: 'Linux'
type: 'VirtualMachineScaleSets'
mode: 'System'
maxPods: 110
availabilityZones: [
'1'
'2'
'3'
]
enableNodePublicIP: false
vnetSubnetID: enableWindows ? aksVNet::defaultSubnet.id : null
tags: {}
}
], enableWindows ? [
{
name: 'winpol'
osDiskSizeGB: osDiskSizeGB
osDiskType: 'Ephemeral'
enableAutoScaling: false
count: 2
vmSize: windowsVMSize
osType: 'Windows'
osSKU: 'Windows2022'
type: 'VirtualMachineScaleSets'
mode: 'User'
maxPods: 110
availabilityZones: [
'1'
'2'
'3'
]
nodeLabels: {}
nodeTaints: []
enableNodePublicIP: false
vnetSubnetID: aksVNet::defaultSubnet.id
tags: {}
}
] : [], enableArm ? [
{
name: 'armpol'
osDiskSizeGB: osDiskSizeGB
enableAutoScaling: false
count: 2
vmSize: armVMSize
osType: 'Linux'
type: 'VirtualMachineScaleSets'
mode: 'User'
maxPods: 110
availabilityZones: [
'1'
'2'
'3'
]
nodeLabels: {}
nodeTaints: []
enableNodePublicIP: false
vnetSubnetID: enableWindows ? aksVNet::defaultSubnet.id : null
tags: {}
}
] : [])
networkProfile: union({
loadBalancerSku: 'standard'
}, enableWindows ? networkProfileWindows : networkProfileLinux)
apiServerAccessProfile: {
enablePrivateCluster: false
}
addonProfiles: {
httpApplicationRouting: {
enabled: true
}
azurepolicy: {
enabled: false
}
azureKeyvaultSecretsProvider: {
enabled: false
}
omsagent: diagLogAnalyticsWorkspaceResourceId == '' ? {
enabled: false
} : {
enabled: true
config: {
logAnalyticsWorkspaceResourceID: diagLogAnalyticsWorkspaceResourceId
}
}
}
}
tags: {}
sku: {
name: 'Base'
tier: 'Standard'
}
identity: {
type: 'SystemAssigned'
}
}
resource aksVNet 'Microsoft.Network/virtualNetworks@2020-11-01' = if (enableWindows) {
location: location
name: '${namePrefix}-vnet'
properties: {
subnets: [
{
name: 'default'
properties: {
addressPrefix: '10.240.0.0/16'
}
}
]
addressSpace: {
addressPrefixes: [
'10.0.0.0/8'
]
}
}
tags: {}
resource defaultSubnet 'subnets' existing = {
name: 'default'
}
}
resource roleAssignVNet 'Microsoft.Authorization/roleAssignments@2020-04-01-preview' = if (enableWindows) {
name: guid('${aksVNet.id}/subnets/default', '${namePrefix}-vnet', 'b24988ac-6180-42a0-ab88-20f7382dd24c')
properties: {
roleDefinitionId: '/subscriptions/${subscription().subscriptionId}/providers/Microsoft.Authorization/roleDefinitions/4d97b98b-1d4f-4787-a291-c67834d212e7'
principalId: aks.identity.principalId
}
scope: aksVNet::defaultSubnet
}
resource aksDiagnosticLogAnalytics 'Microsoft.Insights/diagnosticSettings@2021-05-01-preview' = if (diagLogAnalyticsWorkspaceResourceId != '') {
name: 'loganalytics'
scope: aks
properties: {
logs: [
{
category: 'kube-apiserver'
enabled: true
}
{
category: 'kube-controller-manager'
enabled: true
}
]
workspaceId: diagLogAnalyticsWorkspaceResourceId
}
}
resource aksDiagnosticStorage 'Microsoft.Insights/diagnosticSettings@2021-05-01-preview' = if (diagStorageResourceId != '') {
name: 'storage'
scope: aks
properties: {
logs: [
{
category: 'kube-apiserver'
enabled: true
}
{
category: 'kube-audit'
enabled: true
}
]
storageAccountId: diagStorageResourceId
}
}
output controlPlaneFQDN string = aks.properties.fqdn
output aksManagedIdentityClientId string = aks.properties.identityProfile.kubeletidentity.clientId
output aksManagedIdentityPrincipalId string = aks.properties.identityProfile.kubeletidentity.objectId
|
mikeee/dapr
|
tests/test-infra/azure-aks.bicep
|
bicep
|
mit
| 7,422 |
/*
Copyright 2021 The Dapr Authors
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.
*/
// This template deploys both the Linux and Windows test clusters in Azure
// It needs to be deployed at a subscription level
targetScope = 'subscription'
@minLength(3)
@description('Prefix for all the resources')
param namePrefix string
@description('The location of the first set of resources')
param location1 string
@description('The location of the second set of resources')
param location2 string
@description('The location of the third set of resources')
param location3 string
@description('Optional value for the date tag for resource groups')
param dateTag string = ''
@description('If set, sends certain diagnostic logs to Log Analytics')
param diagLogAnalyticsWorkspaceResourceId string = ''
@description('If set, sends certain diagnostic logs to Azure Storage')
param diagStorageResourceId string = ''
@description('If set, sends certain Arm64 diagnostic logs to Log Analytics')
param armDiagLogAnalyticsWorkspaceResourceId string = ''
@description('If set, sends certain Arm64 diagnostic logs to Azure Storage')
param armDiagStorageResourceId string = ''
@description('If enabled, deploy an Arm64 cluster')
param enableArm bool = true
@description('If enabled, deploy Cosmos DB')
param enableCosmosDB bool = true
@description('If enabled, deploy Service Bus')
param enableServiceBus bool = true
// Deploy the Linux cluster in the first location
resource linuxResources 'Microsoft.Resources/resourceGroups@2020-10-01' = {
name: 'Dapr-E2E-${namePrefix}l'
location: location1
tags: dateTag != '' ? {
date: dateTag
} : {}
}
module linuxCluster 'azure.bicep' = {
name: 'linuxCluster'
scope: linuxResources
params: {
namePrefix: '${namePrefix}l'
location: location1
enableWindows: false
enableArm : false
diagLogAnalyticsWorkspaceResourceId: diagLogAnalyticsWorkspaceResourceId
diagStorageResourceId: diagStorageResourceId
enableCosmosDB: enableCosmosDB
enableServiceBus: enableServiceBus
}
}
// Deploy the Windows cluster in the second location
resource WindowsResources 'Microsoft.Resources/resourceGroups@2020-10-01' = {
name: 'Dapr-E2E-${namePrefix}w'
location: location2
tags: dateTag != '' ? {
date: dateTag
} : {}
}
module windowsCluster 'azure.bicep' = {
name: 'windowsCluster'
scope: WindowsResources
params: {
namePrefix: '${namePrefix}w'
location: location2
enableWindows: true
enableArm : false
diagLogAnalyticsWorkspaceResourceId: diagLogAnalyticsWorkspaceResourceId
diagStorageResourceId: diagStorageResourceId
enableCosmosDB: enableCosmosDB
enableServiceBus: enableServiceBus
}
}
// Deploy the Arm cluster in the third location
resource ArmResources 'Microsoft.Resources/resourceGroups@2020-10-01' = if (enableArm) {
name: 'Dapr-E2E-${namePrefix}la'
location: location3
tags: dateTag != '' ? {
date: dateTag
} : {}
}
module armCluster 'azure.bicep' = if (enableArm) {
name: 'armCluster'
scope: ArmResources
params: {
namePrefix: '${namePrefix}la'
location: location3
enableWindows: false
enableArm : true
diagLogAnalyticsWorkspaceResourceId: armDiagLogAnalyticsWorkspaceResourceId
diagStorageResourceId: armDiagStorageResourceId
enableCosmosDB: enableCosmosDB
enableServiceBus: enableServiceBus
}
}
|
mikeee/dapr
|
tests/test-infra/azure-all.bicep
|
bicep
|
mit
| 3,855 |
/*
Copyright 2021 The Dapr Authors
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.
*/
@description('Name of the Cosmos DB database account resource')
param databaseAccountName string
@description('ID of the role to assign')
param databaseRoleId string
@description('ID of the principal')
param principalId string
@description('ID of the scope (database account or database or collection)')
param scope string
resource rbacAssignment 'Microsoft.DocumentDB/databaseAccounts/sqlRoleAssignments@2021-04-01-preview' = {
name: '${databaseAccountName}/${guid(databaseAccountName, databaseRoleId, principalId)}'
properties: {
roleDefinitionId: databaseRoleId
principalId: principalId
scope: scope
}
}
|
mikeee/dapr
|
tests/test-infra/azure-cosmosdb-rbac.bicep
|
bicep
|
mit
| 1,190 |
/*
Copyright 2021 The Dapr Authors
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.
*/
@description('Prefix for all the resources')
param namePrefix string
@description('The location of the resources')
param location string = resourceGroup().location
@description('Desired throughput for Cosmos DB, in RU/s. Set to 0 to use "serverless"')
param cosmosDbThroughput int = 0
var databaseAccountName = '${namePrefix}db'
var cosmosDbServerlessCapabilities = {
name: 'EnableServerless'
}
var cosmosDbThroughputObj = {
throughput: cosmosDbThroughput
}
/* Cosmos DB Account */
resource databaseAccount 'Microsoft.DocumentDB/databaseAccounts@2021-04-15' = {
name: databaseAccountName
kind: 'GlobalDocumentDB'
location: location
properties: {
consistencyPolicy: {
defaultConsistencyLevel: 'Strong'
}
locations: [
{
locationName: location
}
]
capabilities: cosmosDbThroughput == 0 ? [
cosmosDbServerlessCapabilities
] : []
databaseAccountOfferType: 'Standard'
enableAutomaticFailover: false
enableMultipleWriteLocations: false
}
/* Database in Cosmos DB */
resource database 'sqlDatabases@2021-04-15' = {
name: 'dapre2e'
properties: {
resource: {
id: 'dapre2e'
}
options: cosmosDbThroughput > 0 ? cosmosDbThroughputObj : {}
}
/* Container "items" */
resource itemsContainer 'containers@2021-04-15' = {
name: 'items'
properties: {
resource: {
id: 'items'
partitionKey: {
paths: [
'/partitionKey'
]
kind: 'Hash'
}
defaultTtl: -1
}
options: cosmosDbThroughput > 0 ? cosmosDbThroughputObj : {}
}
}
/* Container "items-query" */
resource itemsQueryContainer 'containers@2021-04-15' = {
name: 'items-query'
properties: {
resource: {
id: 'items-query'
partitionKey: {
paths: [
'/partitionKey'
]
kind: 'Hash'
}
}
options: cosmosDbThroughput > 0 ? cosmosDbThroughputObj : {}
}
}
}
/* RBAC role: Data Reader */
resource dataReaderRole 'sqlRoleDefinitions@2021-10-15' = {
name: '00000000-0000-0000-0000-000000000001'
properties: {
roleName: 'Cosmos DB Built-in Data Reader'
type: 'BuiltInRole'
assignableScopes: [
databaseAccount.id
]
permissions: [
{
dataActions: [
'Microsoft.DocumentDB/databaseAccounts/readMetadata'
'Microsoft.DocumentDB/databaseAccounts/sqlDatabases/containers/executeQuery'
'Microsoft.DocumentDB/databaseAccounts/sqlDatabases/containers/readChangeFeed'
'Microsoft.DocumentDB/databaseAccounts/sqlDatabases/containers/items/read'
]
}
]
}
}
/* RBAC role: Data Contributor */
resource dataContributorRole 'sqlRoleDefinitions@2021-10-15' = {
name: '00000000-0000-0000-0000-000000000002'
properties: {
roleName: 'Cosmos DB Built-in Data Contributor'
type: 'BuiltInRole'
assignableScopes: [
databaseAccount.id
]
permissions: [
{
dataActions: [
'Microsoft.DocumentDB/databaseAccounts/readMetadata'
'Microsoft.DocumentDB/databaseAccounts/sqlDatabases/containers/*'
'Microsoft.DocumentDB/databaseAccounts/sqlDatabases/containers/items/*'
]
}
]
}
}
}
output accountId string = databaseAccount.id
output accountName string = databaseAccount.name
output dataReaderRoleId string = databaseAccount::dataReaderRole.id
output dataContributorRoleId string = databaseAccount::dataContributorRole.id
|
mikeee/dapr
|
tests/test-infra/azure-cosmosdb.bicep
|
bicep
|
mit
| 4,252 |
/*
Copyright 2021 The Dapr Authors
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.
*/
@description('The name of the Service Bus namespace')
param namespace string
@description('Name of the topic to create')
param topicName string
@description('Array with the name of the subscriptions to create')
param topicSubscriptions array
resource topic 'Microsoft.ServiceBus/namespaces/topics@2021-11-01' = {
name: '${namespace}/${topicName}'
properties: {
maxMessageSizeInKilobytes: 1024
maxSizeInMegabytes: 1024
}
resource subscription 'subscriptions@2021-11-01' = [for sub in topicSubscriptions: {
name: sub
properties: {
lockDuration: 'PT5S'
maxDeliveryCount: 999
enableBatchedOperations: false
}
}]
}
|
mikeee/dapr
|
tests/test-infra/azure-servicebus-topic.bicep
|
bicep
|
mit
| 1,223 |
/*
Copyright 2021 The Dapr Authors
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.
*/
@description('Prefix for all the resources')
param namePrefix string
@description('The location of the resources')
param location string = resourceGroup().location
var topicsAndSubscriptions = [
{
name: 'pubsub-a-topic-http'
subscriptions: [
'pubsub-publisher'
'pubsub-subscriber'
'pubsub-publisher-grpc'
'pubsub-subscriber-grpc'
]
}
{
name: 'pubsub-b-topic-http'
subscriptions: [
'pubsub-publisher'
'pubsub-subscriber'
'pubsub-publisher-grpc'
'pubsub-subscriber-grpc'
]
}
{
name: 'pubsub-c-topic-http'
subscriptions: [
'pubsub-publisher'
'pubsub-subscriber'
'pubsub-publisher-grpc'
'pubsub-subscriber-grpc'
]
}
{
name: 'pubsub-raw-topic-http'
subscriptions: [
'pubsub-publisher'
'pubsub-subscriber'
'pubsub-publisher-grpc'
'pubsub-subscriber-grpc'
]
}
{
name: 'pubsub-a-topic-grpc'
subscriptions: [
'pubsub-publisher'
'pubsub-subscriber'
'pubsub-publisher-grpc'
'pubsub-subscriber-grpc'
]
}
{
name: 'pubsub-b-topic-grpc'
subscriptions: [
'pubsub-publisher'
'pubsub-subscriber'
'pubsub-publisher-grpc'
'pubsub-subscriber-grpc'
]
}
{
name: 'pubsub-c-topic-grpc'
subscriptions: [
'pubsub-publisher'
'pubsub-subscriber'
'pubsub-publisher-grpc'
'pubsub-subscriber-grpc'
]
}
{
name: 'pubsub-raw-topic-grpc'
subscriptions: [
'pubsub-publisher'
'pubsub-subscriber'
'pubsub-publisher-grpc'
'pubsub-subscriber-grpc'
]
}
{
name: 'pubsub-routing-http'
subscriptions: [
'pubsub-publisher-routing'
'pubsub-subscriber-routing'
]
}
{
name: 'pubsub-routing-crd-http'
subscriptions: [
'pubsub-publisher-routing'
'pubsub-subscriber-routing'
]
}
{
name: 'pubsub-routing-grpc'
subscriptions: [
'pubsub-publisher-routing-grpc'
'pubsub-subscriber-routing-grpc'
]
}
{
name: 'pubsub-routing-crd-grpc'
subscriptions: [
'pubsub-publisher-routing-grpc'
'pubsub-subscriber-routing-grpc'
]
}
{
name: 'pubsub-job-topic-http'
subscriptions: [
'pubsub-publisher'
'pubsub-subscriber'
'job-subscriber'
'pubsub-publisher-grpc'
'pubsub-subscriber-grpc'
]
}
{
name: 'pubsub-healthcheck-topic-http'
subscriptions: [
'pubsub-publisher'
'pubsub-subscriber'
'pubsub-publisher-grpc'
'pubsub-subscriber-grpc'
]
}
{
name: 'pubsub-healthcheck-topic-grpc'
subscriptions: [
'pubsub-publisher'
'pubsub-subscriber'
'pubsub-publisher-grpc'
'pubsub-subscriber-grpc'
]
}
]
resource serviceBusNamespace 'Microsoft.ServiceBus/namespaces@2021-11-01' = {
name: '${namePrefix}sb'
location: location
sku: {
name: 'Premium'
tier: 'Premium'
capacity: 1
}
properties: {
disableLocalAuth: false
zoneRedundant: false
}
}
module topicSubscriptions './azure-servicebus-topic.bicep' = [for topicSub in topicsAndSubscriptions: {
name: '${topicSub.name}'
params: {
namespace: serviceBusNamespace.name
topicName: topicSub.name
topicSubscriptions: topicSub.subscriptions
}
dependsOn: [
//serviceBusNamespace
]
}]
|
mikeee/dapr
|
tests/test-infra/azure-servicebus.bicep
|
bicep
|
mit
| 3,924 |
/*
Copyright 2021 The Dapr Authors
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.
*/
// This template deploys a test cluster (Linux or Windows) on Azure, and all associated resources
@minLength(3)
@description('Prefix for all the resources')
param namePrefix string
@description('The location of the resources')
param location string = resourceGroup().location
@description('If enabled, add a Windows pool')
param enableWindows bool = false
@description('If enabled, add a ARM64 pool')
param enableArm bool = false
@description('If set, sends certain diagnostic logs to Log Analytics')
param diagLogAnalyticsWorkspaceResourceId string = ''
@description('If set, sends certain diagnostic logs to Azure Storage')
param diagStorageResourceId string = ''
@description('If enabled, deploy Cosmos DB')
param enableCosmosDB bool = true
@description('If enabled, deploy Service Bus')
param enableServiceBus bool = true
// Deploy an AKS cluster
module aksModule './azure-aks.bicep' = {
name: 'azure-aks'
params: {
namePrefix: namePrefix
location: location
enableWindows: enableWindows
enableArm: enableArm
diagLogAnalyticsWorkspaceResourceId: diagLogAnalyticsWorkspaceResourceId
diagStorageResourceId: diagStorageResourceId
}
}
// Deploy a Cosmos DB account
module cosmosdbModule './azure-cosmosdb.bicep' = if (enableCosmosDB) {
name: 'azure-cosmosdb'
params: {
namePrefix: namePrefix
location: location
}
}
// Deploy a Service Bus namespace and all the topics/subscriptions
module serviceBusModule './azure-servicebus.bicep' = if (enableServiceBus) {
name: 'azure-servicebus'
params: {
namePrefix: namePrefix
location: location
}
}
// This is temporarily turned off while we fix issues with Cosmos DB and RBAC
// See: https://github.com/dapr/components-contrib/issues/1603
/*
// Deploy RBAC roles to allow the AKS cluster to access resources in the Cosmos DB account
module cosmosdbRbacModule './azure-cosmosdb-rbac.bicep' = {
name: 'azure-cosmosdb-rbac'
params: {
databaseAccountName: cosmosdbModule.outputs.accountName
databaseRoleId: cosmosdbModule.outputs.dataContributorRoleId
principalId: aksModule.outputs.aksManagedIdentityPrincipalId
scope: cosmosdbModule.outputs.accountId
}
}
// Outputs
output aksIdentityClientId string = aksModule.outputs.aksManagedIdentityClientId
output aksIdentityPrincipalId string = aksModule.outputs.aksManagedIdentityPrincipalId
*/
|
mikeee/dapr
|
tests/test-infra/azure.bicep
|
bicep
|
mit
| 2,930 |
#!/usr/bin/env bash
#
# Copyright 2021 The Dapr Authors
# 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.
#
if [[ -z "$TEST_PREFIX" ]]; then
echo "Environmental variable TEST_PREFIX must be set" 1>&2
exit 1
fi
if [[ -z "$TEST_RESOURCE_GROUP" ]]; then
echo "Environmental variable TEST_RESOURCE_GROUP must be set" 1>&2
exit 1
fi
# Control if we're using Cosmos DB, Service Bus, and Azure Key Vault
USE_COSMOSDB=${1:-true}
USE_SERVICEBUS=${2:-true}
USE_KEYVAULT=${3:-true}
if $USE_COSMOSDB ; then
echo "Configuring Cosmos DB as state store"
# Set environmental variables to use Cosmos DB as state store
export DAPR_TEST_STATE_STORE=cosmosdb
export DAPR_TEST_QUERY_STATE_STORE=cosmosdb
# Write into the GitHub Actions environment
if [ -n "$GITHUB_ENV" ]; then
echo "DAPR_TEST_STATE_STORE=${DAPR_TEST_STATE_STORE}" >> $GITHUB_ENV
echo "DAPR_TEST_QUERY_STATE_STORE=${DAPR_TEST_QUERY_STATE_STORE}" >> $GITHUB_ENV
fi
# Get the credentials for Cosmos DB
COSMOSDB_MASTER_KEY=$(
az cosmosdb keys list \
--name "${TEST_PREFIX}db" \
--resource-group "$TEST_RESOURCE_GROUP" \
--query "primaryMasterKey" \
-o tsv
)
kubectl create secret generic cosmosdb-secret \
--namespace=$DAPR_NAMESPACE \
--from-literal=url=https://${TEST_PREFIX}db.documents.azure.com:443/ \
--from-literal=primaryMasterKey=${COSMOSDB_MASTER_KEY}
else
echo "NOT configuring Cosmos DB as state store"
fi
if $USE_SERVICEBUS ; then
echo "Configuring Service Bus as pubsub broker"
# Set environmental variables to Service Bus pubsub
export DAPR_TEST_PUBSUB=servicebus
if [ -n "$GITHUB_ENV" ]; then
echo "DAPR_TEST_PUBSUB=${DAPR_TEST_PUBSUB}" >> $GITHUB_ENV
fi
# Get the credentials for Service Bus
SERVICEBUS_CONNSTRING=$(
az servicebus namespace authorization-rule keys list \
--resource-group "$TEST_RESOURCE_GROUP" \
--namespace-name "${TEST_PREFIX}sb" \
--name RootManageSharedAccessKey \
--query primaryConnectionString \
-o tsv
)
kubectl create secret generic servicebus-secret \
--namespace=$DAPR_NAMESPACE \
--from-literal=connectionString=${SERVICEBUS_CONNSTRING}
else
echo "NOT configuring Service Bus as pubsub broker"
fi
if $USE_KEYVAULT ; then
echo "Configuring Azure Key Vault as crypto provider"
# Set environmental variables to Azure Key Vault crypto provider
export DAPR_TEST_CRYPTO=azurekeyvault
if [ -n "$GITHUB_ENV" ]; then
echo "DAPR_TEST_CRYPTO=${DAPR_TEST_CRYPTO}" >> $GITHUB_ENV
fi
AzureKeyVaultTenantId=$(echo $AZURE_CREDENTIALS | jq -r '.tenantId')
AzureKeyVaultClientId=$(echo $AZURE_CREDENTIALS | jq -r '.clientId')
AzureKeyVaultClientSecret=$(echo $AZURE_CREDENTIALS | jq -r '.clientSecret')
kubectl create secret generic azurekeyvault-secret \
--namespace=$DAPR_NAMESPACE \
--from-literal="tenant-id=${AzureKeyVaultTenantId}" \
--from-literal="client-id=${AzureKeyVaultClientId}" \
--from-literal="client-secret=${AzureKeyVaultClientSecret}"
else
echo "NOT configuring Azure Key Vault as crypto provider"
fi
|
mikeee/dapr
|
tests/test-infra/setup_azure.sh
|
Shell
|
mit
| 3,590 |
#!/usr/bin/env bash
#
# Copyright 2022 The Dapr Authors
# 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.
#
# Allows skipping some E2E test runs on Azure based on OS and arch.
# This is useful when we are still working to stabilize some targets.
# This script allows the stabilization to take place prior to merging into master.
if [ -n "$GITHUB_ENV" ] && [ "$TARGET_OS" = "linux" ] && [ "$TARGET_ARCH" = "arm64" ]; then
echo "SKIP_E2E=true" >> $GITHUB_ENV
fi
|
mikeee/dapr
|
tests/test-infra/skip_azure.sh
|
Shell
|
mit
| 953 |
#!/usr/bin/env bash
#
# Copyright 2022 The Dapr Authors
# 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.
#
# Allows custom logic to validate registry readiness.
# This is useful when we are still working to stabilize some targets.
# This script allows the stabilization to take place prior to merging into master.
registry_name=$1
elapsed=0
timeout=300
until [ $elapsed -ge $timeout ] || az acr show --name $registry_name --query "id"
do
echo "Azure Container Registry not ready yet: sleeping for 20 seconds"
sleep 20
elapsed=$(expr $elapsed + 20)
done
if [ $elapsed -ge $timeout ]; then
echo "Azure Container Registry not ready on time, pushing images might fail in next steps."
fi
|
mikeee/dapr
|
tests/test-infra/wait_azure_registry.sh
|
Shell
|
mit
| 1,184 |
#!/bin/bash
[ -z "$1" ] && echo "Usage: $0 [LAST_DAPR_COMMIT]" && exit 1
DAPR_CORE_COMMIT=$1
# Update dapr dependencies for all e2e test apps
cd ./apps
appsroot=`pwd`
appsdirName='apps'
for appdir in * ; do
if test -f "$appsroot/$appdir/go.mod"; then
cd $appsroot/$appdir > /dev/null
go get -u github.com/dapr/dapr@$DAPR_CORE_COMMIT
go mod tidy
echo "successfully updated dapr dependency for $appdir"
fi
done
|
mikeee/dapr
|
tests/update_testapps_dependencies.sh
|
Shell
|
mit
| 442 |
/*
Copyright The Dapr Authors.
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.
*/
|
mikeee/dapr
|
tools/boilerplate.go.txt
|
Text
|
mit
| 559 |
PROTOS = operator placement sentry common runtime internals components
ifeq (,$(shell go env GOBIN))
GOBIN=$(shell go env GOPATH)/bin
else
GOBIN=$(shell go env GOBIN)
endif
# Generate code
code-generate: controller-gen
$(CONTROLLER_GEN) object:headerFile="./tools/boilerplate.go.txt" \
crd:crdVersions=v1 paths="./pkg/apis/..." output:crd:artifacts:config=config/crd/bases
$(CONTROLLER_GEN) object:headerFile="./tools/boilerplate.go.txt" \
paths="./pkg/apis/..."
# find or download controller-gen
# download controller-gen if necessary
controller-gen:
ifeq (, $(shell which controller-gen))
@{ \
set -e ;\
CONTROLLER_GEN_TMP_DIR="$$(mktemp -d)" ;\
cd "$$CONTROLLER_GEN_TMP_DIR" ;\
go install sigs.k8s.io/controller-tools/cmd/controller-gen@v0.15.0 ; \
rm -rf "$$CONTROLLER_GEN_TMP_DIR" ;\
}
CONTROLLER_GEN=$(GOBIN)/controller-gen
else
CONTROLLER_GEN=$(shell which controller-gen)
endif
define genProtoForTarget
.PHONY: $(1)
protoc-gen-$(1)-v1:
protoc -I . ./dapr/proto/$(1)/v1/*.proto --go_out=plugins=grpc:.
cp -R ./github.com/dapr/dapr/pkg/proto/$(1)/v1/*.go ./pkg/proto/$(1)/v1
rm -rf ./github.com
endef
# Generate proto gen targets
$(foreach ITEM,$(PROTOS),$(eval $(call genProtoForTarget,$(ITEM))))
PROTOC_ALL_TARGETS:=$(foreach ITEM,$(PROTOS),protoc-gen-$(ITEM)-v1)
protoc-gen: $(PROTOC_ALL_TARGETS)
|
mikeee/dapr
|
tools/codegen.mk
|
mk
|
mit
| 1,336 |
#
# Copyright 2021 The Dapr Authors
# 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.
#
#!/bin/bash
set +x
VERSION=3.10.0
# TODO: Consider using a Docker image for this?
# Generate proto buffers
# First arg is name of language (e.g. 'javascript')
# Second arg is name of tool (e.g. 'js')
# Third arg is path within the language directory to write to
# Fourth arg is args for the generator
# Remaining args are appended to the command.
generate() {
language=${1}
tool=${2}
path=${3}
args=${4}
mkdir -p ${top_root}/../${language}-sdk/${path}
for proto_file in "daprclient/daprclient.proto" "dapr/dapr.proto"; do
echo "Generating ${language} for ${proto_file}"
${root}/bin/protoc --proto_path ${top_root}/pkg/proto/ \
--${tool}_out=${args}:${top_root}/../${language}-sdk/${path} \
${top_root}/pkg/proto/${proto_file} ${@:5}
done
}
# Setup the directories
root=$(dirname "${BASH_SOURCE[0]}")
top_root=${root}/../..
# Detect OS
OS=""
full_os=""
if [[ "$OSTYPE" == "linux-gnu" ]]; then
OS="linux"
full_os="linux"
elif [[ "$OSTYPE" == "darwin"* ]]; then
OS="osx"
full_os="macosx"
fi
file="protoc-${VERSION}-${OS}-x86_64.zip"
# Download and install tools.
wget "https://github.com/protocolbuffers/protobuf/releases/download/v${VERSION}/${file}" \
-O ${root}/${file}
# Download Java gRPC plugin
java_grpc_plugin_file="protoc-gen-grpc-java-1.24.0-${OS}-x86_64.exe"
java_grpc_plugin_path=${root}/${java_grpc_plugin_file}
wget "https://repo1.maven.org/maven2/io/grpc/protoc-gen-grpc-java/1.24.0/${java_grpc_plugin_file}" \
-O ${java_grpc_plugin_path}
chmod +x ${java_grpc_plugin_path}
unzip ${root}/${file} -d ${root}
# find grpc_tools_node_protoc_plugin location
PROTOC_PLUGIN=$(which grpc_tools_node_protoc_plugin)
ts_grpc_plugin_file=$(which protoc-gen-ts)
dotnet_grpc_plugin_file="${HOME}/.nuget/packages/grpc.tools/2.24.0/tools/${full_os}_x64/grpc_csharp_plugin"
language=${1:-"all"}
if [[ "${language}" = "all" ]] || [[ "${language}" = "js" ]]; then
# generate javascript
generate js js src 'import_style=commonjs' \
--plugin=protoc-gen-grpc=${PROTOC_PLUGIN} \
--plugin=protoc-gen-ts=${ts_grpc_plugin_file} \
--ts_out="service=grpc-node:${top_root}/../js-sdk/src" \
--grpc_out=${top_root}/../js-sdk/src
fi
if [[ "$language" = "all" ]] || [[ "$language" = "java" ]]; then
# generate java
generate java java src/main/java '' \
--plugin=protoc-gen-grpc-java=${java_grpc_plugin_path} \
--grpc-java_out=${top_root}/../java-sdk/src/main/java
fi
if [[ "$language" = "all" ]] || [[ "$language" = "python" ]]; then
# generate python
mkdir -p ${top_root}/../python-sdk
python3 -m grpc.tools.protoc -I${top_root}/pkg/proto \
--python_out=${top_root}/../python-sdk \
--grpc_python_out=${top_root}/../python-sdk \
dapr/dapr.proto \
daprclient/daprclient.proto
fi
if [[ "$language" = "all" ]] || [[ "$language" = "go" ]]; then
# generate golang
generate go go . `` --plugin=grpc
fi
if [[ "$language" = "all" ]] || [[ "$language" = "dotnet" ]]; then
# generate dotnet
# dotnet generates their own via dotnet build...
generate dotnet csharp src/Dapr.Client.Grpc '' \
--plugin=protoc-gen-grpc=${dotnet_grpc_plugin_file} \
--grpc_out=${top_root}/../dotnet-sdk/src/Dapr.Client.Grpc
fi
# cleanup
rm -r ${root}/include ${root}/bin ${root}/${file} ${root}/readme.txt ${java_grpc_plugin_path}
|
mikeee/dapr
|
tools/proto/generate.sh
|
Shell
|
mit
| 3,952 |
//go:build tools
// +build tools
/*
Copyright 2019 The Kubernetes Authors.
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.
*/
// This package imports things required by build scripts, to force `go mod` to see them as dependencies
package tools
import _ "k8s.io/code-generator"
|
mikeee/dapr
|
tools/tools.go
|
GO
|
mit
| 757 |
/*
Copyright 2022 The Dapr Authors
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.
*/
package utils
import (
"errors"
"fmt"
"net"
"os"
)
const (
// HostIPEnvVar is the environment variable to override host's chosen IP address.
HostIPEnvVar = "DAPR_HOST_IP"
)
// GetHostAddress selects a valid outbound IP address for the host.
func GetHostAddress() (string, error) {
if val, ok := os.LookupEnv(HostIPEnvVar); ok && val != "" {
return val, nil
}
// Use udp so no handshake is made.
// Any IP can be used, since connection is not established, but we used a known DNS IP.
conn, err := net.Dial("udp", "8.8.8.8:80")
if err != nil {
// Could not find one via a UDP connection, so we fallback to the "old" way: try first non-loopback IPv4:
addrs, err := net.InterfaceAddrs()
if err != nil {
return "", fmt.Errorf("error getting interface IP addresses: %w", err)
}
for _, addr := range addrs {
if ipnet, ok := addr.(*net.IPNet); ok && !ipnet.IP.IsLoopback() {
if ipnet.IP.To4() != nil {
return ipnet.IP.String(), nil
}
}
}
return "", errors.New("could not determine host IP address")
}
defer conn.Close()
return conn.LocalAddr().(*net.UDPAddr).IP.String(), nil
}
|
mikeee/dapr
|
utils/host.go
|
GO
|
mit
| 1,692 |
/*
Copyright 2022 The Dapr Authors
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.
*/
package utils
import (
"testing"
"github.com/stretchr/testify/assert"
"github.com/stretchr/testify/require"
)
func TestGetHostAdress(t *testing.T) {
t.Run("DAPR_HOST_IP present", func(t *testing.T) {
hostIP := "test.local"
t.Setenv(HostIPEnvVar, hostIP)
address, err := GetHostAddress()
require.NoError(t, err)
assert.Equal(t, hostIP, address)
})
t.Run("DAPR_HOST_IP not present, non-empty response", func(t *testing.T) {
address, err := GetHostAddress()
require.NoError(t, err)
assert.NotEmpty(t, address)
})
}
|
mikeee/dapr
|
utils/host_test.go
|
GO
|
mit
| 1,101 |
/*
Copyright 2022 The Dapr Authors
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.
*/
package utils
import (
"io"
"net/http"
"github.com/dapr/kit/streams"
)
// UppercaseRequestMiddleware is a HTTP middleware that transforms the request body to uppercase
func UppercaseRequestMiddleware(next http.Handler) http.Handler {
return http.HandlerFunc(func(w http.ResponseWriter, r *http.Request) {
r.Body = io.NopCloser(streams.UppercaseTransformer(r.Body))
next.ServeHTTP(w, r)
})
}
// UppercaseResponseMiddleware is a HTTP middleware that transforms the response body to uppercase
func UppercaseResponseMiddleware(next http.Handler) http.Handler {
return http.HandlerFunc(func(w http.ResponseWriter, r *http.Request) {
urw := &uppercaseResponseWriter{w}
next.ServeHTTP(urw, r)
})
}
type uppercaseResponseWriter struct {
http.ResponseWriter
}
func (urw *uppercaseResponseWriter) Write(p []byte) (n int, err error) {
var written int
for _, c := range string(p) {
written, err = urw.ResponseWriter.Write(
streams.RuneToUppercase(c),
)
n += written
if err != nil {
return n, err
}
}
return n, nil
}
|
mikeee/dapr
|
utils/http-middlewares.go
|
GO
|
mit
| 1,607 |
/*
Copyright 2023 The Dapr Authors
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.
*/
package utils
import (
"io"
"net/http"
"net/http/httptest"
"strings"
"testing"
"github.com/stretchr/testify/assert"
)
func TestUppercaseRequestMiddleware(t *testing.T) {
requestBody := "fake_body"
testRequest := httptest.NewRequest(http.MethodPost, "/test", strings.NewReader(requestBody))
echoHandler := http.HandlerFunc(func(w http.ResponseWriter, r *http.Request) {
io.Copy(w, r.Body)
})
handler := UppercaseRequestMiddleware(echoHandler)
rr := httptest.NewRecorder()
handler.ServeHTTP(rr, testRequest)
expected := strings.ToUpper(requestBody)
assert.Equal(t, expected, rr.Body.String())
}
func TestResponseMiddleware(t *testing.T) {
testRequest := httptest.NewRequest(http.MethodGet, "/test", nil)
responseBody := "fake_body"
responseHandler := http.HandlerFunc(func(w http.ResponseWriter, r *http.Request) {
w.Write([]byte(responseBody))
})
handler := UppercaseResponseMiddleware(responseHandler)
rr := httptest.NewRecorder()
handler.ServeHTTP(rr, testRequest)
expected := strings.ToUpper(responseBody)
assert.Equal(t, expected, rr.Body.String())
}
|
mikeee/dapr
|
utils/http-middlewares_test.go
|
GO
|
mit
| 1,653 |
/*
Copyright 2023 The Dapr Authors
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.
*/
package utils
import (
"os"
"k8s.io/client-go/kubernetes"
"k8s.io/client-go/rest"
"k8s.io/client-go/tools/clientcmd"
)
var (
clientSet *kubernetes.Clientset
kubeConfig *rest.Config
KubeConfigVar = "KUBE_CONFIG"
)
func initKubeConfig() {
kubeConfig = GetConfig()
clientset, err := kubernetes.NewForConfig(kubeConfig)
if err != nil {
panic(err)
}
clientSet = clientset
}
// GetConfig gets a kubernetes rest config.
func GetConfig() *rest.Config {
if kubeConfig != nil {
return kubeConfig
}
conf, err := rest.InClusterConfig()
if err != nil {
conf, err = clientcmd.BuildConfigFromFlags("", os.Getenv(KubeConfigVar))
if err != nil {
panic(err)
}
}
return conf
}
// GetKubeClient gets a kubernetes client.
func GetKubeClient() *kubernetes.Clientset {
if clientSet == nil {
initKubeConfig()
}
return clientSet
}
|
mikeee/dapr
|
utils/kubernetes.go
|
GO
|
mit
| 1,419 |
/*
Copyright 2022 The Dapr Authors
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.
*/
package utils
import (
"bufio"
"bytes"
"os"
"regexp"
"sort"
"strings"
)
const (
// DefaultKubeClusterDomain is the default value of KubeClusterDomain.
DefaultKubeClusterDomain = "cluster.local"
defaultResolvPath = "/etc/resolv.conf"
commentMarker = "#"
)
var searchRegexp = regexp.MustCompile(`^\s*search\s*(([^\s]+\s*)*)$`)
// GetKubeClusterDomain search KubeClusterDomain value from /etc/resolv.conf file.
func GetKubeClusterDomain() (string, error) {
resolvContent, err := getResolvContent(defaultResolvPath)
if err != nil {
return "", err
}
return getClusterDomain(resolvContent)
}
func getClusterDomain(resolvConf []byte) (string, error) {
var kubeClusterDomain string
searchDomains := getResolvSearchDomains(resolvConf)
sort.Strings(searchDomains)
if len(searchDomains) == 0 || searchDomains[0] == "" {
kubeClusterDomain = DefaultKubeClusterDomain
} else {
kubeClusterDomain = searchDomains[0]
}
return kubeClusterDomain, nil
}
func getResolvContent(resolvPath string) ([]byte, error) {
return os.ReadFile(resolvPath)
}
func getResolvSearchDomains(resolvConf []byte) []string {
var (
domains []string
lines [][]byte
)
scanner := bufio.NewScanner(bytes.NewReader(resolvConf))
for scanner.Scan() {
line := scanner.Bytes()
commentIndex := bytes.Index(line, []byte(commentMarker))
if commentIndex == -1 {
lines = append(lines, line)
} else {
lines = append(lines, line[:commentIndex])
}
}
for _, line := range lines {
match := searchRegexp.FindSubmatch(line)
if match == nil {
continue
}
domains = strings.Fields(string(match[1]))
}
return domains
}
|
mikeee/dapr
|
utils/resolvconf.go
|
GO
|
mit
| 2,210 |
/*
Copyright 2022 The Dapr Authors
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.
*/
package utils
import (
"testing"
"github.com/stretchr/testify/assert"
)
func TestGetClusterDomain(t *testing.T) {
testCases := []struct {
content string
expected string
}{
{
content: "search svc.cluster.local #test comment",
expected: "svc.cluster.local",
},
{
content: "search default.svc.cluster.local svc.cluster.local cluster.local",
expected: "cluster.local",
},
{
content: "",
expected: "cluster.local",
},
}
for _, tc := range testCases {
domain, err := getClusterDomain([]byte(tc.content))
if err != nil {
t.Fatalf("get kube cluster domain error:%s", err)
}
assert.Equal(t, tc.expected, domain)
}
}
func TestGetSearchDomains(t *testing.T) {
testCases := []struct {
content string
expected []string
}{
{
content: "search svc.cluster.local #test comment",
expected: []string{"svc.cluster.local"},
},
{
content: "search default.svc.cluster.local svc.cluster.local cluster.local",
expected: []string{"default.svc.cluster.local", "svc.cluster.local", "cluster.local"},
},
{
content: "",
expected: []string{},
},
}
for _, tc := range testCases {
domains := getResolvSearchDomains([]byte(tc.content))
assert.ElementsMatch(t, domains, tc.expected)
}
}
|
mikeee/dapr
|
utils/resolvconf_test.go
|
GO
|
mit
| 1,820 |
/*
Copyright 2021 The Dapr Authors
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.
*/
package utils
import (
"fmt"
"io/fs"
"os"
"strings"
)
const (
DotDelimiter = "."
)
// Contains reports whether v is present in s.
// Similar to https://pkg.go.dev/golang.org/x/exp/slices#Contains.
func Contains[T comparable](s []T, v T) bool {
for _, e := range s {
if e == v {
return true
}
}
return false
}
// ContainsPrefixed reports whether v is prefixed by any of the strings in s.
func ContainsPrefixed(prefixes []string, v string) bool {
for _, e := range prefixes {
if strings.HasPrefix(v, e) {
return true
}
}
return false
}
// SetEnvVariables set variables to environment.
func SetEnvVariables(variables map[string]string) error {
for key, value := range variables {
err := os.Setenv(key, value)
if err != nil {
return err
}
}
return nil
}
// GetEnvOrElse get the value from the OS environment or use the else value if variable is not present.
func GetEnvOrElse(name, orElse string) string {
if value, ok := os.LookupEnv(name); ok {
return value
}
return orElse
}
// GetIntValOrDefault returns an int value if greater than 0 OR default value.
func GetIntValOrDefault(val int, defaultValue int) int {
if val > 0 {
return val
}
return defaultValue
}
// IsSocket returns if the given file is a unix socket.
func IsSocket(f fs.FileInfo) bool {
return f.Mode()&fs.ModeSocket != 0
}
// SocketExists returns true if the file in that path is an unix socket.
func SocketExists(socketPath string) bool {
if s, err := os.Stat(socketPath); err == nil {
return IsSocket(s)
}
return false
}
func PopulateMetadataForBulkPublishEntry(reqMeta, entryMeta map[string]string) map[string]string {
resMeta := map[string]string{}
for k, v := range entryMeta {
resMeta[k] = v
}
for k, v := range reqMeta {
if _, ok := resMeta[k]; !ok {
// Populate only metadata key that is already not present in the entry level metadata map
resMeta[k] = v
}
}
return resMeta
}
// Filter returns a new slice containing all items in the given slice that satisfy the given test.
func Filter[T any](items []T, test func(item T) bool) []T {
filteredItems := make([]T, len(items))
n := 0
for i := 0; i < len(items); i++ {
if test(items[i]) {
filteredItems[n] = items[i]
n++
}
}
return filteredItems[:n]
}
// MapToSlice is the inversion of SliceToMap. Order is not guaranteed as map retrieval order is not.
func MapToSlice[T comparable, V any](m map[T]V) []T {
l := make([]T, len(m))
var i int
for uid := range m {
l[i] = uid
i++
}
return l
}
const (
logNameFmt = "%s (%s)"
logNameVersionFmt = "%s (%s/%s)"
)
// ComponentLogName returns the name of a component that can be used in logging.
func ComponentLogName(name, typ, version string) string {
if version == "" {
return fmt.Sprintf(logNameFmt, name, typ)
}
return fmt.Sprintf(logNameVersionFmt, name, typ, version)
}
// GetNamespaceOrDefault returns the namespace for Dapr, or the default namespace if it is not set.
func GetNamespaceOrDefault(defaultNamespace string) string {
namespace := os.Getenv("NAMESPACE")
if namespace == "" {
namespace = defaultNamespace
}
return namespace
}
func ParseServiceAddr(val string) []string {
p := strings.Split(val, ",")
for i, v := range p {
p[i] = strings.TrimSpace(v)
}
return p
}
|
mikeee/dapr
|
utils/utils.go
|
GO
|
mit
| 3,840 |
/*
Copyright 2021 The Dapr Authors
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.
*/
package utils
import (
"net"
"os"
"runtime"
"testing"
"github.com/stretchr/testify/assert"
"github.com/stretchr/testify/require"
)
func TestContains(t *testing.T) {
type customType struct {
v1 string
v2 int
}
t.Run("find a item", func(t *testing.T) {
assert.True(t, Contains([]string{"item-1", "item"}, "item"))
assert.True(t, Contains([]int{1, 2, 3}, 1))
assert.True(t, Contains([]customType{{v1: "first", v2: 1}, {v1: "second", v2: 2}}, customType{v1: "second", v2: 2}))
})
t.Run("didn't find a item", func(t *testing.T) {
assert.False(t, Contains([]string{"item-1", "item"}, "not-in-item"))
assert.False(t, Contains([]string{}, "not-in-item"))
assert.False(t, Contains(nil, "not-in-item"))
assert.False(t, Contains([]int{1, 2, 3}, 100))
assert.False(t, Contains([]int{}, 100))
assert.False(t, Contains(nil, 100))
assert.False(t, Contains([]customType{{v1: "first", v2: 1}, {v1: "second", v2: 2}}, customType{v1: "foo", v2: 100}))
assert.False(t, Contains([]customType{}, customType{v1: "foo", v2: 100}))
assert.False(t, Contains(nil, customType{v1: "foo", v2: 100}))
})
}
func TestSetEnvVariables(t *testing.T) {
t.Run("set environment variables success", func(t *testing.T) {
err := SetEnvVariables(map[string]string{
"testKey": "testValue",
})
require.NoError(t, err)
assert.Equal(t, "testValue", os.Getenv("testKey"))
})
t.Run("set environment variables failed", func(t *testing.T) {
err := SetEnvVariables(map[string]string{
"": "testValue",
})
require.Error(t, err)
assert.NotEqual(t, "testValue", os.Getenv(""))
})
}
func TestGetIntValFromStringVal(t *testing.T) {
tcs := []struct {
name string
val int
def int
expected int
}{
{
name: "value is not provided by user, default value is used",
val: 0,
def: 5,
expected: 5,
},
{
name: "val is provided by user",
val: 91,
def: 5,
expected: 91,
},
}
for _, tc := range tcs {
t.Run(tc.name, func(t *testing.T) {
actual := GetIntValOrDefault(tc.val, tc.def)
if actual != tc.expected {
t.Errorf("expected %d, actual %d", tc.expected, actual)
}
})
}
}
func TestEnvOrElse(t *testing.T) {
t.Run("envOrElse should return else value when env var is not present", func(t *testing.T) {
const elseValue, fakeEnVar = "fakeValue", "envVarThatDoesntExists"
require.NoError(t, os.Unsetenv(fakeEnVar))
assert.Equal(t, elseValue, GetEnvOrElse(fakeEnVar, elseValue))
})
t.Run("envOrElse should return env var value when env var is present", func(t *testing.T) {
const elseValue, fakeEnVar, fakeEnvVarValue = "fakeValue", "envVarThatExists", "envVarValue"
defer os.Unsetenv(fakeEnVar)
require.NoError(t, os.Setenv(fakeEnVar, fakeEnvVarValue))
assert.Equal(t, fakeEnvVarValue, GetEnvOrElse(fakeEnVar, elseValue))
})
}
func TestSocketExists(t *testing.T) {
// Unix Domain Socket does not work on windows.
if runtime.GOOS == "windows" {
return
}
t.Run("socket exists should return false if file does not exists", func(t *testing.T) {
assert.False(t, SocketExists("/fake/path"))
})
t.Run("socket exists should return false if file exists but it's not a socket", func(t *testing.T) {
file, err := os.CreateTemp("/tmp", "prefix")
require.NoError(t, err)
defer os.Remove(file.Name())
assert.False(t, SocketExists(file.Name()))
})
t.Run("socket exists should return true if file exists and its a socket", func(t *testing.T) {
const fileName = "/tmp/socket1234.sock"
defer os.Remove(fileName)
listener, err := net.Listen("unix", fileName)
require.NoError(t, err)
defer listener.Close()
assert.True(t, SocketExists(fileName))
})
}
func TestPopulateMetadataForBulkPublishEntry(t *testing.T) {
entryMeta := map[string]string{
"key1": "val1",
"ttl": "22s",
}
t.Run("req Meta does not contain any key present in entryMeta", func(t *testing.T) {
reqMeta := map[string]string{
"rawPayload": "true",
"key2": "val2",
}
resMeta := PopulateMetadataForBulkPublishEntry(reqMeta, entryMeta)
assert.Len(t, resMeta, 4, "expected length to match")
assert.Contains(t, resMeta, "key1", "expected key to be present")
assert.Equal(t, "val1", resMeta["key1"], "expected val to be equal")
assert.Contains(t, resMeta, "key2", "expected key to be present")
assert.Equal(t, "val2", resMeta["key2"], "expected val to be equal")
assert.Contains(t, resMeta, "ttl", "expected key to be present")
assert.Equal(t, "22s", resMeta["ttl"], "expected val to be equal")
assert.Contains(t, resMeta, "rawPayload", "expected key to be present")
assert.Equal(t, "true", resMeta["rawPayload"], "expected val to be equal")
})
t.Run("req Meta contains key present in entryMeta", func(t *testing.T) {
reqMeta := map[string]string{
"ttl": "1m",
"key2": "val2",
}
resMeta := PopulateMetadataForBulkPublishEntry(reqMeta, entryMeta)
assert.Len(t, resMeta, 3, "expected length to match")
assert.Contains(t, resMeta, "key1", "expected key to be present")
assert.Equal(t, "val1", resMeta["key1"], "expected val to be equal")
assert.Contains(t, resMeta, "key2", "expected key to be present")
assert.Equal(t, "val2", resMeta["key2"], "expected val to be equal")
assert.Contains(t, resMeta, "ttl", "expected key to be present")
assert.Equal(t, "22s", resMeta["ttl"], "expected val to be equal")
})
}
func TestFilter(t *testing.T) {
t.Run("should filter out empty values", func(t *testing.T) {
in := []string{"", "a", "", "b", "", "c"}
out := Filter(in, func(s string) bool {
return s != ""
})
assert.Len(t, in, 6)
assert.Len(t, out, 3)
assert.Equal(t, []string{"a", "b", "c"}, out)
})
t.Run("should filter out empty values and return empty collection if all values are filtered out", func(t *testing.T) {
in := []string{"", "", ""}
out := Filter(in, func(s string) bool {
return s != ""
})
assert.Len(t, in, 3)
assert.Empty(t, out)
})
}
func TestContainsPrefixed(t *testing.T) {
tcs := []struct {
name string
prefixes []string
v string
want bool
}{
{
name: "empty",
v: "some-service-account-name",
want: false,
},
{
name: "notFound",
v: "some-service-account-name",
prefixes: []string{"service-account-name", "other-service-account-name"},
want: false,
},
{
name: "one",
v: "some-service-account-name",
prefixes: []string{"service-account-name", "some-service-account-name"},
want: true,
},
}
for _, tc := range tcs {
t.Run(tc.name, func(t *testing.T) {
assert.Equalf(t, tc.want, ContainsPrefixed(tc.prefixes, tc.v), "ContainsPrefixed(%v, %v)", tc.prefixes, tc.v)
})
}
}
func TestMapToSlice(t *testing.T) {
t.Run("mapStringString", func(t *testing.T) {
m := map[string]string{"a": "b", "c": "d", "e": "f"}
got := MapToSlice(m)
assert.ElementsMatch(t, got, []string{"a", "c", "e"})
})
t.Run("mapStringStruct", func(t *testing.T) {
m := map[string]struct{}{"a": {}, "c": {}, "e": {}}
got := MapToSlice(m)
assert.ElementsMatch(t, got, []string{"a", "c", "e"})
})
t.Run("intStringStruct", func(t *testing.T) {
m := map[int]struct{}{1: {}, 2: {}, 3: {}}
got := MapToSlice(m)
assert.ElementsMatch(t, got, []int{1, 2, 3})
})
}
func TestGetNamespaceOrDefault(t *testing.T) {
t.Run("namespace is empty", func(t *testing.T) {
ns := GetNamespaceOrDefault("default")
assert.Equal(t, "default", ns)
})
t.Run("namespace is not empty", func(t *testing.T) {
t.Setenv("NAMESPACE", "testNs")
ns := GetNamespaceOrDefault("default")
assert.Equal(t, "testNs", ns)
})
}
func BenchmarkFilter(b *testing.B) {
vals := make([]int, 100)
for i := 0; i < len(vals); i++ {
vals[i] = i
}
filterFn := func(n int) bool {
return n < 50
}
for n := 0; n < b.N; n++ {
Filter(vals, filterFn)
}
}
func TestParseServiceAddr(t *testing.T) {
testCases := []struct {
addr string
out []string
}{
{
addr: "localhost:1020",
out: []string{"localhost:1020"},
},
{
addr: "placement1:50005,placement2:50005,placement3:50005",
out: []string{"placement1:50005", "placement2:50005", "placement3:50005"},
},
{
addr: "placement1:50005, placement2:50005, placement3:50005",
out: []string{"placement1:50005", "placement2:50005", "placement3:50005"},
},
}
for _, tc := range testCases {
t.Run(tc.addr, func(t *testing.T) {
assert.EqualValues(t, tc.out, ParseServiceAddr(tc.addr))
})
}
}
|
mikeee/dapr
|
utils/utils_test.go
|
GO
|
mit
| 9,030 |
# IDE, temp, generated, and other local-only files
.idea/
*.iml
node_modules/
tweego.exe
*.html
# Ignoring img/ for now because of 5k+ files.
img/
# Ignoring working folder for Quin2k
mod/
|
QuiltedQuail/degrees
|
.gitignore
|
Git
|
unknown
| 191 |
@set TWEEGO_PATH=%USERPROFILE%\Documents\Twine\StoryFormats
@tweego -o "Degrees of Lewdity VERSION.html" game
|
QuiltedQuail/degrees
|
compile.bat
|
Batchfile
|
unknown
| 110 |
function colourContainerClasses() {
var V = State.variables;
return 'hair-' + (V.haircolour||'').replace(/ /g,'-') +
' ' + 'eye-' + (V.eyecolour||'').replace(/ /g,'-') +
' ' + 'upper-' + (V.uppercolour||'').replace(/ /g,'-') +
' ' + 'lower-' + (V.lowercolour||'').replace(/ /g,'-') +
' ' + 'under-' + (V.undercolour||'').replace(/ /g,'-')
}
window.colourContainerClasses = colourContainerClasses; // export function
|
QuiltedQuail/degrees
|
game/base-clothing.js
|
JavaScript
|
unknown
| 429 |
:: Wardrobe [nobr]
<<effects>>
You look in your wardrobe.<br><br>
<<wardrobewear>>
[[Close wardrobe|Bedroom]]<br><br>
<<wardrobe>>
:: Changing Room [nobr]
<<effects>><<set $outside to 0>><<set $location to "beach">>
You are in a small wooden changing room.<br><br>
<<wardrobewear>>
<<if $exposed lte 0>>
[[Leave|Beach]]<br><br>
<<else>>
You can't go out like this!<br><br>
<</if>>
<<wardrobe>>
:: Eden Wardrobe [nobr]
<<effects>>
You look through the cupboard containing your clothes. There's an old dressing screen for privacy.<br><br>
<<wardrobewear>>
<<if $exhibitionism lte 54>>
<<if $exposed lte 0>>
<<link [[Done|Eden Cabin]]>><<pass 1>><</link>><br><br>
<<else>>
You can't remain undressed like this!<br><br>
<</if>>
<<else>>
<<if $exposed lte 1>>
<<link [[Done|Eden Cabin]]>><</link>><br><br>
<<else>>
You can't remain undressed like this!<br><br>
<</if>>
<</if>>
<<wardrobe>>
:: Strip Club Dressing Room [nobr]
<<effects>><<set $outside to 0>><<set $location to "town">>
You are in the strip club's dressing room. <<if $daystate isnot "day" and $daystate isnot "dawn">>There are a few mirrors, currently occupied by staff fixing their hair and makeup.<</if>><br><br>
<<wardrobewear>>
<<if $exhibitionism lte 54>>
<<if $exposed lte 0>>
<<link [[Back to the club (0:01)|Strip Club]]>><<pass 1>><</link>><br><br>
<<else>>
You can't go out like this!<br><br>
<</if>>
<<elseif $exhibitionism gte 95>>
<<link [[Back to the club (0:01)|Strip Club]]>><<pass 1>><</link>><br><br>
<<else>>
<<if $exposed lte 1>>
<<link [[Back to the club (0:01)|Strip Club]]>><<pass 1>><</link>><br><br>
<<else>>
You can't go out like this!<br><br>
<</if>>
<</if>>
<<wardrobe>>
:: Brothel Dressing Room [nobr]
<<effects>><<set $outside to 0>><<set $location to "town">>
You are in the brothel's dressing room. There are a few mirrors, currently occupied by staff fixing their hair and makeup.<br><br>
<<wardrobewear>>
<<if $exhibitionism lte 54>>
<<if $exposed lte 0>>
<<link [[Back to the brothel (0:01)|Brothel]]>><<pass 1>><</link>><br><br>
<<else>>
You can't go out like this!<br><br>
<</if>>
<<elseif $exhibitionism gte 95>>
<<link [[Back to the brothel (0:01)|Brothel]]>><<pass 1>><</link>><br><br>
<<else>>
<<if $exposed lte 1>>
<<link [[Back to the brothel (0:01)|Brothel]]>><<pass 1>><</link>><br><br>
<<else>>
You can't go out like this!<br><br>
<</if>>
<</if>>
<<wardrobe>>
:: Testing Room [nobr]
<<silently>><<effects>><</silently>>
/*<<Avatar>>*/
<<link "<<">><<set $pain -= 10>><<goto "Testing Room">><</link>>
<<link "<">><<set $pain -= 5>><<goto "Testing Room">><</link>>
Pain (<<= $pain>>)
<<link ">">><<set $pain += 5>><<goto "Testing Room">><</link>>
<<link ">>">><<set $pain += 10>><<goto "Testing Room">><</link>> <br>
<<link "<<">><<set $arousal -= 1000>><<goto "Testing Room">><</link>>
<<link "<">><<set $arousal -= 100>><<goto "Testing Room">><</link>>
Arousal (<<= $arousal>>)
<<link ">">><<set $arousal += 100>><<goto "Testing Room">><</link>>
<<link ">>">><<set $arousal += 1000>><<goto "Testing Room">><</link>> <br>
<<link "<<">><<set $stress -= 1000>><<goto "Testing Room">><</link>>
<<link "<">><<set $stress -= 100>><<goto "Testing Room">><</link>>
Stress (<<= $stress>>)
<<link ">">><<set $stress += 100>><<goto "Testing Room">><</link>>
<<link ">>">><<set $stress += 1000>><<goto "Testing Room">><</link>> <br>
<<link "<<">><<set $trauma -= 1000>><<goto "Testing Room">><</link>>
<<link "<">><<set $trauma -= 100>><<goto "Testing Room">><</link>>
Trauma (<<= $trauma>>)
<<link ">">><<set $trauma += 100>><<goto "Testing Room">><</link>>
<<link ">>">><<set $trauma += 1000>><<goto "Testing Room">><</link>> <br><br>
<<link "<<">><<set $promiscuity -= 10>><<goto "Testing Room">><</link>>
<<link "<">><<set $promiscuity -= 2>><<goto "Testing Room">><</link>>
Promiscuity (<<= $promiscuity>>)
<<link ">">><<set $promiscuity += 2>><<goto "Testing Room">><</link>>
<<link ">>">><<set $promiscuity += 10>><<goto "Testing Room">><</link>> <br>
<<link "<<">><<set $exhibitionism -= 10>><<goto "Testing Room">><</link>>
<<link "<">><<set $exhibitionism -= 2>><<goto "Testing Room">><</link>>
Exhibitionism (<<= $exhibitionism>>)
<<link ">">><<set $exhibitionism += 2>><<goto "Testing Room">><</link>>
<<link ">>">><<set $exhibitionism += 10>><<goto "Testing Room">><</link>> <br><br>
Toggle:
<<link "Gender">><<if $playergender is "f">>
<<set $vaginaexist to 0>><<set $playergender to "m">><<set $penisexist to 1>>
<<else>><<set $penisexist to 0>><<set $playergender to "f">><<set $vaginaexist to 1>><</if>>
<<goto "Testing Room">><</link>> |
<<link "Virginity">>
<<if $penilevirginity is 0 or $vaginalvirginity is 0>>
<<set $penilevirginity to 1>><<set $vaginalvirginity to 1>><<set $oralvirginity to 1>><<set $analvirginity to 1>>
<<else>>
<<set $penilevirginity to 0>><<set $vaginalvirginity to 0>><<set $oralvirginity to 0>><<set $analvirginity to 0>>
<</if>>
<<goto "Testing Room">><</link>> |
<<link "Hirsute">>
<<if $hirsutedisable is "f">><<set $hirsutedisable to "t">>
<<else>><<set $hirsutedisable to "f">><</if>>
<<goto "Testing Room">><</link>> |
<<link "Bound Left Arm">>
<<if $leftarm is "bound">><<set $leftarm to 0>><<set $leftboundcarry to 0>>
<<else>><<set $leftarm to "bound">><</if>>
<<goto "Testing Room">><</link>> |
<<link "Bound Right Arm">>
<<if $rightarm is "bound">><<set $rightarm to 0>><<set $rightboundcarry to 0>>
<<else>><<set $rightarm to "bound">><</if>>
<<goto "Testing Room">><</link>> <br><br>
Breast Size - 0, 1, 2, 3, 4, 5, 6, 7, 8, 9, 10, 11, 12 <br>
Hair Colour (<<= $haircolour>>):
<<link "Black">><<set $haircolour to "black">><<goto "Testing Room">><</link>> |
<<link "Brown">><<set $haircolour to "brown">><<goto "Testing Room">><</link>> |
<<link "Red">><<set $haircolour to "red">><<goto "Testing Room">><</link>> |
<<link "Ginger">><<set $haircolour to "ginger">><<goto "Testing Room">><</link>> |
<<link "Blond">><<set $haircolour to "blond">><<goto "Testing Room">><</link>> |
<<link "Green">><<set $haircolour to "green">><<goto "Testing Room">><</link>> |
<<link "Blue">><<set $haircolour to "blue">><<goto "Testing Room">><</link>> |
<<link "Purple">><<set $haircolour to "purple">><<goto "Testing Room">><</link>> <br>
<<link "<<">><<set $hairlength -= 100>><<goto "Testing Room">><</link>>
<<link "<">><<set $hairlength -= 10>><<goto "Testing Room">><</link>>
Hair Length (<<= $hairlength>>)
<<link ">">><<set $hairlength += 10>><<goto "Testing Room">><</link>>
<<link ">>">><<set $hairlength += 100>><<goto "Testing Room">><</link>> <br>
Eye Colour (<<= $eyecolour>>):
<<link "Hazel">><<set $eyecolour to "hazel">><<goto "Testing Room">><</link>> |
<<link "Amber">><<set $eyecolour to "amber">><<goto "Testing Room">><</link>> |
<<link "Green">><<set $eyecolour to "green">><<goto "Testing Room">><</link>> |
<<link "Dark Blue">><<set $eyecolour to "dark blue">><<goto "Testing Room">><</link>> |
<<link "Light Blue">><<set $eyecolour to "light blue">><<goto "Testing Room">><</link>> |
<<link "Purple">><<set $eyecolour to "purple">><<goto "Testing Room">><</link>> <br><br>
<<link "<">><<set $wolfgirl -= 1>><<goto "Testing Room">><</link>>
Wolf (<<= $wolfgirl>>)
<<link ">">><<set $wolfgirl += 1>><<goto "Testing Room">><</link>> |
<<link "<">><<set $angel -= 1>><<goto "Testing Room">><</link>>
Angel (<<= $angel>>)
<<link ">">><<set $angel += 1>><<goto "Testing Room">><</link>> |
<<link "<">><<set $demon -= 1>><<goto "Testing Room">><</link>>
Demon (<<= $demon>>)
<<link ">">><<set $demon += 1>><<goto "Testing Room">><</link>> |
<<link "<">><<set $fallenangel -= 1>><<goto "Testing Room">><</link>>
Fallen Angel (<<= $fallenangel>>)
<<link ">">><<set $fallenangel += 1>><<goto "Testing Room">><</link>> <br><br>
Semen:
<<link "<">><<set $vaginasemen -= 1>><<goto "Testing Room">><</link>>
Vagina (<<= $vaginasemen>>)
<<link ">">><<set $vaginasemen += 1>><<goto "Testing Room">><</link>> |
<<link "<">><<set $anussemen -= 1>><<goto "Testing Room">><</link>>
Anus (<<= $anussemen>>)
<<link ">">><<set $anussemen += 1>><<goto "Testing Room">><</link>> |
<<link "<">><<set $mouthsemen -= 1>><<goto "Testing Room">><</link>>
Mouth (<<= $mouthsemen>>)
<<link ">">><<set $mouthsemen += 1>><<goto "Testing Room">><</link>> <br>
Goo:
<<link "<">><<set $vaginagoo -= 1>><<goto "Testing Room">><</link>>
Vagina (<<= $vaginagoo>>)
<<link ">">><<set $vaginagoo += 1>><<goto "Testing Room">><</link>> |
<<link "<">><<set $anusgoo -= 1>><<goto "Testing Room">><</link>>
Anus (<<= $anusgoo>>)
<<link ">">><<set $anusgoo += 1>><<goto "Testing Room">><</link>> |
<<link "<">><<set $mouthgoo -= 1>><<goto "Testing Room">><</link>>
Mouth (<<= $mouthgoo>>)
<<link ">">><<set $mouthgoo += 1>><<goto "Testing Room">><</link>> <br>
Parasite:
<<link "Chest">>
<<if $chestparasite is 0>><<set $chestparasite to 1>>
<<else>><<set $chestparasite to 0>><</if>>
<<goto "Testing Room">><</link>> |
<<link "Penis">>
<<if $penisparasite is 0>><<set $penisparasite to 1>>
<<else>><<set $penisparasite to 0>><</if>>
<<goto "Testing Room">><</link>> |
<<link "Clit">>
<<if $clitparasite is 0>><<set $clitparasite to 1>>
<<else>><<set $clitparasite to 0>><</if>>
<<goto "Testing Room">><</link>> <br><br>
Upper Clothes: <<link "<<">><<set $upperintegrity -= 10>><<goto "Testing Room">><</link>>
<<link "<">><<set $upperintegrity -= 1>><<goto "Testing Room">><</link>>
Integrity (<<= $upperintegrity>>)
<<link ">">><<set $upperintegrity += 1>><<goto "Testing Room">><</link>>
<<link ">>">><<set $upperintegrity += 10>><<goto "Testing Room">><</link>> |
<<link "<">><<set $upperwet -= 100>><<goto "Testing Room">><</link>>
Wet (<<= $upperwet>>)
<<link ">">><<set $upperwet += 1>><<goto "Testing Room">><</link>> <br>
Lower Clothes: <<link "<<">><<set $lowerintegrity -= 10>><<goto "Testing Room">><</link>>
<<link "<">><<set $lowerintegrity -= 1>><<goto "Testing Room">><</link>>
Integrity (<<= $lowerintegrity>>)
<<link ">">><<set $lowerintegrity += 1>><<goto "Testing Room">><</link>>
<<link ">>">><<set $lowerintegrity += 10>><<goto "Testing Room">><</link>> |
<<link "<">><<set $lowerwet -= 100>><<goto "Testing Room">><</link>>
Wet (<<= $lowerwet>>)
<<link ">">><<set $lowerwet += 1>><<goto "Testing Room">><</link>> <br>
Underwear: <<link "<<">><<set $underintegrity -= 10>><<goto "Testing Room">><</link>>
<<link "<">><<set $underintegrity -= 1>><<goto "Testing Room">><</link>>
Integrity (<<= $underintegrity>>)
<<link ">">><<set $underintegrity += 1>><<goto "Testing Room">><</link>>
<<link ">>">><<set $underintegrity += 10>><<goto "Testing Room">><</link>> |
<<link "<">><<set $underwet -= 100>><<goto "Testing Room">><</link>>
Wet (<<= $underwet>>)
<<link ">">><<set $underwet += 1>><<goto "Testing Room">><</link>> <br>
/*ToDo: Add handling for toggling clothing.*/
/*ToDo: Wardrobe and Shop*/
<br><br>
<<link [[Bedroom]]>><</link>><br>
:: Widgets Wardrobe [widget]
<<widget "wardrobewear">><<nobr>>
<<if $wear is "stripall">><<set $wear to 0>>
<<if $uppertype is "naked" and $lowertype is "naked" and $undertype is "naked">>
There's nothing to remove.
<<else>>
You remove your clothing.
<</if>>
<br><br>
<<uppernaked>>
<<lowernaked>>
<<undernaked>>
<</if>>
<<if $wear is "dry">><<set $wear to 0>>
<<set $upperwet to 0>><<set $lowerwet to 0>><<set $underwet to 0>><<set $upperwetstage to 0>><<set $lowerwetstage to 0>><<set $underwetstage to 0>>
You squeeze the water from your clothes.<br><br>
<</if>>
<<if $wear is "sundress">><<set $wear to 0>>
You wear the sundress.<br><br>
<<if $uppersundressno gte 1 and $lowersundressno gte 1>>
<<uppernaked>><<lowernaked>>
<</if>>
<<if $uppersundressno gte 1>>
<<uppersundress>>
<</if>>
<<if $lowersundressno gte 1>>
<<lowersundress>>
<</if>>
<</if>>
<<if $wear is "schoolswimsuit">><<set $wear to 0>>
You wear the swimsuit.<br><br>
<<if $upperschoolswimsuitno gte 1>>
<<upperschoolswimsuit>>
<</if>>
<<if $lowerschoolswimsuitno gte 1>>
<<lowerschoolswimsuit>>
<</if>>
<</if>>
<<if $wear is "eveninggown">><<set $wear to 0>>
You wear the evening gown.<br><br>
<<if $uppereveninggownno gte 1>>
<<uppereveninggown>>
<</if>>
<<if $lowereveninggownno gte 1>>
<<lowereveninggown>>
<</if>>
<</if>>
<<if $wear is "stripupper">><<set $wear to 0>>
<<if $uppertype isnot "naked">>
You take off your $upperclothes.
<<else>>
You are already topless.
<</if>>
<<uppernaked>><br><br>
<</if>>
<<if $wear is "uppertowel">><<set $wear to 0>><<set $uppertowelnew to 1>>
You wrap the towel around your chest.<br><br>
<<uppertowel>>
<</if>>
<<if $wear is "upperpjs">><<set $wear to 0>>
You wear the pyjama shirt.<br><br>
<<upperpjs>>
<</if>>
<<if $wear is "upperbikini">><<set $wear to 0>>
You wear the bikini top.<br><br>
<<upperbikini>>
<</if>>
<<if $wear is "tshirt">><<set $wear to 0>>
You wear the t-shirt.<br><br>
<<tshirt>>
<</if>>
<<if $wear is "schoolshirt">><<set $wear to 0>>
You wear the school shirt.<br><br>
<<schoolshirt>>
<</if>>
<<if $wear is "tanktop">><<set $wear to 0>>
You wear the tank top.<br><br>
<<tanktop>>
<</if>>
<<if $wear is "striplower">><<set $wear to 0>>
<<if $lowertype isnot "naked">>
You take off your
<<if $upperset isnot $lowerset>>
$lowerclothes
<<else>>$upperclothes.
<</if>>
<<else>>
You are already bottomless.
<</if>>
<<lowernaked>><br><br>
<</if>>
<<if $wear is "lowertowel">><<set $wear to 0>><<set $lowertowelnew to 1>>
You wrap the towel around your pelvis.<br><br>
<<lowertowel>>
<</if>>
<<if $wear is "lowerpjs">><<set $wear to 0>>
You wear the pyjama bottoms.<br><br>
<<lowerpjs>>
<</if>>
<<if $wear is "lowerbikini">><<set $wear to 0>>
You wear the bikini bottoms.<br><br>
<<lowerbikini>>
<</if>>
<<if $wear is "waistapron">><<set $wear to 0>>
You wear the waist apron.<br><br>
<<waistapron>>
<</if>>
<<if $wear is "shorts">><<set $wear to 0>>
You wear the shorts.<br><br>
<<shorts>>
<</if>>
<<if $wear is "schoolshorts">><<set $wear to 0>>
You wear the school shorts.<br><br>
<<schoolshorts>>
<</if>>
<<if $wear is "schoolskirt">><<set $wear to 0>>
You wear the school skirt.<br><br>
<<schoolskirt>>
<</if>>
<<if $wear is "schoolswimshorts">><<set $wear to 0>>
You wear the swim shorts.<br><br>
<<schoolswimshorts>>
<</if>>
<<if $wear is "stripunder">><<set $wear to 0>>
<<if $undertype isnot "naked">>
You take off your $underclothes.
<<else>>
You are already pantiless.
<</if>>
<<undernaked>><br><br>
<</if>>
<<if $wear is "plainpanties">><<set $wear to 0>>
You wear the plain panties.<br><br>
<<plainpanties>>
<</if>>
<<if $wear is "lacepanties">><<set $wear to 0>>
You wear the lace panties.<br><br>
<<lacepanties>>
<</if>>
<<if $wear is "yfronts">><<set $wear to 0>>
You wear the Y fronts.<br><br>
<<yfronts>>
<</if>>
<<if $wear is "tights">><<set $wear to 0>>
You wear the tights.<br><br>
<<tights>>
<</if>>
<<accessorieswear>>
<<exposure>>
<</nobr>><</widget>>
<<widget "wardrobe">><<nobr>>
<<if $upperwetstage gte 1 or $lowerwetstage gte 1 or $underwetstage gte 1>>
<<link "Dry your clothes">><<set $wear to "dry">><<script>>state.display(state.active.title, null)<</script>><</link>><br><br>
<</if>>
Outfits<br>
<<if $uppersundressno gte 1>> |
<<link "Sundress">><<set $wear to "sundress">><<script>>state.display(state.active.title, null)<</script>><</link>>
<<elseif $lowersundressno gte 1>> |
<<link "Sundress">><<set $wear to "sundress">><<script>>state.display(state.active.title, null)<</script>><</link>>
<</if>>
<<if $upperschoolswimsuitno gte 1>> |
<<link "School swimsuit">><<set $wear to "schoolswimsuit">><<script>>state.display(state.active.title, null)<</script>><</link>>
<<elseif $lowerschoolswimsuitno gte 1>> |
<<link "School swimsuit">><<set $wear to "schoolswimsuit">><<script>>state.display(state.active.title, null)<</script>><</link>>
<</if>>
<<if $uppereveninggownno gte 1>> |
<<link "Evening gown">><<set $wear to "eveninggown">><<script>>state.display(state.active.title, null)<</script>><</link>>
<<elseif $lowereveninggownno gte 1>> |
<<link "Evening gown">><<set $wear to "eveninggown">><<script>>state.display(state.active.title, null)<</script>><</link>>
<</if>>
<br>
<<link "Strip all">><<set $wear to "stripall">><<script>>state.display(state.active.title, null)<</script>><</link>>
<br><br>
Tops<br>
<<if $upperpjsno gte 1>> |
<<link "Pyjama shirt">><<set $wear to "upperpjs">><<script>>state.display(state.active.title, null)<</script>><</link>>
<</if>>
<<if $upperbikinino gte 1>> |
<<link "Bikini top">><<set $wear to "upperbikini">><<script>>state.display(state.active.title, null)<</script>><</link>>
<</if>>
<<if $tshirtno gte 1>> |
<<link "T-shirt">><<set $wear to "tshirt">><<script>>state.display(state.active.title, null)<</script>><</link>>
<</if>>
<<if $schoolshirtno gte 1>> |
<<link "School shirt">><<set $wear to "schoolshirt">><<script>>state.display(state.active.title, null)<</script>><</link>>
<</if>>
<<if $tanktopno gte 1>> |
<<link "Tank top">><<set $wear to "tanktop">><<script>>state.display(state.active.title, null)<</script>><</link>>
<</if>>
| <<link "Towel">><<set $wear to "uppertowel">>
<<script>>state.display(state.active.title, null)<</script>>
<</link>>
<br>
<<link "Strip top">><<set $wear to "stripupper">><<script>>state.display(state.active.title, null)<</script>><</link>>
<br><br>
Bottoms<br>
<<if $lowerpjsno gte 1>> |
<<link "Pyjama bottoms">><<set $wear to "lowerpjs">>
<<script>>state.display(state.active.title, null)<</script>><</link>>
<</if>>
<<if $lowerbikinino gte 1>> |
<<link "Bikini bottoms">><<set $wear to "lowerbikini">>
<<script>>state.display(state.active.title, null)<</script>><</link>>
<</if>>
<<if $waistapronno gte 1>> |
<<link "Waist apron">><<set $wear to "waistapron">>
<<script>>state.display(state.active.title, null)<</script>><</link>>
<</if>>
<<if $shortsno gte 1>> |
<<link "Shorts">><<set $wear to "shorts">><<script>>state.display(state.active.title, null)<</script>>
<</link>>
<</if>>
<<if $schoolshortsno gte 1>> |
<<link "School shorts">><<set $wear to "schoolshorts">><<script>>state.display(state.active.title, null)<</script>>
<</link>>
<</if>>
<<if $schoolskirtno gte 1>> |
<<link "School skirt">><<set $wear to "schoolskirt">><<script>>state.display(state.active.title, null)<</script>>
<</link>>
<</if>>
<<if $schoolswimshortsno gte 1>> |
<<link "School swim shorts">><<set $wear to "schoolswimshorts">><<script>>state.display(state.active.title, null)<</script>>
<</link>>
<</if>>
| <<link "Towel">><<set $wear to "lowertowel">>
<<script>>state.display(state.active.title, null)<</script>>
<</link>>
<br>
<<link "Strip bottom">><<set $wear to "striplower">><<script>>state.display(state.active.title, null)<</script>><</link>>
<br><br>
Underwear<br>
<<if $undertype is "chastity">>
You can't remove your chastity belt without help.<br><br>
<<else>>
<<if $plainpantiesno gte 1>> |
<<link "Plain panties">><<set $wear to "plainpanties">><<script>>state.display(state.active.title, null)<</script>><</link>>
<</if>>
<<if $lacepantiesno gte 1>> |
<<link "Lace panties">><<set $wear to "lacepanties">><<script>>state.display(state.active.title, null)<</script>><</link>>
<</if>>
<<if $yfrontsno gte 1>> |
<<link "Y fronts">><<set $wear to "yfronts">><<script>>state.display(state.active.title, null)<</script>><</link>>
<</if>>
<<if $tightsno gte 1>> |
<<link "Tights">><<set $wear to "tights">><<script>>state.display(state.active.title, null)<</script>><</link>>
<</if>>
<br>
<<link "Strip underwear">><<set $wear to "stripunder">><<script>>state.display(state.active.title, null)<</script>><</link>>
<br><br>
<</if>>
<<accessories>>
<<link "Set currently worn clothing as casual outfit">><<set $upperoutfitcasual to $upperclothes>><<set $loweroutfitcasual to $lowerclothes>><<set $underoutfitcasual to $underclothes>><<script>>state.display(state.active.title, null)<</script>><</link>><br>
<<link "Set currently worn clothing as school outfit">><<set $upperoutfitschool to $upperclothes>><<set $loweroutfitschool to $lowerclothes>><<set $underoutfitschool to $underclothes>><<script>>state.display(state.active.title, null)<</script>><</link>><br>
<<link "Set currently worn clothing as custom 1 outfit">><<set $upperoutfitcustom1 to $upperclothes>><<set $loweroutfitcustom1 to $lowerclothes>><<set $underoutfitcustom1 to $underclothes>><<script>>state.display(state.active.title, null)<</script>><</link>><br>
<<link "Set currently worn clothing as custom 2 outfit">><<set $upperoutfitcustom2 to $upperclothes>><<set $loweroutfitcustom2 to $lowerclothes>><<set $underoutfitcustom2 to $underclothes>><<script>>state.display(state.active.title, null)<</script>><</link>><br>
<<link "Set currently worn clothing as custom 3 outfit">><<set $upperoutfitcustom3 to $upperclothes>><<set $loweroutfitcustom3 to $lowerclothes>><<set $underoutfitcustom3 to $underclothes>><<script>>state.display(state.active.title, null)<</script>><</link>><br>
<<link "Set currently worn clothing as custom 4 outfit">><<set $upperoutfitcustom4 to $upperclothes>><<set $loweroutfitcustom4 to $lowerclothes>><<set $underoutfitcustom4 to $underclothes>><<script>>state.display(state.active.title, null)<</script>><</link>><br>
<br>
<<set $upperoff to 0>>
<<set $loweroff to 0>>
<<set $underoff to 0>>
<<exposure>>
<</nobr>><</widget>>
:: Widgets Clothing [widget]
<<widget "clothinginit">><<nobr>>
<<set $uppersundresscolourchoice to 0>>
<<set $lowersundresscolourchoice to 0>>
<<set $upperpjscolourchoice to 0>>
<<set $lowerpjscolourchoice to 0>>
<<set $uppertowelcolourchoice to 0>>
<<set $lowertowelcolourchoice to 0>>
<<set $upperbikinicolourchoice to 0>>
<<set $lowerbikinicolourchoice to 0>>
<<set $plainpantiescolourchoice to 0>>
<<set $lacepantiescolourchoice to 0>>
<<set $tightscolourchoice to 0>>
<<set $waistaproncolourchoice to 0>>
<<set $tshirtcolourchoice to 0>>
<<set $shortscolourchoice to 0>>
<<set $yfrontscolourchoice to 0>>
<<set $schoolshirtcolourchoice to 0>>
<<set $schoolshortscolourchoice to 0>>
<<set $schoolskirtcolourchoice to 0>>
<<set $upperschoolswimsuitcolourchoice to 0>>
<<set $lowerschoolswimsuitcolourchoice to 0>>
<<set $schoolswimshortscolourchoice to 0>>
<<set $chastitybeltcolourchoice to 0>>
<<set $uppereveninggowncolourchoice to 0>>
<<set $lowereveninggowncolourchoice to 0>>
<<set $upperstore to 0>>
<<set $lowerstore to 0>>
<<set $understore to 0>>
<<set $headacc to 0>>
<<set $faceacc to 0>>
<<set $legsacc to 0>>
<<set $feetacc to 0>>
<<set $hairpin to 1>>
<<set $blackshoes to 1>>
<<set $glasses to 1>>
<<set $upperoff to 0>>
<<set $loweroff to 0>>
<<set $underoff to 0>>
<<set $upperwet to 0>>
<<set $lowerwet to 0>>
<<set $underwet to 0>>
<<set $upperwetstage to 0>>
<<set $lowerwetstage to 0>>
<<set $underwetstage to 0>>
<<set $upperwetcarry to 0>>
<<set $lowerwetcarry to 0>>
<<set $underwetcarry to 0>>
<<set $upperwetstagecarry to 0>>
<<set $lowerwetstagecarry to 0>>
<<set $underwetstagecarry to 0>>
<<set $waterwash to 0>>
<</nobr>><</widget>>
<<widget "givestartclothing">><<nobr>>
<<if $playergender is "f">>
<<set $girlsgymsocks to 1>>
<<set $uppersundressnew to 1>>
<<set $lowersundressnew to 1>>
<<set $upperpjsnew to 1>>
<<set $lowerpjsnew to 1>>
<<set $plainpantiesnew to 1>>
<<set $schoolshirtnew to 1>>
<<set $schoolskirtnew to 1>>
<<set $upperschoolswimsuitnew to 1>>
<<set $lowerschoolswimsuitnew to 1>>
<<upperschoolswimsuit>><<lowerschoolswimsuit>><<schoolshirt>><<schoolskirt>><<upperpjs>><<lowerpjs>><<uppersundress>><<lowersundress>><<plainpanties>>
<<set $uppersundressno to 1>>
<<set $upperpjsno to 1>>
<<set $lowersundressno to 1>>
<<set $lowerpjsno to 1>>
<<set $plainpantiesno to 1>>
<<set $schoolshirtno to 1>>
<<set $schoolskirtno to 1>>
<<set $upperschoolswimsuitno to 1>>
<<set $lowerschoolswimsuitno to 1>>
<<set $sundresscolour to "white">>
<<set $sundresscolourchoice to "white">>
<<set $upperpjscolour to "blue">>
<<set $upperpjscolourchoice to "blue">>
<<set $lowerpjscolour to "blue">>
<<set $lowerpjscolourchoice to "blue">>
<<set $plainpantiescolour to "pink">>
<<set $plainpantiescolourchoice to "pink">>
<<set $schoolshirtcolour to "white">>
<<set $schoolshirtcolourchoice to "white">>
<<set $schoolskirtcolour to "black">>
<<set $schoolskirtcolourchoice to "black">>
<<set $schoolswimsuitcolour to "blue">>
<<set $schoolswimsuitcolourchoice to "blue">>
<<set $uppercolour to $sundresscolour>>
<<set $lowercolour to $sundresscolour>>
<<set $undercolour to $plainpantiescolour>>
<<set $upperoff to 0>>
<<set $loweroff to 0>>
<<set $underoff to 0>>
<<set $upperoutfitcasual to "sundress">>
<<set $loweroutfitcasual to "sundress skirt">>
<<set $underoutfitcasual to "plain panties">>
<<set $upperoutfitschool to "school shirt">>
<<set $loweroutfitschool to "school skirt">>
<<set $underoutfitschool to "plain panties">>
<<elseif $playergender is "m">>
<<set $boysgymsocks to 1>>
<<set $upperpjsnew to 1>>
<<set $lowerpjsnew to 1>>
<<set $tshirtnew to 1>>
<<set $shortsnew to 1>>
<<set $yfrontsnew to 1>>
<<set $schoolshirtnew to 1>>
<<set $schoolshortsnew to 1>>
<<set $schoolswimshortsnew to 1>>
<<schoolswimshorts>><<schoolshirt>><<schoolshorts>><<upperpjs>><<lowerpjs>><<shorts>><<tshirt>><<yfronts>>
<<set $upperpjsno to 1>>
<<set $lowerpjsno to 1>>
<<set $tshirtno to 1>>
<<set $shortsno to 1>>
<<set $yfrontsno to 1>>
<<set $schoolshirtno to 1>>
<<set $schoolshortsno to 1>>
<<set $schoolswimshortsno to 1>>
<<set $upperpjscolour to "blue">>
<<set $upperpjscolourchoice to "blue">>
<<set $lowerpjscolour to "blue">>
<<set $lowerpjscolourchoice to "blue">>
<<set $tshirtcolour to "tangerine">>
<<set $tshirtcolourchoice to "tangerine">>
<<set $shortscolour to "blue">>
<<set $shortscolourchoice to "blue">>
<<set $yfrontscolour to "white">>
<<set $yfrontscolourchoice to "white">>
<<set $schoolshirtcolour to "white">>
<<set $schoolshirtcolourchoice to "white">>
<<set $schoolshortscolour to "black">>
<<set $schoolshortscolourchoice to "black">>
<<set $schoolswimshortscolour to "blue">>
<<set $schoolswimshortscolourchoice to "blue">>
<<set $uppercolour to $tshirtcolour>>
<<set $lowercolour to $shortscolour>>
<<set $undercolour to $yfrontscolour>>
<<set $upperoff to 0>>
<<set $loweroff to 0>>
<<set $underoff to 0>>
<<set $upperoutfitcasual to $upperclothes>>
<<set $loweroutfitcasual to $lowerclothes>>
<<set $underoutfitcasual to $underclothes>>
<<set $upperoutfitschool to "school shirt">>
<<set $loweroutfitschool to "school shorts">>
<<set $underoutfitschool to "Y fronts">>
<</if>>
<</nobr>><</widget>>
<<widget "uppernaked">><<nobr>>
<<upperstrip>>
<<if $uppertemp is "init">>
<<set $uppertemp to 1>>
<<elseif $uppertemp is 1>>
<<set $uppertemp to 0>>
<</if>>
<<set $upperclothes to "naked">>
<<set $uppervariable to "naked">>
<<set $upperintegrity to 0>>
<<set $upperintegritymax to 0>>
<<set $upperfabricstrength to 0>>
<<set $upperreveal to 1000>>
<<set $upperword to "n">>
<<set $upperonepiece to 0>>
<<set $strap to 0>>
<<set $open to 0>>
<<set $upperstate to 0>>
<<set $upperstatetop to 0>>
<<set $upperstatebase to 0>>
<<set $upperstatetopbase to 0>>
<<set $upperplural to 0>>
<<set $uppercolour to 0>>
<<set $upperexposed to 2>>
<<set $upperexposedbase to 2>>
<<set $uppertype to "naked">>
<<if $clothingchange isnot 1 and $ruined isnot 1>>
<<if $upperset is $lowerset>>
<<set $clothingchange to 1>><<lowernaked>>
<</if>>
<</if>>
<<set $clothingchange to 0>>
<<set $upperset to "upper">>
<<set $uppergender to "n">>
<</nobr>><</widget>>
<<widget "uppersundress">><<nobr>>
<<upperstrip>><<upperundress>>
<<set $upperclothes to "sundress">>
<<set $uppervariable to "uppersundress">>
<<set $uppersundressintegritymax to 100>>
<<set $upperintegritymax to $uppersundressintegritymax>>
<<set $upperfabricstrength to 30>>
<<set $upperreveal to 200>>
<<set $upperword to "a">>
<<set $upperonepiece to 1>>
<<set $strap to 1>>
<<set $open to 1>>
<<set $upperstate to "waist">>
<<set $upperstatetop to "chest">>
<<set $upperstatebase to "waist">>
<<set $upperstatetopbase to "chest">>
<<set $upperplural to 0>>
<<if $uppersundressnew is 1>><<set $uppersundressnew to 0>><<set $uppersundressintegrity to $uppersundressintegritymax>>
<<set $sundresscolour to either("blue", "white", "red", "green", "black", "pink", "purple", "tangerine", "yellow")>>
<<if $sundresscolourchoice isnot 0>>
<<set $sundresscolour to $sundresscolourchoice>>
<</if>>
<</if>>
<<set $uppercolour to $sundresscolour>>
<<set $upperintegrity to $uppersundressintegrity>>
<<set $upperexposed to 0>>
<<set $upperexposedbase to 0>>
<<set $uppertype to "normal">>
<<if $clothingchange isnot 1>>
<<if $upperset is $lowerset>>
<<set $clothingchange to 1>><<lowerstrip>><<lowerundress>>
<</if>>
<</if>>
<<set $clothingchange to 0>>
<<set $upperset to "sundress">>
<<set $uppergender to "f">>
<</nobr>><</widget>>
<<widget "upperpjs">><<nobr>>
<<upperstrip>><<upperundress>>
<<set $upperclothes to "pyjama shirt">>
<<set $uppervariable to "upperpjs">>
<<set $upperpjsintegritymax to 100>>
<<set $upperintegritymax to $upperpjsintegritymax>>
<<set $upperfabricstrength to 20>>
<<set $upperreveal to 100>>
<<set $upperword to "a">>
<<set $upperonepiece to 0>>
<<set $strap to 0>>
<<set $open to 0>>
<<set $upperstate to "waist">>
<<set $upperstatetop to "chest">>
<<set $upperstatebase to "waist">>
<<set $upperstatetopbase to "chest">>
<<set $upperplural to 0>>
<<if $upperpjsnew is 1>><<set $upperpjsnew to 0>><<set $upperpjsintegrity to $upperpjsintegritymax>>
<<set $upperpjscolour to either("blue", "white", "red", "green", "black", "pink", "purple", "tangerine", "yellow")>>
<<if $upperpjscolourchoice isnot 0>>
<<set $upperpjscolour to $upperpjscolourchoice>>
<</if>>
<</if>>
<<set $uppercolour to $upperpjscolour>>
<<set $upperintegrity to $upperpjsintegrity>>
<<set $upperexposed to 0>>
<<set $upperexposedbase to 0>>
<<set $uppertype to "sleep">>
<<if $clothingchange isnot 1>>
<<if $upperset is $lowerset>>
<<set $clothingchange to 1>><<lowerstrip>><<lowerundress>>
<</if>>
<</if>>
<<set $clothingchange to 0>>
<<set $upperset to "upper">>
<<set $uppergender to "n">>
<</nobr>><</widget>>
<<widget "uppertowel">><<nobr>>
<<upperstrip>><<upperundress>>
<<set $upperclothes to "towel">>
<<set $uppervariable to "uppertowel">>
<<set $uppertowelintegritymax to 10>>
<<set $upperintegritymax to $uppertowelintegritymax>>
<<set $upperfabricstrength to 20>>
<<set $upperreveal to 800>>
<<set $upperword to "a">>
<<set $upperonepiece to 0>>
<<set $strap to 0>>
<<set $open to 1>>
<<set $upperstate to "waist">>
<<set $upperstatetop to "chest">>
<<set $upperstatebase to "waist">>
<<set $upperstatetopbase to "chest">>
<<set $upperplural to 0>>
<<if $uppertowelnew is 1>><<set $uppertowelnew to 0>><<set $uppertowelintegrity to $uppertowelintegritymax>>
<<set $uppertowelcolour to either("blue", "white", "red", "green", "black", "pink", "purple", "tangerine", "yellow")>>
<<if $uppertowelcolourchoice isnot 0>>
<<set $uppertowelcolour to $uppertowelcolourchoice>>
<</if>>
<</if>>
<<set $uppercolour to $uppertowelcolour>>
<<set $upperintegrity to $uppertowelintegrity>>
<<set $upperexposed to 0>>
<<set $upperexposedbase to 0>>
<<set $uppertype to "normal">>
<<if $clothingchange isnot 1>>
<<if $upperset is $lowerset>>
<<set $clothingchange to 1>><<lowerstrip>><<lowerundress>>
<</if>>
<</if>>
<<set $clothingchange to 0>>
<<set $upperset to "upper">>
<<set $uppergender to "n">>
<</nobr>><</widget>>
<<widget "upperbikini">><<nobr>>
<<upperstrip>><<upperundress>>
<<set $upperclothes to "bikini top">>
<<set $uppervariable to "upperbikini">>
<<set $upperbikiniintegritymax to 20>>
<<set $upperintegritymax to $upperbikiniintegritymax>>
<<set $upperfabricstrength to 20>>
<<set $upperreveal to 900>>
<<set $upperword to "a">>
<<set $upperonepiece to 0>>
<<set $strap to 1>>
<<set $open to 1>>
<<set $upperstate to "midriff">>
<<set $upperstatetop to "chest">>
<<set $upperstatebase to "midriff">>
<<set $upperstatetopbase to "chest">>
<<set $upperplural to 0>>
<<if $upperbikininew is 1>><<set $upperbikininew to 0>><<set $upperbikiniintegrity to $upperbikiniintegritymax>><<set $upperbikinicolour to either("blue", "white", "red", "green", "black", "pink", "purple", "tangerine", "yellow")>>
<<if $upperbikinicolourchoice isnot 0>>
<<set $upperbikinicolour to $upperbikinicolourchoice>>
<</if>>
<</if>>
<<set $uppercolour to $upperbikinicolour>>
<<set $upperintegrity to $upperbikiniintegrity>>
<<set $upperexposed to 1>>
<<set $upperexposedbase to 1>>
<<set $uppertype to "swim">>
<<if $clothingchange isnot 1>>
<<if $upperset is $lowerset>>
<<set $clothingchange to 1>><<lowerstrip>><<lowerundress>>
<</if>>
<</if>>
<<set $clothingchange to 0>>
<<set $upperset to "upper">>
<<set $uppergender to "f">>
<</nobr>><</widget>>
<<widget "tshirt">><<nobr>>
<<upperstrip>><<upperundress>>
<<set $upperclothes to "t-shirt">>
<<set $uppervariable to "tshirt">>
<<set $tshirtintegritymax to 100>>
<<set $upperintegritymax to $tshirtintegritymax>>
<<set $upperfabricstrength to 20>>
<<set $upperreveal to 200>>
<<set $upperword to "a">>
<<set $upperonepiece to 0>>
<<set $strap to 0>>
<<set $open to 0>>
<<set $upperstate to "waist">>
<<set $upperstatetop to "chest">>
<<set $upperstatebase to "waist">>
<<set $upperstatetopbase to "chest">>
<<set $upperplural to 0>>
<<if $tshirtnew is 1>><<set $tshirtnew to 0>><<set $tshirtintegrity to $tshirtintegritymax>>
<<set $tshirtcolour to either("blue", "white", "red", "green", "black", "pink", "purple", "tangerine", "yellow")>>
<<if $tshirtcolourchoice isnot 0>>
<<set $tshirtcolour to $tshirtcolourchoice>>
<</if>>
<</if>>
<<set $uppercolour to $tshirtcolour>>
<<set $upperintegrity to $tshirtintegrity>>
<<set $upperexposed to 0>>
<<set $upperexposedbase to 0>>
<<set $uppertype to "normal">>
<<if $clothingchange isnot 1>>
<<if $upperset is $lowerset>>
<<set $clothingchange to 1>><<lowerstrip>><<lowerundress>>
<</if>>
<</if>>
<<set $clothingchange to 0>>
<<set $upperset to "upper">>
<<set $uppergender to "n">>
<</nobr>><</widget>>
<<widget "schoolshirt">><<nobr>>
<<upperstrip>><<upperundress>>
<<set $upperclothes to "school shirt">>
<<set $uppervariable to "schoolshirt">>
<<set $schoolshirtintegritymax to 200>>
<<set $upperintegritymax to $schoolshirtintegritymax>>
<<set $upperfabricstrength to 30>>
<<set $upperreveal to 100>>
<<set $upperword to "a">>
<<set $upperonepiece to 0>>
<<set $strap to 0>>
<<set $open to 0>>
<<set $upperstate to "waist">>
<<set $upperstatetop to "chest">>
<<set $upperstatebase to "waist">>
<<set $upperstatetopbase to "chest">>
<<set $upperplural to 0>>
<<if $schoolshirtnew is 1>><<set $schoolshirtnew to 0>>
<<set $schoolshirtintegrity to $schoolshirtintegritymax>>
<<set $schoolshirtcolour to either("blue", "white", "red", "green", "black", "pink", "purple", "tangerine", "yellow")>>
<<if $schoolshirtcolourchoice isnot 0>>
<<set $schoolshirtcolour to $schoolshirtcolourchoice>>
<</if>>
<</if>>
<<set $uppercolour to $schoolshirtcolour>>
<<set $upperintegrity to $schoolshirtintegrity>>
<<set $upperexposed to 0>>
<<set $upperexposedbase to 0>>
<<set $uppertype to "school">>
<<if $clothingchange isnot 1>>
<<if $upperset is $lowerset>>
<<set $clothingchange to 1>><<lowerstrip>><<lowerundress>>
<</if>>
<</if>>
<<set $clothingchange to 0>>
<<set $upperset to "upper">>
<<set $uppergender to "n">>
<</nobr>><</widget>>
<<widget "upperschoolswimsuit">><<nobr>>
<<upperstrip>><<upperundress>>
<<set $upperclothes to "school swimsuit">>
<<set $uppervariable to "upperschoolswimsuit">>
<<set $upperschoolswimsuitintegritymax to 40>>
<<set $upperintegritymax to $upperschoolswimsuitintegritymax>>
<<set $upperfabricstrength to 30>>
<<set $upperreveal to 600>>
<<set $upperword to "a">>
<<set $upperonepiece to 1>>
<<set $strap to 1>>
<<set $open to 1>>
<<set $upperstate to "waist">>
<<set $upperstatetop to "chest">>
<<set $upperstatebase to "waist">>
<<set $upperstatetopbase to "chest">>
<<set $upperplural to 0>>
<<if $upperschoolswimsuitnew is 1>><<set $upperschoolswimsuitnew to 0>><<set $upperschoolswimsuitintegrity to $upperschoolswimsuitintegritymax>>
<<set $schoolswimsuitcolour to either("blue", "white", "red", "green", "black", "pink", "purple", "tangerine", "yellow")>>
<<if $schoolswimsuitcolourchoice isnot 0>>
<<set $schoolswimsuitcolour to $schoolswimsuitcolourchoice>>
<</if>>
<</if>>
<<set $uppercolour to $schoolswimsuitcolour>>
<<set $upperintegrity to $upperschoolswimsuitintegrity>>
<<set $upperexposed to 1>>
<<set $upperexposedbase to 1>>
<<set $uppertype to "swim">>
<<if $clothingchange isnot 1>>
<<if $upperset is $lowerset>>
<<set $clothingchange to 1>><<lowerstrip>><<lowerundress>>
<</if>>
<</if>>
<<set $clothingchange to 0>>
<<set $upperset to "school swimsuit">>
<<set $uppergender to "f">>
<</nobr>><</widget>>
<<widget "upperplant">><<nobr>>
<<upperstrip>><<upperundress>>
<<set $upperclothes to "plant top">>
<<set $uppervariable to "upperplant">>
<<set $upperplantintegritymax to 10>>
<<set $upperintegritymax to $upperplantintegritymax>>
<<set $upperfabricstrength to 20>>
<<set $upperreveal to 900>>
<<set $upperword to "a">>
<<set $upperonepiece to 0>>
<<set $strap to 0>>
<<set $open to 1>>
<<set $upperstate to "midriff">>
<<set $upperstatetop to "chest">>
<<set $upperstatebase to "midriff">>
<<set $upperstatetopbase to "chest">>
<<set $upperplural to 0>>
<<if $upperplantnew is 1>><<set $upperplantnew to 0>><<set $upperplantintegrity to $upperplantintegritymax>>
<</if>>
<<set $upperplantcolour to "green">>
<<set $uppercolour to $upperplantcolour>>
<<set $upperintegrity to $upperplantintegrity>>
<<set $upperexposed to 1>>
<<set $upperexposedbase to 1>>
<<set $uppertype to "swim">>
<<if $clothingchange isnot 1>>
<<if $upperset is $lowerset>>
<<set $clothingchange to 1>><<lowerstrip>><<lowerundress>>
<</if>>
<</if>>
<<set $clothingchange to 0>>
<<set $upperset to "upper">>
<<set $uppergender to "n">>
<</nobr>><</widget>>
<<widget "uppereveninggown">><<nobr>>
<<upperstrip>><<upperundress>>
<<set $upperclothes to "evening gown">>
<<set $uppervariable to "uppereveninggown">>
<<set $uppereveninggownintegritymax to 200>>
<<set $upperintegritymax to $uppereveninggownintegritymax>>
<<set $upperfabricstrength to 30>>
<<set $upperreveal to 500>>
<<set $upperword to "a">>
<<set $upperonepiece to 1>>
<<set $strap to 1>>
<<set $open to 1>>
<<set $upperstate to "waist">>
<<set $upperstatetop to "chest">>
<<set $upperstatebase to "waist">>
<<set $upperstatetopbase to "chest">>
<<set $upperplural to 0>>
<<if $uppereveninggownnew is 1>><<set $uppereveninggownnew to 0>><<set $uppereveninggownintegrity to $uppereveninggownintegritymax>>
<<set $eveninggowncolour to either("blue", "white", "red", "green", "black", "pink", "purple", "tangerine", "yellow")>>
<<if $eveninggowncolourchoice isnot 0>>
<<set $eveninggowncolour to $eveninggowncolourchoice>>
<</if>>
<</if>>
<<set $uppercolour to $eveninggowncolour>>
<<set $upperintegrity to $uppereveninggownintegrity>>
<<set $upperexposed to 0>>
<<set $upperexposedbase to 0>>
<<set $uppertype to "normal">>
<<if $clothingchange isnot 1>>
<<if $upperset is $lowerset>>
<<set $clothingchange to 1>><<lowerstrip>><<lowerundress>>
<</if>>
<</if>>
<<set $clothingchange to 0>>
<<set $upperset to "evening gown">>
<<set $uppergender to "f">>
<</nobr>><</widget>>
<<widget "tanktop">><<nobr>>
<<upperstrip>><<upperundress>>
<<set $upperclothes to "tank top">>
<<set $uppervariable to "tanktop">>
<<set $tanktopintegritymax to 100>>
<<set $upperintegritymax to $tanktopintegritymax>>
<<set $upperfabricstrength to 20>>
<<set $upperreveal to 300>>
<<set $upperword to "a">>
<<set $upperonepiece to 0>>
<<set $strap to 0>>
<<set $open to 0>>
<<set $upperstate to "waist">>
<<set $upperstatetop to "chest">>
<<set $upperstatebase to "waist">>
<<set $upperstatetopbase to "chest">>
<<set $upperplural to 0>>
<<if $tanktopnew is 1>><<set $tanktopnew to 0>><<set $tanktopintegrity to $tanktopintegritymax>>
<<set $tanktopcolour to either("blue", "white", "red", "green", "black", "pink", "purple", "tangerine", "yellow")>>
<<if $tanktopcolourchoice isnot 0>>
<<set $tanktopcolour to $tanktopcolourchoice>>
<</if>>
<</if>>
<<set $uppercolour to $tanktopcolour>>
<<set $upperintegrity to $tanktopintegrity>>
<<set $upperexposed to 0>>
<<set $upperexposedbase to 0>>
<<set $uppertype to "normal">>
<<if $clothingchange isnot 1>>
<<if $upperset is $lowerset>>
<<set $clothingchange to 1>><<lowerstrip>><<lowerundress>>
<</if>>
<</if>>
<<set $clothingchange to 0>>
<<set $upperset to "upper">>
<<set $uppergender to "n">>
<</nobr>><</widget>>
<<widget "lowernaked">><<nobr>>
<<lowerstrip>>
<<if $lowertemp is "init">>
<<set $lowertemp to 1>>
<<elseif $lowertemp is 1>>
<<set $lowertemp to 0>>
<</if>>
<<set $lowerclothes to "naked">>
<<set $lowervariable to "naked">>
<<set $lowerintegrity to 0>>
<<set $lowerintegritymax to 0>>
<<set $lowerfabricstrength to 0>>
<<set $lowerreveal to 1000>>
<<set $lowerword to "n">>
<<set $loweronepiece to 0>>
<<set $lowerstate to 0>>
<<set $skirt to 0>>
<<set $skirtdown to 0>>
<<set $lowerstatebase to 0>>
<<set $lowervaginaexposed to 1>>
<<set $loweranusexposed to 1>>
<<set $lowerplural to 0>>
<<set $lowercolour to 0>>
<<set $lowerexposed to 2>>
<<set $lowerexposedbase to 2>>
<<set $lowervaginaexposedbase to 1>>
<<set $loweranusexposedbase to 1>>
<<set $lowertype to "naked">>
<<if $clothingchange isnot 1 and $ruined isnot 1>>
<<if $upperset is $lowerset>>
<<set $clothingchange to 1>><<uppernaked>>
<</if>>
<</if>>
<<set $clothingchange to 0>>
<<set $lowerset to "lower">>
<<set $lowergender to "n">>
<</nobr>><</widget>>
<<widget "lowersundress">><<nobr>>
<<lowerstrip>><<lowerundress>>
<<set $lowerclothes to "sundress skirt">>
<<set $lowervariable to "lowersundress">>
<<set $lowersundressintegritymax to 100>>
<<set $lowerintegritymax to $lowersundressintegritymax>>
<<set $fabricstrength to 30>>
<<set $lowerreveal to 200>>
<<set $lowerword to "a">>
<<set $loweronepiece to 1>>
<<set $lowerstate to "waist">>
<<set $skirt to 1>>
<<set $skirtdown to 1>>
<<set $lowerstatebase to "waist">>
<<set $lowervaginaexposed to 0>>
<<set $loweranusexposed to 0>>
<<set $lowerplural to 0>>
<<if $lowersundressnew is 1>><<set $lowersundressnew to 0>><<set $lowersundressintegrity to $lowersundressintegritymax>>
<</if>>
<<set $lowercolour to $sundresscolour>>
<<set $lowerintegrity to $lowersundressintegrity>>
<<set $lowerexposed to 0>>
<<set $lowerexposedbase to 0>>
<<set $lowervaginaexposedbase to 0>>
<<set $loweranusexposedbase to 0>>
<<set $lowertype to "normal">>
<<if $clothingchange isnot 1>>
<<if $upperset is $lowerset>>
<<set $clothingchange to 1>><<upperstrip>><<upperundress>>
<</if>>
<</if>>
<<set $clothingchange to 0>>
<<set $lowerset to "sundress">>
<<set $lowergender to "f">>
<</nobr>><</widget>>
<<widget "lowerpjs">><<nobr>>
<<lowerstrip>><<lowerundress>>
<<set $lowerclothes to "pyjama bottoms">>
<<set $lowervariable to "lowerpjs">>
<<set $lowerpjsintegritymax to 100>>
<<set $lowerintegritymax to $lowerpjsintegritymax>>
<<set $lowerfabricstrength to 20>>
<<set $lowerreveal to 100>>
<<set $lowerword to "n">>
<<set $loweronepiece to 0>>
<<set $lowerstate to "waist">>
<<set $skirt to 0>>
<<set $skirtdown to 0>>
<<set $lowerstatebase to "waist">>
<<set $lowervaginaexposed to 0>>
<<set $loweranusexposed to 0>>
<<set $lowerplural to 1>>
<<if $lowerpjsnew is 1>><<set $lowerpjsnew to 0>><<set $lowerpjsintegrity to $lowerpjsintegritymax>><<set $lowerpjscolour to either("blue", "white", "red", "green", "black", "pink", "purple", "tangerine", "yellow")>>
<<if $lowerpjscolourchoice isnot 0>>
<<set $lowerpjscolour to $lowerpjscolourchoice>>
<</if>>
<</if>>
<<set $lowercolour to $lowerpjscolour>>
<<set $lowerintegrity to $lowerpjsintegrity>>
<<set $lowerexposed to 0>>
<<set $lowerexposedbase to 0>>
<<set $lowervaginaexposedbase to 0>>
<<set $loweranusexposedbase to 0>>
<<set $lowertype to "sleep">>
<<if $clothingchange isnot 1>>
<<if $upperset is $lowerset>>
<<set $clothingchange to 1>><<upperstrip>><<upperundress>>
<</if>>
<</if>>
<<set $clothingchange to 0>>
<<set $lowerset to "lower">>
<<set $lowergender to "n">>
<</nobr>><</widget>>
<<widget "lowertowel">><<nobr>>
<<lowerstrip>><<lowerundress>>
<<set $lowerclothes to "towel">>
<<set $lowervariable to "lowertowel">>
<<set $lowertowelintegritymax to 10>>
<<set $lowerintegritymax to $lowertowelintegritymax>>
<<set $lowerfabricstrength to 20>>
<<set $lowerreveal to 800>>
<<set $lowerword to "n">>
<<set $loweronepiece to 0>>
<<set $lowerstate to "waist">>
<<set $skirt to 1>>
<<set $skirtdown to 1>>
<<set $lowerstatebase to "waist">>
<<set $lowervaginaexposed to 0>>
<<set $loweranusexposed to 0>>
<<set $lowerplural to 0>>
<<if $lowertowelnew is 1>><<set $lowertowelnew to 0>><<set $lowertowelintegrity to $lowertowelintegritymax>><<set $lowertowelcolour to either("blue", "white", "red", "green", "black", "pink", "purple", "tangerine", "yellow")>>
<<if $lowertowelcolourchoice isnot 0>>
<<set $lowertowelcolour to $lowertowelcolourchoice>>
<<set $lowertowelcolourchoice to 0>>
<</if>>
<</if>>
<<set $lowercolour to $lowertowelcolour>>
<<set $lowerintegrity to $lowertowelintegrity>>
<<set $lowerexposed to 0>>
<<set $lowerexposedbase to 0>>
<<set $lowervaginaexposedbase to 0>>
<<set $loweranusexposedbase to 0>>
<<set $lowertype to "normal">>
<<if $clothingchange isnot 1>>
<<if $upperset is $lowerset>>
<<set $clothingchange to 1>><<upperstrip>><<upperundress>>
<</if>>
<</if>>
<<set $clothingchange to 0>>
<<set $lowerset to "lower">>
<<set $lowergender to "n">>
<</nobr>><</widget>>
<<widget "lowerbikini">><<nobr>>
<<lowerstrip>><<lowerundress>>
<<set $lowerclothes to "bikini bottoms">>
<<set $lowervariable to "lowerbikini">>
<<set $lowerbikiniintegritymax to 20>>
<<set $lowerintegritymax to $lowerbikiniintegritymax>>
<<set $lowerfabricstrength to 20>>
<<set $lowerreveal to 900>>
<<set $lowerword to "n">>
<<set $loweronepiece to 0>>
<<set $lowerstate to "waist">>
<<set $skirt to 0>>
<<set $skirtdown to 0>>
<<set $lowerstatebase to "waist">>
<<set $lowervaginaexposed to 0>>
<<set $loweranusexposed to 0>>
<<set $lowerplural to 1>>
<<if $lowerbikininew is 1>><<set $lowerbikininew to 0>><<set $lowerbikiniintegrity to $lowerbikiniintegritymax>><<set $lowerbikinicolour to either("blue", "white", "red", "green", "black", "pink", "purple", "tangerine", "yellow")>>
<<if $lowerbikinicolourchoice isnot 0>>
<<set $lowerbikinicolour to $lowerbikinicolourchoice>>
<</if>>
<</if>>
<<set $lowercolour to $lowerbikinicolour>>
<<set $lowerintegrity to $lowerbikiniintegrity>>
<<set $lowerexposed to 1>>
<<set $lowerexposedbase to 1>>
<<set $lowervaginaexposedbase to 0>>
<<set $loweranusexposedbase to 0>>
<<set $lowertype to "swim">>
<<if $clothingchange isnot 1>>
<<if $upperset is $lowerset>>
<<set $clothingchange to 1>><<upperstrip>><<upperundress>>
<</if>>
<</if>>
<<set $clothingchange to 0>>
<<set $lowerset to "lower">>
<<if $undertype isnot "chastity">>
<<underundress>>
<</if>>
<<set $lowergender to "f">>
<</nobr>><</widget>>
<<widget "waistapron">><<nobr>>
<<lowerstrip>><<lowerundress>>
<<set $lowerclothes to "waist apron">>
<<set $lowervariable to "waistapron">>
<<set $waistapronintegritymax to 10>>
<<set $lowerintegritymax to $waistapronintegritymax>>
<<set $lowerfabricstrength to 20>>
<<set $lowerreveal to 800>>
<<set $lowerword to "a">>
<<set $loweronepiece to 0>>
<<set $lowerstate to "waist">>
<<set $skirt to 1>>
<<set $skirtdown to 1>>
<<set $lowerstatebase to "waist">>
<<set $lowervaginaexposed to 1>>
<<set $loweranusexposed to 1>>
<<set $lowerplural to 0>>
<<if $waistapronnew is 1>><<set $waistapronnew to 0>><<set $waistapronintegrity to $waistapronintegritymax>><<set $waistaproncolour to either("blue", "white", "red", "green", "black", "pink", "purple", "tangerine", "yellow")>>
<<if $waistaproncolourchoice isnot 0>>
<<set $waistaproncolour to $waistaproncolourchoice>>
<</if>>
<</if>>
<<set $lowercolour to $waistaproncolour>>
<<set $lowerintegrity to $waistapronintegrity>>
<<set $lowerexposed to 1>>
<<set $lowerexposedbase to 1>>
<<set $lowervaginaexposedbase to 1>>
<<set $loweranusexposedbase to 1>>
<<set $lowertype to "normal">>
<<if $clothingchange isnot 1>>
<<if $upperset is $lowerset>>
<<set $clothingchange to 1>><<upperstrip>><<upperundress>>
<</if>>
<</if>>
<<set $clothingchange to 0>>
<<set $lowerset to "lower">>
<<set $lowergender to "n">>
<</nobr>><</widget>>
<<widget "shorts">><<nobr>>
<<lowerstrip>><<lowerundress>>
<<set $lowerclothes to "shorts">>
<<set $lowervariable to "shorts">>
<<set $shortsintegritymax to 120>>
<<set $lowerintegritymax to $shortsintegritymax>>
<<set $lowerfabricstrength to 20>>
<<set $lowerreveal to 300>>
<<set $lowerword to "n">>
<<set $loweronepiece to 0>>
<<set $lowerstate to "waist">>
<<set $skirt to 0>>
<<set $skirtdown to 0>>
<<set $lowerstatebase to "waist">>
<<set $lowervaginaexposed to 0>>
<<set $loweranusexposed to 0>>
<<set $lowerplural to 1>>
<<if $shortsnew is 1>><<set $shortsnew to 0>><<set $shortsintegrity to $shortsintegritymax>><<set $shortscolour to either("blue", "white", "red", "green", "black", "pink", "purple", "tangerine", "yellow")>>
<<if $shortscolourchoice isnot 0>>
<<set $shortscolour to $shortscolourchoice>>
<</if>>
<</if>>
<<set $lowercolour to $shortscolour>>
<<set $lowerintegrity to $shortsintegrity>>
<<set $lowerexposed to 0>>
<<set $lowerexposedbase to 0>>
<<set $lowervaginaexposedbase to 0>>
<<set $loweranusexposedbase to 0>>
<<set $lowertype to "normal">>
<<if $clothingchange isnot 1>>
<<if $upperset is $lowerset>>
<<set $clothingchange to 1>><<upperstrip>><<upperundress>>
<</if>>
<</if>>
<<set $clothingchange to 0>>
<<set $lowerset to "lower">>
<<set $lowergender to "n">>
<</nobr>><</widget>>
<<widget "schoolshorts">><<nobr>>
<<lowerstrip>><<lowerundress>>
<<set $lowerclothes to "school shorts">>
<<set $lowervariable to "schoolshorts">>
<<set $schoolshortsintegritymax to 160>>
<<set $lowerintegritymax to $schoolshortsintegritymax>>
<<set $lowerfabricstrength to 20>>
<<set $lowerreveal to 200>>
<<set $lowerword to "n">>
<<set $loweronepiece to 0>>
<<set $lowerstate to "waist">>
<<set $skirt to 0>>
<<set $skirtdown to 0>>
<<set $lowerstatebase to "waist">>
<<set $lowervaginaexposed to 0>>
<<set $loweranusexposed to 0>>
<<set $lowerplural to 1>>
<<if $schoolshortsnew is 1>><<set $schoolshortsnew to 0>><<set $schoolshortsintegrity to $schoolshortsintegritymax>><<set $schoolshortscolour to either("blue", "white", "red", "green", "black", "pink", "purple", "tangerine", "yellow")>>
<<if $schoolshortscolourchoice isnot 0>>
<<set $schoolshortscolour to $schoolshortscolourchoice>>
<</if>>
<</if>>
<<set $lowercolour to $schoolshortscolour>>
<<set $lowerintegrity to $schoolshortsintegrity>>
<<set $lowerexposed to 0>>
<<set $lowerexposedbase to 0>>
<<set $lowervaginaexposedbase to 0>>
<<set $loweranusexposedbase to 0>>
<<set $lowertype to "school">>
<<if $clothingchange isnot 1>>
<<if $upperset is $lowerset>>
<<set $clothingchange to 1>><<upperstrip>><<upperundress>>
<</if>>
<</if>>
<<set $clothingchange to 0>>
<<set $lowerset to "lower">>
<<set $lowergender to "m">>
<</nobr>><</widget>>
<<widget "schoolskirt">><<nobr>>
<<lowerstrip>><<lowerundress>>
<<set $lowerclothes to "school skirt">>
<<set $lowervariable to "schoolskirt">>
<<set $schoolskirtintegritymax to 160>>
<<set $lowerintegritymax to $schoolskirtintegritymax>>
<<set $lowerfabricstrength to 20>>
<<set $lowerreveal to 200>>
<<set $lowerword to "a">>
<<set $loweronepiece to 0>>
<<set $lowerstate to "waist">>
<<set $skirt to 1>>
<<set $skirtdown to 1>>
<<set $lowerstatebase to "waist">>
<<set $lowervaginaexposed to 0>>
<<set $loweranusexposed to 0>>
<<set $lowerplural to 0>>
<<if $schoolskirtnew is 1>><<set $schoolskirtnew to 0>><<set $schoolskirtintegrity to $schoolskirtintegritymax>><<set $schoolskirtcolour to either("blue", "white", "red", "green", "black", "pink", "purple", "tangerine", "yellow")>>
<<if $schoolskirtcolourchoice isnot 0>>
<<set $schoolskirtcolour to $schoolskirtcolourchoice>>
<</if>>
<</if>>
<<set $lowercolour to $schoolskirtcolour>>
<<set $lowerintegrity to $schoolskirtintegrity>>
<<set $lowerexposed to 0>>
<<set $lowerexposedbase to 0>>
<<set $lowervaginaexposedbase to 0>>
<<set $loweranusexposedbase to 0>>
<<set $lowertype to "school">>
<<if $clothingchange isnot 1>>
<<if $upperset is $lowerset>>
<<set $clothingchange to 1>><<upperstrip>><<upperundress>>
<</if>>
<</if>>
<<set $clothingchange to 0>>
<<set $lowerset to "lower">>
<<set $lowergender to "f">>
<</nobr>><</widget>>
<<widget "lowerschoolswimsuit">><<nobr>>
<<lowerstrip>><<lowerundress>>
<<set $lowerclothes to "school swimsuit bottom">>
<<set $lowervariable to "lowerschoolswimsuit">>
<<set $lowerschoolswimsuitintegritymax to 40>>
<<set $lowerintegritymax to $lowerschoolswimsuitintegritymax>>
<<set $fabricstrength to 30>>
<<set $lowerreveal to 600>>
<<set $lowerword to "a">>
<<set $loweronepiece to 1>>
<<set $lowerstate to "waist">>
<<set $skirt to 0>>
<<set $skirtdown to 0>>
<<set $lowerstatebase to "waist">>
<<set $lowervaginaexposed to 0>>
<<set $loweranusexposed to 0>>
<<set $lowerplural to 0>>
<<if $lowerschoolswimsuitnew is 1>><<set $lowerschoolswimsuitnew to 0>><<set $lowerschoolswimsuitintegrity to $lowerschoolswimsuitintegritymax>>
<</if>>
<<set $lowercolour to $schoolswimsuitcolour>>
<<set $lowerintegrity to $lowerschoolswimsuitintegrity>>
<<set $lowerexposed to 1>>
<<set $lowerexposedbase to 1>>
<<set $lowervaginaexposedbase to 0>>
<<set $loweranusexposedbase to 0>>
<<set $lowertype to "swim">>
<<if $clothingchange isnot 1>>
<<if $upperset is $lowerset>>
<<set $clothingchange to 1>><<upperstrip>><<upperundress>>
<</if>>
<</if>>
<<set $clothingchange to 0>>
<<set $lowerset to "school swimsuit">>
<<if $undertype isnot "chastity">>
<<underundress>>
<</if>>
<<set $lowergender to "f">>
<</nobr>><</widget>>
<<widget "schoolswimshorts">><<nobr>>
<<lowerstrip>><<lowerundress>>
<<set $lowerclothes to "school swim shorts">>
<<set $lowervariable to "schoolswimshorts">>
<<set $schoolswimshortsintegritymax to 40>>
<<set $lowerintegritymax to $schoolswimshortsintegritymax>>
<<set $lowerfabricstrength to 20>>
<<set $lowerreveal to 600>>
<<set $lowerword to "n">>
<<set $loweronepiece to 0>>
<<set $lowerstate to "waist">>
<<set $skirt to 0>>
<<set $skirtdown to 0>>
<<set $lowerstatebase to "waist">>
<<set $lowervaginaexposed to 0>>
<<set $loweranusexposed to 0>>
<<set $lowerplural to 1>>
<<if $schoolswimshortsnew is 1>><<set $schoolswimshortsnew to 0>><<set $schoolswimshortsintegrity to $schoolswimshortsintegritymax>><<set $schoolswimshortscolour to either("blue", "white", "red", "green", "black", "pink", "purple", "tangerine", "yellow")>>
<<if $schoolswimshortscolourchoice isnot 0>>
<<set $schoolswimshortscolour to $schoolswimshortscolourchoice>>
<</if>>
<</if>>
<<set $lowercolour to $schoolswimshortscolour>>
<<set $lowerintegrity to $schoolswimshortsintegrity>>
<<set $lowerexposed to 1>>
<<set $lowerexposedbase to 1>>
<<set $lowervaginaexposedbase to 0>>
<<set $loweranusexposedbase to 0>>
<<set $lowertype to "swim">>
<<if $clothingchange isnot 1>>
<<if $upperset is $lowerset>>
<<set $clothingchange to 1>><<upperstrip>><<upperundress>>
<</if>>
<</if>>
<<set $clothingchange to 0>>
<<set $lowerset to "lower">>
<<if $undertype isnot "chastity">>
<<underundress>>
<</if>>
<<set $lowergender to "m">>
<</nobr>><</widget>>
<<widget "lowerplant">><<nobr>>
<<lowerstrip>><<lowerundress>>
<<set $lowerclothes to "plant skirt">>
<<set $lowervariable to "lowerplant">>
<<set $lowerplantintegritymax to 10>>
<<set $lowerintegritymax to $lowerplantintegritymax>>
<<set $lowerfabricstrength to 20>>
<<set $lowerreveal to 900>>
<<set $lowerword to "a">>
<<set $loweronepiece to 0>>
<<set $lowerstate to "waist">>
<<set $skirt to 1>>
<<set $skirtdown to 1>>
<<set $lowerstatebase to "waist">>
<<set $lowervaginaexposed to 1>>
<<set $loweranusexposed to 1>>
<<set $lowerplural to 0>>
<<if $lowerplantnew is 1>><<set $lowerplantnew to 0>><<set $lowerplantintegrity to $lowerplantintegritymax>><<set $lowerplantcolour to "green">>
<</if>>
<<set $lowercolour to $lowerplantcolour>>
<<set $lowerintegrity to $lowerplantintegrity>>
<<set $lowerexposed to 1>>
<<set $lowerexposedbase to 1>>
<<set $lowervaginaexposedbase to 1>>
<<set $loweranusexposedbase to 1>>
<<set $lowertype to "swim">>
<<if $clothingchange isnot 1>>
<<if $upperset is $lowerset>>
<<set $clothingchange to 1>><<upperstrip>><<upperundress>>
<</if>>
<</if>>
<<set $clothingchange to 0>>
<<set $lowerset to "lower">>
<<if $undertype isnot "chastity">>
<<underundress>>
<</if>>
<<set $lowergender to "n">>
<</nobr>><</widget>>
<<widget "lowereveninggown">><<nobr>>
<<lowerstrip>><<lowerundress>>
<<set $lowerclothes to "evening gown skirt">>
<<set $lowervariable to "lowereveninggown">>
<<set $lowereveninggownintegritymax to 200>>
<<set $lowerintegritymax to $lowereveninggownintegritymax>>
<<set $fabricstrength to 30>>
<<set $lowerreveal to 200>>
<<set $lowerword to "a">>
<<set $loweronepiece to 1>>
<<set $lowerstate to "waist">>
<<set $skirt to 1>>
<<set $skirtdown to 1>>
<<set $lowerstatebase to "waist">>
<<set $lowervaginaexposed to 0>>
<<set $loweranusexposed to 0>>
<<set $lowerplural to 0>>
<<if $lowereveninggownnew is 1>><<set $lowereveninggownnew to 0>><<set $lowereveninggownintegrity to $lowereveninggownintegritymax>>
<</if>>
<<set $lowercolour to $eveninggowncolour>>
<<set $lowerintegrity to $lowereveninggownintegrity>>
<<set $lowerexposed to 0>>
<<set $lowerexposedbase to 0>>
<<set $lowervaginaexposedbase to 0>>
<<set $loweranusexposedbase to 0>>
<<set $lowertype to "normal">>
<<if $clothingchange isnot 1>>
<<if $upperset is $lowerset>>
<<set $clothingchange to 1>><<upperstrip>><<upperundress>>
<</if>>
<</if>>
<<set $clothingchange to 0>>
<<set $lowerset to "evening gown">>
<<set $lowergender to "f">>
<</nobr>><</widget>>
<<widget "undernaked">><<nobr>>
<<if $undertype isnot "chastity">>
<<understrip>>
<<if $undertemp is "init">>
<<set $undertemp to 1>>
<<elseif $undertemp is 1>>
<<set $undertemp to 0>>
<</if>>
<<set $underclothes to "naked">>
<<set $undervariable to "naked">>
<<set $underintegrity to 0>>
<<set $underintegritymax to 0>>
<<set $underfabricstrength to 0>>
<<set $underreveal to 1000>>
<<set $underword to "n">>
<<set $understate to 0>>
<<set $understatebase to 0>>
<<set $undervaginaexposed to 1>>
<<set $underanusexposed to 1>>
<<set $underplural to 0>>
<<set $undercolour to 0>>
<<set $underexposed to 1>>
<<set $underexposedbase to 1>>
<<set $undervaginaexposedbase to 1>>
<<set $underanusexposedbase to 1>>
<<set $undertype to "naked">>
<<set $undergender to "n">>
<</if>>
<</nobr>><</widget>>
<<widget "plainpanties">><<nobr>>
<<if $undertype isnot "chastity">>
<<understrip>><<underundress>>
<<set $underclothes to "plain panties">>
<<set $undervariable to "plainpanties">>
<<set $plainpantiesintegritymax to 100>>
<<set $underintegritymax to $plainpantiesintegritymax>>
<<set $underfabricstrength to 15>>
<<set $underreveal to 200>>
<<set $underword to "n">>
<<set $understate to "waist">>
<<set $understatebase to "waist">>
<<set $undervaginaexposed to 0>>
<<set $underanusexposed to 0>>
<<set $underplural to 1>>
<<if $plainpantiesnew is 1>><<set $plainpantiesnew to 0>><<set $plainpantiesintegrity to $plainpantiesintegritymax>><<set $plainpantiescolour to either("blue", "white", "red", "green", "black", "pink", "purple", "tangerine", "yellow")>>
<<if $plainpantiescolourchoice isnot 0>>
<<set $plainpantiescolour to $plainpantiescolourchoice>>
<</if>>
<</if>>
<<set $undercolour to $plainpantiescolour>>
<<set $underintegrity to $plainpantiesintegrity>>
<<set $underexposed to 0>>
<<set $underexposedbase to 0>>
<<set $undervaginaexposedbase to 0>>
<<set $underanusexposedbase to 0>>
<<set $undertype to "normal">>
<<if $lowertype is "swim">>
<<if $upperset is $lowerset>>
<<uppernaked>>
<</if>>
<<lowerundress>>
<</if>>
<<set $undergender to "f">>
<</if>>
<</nobr>><</widget>>
<<widget "lacepanties">><<nobr>>
<<if $undertype isnot "chastity">>
<<understrip>><<underundress>>
<<set $underclothes to "lace panties">>
<<set $undervariable to "lacepanties">>
<<set $lacepantiesintegritymax to 60>>
<<set $underintegritymax to $lacepantiesintegritymax>>
<<set $underfabricstrength to 15>>
<<set $underreveal to 400>>
<<set $underword to "n">>
<<set $understate to "waist">>
<<set $understatebase to "waist">>
<<set $undervaginaexposed to 0>>
<<set $underanusexposed to 0>>
<<set $underplural to 1>>
<<if $lacepantiesnew is 1>><<set $lacepantiesnew to 0>><<set $lacepantiesintegrity to $lacepantiesintegritymax>><<set $lacepantiescolour to either("blue", "white", "red", "green", "black", "pink", "purple", "tangerine", "yellow")>>
<<if $lacepantiescolourchoice isnot 0>>
<<set $lacepantiescolour to $lacepantiescolourchoice>>
<</if>>
<</if>>
<<set $undercolour to $lacepantiescolour>>
<<set $underintegrity to $lacepantiesintegrity>>
<<set $underexposed to 0>>
<<set $underexposedbase to 0>>
<<set $undervaginaexposedbase to 0>>
<<set $underanusexposedbase to 0>>
<<set $undertype to "normal">>
<<if $lowertype is "swim">>
<<if $upperset is $lowerset>>
<<uppernaked>>
<</if>>
<<lowerundress>>
<</if>>
<<set $undergender to "f">>
<</if>>
<</nobr>><</widget>>
<<widget "yfronts">><<nobr>>
<<if $undertype isnot "chastity">>
<<understrip>><<underundress>>
<<set $underclothes to "Y fronts">>
<<set $undervariable to "yfronts">>
<<set $yfrontsintegritymax to 100>>
<<set $underintegritymax to $yfrontsintegritymax>>
<<set $underfabricstrength to 15>>
<<set $underreveal to 200>>
<<set $underword to "n">>
<<set $understate to "waist">>
<<set $understatebase to "waist">>
<<set $undervaginaexposed to 0>>
<<set $underanusexposed to 0>>
<<set $underplural to 1>>
<<if $yfrontsnew is 1>><<set $yfrontsnew to 0>><<set $yfrontsintegrity to $yfrontsintegritymax>><<set $yfrontscolour to either("blue", "white", "red", "green", "black", "pink", "purple", "tangerine", "yellow")>>
<<if $yfrontscolourchoice isnot 0>>
<<set $yfrontscolour to $yfrontscolourchoice>>
<</if>>
<</if>>
<<set $undercolour to $yfrontscolour>>
<<set $underintegrity to $yfrontsintegrity>>
<<set $underexposed to 0>>
<<set $underexposedbase to 0>>
<<set $undervaginaexposedbase to 0>>
<<set $underanusexposedbase to 0>>
<<set $undertype to "normal">>
<<if $lowertype is "swim">>
<<if $upperset is $lowerset>>
<<uppernaked>>
<</if>>
<<lowerundress>>
<</if>>
<<set $undergender to "m">>
<</if>>
<</nobr>><</widget>>
<<widget "chastitybelt">><<nobr>>
<<if $undertype isnot "chastity">>
<<understrip>><<underundress>>
<<set $underclothes to "chastity belt">>
<<set $undervariable to "chastitybelt">>
<<set $chastitybeltintegritymax to 2000>>
<<set $underintegritymax to $chastitybeltintegritymax>>
<<set $underfabricstrength to 15>>
<<set $underreveal to 1000>>
<<set $underword to "a">>
<<set $understate to "chastity">>
<<set $understatebase to "chastity">>
<<set $undervaginaexposed to 0>>
<<set $undervaginaexposedbase to 0>>
<<if $analshield is 1>>
<<set $underanusexposed to 0>>
<<set $underanusexposedbase to 0>>
<<else>>
<<set $underanusexposed to 1>>
<<set $underanusexposedbase to 1>>
<</if>>
<<set $underplural to 0>>
<<if $chastitybeltnew is 1>><<set $chastitybeltnew to 0>><<set $chastitybeltintegrity to $chastitybeltintegritymax>>
<</if>>
<<set $undercolour to "restrictive">>
<<set $underintegrity to $chastitybeltintegrity>>
<<set $underexposed to 1>>
<<set $underexposedbase to 1>>
<<set $undertype to "chastity">>
<<set $undergender to "n">>
<</if>>
<</nobr>><</widget>>
<<widget "tights">><<nobr>>
<<if $undertype isnot "chastity">>
<<understrip>><<underundress>>
<<set $underclothes to "tights">>
<<set $undervariable to "tights">>
<<set $tightsintegritymax to 120>>
<<set $underintegritymax to $tightsintegritymax>>
<<set $underfabricstrength to 5>>
<<set $underreveal to 800>>
<<set $underword to "n">>
<<set $understate to "waist">>
<<set $understatebase to "waist">>
<<set $undervaginaexposed to 0>>
<<set $underanusexposed to 0>>
<<set $underplural to 1>>
<<if $tightsnew is 1>><<set $tightsnew to 0>><<set $tightsintegrity to $tightsintegritymax>><<set $tightscolour to "sheer">>
<<if $tightscolourchoice isnot 0>>
<<set $tightscolour to $tightscolourchoice>>
<</if>>
<</if>>
<<set $undercolour to $tightscolour>>
<<set $underintegrity to $tightsintegrity>>
<<set $underexposed to 1>>
<<set $underexposedbase to 1>>
<<set $undervaginaexposedbase to 0>>
<<set $underanusexposedbase to 0>>
<<set $undertype to "normal">>
<<if $lowertype is "swim">>
<<if $upperset is $lowerset>>
<<uppernaked>>
<</if>>
<<lowerundress>>
<</if>>
<<set $undergender to "f">>
<</if>>
<</nobr>><</widget>>
<<widget "upperstrip">><<nobr>>
<<set $upperlast to $upperclothes>>
<<if $uppertemp is 1>>
<<else>>
<<if $upperclothes is "sundress">>
<<set $uppersundressintegrity to $upperintegrity>>
<<set $upperoff to "sundress">>
<</if>>
<<if $upperclothes is "pyjama shirt">>
<<set $upperpjsintegrity to $upperintegrity>>
<<set $upperoff to "pyjama shirt">>
<</if>>
<<if $upperclothes is "towel">>
<<set $uppertowelintegrity to $upperintegrity>>
<<set $upperoff to "towel">>
<</if>>
<<if $upperclothes is "bikini top">>
<<set $upperbikiniintegrity to $upperintegrity>>
<<set $upperoff to "bikini top">>
<</if>>
<<if $upperclothes is "t-shirt">>
<<set $tshirtintegrity to $upperintegrity>>
<<set $upperoff to "t-shirt">>
<</if>>
<<if $upperclothes is "school shirt">>
<<set $schoolshirtintegrity to $upperintegrity>>
<<set $upperoff to "school shirt">>
<</if>>
<<if $upperclothes is "school swimsuit">>
<<set $upperschoolswimsuitintegrity to $upperintegrity>>
<<set $upperoff to "school swimsuit">>
<</if>>
<<if $upperclothes is "plant top">>
<<set $upperplantintegrity to $upperintegrity>>
<<set $upperoff to "plant top">>
<</if>>
<<if $upperclothes is "evening gown">>
<<set $uppereveninggownintegrity to $upperintegrity>>
<<set $upperoff to "evening gown">>
<</if>>
<<if $upperclothes is "tank top">>
<<set $tanktopintegrity to $upperintegrity>>
<<set $upperoff to "tank top">>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "lowerstrip">><<nobr>>
<<set $lowerlast to $lowerclothes>>
<<if $lowertemp is 1>>
<<else>>
<<if $lowerclothes is "sundress skirt">>
<<set $lowersundressintegrity to $lowerintegrity>>
<<set $loweroff to "sundress skirt">>
<</if>>
<<if $lowerclothes is "pyjama bottoms">>
<<set $lowerpjsintegrity to $lowerintegrity>>
<<set $loweroff to "pyjama bottoms">>
<</if>>
<<if $lowerclothes is "towel">>
<<set $lowertowelintegrity to $lowerintegrity>>
<<set $loweroff to "towel">>
<</if>>
<<if $lowerclothes is "bikini bottoms">>
<<set $lowerbikiniintegrity to $lowerintegrity>>
<<set $loweroff to "bikini bottoms">>
<</if>>
<<if $lowerclothes is "waist apron">>
<<set $waistapronintegrity to $lowerintegrity>>
<<set $loweroff to "waist apron">>
<</if>>
<<if $lowerclothes is "shorts">>
<<set $shortsintegrity to $lowerintegrity>>
<<set $loweroff to "shorts">>
<</if>>
<<if $lowerclothes is "school shorts">>
<<set $schoolshortsintegrity to $lowerintegrity>>
<<set $loweroff to "school shorts">>
<</if>>
<<if $lowerclothes is "school skirt">>
<<set $schoolskirtintegrity to $lowerintegrity>>
<<set $loweroff to "school skirt">>
<</if>>
<<if $lowerclothes is "school swimsuit bottom">>
<<set $lowerschoolswimsuitintegrity to $lowerintegrity>>
<<set $loweroff to "school swimsuit bottom">>
<</if>>
<<if $lowerclothes is "school swim shorts">>
<<set $schoolswimshortsintegrity to $lowerintegrity>>
<<set $loweroff to "school swim shorts">>
<</if>>
<<if $lowerclothes is "plant skirt">>
<<set $lowerplantintegrity to $lowerintegrity>>
<<set $loweroff to "plant skirt">>
<</if>>
<<if $lowerclothes is "evening gown skirt">>
<<set $lowereveninggownintegrity to $lowerintegrity>>
<<set $loweroff to "evening gown skirt">>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "understrip">><<nobr>>
<<set $underlast to $underclothes>>
<<if $undertemp is 1>>
<<else>>
<<if $underclothes is "plain panties">>
<<set $plainpantiesintegrity to $underintegrity>>
<<set $underoff to "plain panties">>
<</if>>
<<if $underclothes is "lace panties">>
<<set $lacepantiesintegrity to $underintegrity>>
<<set $underoff to "lace panties">>
<</if>>
<<if $underclothes is "Y fronts">>
<<set $yfrontsintegrity to $underintegrity>>
<<set $underoff to "Y fronts">>
<</if>>
<<if $underclothes is "chastity belt">>
<<set $chastitybeltintegrity to $underintegrity>>
<<set $underoff to "chastity belt">>
<</if>>
<<if $underclothes is "tights">>
<<set $tightsintegrity to $underintegrity>>
<<set $underoff to "tights">>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "upperruined">><<nobr>><<set $ruined to 1>><<set $eventskipoverrule to 1>><<set $uncladupper to 0>><<set $uncladoutfit to 0>>
<<if $uppertemp is 1>>
<<uppernaked>>
<<set $upperoff to 0>>
<<else>>
<<if $upperclothes is "sundress">>
<<set $uppersundressno to 0>>
<<uppernaked>>
<<if $clothingrebuy is 1>>
<<if $money gte 750>>
<<set $clothingrebuytext to 1>>
<<set $uppersundressnew to 1>>
<<set $uppersundressno to 1>>
<<set $lowersundressnew to 1>>
<<set $lowersundressno to 1>>
<<set $money -= 750>>
<<else>>
<<set $clothingrebuyfailedtext to 1>>
<</if>>
<</if>>
<<set $upperoff to 0>>
<</if>>
<<if $upperclothes is "pyjama shirt">>
<<set $upperpjsno to 0>>
<<uppernaked>>
<<if $clothingrebuy is 1>>
<<if $money gte 1000>>
<<set $clothingrebuytext to 1>>
<<set $upperpjsnew to 1>>
<<set $upperpjsno to 1>>
<<set $money -= 1000>>
<<else>>
<<set $clothingrebuyfailedtext to 1>>
<</if>>
<</if>>
<<set $upperoff to 0>>
<</if>>
<<if $upperclothes is "towel">>
<<set $uppertowelno to 0>>
<<uppernaked>>
<<set $upperoff to 0>>
<</if>>
<<if $upperclothes is "bikini top">>
<<set $upperbikinino to 0>>
<<uppernaked>>
<<if $clothingrebuy is 1>>
<<if $money gte 1000>>
<<set $clothingrebuytext to 1>>
<<set $upperbikininew to 1>>
<<set $upperbikinino to 1>>
<<set $money -= 1000>>
<<else>>
<<set $clothingrebuyfailedtext to 1>>
<</if>>
<</if>>
<<set $upperoff to 0>>
<</if>>
<<if $upperclothes is "t-shirt">>
<<set $tshirtno to 0>>
<<uppernaked>>
<<if $clothingrebuy is 1>>
<<if $money gte 1000>>
<<set $clothingrebuytext to 1>>
<<set $tshirtnew to 1>>
<<set $tshirtno to 1>>
<<set $money -= 1000>>
<<else>>
<<set $clothingrebuyfailedtext to 1>>
<</if>>
<</if>>
<<set $upperoff to 0>>
<</if>>
<<if $upperclothes is "school shirt">>
<<set $schoolshirtno to 0>>
<<uppernaked>>
<<if $clothingrebuy is 1>>
<<if $money gte 2500>>
<<set $clothingrebuytext to 1>>
<<set $schoolshirtnew to 1>>
<<set $schoolshirtno to 1>>
<<set $money -= 2500>>
<<else>>
<<set $clothingrebuyfailedtext to 1>>
<</if>>
<</if>>
<<set $upperoff to 0>>
<</if>>
<<if $upperclothes is "school swimsuit">>
<<set $upperschoolswimsuitno to 0>>
<<uppernaked>>
<<if $clothingrebuy is 1>>
<<if $money gte 750>>
<<set $clothingrebuytext to 1>>
<<set $upperschoolswimsuitnew to 1>>
<<set $upperschoolswimsuitno to 1>>
<<set $lowerschoolswimsuitnew to 1>>
<<set $lowerschoolswimsuitno to 1>>
<<set $money -= 750>>
<<else>>
<<set $clothingrebuyfailedtext to 1>>
<</if>>
<</if>>
<<set $upperoff to 0>>
<</if>>
<<if $upperclothes is "plant top">>
<<set $upperplantno to 0>>
<<uppernaked>>
<<set $upperoff to 0>>
<</if>>
<<if $upperclothes is "evening gown">>
<<set $uppereveninggownno to 0>>
<<uppernaked>>
<<if $clothingrebuy is 1>>
<<if $money gte 6000>>
<<set $clothingrebuytext to 1>>
<<set $uppereveninggownnew to 1>>
<<set $uppereveninggownno to 1>>
<<set $lowereveninggownnew to 1>>
<<set $lowereveninggownno to 1>>
<<set $money -= 6000>>
<<else>>
<<set $clothingrebuyfailedtext to 1>>
<</if>>
<</if>>
<<set $upperoff to 0>>
<</if>>
<<if $upperclothes is "tank top">>
<<set $tanktopno to 0>>
<<uppernaked>>
<<if $clothingrebuy is 1>>
<<if $money gte 1000>>
<<set $clothingrebuytext to 1>>
<<set $tanktopnew to 1>>
<<set $tanktopno to 1>>
<<set $money -= 1000>>
<<else>>
<<set $clothingrebuyfailedtext to 1>>
<</if>>
<</if>>
<<set $upperoff to 0>>
<</if>>
<</if>>
<<set $ruined to 0>><</nobr>><</widget>>
<<widget "lowerruined">><<nobr>><<set $ruined to 1>><<set $eventskipoverrule to 1>><<set $uncladlower to 0>><<set $uncladoutfit to 0>>
<<if $lowertemp is 1>>
<<lowernaked>>
<<set $loweroff to 0>>
<<else>>
<<if $lowerclothes is "sundress skirt">>
<<set $lowersundressno to 0>>
<<lowernaked>>
<<if $clothingrebuy is 1>>
<<if $money gte 750>>
<<set $clothingrebuytext to 1>>
<<set $uppersundressnew to 1>>
<<set $uppersundressno to 1>>
<<set $lowersundressnew to 1>>
<<set $lowersundressno to 1>>
<<set $money -= 750>>
<<else>>
<<set $clothingrebuyfailedtext to 1>>
<</if>>
<</if>>
<<set $loweroff to 0>>
<</if>>
<<if $lowerclothes is "pyjama bottoms">>
<<set $lowerpjsno to 0>>
<<lowernaked>>
<<if $clothingrebuy is 1>>
<<if $money gte 1000>>
<<set $clothingrebuytext to 1>>
<<set $lowerpjsnew to 1>>
<<set $lowerpjsno to 1>>
<<set $money -= 1000>>
<<else>>
<<set $clothingrebuyfailedtext to 1>>
<</if>>
<</if>>
<<set $loweroff to 0>>
<</if>>
<<if $lowerclothes is "towel">>
<<set $lowertowelno to 0>>
<<lowernaked>>
<<set $loweroff to 0>>
<</if>>
<<if $lowerclothes is "bikini bottoms">>
<<set $lowerbikinino to 0>>
<<lowernaked>>
<<if $clothingrebuy is 1>>
<<if $money gte 3000>>
<<set $clothingrebuytext to 1>>
<<set $lowerbikininew to 1>>
<<set $lowerbikinino to 1>>
<<set $money -= 3000>>
<<else>>
<<set $clothingrebuyfailedtext to 1>>
<</if>>
<</if>>
<<set $loweroff to 0>>
<</if>>
<<if $lowerclothes is "waist apron">>
<<set $waistapronno to 0>>
<<lowernaked>>
<<set $loweroff to 0>>
<</if>>
<<if $lowerclothes is "shorts">>
<<set $shortsno to 0>>
<<lowernaked>>
<<if $clothingrebuy is 1>>
<<if $money gte 1000>>
<<set $clothingrebuytext to 1>>
<<set $shortsnew to 1>>
<<set $shortsno to 1>>
<<set $money -= 1000>>
<<else>>
<<set $clothingrebuyfailedtext to 1>>
<</if>>
<</if>>
<<set $loweroff to 0>>
<</if>>
<<if $lowerclothes is "school shorts">>
<<set $schoolshortsno to 0>>
<<lowernaked>>
<<if $clothingrebuy is 1>>
<<if $money gte 2000>>
<<set $clothingrebuytext to 1>>
<<set $schoolshortsnew to 1>>
<<set $schoolshortsno to 1>>
<<set $money -= 2000>>
<<else>>
<<set $clothingrebuyfailedtext to 1>>
<</if>>
<</if>>
<<set $loweroff to 0>>
<</if>>
<<if $lowerclothes is "school skirt">>
<<set $schoolskirtno to 0>>
<<lowernaked>>
<<if $clothingrebuy is 1>>
<<if $money gte 2000>>
<<set $clothingrebuytext to 1>>
<<set $schoolskirtnew to 1>>
<<set $schoolskirtno to 1>>
<<set $money -= 2000>>
<<else>>
<<set $clothingrebuyfailedtext to 1>>
<</if>>
<</if>>
<<set $loweroff to 0>>
<</if>>
<<if $lowerclothes is "school swimsuit bottom">>
<<set $lowerschoolswimsuitno to 0>>
<<lowernaked>>
<<if $clothingrebuy is 1>>
<<if $money gte 750>>
<<set $clothingrebuytext to 1>>
<<set $upperschoolswimsuitnew to 1>>
<<set $upperschoolswimsuitno to 1>>
<<set $lowerschoolswimsuitnew to 1>>
<<set $lowerschoolswimsuitno to 1>>
<<set $money -= 750>>
<<else>>
<<set $clothingrebuyfailedtext to 1>>
<</if>>
<</if>>
<<set $loweroff to 0>>
<</if>>
<<if $lowerclothes is "school swim shorts">>
<<set $schoolswimshortsno to 0>>
<<lowernaked>>
<<if $clothingrebuy is 1>>
<<if $money gte 1500>>
<<set $clothingrebuytext to 1>>
<<set $schoolswimshortsnew to 1>>
<<set $schoolswimshortsno to 1>>
<<set $money -= 1500>>
<<else>>
<<set $clothingrebuyfailedtext to 1>>
<</if>>
<</if>>
<<set $loweroff to 0>>
<</if>>
<<if $lowerclothes is "plant skirt">>
<<set $lowerplantswimsuitno to 0>>
<<lowernaked>>
<<set $loweroff to 0>>
<</if>>
<<if $lowerclothes is "evening gown skirt">>
<<set $lowereveninggownno to 0>>
<<lowernaked>>
<<if $clothingrebuy is 1>>
<<if $money gte 6000>>
<<set $clothingrebuytext to 1>>
<<set $uppereveninggownnew to 1>>
<<set $uppereveninggownno to 1>>
<<set $lowereveninggownnew to 1>>
<<set $lowereveninggownno to 1>>
<<set $money -= 6000>>
<<else>>
<<set $clothingrebuyfailedtext to 1>>
<</if>>
<</if>>
<<set $loweroff to 0>>
<</if>>
<</if>>
<<set $ruined to 0>><</nobr>><</widget>>
<<widget "underruined">><<nobr>><<set $ruined to 1>><<set $eventskipoverrule to 1>><<set $uncladunder to 0>>
<<if $undertemp is 1>>
<<undernaked>>
<<set $underoff to 0>>
<<else>>
<<if $underclothes is "plain panties">>
<<set $plainpantiesno to 0>>
<<undernaked>>
<<if $clothingrebuy is 1>>
<<if $money gte 200>>
<<set $clothingrebuytext to 1>>
<<set $plainpantiesnew to 1>>
<<set $plainpantiesno to 1>>
<<set $money -= 200>>
<<else>>
<<set $clothingrebuyfailedtext to 1>>
<</if>>
<</if>>
<<set $underoff to 0>>
<</if>>
<<if $underclothes is "lace panties">>
<<set $lacepantiesno to 0>>
<<undernaked>>
<<if $clothingrebuy is 1>>
<<if $money gte 600>>
<<set $clothingrebuytext to 1>>
<<set $lacepantiesnew to 1>>
<<set $lacepantiesno to 1>>
<<set $money -= 600>>
<<else>>
<<set $clothingrebuyfailedtext to 1>>
<</if>>
<</if>>
<<set $underoff to 0>>
<</if>>
<<if $underclothes is "Y fronts">>
<<set $yfrontsno to 0>>
<<undernaked>>
<<if $clothingrebuy is 1>>
<<if $money gte 200>>
<<set $clothingrebuytext to 1>>
<<set $yfrontsnew to 1>>
<<set $yfrontsno to 1>>
<<set $money -= 200>>
<<else>>
<<set $clothingrebuyfailedtext to 1>>
<</if>>
<</if>>
<<set $underoff to 0>>
<</if>>
<<if $underclothes is "tights">>
<<set $tightsno to 0>>
<<undernaked>>
<<if $clothingrebuy is 1>>
<<if $money gte 1200>>
<<set $clothingrebuytext to 1>>
<<set $tightsnew to 1>>
<<set $tightsno to 1>>
<<set $money -= 1200>>
<<else>>
<<set $clothingrebuyfailedtext to 1>>
<</if>>
<</if>>
<<set $underoff to 0>>
<</if>>
<<if $underclothes is "chastity belt">>
<<if $undertype is "brokenchastity">>
<<set $chastitybeltno to 0>>
<<undernaked>>
<<set $underoff to 0>>
<<set $analshield to 0>>
<<else>>
<<set $chastitybeltno to 1>>
<<chastitybelt>>
<<set $underoff to 0>>
<</if>>
<</if>>
<</if>>
<<set $ruined to 0>><</nobr>><</widget>>
<<widget "upperon">><<nobr>>
<<if $upperoff isnot 0>>
<<set $upperwetcarry to $upperwet>><<set $upperwetstagecarry to $upperwetstage>>
<</if>>
<<if $upperoff is "sundress" and $uppersundressno gte 1>>
<<uppersundress>>
<</if>>
<<if $upperoff is "pyjama shirt" and $upperpjsno gte 1>>
<<upperpjs>>
<</if>>
<<if $upperoff is "towel">>
<<uppertowel>>
<</if>>
<<if $upperoff is "bikini top" and $upperbikinino gte 1>>
<<upperbikini>>
<</if>>
<<if $upperoff is "t-shirt" and $tshirtno gte 1>>
<<tshirt>>
<</if>>
<<if $upperoff is "school shirt" and $schoolshirtno gte 1>>
<<schoolshirt>>
<</if>>
<<if $upperoff is "school swimsuit" and $upperschoolswimsuitno gte 1>>
<<upperschoolswimsuit>>
<</if>>
<<if $upperoff is "plant top">>
<<upperplant>>
<</if>>
<<if $upperoff is "evening gown" and $uppereveninggownno gte 1>>
<<uppereveninggown>>
<</if>>
<<if $upperoff is "tank top" and $tanktopno gte 1>>
<<tanktop>>
<</if>>
<<set $upperoff to 0>>
<<if $upperwetcarry isnot 0>>
<<set $upperwet to $upperwetcarry>><<set $upperwetstage to $upperwetstagecarry>>
<</if>>
<<set $upperwetcarry to 0>><<set $upperwetstagecarry to 0>>
<</nobr>><</widget>>
<<widget "loweron">><<nobr>>
<<if $loweroff isnot 0>>
<<set $lowerwetcarry to $lowerwet>><<set $lowerwetstagecarry to $lowerwetstage>>
<</if>>
<<if $loweroff is "sundress skirt" and $lowersundressno gte 1>>
<<lowersundress>>
<</if>>
<<if $loweroff is "pyjama bottoms" and $lowerpjsno gte 1>>
<<lowerpjs>>
<</if>>
<<if $loweroff is "towel">>
<<lowertowel>>
<</if>>
<<if $loweroff is "bikini bottoms" and $lowerbikinino gte 1>>
<<lowerbikini>>
<</if>>
<<if $loweroff is "waist apron" and $waistapronno gte 1>>
<<waistapron>>
<</if>>
<<if $loweroff is "shorts" and $shortsno gte 1>>
<<shorts>>
<</if>>
<<if $loweroff is "school shorts" and $schoolshortsno gte 1>>
<<schoolshorts>>
<</if>>
<<if $loweroff is "school skirt" and $schoolskirtno gte 1>>
<<schoolskirt>>
<</if>>
<<if $loweroff is "school swimsuit bottom" and $lowerschoolswimsuitno gte 1>>
<<lowerschoolswimsuit>>
<</if>>
<<if $loweroff is "school swim shorts" and $schoolswimshortsno gte 1>>
<<schoolswimshorts>>
<</if>>
<<if $loweroff is "plant skirt">>
<<lowerplant>>
<</if>>
<<if $loweroff is "evening gown skirt" and $lowereveninggownno gte 1>>
<<lowereveninggown>>
<</if>>
<<set $loweroff to 0>>
<<if $lowerwetcarry isnot 0>>
<<set $lowerwet to $lowerwetcarry>><<set $lowerwetstage to $lowerwetstagecarry>>
<</if>>
<<set $lowerwetcarry to 0>><<set $lowerwetstagecarry to 0>>
<</nobr>><</widget>>
<<widget "underon">><<nobr>>
<<if $underoff isnot 0>>
<<set $underwetcarry to $underwet>><<set $underwetstagecarry to $underwetstage>>
<</if>>
<<if $underoff is "plain panties" and $plainpantiesno gte 1>>
<<plainpanties>>
<</if>>
<<if $underoff is "lace panties" and $lacepantiesno gte 1>>
<<lacepanties>>
<</if>>
<<if $underoff is "Y fronts" and $yfrontsno gte 1>>
<<yfronts>>
<</if>>
<<if $underoff is "chastity belt" and $chastitybeltno gte 1>>
<<chastitybelt>>
<</if>>
<<if $underoff is "tights" and $tightsno gte 1>>
<<tights>>
<</if>>
<<set $underoff to 0>>
<<if $underwetcarry isnot 0>>
<<set $underwet to $underwetcarry>><<set $underwetstage to $underwetstagecarry>>
<</if>>
<<set $underwetcarry to 0>><<set $underwetstagecarry to 0>>
<</nobr>><</widget>>
<<widget "outfiton">><<nobr>>
<<upperon>>
<<loweron>>
<</nobr>><</widget>>
<<widget "clotheson">><<nobr>>
<<upperon>>
<<loweron>>
<<underon>>
<<set $uncladupper to 0>>
<<set $uncladlower to 0>>
<<set $uncladunder to 0>>
<<set $uncladoutfit to 0>>
<<set $unclad to 0>>
<<if $upperclothes is "naked" and $lowerclothes is "naked" and $underclothes is "naked">>
<<else>>
You fix your clothing.<br><br>
<</if>>
<<set $upperstate to $upperstatebase>>
<<set $upperstatetop to $upperstatetopbase>>
<<set $lowerstate to $lowerstatebase>>
<<if $skirt is 1>>
<<set $skirtdown to 1>>
<</if>>
<<set $understate to $understatebase>>
<<set $upperexposed to $upperexposedbase>>
<<set $lowerexposed to $lowerexposedbase>>
<<set $lowervaginaexposed to $lowervaginaexposedbase>>
<<set $loweranusexposed to $loweranusexposedbase>>
<<set $underexposed to $underexposedbase>>
<<set $undervaginaexposed to $undervaginaexposedbase>>
<<set $underanusexposed to $underanusexposedbase>>
<<exposure>>
<<if $exposed gte 1>>
You are conscious of your <<nuditystop>><br><br>
<</if>>
<</nobr>><</widget>>
<<widget "clothesontowel">><<nobr>>
<<upperon>>
<<loweron>>
<<underon>>
<<set $uncladupper to 0>>
<<set $uncladlower to 0>>
<<set $uncladunder to 0>>
<<set $uncladoutfit to 0>>
<<set $unclad to 0>>
<<if $upperclothes is "naked" and $lowerclothes is "naked" and $underclothes is "naked">>
<<else>>
You fix your clothing.<br><br>
<</if>>
<<set $upperstate to $upperstatebase>>
<<set $upperstatetop to $upperstatetopbase>>
<<set $lowerstate to $lowerstatebase>>
<<if $skirt is 1>>
<<set $skirtdown to 1>>
<</if>>
<<set $understate to $understatebase>>
<<set $upperexposed to $upperexposedbase>>
<<set $lowerexposed to $lowerexposedbase>>
<<set $lowervaginaexposed to $lowervaginaexposedbase>>
<<set $loweranusexposed to $loweranusexposedbase>>
<<set $underexposed to $underexposedbase>>
<<set $undervaginaexposed to $undervaginaexposedbase>>
<<set $underanusexposed to $underanusexposedbase>>
<<exposure>>
<<towelup>>
<<if $exposed gte 1>>
You are conscious of your <<nuditystop>><br><br>
<</if>>
<</nobr>><</widget>>
<<widget "uppersteal">><<nobr>>
<<if $upperoff is "sundress">><<uppersundress>>
<<if $stealtextskip isnot 1>><<He>> decides to keep your $upperclothes as a souvenir.<br><br><</if>>
<<upperruined>><<set $upperoff to 0>><<uppernaked>>
<</if>>
<<if $upperoff is "pyjama shirt">><<upperpjs>>
<<if $stealtextskip isnot 1>><<He>> decides to keep your $upperclothes as a souvenir.<br><br><</if>>
<<upperruined>><<set $upperoff to 0>><<uppernaked>>
<</if>>
<<if $upperoff is "towel">><<uppertowel>>
<<if $stealtextskip isnot 1>><<He>> decides to keep your $upperclothes as a souvenir.<br><br><</if>>
<<upperruined>><<set $upperoff to 0>><<uppernaked>>
<</if>>
<<if $upperoff is "bikini top">><<upperbikini>>
<<if $stealtextskip isnot 1>><<He>> decides to keep your $upperclothes as a souvenir.<br><br><</if>>
<<upperruined>><<set $upperoff to 0>><<uppernaked>>
<</if>>
<<if $upperoff is "t-shirt">><<tshirt>>
<<if $stealtextskip isnot 1>><<He>> decides to keep your $upperclothes as a souvenir.<br><br><</if>>
<<upperruined>><<set $upperoff to 0>><<uppernaked>>
<</if>>
<<if $upperoff is "school shirt">><<schoolshirt>>
<<if $stealtextskip isnot 1>><<He>> decides to keep your $upperclothes as a souvenir.<br><br><</if>>
<<upperruined>><<set $upperoff to 0>><<uppernaked>>
<</if>>
<<if $upperoff is "school swimsuit">><<upperschoolswimsuit>>
<<if $stealtextskip isnot 1>><<He>> decides to keep your $upperclothes as a souvenir.<br><br><</if>>
<<upperruined>><<set $upperoff to 0>><<uppernaked>>
<</if>>
<<if $upperoff is "plant top">><<upperplant>>
<<if $stealtextskip isnot 1>><<He>> decides to keep your $upperclothes as a souvenir.<br><br><</if>>
<<upperruined>><<set $upperoff to 0>><<uppernaked>>
<</if>>
<<if $upperoff is "evening gown">><<uppereveninggown>>
<<if $stealtextskip isnot 1>><<He>> decides to keep your $upperclothes as a souvenir.<br><br><</if>>
<<upperruined>><<set $upperoff to 0>><<uppernaked>>
<</if>>
<<if $upperoff is "tank top">><<tanktop>>
<<if $stealtextskip isnot 1>><<He>> decides to keep your $upperclothes as a souvenir.<br><br><</if>>
<<upperruined>><<set $upperoff to 0>><<uppernaked>>
<</if>>
<</nobr>><</widget>>
<<widget "lowersteal">><<nobr>>
<<if $loweroff is "sundress skirt">><<lowersundress>>
<<if $stealtextskip isnot 1>><<He>> decides to keep your $lowerclothes as a souvenir.<br><br><</if>>
<<lowerruined>><<set $loweroff to 0>><<lowernaked>>
<</if>>
<<if $loweroff is "pyjama bottoms">><<lowerpjs>>
<<if $stealtextskip isnot 1>><<He>> decides to keep your $lowerclothes as a souvenir.<br><br><</if>>
<<lowerruined>><<set $loweroff to 0>><<lowernaked>>
<</if>>
<<if $loweroff is "towel">><<lowertowel>>
<<if $stealtextskip isnot 1>><<He>> decides to keep your $lowerclothes as a souvenir.<br><br><</if>>
<<lowerruined>><<set $loweroff to 0>><<lowernaked>>
<</if>>
<<if $loweroff is "bikini bottoms">><<lowerbikini>>
<<if $stealtextskip isnot 1>><<He>> decides to keep your $lowerclothes as a souvenir.<br><br><</if>>
<<lowerruined>><<set $loweroff to 0>><<lowernaked>>
<</if>>
<<if $loweroff is "waist apron">><<waistapron>>
<<if $stealtextskip isnot 1>><<He>> decides to keep your $lowerclothes as a souvenir.<br><br><</if>>
<<lowerruined>><<set $loweroff to 0>><<lowernaked>>
<</if>>
<<if $loweroff is "shorts">><<shorts>>
<<if $stealtextskip isnot 1>><<He>> decides to keep your $lowerclothes as a souvenir.<br><br><</if>>
<<lowerruined>><<set $loweroff to 0>><<lowernaked>>
<</if>>
<<if $loweroff is "school shorts">><<schoolshorts>>
<<if $stealtextskip isnot 1>><<He>> decides to keep your $lowerclothes as a souvenir.<br><br><</if>>
<<lowerruined>><<set $loweroff to 0>><<lowernaked>>
<</if>>
<<if $loweroff is "school skirt">><<schoolskirt>>
<<if $stealtextskip isnot 1>><<He>> decides to keep your $lowerclothes as a souvenir.<br><br><</if>>
<<lowerruined>><<set $loweroff to 0>><<lowernaked>>
<</if>>
<<if $loweroff is "school swimsuit bottom">><<lowerschoolswimsuit>>
<<if $stealtextskip isnot 1>><<He>> decides to keep your $lowerclothes as a souvenir.<br><br><</if>>
<<lowerruined>><<set $loweroff to 0>><<lowernaked>>
<</if>>
<<if $loweroff is "school swim shorts">><<schoolswimshorts>>
<<if $stealtextskip isnot 1>><<He>> decides to keep your $lowerclothes as a souvenir.<br><br><</if>>
<<lowerruined>><<set $loweroff to 0>><<lowernaked>>
<</if>>
<<if $loweroff is "plant skirt">><<lowerplant>>
<<if $stealtextskip isnot 1>><<He>> decides to keep your $lowerclothes as a souvenir.<br><br><</if>>
<<lowerruined>><<set $loweroff to 0>><<lowernaked>>
<</if>>
<<if $loweroff is "evening gown skirt">><<lowereveninggown>>
<<if $stealtextskip isnot 1>><<He>> decides to keep your $lowerclothes as a souvenir.<br><br><</if>>
<<lowerruined>><<set $loweroff to 0>><<lowernaked>>
<</if>>
<</nobr>><</widget>>
<<widget "understeal">><<nobr>>
<<if $underoff is "plain panties">><<plainpanties>>
<<if $stealtextskip isnot 1>><<He>> decides to keep your $underclothes as a souvenir.<br><br><</if>>
<<underruined>><<set $underoff to 0>><<undernaked>>
<</if>>
<<if $underoff is "lace panties">><<lacepanties>>
<<if $stealtextskip isnot 1>><<He>> decides to keep your $underclothes as a souvenir.<br><br><</if>>
<<underruined>><<set $underoff to 0>><<undernaked>>
<</if>>
<<if $underoff is "Y fronts">><<yfronts>>
<<if $stealtextskip isnot 1>><<He>> decides to keep your $underclothes as a souvenir.<br><br><</if>>
<<underruined>><<set $underoff to 0>><<undernaked>>
<</if>>
<<if $underoff is "tights">><<tights>>
<<if $stealtextskip isnot 1>><<He>> decides to keep your $underclothes as a souvenir.<br><br><</if>>
<<underruined>><<set $underoff to 0>><<undernaked>>
<</if>>
<<if $underoff is "chastity belt">>
<</if>>
<</nobr>><</widget>>
<<widget "upperundress">><<nobr>>
<<if $upperset is $lowerset>>
<<set $clothingchange to 1>><<lowernaked>><<set $loweroff to 0>><<set $lowerwet to 0>><<set $lowerwetstage to 0>>
<</if>>
<<uppernaked>><<set $upperoff to 0>><<set $uncladupper to 0>><<set $uncladoutfit to 0>><<set $upperwet to 0>><<set $upperwetstage to 0>>
<</nobr>><</widget>>
<<widget "lowerundress">><<nobr>>
<<if $upperset is $lowerset>>
<<set $clothingchange to 1>><<uppernaked>><<set $upperoff to 0>><<set $upperwet to 0>><<set $upperwetstage to 0>>
<</if>>
<<lowernaked>><<set $loweroff to 0>><<set $uncladlower to 0>><<set $uncladoutfit to 0>><<set $lowerwet to 0>><<set $lowerwetstage to 0>>
<</nobr>><</widget>>
<<widget "underundress">><<nobr>>
<<undernaked>><<set $underoff to 0>><<set $uncladunder to 0>><<set $underwet to 0>><<set $underwetstage to 0>>
<</nobr>><</widget>>
<<widget "undress">><<nobr>>
<<upperundress>>
<<lowerundress>>
<<underundress>>
<</nobr>><</widget>>
<<widget "storeupper">><<nobr>>
<<if $uppertemp isnot 1>>
<<if $uppertype isnot "naked">>
<<if $upperset is $lowerset>>
<<set $lowerstore to $lowerclothes>>
<</if>>
<<set $upperstore to $upperclothes>>
<</if>>
<</if>>
<<upperundress>>
<</nobr>><</widget>>
<<widget "storelower">><<nobr>>
<<if $lowertemp isnot 1>>
<<if $lowertype isnot "naked">>
<<if $upperset is $lowerset>>
<<set $upperstore to $upperclothes>>
<</if>>
<<set $lowerstore to $lowerclothes>>
<</if>>
<</if>>
<<lowerundress>>
<</nobr>><</widget>>
<<widget "storeunder">><<nobr>>
<<if $undertemp isnot 1>>
<<if $undertype isnot "naked" and $undertype isnot "chastity">>
<<set $understore to $underclothes>>
<</if>>
<</if>>
<<underundress>>
<</nobr>><</widget>>
<<widget "storeclothes">><<nobr>>
<<storeupper>>
<<storelower>>
<<storeunder>>
<<if $location is "pool">>
<<set $faceacccarry to $faceacc>>
<<set $headacccarry to $headacc>>
<<set $legsacccarry to $legsacc>>
<<set $feetacccarry to $feetacc>>
<<set $faceacc to 0>>
<<set $headacc to 0>>
<<set $legsacc to 0>>
<<set $feetacc to 0>>
<</if>>
<</nobr>><</widget>>
<<widget "storeon">><<nobr>>
<<if $upperstore isnot 0>>
<<set $upperoff to $upperstore>>
<<set $upperstore to 0>>
<</if>>
<<if $lowerstore isnot 0>>
<<set $loweroff to $lowerstore>>
<<set $lowerstore to 0>>
<</if>>
<<if $understore isnot 0>>
<<set $underoff to $understore>>
<<set $understore to 0>>
<</if>>
<<if $location is "pool">>
<<set $faceacc to $faceacccarry>>
<<set $headacc to $headacccarry>>
<<set $legsacc to $legsacccarry>>
<<set $feetacc to $feetacccarry>>
<<set $faceacccarry to 0>>
<<set $headacccarry to 0>>
<<set $legsacccarry to 0>>
<<set $feetacccarry to 0>>
<</if>>
<<clotheson>>
<<set $storelocation to 0>>
<</nobr>><</widget>>
<<widget "storeclear">><<nobr>>
<<set $upperstore to 0>>
<<set $lowerstore to 0>>
<<set $understore to 0>>
<<set $storelocation to 0>>
<</nobr>><</widget>>
<<widget "storelocation">><<nobr>>
<<if $undertemp isnot 1 and $lowertemp isnot 1 and $uppertemp isnot 1>>
<<set $storelocation to $storelocationinit>>
<<else>>
<</if>>
<</nobr>><</widget>>
:: Widgets Img [widget]
<<widget "img">><<nobr>>
<div id="img" @class="colourContainerClasses()">
<img id="bg" src="img/topleftbg.png">
<img id="base" src="img/body/basenoarms.gif">
<<if $leftarm isnot "bound">>
<<if $masturbationimages is 1>>
<<if $leftaction is "mpenisentrance">>
<img id="leftarm" src="img/body/masturbation/leftarmballs.gif">
<<elseif $leftaction is "mvaginaentrance">>
<img id="leftarm" src="img/body/masturbation/leftarmpussy.gif">
<<elseif $leftaction is "manus">>
<img id="leftarm" src="img/body/masturbation/leftarmass.gif">
<<elseif $leftaction is "manusentrance">>
<img id="leftarm" src="img/body/masturbation/leftarmass.gif">
<<elseif $leftaction is "manusrub">>
<img id="leftarm" src="img/body/masturbation/leftarmass.gif">
<<elseif $leftaction is "manustease">>
<img id="leftarm" src="img/body/masturbation/leftarmass.gif">
<<elseif $leftaction is "manusprostate">>
<img id="leftarm" src="img/body/masturbation/leftarmass.gif">
<<elseif $leftaction is "mpenisshaft">>
<img id="leftarm" src="img/body/masturbation/leftarmshaft.gif">
<<elseif $leftaction is "mpenisglans">>
<img id="leftarm" src="img/body/masturbation/leftarmglans.gif">
<<elseif $leftaction is "mvagina">>
<img id="leftarm" src="img/body/masturbation/leftarmpussy.gif">
<<elseif $leftaction is "mvaginaclit">>
<img id="leftarm" src="img/body/masturbation/leftarmclit.gif">
<<elseif $leftaction is "mvaginatease">>
<img id="leftarm" src="img/body/masturbation/leftarmpussy.gif">
<</if>>
<<elseif $exhibitionism gte 95>>
<img id="base" src="img/body/leftarmidle.png">
<<elseif $exhibitionism gte 55 and $exposed lte 1>>
<img id="base" src="img/body/leftarmidle.png">
<<elseif $upperexposed gte 1 and $exposed gte 1>>
<img id="leftarm" src="img/body/leftarm.gif">
<<else>>
<img id="base" src="img/body/leftarmidle.png">
<</if>>
<</if>>
<<if $rightarm isnot "bound">>
<<if $masturbationimages is 1>>
<<if $rightaction is "mpenisentrance">>
<img id="rightarm" src="img/body/masturbation/rightarmballs.gif">
<<elseif $rightaction is "mvaginaentrance">>
<img id="rightarm" src="img/body/masturbation/rightarmpussy.gif">
<<elseif $rightaction is "manus">>
<img id="rightarm" src="img/body/masturbation/rightarmass.gif">
<<elseif $rightaction is "manusentrance">>
<img id="rightarm" src="img/body/masturbation/rightarmass.gif">
<<elseif $rightaction is "manusrub">>
<img id="rightarm" src="img/body/masturbation/rightarmass.gif">
<<elseif $rightaction is "manustease">>
<img id="rightarm" src="img/body/masturbation/rightarmass.gif">
<<elseif $rightaction is "manusprostate">>
<img id="rightarm" src="img/body/masturbation/rightarmass.gif">
<<elseif $rightaction is "mpenisshaft">>
<img id="rightarm" src="img/body/masturbation/rightarmshaft.gif">
<<elseif $rightaction is "mpenisglans">>
<img id="rightarm" src="img/body/masturbation/rightarmglans.gif">
<<elseif $rightaction is "mvagina">>
<img id="rightarm" src="img/body/masturbation/rightarmpussy.gif">
<<elseif $rightaction is "mvaginaclit">>
<img id="rightarm" src="img/body/masturbation/rightarmclit.gif">
<<elseif $rightaction is "mvaginatease">>
<img id="rightarm" src="img/body/masturbation/rightarmpussy.gif">
<</if>>
<<elseif $exhibitionism gte 95>>
<img id="base" src="img/body/rightarmidle.png">
<<elseif $exhibitionism gte 55 and $exposed lte 1>>
<img id="base" src="img/body/rightarmidle.png">
<<elseif $lowerexposed gte 1 and $exposed gte 1>>
<img id="rightarm" src="img/body/rightarm.png">
<<else>>
<img id="base" src="img/body/rightarmidle.png">
<</if>>
<</if>>
<<if $pain gte 80>>
<img id="tears" src="img/body/tear4.gif">
<<elseif $pain gte 60>>
<img id="tears" src="img/body/tear3.gif">
<<elseif $pain gte 40>>
<img id="tears" src="img/body/tear2.gif">
<<elseif $pain gte 20>>
<img id="tears" src="img/body/tear1.png">
<</if>>
<<if $arousal gte 8000>>
<img id="blush" src="img/body/blush5.png">
<<elseif $arousal gte 6000>>
<img id="blush" src="img/body/blush4.png">
<<elseif $arousal gte 4000>>
<img id="blush" src="img/body/blush3.png">
<<elseif $exposed gte 2>>
<img id="blush" src="img/body/blush2.png">
<<elseif $arousal gte 2000>>
<img id="blush" src="img/body/blush2.png">
<<elseif $exposed gte 1>>
<img id="blush" src="img/body/blush1.png">
<<elseif $arousal gte 100>>
<img id="blush" src="img/body/blush1.png">
<</if>>
<<if $pain gte 100>>
<img id="sclera" src="img/eyes/sclerabloodshot.png">
<</if>>
<<if $trauma gte $traumamax>>
<img id="mouth" src="img/body/mouthneutral.png">
<<elseif $orgasmdown gte 1>>
<img id="mouth" src="img/body/mouthcry.png">
<<elseif $pain gte 80>>
<img id="mouth" src="img/body/mouthcry.png">
<<elseif $pain gte 60>>
<img id="mouth" src="img/body/mouthcry.png">
<<elseif $pain gte 40>>
<img id="mouth" src="img/body/mouthfrown.png">
<<elseif $pain gte 20>>
<img id="mouth" src="img/body/mouthfrown.png">
<<elseif $exposed is 2 and $exhibitionism lt 95>>
<img id="mouth" src="img/body/mouthfrown.png">
<<elseif $pain gte 1>>
<img id="mouth" src="img/body/mouthneutral.png">
<<elseif $exposed is 1 and $exhibitionism lt 55>>
<img id="mouth" src="img/body/mouthneutral.png">
<<elseif $combat is 1 and $consensual isnot 1>>
<img id="mouth" src="img/body/mouthneutral.png">
<<else>>
<img id="mouth" src="img/body/mouthsmile.png">
<</if>>
<<if $trauma gte $traumamax>>
<img id="eyes" class="colour-eye" src="img/eyes/eyeshazelempty.png">
<<else>>
<img id="eyes" class="colour-eye" src="img/eyes/eyeshazel.gif">
<</if>>
<<if $pain gte 100>>
<img id="sclera" src="img/eyes/sclerabloodshot.png">
<</if>>
<<if $vaginasemen + $vaginagoo gte 5>>
<img id="tears" src="img/body/cum/VaginalCumDripVeryFast.gif">
<<elseif $vaginasemen + $vaginagoo gte 4>>
<img id="tears" src="img/body/cum/VaginalCumDripFast.gif">
<<elseif $vaginasemen + $vaginagoo gte 3>>
<img id="tears" src="img/body/cum/VaginalCumDripSlow.gif">
<<elseif $vaginasemen + $vaginagoo gte 2>>
<img id="tears" src="img/body/cum/VaginalCumDripVerySlow.gif">
<<elseif $vaginasemen + $vaginagoo gte 1>>
<img id="tears" src="img/body/cum/VaginalCumDripStart.gif">
<</if>>
<<if $anussemen + $anusgoo gte 5>>
<img id="tears" src="img/body/cum/AnalCumDripVeryFast.gif">
<<elseif $anussemen + $anusgoo gte 4>>
<img id="tears" src="img/body/cum/AnalCumDripFast.gif">
<<elseif $anussemen + $anusgoo gte 3>>
<img id="tears" src="img/body/cum/AnalCumDripSlow.gif">
<<elseif $anussemen + $anusgoo gte 2>>
<img id="tears" src="img/body/cum/AnalCumDripVerySlow.gif">
<<elseif $anussemen + $anusgoo gte 1>>
<img id="tears" src="img/body/cum/AnalCumDripStart.gif">
<</if>>
<<if $mouthsemen + $mouthgoo gte 5>>
<img id="sclera" src="img/body/cum/MouthCumDripVeryFast.gif">
<<elseif $mouthsemen + $mouthgoo gte 4>>
<img id="sclera" src="img/body/cum/MouthCumDripFast.gif">
<<elseif $mouthsemen + $mouthgoo gte 3>>
<img id="sclera" src="img/body/cum/MouthCumDripSlow.gif">
<<elseif $mouthsemen + $mouthgoo gte 2>>
<img id="sclera" src="img/body/cum/MouthCumDripVerySlow.gif">
<<elseif $mouthsemen + $mouthgoo gte 1>>
<img id="sclera" src="img/body/cum/MouthCumDripStart.png">
<</if>>
<<if $fallenangel gte 2>>
<img id="backhair" src="img/transformations/angel/brokenwings.gif">
<img id="backhair" src="img/transformations/angel/brokenhalo.png">
<</if>>
<<if $angel gte 4>>
<img id="backhair" src="img/transformations/angel/halo.gif">
<</if>>
<<if $angel gte 6>>
<img id="backhair" src="img/transformations/angel/wings.gif">
<</if>>
<<if $demon gte 2>>
<img id="lashes" src="img/transformations/demon/demonhorns.gif">
<</if>>
<<if $demon gte 4>>
<img id="backhair" src="img/transformations/demon/demontail.gif">
<</if>>
<<if $demon gte 6>>
<img id="backhair" src="img/transformations/demon/demonwings.gif">
<</if>>
<<if $wolfgirl gte 4>>
<img id="backhair" class="colour-hair" src="img/transformations/wolf/wolfearsred.gif">
<<if $hirsutedisable is "f">>
<img id="hirsute" class="colour-hair" src="img/transformations/hirsute/bushtamered.gif">
<</if>>
<</if>>
<<if $wolfgirl gte 6>>
<img id="backhair" class="colour-hair" src="img/transformations/wolf/wolftailred.gif">
<</if>>
<<if $hairlength gte 900>>
<img id="hair" class="colour-hair" src="img/hair/red/hairfeetred.gif">
<img id="backhair" class="colour-hair" src="img/hair/red/backhairfeetred.gif">
<<elseif $hairlength gte 700>>
<img id="hair" class="colour-hair" src="img/hair/red/hairthighsred.gif">
<img id="backhair" class="colour-hair" src="img/hair/red/backhairthighsred.gif">
<<elseif $hairlength gte 600>>
<img id="hair" class="colour-hair" src="img/hair/red/hairnavelred.gif">
<<elseif $hairlength gte 400>>
<img id="hair" class="colour-hair" src="img/hair/red/hairchestred.gif">
<<elseif $hairlength gte 200>>
<img id="hair" class="colour-hair" src="img/hair/red/hairshoulderred.gif">
<<else>>
<img id="hair" class="colour-hair" src="img/hair/red/hairshortred.gif">
<</if>>
<img id="lashes" class="colour-hair" src="img/hair/red/lashesred.png">
<<if $trauma gte $traumamax>>
<img id="brow" class="colour-hair" src="img/hair/red/browtopred.png">
<<elseif $pain gte 60>>
<img id="brow" class="colour-hair" src="img/hair/red/browlowred.png">
<<elseif $pain gte 20>>
<img id="brow" class="colour-hair" src="img/hair/red/browmidred.png">
<<else>>
<img id="brow" class="colour-hair" src="img/hair/red/browtopred.png">
<</if>>
<<if $underwetstage gte 3>>
<<underclothesimg>>
<<elseif $underwetstage is 2>>
<<underclothesimg>>
<<else>>
<<underclothesimg>>
<</if>>
<<if $lowerwetstage gte 3>>
<<lowerclothesimg>>
<<elseif $lowerwetstage is 2>>
<<lowerclothesimg>>
<<else>>
<<lowerclothesimg>>
<</if>>
<<if $upperwetstage gte 3>>
<<upperclothesimg>>
<<elseif $upperwetstage is 2>>
<<upperclothesimg>>
<<else>>
<<upperclothesimg>>
<</if>>
<<if $collared is 1>>
<img id="collar" src="img/otherclothes/collar.png">
<</if>>
<<if $exposed gte 2 and $penisexist is 1>>
<<if $penilevirginity is 1>>
<img id="tears" src="img/body/penisvirgin.gif">
<<else>>
<img id="tears" src="img/body/penis.gif">
<</if>>
<</if>>
<<if $chestparasite is 1>>
<img id="tears" src="img/body/chestparasite.gif">
<</if>>
<<if $penisparasite is 1 and $exposed gte 2>>
<img id="tears" src="img/body/penisparasite.png">
<</if>>
<<if $clitparasite is 1 and $exposed gte 2>>
<img id="tears" src="img/body/clitparasite.png">
<</if>>
<<if $headacc is "hairpin">>
<img id="headacc" src="img/accessories/hairpin.gif">
<</if>>
<<if $headacc is "beanie">>
<img id="headacc" src="img/accessories/beanie.png">
<</if>>
<<if $faceacc is "glasses">>
<img id="faceacc" src="img/accessories/glasses.gif">
<</if>>
<<if $faceacc is "cool shades">>
<img id="faceacc" src="img/accessories/coolshades.png">
<</if>>
<<if $legsacc is "boys gym socks">>
<img id="legsacc" src="img/accessories/boysgymsocks.png">
<</if>>
<<if $legsacc is "girls gym socks">>
<img id="legsacc" src="img/accessories/girlsgymsocks.png">
<</if>>
<<if $legsacc is "stockings">>
<img id="legsacc" src="img/accessories/stockings.png">
<</if>>
<<if $legsacc is "fishnet stockings">>
<img id="legsacc" src="img/accessories/fishnetstockings.png">
<</if>>
<<if $feetacc is "black shoes">>
<img id="feetacc" src="img/accessories/blackshoes.png">
<</if>>
</div>
<</nobr>><</widget>>
:: Clothing Rebuy [nobr]
<<set $outside to 0>><<effects>>
Enabling clothing rebuy will activate chips in all your clothing. When damaged beyond repair, the clothes automatically order a replacement for no extra charge beyond the cost of the garment. This will not work if you don't have enough money, which will be deducted immediately.<br><br>
Would you like to enable this?<br><br>
<<link [[Yes|Clothing Shop]]>><<set $clothingrebuy to 1>><</link>><br>
<<link [[No|Clothing Shop]]>><</link>><br>
:: Widgets Accessories [widget]
<<widget "accessorieswear">><<nobr>>
<<if $wear is "striphead">><<set $wear to 0>>
<<set $headacc to 0>>
<</if>>
<<if $wear is "stripface">><<set $wear to 0>>
<<set $faceacc to 0>>
<</if>>
<<if $wear is "striplegs">><<set $wear to 0>>
<<set $legsacc to 0>>
<</if>>
<<if $wear is "stripfeet">><<set $wear to 0>>
<<set $feetacc to 0>>
<</if>>
<<if $wear is "hairpin">><<set $wear to 0>>
You put on the hairpin.<br><br>
<<set $headacc to "hairpin">>
<</if>>
<<if $wear is "beanie">><<set $wear to 0>>
You put on the beanie.<br><br>
<<set $headacc to "beanie">>
<</if>>
<<if $wear is "glasses">><<set $wear to 0>>
You put on the glasses.<br><br>
<<set $faceacc to "glasses">>
<</if>>
<<if $wear is "cool shades">><<set $wear to 0>>
You put on the cool shades.<br><br>
<<set $faceacc to "cool shades">>
<</if>>
<<if $wear is "boys gym socks">><<set $wear to 0>>
You put on the boy's gym socks.<br><br>
<<set $legsacc to "boys gym socks">>
<</if>>
<<if $wear is "girls gym socks">><<set $wear to 0>>
You put on the girl's gym socks.<br><br>
<<set $legsacc to "girls gym socks">>
<</if>>
<<if $wear is "stockings">><<set $wear to 0>>
You put on the stockings.<br><br>
<<set $legsacc to "stockings">>
<</if>>
<<if $wear is "fishnet stockings">><<set $wear to 0>>
You put on the fishnet stockings.<br><br>
<<set $legsacc to "fishnet stockings">>
<</if>>
<<if $wear is "black shoes">><<set $wear to 0>>
You put on the shoes.<br><br>
<<set $feetacc to "black shoes">>
<</if>>
<</nobr>><</widget>>
<<widget "accessories">><<nobr>>
<hr>
Head<br>
<<if $headacc isnot 0>>
You are wearing a $headacc.<br>
<</if>>
<<if $hairpin is 1>>
<<link "Hairpin">><<set $wear to "hairpin">><<script>>state.display(state.active.title, null)<</script>><</link>> - Greatly accelerates hair growth.<br>
<</if>>
<<if $beanie is 1>>
<<link "Beanie">><<set $wear to "beanie">><<script>>state.display(state.active.title, null)<</script>><</link>> - Looks pretty cool. Makes status increase faster.<br>
<</if>>
<<link "Nothing">><<set $wear to "striphead">><<script>>state.display(state.active.title, null)<</script>><</link>><br>
<br>
Face<br>
<<if $faceacc isnot 0>>
You are wearing $faceacc.<br>
<</if>>
<<if $glasses is 1>>
<<link "Glasses">><<set $wear to "glasses">><<script>>state.display(state.active.title, null)<</script>><</link>> - Makes studying easier, but you might be picked on at school.<br>
<</if>>
<<if $coolshades is 1>>
<<link "Cool shades">><<set $wear to "cool shades">><<script>>state.display(state.active.title, null)<</script>><</link>> - Makes status increase faster, but the teachers won't like them.<br>
<</if>>
<<link "Nothing">><<set $wear to "stripface">><<script>>state.display(state.active.title, null)<</script>><</link>><br>
<br>
Legs<br>
<<if $legsacc isnot 0>>
You are wearing $legsacc.<br>
<</if>>
<<if $boysgymsocks is 1>>
<<link "Boy's gym socks">><<set $wear to "boys gym socks">><<script>>state.display(state.active.title, null)<</script>><</link>> - Just socks.<br>
<</if>>
<<if $girlsgymsocks is 1>>
<<link "Girl's gym socks">><<set $wear to "girls gym socks">><<script>>state.display(state.active.title, null)<</script>><</link>> - Just socks.<br>
<</if>>
<<if $stockings is 1>>
<<link "Stockings">><<set $wear to "stockings">><<script>>state.display(state.active.title, null)<</script>><</link>> - Attractive and alluring.<br>
<</if>>
<<if $fishnetstockings is 1>>
<<link "Fishnet stockings">><<set $wear to "fishnet stockings">><<script>>state.display(state.active.title, null)<</script>><</link>> - Attractive and alluring.<br>
<</if>>
<<link "Nothing">><<set $wear to "striplegs">><<script>>state.display(state.active.title, null)<</script>><</link>><br>
<br>
Feet<br>
<<if $feetacc isnot 0>>
You are wearing $feetacc.<br>
<</if>>
<<if $blackshoes is 1>>
<<link "Black shoes">><<set $wear to "black shoes">><<script>>state.display(state.active.title, null)<</script>><</link>> - Suitable for school.<br>
<</if>>
<<link "Nothing">><<set $wear to "stripfeet">><<script>>state.display(state.active.title, null)<</script>><</link>><br>
<br>
<br><br>
<</nobr>><</widget>>
:: Accessory Shop [nobr]
<<set $outside to 1>><<set $location to "forest">><<effects>>
You are in the accessory shop. The interior is dark and crowded by tall shelves, holding all manner of items. Most are useless knick-knacks, but some interest you.<br><br>
<<if $buy isnot 0>>
You buy the $buy.<br><br>
<</if>>
<<if $buy is "hairpin">><<set $buy to 0>>
<<set $hairpin to 1>><<set $money -= 1000>>
<</if>>
<<if $buy is "beanie">><<set $buy to 0>>
<<set $beanie to 1>><<set $money -= 7000>>
<</if>>
<<if $buy is "glasses">><<set $buy to 0>>
<<set $glasses to 1>><<set $money -= 2000>>
<</if>>
<<if $buy is "cool shades">><<set $buy to 0>>
<<set $coolshades to 1>><<set $money -= 15000>>
<</if>>
<<if $buy is "girl's gym socks">><<set $buy to 0>>
<<set $girlsgymsocks to 1>><<set $money -= 900>>
<</if>>
<<if $buy is "boy's gym socks">><<set $buy to 0>>
<<set $boysgymsocks to 1>><<set $money -= 900>>
<</if>>
<<if $buy is "stockings">><<set $buy to 0>>
<<set $stockings to 1>><<set $money -= 2200>>
<</if>>
<<if $buy is "fishnet stockings">><<set $buy to 0>>
<<set $fishnetstockings to 1>><<set $money -= 2200>>
<</if>>
<<if $buy is "black shoes">><<set $buy to 0>>
<<set $blackshoes to 1>><<set $money -= 3000>>
<</if>>
<<if $hairpin isnot 1>>
<span class="teal">Hairpin.</span> Costs £10. Greatly accelerates hair growth.<br>
<<if $money gte 1000>>
<<link [[Buy hairpin|Accessory Shop]]>><<set $buy to "hairpin">><</link>>
<<else>>
<span class="blue">You cannot afford it.</span>
<</if>>
<<else>>
<span class="teal">Hairpin.</span><br> <span class="green">Owned</span>
<</if>><br><br>
<<if $beanie isnot 1>>
<span class="teal">Beanie.</span> Costs £70. Makes status rise faster.<br>
<<if $money gte 7000 and $headdrive is 1>>
<<link [[Buy beanie|Accessory Shop]]>><<set $buy to "beanie">><</link>>
<<elseif $headdrive isnot 1>>
<span class="black">Locked.</span> Discover the headteacher's secret.
<<else>>
<span class="blue">You cannot afford it.</span>
<</if>>
<<else>>
<span class="teal">Beanie.</span><br> <span class="green">Owned.</span>
<</if>><br><br>
<br>
<br>
<<if $glasses isnot 1>>
<span class="teal">Glasses.</span> Costs £20. Makes studying easier, but other students might pick on you.<br>
<<if $money gte 2000>>
<<link [[Buy glasses|Accessory Shop]]>><<set $buy to "glasses">><</link>>
<<else>>
<span class="blue">You cannot afford it.</span>
<</if>>
<<else>>
<span class="teal">Glasses.</span><br> <span class="green">Owned.</span>
<</if>><br><br>
<<if $coolshades isnot 1>>
<span class="teal">Cool Shades.</span> Costs £150. Makes status rise faster.<br>
<<if $money gte 15000 and $cool gte 160>>
<<link [[Buy cool shades|Accessory Shop]]>><<set $buy to "cool shades">><</link>>
<<elseif $cool lt 160>>
<span class="black">Locked.</span> Make your peers think you're cool.
<<else>>
<span class="blue">You cannot afford it.</span>
<</if>>
<<else>>
<span class="teal">Cool shades.</span><br> <span class="green">Owned.</span>
<</if>><br><br>
<br>
<br>
<<if $girlsgymsocks isnot 1>>
<span class="teal">Girl's gym socks.</span> Costs £9. Just socks.<br>
<<if $money gte 900>>
<<link [[Buy girl's gym socks|Accessory Shop]]>><<set $buy to "girl's gym socks">><</link>>
<<else>>
<span class="blue">You cannot afford it.</span>
<</if>>
<<else>>
<span class="teal">Girl's gym socks.</span><br> <span class="green">Owned.</span>
<</if>><br><br>
<<if $boysgymsocks isnot 1>>
<span class="teal">Boy's gym socks.</span> Costs £9. Just socks.<br>
<<if $money gte 900>>
<<link [[Buy boy's gym socks|Accessory Shop]]>><<set $buy to "boy's gym socks">><</link>>
<<else>>
<span class="blue">You cannot afford it.</span>
<</if>>
<<else>>
<span class="teal">Boy's gym socks.</span><br> <span class="green">Owned.</span>
<</if>><br><br>
<<if $stockings isnot 1>>
<span class="teal">Stockings.</span> Costs £22. Attractive and alluring.<br>
<<if $money gte 2200 and $moleststat gte 30>>
<<link [[Buy stockings|Accessory Shop]]>><<set $buy to "stockings">><</link>>
<<elseif $moleststat lt 30>>
<span class="black">Locked.</span> Be molested thirty times.
<<else>>
<span class="blue">You cannot afford it.</span>
<</if>>
<<else>>
<span class="teal">Stockings.</span><br> <span class="green">Owned.</span>
<</if>><br><br>
<<if $fishnetstockings isnot 1>>
<span class="teal">Fishnet stockings.</span> Costs £22. Attractive and alluring.<br>
<<if $money gte 2200 and $prostitutionstat gte 10>>
<<link [[Buy fishnet stockings|Accessory Shop]]>><<set $buy to "fishnet stockings">><</link>>
<<elseif $prostitutionstat lt 10>>
<span class="black">Locked.</span> Whore yourself ten times.
<<else>>
<span class="blue">You cannot afford it.</span>
<</if>>
<<else>>
<span class="teal">Fishnet stockings.</span><br> <span class="green">Owned.</span>
<</if>><br><br>
<br>
<br>
<<if $blackshoes isnot 1>>
<span class="teal">Black shoes.</span> Costs £30. Suitable for school.<br>
<<if $money gte 3000>>
<<link [[Buy black shoes|Accessory Shop]]>><<set $buy to "black shoes">><</link>>
<<else>>
<span class="blue">You cannot afford it.</span>
<</if>>
<<else>>
<span class="teal">Black shoes.</span><br> <span class="green">Owned.</span>
<</if>><br><br>
<br><br>
<<link [[Leave|Forest]]>><</link>><br>
:: Widgets Combat Clothes Img [widget]
<<widget "clothesidle">><<nobr>>
<<if $upperset is $lowerset and $skirt is 1>>
<<if $upperstate is "waist">>
<<if $skirtdown is 1>>
<img id="sexlower" class="colour-upper" src="img/sex/doggy/idle/dress/red/doggyidle_dressred_thighs.gif">
<<elseif $skirtdown is 0>>
<img id="sexlower" class="colour-upper" src="img/sex/doggy/idle/dress/red/doggyidle_dressred_hips.gif">
<</if>>
<<elseif $upperstate is "midriff">>
<img id="sexlower" class="colour-upper" src="img/sex/doggy/idle/dress/red/doggyidle_dressred_tummy.gif">
<<elseif $upperstate is "chest">>
<img id="sexlower" class="colour-upper" src="img/sex/doggy/idle/dress/red/doggyidle_dressred_neck.gif">
<</if>>
<</if>>
<<if $lowerclothes is "bikini bottoms">>
<<print "<img id=sexlower class="colour-lower" src='img/sex/doggy/idle/bikinibottom/red/" + "doggyidle_bikinibottom" + "red" + "_" + $lowerstate + ".gif'>">>
<<elseif $lowertype isnot "naked" and $upperset isnot $lowerset>>
<<if $skirt is 1 and $skirtdown is 0 and $lowerstate is "waist">>
<img id="sexlower" class="colour-lower" src="img/sex/doggy/idle/skirt/red/doggyidle_skirtred_waist.gif">
<<elseif $skirt is 1 and $lowerstate is "waist">>
<img id="sexlower" class="colour-lower" src="img/sex/doggy/idle/skirt/red/doggyidle_skirtred_hips.gif">
<<elseif $skirt is 1 and $lowerstate is "thighs">>
<img id="sexlower" class="colour-lower" src="img/sex/doggy/idle/skirt/red/doggyidle_skirtred_thighs.gif">
<<elseif $skirt is 1 and $lowerstate is "knees">>
<img id="sexlower" class="colour-lower" src="img/sex/doggy/idle/skirt/red/doggyidle_skirtred_knees.gif">
<<elseif $skirt is 1 and $lowerstate is "ankles">>
<img id="sexlower" class="colour-lower" src="img/sex/doggy/idle/skirt/red/doggyidle_skirtred_ankles.gif">
<<elseif $lowerstate is "waist">>
<img id="sexlower" class="colour-lower" src="img/sex/doggy/idle/shorts/red/doggyidle_shortsred_hips.gif">
<<elseif $lowerstate is "thighs">>
<img id="sexlower" class="colour-lower" src="img/sex/doggy/idle/shorts/red/doggyidle_shortsred_thighs.gif">
<<elseif $lowerstate is "knees">>
<img id="sexlower" class="colour-lower" src="img/sex/doggy/idle/shorts/red/doggyidle_shortsred_knees.gif">
<<elseif $lowerstate is "ankles">>
<img id="sexlower" class="colour-lower" src="img/sex/doggy/idle/shorts/red/doggyidle_shortsred_ankles.gif">
<</if>>
<</if>>
<<if $undertype isnot "naked" and $undertype isnot "chastity">>
<<if $understate is "waist">>
<img id="sexunder" class="colour-under" src="img/sex/doggy/idle/plainpanties/red/doggyidle_plainpantiesred_hips.gif">
<<elseif $understate is "thighs">>
<img id="sexunder" class="colour-under" src="img/sex/doggy/idle/plainpanties/red/doggyidle_plainpantiesred_thighs.gif">
<<elseif $understate is "knees">>
<img id="sexunder" class="colour-under" src="img/sex/doggy/idle/plainpanties/red/doggyidle_plainpantiesred_knees.gif">
<<elseif $understate is "ankles">>
<img id="sexunder" class="colour-under" src="img/sex/doggy/idle/plainpanties/red/doggyidle_plainpantiesred_ankles.gif">
<</if>>
<</if>>
<<if $upperclothes is "bikini top">>
<<if $upperstate isnot "chest" and $upperstate isnot "midriff">>
<<print "<img id="sexunder" class="colour-upper" src='img/sex/doggy/idle/bikinitop/" + "red" + "/" + "doggyidle_bikinitop" + "red" + "_" + "thorax.gif'>">>
<<else>>
<<print "<img id="sexunder" class="colour-upper" src='img/sex/doggy/idle/bikinitop/" + "red" + "/" + "doggyidle_bikinitop" + "red" + "_" + $upperstate + ".gif'>">>
<</if>>
<<elseif $uppertype isnot "naked" and $upperset isnot $lowerset>>
<<if $leftarm isnot "bound" and $leftarm isnot "grappled">>
<<if $upperstate is "waist">>
<img id="sexunder" class="colour-upper" src="img/sex/doggy/idle/t-shirt/red/doggyidle_tshirtred_waist.gif">
<<else>>
<img id="sexunder" class="colour-upper" src="img/sex/doggy/idle/t-shirt/red/doggyidle_tshirtred_neck.gif">
<</if>>
<<else>>
<<if $upperstate is "waist">>
<img id="sexunder" class="colour-upper" src="img/sex/doggy/idle/t-shirt/red/doggyidle_tshirtred_boundwaist.gif">
<<else>>
<img id="sexunder" class="colour-upper" src="img/sex/doggy/idle/t-shirt/red/doggyidle_tshirtred_boundneck.gif">
<</if>>
<</if>>
<</if>>
<</nobr>><</widget>>
:: Widgets Clothes Img [widget]
<<widget "underclothesimg">><<nobr>>
<<if $underclothes is "plain panties">>
<<if $underintegrity lte ($underintegritymax / 10) * 2>>
<img id="under" class="colour-under" src="img/underclothes/plainpanties/plainpantiestatteredred.png">
<<elseif $underintegrity lte ($underintegritymax / 10) * 5>>
<img id="under" class="colour-under" src="img/underclothes/plainpanties/plainpantiestornred.png">
<<elseif $underintegrity lte ($underintegritymax / 10) * 9>>
<img id="under" class="colour-under" src="img/underclothes/plainpanties/plainpantiesfrayedred.png">
<<else>>
<img id="under" class="colour-under" src="img/underclothes/plainpanties/plainpantiesred.png">
<</if>>
<<elseif $underclothes is "lace panties">>
<<if $underintegrity lte ($underintegritymax / 10) * 2>>
<img id="under" class="colour-under" src="img/underclothes/lacepanties/lacepantiestatteredred.png">
<<elseif $underintegrity lte ($underintegritymax / 10) * 5>>
<img id="under" class="colour-under" src="img/underclothes/lacepanties/lacepantiestornred.png">
<<elseif $underintegrity lte ($underintegritymax / 10) * 9>>
<img id="under" class="colour-under" src="img/underclothes/lacepanties/lacepantiesfrayedred.png">
<<else>>
<img id="under" class="colour-under" src="img/underclothes/lacepanties/lacepantiesred.png">
<</if>>
<<elseif $underclothes is "Y fronts">>
<<if $underintegrity lte ($underintegritymax / 10) * 2>>
<img id="under" class="colour-under" src="img/underclothes/yfronts/yfrontstatteredred.png">
<<elseif $underintegrity lte ($underintegritymax / 10) * 5>>
<img id="under" class="colour-under" src="img/underclothes/yfronts/yfrontstornred.png">
<<elseif $underintegrity lte ($underintegritymax / 10) * 9>>
<img id="under" class="colour-under" src="img/underclothes/yfronts/yfrontsfrayedred.png">
<<else>>
<img id="under" class="colour-under" src="img/underclothes/yfronts/yfrontsred.png">
<</if>>
<<elseif $underclothes is "tights">>
<<if $underintegrity lte ($underintegritymax / 10) * 2>>
<img id="under" src="img/underclothes/tights/tightstattered.png">
<<elseif $underintegrity lte ($underintegritymax / 10) * 5>>
<img id="under" src="img/underclothes/tights/tightstorn.png">
<<elseif $underintegrity lte ($underintegritymax / 10) * 9>>
<img id="under" src="img/underclothes/tights/tightsfrayed.png">
<<else>>
<img id="under" src="img/underclothes/tights/tights.png">
<</if>>
<<elseif $underclothes is "chastity belt">>
<img id="under" src="img/underclothes/chastitybelt/chastitybelt.png">
<<else>>
<</if>>
<</nobr>><</widget>>
<<widget "lowerclothesimg">><<nobr>>
<<if $lowerclothes is "bikini bottoms">>
<img id="lower" class="colour-lower" src="img/lowerclothes/bikinilower/bikinilowerred.gif">
<<elseif $lowerclothes is "pyjama bottoms">>
<<if $lowerintegrity lte ($lowerintegritymax / 10) * 2>>
<img id="lower" class="colour-lower" src="img/lowerclothes/pjslower/pjslowertatteredred.gif">
<<elseif $lowerintegrity lte ($lowerintegritymax / 10) * 5>>
<img id="lower" class="colour-lower" src="img/lowerclothes/pjslower/pjslowertornred.gif">
<<elseif $lowerintegrity lte ($lowerintegritymax / 10) * 9>>
<img id="lower" class="colour-lower" src="img/lowerclothes/pjslower/pjslowerfrayedred.gif">
<<else>>
<img id="lower" class="colour-lower" src="img/lowerclothes/pjslower/pjslowerred.gif">
<</if>>
<<elseif $lowerclothes is "shorts">>
<<if $lowerintegrity lte ($lowerintegritymax / 10) * 2>>
<img id="lower" class="colour-lower" src="img/lowerclothes/shorts/shortstatteredred.gif">
<<elseif $lowerintegrity lte ($lowerintegritymax / 10) * 5>>
<img id="lower" class="colour-lower" src="img/lowerclothes/shorts/shortstornred.gif">
<<elseif $lowerintegrity lte ($lowerintegritymax / 10) * 9>>
<img id="lower" class="colour-lower" src="img/lowerclothes/shorts/shortsfrayedred.gif">
<<else>>
<img id="lower" class="colour-lower" src="img/lowerclothes/shorts/shortsred.gif">
<</if>>
<<elseif $lowerclothes is "sundress skirt">>
<<if $lowerintegrity lte ($lowerintegritymax / 10) * 2>>
<img id="lower" class="colour-lower" src="img/lowerclothes/sundresslower/sundresslowertatteredred.gif">
<<elseif $lowerintegrity lte ($lowerintegritymax / 10) * 5>>
<img id="lower" class="colour-lower" src="img/lowerclothes/sundresslower/sundresslowertornred.gif">
<<elseif $lowerintegrity lte ($lowerintegritymax / 10) * 9>>
<img id="lower" class="colour-lower" src="img/lowerclothes/sundresslower/sundresslowerfrayedred.gif">
<<else>>
<img id="lower" class="colour-lower" src="img/lowerclothes/sundresslower/sundresslowerred.gif">
<</if>>
<<elseif $lowerclothes is "towel">>
<<if $lowerintegrity lte ($lowerintegritymax / 10) * 2>>
<img id="lower" class="colour-lower" src="img/lowerclothes/towellower/towellowertatteredred.gif">
<<elseif $lowerintegrity lte ($lowerintegritymax / 10) * 5>>
<img id="lower" class="colour-lower" src="img/lowerclothes/towellower/towellowertornred.gif">
<<elseif $lowerintegrity lte ($lowerintegritymax / 10) * 9>>
<img id="lower" class="colour-lower" src="img/lowerclothes/towellower/towellowerfrayedred.gif">
<<else>>
<img id="lower" class="colour-lower" src="img/lowerclothes/towellower/towellowerred.gif">
<</if>>
<<elseif $lowerclothes is "waist apron">>
<<if $lowerintegrity lte ($lowerintegritymax / 10) * 2>>
<img id="lower" class="colour-lower" src="img/lowerclothes/waistapron/waistaprontatteredred.gif">
<<elseif $lowerintegrity lte ($lowerintegritymax / 10) * 5>>
<img id="lower" class="colour-lower" src="img/lowerclothes/waistapron/waistaprontornred.gif">
<<elseif $lowerintegrity lte ($lowerintegritymax / 10) * 9>>
<img id="lower" class="colour-lower" src="img/lowerclothes/waistapron/waistapronfrayedred.gif">
<<else>>
<img id="lower" class="colour-lower" src="img/lowerclothes/waistapron/waistapronred.gif">
<</if>>
<<elseif $lowerclothes is "school shorts">>
<<if $lowerintegrity lte ($lowerintegritymax / 10) * 2>>
<img id="lower" class="colour-lower" src="img/lowerclothes/schoolshorts/schoolshortstatteredred.png">
<<elseif $lowerintegrity lte ($lowerintegritymax / 10) * 5>>
<img id="lower" class="colour-lower" src="img/lowerclothes/schoolshorts/schoolshortstornred.png">
<<elseif $lowerintegrity lte ($lowerintegritymax / 10) * 9>>
<img id="lower" class="colour-lower" src="img/lowerclothes/schoolshorts/schoolshortsfrayedred.png">
<<else>>
<img id="lower" class="colour-lower" src="img/lowerclothes/schoolshorts/schoolshortsred.png">
<</if>>
<<elseif $lowerclothes is "school skirt">>
<<if $lowerintegrity lte ($lowerintegritymax / 10) * 2>>
<img id="lower" class="colour-lower" src="img/lowerclothes/schoolskirt/schoolskirttatteredred.gif">
<<elseif $lowerintegrity lte ($lowerintegritymax / 10) * 5>>
<img id="lower" class="colour-lower" src="img/lowerclothes/schoolskirt/schoolskirttornred.gif">
<<elseif $lowerintegrity lte ($lowerintegritymax / 10) * 9>>
<img id="lower" class="colour-lower" src="img/lowerclothes/schoolskirt/schoolskirtfrayedred.gif">
<<else>>
<img id="lower" class="colour-lower" src="img/lowerclothes/schoolskirt/schoolskirtred.gif">
<</if>>
<<elseif $lowerclothes is "school swimsuit bottom">>
<<if $lowerintegrity lte ($lowerintegritymax / 10) * 2>>
<img id="lower" class="colour-lower" src="img/lowerclothes/schoolswimsuitlower/schoolswimsuitlowertatteredred.png">
<<elseif $lowerintegrity lte ($lowerintegritymax / 10) * 5>>
<img id="lower" class="colour-lower" src="img/lowerclothes/schoolswimsuitlower/schoolswimsuitlowertornred.png">
<<elseif $lowerintegrity lte ($lowerintegritymax / 10) * 9>>
<img id="lower" class="colour-lower" src="img/lowerclothes/schoolswimsuitlower/schoolswimsuitlowerfrayedred.png">
<<else>>
<img id="lower" class="colour-lower" src="img/lowerclothes/schoolswimsuitlower/schoolswimsuitlowerred.png">
<</if>>
<<elseif $lowerclothes is "school swim shorts">>
<<if $lowerintegrity lte ($lowerintegritymax / 10) * 2>>
<img id="lower" class="colour-lower" src="img/lowerclothes/schoolswimshorts/schoolswimshortstatteredred.png">
<<elseif $lowerintegrity lte ($lowerintegritymax / 10) * 5>>
<img id="lower" class="colour-lower" src="img/lowerclothes/schoolswimshorts/schoolswimshortstornred.png">
<<elseif $lowerintegrity lte ($lowerintegritymax / 10) * 9>>
<img id="lower" class="colour-lower" src="img/lowerclothes/schoolswimshorts/schoolswimshortsfrayedred.png">
<<else>>
<img id="lower" class="colour-lower" src="img/lowerclothes/schoolswimshorts/schoolswimshortsred.png">
<</if>>
<<elseif $lowerclothes is "evening gown skirt">>
<<if $lowerintegrity lte ($lowerintegritymax / 10) * 2>>
<img id="lower" class="colour-lower" src="img/lowerclothes/eveninggownlower/eveninggownlowertatteredred.gif">
<<elseif $lowerintegrity lte ($lowerintegritymax / 10) * 5>>
<img id="lower" class="colour-lower" src="img/lowerclothes/eveninggownlower/eveninggownlowertornred.gif">
<<elseif $lowerintegrity lte ($lowerintegritymax / 10) * 9>>
<img id="lower" class="colour-lower" src="img/lowerclothes/eveninggownlower/eveninggownlowerfrayedred.gif">
<<else>>
<img id="lower" class="colour-lower" src="img/lowerclothes/eveninggownlower/eveninggownlowerred.gif">
<</if>>
<<elseif $lowerclothes is "plant skirt">>
<img id="lower" src="img/lowerclothes/plantlower/plantlower.gif">
<<else>>
<</if>>
<</nobr>><</widget>>
<<widget "upperclothesimg">><<nobr>>
<<if $upperclothes is "bikini top">>
<img id="upper" class="colour-upper" src="img/upperclothes/bikiniupper/bikiniupperred.gif">
<<elseif $upperclothes is "pyjama shirt">>
<<if $upperintegrity lte ($upperintegritymax / 10) * 2>>
<img id="upper" class="colour-upper" src="img/upperclothes/pjsupper/pjsuppertatteredred.gif">
<<elseif $upperintegrity lte ($upperintegritymax / 10) * 5>>
<img id="upper" class="colour-upper" src="img/upperclothes/pjsupper/pjsuppertornred.gif">
<<elseif $upperintegrity lte ($upperintegritymax / 10) * 9>>
<img id="upper" class="colour-upper" src="img/upperclothes/pjsupper/pjsupperfrayedred.gif">
<<else>>
<img id="upper" class="colour-upper" src="img/upperclothes/pjsupper/pjsupperred.gif">
<</if>>
<<elseif $upperclothes is "sundress">>
<<if $upperintegrity lte ($upperintegritymax / 10) * 2>>
<img id="upper" class="colour-upper" src="img/upperclothes/sundressupper/sundressuppertatteredred.gif">
<<elseif $upperintegrity lte ($upperintegritymax / 10) * 5>>
<img id="upper" class="colour-upper" src="img/upperclothes/sundressupper/sundressuppertornred.gif">
<<elseif $upperintegrity lte ($upperintegritymax / 10) * 9>>
<img id="upper" class="colour-upper" src="img/upperclothes/sundressupper/sundressupperfrayedred.gif">
<<else>>
<img id="upper" class="colour-upper" src="img/upperclothes/sundressupper/sundressupperred.gif">
<</if>>
<<elseif $upperclothes is "towel">>
<<if $upperintegrity lte ($upperintegritymax / 10) * 2>>
<img id="upper" class="colour-upper" src="img/upperclothes/towelupper/toweluppertatteredred.gif">
<<elseif $upperintegrity lte ($upperintegritymax / 10) * 5>>
<img id="upper" class="colour-upper" src="img/upperclothes/towelupper/toweluppertornred.gif">
<<elseif $upperintegrity lte ($upperintegritymax / 10) * 9>>
<img id="upper" class="colour-upper" src="img/upperclothes/towelupper/towelupperfrayedred.gif">
<<else>>
<img id="upper" class="colour-upper" src="img/upperclothes/towelupper/towelupperred.gif">
<</if>>
<<elseif $upperclothes is "t-shirt">>
<<if $upperintegrity lte ($upperintegritymax / 10) * 2>>
<img id="upper" class="colour-upper" src="img/upperclothes/tshirt/tshirttatteredred.gif">
<<elseif $upperintegrity lte ($upperintegritymax / 10) * 5>>
<img id="upper" class="colour-upper" src="img/upperclothes/tshirt/tshirttornred.gif">
<<elseif $upperintegrity lte ($upperintegritymax / 10) * 9>>
<img id="upper" class="colour-upper" src="img/upperclothes/tshirt/tshirtfrayedred.gif">
<<else>>
<img id="upper" class="colour-upper" src="img/upperclothes/tshirt/tshirtred.gif">
<</if>>
<<elseif $upperclothes is "school swimsuit">>
<<if $upperintegrity lte ($upperintegritymax / 10) * 2>>
<img id="upper" class="colour-upper" src="img/upperclothes/schoolswimsuitupper/schoolswimsuituppertatteredred.gif">
<<elseif $upperintegrity lte ($upperintegritymax / 10) * 5>>
<img id="upper" class="colour-upper" src="img/upperclothes/schoolswimsuitupper/schoolswimsuituppertornred.gif">
<<elseif $upperintegrity lte ($upperintegritymax / 10) * 9>>
<img id="upper" class="colour-upper" src="img/upperclothes/schoolswimsuitupper/schoolswimsuitupperfrayedred.gif">
<<else>>
<img id="upper" class="colour-upper" src="img/upperclothes/schoolswimsuitupper/schoolswimsuitupperred.gif">
<</if>>
<<elseif $upperclothes is "school shirt">>
<<if $upperintegrity lte ($upperintegritymax / 10) * 2>>
<img id="upper" class="colour-upper" src="img/upperclothes/schoolshirt/schoolshirttatteredred.gif">
<<elseif $upperintegrity lte ($upperintegritymax / 10) * 5>>
<img id="upper" class="colour-upper" src="img/upperclothes/schoolshirt/schoolshirttornred.gif">
<<elseif $upperintegrity lte ($upperintegritymax / 10) * 9>>
<img id="upper" class="colour-upper" src="img/upperclothes/schoolshirt/schoolshirtfrayedred.gif">
<<else>>
<img id="upper" class="colour-upper" src="img/upperclothes/schoolshirt/schoolshirtred.gif">
<</if>>
<<elseif $upperclothes is "evening gown">>
<<if $upperintegrity lte ($upperintegritymax / 10) * 2>>
<img id="upper" class="colour-upper" src="img/upperclothes/eveninggownupper/eveninggownuppertatteredred.gif">
<<elseif $upperintegrity lte ($upperintegritymax / 10) * 5>>
<img id="upper" class="colour-upper" src="img/upperclothes/eveninggownupper/eveninggownuppertornred.gif">
<<elseif $upperintegrity lte ($upperintegritymax / 10) * 9>>
<img id="upper" class="colour-upper" src="img/upperclothes/eveninggownupper/eveninggownupperfrayedred.gif">
<<else>>
<img id="upper" class="colour-upper" src="img/upperclothes/eveninggownupper/eveninggownupperred.gif">
<</if>>
<<elseif $upperclothes is "tank top">>
<<if $upperintegrity lte ($upperintegritymax / 10) * 2>>
<img id="upper" class="colour-upper" src="img/upperclothes/tanktop/tanktoptatteredred.gif">
<<elseif $upperintegrity lte ($upperintegritymax / 10) * 5>>
<img id="upper" class="colour-upper" src="img/upperclothes/tanktop/tanktoptornred.gif">
<<elseif $upperintegrity lte ($upperintegritymax / 10) * 9>>
<img id="upper" class="colour-upper" src="img/upperclothes/tanktop/tanktopfrayedred.gif">
<<else>>
<img id="upper" class="colour-upper" src="img/upperclothes/tanktop/tanktopred.gif">
<</if>>
<<elseif $upperclothes is "plant top">>
<img id="upper" src="img/upperclothes/plantupper/plantupper.gif">
<<else>>
<</if>>
<<if $rightarm isnot "bound">>
<<if $lowerexposed gte 1 and $exposed gte 2 and $exhibitionism lt 95 or $lowerexposed gte 1 and $exposed gte 1 and $exhibitionism lt 55>>
<<if $upperclothes is "pyjama shirt">>
<img id="rightarmclothes" class="colour-upper" src="img/upperclothes/pjsupper/pjsrightcover/pjsrightcoverred.png">
<<elseif $upperclothes is "t-shirt">>
<img id="rightarmclothes" class="colour-upper" src="img/upperclothes/tshirt/tshirtrightcover/tshirtrightcoverred.png">
<<elseif $upperclothes is "school shirt">>
<img id="rightarmclothes" class="colour-upper" src="img/upperclothes/schoolshirt/schoolshirtcover/schoolshirtcoverred.png">
<<elseif $upperclothes is "tank top">>
<img id="rightarmclothes" class="colour-upper" src="img/upperclothes/tanktop/tanktoprightcover/tanktoprightcoverred.png">
<<else>>
<</if>>
<<else>>
<<if $upperclothes is "pyjama shirt">>
<img id="upper" class="colour-upper" src="img/upperclothes/pjsupper/pjsrightarm/pjsrightarmred.png">
<<elseif $upperclothes is "t-shirt">>
<img id="upper" class="colour-upper" src="img/upperclothes/tshirt/tshirtrightarm/tshirtrightarmred.png">
<<elseif $upperclothes is "school shirt">>
<img id="upper" class="colour-upper" src="img/upperclothes/schoolshirt/schoolshirtrightarm/schoolshirtrightarmred.png">
<<else>>
<</if>>
<</if>>
<</if>>
<<if $leftarm isnot "bound">>
<<if $upperexposed gte 1 and $exposed gte 2 and $exhibitionism lt 95 or $upperexposed gte 1 and $exposed gte 1 and $exhibitionism lt 55>>
<<else>>
<<if $upperclothes is "pyjama shirt">>
<img id="upper" class="colour-upper" src="img/upperclothes/pjsupper/pjsleftarm/pjsleftarmred.png">
<<elseif $upperclothes is "t-shirt">>
<img id="upper" class="colour-upper" src="img/upperclothes/tshirt/tshirtleftarm/tshirtleftarmred.png">
<<elseif $upperclothes is "school shirt">>
<img id="upper" class="colour-upper" src="img/upperclothes/schoolshirt/schoolshirtleftarm/schoolshirtleftarmred.png">
<<else>>
<</if>>
<</if>>
<</if>>
<</nobr>><</widget>>
|
QuiltedQuail/degrees
|
game/base-clothing.twee
|
twee
|
unknown
| 134,885 |
:: Widgets Combat Man [widget]
<<widget "man1">><<nobr>>
<<if $pronoun1 is "m">>
<<set $pronoun to "m">>
<</if>>
<<if $pronoun1 is "f">>
<<set $pronoun to "f">>
<</if>>
<<if $pronoun1 is "i">>
<<set $pronoun to "i">>
<</if>>
<<if $pronoun1 is "n">>
<<set $pronoun to "n">>
<</if>>
<<if $pronoun1 is "t">>
<<set $pronoun to "t">>
<</if>>
<<man1speech>>
<<if $enemyno gte 2>><<set $intro1 to 1>><</if>>
<<if $lefthand is "spank">><<bruise bottom>><<hitstat>><<set $speechspank to 1>>
<<He>> spanks your <<bottom>>
<<if $lowerclothes isnot "naked" and $lowerstate is "waist">>
through your $lowerclothes.
<<elseif $underclothes isnot "naked" and $understate is "waist">>
through your $underclothes.
<<else>>
reddening your exposed skin.
<</if>>
<<violence 5>>
<</if>>
<<if $righthand is "spank">><<bruise bottom>><<hitstat>>
<<He>> spanks your <<bottom>><<set $speechspank to 1>>
<<if $lowerclothes isnot "naked" and $lowerstate is "waist">>
through your $lowerclothes.
<<elseif $underclothes isnot "naked" and $understate is "waist">>
through your $underclothes.
<<else>>
reddening your exposed skin.
<</if>>
<<violence 5>>
<</if>>
<<if $lefthand is "arms">>
<<if $enemytrust gte 20 and $enemyanger lte 20>><span class="lblue"><<He>> releases your arms.</span><<set $lefthand to 0>><<set $leftarm to 0>><<set $rightarm to 0>>
<<else>><<He>> grips your arms.
<<violence 6>><<bruise leftarm>><<bruise rightarm>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand is "arms">>
<<if $enemytrust gte 20 and $enemyanger lte 20>><span class="lblue"><<He>> releases your arms.</span><<set $righthand to 0>><<set $leftarm to 0>><<set $rightarm to 0>>
<<else>><<He>> grips your arms.
<<violence 6>><<bruise leftarm>><<bruise rightarm>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand is "leftarm">>
<<if $enemytrust gte 20 and $enemyanger lte 20>><span class="lblue"><<He>> releases your left arm.</span><<set $lefthand to 0>><<set $leftarm to 0>>
<<else>><<He>> grips your left arm.<<violence 3>><<bruise leftarm>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand is "leftarm">>
<<if $enemytrust gte 20 and $enemyanger lte 20>><span class="lblue"><<He>> releases your left arm.</span><<set $righthand to 0>><<set $leftarm to 0>>
<<else>><<He>> grips your left arm.<<violence 3>><<bruise leftarm>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand is "rightarm">>
<<if $enemytrust gte 20 and $enemyanger lte 20>><span class="lblue"><<He>> releases your right arm.</span><<set $lefthand to 0>><<set $rightarm to 0>>
<<else>><<He>> grips your right arm.<<violence 3>><<bruise rightarm>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand is "rightarm">>
<<if $enemytrust gte 20 and $enemyanger lte 20>><span class="lblue"><<He>> releases your right arm.</span><<set $righthand to 0>><<set $rightarm to 0>>
<<else>><<He>> grips your right arm.<<violence 3>><<bruise rightarm>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand is "vaginaentrance">>
<<if $rng gte 101>><span class="blue"><<He>> moves <<his>> left hand away from your <<pussystop>></span><<set $lefthand to 0>><<set $vaginause to 0>>
<<elseif $rng gte 81>><<He>> <<strokes>> your labia.<<neutral 10>>
<<elseif $rng gte 21>><<He>> gives your clitoris a tweak.<<set $speechclit to 1>><<neutral 10>>
<<elseif $rng lte 20>><span class="pink"><<He>> plunges a finger into your <<pussystop>></span><<neutral 15>><<set $lefthand to "vagina">><<set $speechvagina to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand is "vaginaentrance">>
<<if $rng gte 101>><span class="blue"><<He>> moves <<his>> right hand away from your <<pussystop>></span><<set $righthand to 0>><<set $vaginause to 0>>
<<elseif $rng gte 51>><<He>> <<strokes>> your labia.<<neutral 10>>
<<elseif $rng gte 21>><<He>> gives your clitoris a tweak.<<neutral 10>><<set $speechclit to 1>>
<<elseif $rng lte 20>><span class="pink"><<He>> plunges a finger into your warm <<pussystop>></span><<neutral 15>><<set $righthand to "vagina">><<set $speechvagina to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand is "penisentrance">>
<<if $rng gte 101>><span class="blue"><<He>> moves <<his>> left hand away from your <<penisstop>></span><<set $lefthand to 0>><<set $penisuse to 0>>
<<elseif $rng gte 51>><<He>> <<strokes>> your shaft.<<neutral 10>>
<<elseif $rng gte 21>><<He>> rubs your glans.<<neutral 10>><<set $speechglans to 1>>
<<elseif $rng lte 20>><span class="pink"><<He>> wraps <<his>> fingers around your <<penisstop>></span><<neutral 15>><<set $lefthand to "penis">><<set $speechpenis to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand is "penisentrance">>
<<if $rng gte 101>><span class="blue"><<He>> moves <<his>> right hand away from your <<penisstop>></span><<set $righthand to 0>><<set $penisuse to 0>>
<<elseif $rng gte 51>><<He>> <<strokes>> your shaft.<<neutral 10>>
<<elseif $rng gte 21>><<He>> rubs your glans.<<neutral 10>><<set $speechglans to 1>>
<<elseif $rng lte 20>><span class="pink"><<He>> wraps <<his>> fingers around your penis.</span><<neutral 15>><<set $righthand to "penis">><<set $speechpenis to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand is "vagina">>
<<if $rng gte 101>><span class="purple"><<He>> slides <<his>> finger out of your <<pussystop>></span><<set $lefthand to "vaginaentrance">><<neutral 15>>
<<elseif $rng lte 100>><<He>> <<strokes>> the inside of your <<pussycomma>><<neutral 20>><<set $speechvagina to 1>>
<<if $arousal gte 8000>>
causing involuntary shudders.
<<elseif $arousal gte 2000>>
coaxing out lewd fluid.
<<else>>
eager to explore it.
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand is "vagina">>
<<if $rng gte 101>><span class="purple"><<He>> slides <<his>> finger out of your <<pussystop>></span><<set $righthand to "vaginaentrance">><<neutral 15>>
<<elseif $rng lte 100>><<He>> <<strokes>> the inside of your <<pussycomma>><<neutral 20>><<set $speechvagina to 1>>
<<if $arousal gte 8000>>
causing you involuntary shudders.
<<elseif $arousal gte 2000>>
coaxing out lewd fluid.
<<else>>
invading your body in a most sordid manner.
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand is "penis">>
<<if $rng gte 101>><span class="purple"><<He>> releases your <<penis>> from <<his>> grip.</span><<set $lefthand to "penisentrance">><<neutral 15>>
<<elseif $rng lte 100>><<He>> massages the length of your <<peniscomma>><<neutral 20>><<set $speechpenis to 1>>
<<if $arousal gte 8000>>
causing you involuntary shudders.
<<elseif $arousal gte 2000>>
coaxing out lewd fluid.
<<else>>
exploiting your body's natural reactions in a most sordid manner.
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand is "penis">>
<<if $rng gte 101>><span class="purple"><<He>> releases your <<penis>> from <<his>> grip.</span><<set $righthand to "penisentrance">><<neutral 15>>
<<elseif $rng lte 100>><<He>> massages the length of your <<peniscomma>><<neutral 20>><<set $speechpenis to 1>>
<<if $arousal gte 8000>>
causing you involuntary shudders.
<<elseif $arousal gte 2000>>
coaxing out lewd fluid.
<<else>>
exploiting your body's natural reactions in a most sordid manner.
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand is "anusentrance">>
<<if $rng gte 101>><span class="blue"><<He>> moves <<his>> left hand away from your ass.</span><<set $lefthand to 0>><<set $vaginause to 0>>
<<elseif $rng gte 21>><<He>> <<strokes>> your anus.<<neutral 10>>
<<elseif $rng lte 20>><span class="pink"><<He>> plunges a finger into your ass.</span><<neutral 15>><<set $lefthand to "anus">><<set $speechanus to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand is "anusentrance">>
<<if $rng gte 101>><span class="blue"><<He>> moves <<his>> hand away from your ass.</span><<set $righthand to 0>><<set $vaginause to 0>>
<<elseif $rng gte 21>><<He>> <<strokes>> your anus.<<neutral 10>>
<<elseif $rng lte 20>><span class="pink"><<He>> plunges a finger into your ass.</span><<neutral 15>><<set $righthand to "anus">><<set $speechanus to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand is "anus">>
<<if $rng gte 101>><span class="purple"><<He>> slides <<his>> finger out of your ass.</span><<set $lefthand to "anusentrance">><<neutral 15>>
<<elseif $rng lte 100>><<He>> rhythmically slides <<his>> finger in and out of your ass,<<neutral 20>><<set $speechanus to 1>>
<<if $playergender is "m">>
teasing your prostate.
<<else>>
teasing your anus.
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand is "anus">>
<<if $rng gte 101>><span class="purple"><<He>> slides <<his>> finger out of your ass.</span><<set $righthand to "anusentrance">><<neutral 15>>
<<elseif $rng lte 100>><<He>> rhythmically slides <<his>> finger in and out of your ass,<<neutral 20>><<set $speechanus to 1>>
<<if $playergender is "m">>
teasing your prostate.
<<else>>
teasing your anus.
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand is "mouth">>
<<if $enemyanger lte 20 and $enemytrust gte 20>><span class="teal">Made confident by your accommodating behaviour, <<he>> releases <<his>> hand from your mouth.</span><<set $lefthand to 0>><<set $mouthuse to 0>>
<<else>><<He>> continues to clasp your mouth shut.<<violence 1>><<bruise face>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand is "mouth">>
<<if $enemyanger lte 20 and $enemytrust gte 20>><span class="teal">Made confident by your accommodating behaviour, <<he>> releases <<his>> hand from your mouth.</span><<set $righthand to 0>><<set $mouthuse to 0>>
<<else>><<He>> continues to clasp your mouth shut.<<violence 1>><<bruise face>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand is "throat">>
<<if $enemyanger gte 100>><<set $strangle += 1>>
<<if $strangle is 0>><<He>> strangles your throat.<<violence 5>><<bruise neck>><<bruise neck>><<set $speechthroat to 1>>
<<elseif $strangle lte 2>><span class="purple"><<He>> strangles your throat. You can't breathe!</span><<set $speechthroat to 1>>
<<violence 10>><<bruise neck>><<bruise neck>>
<<elseif $strangle lte 4>><span class="pink"><<He>> strangles your throat. You feel light-headed.</span><<set $speechthroat to 1>>
<<violence 20>><<bruise neck>><<bruise neck>>
<<elseif $strangle lte 6>><span class="pink"><<He>> strangles your throat. You see stars.</span><<set $speechthroat to 1>>
<<violence 40>><<bruise neck>><<bruise neck>>
<<elseif $strangle gte 8>><span class="red"><<He>> strangles your throat. You are suffocating.</span><<set $speechthroat to 1>>
<<violence 100>><<bruise neck>><<bruise neck>>
<</if>>
<<elseif $rng gte 81>><span class="teal"><<He>> releases <<his>> hand from your throat.</span> You gasp for air.
<<set $lefthand to 0>>
<<else>><<He>> holds you down by your throat.<<violence 1>>
<</if>><<bruise neck>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand is "throat">>
<<if $enemyanger gte 100>><<set $strangle += 1>>
<<if $strangle is 0>><<He>> strangles your throat.<<violence 5>><<bruise neck>><<bruise neck>><<set $speechthroat to 1>>
<<elseif $strangle lte 2>><<He>> strangles your throat. <span class="purple">You can't breathe!</span><<set $speechthroat to 1>>
<<violence 10>><<bruise neck>><<bruise neck>>
<<elseif $strangle lte 4>><<He>> strangles your throat. <span class="pink">You feel light-headed.</span><<set $speechthroat to 1>>
<<violence 20>><<bruise neck>><<bruise neck>>
<<elseif $strangle lte 6>><<He>> strangles your throat. <span class="pink">You see stars.</span> <<set $speechthroat to 1>>
<<violence 40>><<bruise neck>><<bruise neck>>
<<elseif $strangle gte 7>><<He>> strangles your throat. <span class="red">You are suffocating.</span><<set $speechthroat to 1>>
<<violence 100>><<bruise neck>><<bruise neck>>
<</if>>
<<elseif $rng gte 81>><span class="teal"><<He>> releases <<his>> hand from your throat.</span> You gasp for air.
<<set $righthand to 0>>
<<else>><<He>> holds you down by your throat.<<violence 1>>
<</if>><<bruise neck>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand is "underclothes" and $undertype is "chastity">>
<span class="blue"><<He>> tries to loosen your $underclothes.</span> <<His>> rough handling leaves you feeling more frustrated and aroused. <<He>> gives up after a few moments of impotent tugging, looking disappointed.<<neutral 1>><<set $enemyanger += 5>><<set $arousal += 5>><<set $lefthand to 0>><<set $speechchastity to 1>><<set $underintegrity -= 10>>
<</if>>
<<if $righthand is "underclothes" and $undertype is "chastity">>
<span class="blue"><<He>> tries to loosen your $underclothes.</span> <<His>> rough handling leaves you feeling more frustrated and aroused.<<He>> gives up after a few moments of impotent tugging, looking disappointed.<<neutral 1>><<set $enemyanger += 5>><<set $arousal += 5>><<set $righthand to 0>><<set $speechchastity to 1>><<set $underintegrity -= 10>>
<</if>>
<<if $lefthand is "underclothes">>
<<if $underclothes is "naked">><span class="purple"><<He>> casts aside the fabric.</span><<set $lefthand to 0>>
<<elseif $understruggle is 1>>You manage to keep <<him>> from pulling down your $underclothes.<<set $understruggle to 0>><<set $speechstripstruggle to 1>>
<<elseif $rng gte 101>><span class="blue"><<He>> releases <<his>> hand from your $underclothes.</span><<set $lefthand to 0>>
<<elseif $rng lte 100>>
<<if $skirt is 1>>
<<if $understate is "waist">><<He>> pulls your $underclothes down your thighs, <span class="lewd">revealing your <<genitalsstop>></span><<set $understate to "thighs">><<neutral 5>><<set $undervaginaexposed to 1>><<set $underanusexposed to 1>><<set $underexposed to 1>><<set $speechgenitals to 1>>
<<elseif $understate is "thighs">><<He>> pulls your $underclothes down to your knees.<<set $understate to "knees">><<neutral 1>>
<<elseif $understate is "knees">><<He>> pulls your $underclothes down to your ankles.<<set $understate to "ankles">><<neutral 1>>
<<elseif $understate is "ankles">><span class="purple"><<He> pulls your $underclothes off your legs.</span><<understrip>><<undernaked>><<neutral 3>><<set $lefthand to 0>><<clothesstripstat>>
<</if>>
<<elseif $lowerstate isnot "waist">>
<<if $understate is "waist">><<He>> pulls your $underclothes down your thighs, <span class="lewd">revealing your <<genitalsstop>></span><<set $understate to "thighs">><<neutral 5>><<set $undervaginaexposed to 1>><<set $underanusexposed to 1>><<set $underexposed to 1>><<set $speechgenitals to 1>>
<<elseif $understate is "thighs">><<He>> pulls your $underclothes down to your knees.<<set $understate to "knees">><<neutral 1>>
<<elseif $understate is "knees">><<He>> pulls your $underclothes down to your ankles.<<set $understate to "ankles">><<neutral 5>>
<<elseif $understate is "ankles">><span class="purple"><<He>> pulls your $underclothes off your legs.</span><<understrip>><<undernaked>><<neutral 3>><<set $lefthand to 0>><<clothesstripstat>>
<</if>>
<<else>><<He>> tugs on your $underclothes.<<neutral 1>><<set $underintegrity -= 10>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand is "underclothes">>
<<if $underclothes is "naked">><span class="purple"><<He>> casts aside the fabric.</span><<set $righthand to 0>>
<<elseif $understruggle is 1>>You manage to keep <<him>> from pulling down your $underclothes.<<set $understruggle to 0>><<set $speechstripstruggle to 1>>
<<elseif $rng gte 101>><span class="purple"><<He>> releases <<his>> hand from your $underclothes.</span><<set $righthand to 0>><<set $skirtuse to 0>>
<<elseif $rng lte 100>>
<<if $skirt is 1>>
<<if $understate is "waist">><<He>> pulls your $underclothes down your thighs, <span class="lewd">revealing your <<genitalsstop>></span><<set $understate to "thighs">><<neutral 5>><<set $undervaginaexposed to 1>><<set $underanusexposed to 1>><<set $underexposed to 1>><<set $speechgenitals to 1>>
<<elseif $understate is "thighs">><<He>> pulls your $underclothes down to your knees.<<set $understate to "knees">><<neutral 1>>
<<elseif $understate is "knees">><<He>> pulls your $underclothes down to your ankles.<<set $understate to "ankles">><<neutral 1>>
<<elseif $understate is "ankles">><span class="purple"><<He>> pulls your $underclothes off your legs.</span><<understrip>><<undernaked>><<neutral 3>><<set $righthand to 0>><<clothesstripstat>>
<</if>>
<<elseif $lowerstate isnot "waist">>
<<if $understate is "waist">><<He>> pulls your $underclothes down your thighs, <span class="lewd">revealing your <<genitalsstop>></span><<set $understate to "thighs">><<neutral 5>><<set $undervaginaexposed to 1>><<set $underanusexposed to 1>><<set $underexposed to 1>><<set $speechgenitals to 1>>
<<elseif $understate is "thighs">><<He>> pulls your $underclothes down to your knees.<<set $understate to "knees">><<neutral 1>>
<<elseif $understate is "knees">><<He>> pulls your $underclothes down to your ankles.<<set $understate to "ankles">><<neutral 5>>
<<elseif $understate is "ankles">><span class="purple"><<He>> pulls your $underclothes off your legs.</span><<understrip>><<undernaked>><<neutral 3>><<set $righthand to 0>><<clothesstripstat>>
<</if>>
<<else>><<He>> tugs on your $underclothes.<<neutral 1>><<set $underintegrity -= 10>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand is "hair">>
<<if $rng gte 101>><span class="lblue"><<He>> releases <<his>> hand from your hair.</span><<set $lefthand to 0>>
<<elseif $enemyanger gte 61>>With your hair in <<his>> grip, <<he>> yanks back your head.<<violence 4>><<set $speechhair to 1>>
<<elseif $enemyanger gte 21>>
<<He>> strokes your hair while holding it bunched in <<his>> grip.<<set $speechhair to 1>><<neutral 1>>
<<else>><span class="lblue"><<He>> releases <<his>> hand from your hair.</span><<set $lefthand to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand is "hair">>
<<if $rng gte 101>><span class="lblue"><<He>> releases <<his>> hand from your hair.</span><<set $righthand to 0>>
<<elseif $enemyanger gte 61>>With your hair in <<his>> grip, <<he>> yanks back your head.<<violence 4>><<set $speechhair to 1>>
<<elseif $enemyanger gte 21>>
<<He>> strokes your hair while holding it bunched in <<his>> grip.<<set $speechhair to 1>><<neutral 1>>
<<else>><span class="lblue"><<He>> releases <<his>> hand from your hair.</span><<set $righthand to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand is "lowerclothes">>
<<if $lowerclothes is "naked">><span class="purple"><<He>> casts aside the fabric.</span><<set $lefthand to 0>>
<<elseif $lowerstruggle is 1>><<set $lowerstruggle to 0>>You manage to keep <<him>> from stripping you of your $lowerclothes.<<set $speechstripstruggle to 1>>
<<elseif $rng gte 101>><<He>> releases <<his>> hand from your
$lowerclothes.<<set $lefthand to 0>>
<<elseif $rng lte 100>>
<<if $skirt is 1>>
<<if $skirtdown is 1>><<He>> lifts up your skirt,
exposing your
<<if $understate is "waist">>$underclothes.<<neutral 2>>
<<else>><span class="lewd"><<genitalsstop>></span><<neutral 5>><<set $speechgenitals to 1>>
<</if>><<set $skirtdown to 0>><<set $lowervaginaexposed to 1>><<set $loweranusexposed to 1>><<set $lowerexposed to 2>>
<<elseif $skirtdown is 0>>
<<if $lowerset is $upperset>>
<<if $upperstate is "waist">>
<<if $position is "wall">>
<<He>> tugs at your $upperclothes, tearing <<upperit>> before <span class="blue">letting go.</span><<set $lefthand to 0>><<neutral 1>><<set $lowerintegrity -= 10>>
<<else>>
<<He>> lifts your $upperclothes above your midriff.<<set $lowerstate to "midriff">><<set $upperstate to "midriff">><<neutral 1>>
<<if $upperstatetop is "waist">>
<<set $upperstatetop to "midriff">>
<</if>>
<</if>>
<<elseif $upperstate is "midriff">><<He>> lifts up your $upperclothes, <span class="lewd">exposing your <<breastsstop>></span><<set $lowerstate to "chest">><<set $upperstate to "chest">><<neutral 2>><<set $upperexposed to 2>><<set $speechbreasts to 1>>
<<if $upperstatetop is "midriff">>
<<set $upperstatetop to "chest">>
<</if>>
<<elseif $upperstate is "chest">><span class="purple"><<He>> pulls your $upperclothes off completely.</span><<lowerstrip>><<upperstrip>><<set $lowerstate to 0>><<set $upperstate to 0>><<uppernaked>><<lowernaked>><<set $lefthand to 0>><<neutral 3>><<clothesstripstat>>
<<if $upperstatetop is "chest">>
<<set $upperstatetop to 0>>
<</if>>
<</if>>
<<elseif $lowerset isnot $upperset>>
<<if $lowerstate is "waist">><<He>> pulls your $lowerclothes down to your thighs.
<<neutral 1>><<set $lowerstate to "thighs">>
<<elseif $lowerstate is "thighs">><<He>> pulls your $lowerclothes down to your knees.<<set $lowerstate to "knees">><<neutral 1>>
<<elseif $lowerstate is "knees">><<He>> pulls your $lowerclothes down to your ankles.<<set $lowerstate to "ankles">><<neutral 1>>
<<elseif $lowerstate is "ankles">><span class="purple"><<He>> completely pulls your $lowerclothes off your legs.</span><<lowerstrip>><<lowernaked>><<set $lefthand to 0>><<neutral 3>><<clothesstripstat>>
<</if>>
<</if>>
<</if>>
<<elseif $upperset is $lowerset>>
<<if $open is 1>>
<<if $upperstatetop is "chest">><<He>> tugs your $lowerclothes, pulling down your $upperclothes and <span class="lewd">revealing your <<breastsstop>></span><<set $upperstatetop to "midriff">><<neutral 3>><<set $upperexposed to 2>><<set $speechbreasts to 1>>
<<if $upperstate is "chest">>
<<set $upperstate to "midriff">>
<</if>>
<<if $lowerstate is "chest">>
<<set $lowerstate to "midriff">>
<</if>>
<<elseif $upperstatetop is "midriff">><<He>> tugs your $lowerclothes, pulling down your $upperclothes passed your midriff.<<set $upperstatetop to "waist">><<neutral 1>>
<<if $upperstate is "midriff">>
<<set $upperstate to "waist">>
<</if>>
<<if $lowerstate is "midriff">>
<<set $lowerstate to "waist">>
<</if>>
<<elseif $upperstatetop is "waist">><<He>> pulls your $upperclothes down to your thighs, revealing your
<<if $understate is "waist">>$underclothes<<neutral 2>>
<<else>><span class="lewd"><<genitalsstop>></span><<neutral 5>><<set $speechgenitals to 1>>
<</if>>
<<set $lowervaginaexposed to 1>><<set $loweranusexposed to 1>>
<<set $upperstatetop to "thighs">>
<<set $upperstate to "thighs">>
<<if $lowerstate is "waist">>
<<set $lowerstate to "thighs">>
<</if>>
<<elseif $upperstatetop is "thighs">><<He>> pulls your $upperclothes down to your knees.<<set $upperstatetop to "knees">><<set $upperstate to "knees">><<neutral 1>>
<<if $lowerstate is "thighs">>
<<set $lowerstate to "knees">>
<</if>>
<<elseif $upperstatetop is "knees">><<He>> pulls your $upperclothes down to your ankles.<<set $upperstatetop to "ankles">><<set $upperstate to "ankles">><<neutral 1>>
<<if $lowerstate is "knees">>
<<set $lowerstate to "ankles">>
<</if>>
<<elseif $upperstatetop is "ankles">><span class="purple"><<He>> pulls your $upperclothes off the bottom of your legs.</span><<upperstrip>><<neutral 5>><<set $upperstatetop to 0>><<set $upperstate to 0>><<uppernaked>>
<<if $lowerstate is "ankles">>
<<set $lowerstate to 0>><<lowerstrip>><<lowernaked>>
<</if>>
<</if>>
<<else>>
<<He>> tugs at your $lowerclothes, tearing <<lowerit>> before <span class="blue">letting go.</span><<set $lefthand to 0>><<set $lowerintegrity -= 10>><<neutral 1>>
<</if>>
<<elseif $upperset isnot $lowerset>>
<<if $lowerstate is "waist">><<He>> pulls down your $lowerclothes, exposing your
<<if $understate is "waist">>$underclothes.<<neutral 2>><<set $lowervaginaexposed to 1>><<set $loweranusexposed to 1>><<set $lowerexposed to 2>>
<<else>><span class="lewd"><<genitalsstop>></span><<neutral 5>><<set $speechgenitals to 1>>
<</if>>
<<set $lowervaginaexposed to 1>><<set $loweranusexposed to 1>><<set $lowerexposed to 2>>
<<set $lowerstate to "thighs">>
<<elseif $lowerstate is "thighs">><<He>> pulls your $lowerclothes down to your knees.<<set $lowerstate to "knees">><<neutral 1>>
<<elseif $lowerstate is "knees">><<He>> pulls your $lowerclothes down to your ankles.<<set $lowerstate to "ankles">><<neutral 1>>
<<elseif $lowerstate is "ankles">><span class="purple"><<He>> completely pulls your $lowerclothes off your legs.</span><<lowerstrip>><<lowernaked>><<set $lefthand to 0>><<neutral 3>><<clothesstripstat>>
<</if>>
<<else>><<He>> tugs at your $lowerclothes, tearing <<lowerit>> before <span class="blue">letting go.</span><<set $lefthand to 0>><<neutral 1>><<set $lowerintegrity -= 10>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand is "lowerclothes">>
<<if $lowerclothes is "naked">><span class="purple"><<He>> casts aside the fabric.</span><<set $righthand to 0>>
<<elseif $lowerstruggle is 1>><<set $lowerstruggle to 0>>You manage to keep <<him>> from stripping you of your $lowerclothes.<<set $speechstripstruggle to 1>>
<<elseif $rng gte 101>><span class="lblue"><<He>> releases <<his>> hand from your
$lowerclothes.</span><<set $righthand to 0>>
<<elseif $rng lte 100>>
<<if $skirt is 1>>
<<if $skirtdown is 1>><<He>> lifts up your skirt,
exposing your
<<if $understate is "waist">>$underclothes.<<neutral 2>>
<<else>><span class="lewd"><<genitalsstop>></span><<neutral 5>><<set $speechgenitals to 1>>
<</if>><<set $skirtdown to 0>><<set $lowervaginaexposed to 1>><<set $loweranusexposed to 1>><<set $lowerexposed to 2>>
<<elseif $skirtdown is 0>>
<<if $lowerset is $upperset>>
<<if $upperstate is "waist">>
<<if $position is "wall">>
<<He>> tugs at your $upperclothes, tearing <<upperit>> before <span class="blue">letting go.</span><<set $righthand to 0>><<neutral 1>><<set $lowerintegrity -= 10>>
<<else>>
<<He>> lifts your $upperclothes above your midriff.<<set $lowerstate to "midriff">><<set $upperstate to "midriff">><<neutral 1>>
<<if $upperstatetop is "waist">>
<<set $upperstatetop to "midriff">>
<</if>>
<</if>>
<<elseif $upperstate is "midriff">><<He>> lifts up your $upperclothes, <span class="lewd">exposing your <<breastsstop>></span><<set $lowerstate to "chest">><<set $upperstate to "chest">><<neutral 2>><<set $upperexposed to 2>><<set $speechbreasts to 1>>
<<if $upperstatetop is "midriff">>
<<set $upperstatetop to "chest">>
<</if>>
<<elseif $upperstate is "chest">><span class="purple"><<He>> pulls your $upperclothes off completely.</span><<set $lowerstate to 0>><<set $upperstate to 0>><<lowerstrip>><<upperstrip>><<uppernaked>><<lowernaked>><<set $righthand to 0>><<neutral 3>><<clothesstripstat>>
<<if $upperstatetop is "chest">>
<<set $upperstatetop to 0>>
<</if>>
<</if>>
<<elseif $lowerset isnot $upperset>>
<<if $lowerstate is "waist">><<He>> pulls your $lowerclothes down to your thighs.
<<neutral 1>><<set $lowerstate to "thighs">>
<<elseif $lowerstate is "thighs">><<He>> pulls your $lowerclothes down to your knees.<<set $lowerstate to "knees">><<neutral 1>>
<<elseif $lowerstate is "knees">><<He>> pulls your $lowerclothes down to your ankles.<<set $lowerstate to "ankles">><<neutral 1>>
<<elseif $lowerstate is "ankles">><span class="purple"><<He>> pulls your $lowerclothes off your legs.</span><<lowerstrip>><<lowernaked>><<set $righthand to 0>><<neutral 3>><<clothesstripstat>>
<</if>>
<</if>>
<</if>>
<<elseif $upperset is $lowerset>>
<<if $open is 1>>
<<if $upperstatetop is "chest">><<He>> tugs your $lowerclothes, pulling down your $upperclothes and <span class="lewd">revealing your <<breastsstop>></span><<set $upperstatetop to "midriff">><<neutral 3>><<set $upperexposed to 2>><<set $speechbreasts to 1>>
<<if $upperstate is "chest">>
<<set $upperstate to "midriff">>
<</if>>
<<if $lowerstate is "chest">>
<<set $lowerstate to "midriff">>
<</if>>
<<elseif $upperstatetop is "midriff">><<He>> tugs your $lowerclothes, pulling down your $upperclothes pass your midriff.<<set $upperstatetop to "waist">><<neutral 1>>
<<if $upperstate is "midriff">>
<<set $upperstate to "waist">>
<</if>>
<<if $lowerstate is "midriff">>
<<set $lowerstate to "waist">>
<</if>>
<<elseif $upperstatetop is "waist">><<He>> pulls your $upperclothes down to your thighs, revealing your
<<if $understate is "waist">>$underclothes<<neutral 2>>
<<else>><span class="lewd"><<genitalsstop>></span><<neutral 5>><<set $speechgenitals to 1>>
<</if>>
<<set $lowervaginaexposed to 1>><<set $loweranusexposed to 1>><<set $lowerexposed to 2>>
<<set $upperstatetop to "thighs">><<set $upperstate to "thighs">>
<<if $lowerstate is "waist">>
<<set $lowerstate to "thighs">>
<</if>>
<<elseif $upperstatetop is "thighs">><<He>> pulls your $upperclothes down to your knees.<<set $upperstatetop to "knees">><<set $upperstate to "knees">><<neutral 1>>
<<if $lowerstate is "thighs">>
<<set $lowerstate to "knees">>
<</if>>
<<elseif $upperstatetop is "knees">><<He>> pulls your $upperclothes down to your ankles.<<set $upperstatetop to "ankles">><<set $upperstate to "ankles">><<neutral 1>>
<<if $lowerstate is "knees">>
<<set $lowerstate to "ankles">>
<</if>>
<<elseif $upperstatetop is "ankles">><span class="purple"><<He>> pulls your $upperclothes off the bottom of your legs.</span><<upperstrip>><<neutral 5>><<set $upperstatetop to 0>><<set $upperstate to 0>><<uppernaked>>
<<if $lowerstate is "ankles">>
<<set $lowerstate to 0>><<lowerstrip>><<lowernaked>>
<</if>>
<</if>>
<<else>>
<<He>> tugs at your $lowerclothes, tearing <<lowerit>> before <span class="blue">letting go.</span><<set $righthand to 0>><<set $lowerintegrity -= 10>><<neutral 1>>
<</if>>
<<elseif $upperset isnot $lowerset>>
<<if $lowerstate is "waist">><<He>> pulls down your $lowerclothes, exposing your
<<if $understate is "waist">>$underclothes.<<neutral 2>><<set $lowervaginaexposed to 1>><<set $loweranusexposed to 1>>
<<else>><span class="lewd"><<genitalsstop>></span><<neutral 5>><<set $speechgenitals to 1>>
<</if>>
<<set $lowervaginaexposed to 1>><<set $loweranusexposed to 1>><<set $lowerexposed to 2>>
<<set $lowerstate to "thighs">>
<<elseif $lowerstate is "thighs">><<He>> pulls your $lowerclothes down to your knees.<<set $lowerstate to "knees">><<neutral 1>>
<<elseif $lowerstate is "knees">><<He>> pulls your $lowerclothes down to your ankles.<<set $lowerstate to "ankles">><<neutral 1>>
<<elseif $lowerstate is "ankles">><span class="purple"><<He>> pulls your $lowerclothes off your legs.</span><<lowerstrip>><<lowernaked>><<set $righthand to 0>><<neutral 3>><<clothesstripstat>>
<</if>>
<<else>>
<<He>> tugs at your $lowerclothes, tearing <<lowerit>> before <span class="blue">letting go.</span><<set $righthand to 0>><<neutral 1>><<set $lowerintegrity -= 10>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand is "upperclothes">>
<<if $upperclothes is "naked">><span class="purple"><<He>> casts aside the fabric.</span><<set $lefthand to 0>>
<<elseif $upperstruggle is 1>><<set $upperstruggle to 0>>You manage to keep <<him>> from stripping you of your $upperclothes.<<set $speechstripstruggle to 1>>
<<elseif $rng gte 101>><span class="lblue"><<He>> releases <<his>> hand from your $upperclothes.</span><<set $lefthand to 0>>
<<elseif $rng lte 100>>
<<if $upperset isnot $lowerset>>
<<if $open is 1>>
<<if $upperstatetop is "chest">><<He>> pulls down your $upperclothes, <span class="lewd">revealing your <<breastsstop>></span><<set $upperstatetop to "midriff">><<neutral 3>><<set $upperexposed to 2>><<set $speechbreasts to 1>>
<<if $upperstate is "chest">>
<<set $upperstate to "midriff">>
<</if>>
<<elseif $upperstatetop is "midriff">><<He>> pulls your $upperclothes down past your midriff.<<set $upperstatetop to "waist">><<neutral 1>>
<<if $upperstate is "midriff">>
<<set $upperstate to "waist">>
<</if>>
<<elseif $upperstatetop is "waist">><<He>> pulls your $upperclothes down to your thighs.
<<set $upperstatetop to "thighs">>
<<set $upperstate to "thighs">>
<<elseif $upperstatetop is "thighs">><<He>> pulls your $upperclothes down to your knees.<<set $upperstatetop to "knees">><<set $upperstate to "knees">><<neutral 1>>
<<elseif $upperstatetop is "knees">><<He>> pulls your $upperclothes down to your ankles.<<set $upperstatetop to "ankles">><<set $upperstate to "ankles">><<neutral 1>>
<<elseif $upperstatetop is "ankles">><span class="purple"><<He>> pulls your $upperclothes off the bottom of your legs.</span><<upperstrip>><<neutral 5>><<set $upperstatetop to 0>><<set $upperstate to 0>><<uppernaked>><<set $lefthand to 0>>
<</if>>
<<elseif $open is 0>>
<<if $position is "wall">>
<<He>> tugs at your $upperclothes, tearing <<upperit>> before <span class="blue">letting go.</span><<set $lefthand to 0>><<set $upperintegrity -= 10>><<neutral 1>>
<<elseif $position isnot "wall">>
<<if $upperstate is "waist">><<He>> lifts up your $upperclothes, exposing your midriff.<<set $upperstate to "midriff">><<neutral 1>>
<<elseif $upperstate is "midriff">><<He>> lifts up your $upperclothes, <span class="lewd">exposing your <<breastsstop>></span><<set $upperstate to "chest">><<neutral 2>><<set $upperexposed to 2>><<set $speechbreasts to 1>>
<<elseif $upperstate is "chest">><span class="purple"><<He>> removes your $upperclothes completely.</span><<upperstrip>><<uppernaked>><<set $lefthand to 0>><<neutral 3>><<clothesstripstat>>
<</if>>
<</if>>
<</if>>
<<elseif $upperset is $lowerset>>
<<if $open is 1>>
<<if $lowerstate is $upperstatetop and $lowerstate is $upperstate and $skirt is 1>>
<<if $position is "wall">>
<<He>> tugs at your $upperclothes, tearing <<upperit>> before <span class="blue">letting go.</span><<set $lefthand to 0>><<set $upperintegrity -= 10>><<neutral 1>>
<<elseif $position isnot "wall">>
<<if $upperstate is "waist">><<He>> pulls your bundled $upperclothes up past your midriff.<<set $upperstate to "midriff">><<neutral 1>>
<<set $lowerstate to "midriff">>
<<set $upperstatetop to "midriff">>
<<elseif $upperstate is "midriff">><<He>> pulls your bundled $upperclothes up past your <<breastsstop>><<set $upperstate to "chest">><<neutral 2>><<set $upperexposed to 2>><<set $speechbreasts to 1>>
<<set $lowerstate to "chest">>
<<set $upperstatetop to "chest">>
<<elseif $upperstate is "chest">><span class="purple"><<He>> pulls your $upperclothes off your body.</span><<upperstrip>><<uppernaked>><<set $lefthand to 0>><<neutral 3>><<clothesstripstat>>
<</if>>
<</if>>
<<else>>
<<if $upperstatetop is "chest">><<He>> pulls down the top of your $upperclothes, <span class="lewd">revealing your <<breastsstop>></span><<set $upperstatetop to "midriff">><<neutral 2>><<set $upperexposed to 2>><<set $speechbreasts to 1>>
<<if $upperstate is "chest">>
<<set $upperstate to "midriff">>
<</if>>
<<if $lowerstate is "chest">>
<<set $lowerstate to "midriff">>
<</if>>
<<elseif $upperstatetop is "midriff">><<He>> pulls your $upperclothes down past your midriff.<<set $upperstatetop to "waist">><<neutral 1>>
<<if $upperstate is "midriff">>
<<set $upperstate to "waist">>
<</if>>
<<if $lowerstate is "midriff">>
<<set $lowerstate to "waist">>
<</if>>
<<elseif $upperstatetop is "waist">><<He>> pulls your $upperclothes down to your thighs, revealing your
<<if $understate is "waist">>$underclothes<<neutral 2>>
<<else>><span class="lewd"><<genitalsstop>></span><<neutral 5>><<set $speechgenitals to 1>>
<</if>>
<<set $lowervaginaexposed to 1>><<set $loweranusexposed to 1>><<set $lowerexposed to 2>>
<<set $upperstatetop to "thighs">>
<<set $upperstate to "thighs">>
<<if $lowerstate is "waist">>
<<set $lowerstate to "thighs">>
<</if>>
<<elseif $upperstatetop is "thighs">><<He>> pulls your $upperclothes down to your knees.<<set $upperstatetop to "knees">><<set $upperstate to "knees">><<neutral 1>>
<<if $lowerstate is "thighs">>
<<set $lowerstate to "knees">>
<</if>>
<<elseif $upperstatetop is "knees">><<He>> pulls your $upperclothes down to your ankles.<<set $upperstatetop to "ankles">><<set $upperstate to "ankles">><<neutral 1>>
<<if $lowerstate is "knees">>
<<set $lowerstate to "ankles">>
<</if>>
<<elseif $upperstatetop is "ankles">><span class="purple"><<He>> pulls your $upperclothes off the bottom of your legs.</span><<upperstrip>><<neutral 5>><<set $upperstatetop to 0>><<set $upperstate to 0>><<uppernaked>><<set $lefthand to 0>>
<<if $lowerstate is "ankles">>
<<set $lowerstate to 0>><<lowerstrip>><<lowernaked>>
<</if>>
<</if>>
<</if>>
<<else>><<He>> tugs at your $upperclothes, tearing <<upperit>> before <span class="blue">letting go.</span><<set $lefthand to 0>><<set $upperintegrity -= 10>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random (1, 100)>>
<<if $righthand is "upperclothes">>
<<if $upperclothes is "naked">><span class="purple"><<He>> casts aside the fabric.</span><<set $righthand to 0>>
<<elseif $upperstruggle is 1>><<set $upperstruggle to 0>>You manage to keep <<him>> from stripping you of your $upperclothes.<<set $speechstripstruggle to 1>>
<<elseif $rng gte 101>><span class="lblue"><<He>> releases <<his>> hand from your $upperclothes.</span><<set $righthand to 0>>
<<elseif $rng lte 100>>
<<if $upperset isnot $lowerset>>
<<if $open is 1>>
<<if $upperstatetop is "chest">><<He>> pulls down your $upperclothes, <span class="lewd">revealing your <<breastsstop>></span><<set $upperstatetop to "midriff">><<neutral 3>><<set $upperexposed to 2>><<set $speechbreasts to 1>>
<<if $upperstate is "chest">>
<<set $upperstate to "midriff">>
<</if>>
<<elseif $upperstatetop is "midriff">><<He>> pulls your $upperclothes down past your midriff.<<set $upperstatetop to "waist">><<neutral 1>>
<<if $upperstate is "midriff">>
<<set $upperstate to "waist">>
<</if>>
<<elseif $upperstatetop is "waist">><<He>> pulls your $upperclothes down to your thighs.
<<set $upperstatetop to "thighs">>
<<set $upperstate to "thighs">>
<<elseif $upperstatetop is "thighs">><<He>> pulls your $upperclothes down to your knees.<<set $upperstatetop to "knees">><<set $upperstate to "knees">><<neutral 1>>
<<elseif $upperstatetop is "knees">><<He>> pulls your $upperclothes down to your ankles.<<set $upperstatetop to "ankles">><<set $upperstate to "ankles">><<neutral 1>>
<<elseif $upperstatetop is "ankles">><span class="purple"><<He>> pulls your $upperclothes off the bottom of your legs.</span><<upperstrip>><<neutral 5>><<set $upperstatetop to 0>><<set $upperstate to 0>><<uppernaked>><<set $righthand to 0>>
<</if>>
<<elseif $open is 0>>
<<if $position is "wall">>
<<He>> tugs at your $upperclothes, tearing <<upperit>> before <span class="blue">letting go.</span><<set $righthand to 0>><<set $upperintegrity -= 10>><<neutral 1>>
<<elseif $position isnot "wall">>
<<if $upperstate is "waist">><<He>> lifts up your $upperclothes, exposing your midriff.<<set $upperstate to "midriff">><<neutral 1>>
<<elseif $upperstate is "midriff">><<He>> lifts up your $upperclothes, <span class="lewd">exposing your <<breastsstop>></span><<set $upperstate to "chest">><<neutral 2>><<set $upperexposed to 2>><<set $speechbreasts to 1>>
<<elseif $upperstate is "chest">><span class="purple"><<He>> removes your $upperclothes completely.</span><<upperstrip>><<uppernaked>><<set $righthand to 0>><<neutral 3>><<clothesstripstat>>
<</if>>
<</if>>
<</if>>
<<elseif $upperset is $lowerset>>
<<if $open is 1>>
<<if $lowerstate is $upperstatetop and $lowerstate is $upperstate and $skirt is 1>>
<<if $position is "wall">>
<<He>> tugs at your $upperclothes, tearing <<upperit>> before <span class="blue">letting go.</span><<set $righthand to 0>><<set $upperintegrity -= 10>><<neutral 1>>
<<elseif $position isnot "wall">>
<<if $upperstate is "waist">><<He>> pulls your bundled $upperclothes up past your midriff.<<set $upperstate to "midriff">><<neutral 1>>
<<set $lowerstate to "midriff">>
<<set $upperstatetop to "midriff">>
<<elseif $upperstate is "midriff">><<He>> pulls your bundled $upperclothes up past your <<breastsstop>><<set $upperstate to "chest">><<neutral 2>><<set $upperexposed to 2>><<set $speechbreasts to 1>>
<<set $lowerstate to "chest">>
<<set $upperstatetop to "chest">>
<<elseif $upperstate is "chest">><span class="purple"><<He>> pulls your $upperclothes off your body.</span><<upperstrip>><<uppernaked>><<set $righthand to 0>><<neutral 3>><<clothesstripstat>>
<</if>>
<</if>>
<<else>>
<<if $upperstatetop is "chest">><<He>> pulls down the top of your $upperclothes, <span class="lewd">revealing your <<breastsstop>></span><<set $upperstatetop to "midriff">><<set $upperexposed to 2>><<neutral 2>><<set $speechbreasts to 1>>
<<if $upperstate is "chest">>
<<set $upperstate to "midriff">>
<</if>>
<<if $lowerstate is "chest">>
<<set $lowerstate to "midriff">>
<</if>>
<<elseif $upperstatetop is "midriff">><<He>> pulls your $upperclothes down past your midriff.<<set $upperstatetop to "waist">><<neutral 1>>
<<if $upperstate is "midriff">>
<<set $upperstate to "waist">>
<</if>>
<<if $lowerstate is "midriff">>
<<set $lowerstate to "waist">>
<</if>>
<<elseif $upperstatetop is "waist">><<He>> pulls your $upperclothes down to your thighs, revealing your
<<if $understate is "waist">>$underclothes<<neutral 2>>
<<else>><span class="lewd"><<genitalsstop>></span><<neutral 5>><<set $speechgenitals to 1>>
<</if>>
<<set $lowervaginaexposed to 1>><<set $loweranusexposed to 1>><<set $lowerexposed to 2>>
<<set $upperstatetop to "thighs">>
<<set $upperstate to "thighs">>
<<if $lowerstate is "waist">>
<<set $lowerstate to "thighs">>
<</if>>
<<elseif $upperstatetop is "thighs">><<He>> pulls your $upperclothes down to your knees.<<set $upperstatetop to "knees">><<set $upperstate to "knees">><<neutral 1>>
<<if $lowerstate is "thighs">>
<<set $lowerstate to "knees">>
<</if>>
<<elseif $upperstatetop is "knees">><<He>> pulls your $upperclothes down to your ankles.<<set $upperstatetop to "ankles">><<set $upperstate to "ankles">><<neutral 1>>
<<if $lowerstate is "knees">>
<<set $lowerstate to "ankles">>
<</if>>
<<elseif $upperstatetop is "ankles">><span class="purple"><<He>> pulls your $upperclothes off the bottom of your legs.</span><<upperstrip>><<neutral 5>><<set $upperstatetop to 0>><<set $upperstate to 0>><<uppernaked>><<set $righthand to 0>>
<<if $lowerstate is "ankles">>
<<set $lowerstate to 0>><<lowerstrip>><<lowernaked>>
<</if>>
<</if>>
<</if>>
<<else>><<He>> tugs at your $upperclothes, tearing <<upperit>> before <span class="blue">letting go.</span><<set $righthand to 0>><<set $upperintegrity -= 10>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand is 0>>
<<if $enemyanger + $rng lte 20>>
<<if $lowerclothes isnot "naked">><span class="purple"><<He>> grasps your $lowerclothes.</span><<set $lefthand to "lowerclothes">><<neutral 1>>
<<elseif $vaginaexist is 1>>
<<He>> <<strokes>> your inner thigh and brushes <<his>> fingers against your clit.<<neutral 10>><<set $speechclit to 1>>
<<elseif $penisexist is 1>>
<<He>> <<strokes>> your inner thigh and brushes <<his>> fingers against your <<glansstop>><<neutral 10>><<set $speechglans to 1>>
<</if>>
<<elseif $enemyanger + $rng lte 30>>
<<if $position is "wall">>
<<if $lowerclothes isnot "naked">><span class="purple"><<He>> grasps your $lowerclothes.</span><<set $lefthand to "lowerclothes">><<neutral 1>>
<<elseif $vaginaexist is 1>>
<<He>> <<strokes>> your inner thigh and brushes <<his>> fingers against your clit.<<neutral 10>><<set $speechclit to 1>>
<<elseif $penisexist is 1>>
<<He>> <<strokes>> your inner thigh and brushes <<his>> fingers against your <<glansstop>><<neutral 10>><<set $speechglans to 1>>
<</if>>
<<else>>
<<if $upperclothes isnot "naked">><span class="purple"><<He>> grasps your $upperclothes.</span><<set $lefthand to "upperclothes">><<neutral 1>>
<<else>><<He>> <<strokes>> your chest, <<his>> fingers lingering around your nipple.<<neutral 4>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 35>>
<<if $skirt is 1>>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $lefthand to "underclothes">><<neutral 1>>
<<elseif $underanusexposed is 1>>
<<if $loweranusexposed is 1>>
<<if $anususe is 0 and $analdisable is "f">><span class="purple"><<He>> presses <<his>> left hand against your <<bottomstop>></span><<set $lefthand to "anusentrance">><<set $anususe to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<<elseif $lowerclothes isnot "waist">>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $lefthand to "underclothes">><<neutral 1>>
<<elseif $underanusexposed is 1>>
<<if $loweranusexposed is 1>>
<<if $anususe is 0 and $analdisable is "f">><span class="purple"><<He>> presses <<his>> left hand against your <<bottomstop>></span><<set $lefthand to "anusentrance">><<set $anususe to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 40>>
<<if $skirt is 1>>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $lefthand to "underclothes">><<neutral 1>>
<<elseif $undervaginaexposed is 1>>
<<if $lowervaginaexposed is 1>>
<<if $vaginaexist is 1>>
<<if $vaginause is 0>><span class="purple"><<He>> presses <<his>> left hand against your <<pussycomma>> resting a finger on your entrance.</span><<set $lefthand to "vaginaentrance">><<set $vaginause to 1>><<neutral 1>>
<</if>>
<<elseif $penisexist is 1>>
<<if $penisuse is 0>><span class="purple"><<He>> presses <<his>> left hand against your <<penisstop>></span><<set $lefthand to "penisentrance">><<set $penisuse to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $lowerclothes isnot "waist">>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $lefthand to "underclothes">><<neutral 1>>
<<elseif $undervaginaexposed is 1>>
<<if $lowervaginaexposed is 1>>
<<if $vaginaexist is 1>>
<<if $vaginause is 0>>
<span class="purple"><<He>> presses <<his>> left hand against your <<pussycomma>> resting a finger on your entrance.</span><<set $lefthand to "vaginaentrance">><<set $vaginause to 1>><<neutral 1>>
<</if>>
<<elseif $penisexist is 1>>
<<if $penisuse is 0>><span class="purple"><<He>> presses <<his>> left hand against your <<penisstop>></span><<set $lefthand to "penisentrance">><<set $penisuse to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 45>>
<<if $position is "wall">>
<<He>> leans against the wall.
<<else>>
<<He>> caresses your tummy.<<neutral 1>>
<</if>>
<<elseif $enemyanger + $rng lte 50>>
<<if $position is "wall">>
<<He>> grips your thigh and pulls, but you're stuck firm.<<neutral 1>>
<<else>>
<<He>> <<strokes>> your hair.<<neutral 1>>
<</if>>
<<elseif $enemyanger + $rng lte 60>>
<<if $position is "wall">>
<<He>> pulls your leg, but you're stuck firm.<<neutral 1>>
<<elseif $uppertype isnot "naked" and $upperstate isnot "chest" and $upperstatetop is "chest">>
<<He>> <<strokes>> your <<breasts>> through your $upperclothes.<<neutral 2>>
<<else>>
<<He>> <<strokes>> your exposed <<breastsstop>><<neutral 4>>
<</if>>
<<elseif $enemyanger + $rng lte 80>><<set $speechbottom to 1>>
<<if $lowerstate is "waist" and $skirt is 0>>
<<He>> fondles your <<bottom>> through your $lowerclothes.<<neutral 2>>
<<elseif $understate is "waist">>
<<He>> fondles your <<bottom>> through your $underclothes.<<neutral 2>>
<<else>>
<<He>> gropes and squeezes your exposed <<bottomstop>><<neutral 4>>
<</if>>
<<elseif $enemyanger + $rng lte 100>>
<<if $penisexist is 1>>
<<if $lowerstate is "waist" and $skirt is 0>>
<<He>> fondles and <<strokes>> your <<penis>> through your $lowerclothes.<<neutral 5>>
<<elseif $understate is "waist">>
<<He>> fondles and <<strokes>> your <<penis>> through your $underclothes.<<neutral 5>>
<<elseif $penisuse is 0>>
<<He>> fondles and <<strokes>> your exposed <<penisstop>><<neutral 10>>
<<else>>
<<He>> fondles and <<strokes>> your <<testiclesstop>><<neutral 10>>
<</if>>
<<elseif $vaginaexist is 1>>
<<if $lowerstate is "waist" and $skirt is 0>>
<<He>> fondles and <<strokes>> your labia through your $lowerclothes.<<neutral 5>>
<<elseif $understate is "waist">>
<<He>> fondles and <<strokes>> your labia through your $underclothes.<<neutral 5>>
<<else>>
<<He>> fondles and <<strokes>> your exposed <<pussystop>><<neutral 10>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 110>>
<<if $lowerclothes isnot "naked">><span class="purple"><<He>> grasps your $lowerclothes.</span><<set $lefthand to "lowerclothes">><<neutral 1>>
<<elseif $vaginaexist is 1>><<He>> pinches your clitoris.<<neutral 15>><<bruise vagina>><<set $speechclit to 1>>
<<elseif $penisexist is 1>>
<<if $penisuse is 0>>
<<He>> pinches your glans.<<neutral 15>><<bruise penis>><<set $speechglans to 1>>
<<else>>
<<He>> pinches your shaft.<<neutral 10>><<bruise penis>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 120>>
<<if $position is "wall">>
<<He>> smacks your thigh.<<violence 1>><<bruise thigh>><<hitstat>>
<<else>>
<<if $upperclothes isnot "naked">><span class="purple"><<He>> grasps your $upperclothes.</span><<set $lefthand to "upperclothes">><<neutral 1>>
<<else>><span class="purple"><<He>> grabs your throat.</span><<violence 2>><<set $lefthand to "throat">>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 125>>
<<if $skirt is 1>>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $lefthand to "underclothes">><<neutral 1>>
<<elseif $underanusexposed is 1>>
<<if $loweranusexposed is 1>>
<<if $anususe is 0 and $analdisable is "f">><span class="purple"><<He>> presses <<his>> left hand against your <<bottomstop>></span><<set $lefthand to "anusentrance">><<set $anususe to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<<elseif $lowerclothes isnot "waist">>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $lefthand to "underclothes">><<neutral 1>>
<<elseif $underanusexposed is 1>>
<<if $loweranusexposed is 1>>
<<if $anususe is 0 and $analdisable is "f">><span class="purple"><<He>> presses <<his>> left hand against your <<bottomstop>></span><<set $lefthand to "anusentrance">><<set $anususe to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 130>>
<<if $skirt is 1>>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $lefthand to "underclothes">><<neutral 1>>
<<elseif $undervaginaexposed is 1>>
<<if $lowervaginaexposed is 1>>
<<if $vaginaexist is 1>>
<<if $vaginause is 0>><span class="purple"><<He>> presses <<his>> left hand against your <<pussycomma>> <<his>> finger resting on your entrance.</span><<set $lefthand to "vaginaentrance">><<set $vaginause to 1>><<neutral 1>>
<</if>>
<<elseif $penisexist is 1>>
<<if $penisuse is 0>><span class="purple"><<He>> presses <<his>> left hand against your <<penisstop>></span><<set $lefthand to "penisentrance">><<set $penisuse to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $lowerclothes isnot "waist">>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $lefthand to "underclothes">><<neutral 1>>
<<elseif $undervaginaexposed is 1>>
<<if $lowervaginaexposed is 1>>
<<if $vaginaexist is 1>>
<<if $vaginause is 0>>
<span class="purple"><<He>> presses <<his>> left hand against your <<pussycomma>> <<his>> finger resting on your entrance.</span><<set $lefthand to "vaginaentrance">><<set $vaginause to 1>><<neutral 1>>
<</if>>
<<elseif $penisexist is 1>>
<<if $penisuse is 0>><span class="purple"><<He>> presses <<his>> left hand against your <<penisstop>></span><<set $lefthand to "penisentrance">><<set $penisuse to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 140>>
<<if $position is "wall">>
<<He>> smacks your <<bottomstop>><<violence 1>><<bruise bottom>><<hitstat>>
<<else>>
<<He>> seizes your hair with <<his>> left hand.<<set $lefthand to "hair">><<violence 2>><<set $speechhair to 1>>
<</if>>
<<elseif $enemyanger + $rng lte 160 and $lefthand isnot "arms" and $righthand isnot "arms" and $leftarm isnot "bound" and $rightarm isnot "bound">>
<span class="purple"><<He>> pins down your arms.</span><<set $lefthand to "arms">><<set $leftarm to "grappled">><<set $rightarm to "grappled">><<disablearms>><<violence 2>><<bruise leftarm>><<bruise rightarm>><<set $speecharms to 1>>
<<if $vaginause is "cover">><<set $vaginause to 0>>
<</if>>
<<if $vaginause is "cover">><<set $vaginause to 0>>
<</if>>
<<if $anususe is "cover">><<set $anususe to 0>>
<</if>>
<<if $anususe is "cover">><<set $anususe to 0>>
<</if>>
<<if $penisuse is "cover">><<set $penisuse to 0>>
<</if>>
<<if $penisuse is "cover">><<set $penisuse to 0>>
<</if>>
<<elseif $enemyanger + $rng lte 160>><<He>> digs <<his>> nails into your <<bottom>> while groping, giving no heed to you comfort.<<violence 10>><<bruise bottom>><<hitstat>><<set $speechspank to 1>>
<<elseif $enemyanger + $rng lte 175>><<He>> slaps your <<bottomstop>><<violence 10>><<bruise bottom>><<hitstat>><<set $speechspank to 1>>
<<elseif $enemyanger + $rng lte 180>><<He>> smacks your thighs.<<violence 10>><<bruise thigh>><<hitstat>><<set $speechbeat to 1>>
<<elseif $enemyanger + $rng lte 185>>
<<if $position is "wall">>
<<He>> punches your thigh.<<bruise thigh>><<hitstat>><<violence 10>><<set $speechbeat to 1>>
<<else>>
<<He>> punches your tummy.<<violence 20>><<bruise tummy>><<hitstat>><<set $speechbeat to 1>>
<</if>>
<<elseif $enemyanger + $rng lte 190>>
<<if $position is "wall">>
<<He>> slaps your <<bottomstop>><<violence 20>><<bruise bottom>><<hitstat>><<set $speechbeat to 1>>
<<else>>
<<He>> slaps your <<breastsstop>><<violence 20>><<bruise chest>><<hitstat>><<set $speechbeat to 1>>
<</if>>
<<elseif $enemyanger + $rng gte 191>>
<<if $position is "wall">>
<<if $penisexist is 1>>
<<He>> scratches your helpless <<bottomstop>><<violence 20>><<bruise bottom>><<hitstat>><<set $speechbeat to 1>>
<<elseif $vaginaexist is 1>>
<<He>> scratches your helpless <<bottomstop>><<violence 20>><<bruise bottom>><<hitstat>><<set $speechbeat to 1>>
<</if>>
<<else>>
<<set $rng to random(1, 100)>>
<<if $rng gte 81>>
<<He>> punches your nose.<<violence 20>><<bruise face>><<hitstat>><<set $speechbeat to 1>>
<<elseif $rng gte 61>>
<<He>> punches the back of your neck.<<violence 20>><<bruise neck>><<hitstat>><<set $speechbeat to 1>>
<<elseif $rng gte 41>>
<<He>> punches your cheek.<<violence 20>><<bruise face>><<hitstat>><<set $speechbeat to 1>>
<<elseif $rng gte 21>>
<<He>> punches your jaw.<<violence 20>><<bruise face>><<hitstat>><<set $speechbeat to 1>>
<<else>>
<<He>> jabs the front of your neck.<<violence 20>><<bruise neck>><<hitstat>><<set $speechbeat to 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand is 0>>
<<if $enemyanger + $rng lte 20>>
<<if $lowerclothes isnot "naked">><span class="purple"><<He>> grasps your $lowerclothes.</span><<set $righthand to "lowerclothes">><<neutral 1>>
<<elseif $vaginaexist is 1>><<He>> <<strokes>> your pubic mound and teases your clit.<<neutral 10>><<set $speechclit to 1>>
<<elseif $penisexist is 1>>
<<He>> <<strokes>> your <<testicles>> and teases your glans.<<neutral 10>><<set $speechglans to 1>>
<</if>>
<<elseif $enemyanger + $rng lte 30>>
<<if $position is "wall">>
<<if $lowerclothes isnot "naked">><span class="purple"><<He>> grasps your $lowerclothes.</span><<set $righthand to "lowerclothes">><<neutral 1>>
<<elseif $vaginaexist is 1>><<He>> runs <<his>> hand up your thigh and <<strokes>> your clit.<<neutral 10>><<set $speechclit to 1>>
<<elseif $penisexist is 1>><<He>> runs <<his>> hand up your thigh and <<strokes>> your <<glansstop>><<neutral 10>><<set $speechglans to 1>>
<</if>>
<<else>>
<<if $upperclothes isnot "naked">><span class="purple"><<He>> grasps your $upperclothes.</span><<set $righthand to "upperclothes">><<neutral 1>>
<<else>><<He>> <<strokes>> your chest and teases your nipple.<<neutral 4>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 35>>
<<if $skirt is 1>>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $righthand to "underclothes">><<neutral 1>>
<<elseif $underanusexposed is 1>>
<<if $loweranusexposed is 1>>
<<if $anususe is 0 and $analdisable is "f">><span class="purple"><<He>> presses <<his>> right hand against your <<bottomstop>></span><<set $righthand to "anusentrance">><<set $anususe to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<<elseif $lowerclothes isnot "waist">>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $righthand to "underclothes">><<neutral 1>>
<<elseif $underanusexposed is 1>>
<<if $loweranusexposed is 1>>
<<if $anususe is 0 and $analdisable is "f">><span class="purple"><<He>> presses <<his>> right hand against your <<bottomstop>></span><<set $righthand to "anusentrance">><<set $anususe to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 40>>
<<if $skirt is 1>>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $righthand to "underclothes">><<neutral 1>>
<<elseif $undervaginaexposed is 1>>
<<if $lowervaginaexposed is 1>>
<<if $vaginaexist is 1>>
<<if $vaginause is 0>>
<span class="purple"><<He>> presses <<his>> right hand against your <<pussycomma>> resting a finger on your entrance.</span><<set $righthand to "vaginaentrance">><<set $vaginause to 1>><<neutral 1>>
<</if>>
<<elseif $penisexist is 1>>
<<if $penisuse is 0>><span class="purple"><<He>> presses <<his>> right hand against your <<penisstop>></span><<set $righthand to "penisentrance">><<set $penisuse to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $lowerclothes isnot "waist">>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $righthand to "underclothes">><<neutral 1>>
<<elseif $undervaginaexposed is 1>>
<<if $lowervaginaexposed is 1>>
<<if $vaginaexist is 1>>
<<if $vaginause is 0>>
<span class="purple"><<He>> presses <<his>> right hand against your <<pussycomma>> resting a finger above your entrance.</span><<set $righthand to "vaginaentrance">><<set $vaginause to 1>><<neutral 1>>
<</if>>
<<elseif $penisexist is 1>>
<<if $penisuse is 0>>
<span class="purple"><<He>> presses <<his>> right hand against your <<penisstop>></span><<set $righthand to "penisentrance">><<set $penisuse to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 45>>
<<if $position is "wall">>
<<He>> rests <<his>> right hand against the wall.
<<else>>
<<He>> <<strokes>> your tummy with <<his>> right hand.<<neutral 1>>
<</if>>
<<elseif $enemyanger + $rng lte 50>>
<<if $position is "wall">>
<<He>> pushes your <<bottomcomma>> making sure you're stuck firm.<<neutral 1>>
<<else>>
<<He>> <<strokes>> your cheek.<<neutral 1>>
<</if>>
<<elseif $enemyanger + $rng lte 60>>
<<if $position is "wall">>
<<He>> tugs on your leg, but you're stuck firm.<<neutral 1>>
<<elseif $uppertype isnot "naked" and $upperstate isnot "chest" and $upperstatetop is "chest">>
<<He>> gropes your <<breasts>> through your $upperclothes.<<neutral 2>>
<<else>>
<<He>> gropes your exposed <<breastsstop>><<neutral 4>>
<</if>>
<<elseif $enemyanger + $rng lte 80>><<set $speechbottom to 1>>
<<if $lowerstate is "waist" and $skirt is 0>>
<<He>> gropes your <<bottom>> through your $lowerclothes.<<neutral 2>>
<<elseif $understate is "waist">>
<<He>> gropes your <<bottom>> through your $underclothes.<<neutral 2>>
<<else>>
<<He>> fondles and <<strokes>> your exposed <<bottomstop>><<neutral 4>>
<</if>>
<<elseif $enemyanger + $rng lte 100>>
<<if $penisexist is 1>>
<<if $lowerstate is "waist" and $skirt is 0>>
<<He>> gropes and <<strokes>> your <<penis>> through your $lowerclothes.<<neutral 5>>
<<elseif $understate is "waist">>
<<He>> gropes and <<strokes>> your <<penis>> through your $underclothes.<<neutral 5>>
<<elseif $penisuse is 0>>
<<He>> gropes and <<strokes>> your exposed <<penisstop>><<neutral 10>>
<<else>>
<<He>> cups and <<strokes>> your <<testiclesstop>><<neutral 10>>
<</if>>
<<elseif $vaginaexist is 1>>
<<if $lowerstate is "waist" and $skirt is 0>>
<<He>> gropes and <<strokes>> your labia through your $lowerclothes.<<neutral 5>>
<<elseif $understate is "waist">>
<<He>> gropes and <<strokes>> your labia through your $underclothes.<<neutral 5>>
<<else>>
<<He>> gropes and <<strokes>> your exposed <<pussystop>><<neutral 10>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 110>>
<<if $lowerclothes isnot "naked">><span class="purple"><<He>> grasps your $lowerclothes.</span><<set $righthand to "lowerclothes">><<neutral 1>>
<<elseif $vaginaexist is 1>>He pinches your clitoris.<<neutral 15>><<bruise vagina>><<set $speechclit to 1>>
<<elseif $penisexist is 1>>
<<if $penisuse is 0>>
<<He>> pinches your glans.<<neutral 15>><<bruise penis>><<set $speechglans to 1>>
<<else>>
<<He>> pinches your shaft.<<neutral 10>><<bruise penis>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 120>>
<<if $position is "wall">>
<<He>> squeezes your thigh.<<violence 1>><<hitstat>><<bruise thigh>>
<<else>>
<<if $upperclothes isnot "naked">><span class="purple"><<He>> grasps your $upperclothes.</span><<set $righthand to "upperclothes">><<neutral 1>>
<<else>><span class="purple"><<He>> grabs your throat.</span><<violence 2>><<set $righthand to "throat">>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 125>>
<<if $skirt is 1>>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $righthand to "underclothes">><<neutral 1>>
<<elseif $underanusexposed is 1>>
<<if $loweranusexposed is 1>>
<<if $anususe is 0 and $analdisable is "f">><span class="purple"><<He>> presses <<his>> right hand against your <<bottomstop>></span><<set $righthand to "anusentrance">><<set $anususe to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<<elseif $lowerclothes isnot "waist">>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $righthand to "underclothes">><<neutral 1>>
<<elseif $underanusexposed is 1>>
<<if $loweranusexposed is 1>>
<<if $anususe is 0 and $analdisable is "f">><span class="purple"><<He>> presses <<his>> right hand against your <<bottomstop>></span><<set $righthand to "anusentrance">><<set $anususe to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 130>>
<<if $skirt is 1>>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $righthand to "underclothes">><<neutral 1>>
<<elseif $undervaginaexposed is 1>>
<<if $lowervaginaexposed is 1>>
<<if $vaginaexist is 1>>
<<if $vaginause is 0>>
<span class="purple"><<He>> presses <<his>> right hand against your <<pussycomma>> <<his>> finger resting on your entrance.</span><<set $righthand to "vaginaentrance">><<set $vaginause to 1>><<neutral 1>>
<</if>>
<<elseif $penisexist is 1>>
<<if $penisuse is 0>><span class="purple"><<He>> presses <<his>> right hand against your <<penisstop>></span><<set $righthand to "penisentrance">><<set $penisuse to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $lowerclothes isnot "waist">>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $righthand to "underclothes">><<neutral 1>>
<<elseif $undervaginaexposed is 1>>
<<if $lowervaginaexposed is 1>>
<<if $vaginaexist is 1>>
<<if $vaginause is 0>>
<span class="purple"><<He>> presses <<his>> right hand against your <<pussycomma>> <<his>> finger resting on your entrance.</span><<set $righthand to "vaginaentrance">><<set $vaginause to 1>><<neutral 1>>
<</if>>
<<elseif $penisexist is 1>>
<<if $penisuse is 0>>
<span class="purple"><<He>> presses <<his>> right hand against your <<penisstop>></span><<set $righthand to "penisentrance">><<set $penisuse to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 140>>
<<if $position is "wall">>
<<He>> slaps your <<bottomstop>><<violence 1>><<bruise bottom>><<hitstat>>
<<else>>
<span class="purple"><<He>> seizes your hair with <<his>> right hand.</span><<set $righthand to "hair">><<violence 2>><<set $speechhair to 1>>
<</if>>
<<elseif $enemyanger + $rng lte 160 and $lefthand isnot "arms" and $righthand isnot "arms" and $leftarm isnot "bound" and $rightarm isnot "bound">><span class="purple"><<He>> pins down your arms.</span><<set $righthand to "arms">><<set $leftarm to "grappled">><<set $rightarm to "grappled">><<disablearms>><<violence 2>><<bruise leftarm>><<bruise rightarm>><<set $speecharms to 1>>
<<if $vaginause is "cover">><<set $vaginause to 0>>
<</if>>
<<if $vaginause is "cover">><<set $vaginause to 0>>
<</if>>
<<if $anususe is "cover">><<set $anususe to 0>>
<</if>>
<<if $anususe is "cover">><<set $anususe to 0>>
<</if>>
<<if $penisuse is "cover">><<set $penisuse to 0>>
<</if>>
<<if $penisuse is "cover">><<set $penisuse to 0>>
<</if>>
<<elseif $enemyanger + $rng lte 160>><<He>> grips your <<bottomcomma>> digging <<his>> nails into your skin.<<violence 10>><<bruise bottom>><<hitstat>><<set $speechspank to 1>>
<<elseif $enemyanger + $rng lte 175>><<He>> spanks your <<bottomstop>><<violence 10>><<bruise bottom>><<hitstat>><<set $speechspank to 1>>
<<elseif $enemyanger + $rng lte 180>><<He>> slaps your thighs.<<violence 10>><<bruise thigh>><<hitstat>><<set $speechbeat to 1>>
<<elseif $enemyanger + $rng lte 185>>
<<if $position is "wall">>
<<He>> beats your thigh.<<bruise thigh>><<hitstat>><<violence 10>><<set $speechbeat to 1>>
<<else>>
<<He>> beats your tummy.<<violence 20>><<bruise tummy>><<hitstat>><<set $speechbeat to 1>>
<</if>>
<<elseif $enemyanger + $rng lte 190>>
<<if $position is "wall">>
<<He>> spanks your <<bottomstop>><<violence 20>><<bruise bottom>><<hitstat>><<set $speechbeat to 1>>
<<else>>
<<He>> spanks your <<breastsstop>><<violence 20>><<bruise chest>><<hitstat>><<set $speechbeat to 1>>
<</if>>
<<elseif $enemyanger + $rng gte 191>>
<<if $position is "wall">>
<<if $penisexist is 1>>
<<He>> jabs your gooch.<<violence 20>><<bruise penis>><<hitstat>><<set $speechbeat to 1>>
<<elseif $vaginaexist is 1>>
<<He>> jabs your gooch.<<violence 20>><<bruise vagina>><<hitstat>><<set $speechbeat to 1>>
<</if>>
<<else>>
<<set $rng to random(1, 100)>>
<<if $rng gte 81>>
<<He>> scratches the side of your face.<<violence 20>><<bruise face>><<hitstat>><<set $speechbeat to 1>>
<<elseif $rng gte 61>>
<<He>> scratches the back of your neck.<<violence 20>><<bruise neck>><<hitstat>><<set $speechbeat to 1>>
<<elseif $rng gte 41>>
<<He>> scratches your cheek.<<violence 20>><<bruise face>><<hitstat>><<set $speechbeat to 1>>
<<elseif $rng gte 21>>
<<He>> scratches your jaw.<<violence 20>><<bruise face>><<hitstat>><<set $speechbeat to 1>>
<<else>>
<<He>> scratches the front of your neck.<<violence 20>><<bruise neck>><<hitstat>><<set $speechbeat to 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis is "clothed">>
<<if $pronoun is "m">>
<<if $enemyarousal gte 40>><<He>> unzips <<his>> fly, <span class="blue">revealing <<his>> erect penis.</span><<set $penis to 0>>
<</if>>
<<else>>
<<if $enemyarousal gte 40>><<He>> pulls up <<his>> skirt, <span class="blue">revealing <<his>> erect penis.</span><<set $penis to 0>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis is "thighs">>
<<if $vaginaexist is 1>>
<<if $rng gte 101>><span class="blue"><<He>> angles <<his>> penis towards your <<pussystop>></span><<set $thighuse to 0>><<set $penis to "vaginaentrance">><<set $vaginause to "penis">><<set $vaginastate to "entrance">><<set $speechvaginaentrance to 1>>
<<else>>
<<He>> rubs <<his>> penis between your thighs and <<pussystop>><<sex 5>>
<</if>>
<<else>>
<<if $rng gte 101>><<He>> moves <<his>> penis out from between your thighs.<<set $thighuse to 0>><<set $penis to 0>>
<<else>>
<<He>> rubs <<his>> penis between your thighs.<<sex 5>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis is "cheeks">>
<<if $rng gte 101>><span class="blue"><<He>> angles <<his>> penis towards your anus.</span><<set $penis to "anusentrance">><<set $anusstate to "entrance">><<set $bottomuse to 0>><<set $cheekactiondefault to "cheeks">><<set $speechanusentrance to 1>>
<<else>>
<<He>> rubs <<his>> penis between your cheeks.<<submission 3>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis is "leftarm">>
<<if $rng gte 1>><<He>> rubs <<his>> penis between your fingers.<<submission 1>>
<<elseif $rng gte 101>><<He>> moves <<his>> penis away from your hand.<<set $penis to 0>><<set $leftarm to 0>><<set $leftactiondefault to "leftgrab">>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis is "rightarm">>
<<if $rng gte 1>><<He>> rubs <<his>> penis between your fingers.<<submission 1>>
<<elseif $rng gte 101>><<He>> moves <<his>> penis away from your hand.<<set $penis to 0>><<set $rightarm to 0>><<set $rightactiondefault to "rightgrab">>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis is "botharm">>
<<if $rng gte 1>><<He>> rubs <<his>> penis between your hands.<<submission 2>>
<<elseif $rng gte 101>><<He>> moves <<his>> penis away from your hands.<<set $penis to 0>><<set $leftarm to 0>><<set $rightarm to 0>><<set $rightactiondefault to "rightgrab">><<set $leftactiondefault to "leftgrab">>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis is "feet">>
<<if $rng gte 1>>
<<He>> rubs <<his>> penis between your feet.<<submission 1>>
<<elseif $rng gte 101>>
<<He>> moves <<his>> penis away from your feet.<<set $penis to 0>><<set $feetuse to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis is "vagina">>
<<if $rng gte 101>><span class="purple"><<He>> slides <<his>> penis out of your <<pussystop>></span><<sex 30>><<set $penis to "vaginaimminent">><<bruise vagina>><<violence 1>><<set $vaginastate to "imminent">>
<<elseif $rng gte 1>>
<<if $enemyanger gte 100>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
<<He>> violates your <<pussy>> with increasing intensity.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues to fuck your <<pussy>> with no regard for your comfort.
<<else>>
<<He>> fucks your <<pussy>> with rough thrusts, giving no regard to your comfort.
<</if>>
<<elseif $enemyanger gte 20>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
You feel <<his>> penis throb as <<he>> pounds away at your <<pussystop>>
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues to violate your <<pussystop>>
<<else>>
<<He>> fucks your <<pussy>> with deep and deliberate thrusts.
<</if>>
<<else>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
<<He>> fucks your <<pussy>> with increasing power.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues thrusting into your <<pussystop>>
<<else>>
<<He>> fucks your <<pussy>> with steady thrusts.
<</if>>
<</if>>
<<sex 30>><<bruise vagina>><<violence 1>><<set $speechvaginapenetrated to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis is "vaginaimminent">>
<<if $rng gte 101>><span class="blue"><<He>> stops pressing <<his>> penis against your pussy.</span><<set $penis to "vaginaentrance">><<set $vaginastate to "entrance">>
<<elseif $rng gte 1>>
<<if $novaginal is 0>><<set $vaginaactiondefault to "take">>
<<if $vaginalvirginity is 0>>
<<if $enemyanger gte 80>>
<span class="pink"><<He>> thrusts <<his>> penis deep into your <<pussystop>></span>
<<elseif $enemyanger gte 20>>
<span class="pink"><<He>> thrusts <<his>> penis deep into your <<pussystop>></span>
<<else>>
<span class="pink"><<He>> glides <<his>> penis deep into your <<pussystop>></span>
<</if>>
<<sex 30>><<set $penis to "vagina">><<vaginalstat>><<bruise vagina>><<violence 1>><<raped>><<vaginaraped>><<set $vaginastate to "penetrated">><<set $speechvaginapenetrated to 1>>
<<elseif $vaginalvirginity is 1>><span class="pink"><<His>> penis thrusts deep into your virgin pussy,</span><span class="red"> breaking your hymen and forever robbing you of your purity.</span><<sex 100>><<set $penis to "vagina">><<set $vaginalvirginity to 0>><<bruise vagina>><<vaginalstat>><<violence 100>><<raped>><<vaginaraped>><<set $vaginastate to "penetrated">><<set $speechvaginavirgin to 1>>
<</if>>
<<else>>
Respecting your wishes, <<he>> presses <<his>> penis against your <<pussy>> but does not penetrate.<<sex 15>><<set $speechvaginawithhold to 1>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis is "vaginaentrance">>
<<if $rng gte 101>><span class="lblue"><<He>> moves <<his>> penis away from your <<pussystop>></span><<set $penis to 0>><<set $vaginause to 0>><<set $vaginastate to 0>>
<<elseif $rng gte 1>>
<<if $lowervaginaexposed is 0>><<He>> rubs <<his>> penis against your <<pussy>> through your $lowerclothes.<<sex 5>><<set $lowerintegrity -= 10>><<set $speechvaginaentrance to 1>>
<<elseif $lowervaginaexposed is 1>><<set $rng to random(1, 100)>>
<<if $undervaginaexposed is 0>><<He>> rubs <<his>> penis against your <<pussy>> through your $underclothes.<<sex 5>><<set $underintegrity -= 10>><<set $speechvaginaentrance to 1>>
<<elseif $undervaginaexposed is 1>>
<<if $rng gte 71>>
<<if $novaginal is 1>>
<span class="purple"><<He>> pushes <<his>> penis against your <<pussystop>></span><<sex 20>><<set $penis to "vaginaimminent">><<set $vaginastate to "imminent">><<set $speechvaginaimminent to 1>>
<<else>>
<span class="purple"><<He>> pushes <<his>> penis against your <<pussycomma>> preparing to penetrate you fully.</span><<sex 20>><<set $penis to "vaginaimminent">><<set $vaginastate to "imminent">><<set $speechvaginaimminent to 1>>
<</if>>
<<elseif $rng gte 1>><<He>> teases your <<pussy>> without penetrating.<<sex 10>><<set $speechvaginaentrance to 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis is "anus">>
<<if $rng gte 101>><span class="purple"><<He>> withdraws <<his>> penis from your anus.</span><<sex 30>><<set $penis to "anusimminent">><<bruise anus>><<violence 1>><<set $anusstate to "imminent">>
<<elseif $rng gte 1>>
<<if $enemyanger gte 100>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
<<He>> ravages your <<bottom>> with a violent intensity.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
You feel <<his>> penis ever deeper within you as <<he>> fucks your <<bottomstop>>
<<else>>
<<He>> fucks your <<bottom>> with rough thrusts, intent on showing you who's boss.
<</if>>
<<elseif $enemyanger gte 20>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
You feel <<his>> penis throb within you as <<he>> fucks your <<bottomstop>>
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues to violate your <<bottomcomma>> giving no regard to your comfort.
<<else>>
<<He>> fucks your <<bottom>> with deep and dominating thrusts.
<</if>>
<<else>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
<<He>> fucks your <<bottom>> with increasing power.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues fucking your <<bottomstop>>
<<else>>
<<He>> fucks your <<bottom>> with steady thrusts.
<</if>>
<</if>>
<<sex 30>><<bruise anus>><<violence 1>><<set $speechanuspenetrated to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis is "anusimminent">>
<<if $rng gte 101>><span class="blue"><<He>> stops pressing <<his>> penis against your anus.</span><<set $penis to "anusentrance">><<set $anusstate to "entrance">>
<<elseif $rng gte 1>>
<<if $noanal is 0>><<set $anusactiondefault to "take">>
<<if $analvirginity is 0>><span class="pink"><<He>> thrusts <<his>> penis deep into your <<bottomstop>></span><<sex 30>><<set $penis to "anus">><<bruise anus>><<analstat>><<violence 1>><<raped>><<set $anusstate to "penetrated">><<set $speechanuspenetrated to 1>>
<<elseif $analvirginity is 1>><span class="pink"><<He>> thrusts <<his>> penis deep into your virgin anus,</span> <span class="red">violating you in a way you hadn't conceived of.</span><<sex 100>><<set $penis to "anus">><<set $analvirginity to 0>><<bruise anus>><<analstat>><<violence 50>><<raped>><<set $anusstate to "penetrated">><<set $speechanusvirgin to 1>>
<</if>>
<<else>>
Respecting your wishes, <<he>> presses <<his>> penis against your anus but does not penetrate.<<sex 15>><<set $speechanuswithhold to 1>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis is "anusentrance">>
<<if $rng gte 101>><span class="lblue"><<He>> moves <<his>> penis away from your <<bottomstop>></span><<set $penis to 0>><<set $anususe to 0>><<set $anusstate to 0>>
<<elseif $rng gte 1>>
<<if $loweranusexposed is 0>><<He>> rubs <<his>> penis against your <<bottom>> through your $lowerclothes.<<sex 5>><<set $lowerintegrity -= 10>><<set $speechanusentrance to 1>>
<<elseif $loweranusexposed is 1>><<set $rng to random(1, 100)>>
<<if $underanusexposed is 0>><<He>> rubs <<his>> penis against your <<bottom>> through your $underclothes.<<set $speechanusentrance to 1>><<sex 5>><<set $underintegrity -= 10>>
<<elseif $underanusexposed is 1>>
<<if $rng gte 71>>
<<if $noanal is 1>>
<span class="pink"><<He>> presses <<his>> penis against your anus.</span><<sex 20>><<set $penis to "anusimminent">><<set $anusstate to "imminent">><<set $speechanusimminent to 1>>
<<else>>
<span class="pink"><<He>> presses <<his>> penis against your anus, preparing to penetrate you fully.</span><<sex 20>><<set $penis to "anusimminent">><<set $anusstate to "imminent">><<set $speechanusimminent to 1>>
<</if>>
<<elseif $rng gte 1>><<His>> penis rubs against your <<bottomstop>><<sex 5>><<set $speechanusentrance to 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis is "mouth">>
<<if $rng gte 101>><span class="purple"><<He>> withdraws <<his>> penis from your mouth.</span><<sex 30>><<set $penis to "mouthimminent">><<bruise face>><<violence 1>><<set $mouthstate to "imminent">>
<<elseif $rng gte 1>><<He>> continues thrusting into your mouth.<<submission 10>><<bruise face>><<violence 1>><<set $speechmouthpenetrated to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis is "mouthimminent">>
<<if $pullaway is 1>><<set $pullaway to 0>>Saliva drips from the tip of <<his>> phallus.
<<else>>
<<if $rng gte 101>><span class="blue"><<He>> stops pressing <<his>> penis against your mouth.</span><<set $penis to "mouthentrance">><<submission 5>><<set $mouthstate to "entrance">>
<<elseif $rng lte 20>>
<<if $oralvirginity is 0>><span class="pink"><<He>> thrusts <<his>> penis into your mouth.</span><<submission 10>><<set $penis to "mouth">><<bruise face>><<oralstat>><<raped>><<set $mouthstate to "penetrated">><<set $speechmouthpenetrated to 1>>
<<elseif $oralvirginity is 1>><span class="pink"><<He>> thrusts <<his>> penis into your mouth.</span><span class="red"> It tastes strange.</span><<submission 30>><<set $penis to "mouth">><<set $oralvirginity to 0>><<bruise face>><<oralstat>><<violence 1>><<raped>><<set $mouthstate to "penetrated">><<set $speechmouthvirgin to 1>>
<</if>>
<<elseif $rng gte 21>>
<<if $mouthsubmit is 1>><<He>> allows you to pleasure <<his>> cock with your mouth.<<submission 5>><<set $speechmouthimminent to 1>>
<<elseif $oralvirginity is 0>><span class="pink"><<He>> thrusts <<his>> penis into your mouth.</span><<submission 10>><<set $penis to "mouth">><<oralstat>><<bruise face>><<violence 1>><<raped>><<set $mouthstate to "penetrated">><<set $speechmouthpenetrated to 1>>
<<elseif $oralvirginity is 1>><span class="pink"><<He>> thrusts <<his>> penis into your mouth.</span><span class="red"> It tastes strange.</span><<submission 30>><<set $penis to "mouth">><<set $oralvirginity to 0>><<oralstat>><<bruise face>><<violence 1>><<raped>><<set $mouthstate to "penetrated">><<set $speechmouthpenetrated to 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis is "mouthentrance">>
<<if $pullaway is 1>><<set $pullaway to 0>><<His>> penis hovers only inches from your face.
<<else>>
<<if $rng gte 101>><span class="lblue"><<He>> moves <<his>> penis away from your mouth.</span><<set $penis to 0>><<set $mouthuse to 0>><<set $mouthstate to 0>>
<<elseif $rng gte 1>><span class="purple"><<He>> pushes <<his>> penis against your lips.</span><<set $penis to "mouthimminent">><<submission 5>><<set $mouthstate to "imminent">><<set $speechmouthimminent to 1>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis is "chest">>
<<if $rng gte 101>><<He>> moves <<his>> penis away from your chest.<<set $penis to 0>><<set $chestuse to 0>>
<<elseif $rng gte 1>><<submission 3>>
<<if $breastcup is "none">>
<<He>> rubs <<his>> penis against your <<breastsstop>><<set $speechchestrub to 1>>
<<else>>
<<He>> rubs <<his>> penis between your <<breastsstop>><<set $speechbreastrub to 1>>
<</if>>
<</if>>
<</if>>
<<if $penis is "footjob">>
<<if $rng gte 101>>
<span class="blue"><<He>> stops pressing <<his>> foot against your <<genitalsstop>></span><<set $penis to 0>>
<<if $penisexist is 1>>
<<set $penisuse to 0>>
<<else>>
<<set $vaginause to 0>>
<</if>>
<<else>>
<<if $penisexist is 1>>
<<He>> presses your <<penis>> against your stomach with <<his>> foot and rubs your glans between <<his>> toes.
<<set $speechpenisfoot to 1>><<neutral 5>><<violence 1>>
<<else>>
<<He>> presses and teases your <<pussy>> with <<his>> foot.
<<set $speechvaginafoot to 1>><<neutral 5>><<violence 1>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis is "otherfrot">>
<<if $rng gte 101>><span class="blue"><<He>> shifts <<his>> ass and presses <<his>> anus against your <<penisstop>></span><<set $penisuse to "otheranus">><<set $penis to "otheranusentrance">><<set $penisstate to "otheranusentrance">><<set $speechotheranusentrance to 1>>
<<else>>
<<He>> rubs <<his>> ass against your <<penisstop>><<sex 5>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis is "otheranus">>
<<if $rng gte 101>><span class="purple"><<He>> moves <<his>> pelvis away, releasing your <<penis>> from <<his>> anus.</span><<sex 30>><<set $penis to "otheranusimminent">><<bruise penis>><<violence 1>><<set $penisstate to "otheranusimminent">><<set $speechotheranusimminent to 1>>
<<elseif $rng gte 1>>
<<if $enemyanger gte 100>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
<<His>> continues to fuck your <<penis>> with <<his>> ass, <<his>> movements violent and erratic.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues to ride you, your penis helpless as it's fucked.
<<else>>
<<He>> fucks your <<penis>> with rough movements, intent on showing you who's boss.
<</if>>
<<elseif $enemyanger gte 20>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
You feel <<his>> ass twitch around your length <<he>> fucks you.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues to violate your <<peniscomma>> using you as a sex toy.
<<else>>
<<He>> fucks your <<peniscomma>> taking as much of you into <<his>> ass as <<he>> can.
<</if>>
<<else>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
<<He>> continues riding your <<peniscomma>> <<his>> anus rhythmically pounding your length. <<His>> body jerks whenever you hit a sensitive spot.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues riding your <<peniscomma>> <<his>> anus rhythmically pounding your length.
<<else>>
<<He>> rides your <<penis>> with steady movements.
<</if>>
<</if>>
<<sex 30>><<bruise penis>><<violence 1>><<set $speechotheranus to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis is "otheranusimminent">>
<<if $rng gte 101>><span class="blue"><<He>> stops pressing <<his>> ass against your <<penisstop>></span><<set $penis to "otheranusentrance">><<set $penisstate to "otheranusentrance">><<set $speechotheranusentrance to 1>>
<<elseif $rng gte 1>>
<<if $nopenile is 0>><<set $penisactiondefault to "otheranustake">>
<<if $penilevirginity is 0>><span class="pink"><<He>> eases your <<penis>> into <<his>> ass, swallowing you to the base.</span><<sex 30>><<set $penis to "otheranus">><<penilestat>><<bruise penis>><<violence 1>><<raped>><<penisraped>><<set $penisstate to "otheranus">><<set $speechotheranus to 1>>
<<elseif $penilevirginity is 1>><span class="pink"><<He>> eases your virgin penis into <<his>> ass,</span><span class="red"> separating your foreskin from your glans and forever robbing you of your purity.</span><<sex 100>><<set $penis to "otheranus">><<set $penilevirginity to 0>><<bruise penis>><<penilestat>><<violence 100>><<raped>><<penisraped>><<set $penisstate to "otheranus">><<set $speechpenisvirgin to 1>>
<</if>>
<<else>>
Respecting your wishes, <<he>> does not envelope your <<penis>> with <<his>> ass, instead teasing the tip of your glans.<<sex 15>><<set $speechotheranuswithhold to 1>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis is "otheranusentrance">>
<<if $rng gte 101>><span class="lblue"><<He>> moves <<his>> ass away from your <<penisstop>></span><<set $penis to 0>><<set $penisuse to 0>><<set $penisstate to 0>>
<<elseif $rng gte 1>>
<<if $lowervaginaexposed is 0>><<He>> rubs <<his>> ass against your <<penis>> through your $lowerclothes.<<sex 5>><<set $lowerintegrity -= 10>><<set $speechotheranusentrance to 1>>
<<elseif $lowervaginaexposed is 1>><<set $rng to random(1, 100)>>
<<if $undervaginaexposed is 0>><<He>> rubs <<his>> ass against your <<penis>> through your $underclothes.<<sex 5>><<set $underintegrity -= 10>><<set $speechotheranusentrance to 1>>
<<elseif $undervaginaexposed is 1>>
<<if $rng gte 71>>
<<if $nopenile is 1>>
<span class="purple"><<He>> presses <<his>> ass against your <<penisstop>></span><<sex 20>><<set $penis to "otheranusimminent">><<set $penisstate to "otheranusimminent">><<set $speechotheranusimminent to 1>>
<<else>>
<span class="purple"><<He>> presses <<his>> ass against your <<peniscomma>> preparing to take you in fully.</span><<sex 20>><<set $penis to "otheranusimminent">><<set $penisstate to "otheranusimminent">><<set $speechotheranusimminent to 1>>
<</if>>
<<elseif $rng gte 1>><<He>> rubs your <<penis>> between <<his>> cheeks.<<sex 10>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis is 0>>
<<if $enemyanger + $rng lte 20>>
<<if $lefthand is 0>>
<<if $enemyarousal lte 40>><<He>> slowly rubs <<his>> shaft.<<submission 1>>
<<elseif $enemyarousal lte 90>><<He>> quickly rubs <<his>> shaft.<<submission 2>>
<<elseif $enemyarousal gte 91>><<He>> rapidly rubs <<his>> shaft.<<submission 3>>
<</if>>
<<elseif $righthand is 0>>
<<if $enemyarousal lte 40>><<He>> slowly rubs <<his>> shaft.<<submission 1>>
<<elseif $enemyarousal lte 90>><<He>> quickly rubs <<his>> shaft.<<submission 2>>
<<elseif $enemyarousal gte 91>><<He>> rapidly rubs <<his>> shaft.<<submission 3>>
<<endif>
<<else>><<He>> rubs <<his>> cock against your thighs.<<submission 2>>
<</if>>
<<elseif $enemyanger + $rng lte 25>>
<<if $position is "wall">>
<<He>> rubs <<his>> cock against your thighs.<<submission 2>>
<<else>>
<<He>> rubs <<his>> cock against your tummy.<<submission 2>>
<</if>>
<<elseif $enemyanger + $rng lte 30>>
<<if $position is "wall">>
<<He>> rubs <<his>> cock against your thighs.<<submission 2>>
<<else>>
<<He>> rubs <<his>> cock against your <<breastsstop>><<submission 2>>
<</if>>
<<elseif $enemyanger + $rng lte 35>><<He>> rubs <<his>> cock against your thighs.<<submission 2>>
<<elseif $enemyanger + $rng lte 40>>
<<if $position is "wall">>
<<He>> rubs <<his>> cock against your thighs.<<submission 2>>
<<elseif $mouth is 0>>
<<He>> rubs <<his>> cock against your face.<<submission 2>>
<<else>>
<<He>> rubs <<his>> cock against your thighs.<<submission 2>>
<</if>>
<<elseif $enemyanger + $rng lte 45>>
<<if $penisexist is 1>>
<<if $penisuse is 0>>
<<if $analdisable is "f" and $consensual is 1>>
<span class="blue"><<He>> straddles you, rubbing <<his>> ass against your <<penisstop>></span><<neutral 5>><<set $penisuse to "otheranus">><<set $penis to "otheranusentrance">><<set $penisstate to "otheranusentrance">><<set $speechotheranusentrance to 1>>
<</if>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 60>>
<<if $mouthuse is 0>>
<<if $penisbitten is 0>>
<<if $position isnot "wall">>
<span class="blue"><<He>> positions <<his>> penis in front of your mouth.</span><<neutral 5>><<set $mouthuse to "penis">><<set $penis to "mouthentrance">><<set $mouthstate to "entrance">><<set $speechmouthentrance to 1>>
<</if>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 80>>
<<if $anususe is 0>>
<<if $analdisable is "f">>
<span class="blue"><<He>> moves between your legs, positioning <<his>> penis in front of your <<bottomstop>></span><<neutral 5>><<set $anususe to "penis">><<set $penis to "anusentrance">><<set $anusstate to "entrance">><<set $speechanusentrance to 1>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 100>>
<<if $vaginaexist is 1>>
<<if $vaginause is 0>><span class="blue"><<He>> moves between your legs, positioning <<his>> penis in front of your <<pussystop>></span><<neutral 5>><<set $vaginause to "penis">><<set $penis to "vaginaentrance">><<set $vaginastate to "entrance">><<set $speechvaginaentrance to 1>>
<</if>>
<<elseif $penisexist is 1>>
<<if $anususe is 0>>
<<if $analdisable is "f">>
<span class="blue"><<He>> moves between your legs, positioning <<his>> penis in front of your <<bottomstop>></span><<neutral 5>><<set $anususe to "penis">><<set $penis to "anusentrance">><<set $anusstate to "entrance">><<set $speechanusentrance to 1>>
<</if>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 120>>
<<He>> slowly traces <<his>> length across your exposed skin.<<neutral 1>>
<<neutral 5>>
<<elseif $enemyanger + $rng lte 140>>
<<if $penisbitten is 0>>
<<if $position isnot "wall">>
<<if $mouthuse is 0>><span class="purple"><<He>> shoves <<his>> penis against your lips.</span><<submission 5>><<set $mouthuse to "penis">><<set $mouthstate to "imminent">><<set $penis to "mouthimminent">><<set $speechmouthimminent to 1>>
<<else>>
<<He>> slowly traces <<his>> length across your exposed skin.<<neutral 1>>
<</if>>
<<else>>
<<He>> slowly traces <<his>> length across your exposed skin.<<neutral 1>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 150>><span class="purple"><<He>> presses <<his>> foot against your <<genitalsstop>></span><<neutral 5>><<violence 1>><<set $penis to "footjob">>
<<if $penisexist is 1>>
<<set $penisuse to "feet">><<set $speechpenisfoot to 1>>
<<else>>
<<set $vaginause to "feet">><<set $speechvaginafoot to 1>>
<</if>>
<<elseif $enemyanger + $rng lte 170>>
<<if $anususe is 0 and $analdisable is "f">>
<<if $loweranusexposed is 1>>
<<if $underanusexposed is 1>>
<span class="purple"><<He>> presses <<his>> penis against your anus, preparing to penetrate.</span><<sex 5>><<set $anususe to "penis">><<set $penis to "anusimminent">><<set $anusstate to "imminent">><<set $speechanusimminent to 1>>
<<elseif $underanusexposed is 0>><span class="blue"><<He>> presses <<his>> penis against your anus through your $underclothes.</span><<sex 3>><<set $penis to "anusentrance">><<set $anususe to "penis">><<set $underintegrity -= 10>><<set $anusstate to "entrance">><<set $speechanusentrance to 1>>
<</if>>
<<elseif $loweranusexposed is 0>><span class="blue"><<He>> presses <<his>> penis against your anus through your $lowerclothes.</span><<sex 2>><<set $penis to "anusentrance">><<set $anususe to "penis">><<set $lowerintegrity -= 10>><<set $anusstate to "entrance">><<set $speechanusentrance to 1>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng gte 171>>
<<if $vaginaexist is 1>>
<<if $vaginause is 0>>
<<if $lowervaginaexposed is 1>>
<<if $undervaginaexposed is 1>><span class="purple"><<He>> presses <<his>> penis against your <<pussycomma>> preparing to penetrate.</span><<sex 5>><<set $vaginause to "penis">><<set $penis to "vaginaimminent">><<set $vaginastate to "imminent">><<set $speechvaginaimminent to 1>>
<<elseif $undervaginaexposed is 0>><span class="blue"><<He>> presses <<his>> penis against your <<pussy>> through your $underclothes.</span><<set $underintegrity -= 10>><<sex 3>><<set $penis to "vaginaentrance">><<set $vaginause to "penis">><<set $vaginastate to "entrance">><<set $speechvaginaentrance to 1>>
<</if>>
<<elseif $lowervaginaexposed is 0>><span class="blue"><<He>> presses <<his>> penis against your <<pussy>> through your $lowerclothes.</span><<sex 2>><<set $penis to "vaginaentrance">><<set $vaginause to "penis">><<set $lowerintegrity -= 10>><<set $vaginastate to "entrance">><<set $speechvaginaentrance to 1>>
<</if>>
<</if>>
<<elseif $penisexist is 1>>
<<if $anususe is 0 and $analdisable is "f">>
<<if $loweranusexposed is 1>>
<<if $underanusexposed is 1>><span class="purple"><<He>> presses <<his>> penis against your anus, preparing to penetrate.</span><<sex 5>><<set $anususe to "penis">><<set $penis to "anusimminent">><<set $anusstate to "imminent">><<set $speechanusimminent to 1>>
<<elseif $underanusexposed is 0>><span class="blue"><<He>> presses <<his>> penis against your anus through your $underclothes.</span><<sex 3>><<set $penis to "anusentrance">><<set $anususe to "penis">><<set $underintegrity -= 10>><<set $anusstate to "entrance">><<set $speechanusentrance to 1>>
<</if>>
<<elseif $loweranusexposed is 0>><span class="blue"><<He>> presses <<his>> penis against your anus through your $lowerclothes.</span><<sex 2>><<set $penis to "anusentrance">><<set $anususe to "penis">><<set $lowerintegrity -= 10>><<set $anusstate to "entrance">><<set $speechanusentrance to 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<set $rng to random(1, 100)>>
<<if $vagina is "clothed">>
<<if $pronoun is "f">>
<<if $enemyarousal gte 40>><span class="blue"><<He>> lifts up <<his>> skirt, revealing <<his>> moistened pussy.</span><<set $vagina to 0>>
<</if>>
<<else>>
<<if $enemyarousal gte 40>><span class="blue"><<He>> unzips <<his>> fly, revealing <<his>> moistened pussy.</span><<set $vagina to 0>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $vagina is "frot">>
<<if $rng gte 101>><span class="blue"><<He>> moves <<his>> clit away and presses <<his>> hungry pussy against your <<penisstop>></span><<set $penisuse to "othervagina">><<set $vagina to "penisentrance">><<set $penisstate to "entrance">><<set $speechpenisentrance to 1>>
<<else>>
<<He>> rubs <<his>> clit against your glans.<<sex 5>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $vagina is "penis">>
<<if $rng gte 101>><span class="purple"><<He>> moves <<his>> pelvis away, releasing your <<penis>> from <<his>> vagina.</span><<sex 30>><<set $vagina to "penisimminent">><<bruise penis>><<violence 1>><<set $penistate to "imminent">><<set $speechpenisimminent to 1>>
<<elseif $rng gte 1>>
<<if $enemyanger gte 100>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
<<His>> continues to fuck your <<peniscomma>> <<his>> movements violent and erratic as <<his>> pussy slides along your length.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues to ride you, your penis helpless as it's fucked.
<<else>>
<<He>> fucks your <<penis>> with rough movements, intent on showing you who's boss.
<</if>>
<<elseif $enemyanger gte 20>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
You feel <<his>> vagina twitch and throb around your length <<he>> fucks you.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues to violate your <<peniscomma>> using you as a sex toy.
<<else>>
<<He>> fucks your <<peniscomma>> taking as much of you into <<his>> vagina as <<he>> can.
<</if>>
<<else>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
<<He>> continues riding your <<peniscomma>> <<his>> vagina rhythmically kneading and squeezing your length. <<His>> body jerks whenever you hit a sensitive spot.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues riding your <<peniscomma>> <<his>> vagina rhythmically kneading and squeezing your length.
<<else>>
<<He>> rides your <<penis>> with steady movements.
<</if>>
<</if>>
<<sex 30>><<bruise penis>><<violence 1>><<set $speechpenispenetrated to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $vagina is "penisimminent">>
<<if $rng gte 101>><span class="blue"><<He>> stops pressing <<his>> pussy against your <<penisstop>></span><<set $vagina to "penisentrance">><<set $penisstate to "entrance">><<set $speechpenisentrance to 1>>
<<elseif $rng gte 1>>
<<if $nopenile is 0>><<set $penisactiondefault to "take">>
<<if $penilevirginity is 0>><span class="pink"><<He>> eases your <<penis>> into <<his>> pussy, swallowing you to the base.</span><<sex 30>><<set $vagina to "penis">><<penilestat>><<bruise penis>><<violence 1>><<raped>><<penisraped>><<set $penisstate to "penetrated">><<set $speechpenispenetrated to 1>>
<<elseif $penilevirginity is 1>><span class="pink"><<He>> eases your virgin penis into <<his>> pussy,</span><span class="red"> separating your foreskin from your glans and forever robbing you of your purity.</span><<sex 100>><<set $vagina to "penis">><<set $penilevirginity to 0>><<bruise penis>><<penilestat>><<violence 100>><<raped>><<penisraped>><<set $penisstate to "penetrated">><<set $speechpenisvirgin to 1>>
<</if>>
<<else>>
Respecting your wishes, <<he>> does not envelope your <<penis>> with <<his>> vagina, instead teasing the tip of your glans.<<sex 15>><<set $speechpeniswithhold to 1>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $vagina is "penisentrance">>
<<if $rng gte 101>><span class="lblue"><<He>> moves <<his>> pussy away from your <<penisstop>></span><<set $vagina to 0>><<set $penisuse to 0>><<set $penisstate to 0>>
<<elseif $rng gte 1>>
<<if $lowervaginaexposed is 0>><<He>> rubs <<his>> pussy against your <<penis>> through your $lowerclothes.<<sex 5>><<set $lowerintegrity -= 10>><<set $speechpenisentrance to 1>>
<<elseif $lowervaginaexposed is 1>><<set $rng to random(1, 100)>>
<<if $undervaginaexposed is 0>><<He>> rubs <<his>> pussy against your <<penis>> through your $underclothes.<<sex 5>><<set $underintegrity -= 10>><<set $speechpenisentrance to 1>>
<<elseif $undervaginaexposed is 1>>
<<if $rng gte 71>>
<<if $nopenile is 1>>
<span class="purple"><<He>> presses <<his>> pussy against your <<penisstop>></span><<sex 20>><<set $vagina to "penisimminent">><<set $penisstate to "imminent">><<set $speechpenisimminent to 1>>
<<else>>
<span class="purple"><<He>> presses <<his>> pussy against your <<peniscomma>> preparing to envelope you fully.</span><<sex 20>><<set $vagina to "penisimminent">><<set $penisstate to "imminent">><<set $speechpenisimminent to 1>>
<</if>>
<<elseif $rng gte 1>><<He>> teases your <<penis>> with <<his>> labia.<<sex 10>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $vagina is "lefthand">>
<<if $rng lte 80>>
<<He>> strokes <<his>> pussy with <<his>> left hand.<<neutral 1>><<set $enemyarousal += 20>>
<<else>>
<span class="blue"><<He>> moves <<his>> left hand away from <<his>> pussy.</span>
<<set $lefthand to 0>><<set $vagina to 0>>
<</if>>
<</if>>
<<if $vagina is "righthand">>
<<if $rng lte 80>>
<<He>> strokes <<his>> pussy with <<his>> right hand.<<neutral 1>><<set $enemyarousal += 20>>
<<else>>
<span class="blue"><<He>> moves <<his>> right hand away from <<his>> pussy.</span>
<<set $righthand to 0>><<set $vagina to 0>>
<</if>>
<</if>>
<<if $vagina is "mouth">>
<<if $enemyanger gte 100>>
<<He>> covers your mouth with <<his>> pussy, making it difficult to breathe.<<violence 3>><<bruise face>><<set $speechvaginamouth to 1>>
<<else>>
<<if $mouthsubmit is 1>>
<<if $rng gte 1>>
<<He>> rubs <<his>> pussy against your lips.
<<if $enemyarousal gte (($enemyarousalmax / 5) * 3)>>
You can taste <<his>> juices.
<</if>>
<<sex 3>><<set $speechvaginamouth to 1>>
<<else>><<He>> moves <<his>> pussy away from your face.<<set $mouthuse to 0>><<set $mouthstate to 0>><<set $vagina to 0>>
<</if>>
<<else>>
<<if $rng gte 1>>
<<He>> rubs <<his>> pussy against your lips.
<<if $enemyarousal gte (($enemyarousalmax / 5) * 3)>>
You can taste <<his>> juices.
<</if>>
<<sex 3>><<set $speechvaginamouth to 1>>
<<else>><<He>> moves <<his>> pussy away from your face.<<set $mouthuse to 0>><<set $mouthstate to 0>><<set $vagina to 0>>
<</if>>
<</if>>
<</if>>
<</if>>
<<if $vagina is "vagina">>
<<if $rng gte 1>>
<<He>> kneads your pussies together.<<sex 20>><<set $speechvaginavagina to 1>>
<<else>>
<span class="lblue"><<He>> moves <<his>> pussy away from yours.</span><<set $vaginause to 0>><<set $vagina to 0>>
<</if>>
<</if>>
<<if $vagina is "leftarm">>
<<if $rng gte 1>>
<<He>> rubs <<his>> pussy against your fingers.<<submission 2>>
<<else>>
<<He>> moves your hand away from <<his>> pussy.<<set $leftarm to 0>><<set $vagina to 0>><<set $leftactiondefault to "leftplay">>
<</if>>
<</if>>
<<if $vagina is "rightarm">>
<<if $rng gte 1>>
<<He>> rubs <<his>> pussy against your fingers.<<submission 2>>
<<else>>
<<He>> moves your hand away from <<his>> pussy.<<set $rightarm to 0>><<set $vagina to 0>><<set $rightactiondefault to "rightplay">>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $vagina is "feet">>
<<if $rng gte 1>>
<<He>> rubs <<his>> pussy against your feet.<<submission 2>>
<<else>>
<<He>> moves your feet away from <<his>> pussy.<<set $feetuse to 0>><<set $vagina to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $vagina is "footjob">>
<<if $rng gte 101>>
<span class="blue"><<He>> stops pressing <<his>> foot against your <<genitalsstop>></span><<set $vagina to 0>>
<<if $penisexist is 1>>
<<set $penisuse to 0>>
<<else>>
<<set $vaginause to 0>>
<</if>>
<<else>>
<<if $penisexist is 1>>
<<He>> presses your penis against your stomach with <<his>> foot and rubs your glans between <<his>> toes.
<<set $speechpenisfoot to 1>><<neutral 5>><<violence 1>>
<<else>>
<<He>> rubs <<his>> foot against your <<pussystop>>
<<set $speechvaginafoot to 1>><<neutral 5>><<violence 1>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $vagina is "otherfrot">>
<<if $rng gte 101>><span class="blue"><<He>> shifts <<his>> ass and presses <<his>> anus against your <<penisstop>></span><<set $penisuse to "otheranus">><<set $vagina to "otheranusentrance">><<set $penisstate to "otheranusentrance">><<set $speechotheranusentrance to 1>>
<<else>>
<<He>> rubs <<his>> ass against your <<penisstop>><<sex 5>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $vagina is "otheranus">>
<<if $rng gte 101>><span class="purple"><<He>> moves <<his>> pelvis away, releasing your <<penis>> from <<his>> anus.</span><<sex 30>><<set $vagina to "otheranusimminent">><<bruise penis>><<violence 1>><<set $penisstate to "otheranusimminent">><<set $speechotheranusimminent to 1>>
<<elseif $rng gte 1>>
<<if $enemyanger gte 100>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
<<His>> continues to fuck your <<penis>> with <<his>> ass, <<his>> movements violent and erratic. Fluid from <<his>> pussy drools onto your length.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues to ride you, your penis helpless as it's fucked.
<<else>>
<<He>> fucks your <<penis>> with rough movements, intent on showing you who's boss.
<</if>>
<<elseif $enemyanger gte 20>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
You feel <<his>> ass twitch around your length as <<he>> fucks you.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues to violate your <<peniscomma>> using you as a sex toy.
<<else>>
<<He>> fucks your <<peniscomma>> taking as much of you into <<his>> ass as <<he>> can.
<</if>>
<<else>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
<<He>> continues riding your <<peniscomma>> <<his>> anus rhythmically pounding your length. <<His>> body jerks whenever you hit a sensitive spot.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues riding your <<peniscomma>> <<his>> anus rhythmically pounding your length.
<<else>>
<<He>> rides your <<penis>> with steady movements.
<</if>>
<</if>>
<<sex 30>><<bruise penis>><<violence 1>><<set $speechotheranus to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $vagina is "otheranusimminent">>
<<if $rng gte 101>><span class="blue"><<He>> stops pressing <<his>> ass against your <<penisstop>></span><<set $vagina to "otheranusentrance">><<set $penisstate to "otheranusentrance">><<set $speechotheranusentrance to 1>>
<<elseif $rng gte 1>>
<<if $nopenile is 0>><<set $penisactiondefault to "take">>
<<if $penilevirginity is 0>><span class="pink"><<He>> eases your <<penis>> into <<his>> ass, swallowing you to the base.</span><<sex 30>><<set $vagina to "otheranus">><<penilestat>><<bruise penis>><<violence 1>><<raped>><<penisraped>><<set $penisstate to "otheranus">><<set $speechotheranus to 1>>
<<elseif $penilevirginity is 1>><span class="pink"><<He>> eases your virgin penis into <<his>> ass,</span><span class="red"> separating your foreskin from your glans and forever robbing you of your purity.</span><<sex 100>><<set $vagina to "otheranus">><<set $penilevirginity to 0>><<bruise penis>><<penilestat>><<violence 100>><<raped>><<penisraped>><<set $penisstate to "otheranus">><<set $speechpenisvirgin to 1>>
<</if>>
<<else>>
Respecting your wishes, <<he>> does not envelope your <<penis>> with <<his>> ass, instead teasing the tip of your glans.<<sex 15>><<set $speechotheranuswithhold to 1>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $vagina is "otheranusentrance">>
<<if $rng gte 101>><span class="lblue"><<He>> moves <<his>> ass away from your <<penisstop>></span><<set $vagina to 0>><<set $penisuse to 0>><<set $penisstate to 0>>
<<elseif $rng gte 1>>
<<if $lowervaginaexposed is 0>><<He>> rubs <<his>> ass against your <<penis>> through your $lowerclothes.<<sex 5>><<set $lowerintegrity -= 10>><<set $speechotheranusentrance to 1>>
<<elseif $lowervaginaexposed is 1>><<set $rng to random(1, 100)>>
<<if $undervaginaexposed is 0>><<He>> rubs <<his>> ass against your <<penis>> through your $underclothes.<<sex 5>><<set $underintegrity -= 10>><<set $speechotheranusentrance to 1>>
<<elseif $undervaginaexposed is 1>>
<<if $rng gte 71>>
<<if $nopenile is 1>>
<span class="purple"><<He>> presses <<his>> ass against your <<penisstop>></span><<sex 20>><<set $vagina to "otheranusimminent">><<set $penisstate to "otheranusimminent">><<set $speechotheranusimminent to 1>>
<<else>>
<span class="purple"><<He>> presses <<his>> ass against your <<peniscomma>> preparing to take you in fully.</span><<sex 20>><<set $vagina to "otheranusimminent">><<set $penisstate to "otheranusimminent">><<set $speechotheranusimminent to 1>>
<</if>>
<<elseif $rng gte 1>><<He>> rubs your <<penis>> between <<his>> cheeks.<<sex 10>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<if $vagina is 0>>
<<if $enemyanger + $rng lte 20>><<He>> sways <<his>> hips suggestively.<<neutral 1>><<set $speechvaginaflaunt to 1>>
<<elseif $enemyanger + $rng lte 40>><<He>> twirls on the spot.<<neutral 3>><<set $speechvaginaflaunt to 1>>
<<elseif $enemyanger + $rng lte 50>>
<<if $penisexist is 1>>
<<if $penisuse is 0 and $analdisable is "f">>
<span class="blue"><<He>> straddles you, rubbing <<his>> ass against your <<penisstop>></span><<neutral 5>><<set $penisuse to "otheranus">><<set $vagina to "otheranusentrance">><<set $penisstate to "otheranusentrance">><<set $speechotheranusentrance to 1>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 60>><<He>> rubs <<his>> pussy against your thigh.<<neutral 10>>
<<elseif $enemyanger + $rng lte 80 and $lefthand is 0>>
<span class="lblue"><<He>> presses <<his>> fingers against <<his>> labia.</span><<neutral 1>><<set $enemyarousal += 10>><<set $vagina to "lefthand">><<set $lefthand to "othervagina">>
<<elseif $enemyanger + $rng lte 80 and $righthand is 0>>
<span class="lblue"><<He>> presses <<his>> fingers against <<his>> labia.</span><<neutral 1>><<set $enemyarousal += 10>><<set $vagina to "righthand">><<set $righthand to "othervagina">>
<<elseif $enemyanger + $rng lte 80>>
<<He>> rubs <<his>> pussy against your thigh.<<neutral 2>>
<<elseif $enemyanger + $rng lte 100 and $penisuse is 0 and $undervaginaexposed is 1 and $lowervaginaexposed is 1>>
<<set $penisuse to "othervagina">><<set $vagina to "penisentrance">><<set $penisstate to "entrance">><span class="blue"><<He>> straddles you, <<his>> pussy hovering close to your <<penisstop>></span>
<<elseif $enemyanger + $rng lte 120 and $penisuse is 0 and $penisexist is 1 and $undervaginaexposed is 1 and $lowervaginaexposed is 1>>
<<set $penisuse to "othervagina">><<set $vagina to "penisimminent">><<set $penisstate to "imminent">><span class="purple"><<He>> wraps <<his>> legs around your pelvis, pressing <<his>> pussy against your <<genitalsstop>></span>
<<elseif $enemyanger + $rng lte 120 and $vaginause is 0 and $vaginaexist is 1 and $undervaginaexposed is 1 and $lowervaginaexposed is 1>>
<<set $vaginause to "othervagina">><<set $vagina to "vagina">><<sex 20>><<He>> pushes <<his>> pussy against yours.
<<elseif $enemyanger + $rng lte 140>>
<<if $position is "wall">>
<<He>> sits on your protruding <<bottomcomma>> pressing down on you painfully.<<violence 3>>
<<elseif $mouth is 0>>
<<He>> rubs <<his>> clit against your face.<<violence 3>>
<<else>>
<<He>> frots against your thigh while squeezing it with <<his>> own.<<violence 3>>
<</if>>
<<elseif $enemyanger + $rng lte 160>><span class="purple"><<He>> presses <<his>> foot against your <<genitalsstop>></span><<neutral 5>><<set $vagina to "footjob">>
<<if $penisexist is 1>>
<<set $penisuse to "feet">><<set $speechpenisfoot to 1>>
<<else>>
<<set $vaginause to "feet">><<set $speechvaginafoot to 1>>
<</if>>
<<elseif $enemyanger + $rng lte 180>>
<<if $position is "wall">>
<<He>> kicks you in the <<bottomstop>><<violence 10>><<hitstat>><<bruise bottom>>
<<else>>
<<He>> kicks you in the stomach.<<violence 10>><<hitstat>><<bruise face>>
<</if>>
<<elseif $enemyanger + $rng lte 200 and $mouthuse is 0>>
<<if $pullaway is 1>><<set $pullaway to 0>>
Saliva drips from her pussy.
<<else>>
<<if $position is "wall">>
<<if $penisexist is 1>>
<<He>> kicks your <<penisstop>><<violence 20>><<hitstat>><<bruise penis>><<set $speechbeat to 1>>
<<elseif $vaginaexist is 1>>
<<He>> kicks your <<pussystop>><<violence 20>><<hitstat>><<bruise vagina>><<set $speechbeat to 1>>
<</if>>
<<else>>
<span class="purple"><<He>> wraps <<his>> legs around your head and presses <<his>> pussy against your mouth.</span>
<<submission 5>><<set $mouthuse to "othervagina">><<set $vagina to "mouth">><<set $mouthstate to "othervagina">><<violence 3>><<bruise face>><<set $speechvaginamouth to 1>>
<</if>>
<</if>>
<<else>>
<<if $position is "wall">>
<<if $penisexist is 1>>
<<He>> kicks your <<penisstop>><<violence 20>><<hitstat>><<bruise penis>><<set $speechbeat to 1>>
<<elseif $vaginaexist is 1>>
<<He>> kicks your <<pussystop>><<violence 20>><<hitstat>><<bruise vagina>><<set $speechbeat to 1>>
<</if>>
<<else>>
<<He>> kicks you in the face.<<violence 10>><<bruise face>><<set $speechbeat to 1>><<hitstat>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth is "thigh">>
<<He>> kisses and licks your thigh.<<neutral 5>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth is "bottom">>
<<He>> kisses and licks your <<bottomstop>><<neutral 5>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth is "anus">>
<<if $rng gte 101>><span class="purple"><<He>> retracts <<his>> tongue from your anus.</span><<sex 30>><<set $mouth to "anusimminent">><<bruise anus>><<violence 1>><<set $anusstate to "othermouthimminent">>
<<elseif $rng gte 1>>
<<if $enemyarousal lte ($enemyarousalmax / 5)>>
<<He>> caresses your anus with <<his>> tongue.<<sex 30>><<bruise anus>><<violence 1>>
<<elseif $enemyarousal lte (($enemyarousalmax / 5) * 2)>>
<<His>> tongue probes inside your <<bottomstop>><<sex 30>><<bruise anus>><<violence 1>>
<<elseif $enemyarousal lte (($enemyarousalmax / 5) * 3)>>
<<He>> circles <<his>> tongue inside your <<bottomstop>><<sex 30>><<bruise anus>><<violence 1>>
<<elseif $enemyarousal lte (($enemyarousalmax / 5) * 4)>>
<<He>> presses <<his>> mouth firmly against your <<bottomcomma>> letting <<him>> push <<his>> tongue deeper into your anus.<<sex 30>><<bruise anus>><<violence 1>>
<<else>>
Repeatedly thrusting and retracting, <<he>> fucks your <<bottom>> with <<his>> tongue.<<sex 30>><<bruise anus>><<violence 1>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth is "anusimminent">>
<<if $rng gte 101>><span class="blue"><<He>> stops pressing <<his>> tongue against your anus.</span><<set $mouth to "anusentrance">><<set $anusstate to "othermouthentrance">>
<<elseif $rng gte 1>>
<<if $noanal is 0>>
<<if $analvirginity is 0>><span class="pink"><<He>> pushes <<his>> tongue into your anus.</span><<sex 30>><<set $mouth to "anus">><<analstat>><<bruise anus>><<violence 1>><<raped>><<set $anusstate to "othermouth">>
<<elseif $analvirginity is 1>><span class="pink"><<He>> pushes <<his>> tongue into your virgin anus,</span><span class="red"> violating you in a way you hadn't conceived of.</span><<sex 100>><<set $mouth to "anus">><<set $analvirginity to 0>><<bruise anus>><<analstat>><<violence 100>><<raped>><<set $anusstate to "othermouth">>
<</if>>
<<else>>
Respecting your wishes, <<he>> does not penetrate your <<bottom>> with <<his>> tongue, instead licking your anus.<<sex 15>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth is "anusentrance">>
<<if $rng gte 101>><span class="lblue"><<He>> moves <<his>> head away from your <<bottomstop>></span><<set $mouth to 0>><<set $anususe to 0>><<set $anusstate to 0>>
<<if $vagina is "othermouth">>
<<set $vagina to 0>>
<</if>>
<<if $penis is "othermouth">>
<<set $penis to 0>>
<</if>>
<<elseif $rng gte 1>>
<<if $loweranusexposed is 0>><<He>> circles <<his>> tongue around your anus through your $lowerclothes.<<sex 5>><<set $lowerintegrity -= 10>>
<<elseif $loweranusexposed is 1>><<set $rng to random(1, 100)>>
<<if $underanusexposed is 0>><<He>> circles <<his>> tongue around your anus through your $underclothes.<<sex 5>><<set $underintegrity -= 10>>
<<elseif $underanusexposed is 1>>
<<if $rng gte 71>>
<<if $noanal is 1>>
<span class="purple"><<He>> presses <<his>> tongue against your anus.</span><<sex 20>><<set $mouth to "anusimminent">><<set $anusstate to "othermouthimminent">>
<<else>>
<span class="purple"><<He>> presses <<his>> tongue against your anus, preparing to penetrate you.</span><<sex 20>><<set $mouth to "anusimminent">><<set $anusstate to "othermouthimminent">>
<</if>>
<<elseif $rng gte 1>><<He>> kisses and licks your <<bottomstop>><<sex 10>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth is "vagina">>
<<if $rng gte 101>><span class="purple"><<He>> retracts <<his>> tongue from your <<pussystop>></span><<sex 30>><<set $mouth to "vaginaimminent">><<bruise vagina>><<violence 1>><<set $vaginastate to "othermouthimminent">>
<<elseif $rng gte 1>>
<<if $enemyarousal lte ($enemyarousalmax / 5)>>
<<He>> caresses your vagina with <<his>> tongue.<<sex 30>><<bruise vagina>><<violence 1>>
<<elseif $enemyarousal lte (($enemyarousalmax / 5) * 2)>>
<<He>> presses down on your clit with <<his>> teeth while exploring your vagina with <<his>> tongue.<<sex 30>><<bruise vagina>><<violence 1>>
<<elseif $enemyarousal lte (($enemyarousalmax / 5) * 3)>>
<<He>> circles <<his>> tongue around your vagina.<<sex 30>><<bruise vagina>><<violence 1>>
<<elseif $enemyarousal lte (($enemyarousalmax / 5) * 4)>>
<<He>> presses <<his>> mouth firmly against your <<pussycomma>> then pushes <<his>> tongue deeper into your vagina. <<He>> slowly pulls out again, then takes a deep breath.<<sex 30>><<bruise vagina>><<violence 1>>
<<else>>
Repeatedly thrusting and retracting, <<he>> fucks your <<pussy>> with <<his>> tongue.<<sex 30>><<bruise vagina>><<violence 1>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth is "vaginaimminent">>
<<if $rng gte 101>><span class="blue"><<He>> stops pressing <<his>> tongue against your <<pussystop>></span><<set $mouth to "vaginaentrance">><<set $vaginastate to "othermouthentrance">>
<<elseif $rng gte 1>>
<<if $novaginal is 0>>
<<if $vaginalvirginity is 0>><span class="pink"><<He>> pushes <<his>> tongue between your <<pussy>> lips.</span><<sex 30>><<set $mouth to "vagina">><<vaginalstat>><<bruise vagina>><<violence 1>><<raped>><<vaginaraped>><<set $vaginastate to "othermouth">>
<<elseif $vaginalvirginity is 1>><span class="pink"><<He>> pushes <<his>> tongue into your virgin pussy,</span><span class="red"> breaking your hymen and forever robbing you of your purity.</span><<sex 100>><<set $mouth to "vagina">><<set $vaginalvirginity to 0>><<bruise vagina>><<vaginalstat>><<violence 100>><<raped>><<vaginaraped>><<set $vaginastate to "othermouth">>
<</if>>
<<else>>
Respecting your wishes, <<he>> does not penetrate your <<pussy>> with <<his>> tongue, instead running <<his>> tongue up and down your labia.<<sex 15>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth is "vaginaentrance">>
<<if $rng gte 101>><span class="lblue"><<He>> moves <<his>> head away from your <<pussystop>></span><<set $mouth to 0>><<set $vaginause to 0>><<set $vaginastate to 0>>
<<if $vagina is "othermouth">>
<<set $vagina to 0>>
<</if>>
<<if $penis is "othermouth">>
<<set $penis to 0>>
<</if>>
<<elseif $rng gte 1>>
<<if $lowervaginaexposed is 0>><<He>> traces the outline of your <<pussy>> with <<his>> tongue through your $lowerclothes.<<sex 5>><<set $lowerintegrity -= 10>>
<<elseif $lowervaginaexposed is 1>><<set $rng to random(1, 100)>>
<<if $undervaginaexposed is 0>><<He>> traces the outline of your <<pussy>> with <<his>> tongue through your $underclothes.<<sex 5>><<set $underintegrity -= 10>>
<<elseif $undervaginaexposed is 1>>
<<if $rng gte 71>>
<<if $novaginal is 1>>
<span class="purple"><<He>> presses <<his>> lips against your <<pussystop>></span><<sex 20>><<set $mouth to "vaginaimminent">><<set $vaginastate to "othermouthimminent">>
<<else>>
<span class="purple"><<He>> presses <<his>> lips against your <<pussycomma>> preparing to fuck you with <<his>> tongue.</span><<sex 20>><<set $mouth to "vaginaimminent">><<set $vaginastate to "othermouthimminent">>
<</if>>
<<elseif $rng gte 1>><<He>> blows on your clit and runs <<his>> tongue around your labia.<<sex 10>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth is "penis">>
<<if $rng gte 101>><span class="purple"><<He>> moves <<his>> head back, releasing your <<penis>> from <<his>> mouth.</span><<sex 30>><<set $mouth to "penisimminent">><<bruise penis>><<violence 1>><<set $penisstate to "othermouthimminent">>
<<elseif $rng gte 1>>
<<if $enemyarousal lte ($enemyarousalmax / 5)>>
<<He>> slowly caresses your shaft with <<his>> tongue.<<sex 30>><<bruise penis>><<violence 1>>
<<elseif $enemyarousal lte (($enemyarousalmax / 5) * 2)>>
Eyes fixed on your face, <<he>> wraps <<his>> tongue around your <<penis>> and sucks.<<sex 30>><<bruise penis>><<violence 1>>
<<elseif $enemyarousal lte (($enemyarousalmax / 5) * 3)>>
<<He>> squeezes <<his>> lips around your <<peniscomma>> and circles <<his>> tongue around your glans.<<sex 30>><<bruise penis>><<violence 1>>
<<elseif $enemyarousal lte (($enemyarousalmax / 5) * 4)>>
<<He>> takes you deeper into <<his>> mouth, until your <<penis>> disappears inside <<him>> completely. <<He>> slowly pushes you out again, then takes a deep breath.<<sex 30>><<bruise penis>><<violence 1>>
<<else>>
<<He>> repeatedly swallows and expels your <<peniscomma>> fucking you with <<his>> mouth.<<sex 30>><<bruise penis>><<violence 1>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth is "penisimminent">>
<<if $rng gte 101>><span class="blue"><<He>> stops pressing <<his>> lips against your <<penisstop>></span><<set $mouth to "penisentrance">><<set $penisstate to "othermouthentrance">>
<<elseif $rng gte 1>>
<<if $nopenile is 0>>
<<if $penilevirginity is 0>><span class="pink"><<He>> pushes <<his>> lips against your <<peniscomma>> taking you into <<his>> mouth.</span><<sex 30>><<set $mouth to "penis">><<penilestat>><<bruise penis>><<violence 1>><<raped>><<penisraped>><<set $penisstate to "othermouth">>
<<elseif $penilevirginity is 1>><span class="pink"><<He>> pushes <<his>> lips against your virgin penis, taking you into <<his>> mouth,</span><span class="red"> separating your foreskin from your glans and forever robbing you of your purity.</span><<sex 100>><<set $mouth to "penis">><<set $penilevirginity to 0>><<bruise penis>><<penilestat>><<violence 100>><<raped>><<penisraped>><<set $penisstate to "othermouth">>
<</if>>
<<else>>
Respecting your wishes, <<he>> does not envelope your <<penis>> with <<his>> mouth, instead kissing the tip of your glans.<<sex 15>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth is "penisentrance">>
<<if $rng gte 101>><span class="lblue"><<He>> moves <<his>> head away from your <<penisstop>></span><<set $mouth to 0>><<set $penisuse to 0>><<set $penisstate to 0>>
<<if $vagina is "othermouth">>
<<set $vagina to 0>>
<</if>>
<<if $penis is "othermouth">>
<<set $penis to 0>>
<</if>>
<<elseif $rng gte 1>>
<<if $lowervaginaexposed is 0>><<He>> traces the outline of your <<penis>> with <<his>> tongue through your $lowerclothes.<<sex 5>><<set $lowerintegrity -= 10>>
<<elseif $lowervaginaexposed is 1>><<set $rng to random(1, 100)>>
<<if $undervaginaexposed is 0>><<He>> traces the outline of your <<penis>> with <<his>> tongue through your $underclothes.<<sex 5>><<set $underintegrity -= 10>>
<<elseif $undervaginaexposed is 1>>
<<if $rng gte 71>>
<<if $nopenile is 1>>
<span class="purple"><<He>> presses <<his>> lips against your <<penisstop>></span><<sex 20>><<set $mouth to "penisimminent">><<set $penisstate to "othermouthimminent">>
<<else>>
<span class="purple"><<He>> presses <<his>> lips against your <<peniscomma>> preparing to take you in <<his>> mouth proper.</span><<sex 20>><<set $mouth to "penisimminent">><<set $penisstate to "othermouthimminent">>
<</if>>
<<elseif $rng gte 1>><<He>> blows on and licks the tip of your <<penisstop>><<sex 10>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth is "kiss">>
<<if $speechvaginavirgin isnot 1 and $speechpenisvirgin isnot 1 and $speechanusvirgin isnot 1 and $speechmouthvirgin isnot 1>>
<<if $rng gte 101>>
<span class="lblue"><<He>> pulls <<his>> mouth away from yours.</span><<set $mouth to 0>><<set $mouthuse to 0>><<set $mouthstate to 0>>
<<else>>
<<if $enemyanger lte 20>>
<<He>> explores your mouth with <<his>> tongue.<<sex 2>>
<<else>>
<<He>> thrusts <<his>> tongue deep into your mouth.<<violence 1>>
<</if>>
<</if>>
<<else>>
<span class="lblue"><<He>> pulls <<his>> mouth away from yours.</span><<set $mouthuse to 0>><<set $mouth to 0>><<set $mouthstate to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth is "kissimminent">>
<<if $speechvaginavirgin isnot 1 and $speechpenisvirgin isnot 1 and $speechanusvirgin isnot 1 and $speechmouthvirgin isnot 1>>
<<if $rng gte 101>>
<span class="lblue"><<He>> pulls <<his>> mouth away from yours.</span><<set $mouth to 0>><<set $mouthuse to 0>><<set $mouthstate to 0>>
<<elseif $rng lte 100>>
<<He>> pushes <<his>> tongue between your lips.<<set $mouth to "kiss">><<set $mouthstate to "kiss">><<sex 2>>
<<else>>
<<if $enemyanger lte 20>>
<<He>> gently probes your lips with <<his>> tongue.<<sex 2>>
<<else>>
<<He>> bites and toys with your lips.<<violence 1>>
<</if>>
<</if>>
<<else>>
<span class="lblue"><<He>> pulls <<his>> mouth away from yours.</span><<set $mouthuse to 0>><<set $mouth to 0>><<set $mouthstate to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth is "kissentrance">>
<<if $speechvaginavirgin isnot 1 and $speechpenisvirgin isnot 1 and $speechanusvirgin isnot 1 and $speechmouthvirgin isnot 1>>
<<if $rng gte 101>>
<span class="lblue"><<He>> pulls <<his>> mouth away from yours.</span><<set $mouth to 0>><<set $mouthuse to 0>><<set $mouthstate to 0>>
<<elseif $rng lte 100>>
<<He>> pulls you closer and presses your lips together in a kiss.<<set $mouth to "kissimminent">><<set $mouthstate to "kissimminent">><<sex 2>>
<<else>>
<<if $enemyanger lte 20>>
<<He>> gently brushes <<his>> lips against yours.<<sex 1>>
<<else>>
<<He>> bites your lower lip.<<violence 1>>
<</if>>
<</if>>
<<else>>
<span class="lblue"><<He>> pulls <<his>> mouth away from yours.</span><<set $mouthuse to 0>><<set $mouth to 0>><<set $mouthstate to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $npc is "Robin">>
<<if $speechvaginavirgin is 1>>
<<He>> gasps. "You saved yourself for me. I don't deserve something so special. Thank you." Tears roll down <<his>> cheeks.
<<elseif $speechpenisvirgin is 1>>
<<He>> gasps. "You saved yourself for me. I don't deserve something so special. Thank you." Tears roll down <<his>> cheeks.
<<elseif $speechanusvirgin is 1>>
<<He>> gasps. "This is so naughty!"
<<elseif $speechmouthvirgin is 1>>
<<He>> gasps. "You're making me feel funny down there."
<</if>>
<<elseif $mouth is 0 and $speechdisable isnot 1>>
<<if $speechvaginavirgin is 1>>
<<if $enemyanger lte 60>>
<<He>> speaks. "You were a virgin! I can't believe my luck!"
<<else>>
<<He>> speaks. "I felt your hymen tear bitch. Something to remember me by."
<</if>>
<<elseif $speechpenisvirgin is 1>>
<<if $enemyanger lte 60>>
<<He>> speaks. "AHH! This was your first time wasn't it? It feels so good!"
<<else>>
<<He>> speaks. "How's it feel to have your virgin dick broken in? Feels amazing for me."
<</if>>
<<elseif $speechanusvirgin is 1>>
<<if $enemyanger lte 60>>
<<He>> speaks. "It's so tight! This must be the first time your ass has been used like this."
<<else>>
<<He>> speaks. "It's so tight! This must be the first time your ass has been used like this. I've got plenty more work to do before you're properly broken in."
<</if>>
<<elseif $speechmouthvirgin is 1>>
<<if $enemyanger lte 60>>
<<He>> speaks. "Is this the first time you've tasted dick?"
<<else>>
<<He>> speaks. "Is this the first time you've tasted dick? You'll be a cum-addicted cock slave soon."
<</if>>
<<elseif $speechcum is 1 and $rng gte 61 and $speechorgasmrepeat lte 1 and $speechorgasmcount lte 6>>
<<cumspeech>>
<<elseif $rng gte 61>>
<<combatspeech>><<neutral 1>>
<<elseif $rng gte 91>>
<<basespeech>><<neutral 1>>
<<else>>
<<set $rng to random(1, 100)>>
<<if $enemyanger + $rng lte 20>><<He>> <<admires>> your body.<<neutral 1>>
<<elseif $enemyanger + $rng lte 25>>
<<if $position is "wall">>
<<He>> <<admires>> your helpless <<bottomstop>><<neutral 1>>
<<else>>
<<He>> <<admires>> your hair.<<neutral 1>>
<</if>>
<<elseif $enemyanger + $rng lte 30>>
<<if $position is "wall">>
<<He>> <<admires>> your helpless hips.<<neutral 1>>
<<else>>
<<He>> <<admires>> your chest.<<neutral 1>>
<</if>>
<<elseif $enemyanger + $rng lte 35>>
<<He>> <<admires>> your legs.<<neutral 1>>
<<elseif $enemyanger + $rng lte 40>>
<<if $position is "wall">>
<<He>> <<admires>> your helpless legs.<<neutral 1>>
<<else>>
<<He>> <<admires>> your face.<<neutral 1>>
<</if>>
<<elseif $enemyanger + $rng lte 45>>
<<if $position is "wall">>
<<He>> kisses your helpless thighs.<<neutral 3>>
<<else>>
<<He>> kisses you on the forehead.<<neutral 3>>
<</if>>
<<elseif $enemyanger + $rng lte 50>>
<<if $position is "wall">>
<<He>> kisses you on the hips.<<neutral 3>>
<<elseif $penis is "mouth" or $vagina is "mouth">>
<<He>> leans back, savouring the feel of your mouth on <<his>> genitals.<<neutral 10>>
<<else>>
<<He>> kisses you on the cheek.<<neutral 3>>
<</if>>
<<elseif $enemyanger + $rng lte 55>>
<<if $position is "wall">>
<<He>> licks your helpless thighs.<<neutral 3>>
<<elseif $penis is "mouth" or $vagina is "mouth">>
<<He>> leans back, savouring the feel of your mouth on <<his>> genitals.<<neutral 10>>
<<else>>
<<He>> kisses your neck.<<neutral 3>>
<</if>>
<<elseif $enemyanger + $rng lte 60>>
<<if $position is "wall">>
<<He>> licks your helpless hips.<<neutral 3>>
<<else>>
<<He>> licks your cheek.<<neutral 3>>
<</if>>
<<elseif $enemyanger + $rng lte 80>><<neutral 10>>
<<if $position is "wall">>
<<He>> licks your helpless legs.<<neutral 3>>
<<else>>
<<if $mouthuse is 0>>
<<if $penis is "chest">>
<<combatspeech>><<neutral 1>>
<<else>>
<span class="blue"><<He>> moves <<his>> lips close to yours, about to kiss.</span><<set $mouthuse to "kiss">><<set $mouthstate to "kissentrance">><<set $mouth to "kissentrance">><<sex 1>>
<</if>>
<<else>>
<<He>> licks your cheek.
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 84>><<neutral 10>>
<<if $anususe is 0 and $vagina is 0 and $analdisable is "f">>
<span class="blue"><<He>> kneels behind you. You feel <<his>> breath on your <<bottomstop>></span><<set $anususe to "othermouth">><<set $anusstate to "othermouthentrance">><<set $mouth to "anusentrance">><<set $vagina to "othermouth">><<sex 1>>
<<elseif $anususe is 0 and $penis is 0 and $analdisable is "f">>
<span class="blue"><<He>> kneels behind you. You feel <<his>> breath on your <<bottomstop>></span><<set $anususe to "othermouth">><<set $anusstate to "othermouthentrance">><<set $mouth to "anusentrance">><<set $penis to "othermouth">><<sex 1>>
<</if>>
<<elseif $enemyanger + $rng lte 92>><<neutral 10>>
<<if $vaginause is 0 and $vagina is 0 and $vaginaexist is 1>>
<span class="blue"><<He>> kneels beside you. You feel <<his>> breath on your <<pussystop>></span><<set $vaginause to "othermouth">><<set $vaginastate to "othermouthentrance">><<set $mouth to "vaginaentrance">><<set $vagina to "othermouth">><<sex 1>>
<<elseif $vaginause is 0 and $penis is 0 and $vaginaexist is 1>>
<span class="blue"><<He>> kneels beside you. You feel <<his>> breath on your <<pussystop>></span><<set $vaginause to "othermouth">><<set $vaginastate to "othermouthentrance">><<set $mouth to "vaginaentrance">><<set $penis to "othermouth">><<sex 1>>
<<else>>
<<He>> breathes on your skin, making your hair stand on end.<<neutral 1>>
<</if>>
<<elseif $enemyanger + $rng lte 100>><<neutral 10>>
<<if $penisuse is 0 and $penis is 0 and $penisexist is 1>>
<span class="blue"><<He>> kneels beside you. You feel <<his>> breath on your <<penisstop>></span><<set $penisuse to "othermouth">><<set $penisstate to "othermouthentrance">><<set $mouth to "penisentrance">><<set $vagina to "othermouth">><<sex 1>>
<<elseif $penisuse is 0 and $vagina is 0 and $penisexist is 1>>
<span class="blue"><<He>> kneels beside you. You feel <<his>> breath on your <<penisstop>></span><<set $penisuse to "othermouth">><<set $penisstate to "othermouthentrance">><<set $mouth to "penisentrance">><<set $penis to "othermouth">><<sex 1>>
<<else>>
<<He>> breathes on your skin, making your hair stand on end.<<neutral 1>>
<</if>>
<<elseif $enemyanger + $rng lte 105>>
<<if $position is "wall">>
<<He>> kisses and caresses your helpless thighs with <<his>> tongue.<<neutral 10>>
<<else>>
<<He>> kisses and caresses your nipple with <<his>> tongue.<<neutral 10>>
<</if>>
<<elseif $enemyanger + $rng lte 110>>
<<if $position is "wall">>
<<He>> kisses and gently bites your helpless <<bottomstop>><<neutral 10>>
<<elseif $penis is "mouth" or $vagina is "mouth">>
<<He>> leans back, savouring the feel of your mouth on <<his>> genitals.<<neutral 10>>
<<else>>
<<He>> kisses and gently bites you on the neck.<<neutral 10>>
<</if>>
<<elseif $enemyanger + $rng lte 115>>
<<He>> spits on your <<genitalsstop>><<neutral 5>>
<<elseif $enemyanger + $rng lte 120>>
<<He>> spits on your <<bottomstop>><<neutral 5>>
<<elseif $enemyanger + $rng lte 130>>
<<He>> spits on your stomach.<<neutral 5>>
<<elseif $enemyanger + $rng lte 140>>
<<if $position is "wall">>
<<He>> spits on your helpless thighs.<<neutral 5>>
<<else>>
<<He>> spits on your face.<<neutral 5>>
<</if>>
<<elseif $enemyanger + $rng lte 150>>
<<He>> bites your <<bottomstop>><<violence 10>><<hitstat>><<bruise bottom>>
<<elseif $enemyanger + $rng lte 160>>
<<if $position is "wall">>
<<He>> bites your thighs.<<violence 10>><<hitstat>><<bruise thigh>>
<<else>>
<<He>> bites your shoulders.<<violence 10>><<hitstat>><<bruise leftarm>><<bruise rightarm>>
<</if>>
<<elseif $enemyanger + $rng lte 170>>
<<if $position is "wall">>
<<He>> bites your hips.<<violence 10>><<hitstat>><<bruise tummy>>
<<elseif $penis is "mouth" or $vagina is "mouth">>
<<He>> leans back, savouring the feel of your mouth on <<his>> genitals.<<neutral 10>>
<<else>>
<<He>> bites your neck.<<violence 10>><<hitstat>><<bruise neck>>
<</if>>
<<elseif $enemyanger + $rng lte 180>>
<<if $position is "wall">>
<<He>> bites your thighs.<<violence 10>><<hitstat>><<bruise thigh>>
<<elseif $penis is "mouth" or $vagina is "mouth">>
<<He>> leans back, savouring the feel of your mouth on <<his>> genitals.<<neutral 10>>
<<else>>
<<He>> bites your cheek.<<violence 10>><<hitstat>><<bruise face>>
<</if>>
<<elseif $enemyanger + $rng gte 190>>
<<if $position is "wall">>
<<He>> bites your <<bottomstop>><<violence 10>><<hitstat>><<bruise bottom>>
<<else>>
<<He>> bites your <<breastsstop>><<violence 10>><<hitstat>><<bruise chest>>
<</if>>
<</if>>
<</if>>
<</if>>
<<manend>>
<<set $pullaway to 0>>
<</nobr>><</widget>>
:: Widgets State Man [widget]
<<widget "stateman">><<nobr>>
<<if $enemyno is 1>>
<<if $pronoun1 is "m">>
<<set $pronoun to "m">>
<</if>>
<<if $pronoun1 is "f">>
<<set $pronoun to "f">>
<</if>>
<<if $pronoun1 is "i">>
<<set $pronoun to "i">>
<</if>>
<<if $pronoun1 is "n">>
<<set $pronoun to "n">>
<</if>>
<<if $pronoun1 is "t">>
<<set $pronoun to "t">>
<</if>>
<<if $enemytype is "beast">>
<<set $pronoun to "i">>
<</if>>
<<if $enemyhealth gte $enemyhealthmax>><span class="red"><<He>> looks eager.</span>
<<elseif $enemyhealth gte ($enemyhealthmax / 5) * 4>><span class="pink"><<He>> looks uncomfortable.</span>
<<elseif $enemyhealth gte ($enemyhealthmax / 5) * 3>><span class="purple"><<He>> looks stung.</span>
<<elseif $enemyhealth gte ($enemyhealthmax / 5) * 2>><span class="blue"><<He>> looks pained.</span>
<<elseif $enemyhealth gte ($enemyhealthmax / 5) * 1>><span class="lblue"><<He>> looks hurt.</span>
<<elseif $enemyhealth gt 0>><span class="teal"><<He>> doesn't look like <<he>> can take much more pain.</span>
<<elseif $enemyhealth lte 0>><span class="green"><<He>> is recoiling in pain.</span>
<</if>>
<<if $enemyarousal gte $enemyarousalmax>>
<<if $penis isnot "none">><span class="red">Ejaculation imminent.</span>
<<else>>
<span class="red">Orgasm imminent.</span>
<</if>>
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 4>><span class="pink">You think <<he>> is approaching orgasm.</span>
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 3>><span class="purple"><<He>> looks lustful. </span>
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>><span class="blue"><<He>> looks horny.</span>
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 1>><span class="lblue"><<He>> looks aroused.</span>
<<elseif $enemyarousal gt 0>><span class="teal"><<He>> looks stimulated.</span>
<<elseif $enemyarousal lte 0>><span class="green"><<He>> is positively flaccid.</span>
<</if>>
<<if $enemyanger gte $enemyangermax>><span class="red"><<He>> is furious.</span>
<<elseif $enemyanger gte ($enemyangermax / 5) * 4>><span class="pink"><<He>> looks incredibly pissed off.</span>
<<elseif $enemyanger gte ($enemyangermax / 5) * 3>><span class="purple"><<He>> looks angry.</span>
<<elseif $enemyanger gte ($enemyangermax / 5) * 2>><span class="blue"><<He>> looks frustrated.</span>
<<elseif $enemyanger gte ($enemyangermax / 5) * 1>><span class="lblue"><<He>> looks irritated.</span>
<<elseif $enemyanger gt 0>><span class="teal"><<He>> looks disappointed.</span>
<<elseif $enemyanger lte 0>><span class="green"><<He>> looks calm.</span>
<</if>>
<<if $enemytrust lte -100>><span class="red"><<He>> looks full of suspicion.</span>
<<elseif $enemytrust lte -60>><span class="pink"><<He>> looks guarded.</span>
<<elseif $enemytrust lte -20>><span class="purple"><<He>> looks wary.</span>
<<elseif $enemytrust lte 20>><span class="blue"><<He>> looks cautious.</span>
<<elseif $enemytrust lte 60>><span class="lblue"><<He>> looks alert</span>
<<elseif $enemytrust lte 100>><span class="teal"><<He>> looks relaxed.</span>
<<elseif $enemytrust gt 100>><span class="green"><<He>> looks confident.</span>
<</if>>
<<else>>
<<set $pronoun to "t">>
<<if $enemyhealth gte $enemyhealthmax>><span class="red"><<He>> look eager.</span>
<<elseif $enemyhealth gte ($enemyhealthmax / 5) * 4>><span class="pink"><<He>> look uncomfortable.</span>
<<elseif $enemyhealth gte ($enemyhealthmax / 5) * 3>><span class="purple"><<He>> look stung.</span>
<<elseif $enemyhealth gte ($enemyhealthmax / 5) * 2>><span class="blue"><<He>> look pained.</span>
<<elseif $enemyhealth gte ($enemyhealthmax / 5) * 1>><span class="lblue"><<He>> look hurt.</span>
<<elseif $enemyhealth gt 0>><span class="teal"><<He>> don't look like <<he>> can take much more pain.</span>
<<elseif $enemyhealth lte 0>><span class="green"><<He>> are recoiling in pain.</span>
<</if>>
<<if $enemyarousal gte $enemyarousalmax>>
<<if $penis isnot "none">><span class="red">Ejaculation imminent.</span>
<<else>>
<span class="red">Orgasm imminent.</span>
<</if>>
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 4>><span class="pink">You think <<he>> are approaching orgasm.</span>
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 3>><span class="purple"><<He>> look lustful. </span>
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>><span class="blue"><<He>> look horny.</span>
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 1>><span class="lblue"><<He>> look aroused.</span>
<<elseif $enemyarousal gt 0>><span class="teal"><<He>> look stimulated.</span>
<<elseif $enemyarousal lte 0>><span class="green"><<He>> are positively flaccid.</span>
<</if>>
<<if $enemyanger gte $enemyangermax>><span class="red"><<He>> are furious.</span>
<<elseif $enemyanger gte ($enemyangermax / 5) * 4>><span class="pink"><<He>> look incredibly pissed off.</span>
<<elseif $enemyanger gte ($enemyangermax / 5) * 3>><span class="purple"><<He>> look angry.</span>
<<elseif $enemyanger gte ($enemyangermax / 5) * 2>><span class="blue"><<He>> look frustrated.</span>
<<elseif $enemyanger gte ($enemyangermax / 5) * 1>><span class="lblue"><<He>> look irritated.</span>
<<elseif $enemyanger gt 0>><span class="teal"><<He>> look disappointed.</span>
<<elseif $enemyanger lte 0>><span class="green"><<He>> look calm.</span>
<</if>>
<<if $enemytrust lte -100>><span class="red"><<He>> look full of suspicion.</span>
<<elseif $enemytrust lte -60>><span class="pink"><<He>> look guarded.</span>
<<elseif $enemytrust lte -20>><span class="purple"><<He>> look wary.</span>
<<elseif $enemytrust lte 20>><span class="blue"><<He>> look cautious.</span>
<<elseif $enemytrust lte 60>><span class="lblue"><<He>> look alert</span>
<<elseif $enemytrust lte 100>><span class="teal"><<He>> look relaxed.</span>
<<elseif $enemytrust gt 100>><span class="green"><<He>> look confident.</span>
<</if>>
<<if $panicattacks gte 1 and $panicviolence is 0 and $panicparalysis is 0 and $controlled is 0>>
<<set $rng to random(1, 100)>>
<<if $rng is 100>>
<<set $panicparalysis to 10>>
<</if>>
<</if>>
<<if $panicattacks gte 2 and $panicviolence is 0 and $panicparalysis is 0 and $controlled is 0>>
<<set $rng to random(1, 100)>>
<<if $rng is 100>>
<<set $panicviolence to 3>>
<</if>>
<</if>>
<</if>>
<br><br>
<<if $arousal gte 10000>>
<<orgasmpassage>>
<</if>>
<<set $seconds += 10>>
<<if $seconds gte 60>>
<<set $seconds to 0>>
<<pass 1>>
<</if>>
<</nobr>><</widget>>
:: Widgets NPCs [widget]
<<widget "man1init">><<nobr>>
<<set $enemyarousal to $allure / 50 + $audiencearousal>>
<<set $enemyanger to 0>>
<<set $enemystrength to 20000>>
<<set $combat to 1>>
<<set $enemytrust to 0>>
<<set $enemyhealth to 200 * $enemyno>>
<<set $enemyarousalmax to 500 * $enemyno>>
<<set $enemyangermax to 200>>
<<set $enemyhealthmax to 200 * $enemyno>>
<<if $dissociation gte 1>>
<<set $enemytrust -= 40>>
<</if>>
<<set $enemytype to "man">>
<<set $rapeavoid to 1>>
<<set $orgasmdown to 0>>
<<set $penisbitten to 0>>
<<set $apologised to 0>>
<<set $understruggle to 0>>
<<set $lowerstruggle to 0>>
<<set $upperstruggle to 0>>
<<set $leftaction to 0>>
<<set $rightaction to 0>>
<<set $traumasaved to $trauma>>
<<set $stresssaved to $stress>>
<<set $traumagain to 0>>
<<set $stressgain to 0>>
<<combatinit>>
<</nobr>><</widget>>
<<widget "man2init">><<nobr>>
<<set $enemyhealth to 400>>
<<set $enemyarousal to $allure / 50>>
<<set $enemyanger to 0>>
<<set $enemystrength to 20000>>
<<set $combat to 1>>
<<set $enemyarousalmax to 1000>>
<<set $enemyangermax to 200>>
<<set $enemyhealthmax to 400>>
<<set $enemytrust to 0>>
<<if $dissociation gte 1>>
<<set $enemytrust -= 40>>
<</if>>
<<set $enemytype to "man">>
<<set $rapeavoid to 1>>
<<set $orgasmdown to 0>>
<<set $penisbitten to 0>>
<<set $apologised to 0>>
<<set $understruggle to 0>>
<<set $lowerstruggle to 0>>
<<set $upperstruggle to 0>>
<<set $leftaction to 0>>
<<set $rightaction to 0>>
<<set $traumasaved to $trauma>>
<<set $stresssaved to $stress>>
<<set $traumagain to 0>>
<<set $stressgain to 0>>
<<combatinit>>
<</nobr>><</widget>>
<<widget "beast1init">><<nobr>>
<<set $enemyhealth to 200>>
<<set $enemyarousal to $allure / 50>>
<<set $enemyanger to 0>>
<<set $enemystrength to 20000>>
<<set $lefthand to "none">>
<<set $righthand to "none">>
<<set $penis to 0>>
<<set $vagina to "none">>
<<set $mouth to 0>>
<<set $combat to 1>>
<<set $enemyarousalmax to 500>>
<<set $enemyangermax to 200>>
<<set $enemyhealthmax to 200>>
<<set $enemytrust to 0>>
<<if $dissociation gte 1>>
<<set $enemytrust -= 40>>
<</if>>
<<set $enemytype to "beast">>
<<set $rapeavoid to 1>>
<<set $orgasmdown to 0>>
<<set $penisbitten to 0>>
<<set $apologised to 0>>
<<set $understruggle to 0>>
<<set $lowerstruggle to 0>>
<<set $upperstruggle to 0>>
<<set $leftaction to 0>>
<<set $rightaction to 0>>
<<set $traumasaved to $trauma>>
<<set $stresssaved to $stress>>
<<set $traumagain to 0>>
<<set $stressgain to 0>>
<<set $beastno to 1>>
<<set $beastnomax to 1>>
<<set $beaststance to "approach">>
<<combatinit>>
<</nobr>><</widget>>
<<widget "beast2init">><<nobr>>
<<set $enemyhealth to 200>>
<<set $enemyarousal to $allure / 50>>
<<set $enemyanger to 0>>
<<set $enemystrength to 20000>>
<<set $lefthand to "none">>
<<set $righthand to "none">>
<<set $penis to 0>>
<<set $vagina to "none">>
<<set $mouth to 0>>
<<set $combat to 1>>
<<set $enemyarousalmax to 500>>
<<set $enemyangermax to 200>>
<<set $enemyhealthmax to 200>>
<<set $enemytrust to 0>>
<<if $dissociation gte 1>>
<<set $enemytrust -= 40>>
<</if>>
<<set $enemytype to "beast">>
<<set $rapeavoid to 1>>
<<set $orgasmdown to 0>>
<<set $penisbitten to 0>>
<<set $apologised to 0>>
<<set $understruggle to 0>>
<<set $lowerstruggle to 0>>
<<set $upperstruggle to 0>>
<<set $leftaction to 0>>
<<set $rightaction to 0>>
<<set $traumasaved to $trauma>>
<<set $stresssaved to $stress>>
<<set $traumagain to 0>>
<<set $stressgain to 0>>
<<set $beastno to 2>>
<<set $beastnomax to 2>>
<<set $beaststance to "approach">>
<<set $enemyarousal2 to $enemyarousal>>
<<set $enemyanger2 to $enemyanger>>
<<set $enemyhealth2 to $enemyhealthmax>>
<<set $enemytrust2 to $enemytrust>>
<<combatinit>>
<</nobr>><</widget>>
<<widget "beast3init">><<nobr>>
<<set $enemyhealth to 200>>
<<set $enemyarousal to $allure / 50>>
<<set $enemyanger to 0>>
<<set $enemystrength to 20000>>
<<set $lefthand to "none">>
<<set $righthand to "none">>
<<set $penis to 0>>
<<set $vagina to "none">>
<<set $mouth to 0>>
<<set $combat to 1>>
<<set $enemyarousalmax to 500>>
<<set $enemyangermax to 200>>
<<set $enemyhealthmax to 200>>
<<set $enemytrust to 0>>
<<if $dissociation gte 1>>
<<set $enemytrust -= 40>>
<</if>>
<<set $enemytype to "beast">>
<<set $rapeavoid to 1>>
<<set $orgasmdown to 0>>
<<set $penisbitten to 0>>
<<set $apologised to 0>>
<<set $understruggle to 0>>
<<set $lowerstruggle to 0>>
<<set $upperstruggle to 0>>
<<set $leftaction to 0>>
<<set $rightaction to 0>>
<<set $traumasaved to $trauma>>
<<set $stresssaved to $stress>>
<<set $traumagain to 0>>
<<set $stressgain to 0>>
<<set $beastno to 3>>
<<set $beastnomax to 3>>
<<set $beaststance to "approach">>
<<set $enemyarousal2 to $enemyarousal>>
<<set $enemyanger2 to $enemyanger>>
<<set $enemyhealth2 to $enemyhealthmax>>
<<set $enemytrust2 to $enemytrust>>
<<set $enemyarousal3 to $enemyarousal>>
<<set $enemyanger3 to $enemyanger>>
<<set $enemyhealth3 to $enemyhealthmax>>
<<set $enemytrust3 to $enemytrust>>
<<combatinit>>
<</nobr>><</widget>>
<<widget "beast4init">><<nobr>>
<<set $enemyhealth to 200>>
<<set $enemyarousal to $allure / 50>>
<<set $enemyanger to 0>>
<<set $enemystrength to 20000>>
<<set $lefthand to "none">>
<<set $righthand to "none">>
<<set $penis to 0>>
<<set $vagina to "none">>
<<set $mouth to 0>>
<<set $combat to 1>>
<<set $enemyarousalmax to 500>>
<<set $enemyangermax to 200>>
<<set $enemyhealthmax to 200>>
<<set $enemytrust to 0>>
<<if $dissociation gte 1>>
<<set $enemytrust -= 40>>
<</if>>
<<set $enemytype to "beast">>
<<set $rapeavoid to 1>>
<<set $orgasmdown to 0>>
<<set $penisbitten to 0>>
<<set $apologised to 0>>
<<set $understruggle to 0>>
<<set $lowerstruggle to 0>>
<<set $upperstruggle to 0>>
<<set $leftaction to 0>>
<<set $rightaction to 0>>
<<set $traumasaved to $trauma>>
<<set $stresssaved to $stress>>
<<set $traumagain to 0>>
<<set $stressgain to 0>>
<<set $beastno to 4>>
<<set $beastnomax to 4>>
<<set $beaststance to "approach">>
<<set $enemyarousal2 to $enemyarousal>>
<<set $enemyanger2 to $enemyanger>>
<<set $enemyhealth2 to $enemyhealthmax>>
<<set $enemytrust2 to $enemytrust>>
<<set $enemyarousal3 to $enemyarousal>>
<<set $enemyanger3 to $enemyanger>>
<<set $enemyhealth3 to $enemyhealthmax>>
<<set $enemytrust3 to $enemytrust>>
<<set $enemyarousal4 to $enemyarousal>>
<<set $enemyanger4 to $enemyanger>>
<<set $enemyhealth4 to $enemyhealthmax>>
<<set $enemytrust4 to $enemytrust>>
<<combatinit>>
<</nobr>><</widget>>
<<widget "beast5init">><<nobr>>
<<set $enemyhealth to 200>>
<<set $enemyarousal to $allure / 50>>
<<set $enemyanger to 0>>
<<set $enemystrength to 20000>>
<<set $lefthand to "none">>
<<set $righthand to "none">>
<<set $penis to 0>>
<<set $vagina to "none">>
<<set $mouth to 0>>
<<set $combat to 1>>
<<set $enemyarousalmax to 500>>
<<set $enemyangermax to 200>>
<<set $enemyhealthmax to 200>>
<<set $enemytrust to 0>>
<<if $dissociation gte 1>>
<<set $enemytrust -= 40>>
<</if>>
<<set $enemytype to "beast">>
<<set $rapeavoid to 1>>
<<set $orgasmdown to 0>>
<<set $penisbitten to 0>>
<<set $apologised to 0>>
<<set $understruggle to 0>>
<<set $lowerstruggle to 0>>
<<set $upperstruggle to 0>>
<<set $leftaction to 0>>
<<set $rightaction to 0>>
<<set $traumasaved to $trauma>>
<<set $stresssaved to $stress>>
<<set $traumagain to 0>>
<<set $stressgain to 0>>
<<set $beastno to 5>>
<<set $beastnomax to 5>>
<<set $beaststance to "approach">>
<<set $enemyarousal2 to $enemyarousal>>
<<set $enemyanger2 to $enemyanger>>
<<set $enemyhealth2 to $enemyhealthmax>>
<<set $enemytrust2 to $enemytrust>>
<<set $enemyarousal3 to $enemyarousal>>
<<set $enemyanger3 to $enemyanger>>
<<set $enemyhealth3 to $enemyhealthmax>>
<<set $enemytrust3 to $enemytrust>>
<<set $enemyarousal4 to $enemyarousal>>
<<set $enemyanger4 to $enemyanger>>
<<set $enemyhealth4 to $enemyhealthmax>>
<<set $enemytrust4 to $enemytrust>>
<<set $enemyarousal5 to $enemyarousal>>
<<set $enemyanger5 to $enemyanger>>
<<set $enemyhealth5 to $enemyhealthmax>>
<<set $enemytrust5 to $enemytrust>>
<<combatinit>>
<</nobr>><</widget>>
<<widget "beast6init">><<nobr>>
<<set $enemyhealth to 200>>
<<set $enemyarousal to $allure / 50>>
<<set $enemyanger to 0>>
<<set $enemystrength to 20000>>
<<set $lefthand to "none">>
<<set $righthand to "none">>
<<set $penis to 0>>
<<set $vagina to "none">>
<<set $mouth to 0>>
<<set $combat to 1>>
<<set $enemyarousalmax to 500>>
<<set $enemyangermax to 200>>
<<set $enemyhealthmax to 200>>
<<set $enemytrust to 0>>
<<if $dissociation gte 1>>
<<set $enemytrust -= 40>>
<</if>>
<<set $enemytype to "beast">>
<<set $rapeavoid to 1>>
<<set $orgasmdown to 0>>
<<set $penisbitten to 0>>
<<set $apologised to 0>>
<<set $understruggle to 0>>
<<set $lowerstruggle to 0>>
<<set $upperstruggle to 0>>
<<set $leftaction to 0>>
<<set $rightaction to 0>>
<<set $traumasaved to $trauma>>
<<set $stresssaved to $stress>>
<<set $traumagain to 0>>
<<set $stressgain to 0>>
<<set $beastno to 6>>
<<set $beastnomax to 6>>
<<set $beaststance to "approach">>
<<set $enemyarousal2 to $enemyarousal>>
<<set $enemyanger2 to $enemyanger>>
<<set $enemyhealth2 to $enemyhealthmax>>
<<set $enemytrust2 to $enemytrust>>
<<set $enemyarousal3 to $enemyarousal>>
<<set $enemyanger3 to $enemyanger>>
<<set $enemyhealth3 to $enemyhealthmax>>
<<set $enemytrust3 to $enemytrust>>
<<set $enemyarousal4 to $enemyarousal>>
<<set $enemyanger4 to $enemyanger>>
<<set $enemyhealth4 to $enemyhealthmax>>
<<set $enemytrust4 to $enemytrust>>
<<set $enemyarousal5 to $enemyarousal>>
<<set $enemyanger5 to $enemyanger>>
<<set $enemyhealth5 to $enemyhealthmax>>
<<set $enemytrust5 to $enemytrust>>
<<set $enemyarousal6 to $enemyarousal>>
<<set $enemyanger6 to $enemyanger>>
<<set $enemyhealth6 to $enemyhealthmax>>
<<set $enemytrust6 to $enemytrust>>
<<combatinit>>
<</nobr>><</widget>>
<<widget "strangeman1init">><<nobr>>
<<set $enemyhealth to 200>>
<<set $enemyarousal to $allure / 50>>
<<set $enemyanger to 0>>
<<set $enemystrength to 20000>>
<<set $lefthand to "mouth">>
<<set $combat to 1>>
<<set $enemyarousalmax to 500>>
<<set $enemyangermax to 200>>
<<set $enemyhealthmax to 200>>
<<set $enemytrust to 0>>
<<if $dissociation gte 1>>
<<set $enemytrust -= 40>>
<</if>>
<<set $enemytype to "man">>
<<set $rapeavoid to 1>>
<<set $orgasmdown to 0>>
<<set $penisbitten to 0>>
<<set $apologised to 0>>
<<set $understruggle to 0>>
<<set $lowerstruggle to 0>>
<<set $upperstruggle to 0>>
<<set $leftaction to 0>>
<<set $rightaction to 0>>
<<set $traumasaved to $trauma>>
<<set $stresssaved to $stress>>
<<set $traumagain to 0>>
<<set $stressgain to 0>>
<<combatinit>>
<</nobr>><</widget>>
<<widget "strangeman2init">><<nobr>>
<<set $enemyhealth to 200>>
<<set $enemyarousal to $allure / 50>>
<<set $enemyanger to 0>>
<<set $enemystrength to 20000>>
<<set $combat to 1>>
<<set $enemyarousalmax to 500>>
<<set $enemyangermax to 200>>
<<set $enemyhealthmax to 200>>
<<set $enemytrust to 0>>
<<if $dissociation gte 1>>
<<set $enemytrust -= 40>>
<</if>>
<<set $enemytype to "man">>
<<set $rapeavoid to 1>>
<<set $orgasmdown to 0>>
<<set $penisbitten to 0>>
<<set $apologised to 0>>
<<set $understruggle to 0>>
<<set $lowerstruggle to 0>>
<<set $upperstruggle to 0>>
<<set $leftaction to 0>>
<<set $rightaction to 0>>
<<set $traumasaved to $trauma>>
<<set $stresssaved to $stress>>
<<set $traumagain to 0>>
<<set $stressgain to 0>>
<<combatinit>>
<</nobr>><</widget>>
<<widget "strangewoman1init">><<nobr>>
<<set $enemyhealth to 200>>
<<set $enemyarousal to $allure / 50>>
<<set $enemyanger to 0>>
<<set $enemystrength to 20000>>
<<set $combat to 1>>
<<set $enemyarousalmax to 500>>
<<set $enemyangermax to 200>>
<<set $enemyhealthmax to 200>>
<<set $enemytrust to 0>>
<<if $dissociation gte 1>>
<<set $enemytrust -= 40>>
<</if>>
<<set $enemytype to "man">>
<<set $rapeavoid to 1>>
<<set $orgasmdown to 0>>
<<set $penisbitten to 0>>
<<set $apologised to 0>>
<<set $understruggle to 0>>
<<set $lowerstruggle to 0>>
<<set $upperstruggle to 0>>
<<set $leftaction to 0>>
<<set $rightaction to 0>>
<<set $traumasaved to $trauma>>
<<set $stresssaved to $stress>>
<<set $traumagain to 0>>
<<set $stressgain to 0>>
<<combatinit>>
<</nobr>><</widget>>
<<widget "tailorinit">><<nobr>>
<<set $enemyhealth to 200>>
<<set $enemyarousal to $allure / 50>>
<<set $enemyanger to 0>>
<<set $enemystrength to 20000>>
<<set $combat to 1>>
<<set $enemyarousalmax to 500>>
<<set $enemyangermax to 200>>
<<set $enemyhealthmax to 200>>
<<set $enemytrust to 0>>
<<if $dissociation gte 1>>
<<set $enemytrust -= 40>>
<</if>>
<<set $enemytype to "man">>
<<set $rapeavoid to 1>>
<<set $orgasmdown to 0>>
<<set $penisbitten to 0>>
<<set $apologised to 0>>
<<set $understruggle to 0>>
<<set $lowerstruggle to 0>>
<<set $upperstruggle to 0>>
<<set $leftaction to 0>>
<<set $rightaction to 0>>
<<set $traumasaved to $trauma>>
<<set $stresssaved to $stress>>
<<set $traumagain to 0>>
<<set $stressgain to 0>>
<<set $leftarm to "bound">>
<<set $rightarm to "bound">>
<<combatinit>>
<</nobr>><</widget>>
<<widget "molestbusinit">><<nobr>>
<<set $enemyhealth to 200>>
<<set $enemyarousal to $allure / 50>>
<<set $enemyanger to 0>>
<<set $enemystrength to 20000>>
<<set $combat to 1>>
<<set $enemyarousalmax to 500>>
<<set $enemyangermax to 200>>
<<set $enemyhealthmax to 200>>
<<set $enemytrust to 0>>
<<if $dissociation gte 1>>
<<set $enemytrust -= 40>>
<</if>>
<<set $enemytype to "man">>
<<set $rapeavoid to 1>>
<<set $orgasmdown to 0>>
<<set $penisbitten to 0>>
<<set $apologised to 0>>
<<set $understruggle to 0>>
<<set $lowerstruggle to 0>>
<<set $upperstruggle to 0>>
<<set $leftaction to 0>>
<<set $rightaction to 0>>
<<set $traumasaved to $trauma>>
<<set $stresssaved to $stress>>
<<set $traumagain to 0>>
<<set $stressgain to 0>>
<<if $daystate isnot "night">><<set $rescue to 1>><</if>>
<<set $mouthuse to "lefthand">>
<<combatinit>>
<</nobr>><</widget>>
<<widget "busmoveinit">><<nobr>>
<<set $enemyhealth to 200>>
<<set $enemyarousal to $allure / 50>>
<<set $enemyanger to 0>>
<<set $enemystrength to 20000>>
<<set $combat to 1>>
<<set $enemyarousalmax to 200>>
<<set $enemyangermax to 200>>
<<set $enemyhealthmax to 200>>
<<set $enemytrust to 0>>
<<if $dissociation gte 1>>
<<set $enemytrust -= 40>>
<</if>>
<<set $enemytype to "man">>
<<set $rapeavoid to 1>>
<<set $orgasmdown to 0>>
<<set $penisbitten to 0>>
<<set $apologised to 0>>
<<set $understruggle to 0>>
<<set $lowerstruggle to 0>>
<<set $upperstruggle to 0>>
<<set $leftaction to 0>>
<<set $rightaction to 0>>
<<set $traumasaved to $trauma>>
<<set $stresssaved to $stress>>
<<set $traumagain to 0>>
<<set $stressgain to 0>>
<<if $daystate isnot "night">><<set $rescue to 1>><</if>>
<<combatinit>>
<</nobr>><</widget>>
<<widget "lefthandinit">><<nobr>>
<<set $enemyhealth to 200>>
<<set $enemyarousal to $allure / 50>>
<<set $enemyanger to 0>>
<<set $enemystrength to 20000>>
<<set $lefthand to 0>>
<<set $righthand to "none">>
<<set $penis to "none">>
<<set $vagina to "none">>
<<set $combat to 1>>
<<set $enemyarousalmax to 100>>
<<set $enemyangermax to 200>>
<<set $enemyhealthmax to 200>>
<<set $enemytrust to 0>>
<<if $dissociation gte 1>>
<<set $enemytrust -= 40>>
<</if>>
<<set $enemytype to "man">>
<<set $rapeavoid to 1>>
<<set $orgasmdown to 0>>
<<set $penisbitten to 0>>
<<set $apologised to 0>>
<<set $understruggle to 0>>
<<set $lowerstruggle to 0>>
<<set $upperstruggle to 0>>
<<set $leftaction to 0>>
<<set $rightaction to 0>>
<<set $traumasaved to $trauma>>
<<set $stresssaved to $stress>>
<<set $traumagain to 0>>
<<set $stressgain to 0>>
<<if $daystate isnot "night">><<set $rescue to 1>><</if>>
<<combatinit>>
<</nobr>><</widget>>
<<widget "nurseinit">><<nobr>>
<<set $enemyhealth to 200>>
<<set $enemyarousal to $allure / 50>>
<<set $enemyanger to 0>>
<<set $enemystrength to 20000>>
<<set $combat to 1>>
<<set $enemyarousalmax to 400>>
<<set $enemyangermax to 200>>
<<set $enemyhealthmax to 200>>
<<set $enemytrust to 0>>
<<if $dissociation gte 1>>
<<set $enemytrust -= 40>>
<</if>>
<<set $enemytype to "man">>
<<set $rapeavoid to 1>>
<<set $orgasmdown to 0>>
<<set $penisbitten to 0>>
<<set $apologised to 0>>
<<set $understruggle to 0>>
<<set $lowerstruggle to 0>>
<<set $upperstruggle to 0>>
<<set $leftaction to 0>>
<<set $rightaction to 0>>
<<set $traumasaved to $trauma>>
<<set $stresssaved to $stress>>
<<set $traumagain to 0>>
<<set $stressgain to 0>>
<<set $drugged += 120>>
<<combatinit>>
<</nobr>><</widget>>
<<widget "spankmaninit">><<nobr>>
<<set $enemyhealth to 200>>
<<set $enemyarousal to 0>>
<<set $enemyanger to 300>>
<<set $enemystrength to 20000>>
<<set $lefthand to "arms">>
<<set $righthand to "spank">>
<<set $combat to 1>>
<<set $enemyarousalmax to 500>>
<<set $enemyangermax to 300>>
<<set $enemyhealthmax to 200>>
<<set $enemytrust to 0>>
<<if $dissociation gte 1>>
<<set $enemytrust -= 40>>
<</if>>
<<set $enemytype to "man">>
<<set $rapeavoid to 1>>
<<set $orgasmdown to 0>>
<<set $penisbitten to 0>>
<<set $apologised to 0>>
<<set $understruggle to 0>>
<<set $lowerstruggle to 0>>
<<set $upperstruggle to 0>>
<<set $leftaction to 0>>
<<set $rightaction to 0>>
<<set $traumasaved to $trauma>>
<<set $stresssaved to $stress>>
<<set $traumagain to 0>>
<<set $stressgain to 0>>
<<set $enemyno to 1>>
<<set $leftarm to "grappled">>
<<set $rightarm to "grappled">>
<<combatinit>>
<</nobr>><</widget>>
<<widget "dog1init">><<nobr>>
<<set $enemyhealth to 200>>
<<set $enemyarousal to $allure / 50>>
<<set $enemyanger to 0>>
<<set $enemystrength to 20000>>
<<set $lefthand to "none">>
<<set $righthand to "none">>
<<set $penis to 0>>
<<set $vagina to "none">>
<<set $mouth to 0>>
<<set $combat to 1>>
<<set $enemyarousalmax to 500>>
<<set $enemyangermax to 200>>
<<set $enemyhealthmax to 200>>
<<set $enemytrust to 0>>
<<if $dissociation gte 1>>
<<set $enemytrust -= 40>>
<</if>>
<<set $enemytype to "beast">>
<<set $rapeavoid to 1>>
<<set $orgasmdown to 0>>
<<set $penisbitten to 0>>
<<set $apologised to 0>>
<<set $understruggle to 0>>
<<set $lowerstruggle to 0>>
<<set $upperstruggle to 0>>
<<set $leftaction to 0>>
<<set $rightaction to 0>>
<<set $traumasaved to $trauma>>
<<set $stresssaved to $stress>>
<<set $traumagain to 0>>
<<set $stressgain to 0>>
<<set $beastno to 1>>
<<set $beastnomax to 1>>
<<set $beaststance to "approach">>
<<set $pronoun1 to "i">>
<<combatinit>>
<</nobr>><</widget>>
<<widget "dog2init">><<nobr>>
<<set $enemyhealth to 200>>
<<set $enemyarousal to $allure / 50>>
<<set $enemyanger to 0>>
<<set $enemystrength to 20000>>
<<set $lefthand to "none">>
<<set $righthand to "none">>
<<set $penis to "leftarm">>
<<set $vagina to "none">>
<<set $mouth to 0>>
<<set $combat to 1>>
<<set $enemyarousalmax to 500>>
<<set $enemyangermax to 200>>
<<set $enemyhealthmax to 200>>
<<set $enemytrust to 0>>
<<if $dissociation gte 1>>
<<set $enemytrust -= 40>>
<</if>>
<<set $enemytype to "beast">>
<<set $rapeavoid to 1>>
<<set $orgasmdown to 0>>
<<set $penisbitten to 0>>
<<set $apologised to 0>>
<<set $understruggle to 0>>
<<set $lowerstruggle to 0>>
<<set $upperstruggle to 0>>
<<set $leftaction to 0>>
<<set $rightaction to 0>>
<<set $traumasaved to $trauma>>
<<set $stresssaved to $stress>>
<<set $traumagain to 0>>
<<set $stressgain to 0>>
<<set $beastno to 2>>
<<set $beastnomax to 2>>
<<set $beaststance to "approach">>
<<set $pronoun1 to "i">>
<<combatinit>>
<</nobr>><</widget>>
<<widget "bound2init">><<nobr>>
<<set $enemyhealth to 400>>
<<set $enemyarousal to $allure / 50>>
<<set $enemyanger to 0>>
<<set $enemystrength to 20000>>
<<set $combat to 1>>
<<set $enemyarousalmax to 1000>>
<<set $enemyangermax to 200>>
<<set $enemyhealthmax to 400>>
<<set $enemytrust to 0>>
<<if $dissociation gte 1>>
<<set $enemytrust -= 40>>
<</if>>
<<set $enemytype to "man">>
<<set $rapeavoid to 1>>
<<set $orgasmdown to 0>>
<<set $penisbitten to 0>>
<<set $apologised to 0>>
<<set $understruggle to 0>>
<<set $lowerstruggle to 0>>
<<set $upperstruggle to 0>>
<<set $leftaction to 0>>
<<set $rightaction to 0>>
<<set $traumasaved to $trauma>>
<<set $stresssaved to $stress>>
<<set $traumagain to 0>>
<<set $stressgain to 0>>
<<combatinit>>
<</nobr>><</widget>>
<<widget "ganginit">><<nobr>>
<<set $enemyhealth to 1200>>
<<set $enemyarousal to $allure / 50>>
<<set $enemyanger to 0>>
<<set $enemystrength to 20000>>
<<set $combat to 1>>
<<set $enemyarousalmax to 3000>>
<<set $enemyangermax to 200>>
<<set $enemyhealthmax to 1200>>
<<set $enemytrust to 0>>
<<if $dissociation gte 1>>
<<set $enemytrust -= 40>>
<</if>>
<<set $enemytype to "man">>
<<set $rapeavoid to 1>>
<<set $orgasmdown to 0>>
<<set $penisbitten to 0>>
<<set $apologised to 0>>
<<set $understruggle to 0>>
<<set $lowerstruggle to 0>>
<<set $upperstruggle to 0>>
<<set $leftaction to 0>>
<<set $rightaction to 0>>
<<set $traumasaved to $trauma>>
<<set $stresssaved to $stress>>
<<set $traumagain to 0>>
<<set $stressgain to 0>>
<<combatinit>>
<</nobr>><</widget>>
<<widget "abomination">><<nobr>>
<<set $enemyhealth to 5555>>
<<set $enemyarousal to $allure / 50>>
<<set $enemyanger to 0>>
<<set $enemystrength to 20000>>
<<set $lefthand to 0>>
<<set $lefthand2 to 0>>
<<set $lefthand3 to 0>>
<<set $lefthand4 to 0>>
<<set $lefthand5 to 0>>
<<set $lefthand6 to 0>>
<<set $righthand to 0>>
<<set $righthand2 to 0>>
<<set $righthand3 to 0>>
<<set $righthand4 to 0>>
<<set $righthand5 to 0>>
<<set $righthand6 to 0>>
<<set $penis to 0>>
<<set $penis2 to 0>>
<<set $penis3 to 0>>
<<set $penis4 to 0>>
<<set $penis5 to "clothed">>
<<set $penis6 to "clothed">>
<<set $vagina to 0>>
<<set $vagina2 to 0>>
<<set $vagina3 to 0>>
<<set $vagina4 to 0>>
<<set $vagina5 to 0>>
<<set $vagina6 to 0>>
<<set $mouth to 0>>
<<set $mouth2 to 0>>
<<set $mouth3 to 0>>
<<set $mouth4 to 0>>
<<set $mouth5 to 0>>
<<set $mouth6 to 0>>
<<set $combat to 1>>
<<set $enemyarousalmax to 500>>
<<set $enemyangermax to 200>>
<<set $enemyhealthmax to 5555>>
<<set $enemytrust to 4444>>
<<if $dissociation gte 1>>
<<set $enemytrust -= 40>>
<</if>>
<<set $rapeavoid to 1>>
<<set $orgasmdown to 0>>
<<set $penisbitten to 0>>
<<set $apologised to 0>>
<<set $understruggle to 0>>
<<set $lowerstruggle to 0>>
<<set $upperstruggle to 0>>
<<set $leftaction to 0>>
<<set $rightaction to 0>>
<<set $traumasaved to $trauma>>
<<set $stresssaved to $stress>>
<<set $traumagain to 0>>
<<set $stressgain to 0>>
<<set $enemyno to 1>>
<<set $pronoun1 to "n">>
<<combatinit>>
<</nobr>><</widget>>
<<widget "abomination2">><<nobr>>
<<set $enemyhealth to 5555>>
<<set $enemyarousal to $allure / 50>>
<<set $enemyanger to 0>>
<<set $enemystrength to 20000>>
<<set $lefthand to 0>>
<<set $lefthand2 to 0>>
<<set $righthand to 0>>
<<set $righthand2 to 0>>
<<set $penis to 0>>
<<set $penis2 to 0>>
<<set $vagina to 0>>
<<set $vagina2 to 0>>
<<set $mouth to 0>>
<<set $mouth2 to 0>>
<<set $combat to 1>>
<<set $enemyarousalmax to 500>>
<<set $enemyangermax to 200>>
<<set $enemyhealthmax to 5555>>
<<set $enemytrust to 4444>>
<<if $dissociation gte 1>>
<<set $enemytrust -= 40>>
<</if>>
<<set $rapeavoid to 1>>
<<set $orgasmdown to 0>>
<<set $penisbitten to 0>>
<<set $apologised to 0>>
<<set $understruggle to 0>>
<<set $lowerstruggle to 0>>
<<set $upperstruggle to 0>>
<<set $leftaction to 0>>
<<set $rightaction to 0>>
<<set $traumasaved to $trauma>>
<<set $stresssaved to $stress>>
<<set $traumagain to 0>>
<<set $stressgain to 0>>
<<set $enemyno to 1>>
<<set $pronoun1 to "n">>
<<combatinit>>
<</nobr>><</widget>>
<<widget "dogpackinit">><<nobr>>
<<set $enemyhealth to 200>>
<<set $enemyarousal to $allure / 50>>
<<set $enemyanger to 0>>
<<set $enemystrength to 20000>>
<<set $lefthand to "none">>
<<set $righthand to "none">>
<<set $penis to 0>>
<<set $vagina to "none">>
<<set $mouth to 0>>
<<set $combat to 1>>
<<set $enemyarousalmax to 500>>
<<set $enemyangermax to 200>>
<<set $enemyhealthmax to 200>>
<<set $enemytrust to 0>>
<<if $dissociation gte 1>>
<<set $enemytrust -= 40>>
<</if>>
<<set $enemytype to "beast">>
<<set $rapeavoid to 1>>
<<set $orgasmdown to 0>>
<<set $penisbitten to 0>>
<<set $apologised to 0>>
<<set $understruggle to 0>>
<<set $lowerstruggle to 0>>
<<set $upperstruggle to 0>>
<<set $leftaction to 0>>
<<set $rightaction to 0>>
<<set $traumasaved to $trauma>>
<<set $stresssaved to $stress>>
<<set $traumagain to 0>>
<<set $stressgain to 0>>
<<set $beastno to 6>>
<<set $beastnomax to 6>>
<<set $beaststance to "approach">>
<<set $enemyarousal2 to $enemyarousal>>
<<set $enemyanger2 to $enemyanger>>
<<set $enemyhealth2 to $enemyhealthmax>>
<<set $enemytrust2 to $enemytrust>>
<<set $enemyarousal3 to $enemyarousal>>
<<set $enemyanger3 to $enemyanger>>
<<set $enemyhealth3 to $enemyhealthmax>>
<<set $enemytrust3 to $enemytrust>>
<<set $enemyarousal4 to $enemyarousal>>
<<set $enemyanger4 to $enemyanger>>
<<set $enemyhealth4 to $enemyhealthmax>>
<<set $enemytrust4 to $enemytrust>>
<<set $enemyarousal5 to $enemyarousal>>
<<set $enemyanger5 to $enemyanger>>
<<set $enemyhealth5 to $enemyhealthmax>>
<<set $enemytrust5 to $enemytrust>>
<<set $enemyarousal6 to $enemyarousal>>
<<set $enemyanger6 to $enemyanger>>
<<set $enemyhealth6 to $enemyhealthmax>>
<<set $enemytrust6 to $enemytrust>>
<<set $pronoun1 to "i">>
<<combatinit>>
<</nobr>><</widget>>
<<widget "combatinit">><<nobr>>
<<if $genderknown.includes($npc)>>
<<set $crossdressing to 0>>
<<else>>
<<if $playergender isnot $playergenderappearance>>
<<set $crossdressing to 1>>
<<else>>
<<set $crossdressing to 0>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "man">><<nobr>>
<<if $finish isnot 1>>
<<if $enemyno gte 1>>
<br><<man1>><br><br>
<</if>>
<<if $enemyno gte 2>>
<<man2>><br><br>
<</if>>
<<if $enemyno gte 3>>
<<man3>><br><br>
<</if>>
<<if $enemyno gte 4>>
<<man4>><br><br>
<</if>>
<<if $enemyno gte 5>>
<<man5>><br><br>
<</if>>
<<if $enemyno gte 6>>
<<man6>><br><br>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $undervaginaexposed gte 1 and $lowervaginaexposed gte 1 and $npc isnot 0>>
<<set $genderknown.pushUnique($npc)>>
<</if>>
<<if $crossdressing is 1 and $undervaginaexposed gte 1 and $lowervaginaexposed gte 1>>
<<set $crossdressing to 0>>
<<if $enemyno gte 2>>
<<if $rng gte 96>>
<span class="red">They recoil in horror upon seeing your <<genitalsstop>> The deception has driven them mad with rage!</span><<set $enemyanger += 200>><<set $enemytrust -= 100>><<set $speechcrossdressangry to 2>>
<<elseif $rng gte 85>>
Your <<genitals>> was clearly not what they were expecting, but they don't seem to mind. <span class="purple">In fact, if their shaking hands are anything to go by they're quite pleased.</span><<set $enemyarousal += (50 * $enemyno)>><<set $speechcrossdressaroused to 2>>
<<elseif $rng gte 50>>
Their eyes widen in shock when they see your <<genitalsstop>> They seem unsure what to do.<<set $enemyanger -= 50>><<set $enemytrust -= 50>><<set $speechcrossdressshock to 2>>
<<elseif $rng gte 30>>
They look disappointed by your <<genitalsstop>> It wasn't what they were expecting.<<set $enemyarousal -= 100>><<set $enemytrust -= 50>><<set $speechcrossdressdisappointed to 2>>
<<else>>
Your <<genitals>> was clearly not what they were expecting, but they don't seem to mind.
<</if>><br><br>
<<else>>
<<if $rng gte 96>>
<span class="red"><<He>> recoils in horror upon seeing your <<genitalsstop>> The deception has driven <<him>> mad with rage!</span><<set $enemyanger += 200>><<set $enemytrust -= 100>><<set $speechcrossdressangry to 2>>
<<elseif $rng gte 86>>
Your <<genitals>> was clearly not what <<he>> was expecting, but <<he>> doesn't seem to mind. <span class="purple">In fact, if <<his>> shaking hands are anything to go by <<he>> is quite pleased.</span><<set $enemyarousal += 50>><<set $speechcrossdressaroused to 2>>
<<elseif $rng gte 50>>
<<His>> eyes widen in shock when <<he>> sees your <<genitalsstop>> <<He>> seems unsure what to do.<<set $enemyanger -= 50>><<set $enemytrust -= 50>><<set $speechcrossdressshock to 2>>
<<elseif $rng gte 30>>
<<He>> looks disappointed by your <<genitalsstop>> It wasn't what <<he>> was expecting.<<set $enemyarousal -= 100>><<set $enemytrust -= 50>><<set $speechcrossdressdisappointed to 2>>
<<else>>
Your <<genitals>> was clearly not what <<he>> was expecting, but <<he>> doesn't seem to mind.
<</if>><br><br>
<</if>>
<</if>>
<<turnend>>
<</nobr>><</widget>>
:: Widgets End Combat [widget]
<<widget "endcombat">><<nobr>>
<<if $assertive gte 1>>
You were
<<if $assertive lte 5>>
<span class="pink">slightly</span>
<<elseif $assertive lte 10>>
<span class="pink">a little</span>
<<elseif $assertive lte 30>>
<span class="purple">somewhat</span>
<<elseif $assertive lte 40>>
<span class="blue">quite</span>
<<elseif $assertive lte 50>>
<span class="lblue">pretty</span>
<<elseif $assertive lte 60>>
<span class="teal">very</span>
<<else>>
<span class="green">extremely</span>
<</if>>
assertive. How do you feel about it?<br>
<span class="meek">It's nice to make people feel good</span> (increase submissiveness)
<<if $assertivedefault is "submissive">>
<<radiobutton "$assertiveaction" "submissive" checked>><br>
<<else>>
<<radiobutton "$assertiveaction" "submissive">><br>
<</if>>
<span class="brat">It's nice to be in control</span> (increase defiance)
<<if $assertivedefault is "defiant">>
<<radiobutton "$assertiveaction" "defiant" checked>><br>
<<else>>
<<radiobutton "$assertiveaction" "defiant">><br>
<</if>>
<span class="green">I'm so naughty</span> (decrease trauma)
<<if $assertivedefault is "trauma">>
<<radiobutton "$assertiveaction" "trauma" checked>><br>
<<else>>
<<radiobutton "$assertiveaction" "trauma">><br>
<</if>>
<span class="green">That was fun</span> (decrease stress)
<<if $assertivedefault is "stress">>
<<radiobutton "$assertiveaction" "stress" checked>><br>
<<else>>
<<radiobutton "$assertiveaction" "stress">><br>
<</if>>
<</if>>
<<endevent>>
<<set $combat to 0>>
<<set $rapeavoid to 1>>
<<set $sexavoid to 1>>
<<set $orgasmdown to 0>>
<<set $penisbitten to 0>>
<<set $apologised to 0>>
<<if $playergender is "f">>
<<set $vaginastate to 0>>
<<set $penisstate to "none">>
<</if>>
<<if $playergender is "m">>
<<set $vaginastate to "none">>
<<set $penisstate to 0>>
<</if>>
<<set $anusstate to 0>>
<<set $mouthstate to 0>>
<<set $finish to 0>>
<<set $mouthuse to 0>>
<<set $anususe to 0>>
<<if $playergender is "f">>
<<set $vaginause to 0>>
<<elseif $playergender is "m">>
<<set $vaginause to "none">>
<<set $penisuse to 0>>
<</if>>
<<set $thighuse to 0>>
<<set $bottomuse to 0>>
<<if $feetuse isnot "bound">>
<<set $feetuse to 0>>
<</if>>
<<if $leftarm isnot "bound">>
<<set $leftarm to 0>>
<</if>>
<<if $rightarm isnot "bound">>
<<set $rightarm to 0>>
<</if>>
<<set $chestuse to 0>>
<<if $head isnot "bound">>
<<set $head to 0>>
<</if>>
<<if $position is "wall">>
<<set $leftarm to 0>>
<<set $rightarm to 0>>
<<set $head to 0>>
<</if>>
<<set $position to 0>>
<<set $understruggle to 0>>
<<set $lowerstruggle to 0>>
<<set $upperstruggle to 0>>
<<set $enemytrust to 0>>
<<set $alarm to 0>>
<<set $event to 0>>
<<set $rescue to 0>>
<<set $phase to 0>>
<<set $phase2 to 0>>
<<set $noise to 0>>
<<set $timer to 0>>
<<set $beastno to 0>>
<<set $beastnomax to 1>>
<<set $beastname to "none">>
<<set $panicparalysis to 0>>
<<set $panicviolence to 0>>
<<set $pullaway to 0>>
<<set $novaginal to 0>>
<<set $noanal to 0>>
<<set $nopenile to 0>>
<<set $speechorgasmweakcumcount to 0>>
<<set $speechorgasmnocumcount to 0>>
<<set $speechorgasmcount to 0>>
<<set $speechorgasmrepeat to 0>>
<<set $underwatertime to 0>>
<<set $underwater to 0>>
<<set $walltype to "wall">>
<<set $angelforgive to 0>>
<<set $penisfucked to 0>>
<<set $vaginafucked to 0>>
<<set $speechdisable to 0>>
<<set $crossdressing to 0>>
<<set $leftactiondefault to $leftaction>>
<<set $rightactiondefault to $rightaction>>
<<set $feetactiondefault to $feetaction>>
<<set $mouthactiondefault to $mouthaction>>
<<set $vaginaactiondefault to $vaginaaction>>
<<set $penisactiondefault to $penisaction>>
<<set $anusactiondefault to $anusaction>>
<<set $thighactiondefault to $thighaction>>
<<set $cheekactiondefault to $cheekaction>>
<<set $chestactiondefault to $chestaction>>
<<actioncarry>>
<<set $penisaction to 0>>
<<set $vaginaaction to 0>>
<<set $anusaction to 0>>
<<set $leftaction to 0>>
<<set $rightaction to 0>>
<<set $mouthaction to 0>>
<<set $thighaction to 0>>
<<set $cheekaction to 0>>
<<set $feetaction to 0>>
<<set $chestaction to 0>>
<<set $mockaction to "none">>
<<set $carryblock to "none">>
<<set $beaststance to 0>>
<<set $enemywounded to 0>>
<<set $enemyejaculated to 0>>
<<set $semenpuddle to 0>>
<<set $strangle to 0>>
<<set $seconds to 0>>
<<set $masturbationorgasm to 0>>
<<set $intro1 to 0>>
<<set $intro2 to 0>>
<<set $intro3 to 0>>
<<set $intro4 to 0>>
<<set $intro5 to 0>>
<<set $intro6 to 0>>
<<set $swarm1 to 0>>
<<set $swarm2 to 0>>
<<set $swarm3 to 0>>
<<set $swarm4 to 0>>
<<set $swarm5 to 0>>
<<set $swarm6 to 0>>
<<set $swarm7 to 0>>
<<set $swarm8 to 0>>
<<set $swarm9 to 0>>
<<set $swarm10 to 0>>
<<set $swarmpending to 0>>
<<set $swarmname to 0>>
<<set $swarmmove to 0>>
<<set $swarmactive to 0>>
<<set $swarmcreature to 0>>
<<set $swarmchestmolest to 0>>
<<set $swarmchestgrab to 0>>
<<set $swarmchestgrabintro to 0>>
<<set $swarmchestgrabclothed to 0>>
<<set $swarmchestclothed to 0>>
<<set $swarmchestcover to 0>>
<<set $swarmactivate to 0>>
<<set $swarmspill to 0>>
<<set $swarmback to 0>>
<<set $swarmbackmolest to 0>>
<<set $swarmbackgrab to 0>>
<<set $swarmbackgrabintro to 0>>
<<set $swarmbackgrabunderclothed to 0>>
<<set $swarmbackunderclothed to 0>>
<<set $swarmbackgrablowerclothed to 0>>
<<set $swarmbacklowerclothed to 0>>
<<set $swarmbackcover to 0>>
<<set $swarmbackinside to 0>>
<<set $swarmbackinsideintro to 0>>
<<set $swarmbackgrablowerchastity to 0>>
<<set $swarmfront to 0>>
<<set $swarmfrontmolest to 0>>
<<set $swarmfrontgrab to 0>>
<<set $swarmfrontgrabintro to 0>>
<<set $swarmfrontgrabunderclothed to 0>>
<<set $swarmfrontunderclothed to 0>>
<<set $swarmfrontgrablowerclothed to 0>>
<<set $swarmfrontlowerclothed to 0>>
<<set $swarmfrontcover to 0>>
<<set $swarmfrontinside to 0>>
<<set $swarmfrontinsideintro to 0>>
<<set $swarmfrontgrablowerchastity to 0>>
<<set $swarmsteady to 0>>
<<set $swarmcount to 0>>
<<set $leftaction to 0>>
<<set $rightaction to 0>>
<<set $back to 0>>
<<set $front to 0>>
<<set $chest to 0>>
<<set $beasttype to "beast">>
<<set $claws to 1>>
<<set $water to 0>>
<<set $vorestrength to 0>>
<<set $vorestruggle to 0>>
<<set $voretentacles to 0>>
<<set $vorestage to 0>>
<<set $vorecreature to 0>>
<<set $swallowed to 0>>
<<set $tentacleno to 0>>
<<set $activetentacleno to 0>>
<<set $tentaclehealth to 0>>
<<set $tentacle1 to 0>>
<<set $tentacle1head to 0>>
<<set $tentacle1shaft to 0>>
<<set $tentacle1health to 0>>
<<set $tentacle2 to 0>>
<<set $tentacle2head to 0>>
<<set $tentacle2shaft to 0>>
<<set $tentacle2health to 0>>
<<set $tentacle3 to 0>>
<<set $tentacle3head to 0>>
<<set $tentacle3shaft to 0>>
<<set $tentacle3health to 0>>
<<set $tentacle4 to 0>>
<<set $tentacle4head to 0>>
<<set $tentacle4shaft to 0>>
<<set $tentacle4health to 0>>
<<set $tentacle5 to 0>>
<<set $tentacle5head to 0>>
<<set $tentacle5shaft to 0>>
<<set $tentacle5health to 0>>
<<set $tentacle6 to 0>>
<<set $tentacle6head to 0>>
<<set $tentacle6shaft to 0>>
<<set $tentacle6health to 0>>
<<set $tentacle7 to 0>>
<<set $tentacle7head to 0>>
<<set $tentacle7shaft to 0>>
<<set $tentacle7health to 0>>
<<set $tentacle8 to 0>>
<<set $tentacle8head to 0>>
<<set $tentacle8shaft to 0>>
<<set $tentacle8health to 0>>
<<set $tentacle9 to 0>>
<<set $tentacle9head to 0>>
<<set $tentacle9shaft to 0>>
<<set $tentacle9health to 0>>
<<set $tentacle10 to 0>>
<<set $tentacle10head to 0>>
<<set $tentacle10shaft to 0>>
<<set $tentacle10health to 0>>
<<set $tentacle11 to 0>>
<<set $tentacle11head to 0>>
<<set $tentacle11shaft to 0>>
<<set $tentacle11health to 0>>
<<set $tentacle12 to 0>>
<<set $tentacle12head to 0>>
<<set $tentacle12shaft to 0>>
<<set $tentacle12health to 0>>
<<set $tentacle13 to 0>>
<<set $tentacle13head to 0>>
<<set $tentacle13shaft to 0>>
<<set $tentacle13health to 0>>
<<set $tentacle14 to 0>>
<<set $tentacle14head to 0>>
<<set $tentacle14shaft to 0>>
<<set $tentacle14health to 0>>
<<set $tentacle15 to 0>>
<<set $tentacle15head to 0>>
<<set $tentacle15shaft to 0>>
<<set $tentacle15health to 0>>
<<set $tentacle16 to 0>>
<<set $tentacle16head to 0>>
<<set $tentacle16shaft to 0>>
<<set $tentacle16health to 0>>
<<set $leftleg to 0>>
<<set $rightleg to 0>>
<<set $breastuse to 0>>
<<set $leftnipple to 0>>
<<set $rightnipple to 0>>
<<set $leftarmstate to 0>>
<<set $rightarmstate to 0>>
<<set $feetstate to 0>>
<<set $audienceselector to 0>>
<<set $audiencecamera to 0>>
<<set $audiencecamera1 to 0>>
<<set $audiencecamera2 to 0>>
<<set $audiencecamera3 to 0>>
<<set $audiencecamera4 to 0>>
<<set $audiencecamera5 to 0>>
<<set $audiencecamera6 to 0>>
<<set $audiencemember to 0>>
<<set $speechcrossdressangry to 0>>
<<set $speechcrossdressaroused to 0>>
<<set $speechcrossdressshock to 0>>
<<set $speechcrossdressdisappointed to 0>>
<<if $seductionskillup gte 1>>
<<set $seductionskillup to 0>>
<span class="gold">You feel more confident in your seduction skills.</span><br>
<</if>>
<<if $oralskillup gte 1>>
<<set $oralskillup to 0>>
<span class="gold">You feel more confident in your ability to give pleasure with your mouth.</span><br>
<</if>>
<<if $vaginalskillup gte 1>>
<<set $vaginalskillup to 0>>
<span class="gold">You feel more confident in your ability to give pleasure with your vagina.</span><br>
<</if>>
<<if $analskillup gte 1>>
<<set $analskillup to 0>>
<span class="gold">You feel more confident in your ability to give pleasure with your anus.</span><br>
<</if>>
<<if $handskillup gte 1>>
<<set $handskillup to 0>>
<span class="gold">You feel more confident in your ability to give pleasure with your hands.</span><br>
<</if>>
<<if $feetskillup gte 1>>
<<set $feetskillup to 0>>
<span class="gold">You feel more confident in your ability to give pleasure with your feet.</span><br>
<</if>>
<<if $bottomskillup gte 1>>
<<set $bottomskillup to 0>>
<span class="gold">You feel more confident in your ability to give pleasure with your buttocks.</span><br>
<</if>>
<<if $thighskillup gte 1>>
<<set $thighskillup to 0>>
<span class="gold">You feel more confident in your ability to give pleasure with your thighs.</span><br>
<</if>>
<<if $chestskillup gte 1>>
<<set $chestskillup to 0>>
<span class="gold">You feel more confident in your ability to use your <<breasts>> to pleasure others.</span><br>
<</if>>
<<if $penileskillup gte 1>>
<<set $penileskillup to 0>>
<span class="gold">You feel more confident in your ability to pleasure others with your penis.</span><br>
<</if>>
<<manend>>
<<turnend>>
<br>
<</nobr>><</widget>>
:: Widgets Combat Beast [widget]
<<widget "beast">><<nobr>>
<<set $pronoun to "i">>
<<if $beaststance is "top">>
The $beasttype has you pinned in a mating posture.
<<if $semenpuddle gte 4>>
<<if $water is 0>>
The semen on the ground makes your knees slip with every thrust.
<<else>>
<</if>>
<</if>>
<</if>>
<<if $beaststance is "approach">>
<<if $enemyanger gte 120>>
The $beasttype bares its teeth at you.
<<elseif $enemyanger gte 80>>
The $beasttype bares its teeth at you.
<<elseif $enemyanger gte 40>>
<<if $water is 1>>
The $beasttype swims around you in a circle.
<<else>>
The $beasttype paces back and forth.
<</if>>
<<else>>
The $beasttype bears down on you.
<</if>>
<</if>>
<<if $mouth is "hair">>
<<if $enemyanger + $rng lte 50>>
<span class="blue"><<He>> releases your hair.</span><<set $mouth to 0>>
<<else>>
<<He>> pulls on your hair, jerking your head back.<<violence 1>>
<</if>>
<</if>>
<<beastclothing>>
<<if $mouth is "neck">>
<<if $enemyanger + $rng lte 100>>
<span class="teal"><<He>> releases your neck from <<his>> jaws.</span><<set $mouth to 0>><<set $neckuse to 0>>
<<elseif $enemyanger + $rng lte 200>>
<<He>> continues to hold you down by the neck.<<violence 3>><<bruise neck>><<hitstat>>
<<else>>
<<He>> tightens <<his>> jaw. You can't breathe!<<violence 10>><<bruise neck>><<bruise neck>><<hitstat>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis is "thighs">>
<<if $vaginaexist is 1>>
<<if $rng gte 101>><span class="blue"><<He>> angles <<his>> penis towards your <<pussystop>></span><<set $thighuse to 0>><<set $penis to "vaginaentrance">><<set $vaginause to "penis">><<set $vaginastate to "entrance">><<set $thighactiondefault to "thighs">>
<<else>>
<<He>> rubs <<his>> penis between your thighs and <<pussystop>><<sex 5>>
<</if>>
<<else>>
<<if $rng gte 101>><<He>> moves <<his>> penis out from between your thighs.<<set $thighuse to 0>><<set $penis to 0>><<set $thighactiondefault to "thighs">>
<<else>>
<<He>> rubs <<his>> penis between your thighs.<<sex 5>>
<</if>>
<</if>>
<</if>>
<<if $penis is "vagina">>
<<if $enemyanger gte 100>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
<<He>> fucks your <<pussy>> with a violent intensity.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues fucking your <<pussystop>> Each thrust feels deeper than the last.
<<else>>
Wanting to prove dominance <<he>> pounds your <<pussy>> with deep and deliberate thrusts.
<</if>>
<<elseif $enemyanger gte 20>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
You feel <<his>> penis throb as <<he>> pounds away at your <<pussystop>>
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> violates your <<pussy>> with increasing eagerness.
<<else>>
<<He>> fucks your <<pussy>> with deep and deliberate thrusts.
<</if>>
<<else>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
<<He>> fucks your <<pussycomma>> eager to fill you with seed.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> pounds your <<pussy>> and shows no sign of relenting.
<<else>>
<<He>> continues thrusting into your <<pussystop>>
<</if>>
<</if>>
<<sex 30>><<bruise vagina>><<violence 2>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis is "vaginaimminent">><<set $vaginaactiondefault to "take">>
<<if $vaginalvirginity is 0>><span class="pink"><<He>> thrusts <<his>> penis deep into your <<pussystop>></span><<sex 30>><<set $penis to "vagina">><<vaginalstat>><<bruise vagina>><<violence 2>><<raped>><<vaginaraped>><<set $vaginastate to "penetrated">>
<<elseif $vaginalvirginity is 1>><span class="pink"><<He>> thrusts <<his>> penis deep into your virgin pussy,</span><span class="red"> breaking your hymen and forever robbing you of your purity.</span><<sex 100>><<set $penis to "vagina">><<set $vaginalvirginity to 0>><<bruise vagina>><<vaginalstat>><<violence 100>><<raped>><<vaginaraped>><<set $vaginastate to "penetrated">>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis is "vaginaentrance">>
<<if $lowervaginaexposed is 0>><<He>> rubs <<his>> penis against your <<pussy>> through your $lowerclothes.<<sex 5>><<set $lowerintegrity -= 10>>
<<elseif $lowervaginaexposed is 1>><<set $rng to random(1, 100)>>
<<if $undervaginaexposed is 0 and $undertype is "chastity">>
<<He>> thrusts against your $underclothes, desperate to breed the <<pussy>> beneath. It hurts itself against the hard material and withdraws, growling.<<set $penis to 0>><<set $vaginause to 0>><<set $vaginastate to 0>><<sex 20>><<set $underintegrity -= 10>><<set $enemyanger += 15>><<set $enemytrust -= 15>><<set $enemyhealth -= 5>>
<<elseif $undervaginaexposed is 0>><<He>> rubs <<his>> penis against your <<pussy>> through your $underclothes.<<sex 5>><<set $underintegrity -= 10>>
<<elseif $undervaginaexposed is 1>>
<<if $rng gte 71>><span class="pink"><<He>> pushes <<his>> penis against your <<pussycomma>> preparing to penetrate you fully.</span><<sex 20>><<set $penis to "vaginaimminent">><<set $vaginastate to "imminent">>
<<elseif $rng gte 1>><<He>> rubs <<his>> penis against your <<pussystop>><<sex 5>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis is "cheeks">>
<<if $rng gte 101>><span class="blue"><<He>> angles <<his>> penis toward your anus.</span><<set $penis to "anusentrance">><<set $anusstate to "entrance">><<set $bottomuse to 0>><<set $cheekactiondefault to "cheeks">>
<<else>>
<<He>> rubs <<his>> penis between your cheeks.<<submission 3>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis is "leftarm">>
<<if $rng lte 101>>
<<He>> rubs <<his>> penis against your hand.<<submission 1>>
<<else>>
<span class="purple"><<He>> moves <<his>> penis away from your hand.</span><<set $penis to 0>><<set $leftarm to 0>><<set $leftcarry to "leftgrab">><<set $leftactiondefault to "leftgrab">>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis is "rightarm">>
<<if $rng lte 101>>
<<He>> rubs <<his>> penis against your hand.<<submission 1>>
<<else>>
<span class="purple"><<He>> moves <<his>> penis away from your hand.</span><<set $penis to 0>><<set $rightarm to 0>><<set $rightcarry to "rightgrab">><<set $rightactiondefault to "rightgrab">>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis is "botharm">>
<<if $rng lte 101>>
<<He>> rubs <<his>> penis against your hands.<<submission 2>>
<<else>>
<span class="purple"><<He>> moves <<his>> penis away from your hands.</span><<set $penis to 0>><<set $leftarm to 0>><<set $rightarm to 0>><<set $leftcarry to "leftgrab">><<set $rightcarry to "rightgrab">><<set $leftactiondefault to "leftgrab">><<set $rightactiondefault to "rightgrab">>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis is "feet">>
<<if $rng lte 101>>
<<He>> rubs <<his>> penis against your feet.<<submission 1>>
<<else>>
<span class="purple"><<He>> moves <<his>> penis away from your feet.</span><<set $penis to 0>><<set $feetuse to 0>><<set $feetactiondefault to "feetgrab">>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis is "anus">>
<<if $enemyanger gte 100>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
<<He>> fucks your <<bottom>> with a violent intensity.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues fucking your <<bottomstop>> Each thrust feels deeper than the last.
<<else>>
Wanting to prove dominance <<he>> pounds your <<bottom>> with deep and deliberate thrusts.
<</if>>
<<elseif $enemyanger gte 20>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
You feel <<his>> penis throb as <<he>> pounds away at your <<bottomstop>>
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> violates your <<bottom>> with increasing eagerness.
<<else>>
<<He>> fucks your <<bottom>> with deep and deliberate thrusts.
<</if>>
<<else>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
<<He>> fucks your <<bottomcomma>> eager to fill you with seed.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> pounds your <<bottom>> and shows no sign of relenting.
<<else>>
<<He>> continues thrusting into your <<bottomstop>>
<</if>>
<</if>>
<<sex 30>><<bruise anus>><<violence 1>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis is "anusimminent">><<set $anusactiondefault to "take">>
<<if $analvirginity is 0>><span class="pink"><<He>> thrusts <<his>> penis deep into your <<bottomstop>></span><<sex 30>><<set $penis to "anus">><<bruise anus>><<analstat>><<violence 1>><<raped>><<set $anusstate to "penetrated">>
<<elseif $analvirginity is 1>><span class="pink"><<He>> thrusts <<his>> penis deep into your <<bottomcomma>></span><span class="red"> violating you in a way you hadn't conceived of.</span><<sex 100>><<set $penis to "anus">><<set $analvirginity to 0>><<bruise anus>><<analstat>><<violence 50>><<raped>><<set $anusstate to "penetrated">>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis is "anusentrance">>
<<if $loweranusexposed is 0>><<He>> rubs <<his>> penis against your <<bottom>> through your $lowerclothes.<<sex 5>><<set $lowerintegrity -= 10>>
<<elseif $loweranusexposed is 1>><<set $rng to random(1, 100)>>
<<if $underanusexposed is 0 and $undertype is "chastity" and $analshield is 1>>
<<He>> thrusts against your $underclothes, desperate to violate the <<bottom>> beneath. It hurts itself against the hard material and withdraws, growling.<<set $penis to 0>><<set $anususe to 0>><<set $anusstate to 0>><<sex 20>><<set $underintegrity -= 10>><<set $enemyanger += 15>><<set $enemytrust -= 15>><<set $enemyhealth -= 5>>
<<elseif $underanusexposed is 0>><<He>> rubs <<his>> penis against your <<bottom>> through your $underclothes.<<sex 5>><<set $underintegrity -= 10>>
<<elseif $underanusexposed is 1>>
<<if $rng gte 71>><span class="pink"><<He>> pushes <<his>> penis against the entrance of your anus, preparing to penetrate you fully.</span><<sex 20>><<set $penis to "anusimminent">><<set $anusstate to "imminent">>
<<elseif $rng gte 1>><<He>> rubs <<his>> penis against your <<bottomstop>><<sex 5>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis is "mouth">>
<<if $rng gte 81>><span class="purple"><<He>> withdraws <<his>> penis from your mouth.</span><<sex 30>><<set $penis to "mouthimminent">><<bruise face>><<violence 1>><<set $mouthstate to "imminent">>
<<elseif $rng gte 1>><<He>> continues thrusting into your wet mouth.<<submission 10>><<bruise face>><<violence 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis is "mouthimminent">>
<<if $rng gte 81>><span class="blue"><<He>> stops pressing <<his>> penis into your mouth.</span><<set $penis to "mouthentrance">><<submission 5>><<set $mouthstate to "entrance">>
<<elseif $rng lte 20>>
<<if $oralvirginity is 0>><span class="pink"><<He>> thrusts <<his>> penis into your mouth.</span><<submission 10>><<set $penis to "mouth">><<bruise face>><<oralstat>><<raped>><<set $mouthstate to "penetrated">>
<<elseif $oralvirginity is 1>><span class="pink"><<He>> thrusts <<his>> penis into your mouth.</span><span class="red"> It tastes strange.</span><<submission 30>><<set $penis to "mouth">><<set $oralvirginity to 0>><<bruise face>><<oralstat>><<violence 1>><<raped>><<set $mouthstate to "penetrated">>
<</if>>
<<elseif $rng gte 21>>
<<if $mouthsubmit is 1>><<He>> allows you to pleasure <<his>> cock with your mouth.<<submission 5>>
<<elseif $oralvirginity is 0>><span class="pink"><<He>> thrusts <<his>> penis into your mouth.</span><<submission 10>><<set $penis to "mouth">><<oralstat>><<bruise face>><<violence 1>><<raped>><<set $mouthstate to "penetrated">>
<<elseif $oralvirginity is 1>><span class="pink"><<He>> thrusts <<his>> penis into your mouth.</span><span class="red"> It tastes strange.</span><<submission 30>><<set $penis to "mouth">><<set $oralvirginity to 0>><<oralstat>><<bruise face>><<violence 1>><<raped>><<set $mouthstate to "penetrated">>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis is "mouthentrance">>
<<if $rng gte 81>><span class="lblue"><<He>> moves <<his>> penis away from your mouth.</span><<set $penis to 0>><<set $mouthuse to 0>><<set $mouthstate to 0>>
<<elseif $rng gte 1>><span class="purple"><<He>> pushes <<his>> penis against your lips.</span><<set $penis to "mouthimminent">><<submission 5>><<set $mouthstate to "imminent">>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $beaststance is "approach">>
<<if $mouth is 0>>
<<if $enemyanger + $rng lte 20>>
Curious, <<he>> sniffs your groin.<<neutral 5>><<set $enemyarousal += 10>>
<<elseif $enemyanger + $rng lte 40>>
<<beastlick>>
<<elseif $enemyanger + $rng lte 160>>
<<if $lowerclothes isnot "naked">>
<<if $skirt is 1>>
<<if $skirtdown is 1>>
<span class="blue"><<He>> lifts up your $lowerclothes with <<his>> teeth.</span><<set $skirtdown to 0>><<set $lowervaginaexposed to 1>><<set $loweranusexposed to 1>><<set $lowerexposed to 2>><<set $lowerintegrity -= 10>>
<<elseif $underclothes isnot "naked" and $undertype isnot "chastity">>
<span class="purple"><<He>> grabs your $underclothes with <<his>> teeth.</span><<set $mouth to "underclothes">><<violence 1>>
<<else>>
<<beastlick>>
<</if>>
<<else>>
<span class="purple"><<He>> grabs your $lowerclothes with <<his>> teeth.</span><<set $mouth to "lowerclothes">><<violence 1>>
<</if>>
<<elseif $underclothes isnot "naked" and $undertype isnot "chastity">>
<span class="purple"><<He>> grabs your $underclothes with <<his>> teeth.</span><<set $mouth to "underclothes">><<violence 1>>
<<else>>
<<beastlick>>
<</if>>
<<elseif $enemyanger + $rng lte 200>>
<<He>> growls menacingly.<<violence 1>>
<<else>>
<<if $claws is 1>>
<<He>> bites and claws at your thighs.
<<else>>
<<He>> bites your thighs.
<</if>>
<<violence 20>><<bruise thigh>><<bruise thigh>><<set $lowerintegrity -= 20>><<set $underintegrity -= 20>><<hitstat>><<set $enemyanger -= 20>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis is 0>>
<<if $enemyarousal gte (($enemyarousalmax / 10) * 3)>>
<<if $water is 0>>
<span class="blue"><<He>> jumps on top of you and pins you down.</span><<set $beaststance to "top">><<violence 5>><<set $head to "grappled">><<set $mouth to 0>>
<<else>>
<span class="blue"><<He>> swims right up to you, pressing <<his>> body against yours.</span><<set $beaststance to "top">><<violence 5>><<set $head to "grappled">><<set $mouth to 0>>
<</if>>
<<else>>
<</if>>
<</if>>
<<elseif $beaststance is "top">>
<<if $mouth is 0>>
<<if ($enemyanger + $rng) lte 20 and $position isnot "wall">>
<<He>> licks your face.<<neutral 2>>
<<elseif ($enemyanger + $rng) lte 40 and $position isnot "wall">>
<<He>> licks your neck.<<neutral 2>>
<<elseif $enemyanger + $rng lte 60>>
<<if $upperclothes isnot "naked">>
<<He>> tears at your $upperclothes.<<neutral 3>><<set $upperintegrity -= 10>>
<<else>>
<<He>> <<if $claws is 1>>presses <<his>> claws into your back.<<else>>bites your back.<</if>>
<</if>>
<<elseif ($enemyanger + $rng) lte 100 and $position isnot "wall">>
<<He>> grabs your hair between <<his>> teeth.<<set $mouth to "hair">><<neutral 3>>
<<elseif $enemyanger + $rng lte 120>>
<<He>> growls menacingly.<<violence 1>>
<<elseif ($enemyanger + $rng) lte 140 and $position isnot "wall">>
<<He>> bites your face.<<violence 5>><<bruise face>><<hitstat>>
<<elseif ($enemyanger + $rng) lte 160 and $position isnot "wall">>
<<He>> bites your neck.<<violence 5>><<bruise neck>><<hitstat>>
<<elseif $position isnot "wall">>
<<He>> grabs your neck between its teeth.<<violence 5>><<bruise neck>><<set $mouth to "neck">><<hitstat>>
<<else>>
<<He>> bites your waist.<<violence 5>><<bruise tummy>><<hitstat>>
<</if>>
<</if>>
<<if $penis is 0>><<set $rng to random(1, 100)>>
<<if $rng lte 25>>
<<He>> humps your rear frantically, rubbing <<his>> penis against your back.<<neutral 5>>
<<elseif $rng lte 50>>
<<He>> humps your rear frantically, rubbing <<his>> penis between your thighs.<<sex 3>>
<<elseif $rng lte 75>>
<<if $anususe is 0 and $analdisable is "f">>
<span class="blue"><<His>> penis gains purchase between your <<bottom>> cheeks.</span><<sex 5>><<bruise anus>><<violence 1>><<set $penis to "anusentrance">><<set $anususe to "penis">><<set $anusstate to "entrance">>
<<else>>
<<His>> penis rubs against your <<bottomstop>><<neutral 5>>
<</if>>
<<elseif $rng lte 100>>
<<if $vaginaexist is 1 and $vaginause is 0>>
<span class="blue"><<He>> humps your rear frantically, gaining purchase in front of your <<pussystop>></span><<sex 5>><<bruise vagina>><<violence 1>><<set $penis to "vaginaentrance">><<set $vaginause to "penis">><<set $vaginastate to "entrance">>
<<elseif $penisexist is 1 and $penisuse is 0>>
<<He>> humps your rear frantically, rubbing against your <<penisstop>><<sex 5>><<bruise penis>><<violence 1>> <<else>>
<<He>> humps your rear frantically, rubbing <<his>> penis between your thighs.<<sex 3>>
<</if>>
<</if>>
<</if>>
<</if>>
<br>
<<if $beastno is 2>>
Another beast awaits its turn.
<<elseif $beastno is 3>>
Two other beasts await their turn.
<<elseif $beastno is 4>>
Three other beasts await their turn.
<<elseif $beastno is 5>>
Four other beasts await their turn.
<<elseif $beastno is 6>>
Five other beasts await their turn.
<</if>>
<</nobr>><</widget>>
<<widget "beastlick">><<nobr>>
<<if $vaginaexist is 1>>
<<if $vaginause is "cover">>
<<He>> licks your hand, trying to taste the <<pussy>> beneath.
<<if $arousal gte 8000>>
It laps up the juices that leak through your fingers.
<<elseif $arousal gte 2000>>
Its tongue probes around and between your fingers, searching for a weak spot.
<<else>>
It tries to force <<his>> tongue between your fingers.
<</if>>
<<elseif $undervaginaexposed is 0>><<neutral 10>>
<<He>> licks your $underclothes, trying to taste the <<pussy>> beneath.
<<if $orgasmdown gte 1>>
<<He>> laps up your leaking juices as you squirm.
<<elseif $arousal gte 8000>>
You're shamed by how good it feels.
<<elseif $arousal gte 2000>>
The incessant probing makes your groin heat up.
<<else>>
You try to shift your crotch away, but <<he>> persists.
<</if>>
<<elseif $lowervaginaexposed is 0>>
<<He>> licks your $lowerclothes, trying to taste the <<pussy>> beneath.
<<if $orgasmdown gte 1>>
<<He>> laps up your leaking juices as you squirm.
<<elseif $arousal gte 8000>>
You're shamed by how good it feels.
<<elseif $arousal gte 2000>>
The incessant probing makes your groin heat up.
<<else>>
You try to shift your crotch away, but <<he>> persists.
<</if>>
<<else>><<neutral 15>>
<<He>> licks your bare pussy.
<<if $orgasmdown gte 1>>
The feeling of <<his>> tongue as you cum is maddening, but <<he>> doesn't relent.
<<elseif $arousal gte 8000>>
The feeling of <<his>> tongue on your sensitive flesh makes your pelvis jerk and spasm.
<<elseif $arousal gte 2000>>
<<His>> hot breath and tongue ellicit shameful feelings.
<<else>>
You try to shift your crotch to escape this violation, but <<he>> persists.
<</if>>
<</if>>
<<elseif $penisexist is 1>>
<<if $penisuse is "cover">>
<<He>> licks your hand, trying to taste the <<penis>> beneath.
<<if $arousal gte 8000>>
It laps up the juices that leak through your fingers.
<<elseif $arousal gte 2000>>
Its tongue probes around and between your fingers, searching for a weak spot.
<<else>>
It tries to force <<his>> tongue between your fingers.
<</if>>
<<elseif $undervaginaexposed is 0>><<neutral 10>>
<<He>> licks your $underclothes, trying to taste the <<penis>> beneath.
<<if $orgasmdown gte 1>>
<<He>> laps up your leaking juices as you squirm.
<<elseif $arousal gte 8000>>
You're shamed by how good it feels.
<<elseif $arousal gte 2000>>
The incessant probing makes your groin heat up.
<<else>>
You try to shift your crotch away, but <<he>> persists.
<</if>>
<<elseif $lowervaginaexposed is 0>>
<<He>> licks your $lowerclothes, trying to taste the <<penis>> beneath.
<<if $orgasmdown gte 1>>
<<He>> laps up your leaking juices as you squirm.
<<elseif $arousal gte 8000>>
You're shamed by how good it feels.
<<elseif $arousal gte 2000>>
The incessant probing makes your groin heat up.
<<else>>
You try to shift your crotch away, but <<he>> persists.
<</if>>
<<else>><<neutral 15>>
<<He>> licks your bare penis.
<<if $orgasmdown gte 1>>
The feeling of <<his>> tongue as you cum is maddening, but <<he>> doesn't relent.
<<elseif $arousal gte 8000>>
The feeling of <<his>> tongue on your sensitive flesh makes your pelvis jerk and spasm.
<<elseif $arousal gte 2000>>
<<His>> hot breath and tongue ellicit shameful feelings.
<<else>>
You try to shift your crotch to escape this violation, but <<he>> persists.
<</if>>
<</if>>
<</if>>
<</nobr>><</widget>>
:: Widgets Actions Man [widget]
<<widget "actionsman">><<nobr>>
<<exposure>>
<<set $face to 0>>
<<if $enemyno gte 2>>
<<set $pronoun to "n">>
<<else>>
<<if $pronoun1 is "m">>
<<set $pronoun to "m">>
<</if>>
<<if $pronoun1 is "f">>
<<set $pronoun to "f">>
<</if>>
<<if $pronoun1 is "i">>
<<set $pronoun to "i">>
<</if>>
<<if $pronoun1 is "n">>
<<set $pronoun to "n">>
<</if>>
<<if $pronoun1 is "t">>
<<set $pronoun to "t">>
<</if>>
<</if>>
<<if $images is 1>><<timed 100ms>>
<<combatimg>>
<br>
<</timed>><</if>>
<<if $traumafocus gte 1 and $traumafocusintro isnot 1>>
<<set $traumafocusintro to 1>>
<i>As you gain focus, you become more and more likely to escape your helpless state of dissociation.</i><br><br>
<</if>>
<<if $traumafocus gt random(1, 1000) and $dissociation gte 2 and $combat is 1>>
<<set $traumafocus to 0>><<set $trauma -= 1000>><<set $dissociation to 1>>
<span class="green">Your lucidity returns.</span> <<ltrauma>> <span class="red">The weight of reality crashes down on you.</span><br><br>
<</if>>
<<actioncarry>>
<<actioncarrydrop>>
<<if $trance lte 0>>
<<if $dissociation lte 1>>
<<if $panicparalysis is 0>>
<<if $panicviolence is 0>>
<<if $orgasmdown lte 0>>
<<if $pain lt 100>>
<<if $leftarm is 0>><br>Your left hand is free.<br>
<<if $leftactiondefault is "leftchest">>
| <label><span class="sub">Stroke</span> <<radiobutton "$leftaction" "leftchest" checked>></label>
<<else>>
| <label><span class="sub">Stroke</span> <<radiobutton "$leftaction" "leftchest">></label>
<</if>>
<<if $consensual isnot 1>>
<<if $leftactiondefault is "lefthit">>
| <label><span class="def">Punch</span> <<radiobutton "$leftaction" "lefthit" checked>></label>
<<else>>
| <label><span class="def">Punch</span> <<radiobutton "$leftaction" "lefthit">></label>
<</if>>
<</if>>
<<if $leftactiondefault is "leftcoverface">>
| <label>Cover your face <<radiobutton "$leftaction" "leftcoverface" checked>></label>
<<else>>
| <label>Cover your face <<radiobutton "$leftaction" "leftcoverface">></label>
<</if>>
<<leftgrab>>
<<leftplay>>
<<leftclothes>>
<<if $lowervaginaexposed is 1 and $undervaginaexposed is 1 and $vaginause is 0>>
<<if $leftactiondefault is "leftcovervagina">>
| <label><span class="brat">Cover your pussy</span> <<radiobutton "$leftaction" "leftcovervagina" checked>></label>
<<else>>
| <label><span class="brat">Cover your pussy</span> <<radiobutton "$leftaction" "leftcovervagina">></label>
<</if>>
<</if>>
<<if $lowervaginaexposed is 1 and $undervaginaexposed is 1 and $penisuse is 0>>
<<if $leftactiondefault is "leftcoverpenis">>
| <label><span class="brat">Cover your penis</span> <<radiobutton "$leftaction" "leftcoverpenis" checked>></label>
<<else>>
| <label><span class="brat">Cover your penis</span> <<radiobutton "$leftaction" "leftcoverpenis">></label>
<</if>>
<</if>>
<<if $loweranusexposed is 1 and $underanusexposed is 1 and $anususe is 0>>
<<if $leftactiondefault is "leftcoveranus">>
| <label><span class="brat">Cover your <<bottom>></span> <<radiobutton "$leftaction" "leftcoveranus" checked>></label>
<<else>>
| <label><span class="brat">Cover your <<bottom>></span> <<radiobutton "$leftaction" "leftcoveranus">></label>
<</if>>
<</if>>
<<if $underclothes isnot "naked">>
<<if $understate is "thighs">>
<<if $leftactiondefault is "leftunderpull">>
| <label><span class="brat">Pull up your $underclothes</span> <<radiobutton "$leftaction" "leftunderpull" checked>></label>
<<else>>
| <label><span class="brat">Pull up your $underclothes</span> <<radiobutton "$leftaction" "leftunderpull">></label>
<</if>>
<</if>>
<<if $understate is "knees">>
<<if $leftactiondefault is "leftunderpull">>
| <label><span class="brat">Pull up your $underclothes</span> <<radiobutton "$leftaction" "leftunderpull" checked>></label>
<<else>>
| <label><span class="brat">Pull up your $underclothes</span> <<radiobutton "$leftaction" "leftunderpull">></label>
<</if>>
<</if>>
<<if $understate is "ankles">>
<<if $leftactiondefault is "leftunderpull">>
| <label><span class="brat">Pull up your $underclothes</span> <<radiobutton "$leftaction" "leftunderpull" checked>></label>
<<else>>
| <label><span class="brat">Pull up your $underclothes</span> <<radiobutton "$leftaction" "leftunderpull">></label>
<</if>>
<</if>>
<</if>>
<<if $skirt is 1>>
<<if $skirtdown is 0>>
<<if $lowerstate is "waist">>
<<if $leftactiondefault is "leftskirtpull">>
| <label><span class="brat">Cover your crotch with your $lowerclothes</span> <<radiobutton "$leftaction" "leftskirtpull" checked>></label>
<<else>>
| <label><span class="brat">Cover your crotch with your $lowerclothes</span> <<radiobutton "$leftaction" "leftskirtpull">></label>
<</if>>
<</if>>
<</if>>
<</if>>
<<if $lowerclothes isnot "naked">>
<<if $upperset is $lowerset>>
<<if $lowerstate isnot $lowerstatebase and $upperstate is $upperstatebase and $upperstatetop is $upperstatetopbase>>
<<if $leftactiondefault is "leftlowerpull">>
| <label><span class="brat">Fix your $lowerclothes</span> <<radiobutton "$leftaction" "leftlowerpull" checked>></label>
<<else>>
| <label><span class="brat">Fix your $lowerclothes</span> <<radiobutton "$leftaction" "leftlowerpull">></label>
<</if>>
<</if>>
<<elseif $lowerstate isnot $lowerstatebase>>
<<if $leftactiondefault is "leftlowerpull">>
| <label><span class="brat">Fix your $lowerclothes</span> <<radiobutton "$leftaction" "leftlowerpull" checked>></label>
<<else>>
| <label><span class="brat">Fix your $lowerclothes</span> <<radiobutton "$leftaction" "leftlowerpull">></label>
<</if>>
<</if>>
<</if>>
<<if $upperclothes isnot "naked">>
<<if $upperstate isnot $upperstatebase>>
<<if $leftactiondefault is "leftupperpull">>
| <label><span class="brat">Fix your $upperclothes</span> <<radiobutton "$leftaction" "leftupperpull" checked>></label>
<<else>>
| <label><span class="brat">Fix your $upperclothes</span> <<radiobutton "$leftaction" "leftupperpull">></label>
<</if>>
<<elseif $upperstatetop isnot $upperstatetopbase>>
<<if $leftactiondefault is "leftupperpull">>
| <label><span class="brat">Fix your $upperclothes</span> <<radiobutton "$leftaction" "leftupperpull" checked>></label>
<<else>>
| <label><span class="brat">Fix your $upperclothes</span> <<radiobutton "$leftaction" "leftupperpull">></label>
<</if>>
<</if>>
<</if>>
<<elseif $leftarm is "penis">><br><br>Your left hand is holding <<his>> penis.<br>
<<if $leftactiondefault is "leftwork">>
| <label><span class="sub">Work <<his>> shaft</span> <<radiobutton "$leftaction" "leftwork" checked>><<handdifficulty>></label>
<<else>>
| <label><span class="sub">Work <<his>> shaft</span> <<radiobutton "$leftaction" "leftwork">><<handdifficulty>></label>
<</if>>
<<if $leftactiondefault is "leftstoppenis">>
| <label>Stop <<radiobutton "$leftaction" "leftstoppenis" checked>></label>
<<else>>
| <label>Stop <<radiobutton "$leftaction" "leftstoppenis">></label>
<</if>>
<<elseif $leftarm is "grappled">>
<br>Your left arm is being held down.<br>
<<if $leftactiondefault is "leftstruggle">>
| <label><span class="def">Struggle</span> <<radiobutton "$leftaction" "leftstruggle" checked>></label>
<<else>>
| <label><span class="def">Struggle</span> <<radiobutton "$leftaction" "leftstruggle">></label>
<</if>>
<<if $leftactiondefault is "rest">>
| <label>Rest <<radiobutton "$leftaction" "rest" checked>></label>
<<else>>
| <label>Rest <<radiobutton "$leftaction" "rest">></label>
<</if>>
<<elseif $leftarm is "bound" and $rightarm is "bound">><br>Your arms are helplessly bound.<br>
<<elseif $leftarm is "othervagina">><br><br>Your left hand is stroking <<his>> pussy.<br>
<<if $leftactiondefault is "leftclit">>
| <label><span class="sub">Rub <<his>> clit</span> <<radiobutton "$leftaction" "leftclit" checked>><<handdifficulty>></label>
<<else>>
| <label><span class="sub">Rub <<his>> clit</span> <<radiobutton "$leftaction" "leftclit">><<handdifficulty>></label>
<</if>>
<<if $leftactiondefault is "leftothervaginastop">>
| <label>Stop <<radiobutton "$leftaction" "leftothervaginastop" checked>></label>
<<else>>
| <label>Stop <<radiobutton "$leftaction" "leftothervaginastop">></label>
<</if>>
<</if>>
<<if $rightarm is 0>><br><br>Your right hand is free.<br>
<<if $rightactiondefault is "rightchest">>
| <label><span class="sub">Stroke</span> <<radiobutton "$rightaction" "rightchest" checked>></label>
<<else>>
| <label><span class="sub">Stroke</span> <<radiobutton "$rightaction" "rightchest">></label>
<</if>>
<<if $consensual isnot 1>>
<<if $rightactiondefault is "righthit">>
| <label><span class="def">Punch</span> <<radiobutton "$rightaction" "righthit" checked>></label>
<<else>>
| <label><span class="def">Punch</span> <<radiobutton "$rightaction" "righthit">></label>
<</if>>
<</if>>
<<if $rightactiondefault is "rightcoverface">>
| <label>Cover your face <<radiobutton "$rightaction" "rightcoverface" checked>></label>
<<else>>
| <label>Cover your face <<radiobutton "$rightaction" "rightcoverface">></label>
<</if>>
<<rightgrab>>
<<rightplay>>
<<rightclothes>>
<<if $lowervaginaexposed is 1 and $undervaginaexposed is 1 and $vaginause is 0>>
<<if $rightactiondefault is "rightcovervagina">>
| <label><span class="brat">Cover your pussy</span> <<radiobutton "$rightaction" "rightcovervagina" checked>></label>
<<else>>
| <label><span class="brat">Cover your pussy</span> <<radiobutton "$rightaction" "rightcovervagina">></label>
<</if>>
<</if>>
<<if $lowervaginaexposed is 1 and $undervaginaexposed is 1 and $penisuse is 0>>
<<if $rightactiondefault is "rightcoverpenis">>
| <label><span class="brat">Cover your penis</span> <<radiobutton "$rightaction" "rightcoverpenis" checked>></label>
<<else>>
| <label><span class="brat">Cover your penis</span> <<radiobutton "$rightaction" "rightcoverpenis">></label>
<</if>>
<</if>>
<<if $loweranusexposed is 1 and $underanusexposed is 1 and $anususe is 0>>
<<if $rightactiondefault is "rightcoveranus">>
| <label><span class="brat">Cover your <<bottom>></span> <<radiobutton "$rightaction" "rightcoveranus" checked>></label>
<<else>>
| <label><span class="brat">Cover your <<bottom>></span> <<radiobutton "$rightaction" "rightcoveranus">></label>
<</if>>
<</if>>
<<if $underclothes isnot "naked">>
<<if $understate is "thighs">>
<<if $rightactiondefault is "rightunderpull">>
| <label><span class="brat">Pull up your $underclothes</span> <<radiobutton "$rightaction" "rightunderpull" checked>></label>
<<else>>
| <label><span class="brat">Pull up your $underclothes</span> <<radiobutton "$rightaction" "rightunderpull">></label>
<</if>>
<</if>>
<<if $understate is "knees">>
<<if $rightactiondefault is "rightunderpull">>
| <label><span class="brat">Pull up your $underclothes</span> <<radiobutton "$rightaction" "rightunderpull" checked>></label>
<<else>>
| <label><span class="brat">Pull up your $underclothes</span> <<radiobutton "$rightaction" "rightunderpull">></label>
<</if>>
<</if>>
<<if $understate is "ankles">>
<<if $rightactiondefault is "rightunderpull">>
| <label><span class="brat">Pull up your $underclothes</span> <<radiobutton "$rightaction" "rightunderpull" checked>></label>
<<else>>
| <label><span class="brat">Pull up your $underclothes</span> <<radiobutton "$rightaction" "rightunderpull">></label>
<</if>>
<</if>>
<</if>>
<<if $skirt is 1>>
<<if $skirtdown is 0>>
<<if $lowerstate is "waist">>
<<if $rightactiondefault is "rightskirtpull">>
| <label><span class="brat">Cover your crotch with your $lowerclothes</span> <<radiobutton "$rightaction" "rightskirtpull" checked>></label>
<<else>>
| <label><span class="brat">Cover your crotch with your $lowerclothes</span> <<radiobutton "$rightaction" "rightskirtpull">></label>
<</if>>
<</if>>
<</if>>
<</if>>
<<if $lowerclothes isnot "naked">>
<<if $lowerset is $upperset>>
<<if $lowerstate isnot $lowerstatebase and $upperstate is $upperstatebase and $upperstatetop is $upperstatetopbase>>
<<if $rightactiondefault is "rightlowerpull">>
| <label><span class="brat">Fix your $lowerclothes</span> <<radiobutton "$rightaction" "rightlowerpull" checked>></label>
<<else>>
| <label><span class="brat">Fix your $lowerclothes</span> <<radiobutton "$rightaction" "rightlowerpull">></label>
<</if>>
<</if>>
<<elseif $lowerstate isnot $lowerstatebase>>
<<if $rightactiondefault is "rightlowerpull">>
| <label><span class="brat">Fix your $lowerclothes</span> <<radiobutton "$rightaction" "rightlowerpull" checked>></label>
<<else>>
| <label><span class="brat">Fix your $lowerclothes</span> <<radiobutton "$rightaction" "rightlowerpull">></label>
<</if>>
<</if>>
<</if>>
<<if $upperclothes isnot "naked">>
<<if $upperstate isnot $upperstatebase>>
<<if $rightactiondefault is "rightupperpull">>
| <label><span class="brat">Fix your $upperclothes</span> <<radiobutton "$rightaction" "rightupperpull" checked>></label>
<<else>>
| <label><span class="brat">Fix your $upperclothes</span> <<radiobutton "$rightaction" "rightupperpull">></label>
<</if>>
<<elseif $upperstatetop isnot $upperstatetopbase>>
<<if $rightactiondefault is "rightupperpull">>
| <label><span class="brat">Fix your $upperclothes</span> <<radiobutton "$rightaction" "rightupperpull" checked>></label>
<<else>>
| <label><span class="brat">Fix your $upperclothes</span> <<radiobutton "$rightaction" "rightupperpull">></label>
<</if>>
<</if>>
<</if>>
<<elseif $rightarm is "penis">><br><br>Your right hand is holding <<his>> penis.<br>
<<if $rightactiondefault is "rightwork">>
| <label><span class="sub">Work <<his>> shaft</span> <<radiobutton "$rightaction" "rightwork" checked>><<handdifficulty>></label>
<<else>>
| <label><span class="sub">Work <<his>> shaft</span> <<radiobutton "$rightaction" "rightwork">><<handdifficulty>></label>
<</if>>
<<if $rightactiondefault is "rightstoppenis">>
| <label>Stop <<radiobutton "$rightaction" "rightstoppenis" checked>></label>
<<else>>
| <label>Stop <<radiobutton "$rightaction" "rightstoppenis">></label>
<</if>>
<<elseif $rightarm is "grappled">><br><br>Your right arm is being held down.<br>
<<if $rightactiondefault is "rightstruggle">>
| <label><span class="def">Struggle</span> <<radiobutton "$rightaction" "rightstruggle" checked>></label>
<<else>>
| <label><span class="def">Struggle</span> <<radiobutton "$rightaction" "rightstruggle">></label>
<</if>>
<<if $rightactiondefault is "rest">>
| <label>Rest <<radiobutton "$rightaction" "rest" checked>></label>
<<else>>
| <label>Rest <<radiobutton "$rightaction" "rest">></label>
<</if>>
<<elseif $rightarm is "bound">><br>
<<elseif $rightarm is "othervagina">><br><br>Your right hand is stroking <<his>> pussy.<br>
<<if $rightactiondefault is "rightclit">>
| <label><span class="sub">Rub <<his>> clit</span> <<radiobutton "$rightaction" "rightclit" checked>><<handdifficulty>></label>
<<else>>
| <label><span class="sub">Rub <<his>> clit</span> <<radiobutton "$rightaction" "rightclit">><<handdifficulty>></label>
<</if>>
<<if $rightactiondefault is "rightothervaginastop">>
| <label>Stop <<radiobutton "$rightaction" "rightothervaginastop" checked>></label>
<<else>>
| <label>Stop <<radiobutton "$rightaction" "rightothervaginastop">></label>
<</if>>
<</if>>
<<if $leftarm is "vagina">><br>Your left hand is protecting your <<pussystop>><br>
<<if $leftactiondefault is "leftstopvagina">>
| <label>Stop <<radiobutton "$leftaction" "leftstopvagina" checked>></label>
<<else>>
| <label>Stop <<radiobutton "$leftaction" "leftstopvagina">></label>
<</if>>
<<if $leftactiondefault is "leftcovervagina">>
| <label><span class="brat">Keep covering</span> <<radiobutton "$leftaction" "leftcovervagina" checked>></label>
<<else>>
| <label><span class="brat">Keep covering</span> <<radiobutton "$leftaction" "leftcovervagina">></label>
<</if>>
<</if>>
<<if $rightarm is "vagina">><br>Your right hand is protecting your <<pussystop>><br>
<<if $rightactiondefault is "rightstopvagina">>
| <label>Stop <<radiobutton "$rightaction" "rightstopvagina" checked>></label>
<<else>>
| <label>Stop <<radiobutton "$rightaction" "rightstopvagina">></label>
<</if>>
<<if $rightactiondefault is "rightcovervagina">>
| <label><span class="brat">Keep covering</span> <<radiobutton "$rightaction" "rightcovervagina" checked>></label>
<<else>>
| <label><span class="brat">Keep covering</span> <<radiobutton "$rightaction" "rightcovervagina">></label>
<</if>>
<</if>>
<<if $leftarm is "coverpenis">><br>Your left hand is protecting your <<penisstop>><br>
<<if $leftactiondefault is "leftstopcoverpenis">>
| <label>Stop <<radiobutton "$leftaction" "leftstopcoverpenis" checked>></label>
<<else>>
| <label>Stop <<radiobutton "$leftaction" "leftstopcoverpenis">></label>
<</if>>
<<if $leftactiondefault is "leftcoverpenis">>
| <label><span class="brat">Keep covering</span> <<radiobutton "$leftaction" "leftcoverpenis" checked>></label>
<<else>>
| <label><span class="brat">Keep covering</span> <<radiobutton "$leftaction" "leftcoverpenis">></label>
<</if>>
<</if>>
<<if $rightarm is "coverpenis">><br>Your right hand is protecting your <<penisstop>><br>
<<if $rightactiondefault is "rightstopcoverpenis">>
| <label>Stop <<radiobutton "$rightaction" "rightstopcoverpenis" checked>></label>
<<else>>
| <label>Stop <<radiobutton "$rightaction" "rightstopcoverpenis">></label>
<</if>>
<<if $rightactiondefault is "rightcoverpenis">>
| <label><span class="brat">Keep covering</span> <<radiobutton "$rightaction" "rightcoverpenis" checked>></label>
<<else>>
| <label><span class="brat">Keep covering</span> <<radiobutton "$rightaction" "rightcoverpenis">></label>
<</if>>
<</if>>
<<if $leftarm is "anus">><br>Your left hand is protecting your <<bottomstop>><br>
<<if $leftactiondefault is "leftstopanus">>
| <label>Stop <<radiobutton "$leftaction" "leftstopanus" checked>></label>
<<else>>
| <label>Stop <<radiobutton "$leftaction" "leftstopanus">></label>
<</if>>
<<if $leftactiondefault is "leftcoveranus">>
| <label><span class="brat">Keep covering</span> <<radiobutton "$leftaction" "leftcoveranus" checked>></label>
<<else>>
| <label><span class="brat">Keep covering</span> <<radiobutton "$leftaction" "leftcoveranus">></label>
<</if>>
<</if>>
<<if $rightarm is "anus">><br>Your right hand is protecting your <<bottomstop>><br>
<<if $rightactiondefault is "rightstopanus">>
| <label>Stop <<radiobutton "$rightaction" "rightstopanus" checked>></label>
<<else>>
| <label>Stop <<radiobutton "$rightaction" "rightstopanus">></label>
<</if>>
<<if $rightactiondefault is "rightcoveranus">>
| <label><span class="brat">Keep covering</span> <<radiobutton "$rightaction" "rightcoveranus" checked>></label>
<<else>>
| <label><span class="brat">Keep covering</span> <<radiobutton "$rightaction" "rightcoveranus">></label>
<</if>>
<</if>>
<br>
<<if $feetuse isnot "grappled" and $feetuse isnot "bound">>
<<if $feetuse is 0>><br><br>Your feet are free.<br>
<<feetgrab>>
<<if $consensual isnot 1>>
<<if $feetactiondefault is "kick">>
| <label><span class="def">Kick</span> <<radiobutton "$feetaction" "kick" checked>></label>
<<else>>
| <label><span class="def">Kick</span> <<radiobutton "$feetaction" "kick">></label>
<</if>>
<</if>>
<<elseif $feetuse is "penis">><br><br>Your feet are holding <<his>> penis.<br>
<<if $feetactiondefault is "grabrub">>
| <label><span class="sub">Rub</span> <<radiobutton "$feetaction" "grabrub" checked>><<feetdifficulty>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$feetaction" "grabrub">><<feetdifficulty>></label>
<</if>>
<<if $feetactiondefault is "stop">>
| <label>Stop <<radiobutton "$feetaction" "stop" checked>></label>
<<else>>
| <label>Stop <<radiobutton "$feetaction" "stop">></label>
<</if>>
<<elseif $feetuse is "othervagina">><br><br>Your feet are holding back <<his>> pussy.<br>
<<if $feetactiondefault is "vaginagrabrub">>
| <label><span class="sub">Rub</span> <<radiobutton "$feetaction" "vaginagrabrub" checked>><<feetdifficulty>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$feetaction" "vaginagrabrub">><<feetdifficulty>></label>
<</if>>
<<if $feetactiondefault is "stop">>
| <label>Stop <<radiobutton "$feetaction" "stop" checked>></label>
<<else>>
| <label>Stop <<radiobutton "$feetaction" "stop">></label>
<</if>>
<<elseif $penis is "clothed">><br>
<<if $feetuse is 0>>Your feet are free.<br>
<<if $feetactiondefault is "rub">>
| <label><span class="sub">Rub <<his>> crotch</span> <<radiobutton "$feetaction" "rub" checked>></label>
<<else>>
| <label><span class="sub">Rub <<his>> crotch</span> <<radiobutton "$feetaction" "rub">></label>
<</if>>
<<if $feetactiondefault is "kick">>
| <label><span class="def">Kick</span> <<radiobutton "$feetaction" "kick" checked>></label>
<<else>>
| <label><span class="def">Kick</span> <<radiobutton "$feetaction" "kick">></label>
<</if>>
<</if>>
<<elseif $penis2 is "clothed">><br>
<<if $feetuse is 0>>Your feet are free.<br>
<<if $feetactiondefault is "rub">>
| <label><span class="sub">Rub <<his>> crotch</span> <<radiobutton "$feetaction" "rub" checked>></label>
<<else>>
| <label><span class="sub">Rub <<his>> crotch</span> <<radiobutton "$feetaction" "rub">></label>
<</if>>
<<if $feetactiondefault is "kick">>
| <label><span class="def">Kick</span> <<radiobutton "$feetaction" "kick" checked>></label>
<<else>>
| <label><span class="def">Kick</span> <<radiobutton "$feetaction" "kick">></label>
<</if>>
<</if>>
<<elseif $penis3 is "clothed">><br>
<<if $feetuse is 0>>Your feet are free.<br>
<<if $feetactiondefault is "rub">>
| <label><span class="sub">Rub <<his>> crotch</span> <<radiobutton "$feetaction" "rub" checked>></label>
<<else>>
| <label><span class="sub">Rub <<his>> crotch</span> <<radiobutton "$feetaction" "rub">></label>
<</if>>
<<if $feetactiondefault is "kick">>
| <label><span class="def">Kick</span> <<radiobutton "$feetaction" "kick" checked>></label>
<<else>>
| <label><span class="def">Kick</span> <<radiobutton "$feetaction" "kick">></label>
<</if>>
<</if>>
<<elseif $penis4 is "clothed">><br>
<<if $feetuse is 0>>Your feet are free.<br>
<<if $feetactiondefault is "rub">>
| <label><span class="sub">Rub <<his>> crotch</span> <<radiobutton "$feetaction" "rub" checked>></label>
<<else>>
| <label><span class="sub">Rub <<his>> crotch</span> <<radiobutton "$feetaction" "rub">></label>
<</if>>
<<if $feetactiondefault is "kick">>
| <label><span class="def">Kick</span> <<radiobutton "$feetaction" "kick" checked>></label>
<<else>>
| <label><span class="def">Kick</span> <<radiobutton "$feetaction" "kick">></label>
<</if>>
<</if>>
<<elseif $penis5 is "clothed">><br>
<<if $feetuse is 0>>Your feet are free.<br>
<<if $feetactiondefault is "rub">>
| <label><span class="sub">Rub <<his>> crotch</span> <<radiobutton "$feetaction" "rub" checked>></label>
<<else>>
| <label><span class="sub">Rub <<his>> crotch</span> <<radiobutton "$feetaction" "rub">></label>
<</if>>
<<if $feetactiondefault is "kick">>
| <label><span class="def">Kick</span> <<radiobutton "$feetaction" "kick" checked>></label>
<<else>>
| <label><span class="def">Kick</span> <<radiobutton "$feetaction" "kick">></label>
<</if>>
<</if>>
<<elseif $penis6 is "clothed">><br>
<<if $feetuse is 0>>Your feet are free.<br>
<<if $feetactiondefault is "rub">>
| <label><span class="sub">Rub <<his>> crotch</span> <<radiobutton "$feetaction" "rub" checked>></label>
<<else>>
| <label><span class="sub">Rub <<his>> crotch</span> <<radiobutton "$feetaction" "rub">></label>
<</if>>
<<if $feetactiondefault is "kick">>
| <label><span class="def">Kick</span> <<radiobutton "$feetaction" "kick" checked>></label>
<<else>>
| <label><span class="def">Kick</span> <<radiobutton "$feetaction" "kick">></label>
<</if>>
<</if>>
<</if>>
<<if $feetuse is 0>>
<<if $feetactiondefault is "rest">>
| <label>Rest <<radiobutton "$feetaction" "rest" checked>></label>
<<else>>
| <label>Rest <<radiobutton "$feetaction" "rest">></label>
<</if>>
<</if>>
<<elseif $feetuse is "bound">>
<br>Your legs are bound.
<<else>><br>Your feet are free but unusable in this position.
<</if>>
<<if $mouthuse is 0>><br><br>Your mouth is free.<br>
<<if $head isnot "grappled" and $head isnot "bound">>
<<if $chestuse is "penis">>
<<if $mouthactiondefault is "peniskiss">>
| <label><span class="sub">Kiss</span> <<radiobutton "$mouthaction" "peniskiss" checked>></label>
<<else>>
| <label><span class="sub">Kiss</span> <<radiobutton "$mouthaction" "peniskiss">></label>
<</if>>
<<else>>
<<if $mouthactiondefault is "kiss">>
| <label><span class="sub">Kiss <<him>></span> <<radiobutton "$mouthaction" "kiss" checked>></label>
<<else>>
| <label><span class="sub">Kiss <<him>></span> <<radiobutton "$mouthaction" "kiss">></label>
<</if>>
<</if>>
<<oral>>
<<if $enemyanger gte 20 and $underwater lte 0>>
<<if $mouthactiondefault is "apologise">>
| <label>Apologise <<radiobutton "$mouthaction" "apologise" checked>></label>
<<else>>
| <label>Apologise <<radiobutton "$mouthaction" "apologise">></label>
<</if>>
<</if>>
<</if>>
<<speak>>
<<elseif $mouthstate is "entrance">><br><br><<His>> penis hovers in front of your mouth.<br>
<<if $mouthactiondefault is "peniskiss">>
| <label><span class="sub">Kiss</span> <<radiobutton "$mouthaction" "peniskiss" checked>></label>
<<else>>
| <label><span class="sub">Kiss</span> <<radiobutton "$mouthaction" "peniskiss">></label>
<</if>>
<<if $consensual is 1 and $promiscuity lte 34 and $enemytype is "man" or $consensual is 1 and $deviancy lte 34 and $enemytype isnot "man">>
<<else>>
<<if $mouthactiondefault is "grasp">>
| <label><span class="meek">Grab between breasts </span><<radiobutton "$mouthaction" "grasp" checked>><<chestdifficulty>> <<combatpromiscuous3>></label>
<<else>>
| <label><span class="meek">Grab between breasts </span><<radiobutton "$mouthaction" "grasp">><<chestdifficulty>><<combatpromiscuous3>></label>
<</if>>
<</if>>
<<if $head isnot "grappled" and $head isnot "bound">>
<<if $mouthactiondefault is "pullaway">>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "pullaway" checked>><<oraldifficulty>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "pullaway">><<oraldifficulty>></label>
<</if>>
<</if>>
<<speak>>
<<elseif $mouthstate is "imminent">><br><br><<His>> penis presses against your lips.<br>
<<if $mouthactiondefault is "lick">>
| <label><span class="sub">Lick</span> <<radiobutton "$mouthaction" "lick" checked>></label>
<<else>>
| <label><span class="sub">Lick</span> <<radiobutton "$mouthaction" "lick">></label>
<</if>>
<<if $head isnot "grappled" and $head isnot "bound">>
<<if $mouthactiondefault is "pullaway">>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "pullaway" checked>><<oraldifficulty>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "pullaway">><<oraldifficulty>></label>
<</if>>
<</if>>
<<speak>>
<<elseif $mouthstate is "penetrated">><br><br><<His>> penis penetrates your mouth.<br>
<<if $mouthactiondefault is "suck">>
| <label><span class="sub">Suck</span> <<radiobutton "$mouthaction" "suck" checked>></label>
<<else>>
| <label><span class="sub">Suck</span> <<radiobutton "$mouthaction" "suck">></label>
<</if>>
<<if $consensual isnot 1>>
<<if $mouthactiondefault is "bite">>
| <label><span class="def">Bite</span> <<radiobutton "$mouthaction" "bite" checked>></label>
<<else>>
| <label><span class="def">Bite</span> <<radiobutton "$mouthaction" "bite">></label>
<</if>>
<</if>>
<<if $head isnot "grappled" and $head isnot "bound">>
<<if $mouthactiondefault is "pullaway">>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "pullaway" checked>><<oraldifficulty>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "pullaway">><<oraldifficulty>></label>
<</if>>
<</if>>
<<elseif $mouthuse is "othervagina">><br><br><<His>> pussy presses against your lips.<br>
<<if $mouthactiondefault is "vaginalick">>
| <label><span class="sub">Lick</span> <<radiobutton "$mouthaction" "vaginalick" checked>></label>
<<else>>
| <label><span class="sub">Lick</span> <<radiobutton "$mouthaction" "vaginalick">></label>
<</if>>
<<if $head isnot "grappled" and $head isnot "bound">>
<<if $mouthactiondefault is "pullawayvagina">>
| <label><span class="brat">Pull Away</span> <<radiobutton "$mouthaction" "pullawayvagina" checked>></label>
<<else>>
| <label><span class="brat">Pull Away</span> <<radiobutton "$mouthaction" "pullawayvagina">></label>
<</if>>
<</if>>
<<speak>>
<<elseif $mouthuse is "kiss">><br><br>
<<if $mouthstate is "kissentrance">>
Your mouth is pressed by another's.<br>
<<elseif $mouthstate is "kissimminent">>
Your mouth is engulfed by another's.<br>
<<elseif $mouthstate is "kiss">>
Your mouth is engulfed by another's.<br>
<</if>>
<<if $mouthactiondefault is "pullawaykiss">>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "pullawaykiss" checked>><<oraldifficulty>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "pullawaykiss">><<oraldifficulty>></label>
<</if>>
<<if $mouthactiondefault is "kissback">>
| <label><span class="sub">Kiss</span> <<radiobutton "$mouthaction" "kissback" checked>></label>
<<else>>
| <label><span class="sub">Kiss</span> <<radiobutton "$mouthaction" "kissback">></label>
<</if>>
<<if $mouthstate isnot "kiss" and $mouthstate isnot "kissimminent">>
<<speak>>
<</if>>
<<else>><br><br>Your mouth is blocked, muffling any noise you make.
<</if>>
<<if $penisstate is 0>><br><br>Your <<penis>> is free.<br>
<<actionspenistovagina>>
<<actionspenistoanus>>
<</if>>
<<if $penisstate is "othermouthentrance">><br><br>You feel breath on your <<penisstop>><br>
<<if $consensual is 1 and $promiscuity lt 0>>
<<else>>
<<if $penisactiondefault is "thighbay">>
| <label><span class="meek">Press your thigh against <<his>> mouth</span> <<radiobutton "$penisaction" "thighbay" checked>><<thighdifficulty>> <<combatpromiscuous1>></label>
<<else>>
| <label><span class="meek">Press your thigh against <<his>> mouth</span> <<radiobutton "$penisaction" "thighbay">><<thighdifficulty>> <<combatpromiscuous1>></label>
<</if>>
<</if>>
<<if $penisactiondefault is "othermouthtease">>
| <label><span class="sub">Rub against <<his>> face</span> <<radiobutton "$penisaction" "othermouthtease" checked>></label>
<<else>>
| <label><span class="sub">Rub against <<his>> face</span> <<radiobutton "$penisaction" "othermouthtease">></label>
<</if>>
<</if>>
<<if $penisstate is "othermouthimminent">><br><br>
<<His>> lips press against the tip of your <<penisstop>><br>
<<if $penisactiondefault is "othermouthrub">>
| <label><span class="sub">Rub against <<his>> lips</span> <<radiobutton "$penisaction" "othermouthrub" checked>></label>
<<else>>
| <label><span class="sub">Rub against <<his>> lips</span> <<radiobutton "$penisaction" "othermouthrub">></label>
<</if>>
<<if $penisactiondefault is "othermouthescape">>
| <label><span class="brat">Pull away</span> <<radiobutton "$penisaction" "othermouthescape" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$penisaction" "othermouthescape">></label>
<</if>>
<</if>>
<<if $penisstate is "othermouth">><br><br>
<<His>> mouth envelopes your <<penisstop>><br>
<<if $penisactiondefault is "othermouthcooperate">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$penisaction" "othermouthcooperate" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$penisaction" "othermouthcooperate">></label>
<</if>>
<</if>>
<<if $penisstate is "entrance">><br><br><<His>> pussy hovers near your <<penisstop>><br>
<<actionspenisvaginafuck>>
<<if $consensual is 1 and $promiscuity lte 54 and $enemytype is "man" or $consensual is 1 and $deviancy lte 54 and $enemytype isnot "man">>
<<else>>
<<if $penisactiondefault is "bay">>
| <label><span class="meek">Frot against <<his>> clit</span> <<radiobutton "$penisaction" "bay" checked>><<peniledifficulty>> <<combatpromiscuous4>></label>
<<else>>
| <label><span class="meek">Frot against <<his>> clit</span> <<radiobutton "$penisaction" "bay">><<peniledifficulty>> <<combatpromiscuous4>></label>
<</if>>
<</if>>
<<if $penisactiondefault is "tease">>
| <label><span class="sub">Tease</span> <<radiobutton "$penisaction" "tease" checked>></label>
<<else>>
| <label><span class="sub">Tease</span> <<radiobutton "$penisaction" "tease">></label>
<</if>>
<</if>>
<<if $penisstate is "imminent">><br><br>
<<His>> pussy presses against your <<penisstop>><br>
<<actionspenisvaginafuck>>
<<if $penisactiondefault is "rub">>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "rub" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "rub">></label>
<</if>>
<<if $penisactiondefault is "escape">>
| <label><span class="brat">Pull away</span> <<radiobutton "$penisaction" "escape" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$penisaction" "escape">></label>
<</if>>
<</if>>
<<if $penisstate is "penetrated">><br><br>
<<His>> vagina envelopes your <<penisstop>><br>
<<if $penisactiondefault is "cooperate">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$penisaction" "cooperate" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$penisaction" "cooperate">></label>
<</if>>
<<if $penisactiondefault is "take">>
| <label>Take it <<radiobutton "$penisaction" "take" checked>></label>
<<else>>
| <label>Take it <<radiobutton "$penisaction" "take">></label>
<</if>>
<</if>>
<<if $penisstate is "otheranusentrance">><br><br><<His>> ass hovers near your <<penisstop>><br>
<<actionspenisanusfuck>>
<<if $consensual is 1 and $promiscuity lte 54 and $enemytype is "man" or $consensual is 1 and $deviancy lte 54 and $enemytype isnot "man">>
<<else>>
<<if $penisactiondefault is "otheranusbay">>
| <label><span class="meek">Frot against <<his>> ass</span> <<radiobutton "$penisaction" "otheranusbay" checked>><<peniledifficulty>> <<combatpromiscuous4>></label>
<<else>>
| <label><span class="meek">Frot against <<his>> ass</span> <<radiobutton "$penisaction" "otheranusbay">><<peniledifficulty>> <<combatpromiscuous4>></label>
<</if>>
<</if>>
<<if $penisactiondefault is "otheranustease">>
| <label><span class="sub">Tease</span> <<radiobutton "$penisaction" "otheranustease" checked>></label>
<<else>>
| <label><span class="sub">Tease</span> <<radiobutton "$penisaction" "otheranustease">></label>
<</if>>
<</if>>
<<if $penisstate is "otheranusimminent">><br><br>
<<His>> ass presses against your <<penisstop>><br>
<<actionspenisanusfuck>>
<<if $penisactiondefault is "otheranusrub">>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "otheranusrub" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "otheranusrub">></label>
<</if>>
<<if $penisactiondefault is "otheranusescape">>
| <label><span class="brat">Pull away</span> <<radiobutton "$penisaction" "otheranusescape" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$penisaction" "otheranusescape">></label>
<</if>>
<</if>>
<<if $penisstate is "otheranus">><br><br>
<<His>> ass envelopes your <<penisstop>><br>
<<if $penisactiondefault is "otheranuscooperate">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$penisaction" "otheranuscooperate" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$penisaction" "otheranuscooperate">></label>
<</if>>
<<if $penisactiondefault is "otheranustake">>
| <label>Take it <<radiobutton "$penisaction" "otheranustake" checked>></label>
<<else>>
| <label>Take it <<radiobutton "$penisaction" "otheranustake">></label>
<</if>>
<</if>>
<<if $penisexist is 1>>
<<if $penisactiondefault is "rest">>
| <label>Rest <<radiobutton "$penisaction" "rest" checked>></label>
<<else>>
| <label>Rest <<radiobutton "$penisaction" "rest">></label>
<</if>>
<</if>>
<<if $vaginastate is 0>><br><br>Your <<pussy>> is free.<br>
<<actionsvaginatopenis>>
<</if>>
<<if $vaginastate is "othermouthentrance">><br><br>You feel breath on your <<pussystop>><br>
<<if $consensual is 1 and $promiscuity lt 0>>
<<else>>
<<if $vaginaactiondefault is "thighbay">>
| <label><span class="meek">Press your thigh against <<his>> mouth</span> <<radiobutton "$vaginaaction" "thighbay" checked>><<thighdifficulty>> <<combatpromiscuous1>></label>
<<else>>
| <label><span class="meek">Press your thigh against <<his>> mouth</span> <<radiobutton "$vaginaaction" "thighbay">><<thighdifficulty>> <<combatpromiscuous1>></label>
<</if>>
<</if>>
<<if $vaginaactiondefault is "othermouthtease">>
| <label><span class="sub">Rub against <<his>> face</span> <<radiobutton "$vaginaaction" "othermouthtease" checked>></label>
<<else>>
| <label><span class="sub">Rub against <<his>> face</span> <<radiobutton "$vaginaaction" "othermouthtease">></label>
<</if>>
<</if>>
<<if $vaginastate is "othermouthimminent">><br><br>
<<His>> lips press against your labia.<br>
<<if $vaginaactiondefault is "othermouthrub">>
| <label><span class="sub">Rub against <<his>> lips</span> <<radiobutton "$vaginaaction" "othermouthrub" checked>></label>
<<else>>
| <label><span class="sub">Rub against <<his>> lips</span> <<radiobutton "$vaginaaction" "othermouthrub">></label>
<</if>>
<<if $vaginaactiondefault is "othermouthescape">>
| <label><span class="brat">Pull away</span> <<radiobutton "$vaginaaction" "othermouthescape" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$vaginaaction" "othermouthescape">></label>
<</if>>
<</if>>
<<if $vaginastate is "othermouth">><br><br>
<<His>> tongue penetrates your <<pussystop>><br>
<<if $vaginaactiondefault is "othermouthcooperate">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$vaginaaction" "othermouthcooperate" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$vaginaaction" "othermouthcooperate">></label>
<</if>>
<</if>>
<<if $vaginastate is "entrance">><br><br><<His>> penis hovers near your <<pussystop>><br>
<<actionsvaginapenisfuck>>
<<if $consensual is 1 and $promiscuity lte 54 and $enemytype is "man" or $consensual is 1 and $deviancy lte 54 and $enemytype isnot "man">>
<<else>>
<<if $thighuse is 0>>
<<if $vaginaactiondefault is "penisthighs">>
| <label><span class="meek">Try to keep <<his>> penis away with your thighs</span> <<radiobutton "$vaginaaction" "penisthighs" checked>><<thighdifficulty>> <<combatpromiscuous4>></label>
<<else>>
| <label><span class="meek">Try to keep <<his>> penis away with your thighs</span> <<radiobutton "$vaginaaction" "penisthighs">><<thighdifficulty>> <<combatpromiscuous4>></label>
<</if>>
<</if>>
<</if>>
<<if $anususe is 0 and $analshield isnot 1>>
<<if $vaginaactiondefault is "penisanus">>
| <label><span class="meek">Offer your <<bottom>> instead</span> <<radiobutton "$vaginaaction" "penisanus" checked>><<analdifficulty>></label>
<<else>>
| <label><span class="meek">Offer your <<bottom>> instead</span> <<radiobutton "$vaginaaction" "penisanus">><<analdifficulty>></label>
<</if>>
<</if>>
<<if $vaginaactiondefault is "penistease">>
| <label><span class="sub">Tease the tip</span> <<radiobutton "$vaginaaction" "penistease" checked>></label>
<<else>>
| <label><span class="sub">Tease the tip</span> <<radiobutton "$vaginaaction" "penistease">></label>
<</if>>
<</if>>
<<if $vaginastate is "imminent">><br><br>
<<His>> penis presses against your <<pussystop>><br>
<<actionsvaginapenisfuck>>
<<if $vaginaactiondefault is "rub">>
| <label><span class="sub">Rub</span> <<radiobutton "$vaginaaction" "rub" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$vaginaaction" "rub">></label>
<</if>>
<<if $vaginaactiondefault is "escape">>
| <label><span class="brat">Pull away</span> <<radiobutton "$vaginaaction" "escape" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$vaginaaction" "escape">></label>
<</if>>
<</if>>
<<if $vaginastate is "penetrated">><br><br>
<<His>> penis penetrates your <<pussystop>><br>
<<if $vaginaactiondefault is "cooperate">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$vaginaaction" "cooperate" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$vaginaaction" "cooperate">></label>
<</if>>
<<if $vaginaactiondefault is "take">>
| <label>Take it <<radiobutton "$vaginaaction" "take" checked>></label>
<<else>>
| <label>Take it <<radiobutton "$vaginaaction" "take">></label>
<</if>>
<</if>>
<<if $vaginaexist is 1>>
<<if $vaginaactiondefault is "rest">>
| <label>Rest <<radiobutton "$vaginaaction" "rest" checked>></label>
<<else>>
| <label>Rest <<radiobutton "$vaginaaction" "rest">></label>
<</if>>
<</if>>
<<if $anusstate is 0>><br><br>Your <<bottom>> is free.<br>
<</if>>
<<if $anusstate is "othermouthentrance">><br><br>You feel breath on your <<bottomstop>><br>
<<if $consensual is 1 and $promiscuity lt 0>>
<<else>>
<<if $anusactiondefault is "bottombay">>
| <label><span class="meek">Press your butt against <<his>> mouth</span> <<radiobutton "$anusaction" "bottombay" checked>><<bottomdifficulty>> <<combatpromiscuous1>></label>
<<else>>
| <label><span class="meek">Press your butt against <<his>> mouth</span> <<radiobutton "$anusaction" "bottombay">><<bottomdifficulty>> <<combatpromiscuous1>></label>
<</if>>
<</if>>
<<if $anusactiondefault is "othermouthtease">>
| <label><span class="sub">Rub against <<his>> face</span> <<radiobutton "$anusaction" "othermouthtease" checked>></label>
<<else>>
| <label><span class="sub">Rub against <<his>> face</span> <<radiobutton "$anusaction" "othermouthtease">></label>
<</if>>
<</if>>
<<if $anusstate is "othermouthimminent">><br><br>
<<His>> lips press against your anus.<br>
<<if $anusactiondefault is "othermouthrub">>
| <label><span class="sub">Rub against <<his>> lips</span> <<radiobutton "$anusaction" "othermouthrub" checked>></label>
<<else>>
| <label><span class="sub">Rub against <<his>> lips</span> <<radiobutton "$anusaction" "othermouthrub">></label>
<</if>>
<<if $anusactiondefault is "othermouthescape">>
| <label><span class="brat">Pull away</span> <<radiobutton "$anusaction" "othermouthescape" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$anusaction" "othermouthescape">></label>
<</if>>
<</if>>
<<if $anusstate is "othermouth">><br><br>
<<His>> tongue penetrates your <<bottomstop>><br>
<<if $anusactiondefault is "othermouthcooperate">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$anusaction" "othermouthcooperate" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$anusaction" "othermouthcooperate">></label>
<</if>>
<</if>>
<<if $anusstate is "entrance">><br><br><<His>> penis hovers near your <<bottomstop>><br>
<<if $consensual is 1 and $promiscuity lte 54 and $enemytype is "man" or $consensual is 1 and $deviancy lte 54 and $enemytype isnot "man">>
<<else>>
<<if $bottomuse is 0>>
<<if $anusactiondefault is "penischeeks">>
| <label><span class="meek">Try to keep <<his>> penis away with your cheeks</span> <<radiobutton "$anusaction" "penischeeks" checked>><<analdifficulty>> <<combatpromiscuous4>></label>
<<else>>
| <label><span class="meek">Try to keep <<his>> penis away with your cheeks</span> <<radiobutton "$anusaction" "penischeeks">><<analdifficulty>> <<combatpromiscuous4>></label>
<</if>>
<</if>>
<</if>>
<<if $vaginause is 0 and $undertype isnot "chastity">>
<<if $anusactiondefault is "penispussy">>
| <label><span class="meek">Offer your pussy instead</span> <<radiobutton "$anusaction" "penispussy" checked>><<vaginaldifficulty>></label>
<<else>>
| <label><span class="meek">Offer your pussy instead</span> <<radiobutton "$anusaction" "penispussy">><<vaginaldifficulty>></label>
<</if>>
<</if>>
<<if $anusactiondefault is "penistease">>
| <label><span class="sub">Tease the tip</span> <<radiobutton "$anusaction" "penistease" checked>></label>
<<else>>
| <label><span class="sub">Tease the tip</span> <<radiobutton "$anusaction" "penistease">></label>
<</if>>
<</if>>
<<if $anusstate is "imminent">><br><br>
<<His>> penis presses against your anus.<br>
<<if $anusactiondefault is "rub">>
| <label><span class="sub">Rub</span> <<radiobutton "$anusaction" "rub" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$anusaction" "rub">></label>
<</if>>
<<if $anusactiondefault is "escape">>
| <label><span class="brat">Pull away</span> <<radiobutton "$anusaction" "escape" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$anusaction" "escape">></label>
<</if>>
<</if>>
<<if $anusstate is "penetrated">><br><br>
<<His>> penis penetrates your anus.<br>
<<if $anusactiondefault is "cooperate">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$anusaction" "cooperate" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$anusaction" "cooperate">></label>
<</if>>
<<if $anusactiondefault is "take">>
| <label>Take it <<radiobutton "$anusaction" "take" checked>></label>
<<else>>
| <label>Take it <<radiobutton "$anusaction" "take">></label>
<</if>>
<</if>>
<<if $bottomuse is 0>>
<<if $anusactiondefault is "rest">>
| <label>Rest <<radiobutton "$anusaction" "rest" checked>></label>
<<else>>
| <label>Rest <<radiobutton "$anusaction" "rest">></label>
<</if>>
<</if>>
<<if $bottomuse is "mouth">><br><br>
You press your <<bottom>> against <<his>> face.<br>
<<if $cheekactiondefault is "othermouthrub">>
| <label><span class="sub">Rub</span> <<radiobutton "$cheekaction" "othermouthrub" checked>><<analdifficulty>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$cheekaction" "othermouthrub">><<analdifficulty>></label>
<</if>>
<<if $cheekactiondefault is "othermouthstop">>
| <label>Stop <<radiobutton "$cheekaction" "othermouthstop" checked>></label>
<<else>>
| <label>Stop <<radiobutton "$cheekaction" "othermouthstop">></label>
<</if>>
<</if>>
<<if $bottomuse is "penis">><br><br>
You hold <<his>> penis between your buttocks.<br>
<<if $cheekactiondefault is "rub">>
| <label><span class="sub">Rub</span> <<radiobutton "$cheekaction" "rub" checked>><<analdifficulty>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$cheekaction" "rub">><<analdifficulty>></label>
<</if>>
<<if $cheekactiondefault is "stop">>
| <label>Stop <<radiobutton "$cheekaction" "stop" checked>></label>
<<else>>
| <label>Stop <<radiobutton "$cheekaction" "stop">></label>
<</if>>
<</if>>
<<if $thighuse is "mouth">><br><br>
You press your thigh against <<his>> mouth.<br>
<<if $thighactiondefault is "othermouthrub">>
| <label><span class="sub">Continue</span> <<radiobutton "$thighaction" "othermouthrub" checked>><<thighdifficulty>></label>
<<else>>
| <label><span class="sub">Continue</span> <<radiobutton "$thighaction" "othermouthrub">><<thighdifficulty>></label>
<</if>>
<<if $thighactiondefault is "othermouthstop">>
| <label>Stop <<radiobutton "$thighaction" "othermouthstop" checked>></label>
<<else>>
| <label>Stop <<radiobutton "$thighaction" "othermouthstop">></label>
<</if>>
<</if>>
<<if $thighuse is "penis">><br><br>
You hold <<his>> penis between your thighs.<br>
<<if $thighactiondefault is "rub">>
| <label><span class="sub">Rub</span> <<radiobutton "$thighaction" "rub" checked>><<thighdifficulty>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$thighaction" "rub">><<thighdifficulty>></label>
<</if>>
<<if $thighactiondefault is "stop">>
| <label>Stop <<radiobutton "$thighaction" "stop" checked>></label>
<<else>>
| <label>Stop <<radiobutton "$thighaction" "stop">></label>
<</if>>
<</if>>
<<if $penisuse is "clit">><br><br>
You press your <<penis>> against <<his>> clit.<br>
<<if $penisactiondefault is "rub">>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "clitrub" checked>><<peniledifficulty>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "clitrub">><<peniledifficulty>></label>
<</if>>
<<if $penisactiondefault is "stop">>
| <label>Stop <<radiobutton "$penisaction" "stop" checked>></label>
<<else>>
| <label>Stop <<radiobutton "$penisaction" "stop">></label>
<</if>>
<</if>>
<<if $penisuse is "otheranusrub">><br><br>
You hold your <<penis>> between <<his>> ass cheeks.<br>
<<if $penisactiondefault is "otheranusrub">>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "otheranusrub" checked>><<peniledifficulty>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "otheranusrub">><<peniledifficulty>></label>
<</if>>
<<if $penisactiondefault is "otheranusstop">>
| <label>Stop <<radiobutton "$penisaction" "otheranusstop" checked>></label>
<<else>>
| <label>Stop <<radiobutton "$penisaction" "otheranusstop">></label>
<</if>>
<</if>>
<<if $chestuse is "penis">><br><br>
<<if $breastcup is "none">>
<<His>> penis rests against your <<breastsstop>><br>
<<else>>
<<His>> penis rests between your <<breasts>><br>
<</if>>
<<if $chestactiondefault is "rub">>
| <label><span class="sub">Rub</span> <<radiobutton "$chestaction" "rub" checked>><<chestdifficulty>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$chestaction" "rub">><<chestdifficulty>></label>
<</if>>
<</if>>
<br><br>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<combatstate>>
<<carryblock>>
<br>
<<set $face to 0>>
<</nobr>><</widget>>
:: Widgets Effects Man [widget]
<<widget "effectsman">><<nobr>><<set $pain -= 1>>
<<if $enemyno gte 2>>
<<set $pronoun to "n">>
<<else>>
<<if $pronoun1 is "m">>
<<set $pronoun to "m">>
<</if>>
<<if $pronoun1 is "f">>
<<set $pronoun to "f">>
<</if>>
<<if $pronoun1 is "i">>
<<set $pronoun to "i">>
<</if>>
<<if $pronoun1 is "n">>
<<set $pronoun to "n">>
<</if>>
<<if $pronoun1 is "t">>
<<set $pronoun to "t">>
<</if>>
<</if>>
<<if $beastno gte 1>>
<<set $pronoun to "i">>
<</if>>
<<set $intro1 to 1>>
<<set $intro2 to 1>>
<<set $intro3 to 1>>
<<set $intro4 to 1>>
<<set $intro5 to 1>>
<<set $intro6 to 1>>
<<if $trance gte 1>>
You stare straight ahead, your body passive and compliant.
<<elseif $dissociation gte 2>>
You stare straight ahead, your body passive and compliant.
<</if>>
<<if $underwater is 1>>
<<set $underwatertime += 1>>
<<if $underwatertime lte 5>>
You are underwater, and cannot speak.
<<elseif $underwatertime lte 10>>
<span class="blue">You are underwater, and cannot breathe.</span><<gstress>><<stress 2>>
<<elseif $underwatertime lte 15>>
<span class="purple">You are underwater, and cannot breathe.</span><<gstress>><<stress 4>>
<<elseif $underwatertime lte 20>>
<span class="pink">You are underwater, and cannot breathe.</span><<gtrauma>><<gstress>><<stress 8>><<trauma 2>>
<<else>>
<span class="red">You are suffocating beneath the water.</span><<set $pain += 20>><<gtrauma>><<gstress>><<stress 12>><<trauma 4>>
<br><br>
<</if>>
<</if>>
<<if $position is "wall">>
You are trapped in a $walltype with your posterior stuck out in the open.
<</if>>
<<effectspain>>
<<effectsorgasm>>
<<effectsdissociation>>
<<effectshandsclothes>>
<<if $leftaction is "leftgrab">><<set $leftaction to 0>><<set $leftactiondefault to "leftgrab">><<handskilluse>><<combatpromiscuity3>>
<<if (1000 - ($rng * 10) - ($enemytrust * 10) - $handskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>><<set $leftactiondefault to "leftwork">>
<<if $penis is 0>>
<<set $penis to "leftarm">><<set $leftarm to "penis">><<submission 1>><<handstat>><span class="lblue">You <<handtext>> grab <<his1>> penis with your left hand.</span>
<<elseif $penis2 is 0>>
<<set $penis2 to "leftarm">><<set $leftarm to "penis">><<submission 1>><<handstat>><span class="lblue">You <<handtext>> grab <<his2>> penis with your left hand.</span>
<<elseif $penis3 is 0>>
<<set $penis3 to "leftarm">><<set $leftarm to "penis">><<submission 1>><<handstat>><span class="lblue">You <<handtext>> grab <<his3>> penis with your left hand.</span>
<<elseif $penis4 is 0>>
<<set $penis4 to "leftarm">><<set $leftarm to "penis">><<submission 1>><<handstat>><span class="lblue">You <<handtext>> grab <<his4>> penis with your left hand.</span>
<<elseif $penis5 is 0>>
<<set $penis5 to "leftarm">><<set $leftarm to "penis">><<submission 1>><<handstat>><span class="lblue">You <<handtext>> grab <<his5>> penis with your left hand.</span>
<<elseif $penis6 is 0>>
<<set $penis6 to "leftarm">><<set $leftarm to "penis">><<submission 1>><<handstat>><span class="lblue">You <<handtext>> grab <<his6>> penis with your left hand.</span>
<</if>>
<<else>>You try to grab <<a>> penis with your left hand, but <<theowner>> moves it away.
<</if>>
<</if>>
<<if $rightaction is "rightgrab">><<set $rightaction to 0>><<set $rightactiondefault to "rightgrab">><<handskilluse>><<combatpromiscuity3>>
<<if (1000 - ($rng * 10) - ($enemytrust * 10) - $handskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>><<set $rightactiondefault to "rightwork">>
<<if $penis is 0>><<set $penis to "rightarm">><<set $rightarm to "penis">><<submission 1>><span class="lblue"><<handstat>>You <<handtext>> grab <<his1>> penis with your right hand.</span>
<<elseif $penis2 is 0>><<set $penis2 to "rightarm">><<set $rightarm to "penis">><<submission 1>><<handstat>><span class="lblue">You <<handtext>> grab <<his2>> penis with your right hand.</span>
<<elseif $penis3 is 0>><<set $penis3 to "rightarm">><<set $rightarm to "penis">><<submission 1>><<handstat>><span class="lblue">You <<handtext>> grab <<his3>> penis with your right hand.</span>
<<elseif $penis4 is 0>><<set $penis4 to "rightarm">><<set $rightarm to "penis">><<submission 1>><<handstat>><span class="lblue">You <<handtext>> grab <<his4>> penis with your right hand.</span>
<<elseif $penis5 is 0>><<set $penis5 to "rightarm">><<set $rightarm to "penis">><<submission 1>><<handstat>><span class="lblue">You <<handtext>> grab <<his5>> penis with your right hand.</span>
<<elseif $penis6 is 0>><<set $penis6 to "rightarm">><<set $rightarm to "penis">><<submission 1>><<handstat>><span class="lblue">You <<handtext>> grab <<his6>> penis with your right hand.</span>
<</if>>
<<else>>You try to grab <<a>> penis with your right hand, but <<theowner>> moves it away.
<</if>>
<</if>>
<<if $leftaction is "leftstroke" and $rightaction is "rightstroke">><<set $leftaction to 0>><<set $rightaction to 0>><<set $leftactiondefault to "leftstroke">><<set $rightactiondefault to "rightstroke">><<submission 2>><<actionspenisstroke>><<handskilluse>><<handskilluse>><</if>>
<<if $leftaction is "leftstroke">><<set $leftaction to 0>><<set $leftactiondefault to "leftstroke">><<submission 1>><<actionspenisstroke>><<handskilluse>>
<</if>>
<<if $rightaction is "rightstroke">><<set $rightaction to 0>><<set $rightactiondefault to "rightstroke">><<submission 1>><<actionspenisstroke>><<handskilluse>>
<</if>>
<<if $leftaction is "leftwork">><<set $leftaction to 0>><<set $leftactiondefault to "leftwork">><<handskilluse>>
<<if (1000 - ($rng * 10) - ($enemytrust * 10) - $handskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>><<submission 3>><<actionsshaftrub>>
<<else>><<set $leftactiondefault to "leftgrab">>
<<set $leftarm to 0>>
<<if $penis is "leftarm">>
<<set $penis to 0>><span class="blue">You try to rub <<his1>> shaft, but <<he>> moves away.</span>
<<elseif $penis2 is "leftarm">>
<<set $penis2 to 0>><span class="blue">You try to rub <<his2>> shaft, but <<he>> moves away.</span>
<<elseif $penis3 is "leftarm">>
<<set $penis3 to 0>><span class="blue">You try to rub <<his3>> shaft, but <<he>> moves away.</span>
<<elseif $penis4 is "leftarm">>
<<set $penis4 to 0>><span class="blue">You try to rub <<his4>> shaft, but <<he>> moves away.</span>
<<elseif $penis5 is "leftarm">>
<<set $penis5 to 0>><span class="blue">You try to rub <<his5>> shaft, but <<he>> moves away.</span>
<<elseif $penis6 is "leftarm">>
<<set $penis6 to 0>><span class="blue">You try to rub <<his6>> shaft, but <<he>> moves away.</span>
<</if>>
<</if>>
<</if>>
<<if $rightaction is "rightwork">><<set $rightction to 0>><<set $rightactiondefault to "rightwork">><<handskilluse>>
<<if (1000 - ($rng * 10) - ($enemytrust * 10) - $handskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>><<submission 3>><<actionsshaftrub>>
<<else>><<set $rightactiondefault to "rightgrab">>
<<set $rightarm to 0>>
<<if $penis is "rightarm">>
<<set $penis to 0>><span class="blue">You try to rub <<his1>> shaft, but <<he>> moves away.</span>
<<elseif $penis2 is "rightarm">>
<<set $penis2 to 0>><span class="blue">You try to rub <<his2>> shaft, but <<he>> moves away.</span>
<<elseif $penis3 is "rightarm">>
<<set $penis3 to 0>><span class="blue">You try to rub <<his3>> shaft, but <<he>> moves away.</span>
<<elseif $penis4 is "rightarm">>
<<set $penis4 to 0>><span class="blue">You try to rub <<his4>> shaft, but <<he>> moves away.</span>
<<elseif $penis5 is "rightarm">>
<<set $penis5 to 0>><span class="blue">You try to rub <<his5>> shaft, but <<he>> moves away.</span>
<<elseif $penis6 is "rightarm">>
<<set $penis6 to 0>><span class="blue">You try to rub <<his6>> shaft, but <<he>> moves away.</span>
<</if>>
<</if>>
<</if>>
<<if $leftaction is "leftstoppenis">><<set $leftaction to 0>><<set $leftactiondefault to "leftstoppenis">><<submission 3>><<set $leftarm to 0>>
<<if $penis is "leftarm">>
<<set $penis to 0>>You let go of <<his1>> penis.
<<elseif $penis2 is "leftarm">>
<<set $penis2 to 0>>You let go of <<his2>> penis.
<<elseif $penis3 is "leftarm">>
<<set $penis3 to 0>>You let go of <<his3>> penis.
<<elseif $penis4 is "leftarm">>
<<set $penis4 to 0>>You let go of <<his4>> penis.
<<elseif $penis5 is "leftarm">>
<<set $penis5 to 0>>You let go of <<his5>> penis.
<<elseif $penis6 is "leftarm">>
<<set $penis6 to 0>>You let go of <<his6>> penis.
<</if>>
<</if>>
<<if $rightaction is "rightstoppenis">><<set $rightaction to 0>><<set $rightactiondefault to "rightstoppenis">><<submission 3>><<set $rightarm to 0>>
<<if $penis is "rightarm">>
<<set $penis to 0>>You let go of <<his1>> penis.
<<elseif $penis2 is "rightarm">>
<<set $penis2 to 0>>You let go of <<his2>> penis.
<<elseif $penis3 is "rightarm">>
<<set $penis3 to 0>>You let go of <<his3>> penis.
<<elseif $penis4 is "rightarm">>
<<set $penis4 to 0>>You let go of <<his4>> penis.
<<elseif $penis5 is "rightarm">>
<<set $penis5 to 0>>You let go of <<his5>> penis.
<<elseif $penis6 is "rightarm">>
<<set $penis6 to 0>>You let go of <<his6>> penis.
<</if>>
<</if>>
<<if $leftaction is "leftstruggle" and $rightaction is "rightstruggle">><<set $leftaction to 0>><<set $rightaction to 0>><<set $leftactiondefault to "leftstruggle">><<set $rightactiondefault to "rightstruggle">>You struggle with all your might.<<defiance 2>><<set $speechstruggle to 1>>
<</if>>
<<if $leftaction is "leftstruggle">><<set $leftaction to 0>><<set $leftactiondefault to "leftstruggle">>You struggle.<<set $speechstruggle to 1>><<defiance 1>>
<</if>>
<<if $rightaction is "rightstruggle">><<set $rightaction to 0>><<set $rightactiondefault to "rightstruggle">>You struggle.<<defiance 1>><<set $speechstruggle to 1>>
<</if>>
<<if $leftaction is "rest" and $rightaction is "rest">><<set $leftaction to 0>><<set $rightaction to 0>><<set $leftactiondefault to "rest">><<set $rightactiondefault to "rest">>You don't resist the force binding your arms.
<</if>>
<<if $leftaction is "rest">><<set $leftaction to 0>><<set $leftactiondefault to "rest">>You rest your left arm.
<</if>>
<<if $rightaction is "rest">><<set $rightaction to 0>><<set $rightactiondefault to "rest">>You rest your right arm.
<</if>>
<<if $leftaction is "leftchest" and $rightaction is "rightchest">><<set $leftaction to 0>><<set $rightaction to 0>><<set $leftactiondefault to "leftchest">><<set $rightactiondefault to "rightchest">><<actionsstroke>><<submission 2>>
<</if>>
<<if $leftaction is "leftchest">><<set $leftaction to 0>><<set $leftactiondefault to "leftchest">><<actionsstroke>><<submission 1>>
<</if>>
<<if $rightaction is "rightchest">><<set $rightaction to 0>><<set $rightactiondefault to "rightchest">><<actionsstroke>><<submission 1>>
<</if>>
<<if $leftaction is "lefthit" and $rightaction is "righthit">><<set $leftaction to 0>><<set $rightaction to 0>><<set $leftactiondefault to "lefthit">><<set $rightactiondefault to "righthit">><<defiance 5>><<actionshit>><<set $speechhit to 1>><<set $attackstat += 2>>
<</if>>
<<if $leftaction is "lefthit">><<set $leftaction to 0>><<set $leftactiondefault to "lefthit">><<actionshit>><<defiance 2>><<set $speechhit to 1>><<set $attackstat += 1>>
<</if>>
<<if $rightaction is "righthit">><<set $rightaction to 0>><<set $rightactiondefault to "righthit">><<actionshit>><<set $speechhit to 1>><<defiance 2>><<set $attackstat += 1>>
<</if>>
<<if $leftaction is "leftcoverface" and $rightaction is "rightcoverface">><<set $leftaction to 0>><<set $rightaction to 0>><<set $leftactiondefault to "leftcoverface">><<set $rightactiondefault to "rightcoverface">>You cover your face with your hands.<<set $speechcoverface to 1>><<set $face to "covered">><<neutral 2>>
<<elseif $leftaction is "leftcoverface">><<set $leftaction to 0>><<set $leftactiondefault to "leftcoverface">>You cover your face with your hand.<<set $speechcoverface to 1>><<set $face to "covered">><<neutral 1>>
<<elseif $rightaction is "rightcoverface">><<set $rightaction to 0>><<set $rightactiondefault to "rightcoverface">>You cover your face with your hand.<<set $speechcoverface to 1>><<set $face to "covered">><<neutral 1>>
<</if>>
<<if $leftaction is "leftcovervagina" and $rightaction is "rightcovervagina">><<set $leftaction to 0>><<set $rightaction to 0>><<set $leftactiondefault to "leftcovervagina">><<set $rightactiondefault to "rightcovervagina">>You cover your pussy with your hands.<<brat 2>><<set $leftarm to "vagina">><<set $rightarm to "vagina">><<set $vaginause to "cover">><<set $speechcovervagina to 1>>
<</if>>
<<if $leftaction is "leftcovervagina">><<set $leftaction to 0>><<set $leftactiondefault to "leftcovervagina">>You cover your pussy with your hand.<<brat 1>><<set $leftarm to "vagina">><<set $vaginause to "cover">><<set $speechcovervagina to 1>>
<</if>>
<<if $rightaction is "rightcovervagina">><<set $rightaction to 0>><<set $rightactiondefault to "rightcovervagina">>You cover your pussy with your hand.<<brat 1>><<set $rightarm to "vagina">><<set $vaginause to "cover">><<set $speechcovervagina to 1>>
<</if>>
<<if $leftaction is "leftcoverpenis" and $rightaction is "rightcoverpenis">><<set $leftaction to 0>><<set $rightaction to 0>><<set $leftactiondefault to "leftcoverpenis">><<set $rightactiondefault to "rightcoverpenis">>You cover your penis with your hands.<<brat 2>><<set $leftarm to "coverpenis">><<set $rightarm to "coverpenis">><<set $penisuse to "cover">><<set $speechcoverpenis to 1>>
<</if>>
<<if $leftaction is "leftcoverpenis">><<set $leftaction to 0>><<set $leftactiondefault to "leftcoverpenis">>You cover your penis with your hand.<<brat 1>><<set $leftarm to "coverpenis">><<set $penisuse to "cover">><<set $speechcoverpenis to 1>>
<</if>>
<<if $rightaction is "rightcoverpenis">><<set $rightaction to 0>><<set $rightactiondefault to "rightcoverpenis">>You cover your penis with your hand.<<brat 1>><<set $rightarm to "coverpenis">><<set $penisuse to "cover">><<set $speechcoverpenis to 1>>
<</if>>
<<if $leftaction is "leftcoveranus" and $rightaction is "rightcoveranus">><<set $leftaction to 0>><<set $rightaction to 0>><<set $leftactiondefault to "leftcoveranus">><<set $rightactiondefault to "rightcoveranus">>You cover your anus with your hands.<<brat 2>><<set $leftarm to "anus">><<set $rightarm to "anus">><<set $anususe to "cover">>
<</if>>
<<if $leftaction is "leftcoveranus">><<set $leftaction to 0>><<set $leftactiondefault to "leftcoveranus">>You cover your anus with your hand.<<brat 1>><<set $leftarm to "anus">><<set $anususe to "cover">>
<</if>>
<<if $rightaction is "rightcoveranus">><<set $rightanus to 0>><<set $rightactiondefault to "rightcoveranus">>You cover your anus with your hand.<<brat 1>><<set $rightarm to "anus">><<set $anususe to "cover">>
<</if>>
<<if $leftaction is "leftstopvagina" and $rightaction is "rightstopvagina">><<set $leftaction to 0>><<set $rightaction to 0>><<set $leftactiondefault to "leftstopvagina">><<set $rightactiondefault to "rightstopvagina">>You stop shielding your pussy with your hands.<<set $leftarm to 0>><<set $rightarm to 0>><<set $vaginause to 0>><<meek 2>>
<</if>>
<<if $leftaction is "leftstopcoverpenis" and $rightaction is "rightstopcoverpenis">><<set $leftaction to 0>><<set $rightaction to 0>><<set $leftactiondefault to "leftstopcoverpenis">><<set $rightactiondefault to "rightstopcoverpenis">>You stop shielding your penis with your hands.<<set $leftarm to 0>><<set $rightarm to 0>><<set $penisuse to 0>><<meek 2>>
<</if>>
<<if $leftaction is "leftstopanus" and $rightaction is "rightstopanus">><<set $leftaction to 0>><<set $rightaction to 0>><<set $leftactiondefault to "leftstopanus">><<set $rightactiondefault to "rightstopanus">>You stop shielding your <<bottom>> with your hands.<<set $leftarm to 0>><<set $rightarm to 0>><<set $anususe to 0>><<meek 2>>
<</if>>
<<if $leftaction is "leftstopvagina">><<set $leftaction to 0>>
<<set $leftactiondefault to "leftstopvagina">>You stop covering your pussy with your left hand.<<set $leftarm to 0>>
<<if $rightarm isnot "vagina">>
<<set $vaginause to 0>>
<</if>><<meek 1>>
<</if>>
<<if $leftaction is "leftstopcoverpenis">><<set $leftaction to 0>><<set $leftactiondefault to "leftstopcoverpenis">>You stop covering your penis with your left hand.<<set $leftarm to 0>> <<if $rightarm isnot "coverpenis">>
<<set $penisuse to 0>>
<</if>><<meek 1>>
<</if>>
<<if $leftaction is "leftstopanus">><<set $leftaction to 0>><<set $leftactiondefault to "leftstopanus">>
You stop covering your <<bottom>> with your left hand.<<set $leftarm to 0>>
<<if $rightarm isnot "anus">>
<<set $anususe to 0>>
<</if>>
<<meek 1>>
<</if>>
<<if $rightaction is "rightstopvagina">><<set $rightaction to 0>><<set $rightactiondefault to "rightstopvagina">>
You stop covering your vagina with your right hand.<<set $rightarm to 0>>
<<if $leftarm isnot "vagina">>
<<set $vaginause to 0>>
<</if>><<meek 1>>
<</if>>
<<if $rightaction is "rightstopcoverpenis">><<set $rightaction to 0>><<set $rightactiondefault to "rightstopcoverpenis">>
You stop covering your penis with your right hand.<<set $rightarm to 0>>
<<if $leftarm isnot "coverpenis">>
<<set $penisuse to 0>>
<</if>><<meek 1>>
<</if>>
<<if $rightaction is "rightstopanus">><<set $rightaction to 0>><<set $rightactiondefault to "rightstopanus">>
You stop covering you anus with your right hand.<<set $rightarm to 0>>
<<if $leftarm isnot "anus">>
<<set $anususe to 0>>
<</if>><<meek 1>>
<</if>>
<<if $leftaction is "leftclit">><<set $leftaction to 0>><<set $leftactiondefault to "leftclit">><<handskilluse>>
<<if (1000 - ($rng * 10) - ($enemytrust * 10) - $handskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<<actionsclitstroke>><<submission 10>>
<<else>><<set $leftarm to 0>><<set $leftactiondefault to "leftplay">>
<<if $vagina is "leftarm">>
<<set $vagina to 0>><span class="blue">You stroke <<his1>> clit, but <<he>> slaps your hand away.</span>
<<elseif $vagina2 is "leftarm">>
<<set $vagina2 to 0>><span class="blue">You stroke <<his2>> clit, but <<he>> slaps your hand away.</span>
<<elseif $vagina3 is "leftarm">>
<<set $vagina3 to 0>><span class="blue">You stroke <<his3>> clit, but <<he>> slaps your hand away.</span>
<<elseif $vagina4 is "leftarm">>
<<set $vagina4 to 0>><span class="blue">You stroke <<his4>> clit, but <<he>> slaps your hand away.</span>
<<elseif $vagina5 is "leftarm">>
<<set $vagina5 to 0>><span class="blue">You stroke <<his5>> clit, but <<he>> slaps your hand away.</span>
<<elseif $vagina6 is "leftarm">>
<<set $vagina6 to 0>><span class="blue">You stroke <<his6>> clit, but <<he>> slaps your hand away.</span>
<</if>>
<</if>>
<</if>>
<<if $rightaction is "rightclit">><<set $rightaction to 0>><<set $rightactiondefault to "rightclit">><<handskilluse>>
<<if (1000 - ($rng * 10) - ($enemytrust * 10) - $handskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<<actionsclitstroke>><<submission 10>>
<<else>><span class="blue">You stroke <<his>> clit, but <<he>> slaps your hand away.</span><<set $rightarm to 0>><<set $rightactiondefault to "rightplay">>
<<if $vagina is "rightarm">>
<<set $vagina to 0>><span class="blue">You stroke <<his1>> clit, but <<he>> slaps your hand away.</span>
<<elseif $vagina2 is "rightarm">>
<<set $vagina2 to 0>><span class="blue">You stroke <<his2>> clit, but <<he>> slaps your hand away.</span>
<<elseif $vagina3 is "rightarm">>
<<set $vagina3 to 0>><span class="blue">You stroke <<his3>> clit, but <<he>> slaps your hand away.</span>
<<elseif $vagina4 is "rightarm">>
<<set $vagina4 to 0>><span class="blue">You stroke <<his4>> clit, but <<he>> slaps your hand away.</span>
<<elseif $vagina5 is "rightarm">>
<<set $vagina5 to 0>><span class="blue">You stroke <<his5>> clit, but <<he>> slaps your hand away.</span>
<<elseif $vagina6 is "rightarm">>
<<set $vagina6 to 0>><span class="blue">You stroke <<his6>> clit, but <<he>> slaps your hand away.</span>
<</if>>
<</if>>
<</if>>
<<if $leftaction is "leftothervaginastop" and $rightaction is "rightothervaginastop">><<set $leftaction to 0>><<set $rightaction to 0>><<set $leftactiondefault to "leftothervaginastop">><<set $rightactiondefault to "rightothervaginastop">>
<<if $vagina is "leftarm">><<set $vagina to 0>><<set $leftarm to 0>><span class="blue">You move your hands away from <<his1>> pussy.</span>
<<elseif $vagina2 is "leftarm">><<set $vagina2 to 0>><<set $leftarm to 0>><span class="blue">You move your hands away from <<his2>> pussy.</span>
<<elseif $vagina3 is "leftarm">><<set $vagina3 to 0>><<set $leftarm to 0>><span class="blue">You move your hands away from <<his3>> pussy.</span>
<<elseif $vagina4 is "leftarm">><<set $vagina4 to 0>><<set $leftarm to 0>><span class="blue">You move your hands away from <<his4>> pussy.</span>
<<elseif $vagina5 is "leftarm">><<set $vagina5 to 0>><<set $leftarm to 0>><span class="blue">You move your hands away from <<his5>> pussy.</span>
<<elseif $vagina6 is "leftarm">><<set $vagina6 to 0>><<set $leftarm to 0>><span class="blue">You move your hands away from <<his6>> pussy.</span>
<</if>>and
<<if $vagina is "rightarm">><<set $vagina to 0>><<set $rightarm to 0>><span class="blue"><<his1>> pussy.</span>
<<elseif $vagina2 is "rightarm">><<set $vagina2 to 0>><<set $rightarm to 0>><span class="blue"><<his2>> pussy.</span>
<<elseif $vagina3 is "rightarm">><<set $vagina3 to 0>><<set $rightarm to 0>><span class="blue"><<his3>> pussy.</span>
<<elseif $vagina4 is "rightarm">><<set $vagina4 to 0>><<set $rightarm to 0>><span class="blue"><<his4>> pussy.</span>
<<elseif $vagina5 is "rightarm">><<set $vagina5 to 0>><<set $rightarm to 0>><span class="blue"><<his5>> pussy.</span>
<<elseif $vagina6 is "rightarm">><<set $vagina6 to 0>><<set $rightarm to 0>><span class="blue"><<his6>> pussy.</span>
<</if>>
<</if>>
<<if $leftaction is "leftothervaginastop">><<set $leftaction to 0>><<set $leftactiondefault to "leftothervaginastop">>
<<if $vagina is "leftarm">><<set $vagina to 0>><<set $leftarm to 0>><span class="blue">You move your hand away from <<his1>> pussy.</span>
<<elseif $vagina2 is "leftarm">><<set $vagina2 to 0>><<set $leftarm to 0>><span class="blue">You move your hand away from <<his2>> pussy.</span>
<<elseif $vagina3 is "leftarm">><<set $vagina3 to 0>><<set $leftarm to 0>><span class="blue">You move your hand away from <<his3>> pussy.</span>
<<elseif $vagina4 is "leftarm">><<set $vagina4 to 0>><<set $leftarm to 0>><span class="blue">You move your hand away from <<his4>> pussy.</span>
<<elseif $vagina5 is "leftarm">><<set $vagina5 to 0>><<set $leftarm to 0>><span class="blue">You move your hand away from <<his5>> pussy.</span>
<<elseif $vagina6 is "leftarm">><<set $vagina6 to 0>><<set $leftarm to 0>><span class="blue">You move your hand away from <<his6>> pussy.</span>
<</if>>
<</if>>
<<if $rightaction is "rightothervaginastop">><<set $rightaction to 0>><<set $rightactiondefault to "rightothervaginastop">>
<<if $vagina is "rightarm">><<set $vagina to 0>><<set $rightarm to 0>><span class="blue">You move your hand away from <<his1>> pussy.</span>
<<elseif $vagina2 is "rightarm">><<set $vagina2 to 0>><<set $rightarm to 0>><span class="blue">You move your hand away from <<his2>> pussy.</span>
<<elseif $vagina3 is "rightarm">><<set $vagina3 to 0>><<set $rightarm to 0>><span class="blue">You move your hand away from <<his3>> pussy.</span>
<<elseif $vagina4 is "rightarm">><<set $vagina4 to 0>><<set $rightarm to 0>><span class="blue">You move your hand away from <<his4>> pussy.</span>
<<elseif $vagina5 is "rightarm">><<set $vagina5 to 0>><<set $rightarm to 0>><span class="blue">You move your hand away from <<his5>> pussy.</span>
<<elseif $vagina6 is "rightarm">><<set $vagina6 to 0>><<set $rightarm to 0>><span class="blue">You move your hand away from <<his6>> pussy.</span>
<</if>>
<</if>>
<<if $leftaction is "leftplay">><<set $leftaction to 0>><<handskilluse>><<set $leftactiondefault to "leftplay">><<combatpromiscuity3>>
<<if (1000 - ($rng * 10) - ($enemytrust * 10) - $handskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>><<set $leftactiondefault to "leftclit">>
<<if $vagina is 0>>
<<set $vagina to "leftarm">><<set $leftarm to "othervagina">><<submission 1>><<handstat>><span class="lblue">You <<handtext>> grab <<his1>> pussy with your left hand.</span>
<<elseif $vagina2 is 0>>
<<set $vagina2 to "leftarm">><<set $leftarm to "othervagina">><<submission 1>><<handstat>><span class="lblue">You <<handtext>> grab <<his2>> pussy with your left hand.</span>
<<elseif $vagina3 is 0>>
<<set $vagina3 to "leftarm">><<set $leftarm to "othervagina">><<submission 1>><<handstat>><span class="lblue">You <<handtext>> grab <<his3>> pussy with your left hand.</span>
<<elseif $vagina4 is 0>>
<<set $vagina4 to "leftarm">><<set $leftarm to "othervagina">><<submission 1>><<handstat>><span class="lblue">You <<handtext>> grab <<his4>> pussy with your left hand.</span>
<<elseif $vagina5 is 0>>
<<set $vagina5 to "leftarm">><<set $leftarm to "othervagina">><<submission 1>><<handstat>><span class="lblue">You <<handtext>> grab <<his5>> pussy with your left hand.</span>
<<elseif $vagina6 is 0>>
<<set $vagina6 to "leftarm">><<set $leftarm to "othervagina">><<submission 1>><<handstat>><span class="lblue">You <<handtext>> grab <<his6>> pussy with your left hand.</span>
<</if>>
<<else>>You try to grab <<a>> pussy with your left hand, but <<theowner>> moves it away.
<</if>>
<</if>>
<<if $rightaction is "rightplay">><<set $rightaction to 0>><<handskilluse>><<set $rightactiondefault to "rightplay">><<combatpromiscuity3>>
<<if (1000 - ($rng * 10) - ($enemytrust * 10) - $handskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>><<set $rightactiondefault to "rightclit">>
<<if $vagina is 0>>
<<set $vagina to "rightarm">><<set $rightarm to "othervagina">><<submission 1>><<handstat>><span class="lblue">You <<handtext>> grab <<his1>> pussy with your right hand.</span>
<<elseif $vagina2 is 0>>
<<set $vagina2 to "rightarm">><<set $rightarm to "othervagina">><<submission 1>><<handstat>><span class="lblue">You <<handtext>> grab <<his2>> pussy with your right hand.</span>
<<elseif $vagina3 is 0>>
<<set $vagina3 to "rightarm">><<set $rightarm to "othervagina">><<submission 1>><<handstat>><span class="lblue">You <<handtext>> grab <<his3>> pussy with your right hand.</span>
<<elseif $vagina4 is 0>>
<<set $vagina4 to "rightarm">><<set $rightarm to "othervagina">><<submission 1>><<handstat>><span class="lblue">You <<handtext>> grab <<his4>> pussy with your right hand.</span>
<<elseif $vagina5 is 0>>
<<set $vagina5 to "rightarm">><<set $rightarm to "othervagina">><<submission 1>><<handstat>><span class="lblue">You <<handtext>> grab <<his5>> pussy with your right hand.</span>
<<elseif $vagina6 is 0>>
<<set $vagina6 to "rightarm">><<set $rightarm to "othervagina">><<submission 1>><<handstat>><span class="lblue">You <<handtext>> grab <<his6>> pussy with your right hand.</span>
<</if>>
<<else>>You try to grab <<a>> pussy with your right hand, but the owner moves it away.
<</if>>
<</if>>
<<if $leftaction is "leftunderpull" and $rightaction is "rightunderpull">><<set $leftaction to 0>><<set $rightaction to 0>><<brat 1>><<set $leftactiondefault to "leftunderpull">><<set $rightactiondefault to "rightunderpull">>
<<if $underclothes is "naked">>
You clutch the tattered remains of your $underlast.<<brat 2>>
<<else>>
<<if $lefthand is "underclothes">>You struggle with <<him>> for control of your $underclothes.<<brat 2>><<set $understruggle to 1>>
<<elseif $righthand is "underclothes">>You struggle for control of your $underclothes.<<brat 2>><<set $understruggle to 1>>
<<elseif $lefthand2 is "underclothes">>You struggle for control of your $underclothes.<<brat 2>><<set $understruggle to 1>>
<<elseif $righthand2 is "underclothes">>You struggle for control of your $underclothes.<<brat 2>><<set $understruggle to 1>>
<<elseif $lefthand3 is "underclothes">>You struggle for control of your $underclothes.<<brat 2>><<set $understruggle to 1>>
<<elseif $righthand3 is "underclothes">>You struggle for control of your $underclothes.<<brat 2>><<set $understruggle to 1>>
<<elseif $lefthand4 is "underclothes">>You struggle for control of your $underclothes.<<brat 2>><<set $understruggle to 1>>
<<elseif $righthand4 is "underclothes">>You struggle for control of your $underclothes.<<brat 2>><<set $understruggle to 1>>
<<elseif $lefthand5 is "underclothes">>You struggle for control of your $underclothes.<<brat 2>><<set $understruggle to 1>>
<<elseif $righthand5 is "underclothes">>You struggle for control of your $underclothes.<<brat 2>><<set $understruggle to 1>>
<<elseif $lefthand6 is "underclothes">>You struggle for control of your $underclothes.<<brat 2>><<set $understruggle to 1>>
<<elseif $righthand6 is "underclothes">>You struggle for control of your $underclothes.<<brat 2>><<set $understruggle to 1>>
<<elseif $mouth is "underclothes">>
You struggle for control of your $underclothes.<<brat 2>><<set $understruggle to 1>>
<<else>>
<<if $understate is "ankles">><<set $understate to "knees">>You pull your $underclothes up to your knees.
<<elseif $understate is "knees">><<set $understate to "thighs">>You pull your $underclothes up to your thighs.
<<elseif $understate is "thighs">>
<<if $vaginause is 0 and $anususe is 0>>You pull your $underclothes up to your waist.<<set $understate to "waist">><<set $underexposed to $underexposedbase>><<set $undervaginaexposed to $undervaginaexposedbase>><<set $underanusexposed to $underanusexposedbase>>
<<else>>
You try to pull up your $underclothes, but something is in the way.
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<if $leftaction is "leftunderpull">><<set $leftaction to 0>><<brat 1>><<set $leftactiondefault to "leftunderpull">>
<<if $underclothes is "naked">>
You clutch the tattered remains of your $underlast.
<<else>>
<<if $lefthand isnot "underclothes" and $righthand isnot "underclothes" and $lefthand2 isnot "underclothes" and $righthand2 isnot "underclothes" and $lefthand3 isnot "underclothes" and $righthand3 isnot "underclothes" and $lefthand4 isnot "underclothes" and $righthand4 isnot "underclothes" and $lefthand5 isnot "underclothes" and $righthand5 isnot "underclothes" and $lefthand6 isnot "underclothes" and $righthand6 isnot "underclothes" and $mouth isnot "underclothes">>
<<if $understate is "ankles">><<set $understate to "knees">>You pull your $underclothes up to your knees.
<<elseif $understate is "knees">><<set $understate to "thighs">>You pull your $underclothes up to your thighs.
<<elseif $understate is "thighs">>
<<if $vaginause is 0 and $anususe is 0>>You pull your $underclothes up to your waist.<<set $understate to "waist">><<set $underexposed to $underexposedbase>><<set $undervaginaexposed to $undervaginaexposedbase>><<set $underanusexposed to $underanusexposedbase>>
<<else>>
You try to pull up your $underclothes, but something is in the way.
<</if>>
<</if>>
<<else>>
You try to pull up your $underclothes, but one hand won't be enough.<<brat 1>>
<</if>>
<</if>>
<</if>>
<<if $rightaction is "rightunderpull">><<set $rightaction to 0>><<brat 1>><<set $rightactiondefault to "rightunderpull">>
<<if $underclothes is "naked">>
You clutch the tattered remains of your $underlast.
<<else>>
<<if $lefthand isnot "underclothes" and $righthand isnot "underclothes" and $lefthand2 isnot "underclothes" and $righthand2 isnot "underclothes" and $lefthand3 isnot "underclothes" and $righthand3 isnot "underclothes" and $lefthand4 isnot "underclothes" and $righthand4 isnot "underclothes" and $lefthand5 isnot "underclothes" and $righthand5 isnot "underclothes" and $lefthand6 isnot "underclothes" and $righthand6 isnot "underclothes" and $mouth isnot "underclothes">>
<<if $understate is "ankles">><<set $understate to "knees">>You pull your $underclothes up to your knees.
<<elseif $understate is "knees">><<set $understate to "thighs">>You pull your $underclothes up to your thighs.
<<elseif $understate is "thighs">>
<<if $vaginause is 0 and $anususe is 0>>You pull your $underclothes up to your waist.<<set $understate to "waist">><<set $underexposed to $underexposedbase>><<set $undervaginaexposed to $undervaginaexposedbase>><<set $underanusexposed to $underanusexposedbase>>
<<else>>
You try to pull up your $underclothes, but one hand won't be enough.
<</if>>
<</if>>
<<else>>
You try to pull up your $underclothes, but you aren't strong enough.<<brat 1>>
<</if>>
<</if>>
<</if>>
<<if $leftaction is "leftskirtpull" and $rightaction is "rightskirtpull">><<set $leftaction to 0>><<set $rightaction to 0>><<set $leftactiondefault to "leftskirtpull">><<set $rightactiondefault to "rightskirtpull">><<brat 1>>
<<if $lowerclothes is "naked">>
You clutch the tattered remains of your $lowerlast.
<<else>>
You pull your $lowerclothes down with both hands, covering your crotch.<<set $skirtdown to 1>><<set $lowervaginaexposed to $lowervaginaexposedbase>><<set $loweranusexposed to $loweranusexposedbase>><<set $lowerexposed to $lowerexposedbase>>
<</if>>
<</if>>
<<if $leftaction is "leftskirtpull">><<set $leftaction to 0>><<set $leftactiondefault to "leftskirtpull">><<brat 1>>
<<if $lowerclothes is "naked">>
You clutch the tattered remains of your $lowerlast.
<<else>>
You pull your $lowerclothes back down, covering your crotch.<<set $skirtdown to 1>><<set $lowervaginaexposed to $lowervaginaexposedbase>><<set $loweranusexposed to $loweranusexposedbase>><<set $lowerexposed to $lowerexposedbase>>
<</if>>
<</if>>
<<if $rightaction is "rightskirtpull">><<set $rightaction to 0>><<set $rightactiondefault to "rightskirtpull">><<brat 1>>
<<if $lowerclothes is "naked">>
You clutch the tattered remains of your $lowerlast.
<<else>>
You pull your $lowerclothes back down, covering your crotch.<<set $skirtdown to 1>><<set $lowervaginaexposed to $lowervaginaexposedbase>><<set $loweranusexposed to $loweranusexposedbase>><<set $lowerexposed to $lowerexposedbase>>
<</if>>
<</if>>
<<if $leftaction is "leftlowerpull" and $rightaction is "rightlowerpull">><<set $leftaction to 0>><<set $rightaction to 0>><<brat 1>><<set $leftactiondefault to "leftlowerpull">><<set $rightactiondefault to "rightlowerpull">>
<<if $lowerclothes is "naked">>
You clutch the tattered remains of your $lowerlast.<<brat 2>>
<<else>>
<<if $lefthand is "lowerclothes">>You struggle for control of your $lowerclothes.<<brat 2>><<set $lowerstruggle to 1>>
<<elseif $righthand is "lowerclothes">>You struggle for control of your $lowerclothes.<<brat 2>><<set $lowerstruggle to 1>>
<<elseif $lefthand2 is "lowerclothes">>You struggle for control of your $lowerclothes.<<brat 2>><<set $lowerstruggle to 1>>
<<elseif $righthand2 is "lowerclothes">>You struggle for control of your $lowerclothes.<<brat 2>><<set $lowerstruggle to 1>>
<<elseif $lefthand3 is "lowerclothes">>You struggle for control of your $lowerclothes.<<brat 2>><<set $lowerstruggle to 1>>
<<elseif $righthand4 is "lowerclothes">>You struggle for control of your $lowerclothes.<<brat 2>><<set $lowerstruggle to 1>>
<<elseif $lefthand5 is "lowerclothes">>You struggle for control of your $lowerclothes.<<brat 2>><<set $lowerstruggle to 1>>
<<elseif $righthand5 is "lowerclothes">>You struggle for control of your $lowerclothes.<<brat 2>><<set $lowerstruggle to 1>>
<<elseif $lefthand6 is "lowerclothes">>You struggle for control of your $lowerclothes.<<brat 2>><<set $lowerstruggle to 1>>
<<elseif $righthand6 is "lowerclothes">>You struggle for control of your $lowerclothes.<<brat 2>><<set $lowerstruggle to 1>>
<<elseif $mouth is "lowerclothes">>
You struggle for control of your $lowerclothes.<<brat 2>><<set $lowerstruggle to 1>>
<<else>>
<<if $vaginause isnot 0 and $vaginause isnot "none">>
Your $lowerclothes hang loosely, but you can't adjust <<lowerit>> while your <<pussy>> is threatened.
<<elseif $penisuse isnot 0 and $penisuse isnot "none">>
Your $lowerclothes hang loosely, but you can't adjust <<lowerit>> while your <<penis>> is threatened.
<<elseif $anususe isnot 0>>
Your $lowerclothes hang loosely, but you can't adjust <<lowerit>> while your <<bottom>> is threatened.
<<else>>
You fix your $lowerclothes, concealing your
<<if $underexposed gte 1>>
<<genitalsstop>>
<<else>>
$underclothes.
<</if>>
<<brat 5>><<set $lowerstate to $lowerstatebase>><<if $skirt is 1>><<set $skirtdown to 1>><</if>><<set $lowervaginaexposed to $lowervaginaexposedbase>><<set $loweranusexposed to $loweranusexposedbase>><<set $lowerexposed to $lowerexposedbase>>
<</if>>
<</if>>
<</if>>
<</if>>
<<if $leftaction is "leftlowerpull">><<set $leftaction to 0>><<brat 1>><<set $leftactiondefault to "leftlowerpull">>
<<if $lowerclothes is "naked">>
You clutch the tattered remains of your $lowerlast.<<brat 1>>
<<else>>
<<if $lefthand is "lowerclothes">>You try to pull up your $lowerclothes, but you aren't strong enough.<<brat 1>>
<<elseif $righthand is "lowerclothes">>You try to pull up your $lowerclothes, but you aren't strong enough.<<brat 1>>
<<elseif $lefthand2 is "lowerclothes">>You try to pull up your $lowerclothes, but you aren't strong enough.<<brat 1>>
<<elseif $righthand3 is "lowerclothes">>You try to pull up your $lowerclothes, but you aren't strong enough.<<brat 1>>
<<elseif $lefthand3 is "lowerclothes">>You try to pull up your $lowerclothes, but you aren't strong enough.<<brat 1>>
<<elseif $righthand3 is "lowerclothes">>You try to pull up your $lowerclothes, but you aren't strong enough.<<brat 1>>
<<elseif $lefthand4 is "lowerclothes">>You try to pull up your $lowerclothes, but you aren't strong enough.<<brat 1>>
<<elseif $righthand4 is "lowerclothes">>You try to pull up your $lowerclothes, but you aren't strong enough.<<brat 1>>
<<elseif $lefthand5 is "lowerclothes">>You try to pull up your $lowerclothes, but you aren't strong enough.<<brat 1>>
<<elseif $righthand5 is "lowerclothes">>You try to pull up your $lowerclothes, but you aren't strong enough.<<brat 1>>
<<elseif $lefthand6 is "lowerclothes">>You try to pull up your $lowerclothes, but you aren't strong enough.<<brat 1>>
<<elseif $righthand6 is "lowerclothes">>You try to pull up your $lowerclothes, but you aren't strong enough.<<brat 1>>
<<elseif $mouth is "lowerclothes">>
You try to pull up your $lowerclothes, but you aren't strong enough.<<brat 1>>
<<else>>
<<if $vaginause isnot 0 and $vaginause isnot "none">>
Your $lowerclothes hang loosely, but you can't adjust <<lowerit>> while your <<pussy>> is threatened.
<<elseif $penisuse isnot 0 and $penisuse isnot "none">>
Your $lowerclothes hang loosely, but you can't adjust <<lowerit>> while your <<penis>> is threatened.
<<elseif $anususe isnot 0>>
Your $lowerclothes hang loosely, but you can't adjust <<lowerit>> while your <<bottom>> is threatened.
<<else>>
You fix your $lowerclothes, concealing your
<<if $underexposed gte 1>>
<<genitalsstop>>
<<else>>
$underclothes.
<</if>>
<<brat 5>><<set $lowerstate to $lowerstatebase>><<if $skirt is 1>><<set $skirtdown to 1>><</if>><<set $lowervaginaexposed to $lowervaginaexposedbase>><<set $loweranusexposed to $loweranusexposedbase>><<set $lowerexposed to $lowerexposedbase>>
<</if>>
<</if>>
<</if>>
<</if>>
<<if $rightaction is "rightlowerpull">><<set $rightaction to 0>><<brat 1>><<set $rightactiondefault to "rightlowerpull">>
<<if $lowerclothes is "naked">>
You clutch the tattered remains of your $lowerlast.
<<else>>
<<if $lefthand is "lowerclothes">>You try to pull up your $lowerclothes, but you aren't strong enough.<<brat 1>>
<<elseif $righthand is "lowerclothes">>You try to pull up your $lowerclothes, but you aren't strong enough.<<brat 1>>
<<elseif $lefthand2 is "lowerclothes">>You try to pull up your $lowerclothes, but you aren't strong enough.<<brat 1>>
<<elseif $righthand2 is "lowerclothes">>You try to pull up your $lowerclothes, but you aren't strong enough.<<brat 1>>
<<elseif $lefthand3 is "lowerclothes">>You try to pull up your $lowerclothes, but you aren't strong enough.<<brat 1>>
<<elseif $righthand3 is "lowerclothes">>You try to pull up your $lowerclothes, but you aren't strong enough.<<brat 1>>
<<elseif $lefthand4 is "lowerclothes">>You try to pull up your $lowerclothes, but you aren't strong enough.<<brat 1>>
<<elseif $righthand4 is "lowerclothes">>You try to pull up your $lowerclothes, but you aren't strong enough.<<brat 1>>
<<elseif $lefthand5 is "lowerclothes">>You try to pull up your $lowerclothes, but you aren't strong enough.<<brat 1>>
<<elseif $righthand5 is "lowerclothes">>You try to pull up your $lowerclothes, but you aren't strong enough.<<brat 1>>
<<elseif $lefthand6 is "lowerclothes">>You try to pull up your $lowerclothes, but you aren't strong enough.<<brat 1>>
<<elseif $righthand6 is "lowerclothes">>You try to pull up your $lowerclothes, but you aren't strong enough.<<brat 1>>
<<elseif $mouth is "lowerclothes">>
You try to pull up your $lowerclothes, but you aren't strong enough.<<brat 1>>
<<else>>
<<if $vaginause isnot 0 and $vaginause isnot "none">>
Your $lowerclothes hang loosely, but you can't adjust <<lowerit>> while your <<pussy>> is threatened.
<<elseif $penisuse isnot 0 and $penisuse isnot "none">>
Your $lowerclothes hang loosely, but you can't adjust <<lowerit>> while your <<penis>> is threatened.
<<elseif $anususe isnot 0>>
Your $lowerclothes hang loosely, but you can't adjust <<lowerit>> while your <<bottom>> is threatened.
<<else>>
You fix your $lowerclothes, concealing your
<<if $underexposed gte 1>>
<<genitalsstop>>
<<else>>
$underclothes.
<</if>>
<<brat 5>><<set $lowerstate to $lowerstatebase>><<if $skirt is 1>><<set $skirtdown to 1>><</if>><<set $lowervaginaexposed to $lowervaginaexposedbase>><<set $loweranusexposed to $loweranusexposedbase>><<set $lowerexposed to $lowerexposedbase>>
<</if>>
<</if>>
<</if>>
<</if>>
<<if $leftaction is "leftupperpull" and $rightaction is "rightupperpull">><<set $leftaction to 0>><<set $rightaction to 0>><<brat 1>><<set $leftactiondefault to "leftupperpull">><<set $rightactiondefault to "rightupperpull">>
<<if $upperclothes is "naked">>
You clutch the tattered remains of your $upperlast.
<<else>>
<<if $righthand is "upperclothes">>You struggle for control of your $upperclothes.<<brat 2>><<set $upperstruggle to 1>>
<<elseif $lefthand is "upperclothes">>You struggle for control of your $upperclothes.<<brat 2>><<set $upperstruggle to 1>>
<<elseif $righthand2 is "upperclothes">>You struggle for control of your $upperclothes.<<brat 2>><<set $upperstruggle to 1>>
<<elseif $lefthand2 is "upperclothes">>You struggle for control of your $upperclothes.<<brat 2>><<set $upperstruggle to 1>>
<<elseif $righthand3 is "upperclothes">>You struggle for control of your $upperclothes.<<brat 2>><<set $upperstruggle to 1>>
<<elseif $lefthand3 is "upperclothes">>You struggle for control of your $upperclothes.<<brat 2>><<set $upperstruggle to 1>>
<<elseif $righthand4 is "upperclothes">>You struggle for control of your $upperclothes.<<brat 2>><<set $upperstruggle to 1>>
<<elseif $lefthand4 is "upperclothes">>You struggle for control of your $upperclothes.<<brat 2>><<set $upperstruggle to 1>>
<<elseif $righthand5 is "upperclothes">>You struggle for control of your $upperclothes.<<brat 2>><<set $upperstruggle to 1>>
<<elseif $lefthand5 is "upperclothes">>You struggle for control of your $upperclothes.<<brat 2>><<set $upperstruggle to 1>>
<<elseif $righthand6 is "upperclothes">>You struggle for control of your $upperclothes.<<brat 2>><<set $upperstruggle to 1>>
<<elseif $lefthand6 is "upperclothes">>You struggle for control of your $upperclothes.<<brat 2>><<set $upperstruggle to 1>>
<<elseif $mouth is "upperclothes">>
You struggle for control of your $upperclothes.<<brat 2>><<set $upperstruggle to 1>>
<<else>>
<<if $vaginause isnot 0 and $vaginause isnot "none">>
Your $upperclothes hang loosely, but you can't adjust <<upperit>> while your <<pussy>> is threatened.
<<elseif $penisuse isnot 0 and $penisuse isnot "none">>
Your $upperclothes hang loosely, but you can't adjust <<upperit>> while your <<penis>> is threatened.
<<elseif $anususe isnot 0>>
Your $upperclothes hang loosely, but you can't adjust <<upperit>> while your <<bottom>> is threatened.
<<elseif $lowerset is $upperset>>
You fix your $upperclothes, concealing your <<breasts>> and
<<if $underexposed gte 1>>
<<genitalsstop>>
<<else>>
$underclothes.
<</if>>
<<brat 5>><<set $upperstate to $upperstatebase>><<set $upperstatetop to $upperstatetopbase>><<set $upperexposed to $upperexposedbase>><<set $lowerstate to $lowerstatebase>><<if $skirt is 1>><<set $skirtdown to 1>><</if>><<set $lowervaginaexposed to $lowervaginaexposedbase>><<set $loweranusexposed to $loweranusexposedbase>><<set $lowerexposed to $lowerexposedbase>>
<<else>>
You fix your $upperclothes, concealing your <<breastsstop>><<brat 5>><<set $upperstate to $upperstatebase>><<set $upperstatetop to $upperstatetopbase>><<set $upperexposed to $upperexposedbase>>
<</if>>
<</if>>
<</if>>
<</if>>
<<if $leftaction is "leftupperpull">><<set $leftaction to 0>><<brat 1>><<set $leftactiondefault to "leftupperpull">>
<<if $upperclothes is "naked">>
You clutch the tattered remains of your $upperlast.
<<else>>
<<if $righthand is "upperclothes">>You struggle for your $upperclothes, but you aren't strong enough.<<brat 1>>
<<elseif $lefthand is "upperclothes">>You struggle for your $upperclothes, but you aren't strong enough.<<brat 1>>
<<elseif $righthand2 is "upperclothes">>You struggle for your $upperclothes, but you aren't strong enough.<<brat 1>>
<<elseif $lefthand2 is "upperclothes">>You struggle for your $upperclothes, but you aren't strong enough.<<brat 1>>
<<elseif $righthand3 is "upperclothes">>You struggle for your $upperclothes, but you aren't strong enough.<<brat 1>>
<<elseif $lefthand3 is "upperclothes">>You struggle for your $upperclothes, but you aren't strong enough.<<brat 1>>
<<elseif $righthand4 is "upperclothes">>You struggle for your $upperclothes, but you aren't strong enough.<<brat 1>>
<<elseif $lefthand4 is "upperclothes">>You struggle for your $upperclothes, but you aren't strong enough.<<brat 1>>
<<elseif $righthand5 is "upperclothes">>You struggle for your $upperclothes, but you aren't strong enough.<<brat 1>>
<<elseif $lefthand5 is "upperclothes">>You struggle for your $upperclothes, but you aren't strong enough.<<brat 1>>
<<elseif $righthand6 is "upperclothes">>You struggle for your $upperclothes, but you aren't strong enough.<<brat 1>>
<<elseif $lefthand6 is "upperclothes">>You struggle for your $upperclothes, but you aren't strong enough.<<brat 1>>
<<elseif $mouth is "upperclothes">>
You struggle for your $upperclothes, but you aren't strong enough.<<brat 1>>
<<else>>
<<if $vaginause isnot 0 and $vaginause isnot "none">>
Your $upperclothes hang loosely, but you can't adjust <<upperit>> while your <<pussy>> is threatened.
<<elseif $penisuse isnot 0 and $penisuse isnot "none">>
Your $upperclothes hang loosely, but you can't adjust <<upperit>> while your <<penis>> is threatened.
<<elseif $anususe isnot 0>>
Your $upperclothes hang loosely, but you can't adjust <<upperit>> while your <<bottom>> is threatened.
<<elseif $lowerset is $upperset>>
You fix your $upperclothes, concealing your <<breasts>> and
<<if $underexposed gte 1>>
<<genitalsstop>>
<<else>>
$underclothes.
<</if>>
<<brat 5>><<set $upperstate to $upperstatebase>><<set $upperstatetop to $upperstatetopbase>><<set $upperexposed to $upperexposedbase>><<set $lowerstate to $lowerstatebase>><<if $skirt is 1>><<set $skirtdown to 1>><</if>><<set $lowervaginaexposed to $lowervaginaexposedbase>><<set $loweranusexposed to $loweranusexposedbase>><<set $lowerexposed to $lowerexposedbase>>
<<else>>
You fix your $upperclothes, concealing your <<breastsstop>><<brat 5>><<set $upperstate to $upperstatebase>><<set $upperstatetop to $upperstatetopbase>><<set $upperexposed to $upperexposedbase>>
<</if>>
<</if>>
<</if>>
<</if>>
<<if $rightaction is "rightupperpull">><<set $rightaction to 0>><<brat 1>><<set $rightactiondefault to "rightupperpull">>
<<if $upperclothes is "naked">>
You clutch the tattered remains of your $upperlast.
<<else>>
<<if $righthand is "upperclothes">>You struggle for your $upperclothes, but you aren't strong enough.<<brat 1>>
<<elseif $lefthand is "upperclothes">>You struggle for your $upperclothes, but you aren't strong enough.<<brat 1>>
<<elseif $righthand2 is "upperclothes">>You struggle for your $upperclothes, but you aren't strong enough.<<brat 1>>
<<elseif $lefthand2 is "upperclothes">>You struggle for your $upperclothes, but you aren't strong enough.<<brat 1>>
<<elseif $righthand3 is "upperclothes">>You struggle for your $upperclothes, but you aren't strong enough.<<brat 1>>
<<elseif $lefthand3 is "upperclothes">>You struggle for your $upperclothes, but you aren't strong enough.<<brat 1>>
<<elseif $righthand4 is "upperclothes">>You struggle for your $upperclothes, but you aren't strong enough.<<brat 1>>
<<elseif $lefthand4 is "upperclothes">>You struggle for your $upperclothes, but you aren't strong enough.<<brat 1>>
<<elseif $righthand5 is "upperclothes">>You struggle for your $upperclothes, but you aren't strong enough.<<brat 1>>
<<elseif $lefthand5 is "upperclothes">>You struggle for your $upperclothes, but you aren't strong enough.<<brat 1>>
<<elseif $righthand6 is "upperclothes">>You struggle for your $upperclothes, but you aren't strong enough.<<brat 1>>
<<elseif $lefthand6 is "upperclothes">>You struggle for your $upperclothes, but you aren't strong enough.<<brat 1>>
<<elseif $mouth is "upperclothes">>
You struggle for your $upperclothes, but you aren't strong enough.<<brat 1>>
<<else>>
<<if $vaginause isnot 0 and $vaginause isnot "none">>
Your $upperclothes hang loosely, but you can't adjust <<upperit>> while your <<pussy>> is threatened.
<<elseif $penisuse isnot 0 and $penisuse isnot "none">>
Your $upperclothes hang loosely, but you can't adjust <<upperit>> while your <<penis>> is threatened.
<<elseif $anususe isnot 0>>
Your $upperclothes hang loosely, but you can't adjust <<upperit>> while your <<bottom>> is threatened.
<<elseif $lowerset is $upperset>>
You fix your $upperclothes, concealing your <<breasts>> and
<<if $underexposed gte 1>>
<<genitalsstop>>
<<else>>
$underclothes.
<</if>>
<<brat 5>><<set $upperstate to $upperstatebase>><<set $upperstatetop to $upperstatetopbase>><<set $upperexposed to $upperexposedbase>><<set $lowerstate to $lowerstatebase>><<if $skirt is 1>><<set $skirtdown to 1>><</if>><<set $lowervaginaexposed to $lowervaginaexposedbase>><<set $loweranusexposed to $loweranusexposedbase>><<set $lowerexposed to $lowerexposedbase>>
<<else>>
You fix your $upperclothes, concealing your <<breastsstop>><<brat 5>><<set $upperstate to $upperstatebase>><<set $upperstatetop to $upperstatetopbase>><<set $upperexposed to $upperexposedbase>>
<</if>>
<</if>>
<</if>>
<</if>>
<<if $feetaction is "grab">><<set $feetaction to 0>><<set $feetactiondefault to "grab">><<combatpromiscuity3>>
<<if (1000 - ($rng * 10) - ($enemytrust * 10) - $feetskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<<set $feetactiondefault to "grabrub">>
<<if $penis is 0>><<submission 2>><<set $penis to "feet">><<set $feetuse to "penis">><<feetstat>><<feetskilluse>><span class="lblue">You <<feettext>> grab <<his1>> penis between your feet.</span>
<<elseif $penis2 is 0>><<submission 2>><<set $penis2 to "feet">><<set $feetuse to "penis">><<feetstat>><<feetskilluse>><span class="lblue">You <<feettext>> grab <<his2>> penis between your feet.</span>
<<elseif $penis3 is 0>><<submission 2>><<set $penis3 to "feet">><<set $feetuse to "penis">><<feetstat>><<feetskilluse>><span class="lblue">You <<feettext>> grab <<his3>> penis between your feet.</span>
<<elseif $penis4 is 0>><<submission 2>><<set $penis4 to "feet">><<set $feetuse to "penis">><<feetstat>><<feetskilluse>><span class="lblue">You <<feettext>> grab <<his4>> penis between your feet.</span>
<<elseif $penis5 is 0>><<submission 2>><<set $penis5 to "feet">><<set $feetuse to "penis">><<feetstat>><<feetskilluse>><span class="lblue">You <<feettext>> grab <<his5>> penis between your feet.</span>
<<elseif $penis6 is 0>><<submission 2>><<set $penis6 to "feet">><<set $feetuse to "penis">><<feetstat>><<feetskilluse>><span class="lblue">You <<feettext>> grab <<his6>> penis between your feet.</span>
<</if>>
<<else>>
You clumsily try to grab <<a>> penis between your feet, but fail.<<feetskilluse>><<submission 2>>
<</if>>
<</if>>
<<if $feetaction is "rest">><<set $feetaction to 0>><<set $feetactiondefault to "rest">><<neutral 1>>You rest your legs.
<</if>>
<<if $feetaction is "kick">><<set $feetaction to 0>><<set $feetactiondefault to "kick">><<defiance 5>><<actionskick>><<set $attackstat += 1>>
<</if>>
<<if $feetaction is "rub">><<set $feetaction to 0>><<submission 1>><<actionsfeetrub>>
<</if>>
<br>
<<set $rng to random(1, 100)>>
<<if $feetaction is "grabrub">><<feetskilluse>><<set $feetactiondefault to "grabrub">><<set $feetaction to 0>>
<<if (1000 - ($rng * 10) - ($enemytrust * 10) - $feetskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<<actionsgrabrub>><<submission 2>>
<<else>><<set $feetactiondefault to "grab">>
<<if $penis is "feet">>
<span class="blue">You try to rub <<his1>> penis between your feet, but <<he>> moves away.</span><<set $feetuse to 0>><<set $penis to 0>>
<<elseif $penis2 is "feet">>
<span class="blue">You try to rub <<his2>> penis between your feet, but <<he>> moves away.</span><<set $feetuse to 0>><<set $penis2 to 0>>
<<elseif $penis3 is 0>>
<span class="blue">You try to rub <<his3>> penis between your feet, but <<he>> moves away.</span><<set $feetuse to 0>><<set $penis3 to 0>>
<<elseif $penis4 is "feet">>
<span class="blue">You try to rub <<his4>> penis between your feet, but <<he>> moves away.</span><<set $feetuse to 0>><<set $penis4 to 0>>
<<elseif $penis5 is "feet">>
<span class="blue">You try to rub <<his5>> penis between your feet, but <<he>> moves away.</span><<set $feetuse to 0>><<set $penis5 to 0>>
<<elseif $penis6 is "feet">>
<span class="blue">You try to rub <<his6>> penis between your feet, but <<he>> moves away.</span><<set $feetuse to 0>><<set $penis6 to 0>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $feetaction is "vaginagrab">><<feetskilluse>><<set $feetaction to 0>><<set $feetactiondefault to "vaginagrab">><<combatpromiscuity3>>
<<if (1000 - ($rng * 10) - ($enemytrust * 10) - $feetskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>><<set $feetactiondefault to "vaginagrabrub">>
<<if $vagina is 0>>
<<submission 2>><<set $feetuse to "othervagina">><<set $vagina to "feet">><<feetstat>><span class="lblue">You <<feettext>> press your feet against <<his1>> pussy.</span>
<<elseif $vagina2 is 0>>
<<submission 2>><<set $feetuse to "othervagina">><<set $vagina2 to "feet">><<feetstat>><span class="lblue">You <<feettext>> press your feet against <<his2>> pussy.</span>
<<elseif $vagina3 is 0>>
<<submission 2>><<set $feetuse to "othervagina">><<set $vagina3 to "feet">><<feetstat>><span class="lblue">You <<feettext>> press your feet against <<his3>> pussy.</span>
<<elseif $vagina4 is 0>>
<<submission 2>><<set $feetuse to "othervagina">><<set $vagina4 to "feet">><<feetstat>><span class="lblue">You <<feettext>> press your feet against <<his4>> pussy.</span>
<<elseif $vagina5 is 0>>
<<submission 2>><<set $feetuse to "othervagina">><<set $vagina5 to "feet">><<feetstat>><span class="lblue">You <<feettext>> press your feet against <<his5>> pussy.</span>
<<elseif $vagina6 is 0>>
<<submission 2>><<set $feetuse to "othervagina">><<set $vagina6 to "feet">><<feetstat>><span class="lblue">You <<feettext>> press your feet against <<his6>> pussy.</span>
<</if>>
<<else>>
You try to keep <<a>> pussy away with your feet, but <<theowner>> moves it away.
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $feetaction is "vaginagrabrub">><<set $feetaction to 0>><<feetskilluse>><<set $feetactiondefault to "vaginagrabrub">>
<<if (1000 - ($rng * 10) - ($enemytrust * 10) - $feetskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<<actionsfeetpussy>><<submission 2>>
<<else>><<set $feetactiondefault to "vaginagrab">>
<<if $vagina is "feet">>
<span class="blue">You try to keep <<his1>> pussy away with your feet, but <<he>> moves away.</span><<set $feetuse to 0>><<set $vagina to 0>>
<<elseif $vagina2 is "feet">>
<span class="blue">You try to keep <<his2>> pussy away with your feet, but <<he>> moves away.</span><<set $feetuse to 0>><<set $vagina2 to 0>>
<<elseif $vagina3 is 0>>
<span class="blue">You try to keep <<his3>> pussy away with your feet, but <<he>> moves away.</span><<set $feetuse to 0>><<set $vagina3 to 0>>
<<elseif $vagina4 is "feet">>
<span class="blue">You try to keep <<his4>> pussy away with your feet, but <<he>> moves away.</span><<set $feetuse to 0>><<set $vagina4 to 0>>
<<elseif $vagina5 is "feet">>
<span class="blue">You try to keep <<his5>> pussy away with your feet, but <<he>> moves away.</span><<set $feetuse to 0>><<set $vagina5 to 0>>
<<elseif $vagina6 is "feet">>
<span class="blue">You try to keep <<his6>> pussy away with your feet, but <<he>> moves away.</span><<set $feetuse to 0>><<set $vagina6 to 0>>
<</if>>
<</if>>
<</if>>
<<if $feetaction is "stop">><<set $feetaction to 0>><<set $feetactiondefault to "stop">>You move your feet away from their genitals.<<set $feetuse to 0>>
<<if $penis is "feet">>
<<set $penis to 0>>
<<elseif $penis2 is "feet">>
<<set $penis2 to 0>>
<<elseif $penis3 is "feet">>
<<set $penis3 to 0>>
<<elseif $penis4 is "feet">>
<<set $penis4 to 0>>
<<elseif $penis5 is "feet">>
<<set $penis5 to 0>>
<<elseif $penis6 is "feet">>
<<set $penis6 to 0>>
<<elseif $vagina is "feet">>
<<set $vagina to 0>>
<<elseif $vagina2 is "feet">>
<<set $vagina2 to 0>>
<<elseif $vagina3 is "feet">>
<<set $vagina3 to 0>>
<<elseif $vagina4 is "feet">>
<<set $vagina4 to 0>>
<<elseif $vagina5 is "feet">>
<<set $vagina5 to 0>>
<<elseif $vagina6 is "feet">>
<<set $vagina6 to 0>>
<</if>>
<</if>>
<<if $mouthaction is "rest">><<set $mouthaction to 0>><<set $mouthactiondefault to "rest">>
<</if>>
<<if $mouthaction is "kiss">><<set $mouthaction to 0>>
<<actionskiss>><<submission 3>><<set $mouthactiondefault to "kiss">>
<</if>>
<<if $mouthaction is "plead">><<set $mouthaction to 0>><<set $mouthactiondefault to "plead">>
<<actionsplead>><<set $speechplead to 1>>
<<if $englishtrait is 4>>
<<meek 5>>
<<elseif $englishtrait is 3>>
<<meek 4>>
<<elseif $englishtrait is 2>>
<<meek 3>>
<<elseif $englishtrait is 1>>
<<meek 2>>
<<else>>
<<meek 1>>
<</if>>
<</if>>
<<if $mouthaction is "moan">><<set $mouthaction to 0>><<set $mouthactiondefault to "moan">>
<<actionsmoan>><<set $speechmoan to 1>>
<<if $englishtrait is 4>>
<<submission 5>>
<<elseif $englishtrait is 3>>
<<submission 4>>
<<elseif $englishtrait is 2>>
<<submission 3>>
<<elseif $englishtrait is 1>>
<<submission 2>>
<<else>>
<<submission 1>>
<</if>>
<</if>>
<<if $mouthaction is "demand">><<set $mouthaction to 0>><<set $mouthactiondefault to "demand">>
<<actionsdemand>><<set $speechdemand to 1>>
<<if $englishtrait is 4>>
<<defiance 5>>
<<elseif $englishtrait is 3>>
<<defiance 4>>
<<elseif $englishtrait is 2>>
<<defiance 3>>
<<elseif $englishtrait is 1>>
<<defiance 2>>
<<else>>
<<defiance 1>>
<</if>>
<</if>>
<<if $mouthaction is "mock">><<set $mouthaction to 0>><<set $mouthactiondefault to "mock">>
<<actionsmock>><<set $speechdemand to 1>>
<<if $englishtrait is 4>>
<<brat 5>><<if $mockaction is $insecurity1 or $mockaction is $insecurity2 or $mockaction is $insecurity3 or $mockaction is $insecurity4 or $mockaction is $insecurity5 or $mockaction is $insecurity6>><<if $consensual is 1>><<submissive5>><<else>><<combatcontrol 5>><</if>><</if>>
<<elseif $englishtrait is 3>>
<<brat 4>><<if $mockaction is $insecurity1 or $mockaction is $insecurity2 or $mockaction is $insecurity3 or $mockaction is $insecurity4 or $mockaction is $insecurity5 or $mockaction is $insecurity6>><<if $consensual is 1>><<submissive4>><<else>><<combatcontrol 4>><</if>><</if>>
<<elseif $englishtrait is 2>>
<<brat 3>><<if $mockaction is $insecurity1 or $mockaction is $insecurity2 or $mockaction is $insecurity3 or $mockaction is $insecurity4 or $mockaction is $insecurity5 or $mockaction is $insecurity6>><<if $consensual is 1>><<submissive3>><<else>><<combatcontrol 3>><</if>><</if>>
<<elseif $englishtrait is 1>>
<<brat 2>><<if $mockaction is $insecurity1 or $mockaction is $insecurity2 or $mockaction is $insecurity3 or $mockaction is $insecurity4 or $mockaction is $insecurity5 or $mockaction is $insecurity6>><<if $consensual is 1>><<submissive2>><<else>><<combatcontrol 2>><</if>><</if>>
<<else>>
<<brat 1>><<if $mockaction is $insecurity1 or $mockaction is $insecurity2 or $mockaction is $insecurity3 or $mockaction is $insecurity4 or $mockaction is $insecurity5 or $mockaction is $insecurity6>><<if $consensual is 1>><<submissive1>><<else>><<combatcontrol 1>><</if>><</if>>
<</if>>
<</if>>
<<if $mouthaction is "mouth">><<set $mouthaction to 0>><<meek 1>><<set $mouthactiondefault to "mouth">><<combatpromiscuity4>>
<<if $penisbitten is 1>><<He>> smacks your head away from <<his>> penis.<<violence 5>>
<<elseif (1000 - ($rng * 10) - ($enemytrust * 10) - $oralskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<<set $mouthactiondefault to "lick">><<set $mouthsubmit to 1>>
<<if $penis is 0>>
<<set $penis to "mouthentrance">><<set $mouthuse to "penis">><<oralskilluse>><<set $mouthstate to "entrance">><span class="lblue">You <<oraltext>> move your mouth to <<his1>> penis and <<he>> waits expectantly.</span>
<<elseif $penis2 is 0>>
<<set $penis2 to "mouthentrance">><<set $mouthuse to "penis">><<oralskilluse>><<set $mouthstate to "entrance">><span class="lblue">You <<oraltext>> move your mouth to <<his2>> penis and <<he>> waits expectantly.</span>
<<elseif $penis3 is 0>>
<<set $penis3 to "mouthentrance">><<set $mouthuse to "penis">><<oralskilluse>><<set $mouthstate to "entrance">><span class="lblue">You <<oraltext>> move your mouth to <<his3>> penis and <<he>> waits expectantly.</span>
<<elseif $penis4 is 0>>
<<set $penis4 to "mouthentrance">><<set $mouthuse to "penis">><<oralskilluse>><<set $mouthstate to "entrance">><span class="lblue">You <<oraltext>> move your mouth to <<his4>> penis and <<he>> waits expectantly.</span>
<<elseif $penis5 is 0>>
<<set $penis5 to "mouthentrance">><<set $mouthuse to "penis">><<oralskilluse>><<set $mouthstate to "entrance">><span class="lblue">You <<oraltext>> move your mouth to <<his5>> penis and <<he>> waits expectantly.</span>
<<elseif $penis6 is 0>>
<<set $penis6 to "mouthentrance">><<set $mouthuse to "penis">><<oralskilluse>><<set $mouthstate to "entrance">><span class="lblue">You <<oraltext>> move your mouth to <<his6>> penis and <<he>> waits expectantly.</span>
<</if>>
<<else>>You try to move into a position where your mouth can take <<a>> penis, but <<theowner>> has other ideas.<<oralskilluse>>
<</if>>
<</if>>
<<if $mouthaction is "othervagina">><<set $mouthaction to 0>><<meek 1>><<set $mouthactiondefault to "othervagina">><<combatpromiscuity4>>
<<if $penisbitten is 1>><<He>> smacks your head away from <<his>> pussy.<<violence 5>>
<<elseif (1000 - ($rng * 10) - ($enemytrust * 10) - $oralskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>><<set $mouthactiondefault to "vaginalick">>
<<if $vagina is 0>>
<span class="lblue">You <<oraltext>> move your mouth to <<his1>> pussy and <<he>> waits expectantly.</span><<set $vagina to "mouthentrance">><<set $mouthstate to "vaginaentrance">><<set $mouthuse to "othervagina">><<oralskilluse>>
<<elseif $vagina2 is 0>>
<span class="lblue">You <<oraltext>> move your mouth to <<his2>> pussy and <<he>> waits expectantly.</span><<set $vagina2 to "mouthentrance">><<set $mouthstate to "vaginaentrance">><<set $mouthuse to "othervagina">><<oralskilluse>>
<<elseif $vagina3 is 0>>
<span class="lblue">You <<oraltext>> move your mouth to <<his3>> pussy and <<he>> waits expectantly.</span><<set $vagina3 to "mouthentrance">><<set $mouthstate to "vaginaentrance">><<set $mouthuse to "othervagina">><<oralskilluse>>
<<elseif $vagina4 is 0>>
<span class="lblue">You <<oraltext>> move your mouth to <<his4>> pussy and <<he>> waits expectantly.</span><<set $vagina4 to "mouthentrance">><<set $mouthstate to "vaginaentrance">><<set $mouthuse to "othervagina">><<oralskilluse>>
<<elseif $vagina5 is 0>>
<span class="lblue">You <<oraltext>> move your mouth to <<his5>> pussy and <<he>> waits expectantly.</span><<set $vagina5 to "mouthentrance">><<set $mouthstate to "vaginaentrance">><<set $mouthuse to "othervagina">><<oralskilluse>>
<<elseif $vagina6 is 0>>
<span class="lblue">You <<oraltext>> move your mouth to <<his6>> pussy and <<he>> waits expectantly.</span><<set $vagina6 to "mouthentrance">><<set $mouthstate to "vaginaentrance">><<set $mouthuse to "othervagina">><<oralskilluse>>
<</if>>
<<else>>You try to move into a position where your mouth can eat pussy, but <<theowner>> has other ideas.<<oralskilluse>>
<</if>>
<</if>>
<<if $mouthaction is "scream">><<set $mouthaction to 0>>
You scream for help.<<brat 10>><<set $alarm to 1>><<set $mouthactiondefault to "scream">><<set $speechscream to 1>>
<<if $lefthand is 0 and $mouthuse is 0>><<set $lefthand to "mouth">><<He>> clasps <<his>> hand over your mouth to silence you.<<set $enemytrust -= 40>><<set $mouthuse to "lefthand">>
<<elseif $righthand is 0 and $mouthuse is 0>><<set $righthand to "mouth">><<He>> clasps <<his>> hand over your mouth to silence you.<<set $enemytrust -= 40>><<set $mouthuse to "lefthand">>
<</if>>
<</if>>
<<if $mouthaction is "apologise">><<set $mouthaction to 0>>
<<if $enemytype is "beast">>
You tell <<him>> you're sorry for being bad.<<set $mouthactiondefault to "plead">>
<<if $apologised is 0>>While it doesn't understand you, your tone of voice has an impact.<<set $apologised to 1>><<set $speechapologise to 1>>
<<if $englishtrait is 4>>
<<set $enemyanger -= 250>>
<<elseif $englishtrait is 3>>
<<set $enemyanger -= 200>>
<<elseif $englishtrait is 2>>
<<set $enemyanger -= 150>>
<<elseif $englishtrait is 1>>
<<set $enemyanger -= 100>>
<<else>>
<<set $enemyanger -= 50>>
<</if>>
<<else>><<He>> ignores you.<<set $speechapologiseno to 1>>
<</if>>
<<else>>
You tell <<him>> you're sorry for being bad.<<set $mouthactiondefault to "plead">>
<<if $apologised is 0>><<His>> face softens.<<set $apologised to 1>><<set $speechapologise to 1>>
<<if $englishtrait is 4>>
<<set $enemyanger -= 250>>
<<elseif $englishtrait is 3>>
<<set $enemyanger -= 200>>
<<elseif $englishtrait is 2>>
<<set $enemyanger -= 150>>
<<elseif $englishtrait is 1>>
<<set $enemyanger -= 100>>
<<else>>
<<set $enemyanger -= 50>>
<</if>>
<<else>><<He>> ignores you.<<set $speechapologiseno to 1>>
<</if>>
<</if>>
<</if>>
<<if $mouthaction is "forgive">><<set $mouthaction to 0>><<set $mouthactiondefault to "plead">>
<<set $trauma -= $traumagain>><<set $traumagain to 0>><<set $speechforgive to 1>><<set $angelforgive to 1>>
<<if $enemytype is "beast">>
"You don't know any better. You're just a $beasttype," you say. "I forgive you."
<<else>>
"Even though you're doing such a horrible thing, don't worry," you say. "I forgive you."
<</if>>
<</if>>
<<if $mouthaction is "peniskiss">><<set $mouthaction to 0>><<set $mouthactiondefault to "peniskiss">>
<<actionspeniskiss>>
<<submission 3>><<oralskilluse>>
<</if>>
<<if $mouthaction is "lick">><<set $mouthaction to 0>><<set $mouthactiondefault to "lick">><<actionspenislick>><<submission 5>><<oralskilluse>>
<</if>>
<<if $mouthaction is "suck">><<set $mouthaction to 0>><<set $mouthactiondefault to "suck">><<actionspenissuck>><<submission 10>><<oralskilluse>>
<</if>>
<<if $mouthaction is "pullaway">><<set $mouthaction to 0>><<set $mouthactiondefault to "pullaway">>You try to pull your head away from the penis threatening your mouth.<<oralskilluse>><<brat 1>>
<<if (1000 - ($rng * 10) - ($enemytrust * 10) - $oralskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<<set $pullaway to 1>>
<<if $penis is "mouth">>
<<set $penis to "mouthimminent">><<set $mouthstate to "imminent">><span class="green"><<He 1>> doesn't stop you.</span>
<<elseif $penis2 is "mouth">>
<<set $penis2 to "mouthimminent">><<set $mouthstate to "imminent">><span class="green"><<He 2>> doesn't stop you.</span>
<<elseif $penis3 is "mouth">>
<<set $penis3 to "mouthimminent">><<set $mouthstate to "imminent">><span class="green"><<He 3>> doesn't stop you.</span>
<<elseif $penis4 is "mouth">>
<<set $penis4 to "mouthimminent">><<set $mouthstate to "imminent">><span class="green"><<He 4>> doesn't stop you.</span>
<<elseif $penis5 is "mouth">>
<<set $penis5 to "mouthimminent">><<set $mouthstate to "imminent">><span class="green"><<He 5>> doesn't stop you.</span>
<<elseif $penis6 is "mouth">>
<<set $penis6 to "mouthimminent">><<set $mouthstate to "imminent">><span class="green"><<He 6>> doesn't stop you.</span>
<<elseif $penis is "mouthimminent">>
<<set $penis to "mouthentrance">><<set $mouthstate to "entrance">><span class="green"><<He 1>> doesn't stop you.</span>
<<elseif $penis2 is "mouthimminent">>
<<set $penis2 to "mouthentrance">><<set $mouthstate to "entrance">><span class="green"><<He 2>> doesn't stop you.</span>
<<elseif $penis3 is "mouthimminent">>
<<set $penis3 to "mouthentrance">><<set $mouthstate to "entrance">><span class="green"><<He 3>> doesn't stop you.</span>
<<elseif $penis4 is "mouthimminent">>
<<set $penis4 to "mouthentrance">><<set $mouthstate to "entrance">><span class="green"><<He 4>> doesn't stop you.</span>
<<elseif $penis5 is "mouthimminent">>
<<set $penis5 to "mouthentrance">><<set $mouthstate to "entrance">><span class="green"><<He 5>> doesn't stop you.</span>
<<elseif $penis6 is "mouthimminent">>
<<set $penis6 to "mouthentrance">><<set $mouthstate to "entrance">><span class="green"><<He 6>> doesn't stop you.</span>
<<elseif $penis is "mouthentrance">>
<<set $penis to 0>><<set $mouthstate to 0>><<set $mouthuse to 0>><<set $mouthstate to 0>><span class="green"><<He 1>> doesn't stop you.</span>
<<elseif $penis2 is "mouthentrance">>
<<set $penis2 to 0>><<set $mouthstate to 0>><<set $mouthuse to 0>><<set $mouthstate to 0>><span class="green"><<He 2>> doesn't stop you.</span>
<<elseif $penis3 is "mouthentrance">>
<<set $penis3 to 0>><<set $mouthstate to 0>><<set $mouthuse to 0>><<set $mouthstate to 0>><span class="green"><<He 3>> doesn't stop you.</span>
<<elseif $penis4 is "mouthentrance">>
<<set $penis4 to 0>><<set $mouthstate to 0>><<set $mouthuse to 0>><<set $mouthstate to 0>><span class="green"><<He 4>> doesn't stop you.</span>
<<elseif $penis5 is "mouthentrance">>
<<set $penis5 to 0>><<set $mouthstate to 0>><<set $mouthuse to 0>><<set $mouthstate to 0>><span class="green"><<He 5>> doesn't stop you.</span>
<<elseif $penis6 is "mouthentrance">>
<<set $penis6 to 0>><<set $mouthstate to 0>><<set $mouthuse to 0>><<set $mouthstate to 0>><span class="green"><<He 6>> doesn't stop you.</span>
<</if>>
<<else>>
<<if $consensual is 1>>
<<set $consensual to 0>><<molested>><<controlloss>>
<</if>>
<<violence 1>>
<<if $mouthstate is "penetrated">><span class="red">However, <<theowner>> refuses to allow it, </span>forcing the phallus back into your mouth.
<<elseif $mouthstate is "imminent">><span class="red">However, <<theowner>> refuses to allow it, </span>instead pushing the penis against your lips.
<<elseif $mouthstate is "entrance">><span class="red">However, <<theowner>> refuses to allow it, </span>instead pushing the penis against your lips.
<</if>>
<</if>>
<</if>>
<<if $mouthaction is "pullawayvagina">><<set $mouthaction to 0>><<set $mouthactiondefault to "pullawayvagina">>
<<if $consensual is 1>>
You try to move your head away from the pussy.<<oralskilluse>><<brat 1>>
<<else>>
You try to pull your head away from the pussy threatening your mouth.<<oralskilluse>><<brat 1>>
<</if>>
<<if (1000 - ($rng * 10) - ($enemytrust * 10) - $oralskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<<set $mouthuse to 0>><<set $mouthstate to 0>><<set $pullaway to 1>>
<<if $vagina is "mouth">>
<<set $vagina to 0>><span class="green"><<He 1>> doesn't stop you.</span>
<<elseif $vagina2 is "mouth">>
<<set $vagina2 to 0>><span class="green"><<He 2>> doesn't stop you.</span>
<<elseif $vagina3 is "mouth">>
<<set $vagina3 to 0>><span class="green"><<He 3>> doesn't stop you.</span>
<<elseif $vagina4 is "mouth">>
<<set $vagina4 to 0>><span class="green"><<He 4>> doesn't stop you.</span>
<<elseif $vagina5 is "mouth">>
<<set $vagina5 to 0>><span class="green"><<He 5>> doesn't stop you.</span>
<<elseif $vagina6 is "mouth">>
<<set $vagina6 to 0>><span class="green"><<He 6>> doesn't stop you.</span>
<</if>>
<<if $vagina is "mouthimminent">>
<<set $vagina to 0>><span class="green"><<He 1>> doesn't stop you.</span>
<<elseif $vagina2 is "mouthimminent">>
<<set $vagina2 to 0>><span class="green"><<He 2>> doesn't stop you.</span>
<<elseif $vagina3 is "mouthimminent">>
<<set $vagina3 to 0>><span class="green"><<He 3>> doesn't stop you.</span>
<<elseif $vagina4 is "mouthimminent">>
<<set $vagina4 to 0>><span class="green"><<He 4>> doesn't stop you.</span>
<<elseif $vagina5 is "mouthimminent">>
<<set $vagina5 to 0>><span class="green"><<He 5>> doesn't stop you.</span>
<<elseif $vagina6 is "mouthimminent">>
<<set $vagina6 to 0>><span class="green"><<He 6>> doesn't stop you.</span>
<</if>>
<<if $vagina is "mouthentrance">>
<<set $vagina to 0>><span class="green"><<He 1>> doesn't stop you.</span>
<<elseif $vagina2 is "mouthentrance">>
<<set $vagina2 to 0>><span class="green"><<He 2>> doesn't stop you.</span>
<<elseif $vagina3 is "mouthentrance">>
<<set $vagina3 to 0>><span class="green"><<He 3>> doesn't stop you.</span>
<<elseif $vagina4 is "mouthentrance">>
<<set $vagina4 to 0>><span class="green"><<He 4>> doesn't stop you.</span>
<<elseif $vagina5 is "mouthentrance">>
<<set $vagina5 to 0>><span class="green"><<He 5>> doesn't stop you.</span>
<<elseif $vagina6 is "mouthentrance">>
<<set $vagina6 to 0>><span class="green"><<He 6>> doesn't stop you.</span>
<</if>>
<<else>>
<<if $consensual is 1>>
<<set $consensual to 0>><<molested>><<controlloss>>
<</if>>
<span class="red">However,<<theowner>> refuses to allow it, </span>forcing it against your face.<<violence 1>>
<</if>>
<</if>>
<<if $mouthaction is "bite">><<set $mouthaction to 0>><<set $mouthactiondefault to "bite">>You bite down on the penis, <<theowner>> <<if $enemytype is "man">>yelps<<elseif $enemytype is "beast">>growls<<else>>shrieks<</if>> and recoils in agony.<<defiance 20>><<attackstat>><<set $mouthuse to 0>><<set $penisbitten to 1>><<set $mouthstate to 0>>
<<if $wolfgirl gte 2>>
<<defiance 20>><<defiance 20>>You lick your fangs clean.
<</if>>
<<if $penis is "mouth">>
<<set $penis to 0>>
<<elseif $penis2 is "mouth">>
<<set $penis2 to 0>>
<<elseif $penis3 is "mouth">>
<<set $penis3 to 0>>
<<elseif $penis4 is "mouth">>
<<set $penis4 to 0>>
<<elseif $penis5 is "mouth">>
<<set $penis5 to 0>>
<<elseif $penis6 is "mouth">>
<<set $penis6 to 0>>
<</if>>
<</if>>
<<if $mouthaction is "vaginalick">><<set $mouthaction to 0>><<set $mouthactiondefault to "vaginalick">><<actionspussylick>><<submission 10>><<oralskilluse>>
<</if>>
<<if $mouthaction is "finish">><<set $mouthaction to 0>>
<<set $mouthactiondefault to "plead">><<brat 10>>You tell <<him>> you've had enough and want to stop.
<<if (1000 - ($rng * 10) - ($enemytrust * 10) - $seductionskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100) or $gamemode is "soft">>
<<set $finish to 1>>
<<if $enemytype is "man">>
<<He>> <<if $enemyno gte 2>>look<<else>>looks<</if>> disappointed, <span class="green">but <<if $enemyno gte 2>>comply<<else>>complies<</if>>.</span>
<<else>>
It can't speak, <span class="green">but understands your tone and complies.</span>
<</if>>
<<if $gamemode is "soft">>
<<set $enemyhealth to -1000>>
<</if>>
<<else>>
<<set $consensual to 0>>
<<if $enemytype is "man">>
<span class="red"><<if $enemyno gte 2>>They refuse!<<else>><<He>> refuses!<</if>></span>
<<else>>
Eager to breed, <span class="red">it ignores your desire.</span>
<</if>>
<<molested>><<controlloss>>
<</if>>
<</if>>
<<if $mouthaction is "novaginal">><<set $mouthaction to 0>>
<<set $mouthactiondefault to "plead">><<brat 5>><<seductionskillusecombat>>
<<if $vaginalvirginity is 1>>
You tell <<him>> you don't want anything penetrating your vagina, you are a virgin after all.
<<else>>
You tell <<him>> you don't want anything penetrating your vagina.
<</if>>
<<if (1000 - ($rng * 10) - ($enemytrust * 10) - $seductionskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<<set $novaginal to 1>><span class="green">They nod in acknowledgement.</span>
<<if $vaginastate is "penetrated">><<set $vaginastate to "entrance">>
<<if $penis is "vagina">>
<<set $penis to "vaginaentrance">><<person1>>The <<person>> withdraws <<his>> penis from your vagina.
<<elseif $penis2 is "vagina">>
<<set $penis2 to "vaginaentrance">><<person2>>The <<person>> withdraws <<his>> penis from your vagina.
<<elseif $penis3 is "vagina">>
<<set $penis3 to "vaginaentrance">><<person3>>The <<person>> withdraws <<his>> penis from your vagina.
<<elseif $penis4 is "vagina">>
<<set $penis4 to "vaginaentrance">><<person4>>The <<person>> withdraws <<his>> penis from your vagina.
<<elseif $penis5 is "vagina">>
<<set $penis5 to "vaginaentrance">><<person5>>The <<person>> withdraws <<his>> penis from your vagina.
<<elseif $penis6 is "vagina">>
<<set $penis6 to "vaginaentrance">><<person6>>The <<person>> withdraws <<his>> penis from your vagina.
<</if>>
<</if>>
<<else>>
<<set $consensual to 0>>They pause a moment before responding, <span class="red">"Stupid slut, you think you can tell me what to do?"</span><<molested>><<controlloss>>
<</if>>
<</if>>
<<if $mouthaction is "noanal">><<set $mouthaction to 0>>
<<set $mouthactiondefault to "plead">><<brat 5>><<seductionskillusecombat>>
<<if $analvirginity is 1>>
You tell <<him>> you don't want anything inside your anus, it's dirty there!
<<else>>
You tell <<him>> you don't want anything penetrating your anus.
<</if>>
<<if (1000 - ($rng * 10) - ($enemytrust * 10) - $seductionskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>><<set $noanal to 1>>
<<set $noanal to 1>><span class="green">They nod in acknowledgement.</span>
<<if $anusstate is "penetrated">><<set $anusstate to "entrance">>
<<if $penis is "anus">>
<<set $penis to "anusentrance">><<person1>>The <<person>> withdraws <<his>> penis from your anus.
<<elseif $penis2 is "anus">>
<<set $penis2 to "anusentrance">><<person2>>The <<person>> withdraws <<his>> penis from your anus.
<<elseif $penis3 is "anus">>
<<set $penis3 to "anusentrance">><<person3>>The <<person>> withdraws <<his>> penis from your anus.
<<elseif $penis4 is "anus">>
<<set $penis4 to "anusentrance">><<person4>>The <<person>> withdraws <<his>> penis from your anus.
<<elseif $penis5 is "anus">>
<<set $penis5 to "anusentrance">><<person5>>The <<person>> withdraws <<his>> penis from your anus.
<<elseif $penis6 is "anus">>
<<set $penis6 to "anusentrance">><<person6>>The <<person>> withdraws <<his>> penis from your anus.
<</if>>
<</if>>
<<else>>
<<set $consensual to 0>>They pause a moment before responding, <span class="red">"Stupid slut, you think you can tell me what to do?"</span><<molested>><<controlloss>>
<</if>>
<</if>>
<<if $mouthaction is "nopenile">><<set $mouthaction to 0>>
<<set $mouthactiondefault to "plead">><<brat 5>><<seductionskillusecombat>>
<<if $penilevirginity is 1>>
You tell <<him>> you don't want your penis put inside anything, you are a virgin after all.
<<else>>
You tell <<him>> you don't want your penis put inside anything.
<</if>>
<<if (1000 - ($rng * 10) - ($enemytrust * 10) - $seductionskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<<set $nopenile to 1>><span class="green">They nod in acknowledgement.</span>
<<if $penisstate is "penetrated">><<set $penisstate to "entrance">>
<<if $vagina is "penis">>
<<set $vagina to "penisentrance">><<person1>>The <<person>> frees your penis from <<his>> vagina.
<<elseif $vagina2 is "penis">>
<<set $vagina2 to "penisentrance">><<person2>>The <<person>> frees your penis from <<his>> vagina.
<<elseif $vagina3 is "penis">>
<<set $vagina3 to "penisentrance">><<person3>>The <<person>> frees your penis from <<his>> vagina.
<<elseif $vagina4 is "penis">>
<<set $vagina4 to "penisentrance">><<person4>>The <<person>> frees your penis from <<his>> vagina.
<<elseif $vagina5 is "penis">>
<<set $vagina5 to "penisentrance">><<person5>>The <<person>> frees your penis from <<his>> vagina.
<<elseif $vagina6 is "penis">>
<<set $vagina6 to "penisentrance">><<person6>>The <<person>> frees your penis from <<his>> vagina.
<</if>>
<</if>>
<<if $penisstate is "penetratedanal">><<set $penisstate to "entranceanal">>
<<if $anus is "penis">>
<<set $anus to "penisentrance">><<person1>>The <<person>> frees your penis from <<his>> anus.
<<elseif $anus2 is "penis">>
<<set $anus2 to "penisentrance">><<person2>>The <<person>> frees your penis from <<his>> anus.
<<elseif $anus3 is "penis">>
<<set $anus3 to "penisentrance">><<person3>>The <<person>> frees your penis from <<his>> anus.
<<elseif $anus4 is "penis">>
<<set $anus4 to "penisentrance">><<person4>>The <<person>> frees your penis from <<his>> anus.
<<elseif $anus5 is "penis">>
<<set $anus5 to "penisentrance">><<person5>>The <<person>> frees your penis from <<his>> anus.
<<elseif $anus6 is "penis">>
<<set $anus6 to "penisentrance">><<person6>>The <<person>> frees your penis from <<his>> anus.
<</if>>
<</if>>
<<if $penisstate is "penetratedoral">><<set $penisstate to "entranceoral">>
<<if $mouth is "penis">>
<<set $mouth to "penisentrance">><<person1>>The <<person>> slips your penis out of <<his>> mouth.
<<elseif $mouth2 is "penis">>
<<set $mouth2 to "penisentrance">><<person2>>The <<person>> slips your penis out of <<his>> mouth.
<<elseif $mouth3 is "penis">>
<<set $mouth3 to "penisentrance">><<person3>>The <<person>> slips your penis out of <<his>> mouth.
<<elseif $mouth4 is "penis">>
<<set $mouth4 to "penisentrance">><<person4>>The <<person>> slips your penis out of <<his>> mouth.
<<elseif $mouth5 is "penis">>
<<set $mouth5 to "penisentrance">><<person5>>The <<person>> slips your penis out of <<his>> mouth.
<<elseif $mouth6 is "penis">>
<<set $mouth6 to "penisentrance">><<person6>>The <<person>> slips your penis out of <<his>> mouth.
<</if>>
<</if>>
<<else>>
<<set $consensual to 0>>They pause a moment before responding, <span class="red">"Stupid slut, you think you can tell me what to do?"</span><<molested>><<controlloss>>
<</if>>
<</if>>
<<if $mouthaction is "pullawaykiss">>
<<set $mouthaction to 0>><<set $mouthactiondefault to "pullawaykiss">>You try to pull your head away from their lips.<<oralskilluse>><<brat 1>>
<<if (1000 - ($rng * 10) - ($enemytrust * 10) - $oralskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<<set $mouthuse to 0>><<set $mouthstate to 0>>
<<if $mouth is "kissentrance">>
<<set $mouth to 0>><span class="green"><<He 1>> doesn't stop you.</span>
<<elseif $mouth2 is "kissentrance">>
<<set $mouth2 to 0>><span class="green"><<He 2>> doesn't stop you.</span>
<<elseif $mouth3 is "kissentrance">>
<<set $mouth3 to 0>><span class="green"><<He 3>> doesn't stop you.</span>
<<elseif $mouth4 is "kissentrance">>
<<set $mouth4 to 0>><span class="green"><<He 4>> doesn't stop you.</span>
<<elseif $mouth5 is "kissentrance">>
<<set $mouth5 to 0>><span class="green"><<He 5>> doesn't stop you.</span>
<<elseif $mouth6 is "kissentrance">>
<<set $mouth6 to 0>><span class="green"><<He 6>> doesn't stop you.</span>
<</if>>
<<if $mouth is "kissimminent">>
<<set $mouth to 0>><span class="green"><<He 1>> doesn't stop you.</span>
<<elseif $mouth2 is "kissimminent">>
<<set $mouth2 to 0>><span class="green"><<He 2>> doesn't stop you.</span>
<<elseif $mouth3 is "kissimminent">>
<<set $mouth3 to 0>><span class="green"><<He 3>> doesn't stop you.</span>
<<elseif $mouth4 is "kissimminent">>
<<set $mouth4 to 0>><span class="green"><<He 4>> doesn't stop you.</span>
<<elseif $mouth5 is "kissimminent">>
<<set $mouth5 to 0>><span class="green"><<He 5>> doesn't stop you.</span>
<<elseif $mouth6 is "kissimminent">>
<<set $mouth6 to 0>><span class="green"><<He 6>> doesn't stop you.</span>
<</if>>
<<if $mouth is "kiss">>
<<set $mouth to 0>><span class="green"><<He 1>> doesn't stop you.</span>
<<elseif $mouth2 is "kiss">>
<<set $mouth2 to 0>><span class="green"><<He 2>> doesn't stop you.</span>
<<elseif $mouth3 is "kiss">>
<<set $mouth3 to 0>><span class="green"><<He 3>> doesn't stop you.</span>
<<elseif $mouth4 is "kiss">>
<<set $mouth4 to 0>><span class="green"><<He 4>> doesn't stop you.</span>
<<elseif $mouth5 is "kiss">>
<<set $mouth5 to 0>><span class="green"><<He 5>> doesn't stop you.</span>
<<elseif $mouth6 is "kiss">>
<<set $mouth6 to 0>><span class="green"><<He 6>> doesn't stop you.</span>
<</if>>
<<else>>
<<if $consensual is 1>>
<<set $consensual to 0>><<molested>><<controlloss>>
<</if>>
<span class="red">However, <<theowner>> refuses to allow it, </span>kissing you more firmly.<<violence 1>>
<</if>>
<</if>>
<<if $mouthaction is "kissback">>
<<set $mouthaction to 0>><<set $mouthactiondefault to "kissback">><<actionskissback>><<submission 2>><<oralskilluse>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $vaginaaction is "penisthighs">><<set $vaginaaction to 0>><<meek 1>><<thighskilluse>><<set $vaginaactiondefault to "penisthighs">><<combatpromiscuity4>>
<<if (1000 - ($rng * 10) - ($enemytrust * 10) - $thighskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>><<set $thighactiondefault to "rub">>
<<if $penis is "vaginaentrance">>
<span class="lblue">You <<thightext>> grab <<his1>> penis between your thighs.</span><<set $penis to "thighs">><<set $vaginause to 0>><<set $thighuse to "penis">><<thighstat>><<sex 5>><<set $vaginastate to 0>>
<<elseif $penis2 is "vaginaentrance">>
<span class="lblue">You <<thightext>> grab <<his2>> penis between your thighs.</span><<set $penis2 to "thighs">><<set $vaginause to 0>><<set $thighuse to "penis">><<thighstat>><<sex 5>><<set $vaginastate to 0>>
<<elseif $penis3 is "vaginaentrance">>
<span class="lblue">You <<thightext>> grab <<his3>> penis between your thighs.</span><<set $penis3 to "thighs">><<set $vaginause to 0>><<set $thighuse to "penis">><<thighstat>><<sex 5>><<set $vaginastate to 0>>
<<elseif $penis4 is "vaginaentrance">>
<span class="lblue">You <<thightext>> grab <<his4>> penis between your thighs.</span><<set $penis4 to "thighs">><<set $vaginause to 0>><<set $thighuse to "penis">><<thighstat>><<sex 5>><<set $vaginastate to 0>>
<<elseif $penis5 is "vaginaentrance">>
<span class="lblue">You <<thightext>> grab <<his5>> penis between your thighs.</span><<set $penis5 to "thighs">><<set $vaginause to 0>><<set $thighuse to "penis">><<thighstat>><<sex 5>><<set $vaginastate to 0>>
<<elseif $penis6 is "vaginaentrance">>
<span class="lblue">You <<thightext>> grab <<his6>> penis between your thighs.</span><<set $penis6 to "thighs">><<set $vaginause to 0>><<set $thighuse to "penis">><<thighstat>><<sex 5>><<set $vaginastate to 0>>
<</if>>
<<else>>
You try to hold <<a>> penis between your thighs, but <<theowner>> is intent on your pussy.
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<effectsvaginatopenis>>
<<set $rng to random(1, 100)>>
<<effectsvaginapenisfuck>>
<<if $vaginaaction is "rest">><<set $vaginaaction to 0>><<set $vaginaactiondefault to "rest">>
<</if>>
<<set $rng to random(1, 100)>>
<<if $vaginaaction is "penisanus">><<set $vaginaaction to 0>><<meek 5>><<analskilluse>><<set $vaginaactiondefault to "penisanus">>
<<if (1000 - ($rng * 10) - ($enemytrust * 10) - $analskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<<if $penis is "vaginaentrance">>
<span class="blue">You give your <<bottom>> a little wiggle, <<person1>>the <<combatperson>> responds to the provocation and moves <<his1>> penis in front of your butt.</span><<submission 2>><<set $anususe to "penis">><<set $penis to "anusentrance">><<set $vaginause to 0>><<set $anusstate to "entrance">><<set $vaginastate to 0>>
<<elseif $penis2 is "vaginaentrance">>
<span class="blue">You give your <<bottom>> a little wiggle, <<person2>>the <<combatperson>> responds to the provocation and moves <<his2>> penis in front of your butt.</span><<submission 2>><<set $anususe to "penis">><<set $penis2 to "anusentrance">><<set $vaginause to 0>><<set $anusstate to "entrance">><<set $vaginastate to 0>>
<<elseif $penis3 is "vaginaentrance">>
<span class="blue">You give your <<bottom>> a little wiggle, <<person3>>the <<combatperson>> responds to the provocation and moves <<his3>> penis in front of your butt.</span><<submission 2>><<set $anususe to "penis">><<set $penis3 to "anusentrance">><<set $vaginause to 0>><<set $anusstate to "entrance">><<set $vaginastate to 0>>
<<elseif $penis4 is "vaginaentrance">>
<span class="blue">You give your <<bottom>> a little wiggle, <<person4>>the <<combatperson>> responds to the provocation and moves <<his4>> penis in front of your butt.</span><<submission 2>><<set $anususe to "penis">><<set $penis4 to "anusentrance">><<set $vaginause to 0>><<set $anusstate to "entrance">><<set $vaginastate to 0>>
<<elseif $penis5 is "vaginaentrance">>
<span class="blue">You give your <<bottom>> a little wiggle, <<person5>>the <<combatperson>> responds to the provocation and moves <<his5>> penis in front of your butt.</span><<submission 2>><<set $anususe to "penis">><<set $penis5 to "anusentrance">><<set $vaginause to 0>><<set $anusstate to "entrance">><<set $vaginastate to 0>>
<<elseif $penis6 is "vaginaentrance">>
<span class="blue">You give your <<bottom>> a little wiggle, <<person6>>the <<combatperson>> responds to the provocation and moves <<his6>> penis in front of your butt.</span><<submission 2>><<set $anususe to "penis">><<set $penis6 to "anusentrance">><<set $vaginause to 0>><<set $anusstate to "entrance">><<set $vaginastate to 0>>
<</if>>
<<else>>You give your <<bottom>> a little wiggle, but you just receive a slap.<<violence 2>><<hitstat>><<bruise bottom>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $anusaction is "rest">><<set $anusaction to 0>><<set $anusactiondefault to "rest">>
<</if>>
<<if $anusaction is "penischeeks">><<set $anusaction to 0>><<meek 1>><<bottomskilluse>><<set $anusactiondefault to "penischeeks">><<combatpromiscuity4>>
<<if (1000 - ($rng * 10) - ($enemytrust * 10) - $bottomskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<<set $cheekactiondefault to "rub">>
<<if $penis is "anusentrance">>
<<set $penis to "cheeks">><<bottomstat>><<submission 2>><<set $bottomuse to "penis">><<set $anusstate to "cheeks">><span class="lblue">You <<bottomtext>> grab <<his>> penis between your butt cheeks.</span>
<<elseif $penis2 is "anusentrance">>
<<set $penis2 to "cheeks">><<bottomstat>><<submission 2>><<set $bottomuse to "penis">><<set $anusstate to "cheeks">><span class="lblue">You <<bottomtext>> grab <<his2>> penis between your butt cheeks.</span>
<<elseif $penis3 is "anusentrance">>
<<set $penis3 to "cheeks">><<bottomstat>><<submission 2>><<set $bottomuse to "penis">><<set $anusstate to "cheeks">><span class="lblue">You <<bottomtext>> grab <<his3>> penis between your butt cheeks.</span>
<<elseif $penis4 is "anusentrance">>
<<set $penis4 to "cheeks">><<bottomstat>><<submission 2>><<set $bottomuse to "penis">><<set $anusstate to "cheeks">><span class="lblue">You <<bottomtext>> grab <<his4>> penis between your butt cheeks.</span>
<<elseif $penis5 is "anusentrance">>
<<set $penis5 to "cheeks">><<bottomstat>><<submission 2>><<set $bottomuse to "penis">><<set $anusstate to "cheeks">><span class="lblue">You <<bottomtext>> grab <<his5>> penis between your butt cheeks.</span>
<<elseif $penis6 is "anusentrance">>
<<set $penis6 to "cheeks">><<bottomstat>><<submission 2>><<set $bottomuse to "penis">><<set $anusstate to "cheeks">><span class="lblue">You <<bottomtext>> grab <<his6>> penis between your butt cheeks.</span>
<</if>>
<<else>>
You try to grab <<a>> penis between your cheeks, but <<theowner>> isn't interested.
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $anusaction is "penispussy">><<set $anusaction to 0>><<meek 10>><<vaginalskilluse>><<set $anusactiondefault to "penispussy">>
<<if (1000 - ($rng * 10) - ($enemytrust * 10) - $vaginalskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<<if $penis is "anusentrance">>
<<submission 2>><<set $vaginause to "penis">><<set $penis to "vaginaentrance">><<set $anususe to 0>><<set $vaginastate to "entrance">><<set $anusstate to 0>><span class="lblue">You spread your thighs, giving clear access to your pussy. The <<person1>><<combatperson>> takes advantage and moves <<his1>> penis away from your butt.</span>
<<elseif $penis2 is "anusentrance">>
<<submission 2>><<set $vaginause to "penis">><<set $penis2 to "vaginaentrance">><<set $anususe to 0>><<set $vaginastate to "entrance">><<set $anusstate to 0>><span class="lblue">You spread your thighs, giving clear access to your pussy. The <<person2>><<combatperson>> takes advantage and moves <<his2>> penis away from your butt.</span>
<<elseif $penis3 is "anusentrance">>
<<submission 2>><<set $vaginause to "penis">><<set $penis3 to "vaginaentrance">><<set $anususe to 0>><<set $vaginastate to "entrance">><<set $anusstate to 0>><span class="lblue">You spread your thighs, giving clear access to your pussy. The <<person3>><<combatperson>> takes advantage and moves <<his3>> penis away from your butt.</span>
<<elseif $penis4 is "anusentrance">>
<<submission 2>><<set $vaginause to "penis">><<set $penis4 to "vaginaentrance">><<set $anususe to 0>><<set $vaginastate to "entrance">><<set $anusstate to 0>><span class="lblue">You spread your thighs, giving clear access to your pussy. The <<person4>><<combatperson>> takes advantage and moves <<his4>> penis away from your butt.</span>
<<elseif $penis5 is "anusentrance">>
<<submission 2>><<set $vaginause to "penis">><<set $penis5 to "vaginaentrance">><<set $anususe to 0>><<set $vaginastate to "entrance">><<set $anusstate to 0>><span class="lblue">You spread your thighs, giving clear access to your pussy. The <<person5>><<combatperson>> takes advantage and moves <<his5>> penis away from your butt.</span>
<<elseif $penis6 is "anusentrance">>
<<submission 2>><<set $vaginause to "penis">><<set $penis6 to "vaginaentrance">><<set $anususe to 0>><<set $vaginastate to "entrance">><<set $anusstate to 0>><span class="lblue">You spread your thighs, giving clear access to your pussy. The <<person6>><<combatperson>> takes advantage and moves <<his6>> penis away from your butt.</span>
<</if>>
<<else>>You spread your thighs, but fail to garner interest.
<</if>>
<</if>>
<<if $cheekaction is "rub">><<set $cheekaction to 0>><<bottomskilluse>><<set $cheekactiondefault to "rub">>
<<if (1000 - ($rng * 10) - ($enemytrust * 10) - $bottomskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<<actionscheekrub>><<set $cheekactiondefault to "rub">><<submission 3>><<bottomstat>>
<<else>><<set $cheekactiondefault to "cheeks">>
<<if $penis is "cheeks">>
<<set $penis to "anusentrance">><<set $bottomuse to 0>><<set $anusstate to "entrance">><span class="blue">You try to rub <<his1>> penis between your cheeks, but <<he>> is not interested.</span>
<<elseif $penis2 is "cheeks">>
<<set $penis2 to "anusentrance">><<set $bottomuse to 0>><<set $anusstate to "entrance">><span class="blue">You try to rub <<his2>> penis between your cheeks, but <<he>> is not interested.</span>
<<elseif $penis3 is "cheeks">>
<<set $penis3 to "anusentrance">><<set $bottomuse to 0>><<set $anusstate to "entrance">><span class="blue">You try to rub <<his3>> penis between your cheeks, but <<he>> is not interested.</span>
<<elseif $penis4 is "cheeks">>
<<set $penis4 to "anusentrance">><<set $bottomuse to 0>><<set $anusstate to "entrance">><span class="blue">You try to rub <<his4>> penis between your cheeks, but <<he>> is not interested.</span>
<<elseif $penis5 is "cheeks">>
<<set $penis5 to "anusentrance">><<set $bottomuse to 0>><<set $anusstate to "entrance">><span class="blue">You try to rub <<his5>> penis between your cheeks, but <<he>> is not interested.</span>
<<elseif $penis6 is "cheeks">>
<<set $penis6 to "anusentrance">><<set $bottomuse to 0>><<set $anusstate to "entrance">><span class="blue">You try to rub <<his6>> penis between your cheeks, but <<he>> is not interested.</span>
<</if>>
<</if>>
<</if>>
<<if $cheekaction is "stop">><<set $cheekaction to 0>><<set $cheekactiondefault to "stop">>
<<if $penis is "cheeks">>
<<set $penis to "anusentrance">><<set $bottomuse to 0>><<set $anusstate to "entrance">><span class="blue">You stop holding <<his1>> penis between your cheeks. <<He>> angles toward your anus.</span>
<<elseif $penis2 is "cheeks">>
<<set $penis2 to "anusentrance">><<set $bottomuse to 0>><<set $anusstate to "entrance">><span class="blue">You stop holding <<his2>> penis between your cheeks. <<He>> angles toward your anus.</span>
<<elseif $penis3 is "cheeks">>
<<set $penis3 to "anusentrance">><<set $bottomuse to 0>><<set $anusstate to "entrance">><span class="blue">You stop holding <<his3>> penis between your cheeks. <<He>> angles toward your anus.</span>
<<elseif $penis4 is "cheeks">>
<<set $penis4 to "anusentrance">><<set $bottomuse to 0>><<set $anusstate to "entrance">><span class="blue">You stop holding <<his4>> penis between your cheeks. <<He>> angles toward your anus.</span>
<<elseif $penis5 is "cheeks">>
<<set $penis5 to "anusentrance">><<set $bottomuse to 0>><<set $anusstate to "entrance">><span class="blue">You stop holding <<his5>> penis between your cheeks. <<He>> angles toward your anus.</span>
<<elseif $penis6 is "cheeks">>
<<set $penis6 to "anusentrance">><<set $bottomuse to 0>><<set $anusstate to "entrance">><span class="blue">You stop holding <<his6>> penis between your cheeks. <<He>> angles toward your anus.</span>
<</if>>
<</if>>
<<if $anusaction is "penistease">><<set $anusactiondefault to "penistease">><<set $cheekaction to 0>>You tease the tip of the penis with your <<bottomstop>><<sex 3>><<analskilluse>>
<</if>>
<<if $thighaction is "rub">><<set $thighaction to 0>><<thighskilluse>><<set $thighactiondefault to "rub">>
<<if (1000 - ($rng * 10) - ($enemytrust * 10) - $thighskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>><<set $thighactiondefault to "rub">>
<<actionsthighrub>><<thighstat>><<sex 5>>
<<else>><<set $thighactiondefault to "thighs">>
<<set $thighuse to 0>>
<<if $vaginause is 0>><<set $vaginause to "penis">>
<<if $penis is "thighs">>
<<set $penis to "vaginaentrance">><<set $vaginastate to "entrance">><span class="blue">You try to hold <<his1>> penis between your thighs, but <<he>> instead angles it towards your <<genitalsstop>></span>
<<elseif $penis2 is "thighs">>
<<set $penis2 to "vaginaentrance">><<set $vaginastate to "entrance">><span class="blue">You try to hold <<his2>> penis between your thighs, but <<he>> instead angles it towards your <<genitalsstop>></span>
<<elseif $penis3 is "thighs">>
<<set $penis3 to "vaginaentrance">><<set $vaginastate to "entrance">><span class="blue">You try to hold <<his3>> penis between your thighs, but <<he>> instead angles it towards your <<genitalsstop>></span>
<<elseif $penis4 is "thighs">>
<<set $penis4 to "vaginaentrance">><<set $vaginastate to "entrance">><span class="blue">You try to hold <<his4>> penis between your thighs, but <<he>> instead angles it towards your <<genitalsstop>></span>
<<elseif $penis5 is "thighs">>
<<set $penis5 to "vaginaentrance">><<set $vaginastate to "entrance">><span class="blue">You try to hold <<his5>> penis between your thighs, but <<he>> instead angles it towards your <<genitalsstop>></span>
<<elseif $penis5 is "thighs">>
<<set $penis6 to "vaginaentrance">><<set $vaginastate to "entrance">><span class="blue">You try to hold <<his6>> penis between your thighs, but <<he>> instead angles it towards your <<genitalsstop>></span>
<</if>>
<<else>>
<<if $penis is "thighs">>
<<set $penis to 0>><span class="blue">You try to hold <<his1>> penis between your thighs, but <<he>> moves it away.</span>
<<elseif $penis2 is "thighs">>
<<set $penis2 to 0>><span class="blue">You try to hold <<his1>> penis between your thighs, but <<he>> moves it away.</span>
<<elseif $penis3 is "thighs">>
<<set $penis3 to 0>><span class="blue">You try to hold <<his1>> penis between your thighs, but <<he>> moves it away.</span>
<<elseif $penis4 is "thighs">>
<<set $penis4 to 0>><span class="blue">You try to hold <<his1>> penis between your thighs, but <<he>> moves it away.</span>
<<elseif $penis5 is "thighs">>
<<set $penis5 to 0>><span class="blue">You try to hold <<his1>> penis between your thighs, but <<he>> moves it away.</span>
<<elseif $penis6 is "thighs">>
<<set $penis6 to 0>><span class="blue">You try to hold <<his1>> penis between your thighs, but <<he>> moves it away.</span>
<</if>>
<</if>>
<</if>>
<</if>>
<<if $thighaction is "stop">><<set $thighaction to 0>><<set $thighactiondefault to "stop">>You stop holding <<his>> penis between your thighs.<<set $thighuse to 0>>
<<if $vaginause is 0>>
<<if $penis is "thighs">>
<<set $penis to "vaginaentrance">><<set $vaginastate to "entrance">><span class="blue"><<He>> angles towards your <<genitalsstop>></span>
<<elseif $penis2 is "thighs">>
<<set $penis2 to "vaginaentrance">><<set $vaginastate to "entrance">><span class="blue"><<He>> angles towards your <<genitalsstop>></span>
<<elseif $penis3 is "thighs">>
<<set $penis3 to "vaginaentrance">><<set $vaginastate to "entrance">><span class="blue"><<He>> angles towards your <<genitalsstop>></span>
<<elseif $penis4 is "thighs">>
<<set $penis4 to "vaginaentrance">><<set $vaginastate to "entrance">><span class="blue"><<He>> angles towards your <<genitalsstop>></span>
<<elseif $penis5 is "thighs">>
<<set $penis5 to "vaginaentrance">><<set $vaginastate to "entrance">><span class="blue"><<He>> angles towards your <<genitalsstop>></span>
<<elseif $penis5 is "thighs">>
<<set $penis5 to "vaginaentrance">><<set $vaginastate to "entrance">><span class="blue"><<He>> angles towards your <<genitalsstop>></span>
<</if>>
<<else>>
<<if $penis is "thighs">>
<<set $penis to 0>>
<<elseif $penis2 is "thighs">>
<<set $penis2 to 0>>
<<elseif $penis3 is "thighs">>
<<set $penis3 to 0>>
<<elseif $penis4 is "thighs">>
<<set $penis4 to 0>>
<<elseif $penis5 is "thighs">>
<<set $penis5 to 0>>
<<elseif $penis6 is "thighs">>
<<set $penis6 to 0>>
<</if>>
<</if>>
<</if>>
<<if $vaginaaction is "penistease">><<set $vaginaaction to 0>><<set $vaginaactiondefault to "penistease">><<actionspenistip>><<sex 5>><<vaginalskilluse>>
<</if>>
<<if $vaginaaction is "rub">><<set $vaginaaction to 0>><<set $vaginaactiondefault to "rub">><<actionspenisrub>><<sex 10>><<vaginalskilluse>>
<</if>>
<<if $vaginaaction is "cooperate">><<set $vaginaaction to 0>><<set $vaginaactiondefault to "cooperate">><<actionspenisride>><<submission 20>><<vaginalskilluse>>
<</if>>
<<if $vaginaaction is "take">><<set $vaginaaction to 0>><<set $vaginaactiondefault to "take">><<actionspenistake>>
<</if>>
<<if $vaginaaction is "escape">><<set $vaginaaction to 0>><<set $vaginaactiondefault to "escape">><<actionsvaginaescape>><<brat 10>><<set $vaginause to "penis">><<set $vaginastate to "entrance">>
<<if $penis is "vaginaimminent">>
<<set $penis to "vaginaentrance">><<set $speechvaginaescape1 to 1>>
<<elseif $penis2 is "vaginaimminent">>
<<set $penis2 to "vaginaentrance">><<set $speechvaginaescape2 to 1>>
<<elseif $penis3 is "vaginaimminent">>
<<set $penis3 to "vaginaentrance">><<set $speechvaginaescape3 to 1>>
<<elseif $penis4 is "vaginaimminent">>
<<set $penis4 to "vaginaentrance">><<set $speechvaginaescape4 to 1>>
<<elseif $penis5 is "vaginaimminent">>
<<set $penis5 to "vaginaentrance">><<set $speechvaginaescape5 to 1>>
<<elseif $penis6 is "vaginaimminent">>
<<set $penis6 to "vaginaentrance">><<set $speechvaginaescape6 to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<effectspenistovagina>>
<<set $rng to random(1, 100)>>
<<effectspenisvaginafuck>>
<<set $rng to random(1, 100)>>
<<effectspenisanusfuck>>
<<set $rng to random(1, 100)>>
<<effectspenistoanus>>
<<if $penisaction is "rest">><<set $penisaction to 0>><<set $penisactiondefault to "rest">>
<</if>>
<<if $penisaction is "bay">><<set $penisaction to 0>><<meek 1>><<penileskilluse>><<set $penisactiondefault to "bay">><<combatpromiscuity4>>
<<if (1000 - ($rng * 10) - ($enemytrust * 10) - $penileskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>><<set $penisactiondefault to "rub">>
<<if $vagina is "penisentrance">>
<span class="lblue">You <<peniletext>> press your penis against <<his1>> clit.</span><<set $vagina to "frot">><<set $penisuse to "clit">><<penilestat>><<sex 5>><<set $penisstate to "clit">>
<<elseif $vagina2 is "penisentrance">>
<span class="lblue">You <<peniletext>> press your <<penis>> against <<his2>> clit.</span><<set $vagina2 to "frot">><<set $penisuse to "clit">><<penilestat>><<sex 5>><<set $penisstate to "clit">>
<<elseif $vagina3 is "penisentrance">>
<span class="lblue">You <<peniletext>> press your <<penis>> against <<his3>> clit.</span><<set $vagina3 to "frot">><<set $penisuse to "clit">><<penilestat>><<sex 5>><<set $penisstate to "clit">>
<<elseif $vagina4 is "penisentrance">>
<span class="lblue">You <<peniletext>> press your <<penis>> against <<his4>> clit.</span><<set $vagina4 to "frot">><<set $penisuse to "clit">><<penilestat>><<sex 5>><<set $penisstate to "clit">>
<<elseif $vagina5 is "penisentrance">>
<span class="lblue">You <<peniletext>> press your <<penis>> against <<his5>> clit.</span><<set $vagina5 to "frot">><<set $penisuse to "clit">><<penilestat>><<sex 5>><<set $penisstate to "clit">>
<<elseif $vagina6 is "penisentrance">>
<span class="lblue">You <<peniletext>> press your <<penis>> against <<his6>> clit.</span><<set $vagina6 to "frot">><<set $penisuse to "clit">><<penilestat>><<sex 5>><<set $penisstate to "clit">>
<</if>>
<<else>>
You try to keep the vagina menacing your <<penis>> at bay by rubbing against the clit, but <<theowner>> has other ideas.
<</if>>
<</if>>
<<if $penisaction is "clitrub">><<set $penisaction to 0>><<set $penisactiondefault to "rub">><<penileskilluse>>
<<if (1000 - ($rng * 10) - ($enemytrust * 10) - $penileskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>><<set $penisactiondefault to "rub">><<penilestat>><<sex 5>>
<<actionsclitrub>>
<<else>><<set $penisactiondefault to "bay">>
<<set $penisuse to "othervagina">><<set $penisstate to "entrance">>
<<if $vagina is "frot">>
<<set $vagina to "penisentrance">><span class="blue">You rub your <<penis>> against <<his1>> clit, but <<he>> would prefer the main course and moves <<his>> labia closer to your tip.</span>
<<elseif $vagina2 is "frot">>
<<set $vagina2 to "penisentrance">><span class="blue">You rub your <<penis>> against <<his2>> clit, but <<he>> would prefer the main course and moves <<his>> labia closer to your tip.</span>
<<elseif $vagina3 is "frot">>
<<set $vagina3 to "penisentrance">><span class="blue">You rub your <<penis>> against <<his3>> clit, but <<he>> would prefer the main course and moves <<his>> labia closer to your tip.</span>
<<elseif $vagina4 is "frot">>
<<set $vagina4 to "penisentrance">><span class="blue">You rub your <<penis>> against <<his4>> clit, but <<he>> would prefer the main course and moves <<his>> labia closer to your tip.</span>
<<elseif $vagina5 is "frot">>
<<set $vagina5 to "penisentrance">><span class="blue">You rub your <<penis>> against <<his5>> clit, but <<he>> would prefer the main course and moves <<his>> labia closer to your tip.</span>
<<elseif $vagina6 is "frot">>
<<set $vagina6 to "penisentrance">><span class="blue">You rub your <<penis>> against <<his6>> clit, but <<he>> would prefer the main course and moves <<his>> labia closer to your tip.</span>
<</if>>
<</if>>
<</if>>
<<if $penisaction is "stop">><<set $penisaction to 0>><<set $penisactiondefault to "stop">>
<<if $vagina is "bay">>
<<set $vagina to "penisentrance">><<set $penisstate to "entrance">><<set $penisuse to "othervagina">><span class="blue">You stop rubbing <<his1>> clit with your <<penisstop>></span>
<<elseif $vagina2 is "bay">>
<<set $vagina2 to "penisentrance">><<set $penisstate to "entrance">><<set $penisuse to "othervagina">><span class="blue">You stop rubbing <<his2>> clit with your <<penisstop>></span>
<<elseif $vagina3 is "bay">>
<<set $vagina3 to "penisentrance">><<set $penisstate to "entrance">><<set $penisuse to "othervagina">><span class="blue">You stop rubbing <<his3>> clit with your <<penisstop>></span>
<<elseif $vagina4 is "bay">>
<<set $vagina4 to "penisentrance">><<set $penisstate to "entrance">><<set $penisuse to "othervagina">><span class="blue">You stop rubbing <<his4>> clit with your <<penisstop>></span>
<<elseif $vagina5 is "bay">>
<<set $vagina5 to "penisentrance">><<set $penisstate to "entrance">><<set $penisuse to "othervagina">><span class="blue">You stop rubbing <<his5>> clit with your <<penisstop>></span>
<<elseif $vagina6 is "bay">>
<<set $vagina6 to "penisentrance">><<set $penisstate to "entrance">><<set $penisuse to "othervagina">><span class="blue">You stop rubbing <<his6>> clit with your <<penisstop>></span>
<</if>>
<</if>>
<<if $penisaction is "tease">><<set $penisaction to 0>><<set $penisactiondefault to "tease">><<actionspussytease>><<sex 5>><<penileskilluse>>
<</if>>
<<if $penisaction is "rub">><<set $penisaction to 0>><<set $penisactiondefault to "rub">><<actionspussyrub>><<sex 10>><<penileskilluse>>
<</if>>
<<if $penisaction is "cooperate">><<set $penisaction to 0>><<set $penisactiondefault to "cooperate">><<actionspussythrust>><<submission 20>><<penileskilluse>>
<</if>>
<<if $penisaction is "take">><<set $penisaction to 0>><<set $penisactiondefault to "take">><<actionspussytake>>
<</if>>
<<if $penisaction is "escape">><<set $penisaction to 0>><<set $penisactiondefault to "escape">><<actionspenisescape>><<brat 10>><<set $penisuse to "othervagina">><<set $penisstate to "entrance">>
<<if $vagina is "penisimminent">>
<<set $vagina to "penisentrance">><<set $speechpenisescape1 to 1>>
<<elseif $vagina2 is "penisimminent">>
<<set $vagina2 to "penisentrance">><<set $speechpenisescape2 to 1>>
<<elseif $vagina3 is "penisimminent">>
<<set $vagina3 to "penisentrance">><<set $speechpenisescape3 to 1>>
<<elseif $vagina4 is "penisimminent">>
<<set $vagina4 to "penisentrance">><<set $speechpenisescape4 to 1>>
<<elseif $vagina5 is "penisimminent">>
<<set $vagina5 to "penisentrance">><<set $speechpenisescape5 to 1>>
<<elseif $vagina6 is "penisimminent">>
<<set $vagina6 to "penisentrance">><<set $speechpenisescape6 to 1>>
<</if>>
<</if>>
<<if $vaginaaction is "thighbay">><<set $vaginaaction to 0>><<meek 1>><<thighskilluse>><<set $vaginaactiondefault to "thighbay">><<combatpromiscuity1>>
<<if (1000 - ($rng * 10) - ($enemytrust * 10) - $thighskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>><<set $thighactiondefault to "othermouthrub">>
<<if $mouth is "vaginaentrance">>
<span class="lblue">You <<thightext>> press your thigh against <<his1>> mouth.</span><<set $mouth to "thigh">><<set $vaginause to 0>><<thighstat>><<neutral 5>><<set $vaginastate to 0>><<set $thighuse to "mouth">>
<<elseif $mouth2 is "vaginaentrance">>
<span class="lblue">You <<thightext>> press your thigh against <<his2>> mouth.</span><<set $mouth2 to "thigh">><<set $vaginause to 0>><<thighstat>><<neutral 5>><<set $vaginastate to 0>><<set $thighuse to "mouth">>
<<elseif $mouth3 is "vaginaentrance">>
<span class="lblue">You <<thightext>> press your thigh against <<his3>> mouth.</span><<set $mouth3 to "thigh">><<set $vaginause to 0>><<thighstat>><<neutral 5>><<set $vaginastate to 0>><<set $thighuse to "mouth">>
<<elseif $mouth4 is "vaginaentrance">>
<span class="lblue">You <<thightext>> press your thigh against <<his4>> mouth.</span><<set $mouth4 to "thigh">><<set $vaginause to 0>><<thighstat>><<neutral 5>><<set $vaginastate to 0>><<set $thighuse to "mouth">>
<<elseif $mouth5 is "vaginaentrance">>
<span class="lblue">You <<thightext>> press your thigh against <<his5>> mouth.</span><<set $mouth5 to "thigh">><<set $vaginause to 0>><<thighstat>><<neutral 5>><<set $vaginastate to 0>><<set $thighuse to "mouth">>
<<elseif $mouth6 is "vaginaentrance">>
<span class="lblue">You <<thightext>> press your thigh against <<his6>> mouth.</span><<set $mouth6 to "thigh">><<set $vaginause to 0>><<thighstat>><<neutral 5>><<set $vaginastate to 0>><<set $thighuse to "mouth">>
<</if>>
<<else>>
You try to keep the mouth menacing your <<pussy>> at bay by pressing your thigh against it, but <<theowner>> has other ideas.
<</if>>
<</if>>
<<if $vaginaaction is "othermouthtease">><<set $vaginaaction to 0>><<set $vaginaactiondefault to "othermouthtease">><<actionsothermouthvaginatease>><<sex 5>><<vaginalskilluse>>
<</if>>
<<if $vaginaaction is "othermouthrub">><<set $vaginaaction to 0>><<set $vaginaactiondefault to "othermouthrub">><<actionsothermouthvaginarub>><<sex 10>><<vaginalskilluse>>
<</if>>
<<if $vaginaaction is "othermouthcooperate">><<set $vaginaaction to 0>><<set $vaginaactiondefault to "othermouthcooperate">><<actionsothermouthvaginathrust>><<submission 20>><<vaginalskilluse>>
<</if>>
<<if $vaginaaction is "othermouthescape">><<set $vaginaaction to 0>><<set $vaginaactiondefault to "othermouthescape">><<actionsothermouthvaginaescape>><<brat 10>><<set $vaginause to "othermouth">><<set $vaginastate to "othermouthentrance">>
<<if $mouth is "vaginaimminent">>
<<set $mouth to "vaginaentrance">>
<<elseif $mouth2 is "vaginaimminent">>
<<set $mouth2 to "vaginaentrance">>
<<elseif $mouth3 is "vaginaimminent">>
<<set $mouth3 to "vaginaentrance">>
<<elseif $mouth4 is "vaginaimminent">>
<<set $mouth4 to "vaginaentrance">>
<<elseif $mouth5 is "vaginaimminent">>
<<set $mouth5 to "vaginaentrance">>
<<elseif $mouth6 is "vaginaimminent">>
<<set $mouth6 to "vaginaentrance">>
<</if>>
<</if>>
<<if $thighaction is "othermouthrub">><<set $thighaction to 0>><<set $thighactiondefault to "othermouthrub">><<thighskilluse>>
<<if (1000 - ($rng * 10) - ($enemytrust * 10) - $thighskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>><<set $thighactiondefault to "othermouthrub">><<thighstat>><<sex 5>>
<<actionsmouththighrub>>
<<else>>
<<if $penisuse is 0>><<set $penisuse to "othermouth">><<set $penisstate to "othermouthentrance">><<set $penisactiondefault to "thighbay">><<set $thighuse to 0>>
<<if $mouth is "thigh">>
<<set $mouth to "penisentrance">><span class="blue">You press your thigh against <<his1>> mouth, but <<he>> would prefer the main course and moves <<his>> head closer to your <<penisstop>></span>
<<elseif $mouth2 is "thigh">>
<<set $mouth2 to "penisentrance">><span class="blue">You press your thigh against <<his2>> mouth, but <<he>> would prefer the main course and moves <<his>> head closer to your <<penisstop>></span>
<<elseif $mouth3 is "thigh">>
<<set $mouth3 to "penisentrance">><span class="blue">You press your thigh against <<his3>> mouth, but <<he>> would prefer the main course and moves <<his>> head closer to your <<penisstop>></span>
<<elseif $mouth4 is "thigh">>
<<set $mouth4 to "penisentrance">><span class="blue">You press your thigh against <<his4>> mouth, but <<he>> would prefer the main course and moves <<his>> head closer to your <<penisstop>></span>
<<elseif $mouth5 is "thigh">>
<<set $mouth5 to "penisentrance">><span class="blue">You press your thigh against <<his5>> mouth, but <<he>> would prefer the main course and moves <<his>> head closer to your <<penisstop>></span>
<<elseif $mouth6 is "thigh">>
<<set $mouth6 to "penisentrance">><span class="blue">You press your thigh against <<his6>> mouth, but <<he>> would prefer the main course and moves <<his>> head closer to your <<penisstop>></span>
<</if>>
<<elseif $vaginause is 0>><<set $vaginause to "othermouth">><<set $vaginastate to "othermouthentrance">><<set $vaginaactiondefault to "thighbay">><<set $thighuse to 0>>
<<if $mouth is "thigh">>
<<set $mouth to "vaginaentrance">><span class="blue">You press your thigh against <<his1>> mouth, but <<he>> would prefer the main course and moves <<his>> head closer to your <<pussystop>></span>
<<elseif $mouth2 is "thigh">>
<<set $mouth2 to "vaginaentrance">><span class="blue">You press your thigh against <<his2>> mouth, but <<he>> would prefer the main course and moves <<his>> head closer to your <<pussystop>></span>
<<elseif $mouth3 is "thigh">>
<<set $mouth3 to "vaginaentrance">><span class="blue">You press your thigh against <<his3>> mouth, but <<he>> would prefer the main course and moves <<his>> head closer to your <<pussystop>></span>
<<elseif $mouth4 is "thigh">>
<<set $mouth4 to "vaginaentrance">><span class="blue">You press your thigh against <<his4>> mouth, but <<he>> would prefer the main course and moves <<his>> head closer to your <<pussystop>></span>
<<elseif $mouth5 is "thigh">>
<<set $mouth5 to "vaginaentrance">><span class="blue">You press your thigh against <<his5>> mouth, but <<he>> would prefer the main course and moves <<his>> head closer to your <<pussystop>></span>
<<elseif $mouth6 is "thigh">>
<<set $mouth6 to "vaginaentrance">><span class="blue">You press your thigh against <<his6>> mouth, but <<he>> would prefer the main course and moves <<his>> head closer to your <<pussystop>></span>
<</if>>
<<else>>
<<if $mouth is "thigh">>
<<if $penis is "othermouth">>
<<set $penis to 0>>
<</if>>
<<if $vagina is "othermouth">>
<<set $vagina to 0>>
<</if>>
<span class="lblue">You press your thigh against <<his1>> mouth, but <<he>> moves <<his>> head away from you.</span><<set $mouth to 0>><<set $thighuse to 0>>
<<elseif $mouth2 is "thigh">>
<<if $penis2 is "othermouth">>
<<set $penis2 to 0>>
<</if>>
<<if $vagina2 is "othermouth">>
<<set $vagina2 to 0>>
<</if>>
<span class="lblue">You press your thigh against <<his2>> mouth, but <<he>> moves <<his>> head away from you.</span><<set $mouth2 to 0>><<set $thighuse to 0>>
<<elseif $mouth3 is "thigh">>
<<if $penis3 is "othermouth">>
<<set $penis3 to 0>>
<</if>>
<<if $vagina3 is "othermouth">>
<<set $vagina3 to 0>>
<</if>>
<span class="lblue">You press your thigh against <<his3>> mouth, but <<he>> moves <<his>> head away from you.</span><<set $mouth3 to 0>><<set $thighuse to 0>>
<<elseif $mouth4 is "thigh">>
<<if $penis4 is "othermouth">>
<<set $penis4 to 0>>
<</if>>
<<if $vagina4 is "othermouth">>
<<set $vagina4 to 0>>
<</if>>
<span class="lblue">You press your thigh against <<his4>> mouth, but <<he>> moves <<his>> head away from you.</span><<set $mouth4 to 0>><<set $thighuse to 0>>
<<elseif $mouth5 is "thigh">>
<<if $penis5 is "othermouth">>
<<set $penis5 to 0>>
<</if>>
<<if $vagina5 is "othermouth">>
<<set $vagina5 to 0>>
<</if>>
<span class="lblue">You press your thigh against <<his5>> mouth, but <<he>> moves <<his>> head away from you.</span><<set $mouth5 to 0>><<set $thighuse to 0>>
<<elseif $mouth6 is "thigh">>
<<if $penis6 is "othermouth">>
<<set $penis6 to 0>>
<</if>>
<<if $vagina6 is "othermouth">>
<<set $vagina6 to 0>>
<</if>>
<span class="lblue">You press your thigh against <<his6>> mouth, but <<he>> moves <<his>> head away from you.</span><<set $mouth6 to 0>><<set $thighuse to 0>>
<</if>>
<</if>>
<</if>>
<</if>>
<<if $thighaction is "othermouthstop">><<set $thighaction to 0>><<set $thighactiondefault to "stop">><<set $thighuse to 0>>
<<if $penisuse is 0>>
<<if $mouth is "thigh">>
<<set $mouth to "penisentrance">><<set $penisstate to "othermouthentrance">><<set $penisuse to "othermouth">><span class="blue">You stop pressing your thigh against <<his1>> mouth.</span>
<<elseif $mouth2 is "thigh">>
<<set $mouth2 to "penisentrance">><<set $penisstate to "othermouthentrance">><<set $penisuse to "othermouth">><span class="blue">You stop pressing your thigh against <<his2>> mouth.</span>
<<elseif $mouth3 is "thigh">>
<<set $mouth3 to "penisentrance">><<set $penisstate to "othermouthentrance">><<set $penisuse to "othermouth">><span class="blue">You stop pressing your thigh against <<his3>> mouth.</span>
<<elseif $mouth4 is "thigh">>
<<set $mouth4 to "penisentrance">><<set $penisstate to "othermouthentrance">><<set $penisuse to "othermouth">><span class="blue">You stop pressing your thigh against <<his4>> mouth.</span>
<<elseif $mouth5 is "thigh">>
<<set $mouth5 to "penisentrance">><<set $penisstate to "othermouthentrance">><<set $penisuse to "othermouth">><span class="blue">You stop pressing your thigh against <<his5>> mouth.</span>
<<elseif $mouth6 is "thigh">>
<<set $mouth6 to "penisentrance">><<set $penisstate to "othermouthentrance">><<set $penisuse to "othermouth">><span class="blue">You stop pressing your thigh against <<his6>> mouth.</span>
<</if>>
<<elseif $vaginause is 0>>
<<if $mouth is "thigh">>
<<set $mouth to "vaginaentrance">><<set $vaginastate to "othermouthentrance">><<set $vaginause to "othermouth">><span class="blue">You stop pressing your thigh against <<his1>> mouth.</span>
<<elseif $mouth2 is "thigh">>
<<set $mouth2 to "vaginaentrance">><<set $vaginastate to "othermouthentrance">><<set $vaginause to "othermouth">><span class="blue">You stop pressing your thigh against <<his2>> mouth.</span>
<<elseif $mouth3 is "thigh">>
<<set $mouth3 to "vaginaentrance">><<set $vaginastate to "othermouthentrance">><<set $vaginause to "othermouth">><span class="blue">You stop pressing your thigh against <<his3>> mouth.</span>
<<elseif $mouth4 is "thigh">>
<<set $mouth4 to "vaginaentrance">><<set $vaginastate to "othermouthentrance">><<set $vaginause to "othermouth">><span class="blue">You stop pressing your thigh against <<his4>> mouth.</span>
<<elseif $mouth5 is "thigh">>
<<set $mouth5 to "vaginaentrance">><<set $vaginastate to "othermouthentrance">><<set $vaginause to "othermouth">><span class="blue">You stop pressing your thigh against <<his5>> mouth.</span>
<<elseif $mouth6 is "thigh">>
<<set $mouth6 to "vaginaentrance">><<set $vaginastate to "othermouthentrance">><<set $vaginause to "othermouth">><span class="blue">You stop pressing your thigh against <<his6>> mouth.</span>
<</if>>
<<else>>
<<if $mouth is "thigh">>
<<if $penis is "othermouth">>
<<set $penis to 0>>
<</if>>
<<if $vagina is "othermouth">>
<<set $vagina to 0>>
<</if>>
<<set $mouth to 0>><span class="blue">You stop pressing your thigh against <<his1>> mouth.</span>
<<elseif $mouth2 is "thigh">>
<<if $penis2 is "othermouth">>
<<set $penis2 to 0>>
<</if>>
<<if $vagina2 is "othermouth">>
<<set $vagina2 to 0>>
<</if>>
<<set $mouth2 to 0>><span class="blue">You stop pressing your thigh against <<his2>> mouth.</span>
<<elseif $mouth3 is "thigh">>
<<if $penis3 is "othermouth">>
<<set $penis3 to 0>>
<</if>>
<<if $vagina3 is "othermouth">>
<<set $vagina3 to 0>>
<</if>>
<<set $mouth3 to 0>><span class="blue">You stop pressing your thigh against <<his3>> mouth.</span>
<<elseif $mouth4 is "thigh">>
<<if $penis4 is "othermouth">>
<<set $penis4 to 0>>
<</if>>
<<if $vagina4 is "othermouth">>
<<set $vagina4 to 0>>
<</if>>
<<set $mouth4 to 0>><span class="blue">You stop pressing your thigh against <<his4>> mouth.</span>
<<elseif $mouth5 is "thigh">>
<<if $penis5 is "othermouth">>
<<set $penis5 to 0>>
<</if>>
<<if $vagina5 is "othermouth">>
<<set $vagina5 to 0>>
<</if>>
<<set $mouth5 to 0>><span class="blue">You stop pressing your thigh against <<his5>> mouth.</span>
<<elseif $mouth6 is "thigh">>
<<if $penis6 is "othermouth">>
<<set $penis6 to 0>>
<</if>>
<<if $vagina6 is "othermouth">>
<<set $vagina6 to 0>>
<</if>>
<<set $mouth6 to 0>><span class="blue">You stop pressing your thigh against <<his6>> mouth.</span>
<</if>>
<</if>>
<</if>>
<<if $penisaction is "thighbay">><<set $penisaction to 0>><<meek 1>><<thighskilluse>><<set $penisactiondefault to "thighbay">><<combatpromiscuity1>>
<<if (1000 - ($rng * 10) - ($enemytrust * 10) - $thighskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>><<set $thighactiondefault to "othermouthrub">>
<<if $mouth is "penisentrance">>
<span class="lblue">You <<thightext>> press your thigh against <<his1>> mouth.</span><<set $mouth to "thigh">><<set $penisuse to 0>><<thighstat>><<neutral 5>><<set $penisstate to 0>><<set $thighuse to "mouth">>
<<elseif $mouth2 is "penisentrance">>
<span class="lblue">You <<thightext>> press your thigh against <<his2>> mouth.</span><<set $mouth2 to "thigh">><<set $penisuse to 0>><<thighstat>><<neutral 5>><<set $penisstate to 0>><<set $thighuse to "mouth">>
<<elseif $mouth3 is "penisentrance">>
<span class="lblue">You <<thightext>> press your thigh against <<his3>> mouth.</span><<set $mouth3 to "thigh">><<set $penisuse to 0>><<thighstat>><<neutral 5>><<set $penisstate to 0>><<set $thighuse to "mouth">>
<<elseif $mouth4 is "penisentrance">>
<span class="lblue">You <<thightext>> press your thigh against <<his4>> mouth.</span><<set $mouth4 to "thigh">><<set $penisuse to 0>><<thighstat>><<neutral 5>><<set $penisstate to 0>><<set $thighuse to "mouth">>
<<elseif $mouth5 is "penisentrance">>
<span class="lblue">You <<thightext>> press your thigh against <<his5>> mouth.</span><<set $mouth5 to "thigh">><<set $penisuse to 0>><<thighstat>><<neutral 5>><<set $penisstate to 0>><<set $thighuse to "mouth">>
<<elseif $mouth6 is "penisentrance">>
<span class="lblue">You <<thightext>> press your thigh against <<his6>> mouth.</span><<set $mouth6 to "thigh">><<set $penisuse to 0>><<thighstat>><<neutral 5>><<set $penisstate to 0>><<set $thighuse to "mouth">>
<</if>>
<<else>>
You try to keep the mouth menacing your <<penis>> at bay by pressing your thigh against it, but <<theowner>> has other ideas.
<</if>>
<</if>>
<<if $penisaction is "othermouthtease">><<set $penisaction to 0>><<set $penisactiondefault to "othermouthtease">><<actionsothermouthpenistease>><<sex 5>><<penileskilluse>>
<</if>>
<<if $penisaction is "othermouthrub">><<set $penisaction to 0>><<set $penisactiondefault to "othermouthrub">><<actionsothermouthpenisrub>><<sex 10>><<penileskilluse>>
<</if>>
<<if $penisaction is "othermouthcooperate">><<set $penisaction to 0>><<set $penisactiondefault to "othermouthcooperate">><<actionsothermouthpenisthrust>><<submission 20>><<penileskilluse>>
<</if>>
<<if $penisaction is "othermouthescape">><<set $penisaction to 0>><<set $penisactiondefault to "othermouthescape">><<actionsothermouthpenisescape>><<brat 10>><<set $penisuse to "othermouth">><<set $penisstate to "othermouthentrance">>
<<if $mouth is "penisimminent">>
<<set $mouth to "penisentrance">>
<<elseif $mouth2 is "penisimminent">>
<<set $mouth2 to "penisentrance">>
<<elseif $mouth3 is "penisimminent">>
<<set $mouth3 to "penisentrance">>
<<elseif $mouth4 is "penisimminent">>
<<set $mouth4 to "penisentrance">>
<<elseif $mouth5 is "penisimminent">>
<<set $mouth5 to "penisentrance">>
<<elseif $mouth6 is "penisimminent">>
<<set $mouth6 to "penisentrance">>
<</if>>
<</if>>
<<if $cheekaction is "othermouthrub">><<set $cheekaction to 0>><<set $cheekactiondefault to "othermouthrub">><<bottomskilluse>>
<<if (1000 - ($rng * 10) - ($enemytrust * 10) - $bottomskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>><<set $cheekactiondefault to "othermouthrub">><<bottomstat>><<sex 5>>
<<actionsmouthbottomrub>>
<<else>>
<<if $anususe is 0>><<set $anususe to "othermouth">><<set $anusstate to "othermouthentrance">><<set $anusactiondefault to "bottombay">><<set $bottomuse to 0>>
<<if $mouth is "bottom">>
<<set $mouth to "anusentrance">><span class="blue">You press your <<bottom>> against <<his1>> mouth, but instead <<he>> moves <<his>> head between your cheeks.</span>
<<elseif $mouth2 is "bottom">>
<<set $mouth2 to "anusentrance">><span class="blue">You press your <<bottom>> against <<his2>> mouth, but instead <<he>> moves <<his>> head between your cheeks.</span>
<<elseif $mouth3 is "bottom">>
<<set $mouth3 to "anusentrance">><span class="blue">You press your <<bottom>> against <<his3>> mouth, but instead <<he>> moves <<his>> head between your cheeks.</span>
<<elseif $mouth4 is "bottom">>
<<set $mouth4 to "anusentrance">><span class="blue">You press your <<bottom>> against <<his4>> mouth, but instead <<he>> moves <<his>> head between your cheeks.</span>
<<elseif $mouth5 is "bottom">>
<<set $mouth5 to "anusentrance">><span class="blue">You press your <<bottom>> against <<his5>> mouth, but instead <<he>> moves <<his>> head between your cheeks.</span>
<<elseif $mouth6 is "bottom">>
<<set $mouth6 to "anusentrance">><span class="blue">You press your <<bottom>> against <<his6>> mouth, but instead <<he>> moves <<his>> head between your cheeks.</span>
<</if>>
<<else>>
<<if $mouth is "bottom">>
<<if $penis is "othermouth">>
<<set $penis to 0>>
<</if>>
<<if $vagina is "othermouth">>
<<set $vagina to 0>>
<</if>>
<span class="lblue">You press your <<bottom>> against <<his1>> mouth, but <<he>> moves <<his>> head away from you.</span><<set $mouth to 0>><<set $bottomuse to 0>>
<<elseif $mouth2 is "bottom">>
<<if $penis2 is "othermouth">>
<<set $penis2 to 0>>
<</if>>
<<if $vagina2 is "othermouth">>
<<set $vagina2 to 0>>
<</if>>
<span class="lblue">You press your <<bottom>> against <<his2>> mouth, but <<he>> moves <<his>> head away from you.</span><<set $mouth2 to 0>><<set $bottomuse to 0>>
<<elseif $mouth3 is "bottom">>
<<if $penis3 is "othermouth">>
<<set $penis3 to 0>>
<</if>>
<<if $vagina3 is "othermouth">>
<<set $vagina3 to 0>>
<</if>>
<span class="lblue">You press your <<bottom>> against <<his3>> mouth, but <<he>> moves <<his>> head away from you.</span><<set $mouth3 to 0>><<set $bottomuse to 0>>
<<elseif $mouth4 is "bottom">>
<<if $penis4 is "othermouth">>
<<set $penis4 to 0>>
<</if>>
<<if $vagina4 is "othermouth">>
<<set $vagina4 to 0>>
<</if>>
<span class="lblue">You press your <<bottom>> against <<his4>> mouth, but <<he>> moves <<his>> head away from you.</span><<set $mouth4 to 0>><<set $bottomuse to 0>>
<<elseif $mouth5 is "bottom">>
<<if $penis5 is "othermouth">>
<<set $penis5 to 0>>
<</if>>
<<if $vagina5 is "othermouth">>
<<set $vagina5 to 0>>
<</if>>
<span class="lblue">You press your <<bottom>> against <<his5>> mouth, but <<he>> moves <<his>> head away from you.</span><<set $mouth5 to 0>><<set $bottomuse to 0>>
<<elseif $mouth6 is "bottom">>
<<if $penis6 is "othermouth">>
<<set $penis6 to 0>>
<</if>>
<<if $vagina6 is "othermouth">>
<<set $vagina6 to 0>>
<</if>>
<span class="lblue">You press your <<bottom>> against <<his6>> mouth, but <<he>> moves <<his>> head away from you.</span><<set $mouth6 to 0>><<set $bottomuse to 0>>
<</if>>
<</if>>
<</if>>
<</if>>
<<if $cheekaction is "othermouthstop">><<set $cheekaction to 0>><<set $cheekactiondefault to "stop">><<set $bottomuse to 0>>
<<if $anususe is 0>>
<<if $mouth is "bottom">>
<<set $mouth to "anusentrance">><<set $anusstate to "othermouthentrance">><<set $anususe to "othermouth">><span class="blue">You stop pressing your <<bottom>> against <<his1>> mouth.</span>
<<elseif $mouth2 is "bottom">>
<<set $mouth2 to "anusentrance">><<set $anusstate to "othermouthentrance">><<set $anususe to "othermouth">><span class="blue">You stop pressing your <<bottom>> against <<his2>> mouth.</span>
<<elseif $mouth3 is "bottom">>
<<set $mouth3 to "anusentrance">><<set $anusstate to "othermouthentrance">><<set $anususe to "othermouth">><span class="blue">You stop pressing your <<bottom>> against <<his3>> mouth.</span>
<<elseif $mouth4 is "bottom">>
<<set $mouth4 to "anusentrance">><<set $anusstate to "othermouthentrance">><<set $anususe to "othermouth">><span class="blue">You stop pressing your <<bottom>> against <<his4>> mouth.</span>
<<elseif $mouth5 is "bottom">>
<<set $mouth5 to "anusentrance">><<set $anusstate to "othermouthentrance">><<set $anususe to "othermouth">><span class="blue">You stop pressing your <<bottom>> against <<his5>> mouth.</span>
<<elseif $mouth6 is "bottom">>
<<set $mouth6 to "anusentrance">><<set $anusstate to "othermouthentrance">><<set $anususe to "othermouth">><span class="blue">You stop pressing your <<bottom>> against <<his6>> mouth.</span>
<</if>>
<<else>>
<<if $mouth is "bottom">>
<<if $penis is "othermouth">>
<<set $penis to 0>>
<</if>>
<<if $vagina is "othermouth">>
<<set $vagina to 0>>
<</if>>
<<set $mouth to 0>><span class="blue">You stop pressing your <<bottom>> against <<his1>> mouth.</span>
<<elseif $mouth2 is "bottom">>
<<if $penis2 is "othermouth">>
<<set $penis2 to 0>>
<</if>>
<<if $vagina2 is "othermouth">>
<<set $vagina2 to 0>>
<</if>>
<<set $mouth2 to 0>><span class="blue">You stop pressing your <<bottom>> against <<his2>> mouth.</span>
<<elseif $mouth3 is "bottom">>
<<if $penis3 is "othermouth">>
<<set $penis3 to 0>>
<</if>>
<<if $vagina3 is "othermouth">>
<<set $vagina3 to 0>>
<</if>>
<<set $mouth3 to 0>><span class="blue">You stop pressing your <<bottom>> against <<his3>> mouth.</span>
<<elseif $mouth4 is "bottom">>
<<if $penis4 is "othermouth">>
<<set $penis4 to 0>>
<</if>>
<<if $vagina4 is "othermouth">>
<<set $vagina4 to 0>>
<</if>>
<<set $mouth4 to 0>><span class="blue">You stop pressing your <<bottom>> against <<his4>> mouth.</span>
<<elseif $mouth5 is "bottom">>
<<if $penis5 is "othermouth">>
<<set $penis5 to 0>>
<</if>>
<<if $vagina5 is "othermouth">>
<<set $vagina5 to 0>>
<</if>>
<<set $mouth5 to 0>><span class="blue">You stop pressing your <<bottom>> against <<his5>> mouth.</span>
<<elseif $mouth6 is "bottom">>
<<if $penis6 is "othermouth">>
<<set $penis6 to 0>>
<</if>>
<<if $vagina6 is "othermouth">>
<<set $vagina6 to 0>>
<</if>>
<<set $mouth6 to 0>><span class="blue">You stop pressing your <<bottom>> against <<his6>> mouth.</span>
<</if>>
<</if>>
<</if>>
<<if $anusaction is "bottombay">><<set $anusaction to 0>><<meek 1>><<bottomskilluse>><<set $anusactiondefault to "bottombay">><<combatpromiscuity1>>
<<if (1000 - ($rng * 10) - ($enemytrust * 10) - $bottomskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>><<set $cheekactiondefault to "othermouthrub">>
<<if $mouth is "anusentrance">>
<span class="lblue">You <<bottomtext>> press your <<bottom>> against <<his1>> mouth.</span><<set $mouth to "bottom">><<set $anususe to 0>><<bottomstat>><<neutral 5>><<set $anusstate to 0>><<set $bottomuse to "mouth">>
<<elseif $mouth2 is "anusentrance">>
<span class="lblue">You <<bottomtext>> press your <<bottom>> against <<his2>> mouth.</span><<set $mouth2 to "bottom">><<set $anususe to 0>><<bottomstat>><<neutral 5>><<set $anusstate to 0>><<set $bottomuse to "mouth">>
<<elseif $mouth3 is "anusentrance">>
<span class="lblue">You <<bottomtext>> press your <<bottom>> against <<his3>> mouth.</span><<set $mouth3 to "bottom">><<set $anususe to 0>><<bottomstat>><<neutral 5>><<set $anusstate to 0>><<set $bottomuse to "mouth">>
<<elseif $mouth4 is "anusentrance">>
<span class="lblue">You <<bottomtext>> press your <<bottom>> against <<his4>> mouth.</span><<set $mouth4 to "bottom">><<set $anususe to 0>><<bottomstat>><<neutral 5>><<set $anusstate to 0>><<set $bottomuse to "mouth">>
<<elseif $mouth5 is "anusentrance">>
<span class="lblue">You <<bottomtext>> press your <<bottom>> against <<his5>> mouth.</span><<set $mouth5 to "bottom">><<set $anususe to 0>><<bottomstat>><<neutral 5>><<set $anusstate to 0>><<set $bottomuse to "mouth">>
<<elseif $mouth6 is "anusentrance">>
<span class="lblue">You <<bottomtext>> press your <<bottom>> against <<his6>> mouth.</span><<set $mouth6 to "bottom">><<set $anususe to 0>><<bottomstat>><<neutral 5>><<set $anusstate to 0>><<set $bottomuse to "mouth">>
<</if>>
<<else>>
You try to keep the mouth menacing your anus at bay by pressing your <<bottom>> against it, but <<theowner>> has other ideas.
<</if>>
<</if>>
<<if $anusaction is "othermouthtease">><<set $anusaction to 0>><<set $anusactiondefault to "othermouthtease">><<actionsothermouthanustease>><<sex 5>><<analskilluse>>
<</if>>
<<if $anusaction is "othermouthrub">><<set $anusaction to 0>><<set $anusactiondefault to "othermouthrub">><<actionsothermouthanusrub>><<sex 10>><<analskilluse>>
<</if>>
<<if $anusaction is "othermouthcooperate">><<set $anusaction to 0>><<set $anusactiondefault to "othermouthcooperate">><<actionsothermouthanusthrust>><<submission 20>><<analskilluse>>
<</if>>
<<if $anusaction is "othermouthescape">><<set $anusaction to 0>><<set $anusactiondefault to "othermouthescape">><<actionsothermouthanusescape>><<brat 10>><<set $anususe to "othermouth">><<set $anusstate to "othermouthentrance">>
<<if $mouth is "anusimminent">>
<<set $mouth to "anusentrance">>
<<elseif $mouth2 is "anusimminent">>
<<set $mouth2 to "anusentrance">>
<<elseif $mouth3 is "anusimminent">>
<<set $mouth3 to "anusentrance">>
<<elseif $mouth4 is "anusimminent">>
<<set $mouth4 to "anusentrance">>
<<elseif $mouth5 is "anusimminent">>
<<set $mouth5 to "anusentrance">>
<<elseif $mouth6 is "anusimminent">>
<<set $mouth6 to "anusentrance">>
<</if>>
<</if>>
<<if $penisaction is "otheranusbay">><<set $penisaction to 0>><<meek 1>><<penileskilluse>><<set $penisactiondefault to "otheranusbay">><<combatpromiscuity4>>
<<if (1000 - ($rng * 10) - ($enemytrust * 10) - $penileskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>><<set $penisactiondefault to "otheranusrub">>
<<if $vagina is "otheranusentrance">>
<span class="lblue">You <<peniletext>> point your <<penis>> away from <<his1>> anus, rubbing between <<his1>> cheeks.</span><<set $vagina to "otheranusfrot">><<set $penisuse to "otheranusrub">><<penilestat>><<sex 5>><<set $penisstate to "otheranusrub">>
<</if>>
<<if $vagina2 is "otheranusentrance">>
<span class="lblue">You <<peniletext>> point your <<penis>> away from <<his1>> anus, rubbing between <<his1>> cheeks.</span><<set $vagina2 to "otheranusfrot">><<set $penisuse to "otheranusrub">><<penilestat>><<sex 5>><<set $penisstate to "otheranusrub">>
<</if>>
<<if $vagina3 is "otheranusentrance">>
<span class="lblue">You <<peniletext>> point your <<penis>> away from <<his2>> anus, rubbing between <<his1>> cheeks.</span><<set $vagina3 to "otheranusfrot">><<set $penisuse to "otheranusrub">><<penilestat>><<sex 5>><<set $penisstate to "otheranusrub">>
<</if>>
<<if $vagina4 is "otheranusentrance">>
<span class="lblue">You <<peniletext>> point your <<penis>> away from <<his3>> anus, rubbing between <<his1>> cheeks.</span><<set $vagina4 to "otheranusfrot">><<set $penisuse to "otheranusrub">><<penilestat>><<sex 5>><<set $penisstate to "otheranusrub">>
<</if>>
<<if $vagina5 is "otheranusentrance">>
<span class="lblue">You <<peniletext>> point your <<penis>> away from <<his4>> anus, rubbing between <<his1>> cheeks.</span><<set $vagina5 to "otheranusfrot">><<set $penisuse to "otheranusrub">><<penilestat>><<sex 5>><<set $penisstate to "otheranusrub">>
<</if>>
<<if $vagina6 is "otheranusentrance">>
<span class="lblue">You <<peniletext>> point your <<penis>> away from <<his5>> anus, rubbing between <<his1>> cheeks.</span><<set $vagina6 to "otheranusfrot">><<set $penisuse to "otheranusrub">><<penilestat>><<sex 5>><<set $penisstate to "otheranusrub">>
<</if>>
<<if $penis is "otheranusentrance">>
<span class="lblue">You <<peniletext>> point your <<penis>> away from <<his6>> anus, rubbing between <<his1>> cheeks.</span><<set $penis to "otheranusfrot">><<set $penisuse to "otheranusrub">><<penilestat>><<sex 5>><<set $penisstate to "otheranusrub">>
<</if>>
<<if $penis2 is "otheranusentrance">>
<span class="lblue">You <<peniletext>> point your <<penis>> away from <<his2>> anus, rubbing between <<his1>> cheeks.</span><<set $penis2 to "otheranusfrot">><<set $penisuse to "otheranusrub">><<penilestat>><<sex 5>><<set $penisstate to "otheranusrub">>
<</if>>
<<if $penis3 is "otheranusentrance">>
<span class="lblue">You <<peniletext>> point your <<penis>> away from <<his3>> anus, rubbing between <<his1>> cheeks.</span><<set $penis3 to "otheranusfrot">><<set $penisuse to "otheranusrub">><<penilestat>><<sex 5>><<set $penisstate to "otheranusrub">>
<</if>>
<<if $penis4 is "otheranusentrance">>
<span class="lblue">You <<peniletext>> point your <<penis>> away from <<his4>> anus, rubbing between <<his1>> cheeks.</span><<set $penis4 to "otheranusfrot">><<set $penisuse to "otheranusrub">><<penilestat>><<sex 5>><<set $penisstate to "otheranusrub">>
<</if>>
<<if $penis5 is "otheranusentrance">>
<span class="lblue">You <<peniletext>> point your <<penis>> away from <<his5>> anus, rubbing between <<his1>> cheeks.</span><<set $penis5 to "otheranusfrot">><<set $penisuse to "otheranusrub">><<penilestat>><<sex 5>><<set $penisstate to "otheranusrub">>
<</if>>
<<if $penis6 is "otheranusentrance">>
<span class="lblue">You <<peniletext>> point your <<penis>> away from <<his6>> anus, rubbing between <<his1>> cheeks.</span><<set $penis6 to "otheranusfrot">><<set $penisuse to "otheranusrub">><<penilestat>><<sex 5>><<set $penisstate to "otheranusrub">>
<</if>>
<<else>>
You try to move your <<penis>> away from the anus pressing against it, but <<theowner>> has other ideas.
<</if>>
<</if>>
<<if $penisaction is "otheranusrub">><<set $penisaction to 0>><<set $penisactiondefault to "otheranusrub">><<penileskilluse>>
<<if (1000 - ($rng * 10) - ($enemytrust * 10) - $penileskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>><<set $penisactiondefault to "otheranusrub">><<penilestat>><<sex 5>>
<<actionsotheranusrub>>
<<else>><<set $penisactiondefault to "otheranusbay">>
<<set $penisuse to "otheranus">><<set $penisstate to "otheranusentrance">>
<<if $vagina is "otheranusfrot">>
<<set $vagina to "otheranusentrance">><span class="blue">You rub your penis between <<his1>> cheeks, but <<he>> would prefer the main course and presses <<his>> anus against your tip.</span>
<</if>>
<<if $vagina2 is "otheranusfrot">>
<<set $vagina2 to "otheranusentrance">><span class="blue">You rub your penis between <<his2>> cheeks, but <<he>> would prefer the main course and presses <<his>> anus against your tip.</span>
<</if>>
<<if $vagina3 is "otheranusfrot">>
<<set $vagina3 to "otheranusentrance">><span class="blue">You rub your penis between <<his3>> cheeks, but <<he>> would prefer the main course and presses <<his>> anus against your tip.</span>
<</if>>
<<if $vagina4 is "otheranusfrot">>
<<set $vagina4 to "otheranusentrance">><span class="blue">You rub your penis between <<his4>> cheeks, but <<he>> would prefer the main course and presses <<his>> anus against your tip.</span>
<</if>>
<<if $vagina5 is "otheranusfrot">>
<<set $vagina5 to "otheranusentrance">><span class="blue">You rub your penis between <<his5>> cheeks, but <<he>> would prefer the main course and presses <<his>> anus against your tip.</span>
<</if>>
<<if $vagina6 is "otheranusfrot">>
<<set $vagina6 to "otheranusentrance">><span class="blue">You rub your penis between <<his6>> cheeks, but <<he>> would prefer the main course and presses <<his>> anus against your tip.</span>
<</if>>
<<if $penis is "otheranusfrot">>
<<set $penis to "otheranusentrance">><span class="blue">You rub your penis between <<his1>> cheeks, but <<he>> would prefer the main course and presses <<his>> anus against your tip.</span>
<</if>>
<<if $penis2 is "otheranusfrot">>
<<set $penis2 to "otheranusentrance">><span class="blue">You rub your penis between <<his2>> cheeks, but <<he>> would prefer the main course and presses <<his>> anus against your tip.</span>
<</if>>
<<if $penis3 is "otheranusfrot">>
<<set $penis3 to "otheranusentrance">><span class="blue">You rub your penis between <<his3>> cheeks, but <<he>> would prefer the main course and presses <<his>> anus against your tip.</span>
<</if>>
<<if $penis4 is "otheranusfrot">>
<<set $penis4 to "otheranusentrance">><span class="blue">You rub your penis between <<his4>> cheeks, but <<he>> would prefer the main course and presses <<his>> anus against your tip.</span>
<</if>>
<<if $penis5 is "otheranusfrot">>
<<set $penis5 to "otheranusentrance">><span class="blue">You rub your penis between <<his5>> cheeks, but <<he>> would prefer the main course and presses <<his>> anus against your tip.</span>
<</if>>
<<if $penis6 is "otheranusfrot">>
<<set $penis6 to "otheranusentrance">><span class="blue">You rub your penis between <<his6>> cheeks, but <<he>> would prefer the main course and presses <<his>> anus against your tip.</span>
<</if>>
<</if>>
<</if>>
<<if $penisaction is "otheranusstop">><<set $penisaction to 0>><<set $penisactiondefault to "stop">>
<<if $vagina is "otheranusbay">>
<<set $vagina to "otheranusentrance">><<set $penisstate to "otheranusentrance">><<set $penisuse to "otheranus">><span class="blue">You stop rubbing your <<penis>> between <<his1>> cheeks.</span>
<</if>>
<<if $vagina2 is "otheranusbay">>
<<set $vagina2 to "otheranusentrance">><<set $penisstate to "otheranusentrance">><<set $penisuse to "otheranus">><span class="blue">You stop rubbing your <<penis>> between <<his2>> cheeks.</span>
<</if>>
<<if $vagina3 is "otheranusbay">>
<<set $vagina3 to "otheranusentrance">><<set $penisstate to "otheranusentrance">><<set $penisuse to "otheranus">><span class="blue">You stop rubbing your <<penis>> between <<his3>> cheeks.</span>
<</if>>
<<if $vagina4 is "otheranusbay">>
<<set $vagina4 to "otheranusentrance">><<set $penisstate to "otheranusentrance">><<set $penisuse to "otheranus">><span class="blue">You stop rubbing your <<penis>> between <<his4>> cheeks.</span>
<</if>>
<<if $vagina5 is "otheranusbay">>
<<set $vagina5 to "otheranusentrance">><<set $penisstate to "otheranusentrance">><<set $penisuse to "otheranus">><span class="blue">You stop rubbing your <<penis>> between <<his5>> cheeks.</span>
<</if>>
<<if $vagina6 is "otheranusbay">>
<<set $vagina6 to "otheranusentrance">><<set $penisstate to "otheranusentrance">><<set $penisuse to "otheranus">><span class="blue">You stop rubbing your <<penis>> between <<his6>> cheeks.</span>
<</if>>
<<if $penis is "otheranusbay">>
<<set $penis to "otheranusentrance">><<set $penisstate to "otheranusentrance">><<set $penisuse to "otheranus">><span class="blue">You stop rubbing your <<penis>> between <<his1>> cheeks.</span>
<</if>>
<<if $penis2 is "otheranusbay">>
<<set $penis2 to "otheranusentrance">><<set $penisstate to "otheranusentrance">><<set $penisuse to "otheranus">><span class="blue">You stop rubbing your <<penis>> between <<his2>> cheeks.</span>
<</if>>
<<if $penis3 is "otheranusbay">>
<<set $penis3 to "otheranusentrance">><<set $penisstate to "otheranusentrance">><<set $penisuse to "otheranus">><span class="blue">You stop rubbing your <<penis>> between <<his3>> cheeks.</span>
<</if>>
<<if $penis4 is "otheranusbay">>
<<set $penis4 to "otheranusentrance">><<set $penisstate to "otheranusentrance">><<set $penisuse to "otheranus">><span class="blue">You stop rubbing your <<penis>> between <<his4>> cheeks.</span>
<</if>>
<<if $penis5 is "otheranusbay">>
<<set $penis5 to "otheranusentrance">><<set $penisstate to "otheranusentrance">><<set $penisuse to "otheranus">><span class="blue">You stop rubbing your <<penis>> between <<his5>> cheeks.</span>
<</if>>
<<if $penis6 is "otheranusbay">>
<<set $penis6 to "otheranusentrance">><<set $penisstate to "otheranusentrance">><<set $penisuse to "otheranus">><span class="blue">You stop rubbing your <<penis>> between <<his6>> cheeks.</span>
<</if>>
<</if>>
<<if $penisaction is "otheranustease">><<set $penisaction to 0>><<set $penisactiondefault to "otheranustease">><<actionsotheranustease>><<sex 5>><<penileskilluse>>
<</if>>
<<if $penisaction is "otheranuscooperate">><<set $penisaction to 0>><<set $penisactiondefault to "otheranuscooperate">><<actionsotheranusthrust>><<submission 20>><<penileskilluse>>
<</if>>
<<if $penisaction is "otheranustake">><<set $penisaction to 0>><<set $penisactiondefault to "otheranustake">><<actionsotheranustake>>
<</if>>
<<if $penisaction is "otheranusescape">><<set $penisaction to 0>><<set $penisactiondefault to "otheranusescape">><<actionsotheranusescape>><<brat 10>><<set $penisuse to "otheranus">><<set $penisstate to "otheranusentrance">>
<<if $vagina is "otheranusimminent">>
<<set $vagina to "otheranusentrance">><<set $speechotheranusescape1 to 1>>
<</if>>
<<if $vagina2 is "otheranusimminent">>
<<set $vagina2 to "otheranusentrance">><<set $speechotheranusescape2 to 1>>
<</if>>
<<if $vagina3 is "otheranusimminent">>
<<set $vagina3 to "otheranusentrance">><<set $speechotheranusescape3 to 1>>
<</if>>
<<if $vagina4 is "otheranusimminent">>
<<set $vagina4 to "otheranusentrance">><<set $speechotheranusescape4 to 1>>
<</if>>
<<if $vagina5 is "otheranusimminent">>
<<set $vagina5 to "otheranusentrance">><<set $speechotheranusescape5 to 1>>
<</if>>
<<if $vagina6 is "otheranusimminent">>
<<set $vagina6 to "otheranusentrance">><<set $speechotheranusescape6 to 1>>
<</if>>
<<if $penis is "otheranusimminent">>
<<set $penis to "otheranusentrance">><<set $speechotheranusescape1 to 1>>
<</if>>
<<if $penis2 is "otheranusimminent">>
<<set $penis2 to "otheranusentrance">><<set $speechotheranusescape2 to 1>>
<</if>>
<<if $penis3 is "otheranusimminent">>
<<set $penis3 to "otheranusentrance">><<set $speechotheranusescape3 to 1>>
<</if>>
<<if $penis4 is "otheranusimminent">>
<<set $penis4 to "otheranusentrance">><<set $speechotheranusescape4 to 1>>
<</if>>
<<if $penis5 is "otheranusimminent">>
<<set $penis5 to "otheranusentrance">><<set $speechotheranusescape5 to 1>>
<</if>>
<<if $penis6 is "otheranusimminent">>
<<set $penis6 to "otheranusentrance">><<set $speechotheranusescape6 to 1>>
<</if>>
<</if>>
<<if $anusaction is "rub">><<set $anusaction to 0>><<set $anusactiondefault to "rub">><<actionsanusrub>><<sex 10>>
<<analskilluse>>
<</if>>
<<if $anusaction is "cooperate">><<set $anusaction to 0>><<set $anusactiondefault to "cooperate">><<actionsanusthrust>><<submission 15>><<analskilluse>>
<</if>>
<<if $anusaction is "take">><<set $anusaction to 0>><<set $anusactiondefault to "take">><<actionsanustake>>
<</if>>
<<if $anusaction is "escape">><<set $anusaction to 0>><<set $anusactiondefault to "escape">><<actionsanusescape>><<brat 10>><<set $anususe to "penis">><<set $anusstate to "entrance">>
<<if $penis is "anusimminent">>
<<set $penis to "anusentrance">><<set $speechanusescape1 to 1>>
<<elseif $penis2 is "anusimminent">>
<<set $penis2 to "anusentrance">><<set $speechanusescape2 to 1>>
<<elseif $penis3 is "anusimminent">>
<<set $penis3 to "anusentrance">><<set $speechanusescape3 to 1>>
<<elseif $penis4 is "anusimminent">>
<<set $penis4 to "anusentrance">><<set $speechanusescape4 to 1>>
<<elseif $penis5 is "anusimminent">>
<<set $penis5 to "anusentrance">><<set $speechanusescape5 to 1>>
<<elseif $penis6 is "anusimminent">>
<<set $penis6 to "anusentrance">><<set $speechanusescape6 to 1>>
<</if>>
<</if>>
<<if $chestaction is "rub">>
<<set $chestaction to 0>>
<<set $chestactiondefault to "rub">>
<<if (1000 - ($rng * 10) - ($enemytrust * 10) - $chestskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<<if $breastcup is "none">>
You rub your <<breasts>> against <<his>> penis.
<<else>>
You rub <<his>> penis between your <<breasts>>
<</if>>
<<submission 3>><<chestskilluse>><<cheststat>>
<<else>>
<<set $chestuse to 0>>
<<if $mouthuse is 0>><<set $mouthactiondefault to "grasp">> <<set $mouthstate to "entrance">><<set $mouthuse to "penis">>
<<if $penis is "chest">>
<<set $penis to "mouthentrance">><span class="blue">You try to rub your <<breasts>> against <<his1>> penis, but <<he>> moves <<his>> penis to your mouth.</span>
<<elseif $penis2 is "chest">>
<<set $penis2 to "mouthentrance">><span class="blue">You try to rub your <<breasts>> against <<his2>> penis, but <<he>> moves <<his>> penis to your mouth.</span>
<<elseif $penis3 is "chest">>
<<set $penis3 to "mouthentrance">><span class="blue">You try to rub your <<breasts>> against <<his3>> penis, but <<he>> moves <<his>> penis to your mouth.</span>
<<elseif $penis4 is "chest">>
<<set $penis4 to "mouthentrance">><span class="blue">You try to rub your <<breasts>> against <<his4>> penis, but <<he>> moves <<his>> penis to your mouth.</span>
<<elseif $penis5 is "chest">>
<<set $penis5 to "mouthentrance">><span class="blue">You try to rub your <<breasts>> against <<his5>> penis, but <<he>> moves <<his>> penis to your mouth.</span>
<<elseif $penis6 is "chest">>
<<set $penis6 to "mouthentrance">><span class="blue">You try to rub your <<breasts>> against <<his6>> penis, but <<he>> moves <<his>> penis to your mouth.</span>
<</if>>
<<else>>
<<if $penis is "chest">>
<<set $penis to 0>><span class="blue">You try to rub your <<breasts>> against <<his1>> penis, but <<he>> pulls away.</span>
<<elseif $penis2 is "chest">>
<<set $penis2 to 0>><span class="blue">You try to rub your <<breasts>> against <<his2>> penis, but <<he>> pulls away.</span>
<<elseif $penis3 is "chest">>
<<set $penis3 to 0>><span class="blue">You try to rub your <<breasts>> against <<his3>> penis, but <<he>> pulls away.</span>
<<elseif $penis4 is "chest">>
<<set $penis4 to 0>><span class="blue">You try to rub your <<breasts>> against <<his4>> penis, but <<he>> pulls away.</span>
<<elseif $penis5 is "chest">>
<<set $penis5 to 0>><span class="blue">You try to rub your <<breasts>> against <<his5>> penis, but <<he>> pulls away.</span>
<<elseif $penis6 is "chest">>
<<set $penis6 to 0>><span class="blue">You try to rub your <<breasts>> against <<his6>> penis, but <<he>> pulls away.</span>
<</if>>
<</if>>
<</if>>
<</if>>
<<if $mouthaction is "grasp">><<set $mouthaction to 0>><<set $mouthactiondefault to "grasp">><<chestskilluse>><<combatpromiscuity3>>
<<if (1000 - ($rng * 10) - ($enemytrust * 10) - $chestskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>><<set $chestactiondefault to "rub">><<set $chestuse to "penis">><<cheststat>><<set $mouthstate to 0>><<set $mouthuse to 0>><<set $mouthactiondefault to "peniskiss">>
<<if $penis is "mouthentrance">>
<<set $penis to "chest">>
<<if $breastcup is "none">>
<span class="lblue">You <<chesttext>> squeeze your <<breasts>> together as best you can and try to grab <<his1>> penis between them. Your breasts are too small for it to be effective, but your cute attempt succeeds in charming <<him>>.</span> <<He>> rubs <<his>> penis against your chest.
<<else>>
<span class="lblue">You <<chesttext>> grab <<his1>> penis between your <<breastsstop>></span>
<</if>>
<<elseif $penis2 is "mouthentrance">>
<<set $penis2 to "chest">>
<<if $breastcup is "none">>
<span class="lblue">You <<chesttext>> squeeze your <<breasts>> together as best you can and try to grab <<his2>> penis between them. Your breasts are too small for it to be effective, but your cute attempt succeeds in charming <<him>>.</span> <<He>> rubs <<his>> penis against your chest.
<<else>>
<span class="lblue">You <<chesttext>> grab <<his2>> penis between your <<breastsstop>></span>
<</if>>
<<elseif $penis3 is "mouthentrance">>
<<set $penis3 to "chest">>
<<if $breastcup is "none">>
<span class="lblue">You <<chesttext>> squeeze your <<breasts>> together as best you can and try to grab <<his3>> penis between them. Your breasts are too small for it to be effective, but your cute attempt succeeds in charming <<him>>.</span> <<He>> rubs <<his>> penis against your chest.
<<else>>
<span class="lblue">You <<chesttext>> grab <<his3>> penis between your <<breastsstop>></span>
<</if>>
<<elseif $penis4 is "mouthentrance">>
<<set $penis4 to "chest">>
<<if $breastcup is "none">>
<span class="lblue">You <<chesttext>> squeeze your <<breasts>> together as best you can and try to grab <<his4>> penis between them. Your breasts are too small for it to be effective, but your cute attempt succeeds in charming <<him>>.</span> <<He>> rubs <<his>> penis against your chest.
<<else>>
<span class="lblue">You <<chesttext>> grab <<his4>> penis between your <<breastsstop>></span>
<</if>>
<<elseif $penis5 is "mouthentrance">>
<<set $penis5 to "chest">>
<<if $breastcup is "none">>
<span class="lblue">You <<chesttext>> squeeze your <<breasts>> together as best you can and try to grab <<his5>> penis between them. Your breasts are too small for it to be effective, but your cute attempt succeeds in charming <<him>>.</span> <<He>> rubs <<his>> penis against your chest.
<<else>>
<span class="lblue">You <<chesttext>> grab <<his5>> penis between your <<breastsstop>></span>
<</if>>
<<elseif $penis6 is "mouthentrance">>
<<set $penis6 to "chest">>
<<if $breastcup is "none">>
<span class="lblue">You <<chesttext>> squeeze your <<breasts>> together as best you can and try to grab <<his6>> penis between them. Your breasts are too small for it to be effective, but your cute attempt succeeds in charming <<him>>.</span> <<He>> rubs <<his>> penis against your chest.
<<else>>
<span class="lblue">You <<chesttext>> grab <<his6>> penis between your <<breastsstop>></span>
<</if>>
<</if>>
<<else>>
<<if $breastcup is "none">>
You squeeze your <<breasts>> together as best you can and try to grab <<a>> penis between them, to no avail.
<<else>>
You try to grab <<a>> penis between your <<breasts>>, but fail.
<</if>>
<</if>>
<</if>>
<<set $intro1 to 0>>
<<set $intro2 to 0>>
<<set $intro3 to 0>>
<<set $intro4 to 0>>
<<set $intro5 to 0>>
<<set $intro6 to 0>>
<br>
<</nobr>><</widget>>
:: Widgets Ejaculation [widget]
<<widget "ejaculation">><<nobr>>
<<set $ejaculating to 1>>
<<if $consensual is 1>>
<<famesex 1>>
<<else>>
<<famerape 1>>
<</if>>
<<if $exposed is 1>>
<<fameexhibitionism 1>>
<<elseif $exposed gte 2>>
<<fameexhibitionism 2>>
<</if>>
<<if $pronoun1 is "m">>
<<set $pronoun to "m">>
<</if>>
<<if $pronoun1 is "f">>
<<set $pronoun to "f">>
<</if>>
<<if $pronoun1 is "i">>
<<set $pronoun to "i">>
<</if>>
<<if $pronoun1 is "n">>
<<set $pronoun to "n">>
<</if>>
<<if $pronoun1 is "t">>
<<set $pronoun to "t">>
<</if>>
<<if $enemytype is "man">>
<<set $intro1 to 1>>
<<else>>
<<set $pronoun to "i">>
<</if>>
<<if $vagina isnot "none" and $penis is "none">>
<<He>> convulses in orgasmic bliss.<br><br>
<</if>>
<<if $penis is "idle">><<He>> groans as a wet patch forms on <<his>> trousers.<br><br>
<</if>>
<<if $penis is "thighs">><<He>> ejaculates onto your thighs.<br><br>
<<thighejacstat>><<ejacstat>><<set $hygiene += 500>><<set $thighsemen += 1>>
<</if>>
<<if $penis is "vaginaentrance">><<He>> ejaculates onto your pussy.<br><br>
<<vaginalentranceejacstat>><<ejacstat>><<set $hygiene += 500>><<set $vaginaoutsidesemen += 1>>
<</if>>
<<if $penis is "vaginaimminent">><<He>> ejaculates onto your pussy.<br><br>
<<vaginalentranceejacstat>><<ejacstat>><<set $hygiene += 500>><<set $vaginaoutsidesemen += 1>>
<</if>>
<<if $penis is "vagina">><<He>> ejaculates deep into your womb.<br><br><<vaginalejacstat>><<ejacstat>><<set $hygiene += 500>><<set $vaginasemen += 1>>
<</if>>
<<if $penis is "cheeks">><<He>> ejaculates onto your back.
<br><br><<bottomejacstat>><<ejacstat>><<set $hygiene += 500>><<set $bottomsemen += 1>>
<</if>>
<<if $penis is "anusentrance">><<He>> ejaculates between your <<bottom>> cheeks.<br>
<br><<bottomejacstat>><<ejacstat>><<set $hygiene += 500>><<set $bottomsemen += 1>>
<</if>>
<<if $penis is "anusimminent">><<He>> ejaculates between your <<bottom>> cheeks.<br>
<br><<bottomejacstat>><<ejacstat>><<set $hygiene += 500>><<set $bottomsemen += 1>>
<</if>>
<<if $penis is "anus">><<He>> ejaculates into your bowels.
<br><br><<analejacstat>><<ejacstat>><<set $hunger -= 200>><<set $thirst -= 200>><<set $hygiene += 500>><<set $anussemen += 1>>
<</if>>
<<if $penis is "chest">><<He>> ejaculates onto your chest.
<br><br><<chestejacstat>><<ejacstat>><<set $hygiene += 500>><<set $chestsemen += 1>>
<</if>>
<<if $penis is "mouthentrance">><<He>> ejaculates onto your face.
<br><br><<faceejacstat>><<ejacstat>><<set $hygiene += 500>><<set $facesemen += 1>>
<</if>>
<<if $penis is "mouthimminent">><<He>> ejaculates onto your face.
<br><br><<faceejacstat>><<ejacstat>><<set $hygiene += 500>><<set $facesemen += 1>>
<</if>>
<<if $penis is "mouth">><<He>> ejaculates down the back of your throat.
<br><br><<oralejacstat>><<ejacstat>><<set $hunger -= 200>><<set $thirst -= 200>><<set $mouthsemen += 1>>
<</if>>
<<if $penis is "feet">><<He>> ejaculates on your feet.
<br><br><<feetejacstat>><<ejacstat>><<set $hygiene += 500>><<set $feetsemen += 1>>
<</if>>
<<if $penis is "leftarm" and $penis is "rightarm">><<He>> ejaculates on your hands.
<br><br><<handejacstat>><<ejacstat>><<set $hygiene += 500>><<set $leftarmsemen += 1>><<set $rightarmsemen += 1>>
<</if>>
<<if $penis is "leftarm">><<He>> ejaculates on your hand.
<br><br><<handejacstat>><<ejacstat>><<set $hygiene += 500>><<set $leftarmsemen += 1>>
<</if>>
<<if $penis is "rightarm">><<He>> ejaculates on your hand.
<br><br><<handejacstat>><<ejacstat>><<set $hygiene += 500>><<set $rightarmsemen += 1>>
<</if>>
<<if $penis is 0>><<He>> ejaculates onto your tummy.
<br><br>
<<tummyejacstat>><<ejacstat>><<set $hygiene += 500>><<set $tummysemen += 1>>
<</if>>
<<if $enemyno gte 2>>
<<if $consensual is 1>>
<<famesex 1>>
<<else>>
<<famerape 1>>
<</if>>
<<if $exposed is 1>>
<<fameexhibitionism 1>>
<<elseif $exposed gte 2>>
<<fameexhibitionism 2>>
<</if>>
<<if $pronoun2 is "m">>
<<set $pronoun to "m">>
<</if>>
<<if $pronoun2 is "f">>
<<set $pronoun to "f">>
<</if>>
<<if $pronoun2 is "i">>
<<set $pronoun to "i">>
<</if>>
<<if $pronoun2 is "n">>
<<set $pronoun to "n">>
<</if>>
<<if $pronoun2 is "t">>
<<set $pronoun to "t">>
<</if>>
<<set $intro2 to 1>>
<<if $vagina2 isnot "none" and $penis2 is "none">>
<<He>> convulses in orgasmic bliss.<br><br>
<</if>>
<<if $penis2 is "idle">><<He>> groans as a wet patch forms on <<his>> trousers.<br><br>
<</if>>
<<if $penis2 is "thighs">><<He>> ejaculates onto your thighs.<br><br>
<<thighejacstat>><<ejacstat>><<set $hygiene += 500>><<set $thighsemen += 1>>
<</if>>
<<if $penis2 is "vaginaentrance">><<He>> ejaculates onto your pussy.<br><br>
<<vaginalentranceejacstat>><<ejacstat>><<set $hygiene += 500>><<set $vaginaoutsidesemen += 1>>
<</if>>
<<if $penis2 is "vaginaimminent">><<He>> ejaculates onto your pussy.<br><br>
<<vaginalentranceejacstat>><<ejacstat>><<set $hygiene += 500>><<set $vaginaoutsidesemen += 1>>
<</if>>
<<if $penis2 is "vagina">><<He>> ejaculates deep into your womb.<br><br><<vaginalejacstat>><<ejacstat>><<set $hygiene += 500>><<set $vaginasemen += 1>>
<</if>>
<<if $penis2 is "cheeks">><<He>> ejaculates onto your back.
<br><br><<bottomejacstat>><<ejacstat>><<set $hygiene += 500>><<set $bottomsemen += 1>>
<</if>>
<<if $penis2 is "anusentrance">><<He>> ejaculates onto your <<bottomstop>><br>
<br><<bottomejacstat>><<ejacstat>><<set $hygiene += 500>><<set $bottomsemen += 1>>
<</if>>
<<if $penis2 is "anusimminent">><<He>> ejaculates onto your <<bottomstop>><br>
<br><<bottomejacstat>><<ejacstat>><<set $hygiene += 500>><<set $bottomsemen += 1>>
<</if>>
<<if $penis2 is "anus">><<He>> ejaculates into your bowels.
<br><br><<analejacstat>><<ejacstat>><<set $hunger -= 200>><<set $thirst -= 200>><<set $hygiene += 500>><<set $anussemen += 1>>
<</if>>
<<if $penis2 is "chest">><<He>> ejaculates onto your chest.
<br><br><<chestejacstat>><<ejacstat>><<set $hygiene += 500>><<set $chestsemen += 1>>
<</if>>
<<if $penis2 is "mouthentrance">><<He>> ejaculates onto your face.
<br><br><<faceejacstat>><<ejacstat>><<set $hygiene += 500>><<set $facesemen += 1>>
<</if>>
<<if $penis2 is "mouthimminent">><<He>> ejaculates onto your face.
<br><br><<faceejacstat>><<ejacstat>><<set $hygiene += 500>><<set $facesemen += 1>>
<</if>>
<<if $penis2 is "mouth">><<He>> ejaculates down the back of your throat.
<br><br><<oralejacstat>><<ejacstat>><<set $hunger -= 200>><<set $thirst -= 200>><<set $mouthsemen += 1>>
<</if>>
<<if $penis2 is "feet">><<He>> ejaculates on your feet.
<br><br><<feetejacstat>><<ejacstat>><<set $hygiene += 500>><<set $feetsemen += 1>>
<</if>>
<<if $penis2 is "leftarm" and $penis is "rightarm">><<He>> ejaculates on your hands.
<br><br><<handejacstat>><<ejacstat>><<set $hygiene += 500>><<set $leftarmsemen += 1>><<set $rightarmsemen += 1>>
<</if>>
<<if $penis2 is "leftarm">><<He>> ejaculates on your hand.
<br><br><<handejacstat>><<ejacstat>><<set $hygiene += 500>><<set $leftarmsemen += 1>>
<</if>>
<<if $penis2 is "rightarm">><<He>> ejaculates on your hand.
<br><br><<handejacstat>><<ejacstat>><<set $hygiene += 500>><<set $rightsemen += 1>>
<</if>>
<<if $penis2 is 0>><<He>> ejaculates onto your tummy.
<br><br>
<<tummyejacstat>><<ejacstat>><<set $hygiene += 500>><<set $tummysemen += 1>>
<</if>>
<</if>>
<<if $enemyno gte 3>>
<<if $consensual is 1>>
<<famesex 1>>
<<else>>
<<famerape 1>>
<</if>>
<<if $exposed is 1>>
<<fameexhibitionism 1>>
<<elseif $exposed gte 2>>
<<fameexhibitionism 2>>
<</if>>
<<if $pronoun3 is "m">>
<<set $pronoun to "m">>
<</if>>
<<if $pronoun3 is "f">>
<<set $pronoun to "f">>
<</if>>
<<if $pronoun3 is "i">>
<<set $pronoun to "i">>
<</if>>
<<if $pronoun3 is "n">>
<<set $pronoun to "n">>
<</if>>
<<if $pronoun3 is "t">>
<<set $pronoun to "t">>
<</if>>
<<set $intro3 to 1>>
<<if $vagina3 isnot "none" and $penis3 is "none">>
<<He>> convulses in orgasmic bliss.<br><br>
<</if>>
<<if $penis3 is "idle">><<He>> groans as a wet patch forms on <<his>> trousers.<br><br>
<</if>>
<<if $penis3 is "thighs">><<He>> ejaculates onto your thighs.<br><br>
<<thighejacstat>><<ejacstat>><<set $hygiene += 500>><<set $thighsemen += 1>>
<</if>>
<<if $penis3 is "vaginaentrance">><<He>> ejaculates onto your pussy.<br><br>
<<vaginalentranceejacstat>><<ejacstat>><<set $hygiene += 500>><<set $vaginaoutsidesemen += 1>>
<</if>>
<<if $penis3 is "vaginaimminent">><<He>> ejaculates onto your pussy.<br><br>
<<vaginalentranceejacstat>><<ejacstat>><<set $hygiene += 500>><<set $vaginaoutsidesemen += 1>>
<</if>>
<<if $penis3 is "vagina">><<He>> ejaculates deep into your womb.<br><br><<vaginalejacstat>><<ejacstat>><<set $hygiene += 500>><<set $vaginasemen += 1>>
<</if>>
<<if $penis3 is "cheeks">><<He>> ejaculates onto your back.
<br><br><<bottomejacstat>><<ejacstat>><<set $hygiene += 500>><<set $bottomsemen += 1>>
<</if>>
<<if $penis3 is "anusentrance">><<He>> ejaculates onto your <<bottomstop>><br>
<br><<bottomejacstat>><<ejacstat>><<set $hygiene += 500>><<set $bottomsemen += 1>>
<</if>>
<<if $penis3 is "anusimminent">><<He>> ejaculates onto your <<bottomstop>><br>
<br><<bottomejacstat>><<ejacstat>><<set $hygiene += 500>><<set $bottomsemen += 1>>
<</if>>
<<if $penis3 is "anus">><<He>> ejaculates into your bowels.
<br><br><<analejacstat>><<ejacstat>><<set $hunger -= 200>><<set $thirst -= 200>><<set $hygiene += 500>><<set $anussemen += 1>>
<</if>>
<<if $penis3 is "chest">><<He>> ejaculates onto your chest.
<br><br><<chestejacstat>><<ejacstat>><<set $hygiene += 500>><<set $chestsemen += 1>>
<</if>>
<<if $penis3 is "mouthentrance">><<He>> ejaculates onto your face.
<br><br><<faceejacstat>><<ejacstat>><<set $hygiene += 500>><<set $facesemen += 1>>
<</if>>
<<if $penis3 is "mouthimminent">><<He>> ejaculates onto your face.
<br><br><<faceejacstat>><<ejacstat>><<set $hygiene += 500>><<set $facesemen += 1>>
<</if>>
<<if $penis3 is "mouth">><<He>> ejaculates down the back of your throat.
<br><br><<oralejacstat>><<ejacstat>><<set $hunger -= 200>><<set $thirst -= 200>><<set $mouthsemen += 1>>
<</if>>
<<if $penis3 is "feet">><<He>> ejaculates on your feet.
<br><br><<feetejacstat>><<ejacstat>><<set $hygiene += 500>><<set $feetsemen += 1>>
<</if>>
<<if $penis3 is "leftarm" and $penis is "rightarm">><<He>> ejaculates on your hands.
<br><br><<handejacstat>><<ejacstat>><<set $hygiene += 500>><<set $leftarmsemen += 1>><<set $rightarmsemen += 1>>
<</if>>
<<if $penis3 is "leftarm">><<He>> ejaculates on your hand.
<br><br><<handejacstat>><<ejacstat>><<set $hygiene += 500>><<set $leftarmsemen += 1>>
<</if>>
<<if $penis3 is "rightarm">><<He>> ejaculates on your hand.
<br><br><<handejacstat>><<ejacstat>><<set $hygiene += 500>><<set $rightarmsemen += 1>>
<</if>>
<<if $penis3 is 0>><<He>> ejaculates onto your tummy.
<br><br>
<<tummyejacstat>><<ejacstat>><<set $hygiene += 500>><<set $tummysemen += 1>>
<</if>>
<</if>>
<<if $enemyno gte 4>>
<<if $consensual is 1>>
<<famesex 1>>
<<else>>
<<famerape 1>>
<</if>>
<<if $exposed is 1>>
<<fameexhibitionism 1>>
<<elseif $exposed gte 2>>
<<fameexhibitionism 2>>
<</if>>
<<if $pronoun4 is "m">>
<<set $pronoun to "m">>
<</if>>
<<if $pronoun4 is "f">>
<<set $pronoun to "f">>
<</if>>
<<if $pronoun4 is "i">>
<<set $pronoun to "i">>
<</if>>
<<if $pronoun4 is "n">>
<<set $pronoun to "n">>
<</if>>
<<if $pronoun4 is "t">>
<<set $pronoun to "t">>
<</if>>
<<set $intro4 to 1>>
<<if $vagina4 isnot "none" and $penis4 is "none">>
<<He>> convulses in orgasmic bliss.<br><br>
<</if>>
<<if $penis4 is "idle">><<He>> groans as a wet patch forms on <<his>> trousers.<br><br>
<</if>>
<<if $penis4 is "thighs">><<He>> ejaculates onto your thighs.<br><br>
<<thighejacstat>><<ejacstat>><<set $hygiene += 500>><<set $thighsemen += 1>>
<</if>>
<<if $penis4 is "vaginaentrance">><<He>> ejaculates onto your pussy.<br><br>
<<vaginalentranceejacstat>><<ejacstat>><<set $hygiene += 500>><<set $vaginaoutsidesemen += 1>>
<</if>>
<<if $penis4 is "vaginaimminent">><<He>> ejaculates onto your pussy.<br><br>
<<vaginalentranceejacstat>><<ejacstat>><<set $hygiene += 500>><<set $vaginaoutsidesemen += 1>>
<</if>>
<<if $penis4 is "vagina">><<He>> ejaculates deep into your womb.<br><br><<vaginalejacstat>><<ejacstat>><<set $hygiene += 500>><<set $vaginasemen += 1>>
<</if>>
<<if $penis4 is "cheeks">><<He>> ejaculates onto your back.
<br><br><<bottomejacstat>><<ejacstat>><<set $hygiene += 500>><<set $bottomsemen += 1>>
<</if>>
<<if $penis4 is "anusentrance">><<He>> ejaculates onto your <<bottomstop>><br>
<br><<bottomejacstat>><<ejacstat>><<set $hygiene += 500>><<set $bottomsemen += 1>>
<</if>>
<<if $penis4 is "anusimminent">><<He>> ejaculates onto your <<bottomstop>><br>
<br><<bottomejacstat>><<ejacstat>><<set $hygiene += 500>><<set $bottomsemen += 1>>
<</if>>
<<if $penis4 is "anus">><<He>> ejaculates into your bowels.
<br><br><<analejacstat>><<ejacstat>><<set $hunger -= 200>><<set $thirst -= 200>><<set $hygiene += 500>><<set $anussemen += 1>>
<</if>>
<<if $penis4 is "chest">><<He>> ejaculates onto your chest.
<br><br><<chestejacstat>><<ejacstat>><<set $hygiene += 500>><<set $chestsemen += 1>>
<</if>>
<<if $penis4 is "mouthentrance">><<He>> ejaculates onto your face.
<br><br><<faceejacstat>><<ejacstat>><<set $hygiene += 500>><<set $facesemen += 1>>
<</if>>
<<if $penis4 is "mouthimminent">><<He>> ejaculates onto your face.
<br><br><<faceejacstat>><<ejacstat>><<set $hygiene += 500>><<set $facesemen += 1>>
<</if>>
<<if $penis4 is "mouth">><<He>> ejaculates down the back of your throat.
<br><br><<oralejacstat>><<ejacstat>><<set $hunger -= 200>><<set $thirst -= 200>><<set $mouthsemen += 1>>
<</if>>
<<if $penis4 is "feet">><<He>> ejaculates on your feet.
<br><br><<feetejacstat>><<ejacstat>><<set $hygiene += 500>><<set $feetsemen += 1>>
<</if>>
<<if $penis4 is "leftarm" and $penis is "rightarm">><<He>> ejaculates on your hands.
<br><br><<handejacstat>><<ejacstat>><<set $hygiene += 500>><<set $leftarmsemen += 1>><<set $rightsemen += 1>>
<</if>>
<<if $penis4 is "leftarm">><<He>> ejaculates on your hand.
<br><br><<handejacstat>><<ejacstat>><<set $hygiene += 500>><<set $leftarmsemen += 1>>
<</if>>
<<if $penis4 is "rightarm">><<He>> ejaculates on your hand.
<br><br><<handejacstat>><<ejacstat>><<set $hygiene += 500>><<set $rightsemen += 1>>
<</if>>
<<if $penis4 is 0>><<He>> ejaculates onto your tummy.
<br><br>
<<tummyejacstat>><<ejacstat>><<set $hygiene += 500>><<set $tummysemen += 1>>
<</if>>
<</if>>
<<if $enemyno gte 5>>
<<if $consensual is 1>>
<<famesex 1>>
<<else>>
<<famerape 1>>
<</if>>
<<if $exposed is 1>>
<<fameexhibitionism 1>>
<<elseif $exposed gte 2>>
<<fameexhibitionism 2>>
<</if>>
<<if $pronoun5 is "m">>
<<set $pronoun to "m">>
<</if>>
<<if $pronoun5 is "f">>
<<set $pronoun to "f">>
<</if>>
<<if $pronoun5 is "i">>
<<set $pronoun to "i">>
<</if>>
<<if $pronoun5 is "n">>
<<set $pronoun to "n">>
<</if>>
<<if $pronoun5 is "t">>
<<set $pronoun to "t">>
<</if>>
<<set $intro2 to 1>>
<<if $vagina5 isnot "none" and $penis5 is "none">>
<<He>> convulses in orgasmic bliss.<br><br>
<</if>>
<<if $penis5 is "idle">><<He>> groans as a wet patch forms on <<his>> trousers.<br><br>
<</if>>
<<if $penis5 is "thighs">><<He>> ejaculates onto your thighs.<br><br>
<<thighejacstat>><<ejacstat>><<set $hygiene += 500>><<set $thighsemen += 1>>
<</if>>
<<if $penis5 is "vaginaentrance">><<He>> ejaculates onto your pussy.<br><br>
<<vaginalentranceejacstat>><<ejacstat>><<set $hygiene += 500>><<set $vaginaoutsidesemen += 1>>
<</if>>
<<if $penis5 is "vaginaimminent">><<He>> ejaculates onto your pussy.<br><br>
<<vaginalentranceejacstat>><<ejacstat>><<set $hygiene += 500>><<set $vaginaoutsidesemen += 1>>
<</if>>
<<if $penis5 is "vagina">><<He>> ejaculates deep into your womb.<br><br><<vaginalejacstat>><<ejacstat>><<set $hygiene += 500>><<set $vaginasemen += 1>>
<</if>>
<<if $penis5 is "cheeks">><<He>> ejaculates onto your back.
<br><br><<bottomejacstat>><<ejacstat>><<set $hygiene += 500>><<set $bottomsemen += 1>>
<</if>>
<<if $penis5 is "anusentrance">><<He>> ejaculates onto your <<bottomstop>><br>
<br><<bottomejacstat>><<ejacstat>><<set $hygiene += 500>><<set $bottomsemen += 1>>
<</if>>
<<if $penis5 is "anusimminent">><<He>> ejaculates onto your <<bottomstop>><br>
<br><<bottomejacstat>><<ejacstat>><<set $hygiene += 500>><<set $bottomsemen += 1>>
<</if>>
<<if $penis5 is "anus">><<He>> ejaculates into your bowels.
<br><br><<analejacstat>><<ejacstat>><<set $hunger -= 200>><<set $thirst -= 200>><<set $hygiene += 500>><<set $anussemen += 1>>
<</if>>
<<if $penis5 is "chest">><<He>> ejaculates onto your chest.
<br><br><<chestejacstat>><<ejacstat>><<set $hygiene += 500>><<set $chestsemen += 1>>
<</if>>
<<if $penis5 is "mouthentrance">><<He>> ejaculates onto your face.
<br><br><<faceejacstat>><<ejacstat>><<set $hygiene += 500>><<set $facesemen += 1>>
<</if>>
<<if $penis5 is "mouthimminent">><<He>> ejaculates onto your face.
<br><br><<faceejacstat>><<ejacstat>><<set $hygiene += 500>><<set $facesemen += 1>>
<</if>>
<<if $penis5 is "mouth">><<He>> ejaculates down the back of your throat.
<br><br><<oralejacstat>><<ejacstat>><<set $hunger -= 200>><<set $thirst -= 200>><<set $mouthsemen += 1>>
<</if>>
<<if $penis5 is "feet">><<He>> ejaculates on your feet.
<br><br><<feetejacstat>><<ejacstat>><<set $hygiene += 500>><<set $feetsemen += 1>>
<</if>>
<<if $penis5 is "leftarm" and $penis is "rightarm">><<He>> ejaculates on your hands.
<br><br><<handejacstat>><<ejacstat>><<set $hygiene += 500>><<set $leftarmsemen += 1>><<set $rightsemen += 1>>
<</if>>
<<if $penis5 is "leftarm">><<He>> ejaculates on your hand.
<br><br><<handejacstat>><<ejacstat>><<set $hygiene += 500>><<set $leftarmsemen += 1>>
<</if>>
<<if $penis5 is "rightarm">><<He>> ejaculates on your hand.
<br><br><<handejacstat>><<ejacstat>><<set $hygiene += 500>><<set $rightsemen += 1>>
<</if>>
<<if $penis5 is 0>><<He>> ejaculates onto your tummy.
<br><br>
<<tummyejacstat>><<ejacstat>><<set $hygiene += 500>><<set $tummysemen += 1>>
<</if>>
<</if>>
<<if $enemyno gte 6>>
<<if $consensual is 1>>
<<famesex 1>>
<<else>>
<<famerape 1>>
<</if>>
<<if $exposed is 1>>
<<fameexhibitionism 1>>
<<elseif $exposed gte 2>>
<<fameexhibitionism 2>>
<</if>>
<<if $pronoun6 is "m">>
<<set $pronoun to "m">>
<</if>>
<<if $pronoun6 is "f">>
<<set $pronoun to "f">>
<</if>>
<<if $pronoun6 is "i">>
<<set $pronoun to "i">>
<</if>>
<<if $pronoun6 is "n">>
<<set $pronoun to "n">>
<</if>>
<<if $pronoun6 is "t">>
<<set $pronoun to "t">>
<</if>>
<<set $intro6 to 1>>
<<if $vagina6 isnot "none" and $penis6 is "none">>
<<He>> convulses in orgasmic bliss.<br><br>
<</if>>
<<if $penis6 is "idle">><<He>> groans as a wet patch forms on <<his>> trousers.<br><br>
<</if>>
<<if $penis6 is "thighs">><<He>> ejaculates onto your thighs.<br><br>
<<thighejacstat>><<ejacstat>><<set $hygiene += 500>>
<<set $thighsemen += 1>><</if>>
<<if $penis6 is "vaginaentrance">><<He>> ejaculates onto your pussy.<br><br>
<<vaginalentranceejacstat>><<ejacstat>><<set $hygiene += 500>><<set $vaginaoutsidesemen += 1>>
<</if>>
<<if $penis6 is "vaginaimminent">><<He>> ejaculates onto your pussy.<br><br>
<<vaginalentranceejacstat>><<ejacstat>><<set $hygiene += 500>><<set $vaginaoutsidesemen += 1>>
<</if>>
<<if $penis6 is "vagina">><<He>> ejaculates deep into your womb.<br><br><<vaginalejacstat>><<ejacstat>><<set $hygiene += 500>><<set $vaginasemen += 1>>
<</if>>
<<if $penis6 is "cheeks">><<He>> ejaculates onto your back.
<br><br><<bottomejacstat>><<ejacstat>><<set $hygiene += 500>><<set $bottomsemen += 1>>
<</if>>
<<if $penis6 is "anusentrance">><<He>> ejaculates onto your <<bottomstop>><br>
<br><<bottomejacstat>><<ejacstat>><<set $hygiene += 500>><<set $bottomsemen += 1>>
<</if>>
<<if $penis6 is "anusimminent">><<He>> ejaculates onto your <<bottomstop>><br>
<br><<bottomejacstat>><<ejacstat>><<set $hygiene += 500>><<set $bottomsemen += 1>>
<</if>>
<<if $penis6 is "anus">><<He>> ejaculates into your bowels.
<br><br><<analejacstat>><<ejacstat>><<set $hunger -= 200>><<set $thirst -= 200>><<set $hygiene += 500>><<set $anussemen += 1>>
<</if>>
<<if $penis6 is "chest">><<He>> ejaculates onto your chest.
<br><br><<chestejacstat>><<ejacstat>><<set $hygiene += 500>><<set $chestsemen += 1>>
<</if>>
<<if $penis6 is "mouthentrance">><<He>> ejaculates onto your face.
<br><br><<faceejacstat>><<ejacstat>><<set $hygiene += 500>><<set $facesemen += 1>>
<</if>>
<<if $penis6 is "mouthimminent">><<He>> ejaculates onto your face.
<br><br><<faceejacstat>><<ejacstat>><<set $hygiene += 500>><<set $facesemen += 1>>
<</if>>
<<if $penis6 is "mouth">><<He>> ejaculates down the back of your throat.
<br><br><<oralejacstat>><<ejacstat>><<set $hunger -= 200>><<set $thirst -= 200>><<set $mouthsemen += 1>>
<</if>>
<<if $penis6 is "feet">><<He>> ejaculates on your feet.
<br><br><<feetejacstat>><<ejacstat>><<set $hygiene += 500>><<set $feetsemen += 1>>
<</if>>
<<if $penis6 is "leftarm" and $penis is "rightarm">><<He>> ejaculates on your hands.
<br><br><<handejacstat>><<ejacstat>><<set $hygiene += 500>><<set $leftarmsemen += 1>><<set $rightarmsemen += 1>>
<</if>>
<<if $penis6 is "leftarm">><<He>> ejaculates on your hand.
<br><br><<handejacstat>><<ejacstat>><<set $hygiene += 500>><<set $leftarmsemen += 1>>
<</if>>
<<if $penis6 is "rightarm">><<He>> ejaculates on your hand.
<br><br><<handejacstat>><<ejacstat>><<set $hygiene += 500>><<set $rightsemen += 1>>
<</if>>
<<if $penis6 is 0>><<He>> ejaculates onto your tummy.
<br><br>
<<tummyejacstat>><<ejacstat>><<set $hygiene += 500>><<set $tummysemen += 1>>
<</if>>
<</if>>
<<if $images is 1>>
<<combatimg>>
<br>
<</if>>
<<set $ejaculating to 0>>
<</nobr>><</widget>>
<<widget "beastejaculation">><<nobr>>
<<set $ejaculating to 1>>
<<set $enemyejaculated += 1>>
<<set $pronoun to "i">>
<<if $penis is "thighs">><<He>> ejaculates onto your thighs.<br><br>
<<thighejacstat>><<ejacstat>><<set $hygiene += 500>><<set $thighsemen += 1>>
<</if>>
<<if $penis is "vaginaentrance">><<He>> ejaculates onto your pussy.<br><br>
<<vaginalentranceejacstat>><<ejacstat>><<set $hygiene += 500>><<set $vaginaoutsidesemen += 1>>
<</if>>
<<if $penis is "vaginaimminent">><<He>> ejaculates onto your pussy.<br><br>
<<vaginalentranceejacstat>><<ejacstat>><<set $hygiene += 500>><<set $vaginaoutsidesemen += 1>>
<</if>>
<<if $penis is "vagina">>
<<if random(1, 100) gte 81 and $beasttype is "dog">>
With a final thrust, it forces its knot into your <<pussystop>> It ejaculates deep into your womb. You feel the semen build within you, its exit plugged. The $beasttype climbs off and faces away from you, but you're locked together for a humiliating five minutes until the knot shrinks enough that the $beasttype can wiggle it free.<<pass 5>>
<<elseif random(1, 100) gte 61 and $beasttype is "wolf">>
With a final thrust, it forces its knot into your <<pussystop>> It ejaculates deep into your womb. You feel the semen build within you, its exit plugged. The $beasttype climbs off and faces away from you, but you're locked together for a humiliating five minutes until the knot shrinks enough that the $beasttype can wiggle it free.<<pass 5>><<set $wolfbuild += 1>>
<<else>>
<<He>> ejaculates deep into your womb.
<</if>>
<br><br><<vaginalejacstat>><<ejacstat>><<set $hygiene += 500>><<set $vaginasemen += 1>>
<<if $beasttype is "wolf">>
<<set $wolfbuild += 1>>
<</if>>
<</if>>
<<if $penis is "cheeks">><<He>> ejaculates onto your back.
<br><br><<bottomejacstat>><<ejacstat>><<set $hygiene += 500>><<set $bottomsemen += 1>>
<</if>>
<<if $penis is "anusentrance">><<He>> ejaculates onto your <<bottomstop>><br>
<br><<bottomejacstat>><<ejacstat>><<set $hygiene += 500>><<set $bottomsemen += 1>>
<</if>>
<<if $penis is "anusimminent">><<He>> ejaculates onto your <<bottomstop>><br>
<br><<bottomejacstat>><<ejacstat>><<set $hygiene += 500>><<set $bottomsemen += 1>>
<</if>>
<<if $penis is "anus">>
<<if random(1, 100) gte 81 and $beasttype is "dog">>
With a final thrust, it forces its knot into your <<bottomstop>> It ejaculates deep into your bowels. You feel the semen build within you, its exit plugged. The $beasttype climbs off and faces away from you, but you're locked together for a humiliating five minutes until the knot shrinks enough that the $beasttype can wiggle it free.<<pass 5>>
<<elseif random(1, 100) gte 61 and $beasttype is "wolf">>
With a final thrust, it forces its knot into your <<bottomstop>> It ejaculates deep into your bowels. You feel the semen build within you, its exit plugged. The $beasttype climbs off and faces away from you, but you're locked together for a humiliating five minutes until the knot shrinks enough that the $beasttype can wiggle it free.<<pass 5>><<set $wolfbuild += 1>>
<<else>>
<<He>> ejaculates into your bowels.
<</if>>
<br><br><<analejacstat>><<ejacstat>><<set $hunger -= 200>><<set $thirst -= 200>><<set $hygiene += 500>><<set $anussemen += 1>>
<<if $beasttype is "wolf">>
<<set $wolfbuild += 1>>
<</if>>
<</if>>
<<if $penis is "chest">><<He>> ejaculates onto your chest.
<br><br><<chestejacstat>><<ejacstat>><<set $hygiene += 500>><<set $chestsemen += 1>>
<</if>>
<<if $penis is "mouthentrance">><<He>> ejaculates onto your face.
<br><br><<faceejacstat>><<ejacstat>><<set $hygiene += 500>><<set $facesemen += 1>>
<</if>>
<<if $penis is "mouthimminent">><<He>> ejaculates onto your face.
<br><br><<faceejacstat>><<ejacstat>><<set $hygiene += 500>><<set $facesemen += 1>>
<</if>>
<<if $penis is "mouth">><<He>> ejaculates down the back of your throat.
<br><br><<oralejacstat>><<ejacstat>><<set $hunger -= 200>><<set $thirst -= 200>><<set $mouthsemen += 1>>
<<if $beasttype is "wolf">>
<<set $wolfbuild += 1>>
<</if>>
<</if>>
<<if $penis is "feet">><<He>> ejaculates on your feet.
<br><br><<feetejacstat>><<ejacstat>><<set $hygiene += 500>><<set $feetsemen += 1>>
<</if>>
<<if $penis is "leftarm" and $penis is "rightarm">><<He>> ejaculates on your hands.
<br><br><<handejacstat>><<ejacstat>><<set $hygiene += 500>><<set $leftarmsemen += 1>><<set $rightarmsemen += 1>>
<</if>>
<<if $penis is "leftarm">><<He>> ejaculates on your hand.
<br><br><<handejacstat>><<ejacstat>><<set $hygiene += 500>><<set $leftarmsemen += 1>>
<</if>>
<<if $penis is "rightarm">><<He>> ejaculates on your hand.
<br><br><<handejacstat>><<ejacstat>><<set $hygiene += 500>><<set $rightarmsemen += 1>>
<</if>>
<<if $penis is 0>><<He>> ejaculates onto your tummy.
<br><br>
<<tummyejacstat>><<ejacstat>><<set $hygiene += 500>><<set $tummysemen += 1>>
<</if>>
<<if $images is 1>>
<<combatimg>>
<br>
<</if>>
<<if $beastnomax - $beastno is 0>>
<<set $enemyarousal to $enemyarousal2>>
<<set $enemyanger to $enemyanger2>>
<<set $enemyhealth to $enemyhealth2>>
<<set $enemytrust to $enemytrust2>>
<<elseif $beastnomax - $beastno is 1>>
<<set $enemyarousal to $enemyarousal3>>
<<set $enemyanger to $enemyanger3>>
<<set $enemyhealth to $enemyhealth3>>
<<set $enemytrust to $enemytrust3>>
<<elseif $beastnomax - $beastno is 2>>
<<set $enemyarousal to $enemyarousal4>>
<<set $enemyanger to $enemyanger4>>
<<set $enemyhealth to $enemyhealth4>>
<<set $enemytrust to $enemytrust4>>
<<elseif $beastnomax - $beastno is 3>>
<<set $enemyarousal to $enemyarousal5>>
<<set $enemyanger to $enemyanger5>>
<<set $enemyhealth to $enemyhealth5>>
<<set $enemytrust to $enemytrust5>>
<<elseif $beastnomax - $beastno is 4>>
<<set $enemyarousal to $enemyarousal6>>
<<set $enemyanger to $enemyanger6>>
<<set $enemyhealth to $enemyhealth6>>
<<set $enemytrust to $enemytrust6>>
<<elseif $beastnomax - $beastno is 5>>
<<set $enemyarousal to $enemyarousal2>>
<<set $enemyanger to $enemyanger2>>
<<set $enemyhealth to $enemyhealth2>>
<<set $enemytrust to $enemytrust2>>
<</if>>
<<if $water is 0>>
<<if $penis is "vagina">><<set $semenpuddle += 1>>
<br><<His>> penis slides out of your vagina.<br>
<<if $semenpuddle is 1>>
Lacking anything to hold it in, semen drools out and forms a puddle beneath you.<br><br>
<</if>>
<<if $semenpuddle is 2>>
Lacking anything to hold it in, semen drools out and adds to the puddle beneath you.<br><br>
<</if>>
<<if $semenpuddle is 3>>
Lacking anything to hold it in, semen drools out and adds to the growing puddle beneath you.<br><br>
<</if>>
<<if $semenpuddle is 4>>
Lacking anything to hold it in, semen drools out and adds to the growing pool beneath you.<br><br>
<</if>>
<<if $semenpuddle is 5>>
Lacking anything to hold it in, semen drools out and adds to the growing pool beneath you.<br><br>
<</if>>
<<if $semenpuddle is 6>>
Lacking anything to hold it in, semen drools out and adds to the growing pool beneath you.<br><br>
<</if>>
<</if>>
<<if $penis is "anus">><<set $semenpuddle += 1>>
<<His>> penis slides out of your anus.<br>
<<if $semenpuddle is 1>>
Lacking anything to hold it in, semen drools out and forms a puddle beneath you.<br><br>
<</if>>
<<if $semenpuddle is 2>>
Lacking anything to hold it in, semen drools out and adds to the puddle beneath you.<br><br>
<</if>>
<<if $semenpuddle is 3>>
Lacking anything to hold it in, semen drools out and adds to the growing puddle beneath you.<br><br>
<</if>>
<<if $semenpuddle is 4>>
Lacking anything to hold it in, semen drools out and adds to the growing pool beneath you.<br><br>
<</if>>
<<if $semenpuddle is 5>>
Lacking anything to hold it in, semen drools out and adds to the growing pool beneath you.<br><br>
<</if>>
<<if $semenpuddle is 6>>
Lacking anything to hold it in, semen drools out and adds to the growing pool beneath you.<br><br>
<</if>>
<</if>>
<</if>>
<<set $beaststance to "approach">><<set $penis to 0>><<set $mouth to 0>>
<<if $vaginaexist is 1>>
<<set $vaginause to 0>>
<<set $vaginastate to 0>>
<</if>>
<<if $penisexist is 1>>
<<set $penisuse to 0>>
<<set $penisstate to 0>>
<</if>>
<<set $mouthuse to 0>>
<<set $anususe to 0>>
<<set $thighuse to 0>>
<<set $bottomuse to 0>>
<<set $feetuse to 0>>
<<if $leftarm isnot "bound" and $position isnot "wall">>
<<set $leftarm to 0>>
<</if>>
<<if $rightarm isnot "bound" and $position isnot "wall">>
<<set $rightarm to 0>>
<</if>>
<<set $chestuse to 0>>
<<if $head isnot "bound" and $position isnot "wall">>
<<set $head to 0>>
<</if>>
<<set $anusstate to 0>>
<<set $mouthstate to 0>>
<<set $leftaction to 0>>
<<set $rightaction to 0>>
<<set $vaginaaction to 0>>
<<set $anusaction to 0>>
<<set $thighaction to 0>>
<<set $cheekaction to 0>>
<<set $feetaction to 0>>
<<set $mouthaction to 0>>
<<set $ejaculating to 0>>
<</nobr>><</widget>>
:: Widgets Wound [widget]
<<widget "beastwound">><<nobr>>
<<set $enemywounded += 1>>
<<if $beastnomax - $beastno is 0>>
<<set $enemyarousal to $enemyarousal2>>
<<set $enemyanger to $enemyanger2>>
<<set $enemyhealth to $enemyhealth2>>
<<set $enemytrust to $enemytrust2>>
<<elseif $beastnomax - $beastno is 1>>
<<set $enemyarousal to $enemyarousal3>>
<<set $enemyanger to $enemyanger3>>
<<set $enemyhealth to $enemyhealth3>>
<<set $enemytrust to $enemytrust3>>
<<elseif $beastnomax - $beastno is 2>>
<<set $enemyarousal to $enemyarousal4>>
<<set $enemyanger to $enemyanger4>>
<<set $enemyhealth to $enemyhealth4>>
<<set $enemytrust to $enemytrust4>>
<<elseif $beastnomax - $beastno is 3>>
<<set $enemyarousal to $enemyarousal5>>
<<set $enemyanger to $enemyanger5>>
<<set $enemyhealth to $enemyhealth5>>
<<set $enemytrust to $enemytrust5>>
<<elseif $beastnomax - $beastno is 4>>
<<set $enemyarousal to $enemyarousal6>>
<<set $enemyanger to $enemyanger6>>
<<set $enemyhealth to $enemyhealth6>>
<<set $enemytrust to $enemytrust6>>
<<elseif $beastnomax - $beastno is 5>>
<<set $enemyarousal to $enemyarousal2>>
<<set $enemyanger to $enemyanger2>>
<<set $enemyhealth to $enemyhealth2>>
<<set $enemytrust to $enemytrust2>>
<</if>>
<<set $beaststance to "approach">><<set $penis to 0>><<set $mouth to 0>>
<<set $mouthuse to 0>>
<<set $anususe to 0>>
<<if $vaginaexist is 1>>
<<set $vaginause to 0>>
<<set $vaginastate to 0>>
<</if>>
<<set $thighuse to 0>>
<<set $bottomuse to 0>>
<<set $feetuse to 0>>
<<if $leftarm isnot "bound" and $position isnot "wall">>
<<set $leftarm to 0>>
<</if>>
<<if $rightarm isnot "bound" and $position isnot "wall">>
<<set $rightarm to 0>>
<</if>>
<<set $chestuse to 0>>
<<if $head isnot "bound" and $position isnot "wall">>
<<set $head to 0>>
<</if>>
<<set $anusstate to 0>>
<<set $mouthstate to 0>>
<<set $leftaction to 0>>
<<set $rightaction to 0>>
<<set $vaginaaction to 0>>
<<set $anusaction to 0>>
<<set $thighaction to 0>>
<<set $cheekaction to 0>>
<<set $feetaction to 0>>
<<set $mouthaction to 0>>
<</nobr>><</widget>>
:: Widgets Combat Man 2 [widget]
<<widget "man2">><<nobr>>
<<if $pronoun2 is "m">>
<<set $pronoun to "m">>
<</if>>
<<if $pronoun2 is "f">>
<<set $pronoun to "f">>
<</if>>
<<if $pronoun2 is "i">>
<<set $pronoun to "i">>
<</if>>
<<if $pronoun2 is "n">>
<<set $pronoun to "n">>
<</if>>
<<if $pronoun2 is "t">>
<<set $pronoun to "t">>
<</if>>
<<man2speech>>
<<set $intro2 to 1>>
<<if $lefthand2 is "spank">><<bruise bottom>><<hitstat>><<set $speechspank to 1>>
<<He>> spanks your <<bottom>>
<<if $lowerclothes isnot "naked" and $lowerstate is "waist">>
through your $lowerclothes.
<<elseif $underclothes isnot "naked" and $understate is "waist">>
through your $underclothes.
<<else>>
reddening your exposed skin.
<</if>>
<<violence 5>>
<</if>>
<<if $righthand2 is "spank">><<bruise bottom>><<hitstat>>
<<He>> spanks your <<bottom>><<set $speechspank to 1>>
<<if $lowerclothes isnot "naked" and $lowerstate is "waist">>
through your $lowerclothes.
<<elseif $underclothes isnot "naked" and $understate is "waist">>
through your $underclothes.
<<else>>
reddening your exposed skin.
<</if>>
<<violence 5>>
<</if>>
<<if $lefthand2 is "arms">>
<<if $enemytrust gte 20 and $enemyanger lte 20>><span class="lblue"><<He>> releases your arms.</span><<set $lefthand2 to 0>><<set $leftarm to 0>><<set $rightarm to 0>>
<<else>><<He>> grips your arms.
<<violence 6>><<bruise leftarm>><<bruise rightarm>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand2 is "arms">>
<<if $enemytrust gte 20 and $enemyanger lte 20>><span class="lblue"><<He>> releases your arms.</span><<set $righthand2 to 0>><<set $leftarm to 0>><<set $rightarm to 0>>
<<else>><<He>> grips your arms.
<<violence 6>><<bruise leftarm>><<bruise rightarm>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand2 is "leftarm">>
<<if $enemytrust gte 20 and $enemyanger lte 20>><span class="lblue"><<He>> releases your left arm.</span><<set $lefthand2 to 0>><<set $leftarm to 0>>
<<else>><<He>> grips your left arm.<<violence 3>><<bruise leftarm>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand2 is "leftarm">>
<<if $enemytrust gte 20 and $enemyanger lte 20>><span class="lblue"><<He>> releases your left arm.</span><<set $righthand2 to 0>><<set $leftarm to 0>>
<<else>><<He>> grips your left arm.<<violence 3>><<bruise leftarm>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand2 is "rightarm">>
<<if $enemytrust gte 20 and $enemyanger lte 20>><span class="lblue"><<He>> releases your right arm.</span><<set $lefthand2 to 0>><<set $rightarm to 0>>
<<else>><<He>> grips your right arm.<<violence 3>><<bruise rightarm>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand2 is "rightarm">>
<<if $enemytrust gte 20 and $enemyanger lte 20>><span class="lblue"><<He>> releases your right arm.</span><<set $righthand2 to 0>><<set $rightarm to 0>>
<<else>><<He>> grips your right arm.<<violence 3>><<bruise rightarm>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand2 is "vaginaentrance">>
<<if $rng gte 101>><span class="blue"><<He>> moves <<his>> left hand away from your <<pussystop>></span><<set $lefthand2 to 0>><<set $vaginause to 0>>
<<elseif $rng gte 81>><<He>> <<strokes>> your labia.<<neutral 10>>
<<elseif $rng gte 21>><<He>> gives your clitoris a tweak.<<set $speechclit to 1>><<neutral 10>>
<<elseif $rng lte 20>><span class="pink"><<He>> plunges a finger into your <<pussystop>></span><<neutral 15>><<set $lefthand2 to "vagina">><<set $speechvagina to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand2 is "vaginaentrance">>
<<if $rng gte 101>><span class="blue"><<He>> moves <<his>> right hand away from your <<pussystop>></span><<set $righthand2 to 0>><<set $vaginause to 0>>
<<elseif $rng gte 51>><<He>> <<strokes>> your labia.<<neutral 10>>
<<elseif $rng gte 21>><<He>> gives your clitoris a tweak.<<neutral 10>><<set $speechclit to 1>>
<<elseif $rng lte 20>><span class="pink"><<He>> plunges a finger into your warm <<pussystop>></span><<neutral 15>><<set $righthand2 to "vagina">><<set $speechvagina to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand2 is "penisentrance">>
<<if $rng gte 101>><span class="blue"><<He>> moves <<his>> left hand away from your <<penisstop>></span><<set $lefthand2 to 0>><<set $penisuse to 0>>
<<elseif $rng gte 51>><<He>> <<strokes>> your shaft.<<neutral 10>>
<<elseif $rng gte 21>><<He>> rubs your glans.<<neutral 10>><<set $speechglans to 1>>
<<elseif $rng lte 20>><span class="pink"><<He>> wraps <<his>> fingers around your <<penisstop>></span><<neutral 15>><<set $lefthand2 to "penis">><<set $speechpenis to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand2 is "penisentrance">>
<<if $rng gte 101>><span class="blue"><<He>> moves <<his>> right hand away from your <<penisstop>></span><<set $righthand2 to 0>><<set $penisuse to 0>>
<<elseif $rng gte 51>><<He>> <<strokes>> your shaft.<<neutral 10>>
<<elseif $rng gte 21>><<He>> rubs your glans.<<neutral 10>><<set $speechglans to 1>>
<<elseif $rng lte 20>><span class="pink"><<He>> wraps <<his>> fingers around your penis.</span><<neutral 15>><<set $righthand2 to "penis">><<set $speechpenis to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand2 is "vagina">>
<<if $rng gte 101>><span class="purple"><<He>> slides <<his>> finger out of your <<pussystop>></span><<set $lefthand2 to "vaginaentrance">><<neutral 15>>
<<elseif $rng lte 100>><<He>> <<strokes>> the inside of your <<pussycomma>><<neutral 20>><<set $speechvagina to 1>>
<<if $arousal gte 8000>>
causing involuntary shudders.
<<elseif $arousal gte 2000>>
coaxing out lewd fluid.
<<else>>
eager to explore it.
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand2 is "vagina">>
<<if $rng gte 101>><span class="purple"><<He>> slides <<his>> finger out of your <<pussystop>></span><<set $righthand2 to "vaginaentrance">><<neutral 15>>
<<elseif $rng lte 100>><<He>> <<strokes>> the inside of your <<pussycomma>><<neutral 20>><<set $speechvagina to 1>>
<<if $arousal gte 8000>>
causing you involuntary shudders.
<<elseif $arousal gte 2000>>
coaxing out lewd fluid.
<<else>>
invading your body in a most sordid manner.
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand2 is "penis">>
<<if $rng gte 101>><span class="purple"><<He>> releases your <<penis>> from <<his>> grip.</span><<set $lefthand2 to "penisentrance">><<neutral 15>>
<<elseif $rng lte 100>><<He>> massages the length of your <<peniscomma>><<neutral 20>><<set $speechpenis to 1>>
<<if $arousal gte 8000>>
causing you involuntary shudders.
<<elseif $arousal gte 2000>>
coaxing out lewd fluid.
<<else>>
exploiting your body's natural reactions in a most sordid manner.
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand2 is "penis">>
<<if $rng gte 101>><span class="purple"><<He>> releases your <<penis>> from <<his>> grip.</span><<set $righthand2 to "penisentrance">><<neutral 15>>
<<elseif $rng lte 100>><<He>> massages the length of your <<peniscomma>><<neutral 20>><<set $speechpenis to 1>>
<<if $arousal gte 8000>>
causing you involuntary shudders.
<<elseif $arousal gte 2000>>
coaxing out lewd fluid.
<<else>>
exploiting your body's natural reactions in a most sordid manner.
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand2 is "anusentrance">>
<<if $rng gte 101>><span class="blue"><<He>> moves <<his>> left hand away from your ass.</span><<set $lefthand2 to 0>><<set $vaginause to 0>>
<<elseif $rng gte 21>><<He>> <<strokes>> your anus.<<neutral 10>>
<<elseif $rng lte 20>><span class="pink"><<He>> plunges a finger into your ass.</span><<neutral 15>><<set $lefthand2 to "anus">><<set $speechanus to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand2 is "anusentrance">>
<<if $rng gte 101>><span class="blue"><<He>> moves <<his>> hand away from your ass.</span><<set $righthand2 to 0>><<set $vaginause to 0>>
<<elseif $rng gte 21>><<He>> <<strokes>> your anus.<<neutral 10>>
<<elseif $rng lte 20>><span class="pink"><<He>> plunges a finger into your ass.</span><<neutral 15>><<set $righthand2 to "anus">><<set $speechanus to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand2 is "anus">>
<<if $rng gte 101>><span class="purple"><<He>> slides <<his>> finger out of your ass.</span><<set $lefthand2 to "anusentrance">><<neutral 15>>
<<elseif $rng lte 100>><<He>> rhythmically slides <<his>> finger in and out of your ass,<<neutral 20>><<set $speechanus to 1>>
<<if $playergender is "m">>
teasing your prostate.
<<else>>
teasing your anus.
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand2 is "anus">>
<<if $rng gte 101>><span class="purple"><<He>> slides <<his>> finger out of your ass.</span><<set $righthand2 to "anusentrance">><<neutral 15>>
<<elseif $rng lte 100>><<He>> rhythmically slides <<his>> finger in and out of your ass,<<neutral 20>><<set $speechanus to 1>>
<<if $playergender is "m">>
teasing your prostate.
<<else>>
teasing your anus.
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand2 is "mouth">>
<<if $enemyanger lte 20 and $enemytrust gte 20>><span class="teal">Made confident by your accommodating behaviour, <<he>> releases <<his>> hand from your mouth.</span><<set $lefthand2 to 0>><<set $mouthuse to 0>>
<<else>><<He>> continues to clasp your mouth shut.<<violence 1>><<bruise face>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand2 is "mouth">>
<<if $enemyanger lte 20 and $enemytrust gte 20>><span class="teal">Made confident by your accommodating behaviour, <<he>> releases <<his>> hand from your mouth.</span><<set $righthand2 to 0>><<set $mouthuse to 0>>
<<else>><<He>> continues to clasp your mouth shut.<<violence 1>><<bruise face>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand2 is "throat">>
<<if $enemyanger gte 100>><<set $strangle += 1>>
<<if $strangle is 0>><<He>> strangles your throat.<<violence 5>><<bruise neck>><<bruise neck>><<set $speechthroat to 1>>
<<elseif $strangle lte 2>><span class="purple"><<He>> strangles your throat. You can't breathe!</span><<set $speechthroat to 1>>
<<violence 10>><<bruise neck>><<bruise neck>>
<<elseif $strangle lte 4>><span class="pink"><<He>> strangles your throat. You feel light-headed.</span><<set $speechthroat to 1>>
<<violence 20>><<bruise neck>><<bruise neck>>
<<elseif $strangle lte 6>><span class="pink"><<He>> strangles your throat. You see stars.</span><<set $speechthroat to 1>>
<<violence 40>><<bruise neck>><<bruise neck>>
<<elseif $strangle gte 8>><span class="red"><<He>> strangles your throat. You are suffocating.</span><<set $speechthroat to 1>>
<<violence 100>><<bruise neck>><<bruise neck>>
<</if>>
<<elseif $rng gte 81>><span class="teal"><<He>> releases <<his>> hand from your throat.</span> You gasp for air.
<<set $lefthand2 to 0>>
<<else>><<He>> holds you down by your throat.<<violence 1>>
<</if>><<bruise neck>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand2 is "throat">>
<<if $enemyanger gte 100>><<set $strangle += 1>>
<<if $strangle is 0>><<He>> strangles your throat.<<violence 5>><<bruise neck>><<bruise neck>><<set $speechthroat to 1>>
<<elseif $strangle lte 2>><<He>> strangles your throat. <span class="purple">You can't breathe!</span><<set $speechthroat to 1>>
<<violence 10>><<bruise neck>><<bruise neck>>
<<elseif $strangle lte 4>><<He>> strangles your throat. <span class="pink">You feel light-headed.</span><<set $speechthroat to 1>>
<<violence 20>><<bruise neck>><<bruise neck>>
<<elseif $strangle lte 6>><<He>> strangles your throat. <span class="pink">You see stars.</span> <<set $speechthroat to 1>>
<<violence 40>><<bruise neck>><<bruise neck>>
<<elseif $strangle gte 7>><<He>> strangles your throat. <span class="red">You are suffocating.</span><<set $speechthroat to 1>>
<<violence 100>><<bruise neck>><<bruise neck>>
<</if>>
<<elseif $rng gte 81>><span class="teal"><<He>> releases <<his>> hand from your throat.</span> You gasp for air.
<<set $righthand2 to 0>>
<<else>><<He>> holds you down by your throat.<<violence 1>>
<</if>><<bruise neck>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand2 is "underclothes" and $undertype is "chastity">>
<span class="blue"><<He>> tries to loosen your $underclothes.</span> <<His>> rough handling leaves you feeling more frustrated and aroused. <<He>> gives up after a few moments of impotent tugging, looking disappointed.<<neutral 1>><<set $enemyanger += 5>><<set $arousal += 5>><<set $lefthand2 to 0>><<set $speechchastity to 1>><<set $underintegrity -= 10>>
<</if>>
<<if $righthand2 is "underclothes" and $undertype is "chastity">>
<span class="blue"><<He>> tries to loosen your $underclothes.</span> <<His>> rough handling leaves you feeling more frustrated and aroused.<<He>> gives up after a few moments of impotent tugging, looking disappointed.<<neutral 1>><<set $enemyanger += 5>><<set $arousal += 5>><<set $righthand2 to 0>><<set $speechchastity to 1>><<set $underintegrity -= 10>>
<</if>>
<<if $lefthand2 is "underclothes">>
<<if $underclothes is "naked">><span class="purple"><<He>> casts aside the fabric.</span><<set $lefthand2 to 0>>
<<elseif $understruggle is 1>>You manage to keep <<him>> from pulling down your $underclothes.<<set $understruggle to 0>><<set $speechstripstruggle to 1>>
<<elseif $rng gte 101>><span class="blue"><<He>> releases <<his>> hand from your $underclothes.</span><<set $lefthand2 to 0>>
<<elseif $rng lte 100>>
<<if $skirt is 1>>
<<if $understate is "waist">><<He>> pulls your $underclothes down your thighs, <span class="lewd">revealing your <<genitalsstop>></span><<set $understate to "thighs">><<neutral 5>><<set $undervaginaexposed to 1>><<set $underanusexposed to 1>><<set $underexposed to 1>><<set $speechgenitals to 1>>
<<elseif $understate is "thighs">><<He>> pulls your $underclothes down to your knees.<<set $understate to "knees">><<neutral 1>>
<<elseif $understate is "knees">><<He>> pulls your $underclothes down to your ankles.<<set $understate to "ankles">><<neutral 1>>
<<elseif $understate is "ankles">><span class="purple"><<He> pulls your $underclothes off your legs.</span><<understrip>><<undernaked>><<neutral 3>><<set $lefthand2 to 0>><<clothesstripstat>>
<</if>>
<<elseif $lowerstate isnot "waist">>
<<if $understate is "waist">><<He>> pulls your $underclothes down your thighs, <span class="lewd">revealing your <<genitalsstop>></span><<set $understate to "thighs">><<neutral 5>><<set $undervaginaexposed to 1>><<set $underanusexposed to 1>><<set $underexposed to 1>><<set $speechgenitals to 1>>
<<elseif $understate is "thighs">><<He>> pulls your $underclothes down to your knees.<<set $understate to "knees">><<neutral 1>>
<<elseif $understate is "knees">><<He>> pulls your $underclothes down to your ankles.<<set $understate to "ankles">><<neutral 5>>
<<elseif $understate is "ankles">><span class="purple"><<He>> pulls your $underclothes off your legs.</span><<understrip>><<undernaked>><<neutral 3>><<set $lefthand2 to 0>><<clothesstripstat>>
<</if>>
<<else>><<He>> tugs on your $underclothes.<<neutral 1>><<set $underintegrity -= 10>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand2 is "underclothes">>
<<if $underclothes is "naked">><span class="purple"><<He>> casts aside the fabric.</span><<set $righthand2 to 0>>
<<elseif $understruggle is 1>>You manage to keep <<him>> from pulling down your $underclothes.<<set $understruggle to 0>><<set $speechstripstruggle to 1>>
<<elseif $rng gte 101>><span class="purple"><<He>> releases <<his>> hand from your $underclothes.</span><<set $righthand2 to 0>><<set $skirtuse to 0>>
<<elseif $rng lte 100>>
<<if $skirt is 1>>
<<if $understate is "waist">><<He>> pulls your $underclothes down your thighs, <span class="lewd">revealing your <<genitalsstop>></span><<set $understate to "thighs">><<neutral 5>><<set $undervaginaexposed to 1>><<set $underanusexposed to 1>><<set $underexposed to 1>><<set $speechgenitals to 1>>
<<elseif $understate is "thighs">><<He>> pulls your $underclothes down to your knees.<<set $understate to "knees">><<neutral 1>>
<<elseif $understate is "knees">><<He>> pulls your $underclothes down to your ankles.<<set $understate to "ankles">><<neutral 1>>
<<elseif $understate is "ankles">><span class="purple"><<He>> pulls your $underclothes off your legs.</span><<understrip>><<undernaked>><<neutral 3>><<set $righthand2 to 0>><<clothesstripstat>>
<</if>>
<<elseif $lowerstate isnot "waist">>
<<if $understate is "waist">><<He>> pulls your $underclothes down your thighs, <span class="lewd">revealing your <<genitalsstop>></span><<set $understate to "thighs">><<neutral 5>><<set $undervaginaexposed to 1>><<set $underanusexposed to 1>><<set $underexposed to 1>><<set $speechgenitals to 1>>
<<elseif $understate is "thighs">><<He>> pulls your $underclothes down to your knees.<<set $understate to "knees">><<neutral 1>>
<<elseif $understate is "knees">><<He>> pulls your $underclothes down to your ankles.<<set $understate to "ankles">><<neutral 5>>
<<elseif $understate is "ankles">><span class="purple"><<He>> pulls your $underclothes off your legs.</span><<understrip>><<undernaked>><<neutral 3>><<set $righthand2 to 0>><<clothesstripstat>>
<</if>>
<<else>><<He>> tugs on your $underclothes.<<neutral 1>><<set $underintegrity -= 10>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand2 is "hair">>
<<if $rng gte 101>><span class="lblue"><<He>> releases <<his>> hand from your hair.</span><<set $lefthand2 to 0>>
<<elseif $enemyanger gte 61>>With your hair in <<his>> grip, <<he>> yanks back your head.<<violence 4>><<set $speechhair to 1>>
<<elseif $enemyanger gte 21>>
<<He>> strokes your hair while holding it bunched in <<his>> grip.<<set $speechhair to 1>><<neutral 1>>
<<else>><span class="lblue"><<He>> releases <<his>> hand from your hair.</span><<set $lefthand2 to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand2 is "hair">>
<<if $rng gte 101>><span class="lblue"><<He>> releases <<his>> hand from your hair.</span><<set $righthand2 to 0>>
<<elseif $enemyanger gte 61>>With your hair in <<his>> grip, <<he>> yanks back your head.<<violence 4>><<set $speechhair to 1>>
<<elseif $enemyanger gte 21>>
<<He>> strokes your hair while holding it bunched in <<his>> grip.<<set $speechhair to 1>><<neutral 1>>
<<else>><span class="lblue"><<He>> releases <<his>> hand from your hair.</span><<set $righthand2 to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand2 is "lowerclothes">>
<<if $lowerclothes is "naked">><span class="purple"><<He>> casts aside the fabric.</span><<set $lefthand2 to 0>>
<<elseif $lowerstruggle is 1>><<set $lowerstruggle to 0>>You manage to keep <<him>> from stripping you of your $lowerclothes.<<set $speechstripstruggle to 1>>
<<elseif $rng gte 101>><<He>> releases <<his>> hand from your
$lowerclothes.<<set $lefthand2 to 0>>
<<elseif $rng lte 100>>
<<if $skirt is 1>>
<<if $skirtdown is 1>><<He>> lifts up your skirt,
exposing your
<<if $understate is "waist">>$underclothes.<<neutral 2>>
<<else>><span class="lewd"><<genitalsstop>></span><<neutral 5>><<set $speechgenitals to 1>>
<</if>><<set $skirtdown to 0>><<set $lowervaginaexposed to 1>><<set $loweranusexposed to 1>><<set $lowerexposed to 2>>
<<elseif $skirtdown is 0>>
<<if $lowerset is $upperset>>
<<if $upperstate is "waist">>
<<if $position is "wall">>
<<He>> tugs at your $upperclothes, tearing <<upperit>> before <span class="blue">letting go.</span><<set $lefthand2 to 0>><<neutral 1>><<set $lowerintegrity -= 10>>
<<else>>
<<He>> lifts your $upperclothes above your midriff.<<set $lowerstate to "midriff">><<set $upperstate to "midriff">><<neutral 1>>
<<if $upperstatetop is "waist">>
<<set $upperstatetop to "midriff">>
<</if>>
<</if>>
<<elseif $upperstate is "midriff">><<He>> lifts up your $upperclothes, <span class="lewd">exposing your <<breastsstop>></span><<set $lowerstate to "chest">><<set $upperstate to "chest">><<neutral 2>><<set $upperexposed to 2>><<set $speechbreasts to 1>>
<<if $upperstatetop is "midriff">>
<<set $upperstatetop to "chest">>
<</if>>
<<elseif $upperstate is "chest">><span class="purple"><<He>> pulls your $upperclothes off completely.</span><<lowerstrip>><<upperstrip>><<set $lowerstate to 0>><<set $upperstate to 0>><<uppernaked>><<lowernaked>><<set $lefthand2 to 0>><<neutral 3>><<clothesstripstat>>
<<if $upperstatetop is "chest">>
<<set $upperstatetop to 0>>
<</if>>
<</if>>
<<elseif $lowerset isnot $upperset>>
<<if $lowerstate is "waist">><<He>> pulls your $lowerclothes down to your thighs.
<<neutral 1>><<set $lowerstate to "thighs">>
<<elseif $lowerstate is "thighs">><<He>> pulls your $lowerclothes down to your knees.<<set $lowerstate to "knees">><<neutral 1>>
<<elseif $lowerstate is "knees">><<He>> pulls your $lowerclothes down to your ankles.<<set $lowerstate to "ankles">><<neutral 1>>
<<elseif $lowerstate is "ankles">><span class="purple"><<He>> completely pulls your $lowerclothes off your legs.</span><<lowerstrip>><<lowernaked>><<set $lefthand2 to 0>><<neutral 3>><<clothesstripstat>>
<</if>>
<</if>>
<</if>>
<<elseif $upperset is $lowerset>>
<<if $open is 1>>
<<if $upperstatetop is "chest">><<He>> tugs your $lowerclothes, pulling down your $upperclothes and <span class="lewd">revealing your <<breastsstop>></span><<set $upperstatetop to "midriff">><<neutral 3>><<set $upperexposed to 2>><<set $speechbreasts to 1>>
<<if $upperstate is "chest">>
<<set $upperstate to "midriff">>
<</if>>
<<if $lowerstate is "chest">>
<<set $lowerstate to "midriff">>
<</if>>
<<elseif $upperstatetop is "midriff">><<He>> tugs your $lowerclothes, pulling down your $upperclothes passed your midriff.<<set $upperstatetop to "waist">><<neutral 1>>
<<if $upperstate is "midriff">>
<<set $upperstate to "waist">>
<</if>>
<<if $lowerstate is "midriff">>
<<set $lowerstate to "waist">>
<</if>>
<<elseif $upperstatetop is "waist">><<He>> pulls your $upperclothes down to your thighs, revealing your
<<if $understate is "waist">>$underclothes<<neutral 2>>
<<else>><span class="lewd"><<genitalsstop>></span><<neutral 5>><<set $speechgenitals to 1>>
<</if>>
<<set $lowervaginaexposed to 1>><<set $loweranusexposed to 1>>
<<set $upperstatetop to "thighs">>
<<set $upperstate to "thighs">>
<<if $lowerstate is "waist">>
<<set $lowerstate to "thighs">>
<</if>>
<<elseif $upperstatetop is "thighs">><<He>> pulls your $upperclothes down to your knees.<<set $upperstatetop to "knees">><<set $upperstate to "knees">><<neutral 1>>
<<if $lowerstate is "thighs">>
<<set $lowerstate to "knees">>
<</if>>
<<elseif $upperstatetop is "knees">><<He>> pulls your $upperclothes down to your ankles.<<set $upperstatetop to "ankles">><<set $upperstate to "ankles">><<neutral 1>>
<<if $lowerstate is "knees">>
<<set $lowerstate to "ankles">>
<</if>>
<<elseif $upperstatetop is "ankles">><span class="purple"><<He>> pulls your $upperclothes off the bottom of your legs.</span><<upperstrip>><<neutral 5>><<set $upperstatetop to 0>><<set $upperstate to 0>><<uppernaked>>
<<if $lowerstate is "ankles">>
<<set $lowerstate to 0>><<lowerstrip>><<lowernaked>>
<</if>>
<</if>>
<<else>>
<<He>> tugs at your $lowerclothes, tearing <<lowerit>> before <span class="blue">letting go.</span><<set $lefthand2 to 0>><<set $lowerintegrity -= 10>><<neutral 1>>
<</if>>
<<elseif $upperset isnot $lowerset>>
<<if $lowerstate is "waist">><<He>> pulls down your $lowerclothes, exposing your
<<if $understate is "waist">>$underclothes.<<neutral 2>><<set $lowervaginaexposed to 1>><<set $loweranusexposed to 1>><<set $lowerexposed to 2>>
<<else>><span class="lewd"><<genitalsstop>></span><<neutral 5>><<set $speechgenitals to 1>>
<</if>>
<<set $lowervaginaexposed to 1>><<set $loweranusexposed to 1>><<set $lowerexposed to 2>>
<<set $lowerstate to "thighs">>
<<elseif $lowerstate is "thighs">><<He>> pulls your $lowerclothes down to your knees.<<set $lowerstate to "knees">><<neutral 1>>
<<elseif $lowerstate is "knees">><<He>> pulls your $lowerclothes down to your ankles.<<set $lowerstate to "ankles">><<neutral 1>>
<<elseif $lowerstate is "ankles">><span class="purple"><<He>> completely pulls your $lowerclothes off your legs.</span><<lowerstrip>><<lowernaked>><<set $lefthand2 to 0>><<neutral 3>><<clothesstripstat>>
<</if>>
<<else>><<He>> tugs at your $lowerclothes, tearing <<lowerit>> before <span class="blue">letting go.</span><<set $lefthand2 to 0>><<neutral 1>><<set $lowerintegrity -= 10>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand2 is "lowerclothes">>
<<if $lowerclothes is "naked">><span class="purple"><<He>> casts aside the fabric.</span><<set $righthand2 to 0>>
<<elseif $lowerstruggle is 1>><<set $lowerstruggle to 0>>You manage to keep <<him>> from stripping you of your $lowerclothes.<<set $speechstripstruggle to 1>>
<<elseif $rng gte 101>><span class="lblue"><<He>> releases <<his>> hand from your
$lowerclothes.</span><<set $righthand2 to 0>>
<<elseif $rng lte 100>>
<<if $skirt is 1>>
<<if $skirtdown is 1>><<He>> lifts up your skirt,
exposing your
<<if $understate is "waist">>$underclothes.<<neutral 2>>
<<else>><span class="lewd"><<genitalsstop>></span><<neutral 5>><<set $speechgenitals to 1>>
<</if>><<set $skirtdown to 0>><<set $lowervaginaexposed to 1>><<set $loweranusexposed to 1>><<set $lowerexposed to 2>>
<<elseif $skirtdown is 0>>
<<if $lowerset is $upperset>>
<<if $upperstate is "waist">>
<<if $position is "wall">>
<<He>> tugs at your $upperclothes, tearing <<upperit>> before <span class="blue">letting go.</span><<set $righthand2 to 0>><<neutral 1>><<set $lowerintegrity -= 10>>
<<else>>
<<He>> lifts your $upperclothes above your midriff.<<set $lowerstate to "midriff">><<set $upperstate to "midriff">><<neutral 1>>
<<if $upperstatetop is "waist">>
<<set $upperstatetop to "midriff">>
<</if>>
<</if>>
<<elseif $upperstate is "midriff">><<He>> lifts up your $upperclothes, <span class="lewd">exposing your <<breastsstop>></span><<set $lowerstate to "chest">><<set $upperstate to "chest">><<neutral 2>><<set $upperexposed to 2>><<set $speechbreasts to 1>>
<<if $upperstatetop is "midriff">>
<<set $upperstatetop to "chest">>
<</if>>
<<elseif $upperstate is "chest">><span class="purple"><<He>> pulls your $upperclothes off completely.</span><<set $lowerstate to 0>><<set $upperstate to 0>><<lowerstrip>><<upperstrip>><<uppernaked>><<lowernaked>><<set $righthand2 to 0>><<neutral 3>><<clothesstripstat>>
<<if $upperstatetop is "chest">>
<<set $upperstatetop to 0>>
<</if>>
<</if>>
<<elseif $lowerset isnot $upperset>>
<<if $lowerstate is "waist">><<He>> pulls your $lowerclothes down to your thighs.
<<neutral 1>><<set $lowerstate to "thighs">>
<<elseif $lowerstate is "thighs">><<He>> pulls your $lowerclothes down to your knees.<<set $lowerstate to "knees">><<neutral 1>>
<<elseif $lowerstate is "knees">><<He>> pulls your $lowerclothes down to your ankles.<<set $lowerstate to "ankles">><<neutral 1>>
<<elseif $lowerstate is "ankles">><span class="purple"><<He>> pulls your $lowerclothes off your legs.</span><<lowerstrip>><<lowernaked>><<set $righthand2 to 0>><<neutral 3>><<clothesstripstat>>
<</if>>
<</if>>
<</if>>
<<elseif $upperset is $lowerset>>
<<if $open is 1>>
<<if $upperstatetop is "chest">><<He>> tugs your $lowerclothes, pulling down your $upperclothes and <span class="lewd">revealing your <<breastsstop>></span><<set $upperstatetop to "midriff">><<neutral 3>><<set $upperexposed to 2>><<set $speechbreasts to 1>>
<<if $upperstate is "chest">>
<<set $upperstate to "midriff">>
<</if>>
<<if $lowerstate is "chest">>
<<set $lowerstate to "midriff">>
<</if>>
<<elseif $upperstatetop is "midriff">><<He>> tugs your $lowerclothes, pulling down your $upperclothes pass your midriff.<<set $upperstatetop to "waist">><<neutral 1>>
<<if $upperstate is "midriff">>
<<set $upperstate to "waist">>
<</if>>
<<if $lowerstate is "midriff">>
<<set $lowerstate to "waist">>
<</if>>
<<elseif $upperstatetop is "waist">><<He>> pulls your $upperclothes down to your thighs, revealing your
<<if $understate is "waist">>$underclothes<<neutral 2>>
<<else>><span class="lewd"><<genitalsstop>></span><<neutral 5>><<set $speechgenitals to 1>>
<</if>>
<<set $lowervaginaexposed to 1>><<set $loweranusexposed to 1>><<set $lowerexposed to 2>>
<<set $upperstatetop to "thighs">><<set $upperstate to "thighs">>
<<if $lowerstate is "waist">>
<<set $lowerstate to "thighs">>
<</if>>
<<elseif $upperstatetop is "thighs">><<He>> pulls your $upperclothes down to your knees.<<set $upperstatetop to "knees">><<set $upperstate to "knees">><<neutral 1>>
<<if $lowerstate is "thighs">>
<<set $lowerstate to "knees">>
<</if>>
<<elseif $upperstatetop is "knees">><<He>> pulls your $upperclothes down to your ankles.<<set $upperstatetop to "ankles">><<set $upperstate to "ankles">><<neutral 1>>
<<if $lowerstate is "knees">>
<<set $lowerstate to "ankles">>
<</if>>
<<elseif $upperstatetop is "ankles">><span class="purple"><<He>> pulls your $upperclothes off the bottom of your legs.</span><<upperstrip>><<neutral 5>><<set $upperstatetop to 0>><<set $upperstate to 0>><<uppernaked>>
<<if $lowerstate is "ankles">>
<<set $lowerstate to 0>><<lowerstrip>><<lowernaked>>
<</if>>
<</if>>
<<else>>
<<He>> tugs at your $lowerclothes, tearing <<lowerit>> before <span class="blue">letting go.</span><<set $righthand2 to 0>><<set $lowerintegrity -= 10>><<neutral 1>>
<</if>>
<<elseif $upperset isnot $lowerset>>
<<if $lowerstate is "waist">><<He>> pulls down your $lowerclothes, exposing your
<<if $understate is "waist">>$underclothes.<<neutral 2>><<set $lowervaginaexposed to 1>><<set $loweranusexposed to 1>>
<<else>><span class="lewd"><<genitalsstop>></span><<neutral 5>><<set $speechgenitals to 1>>
<</if>>
<<set $lowervaginaexposed to 1>><<set $loweranusexposed to 1>><<set $lowerexposed to 2>>
<<set $lowerstate to "thighs">>
<<elseif $lowerstate is "thighs">><<He>> pulls your $lowerclothes down to your knees.<<set $lowerstate to "knees">><<neutral 1>>
<<elseif $lowerstate is "knees">><<He>> pulls your $lowerclothes down to your ankles.<<set $lowerstate to "ankles">><<neutral 1>>
<<elseif $lowerstate is "ankles">><span class="purple"><<He>> pulls your $lowerclothes off your legs.</span><<lowerstrip>><<lowernaked>><<set $righthand2 to 0>><<neutral 3>><<clothesstripstat>>
<</if>>
<<else>><<He>> tugs at your $lowerclothes, tearing <<lowerit>> before <span class="blue">letting go.</span><<set $righthand2 to 0>><<neutral 1>><<set $lowerintegrity -= 10>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand2 is "upperclothes">>
<<if $upperclothes is "naked">><span class="purple"><<He>> casts aside the fabric.</span><<set $lefthand2 to 0>>
<<elseif $upperstruggle is 1>><<set $upperstruggle to 0>>You manage to keep <<him>> from stripping you of your $upperclothes.<<set $speechstripstruggle to 1>>
<<elseif $rng gte 101>><span class="lblue"><<He>> releases <<his>> hand from your $upperclothes.</span><<set $lefthand2 to 0>>
<<elseif $rng lte 100>>
<<if $upperset isnot $lowerset>>
<<if $open is 1>>
<<if $upperstatetop is "chest">><<He>> pulls down your $upperclothes, <span class="lewd">revealing your <<breastsstop>></span><<set $upperstatetop to "midriff">><<neutral 3>><<set $upperexposed to 2>><<set $speechbreasts to 1>>
<<if $upperstate is "chest">>
<<set $upperstate to "midriff">>
<</if>>
<<elseif $upperstatetop is "midriff">><<He>> pulls your $upperclothes down past your midriff.<<set $upperstatetop to "waist">><<neutral 1>>
<<if $upperstate is "midriff">>
<<set $upperstate to "waist">>
<</if>>
<<elseif $upperstatetop is "waist">><<He>> pulls your $upperclothes down to your thighs.
<<set $upperstatetop to "thighs">>
<<set $upperstate to "thighs">>
<<elseif $upperstatetop is "thighs">><<He>> pulls your $upperclothes down to your knees.<<set $upperstatetop to "knees">><<set $upperstate to "knees">><<neutral 1>>
<<elseif $upperstatetop is "knees">><<He>> pulls your $upperclothes down to your ankles.<<set $upperstatetop to "ankles">><<set $upperstate to "ankles">><<neutral 1>>
<<elseif $upperstatetop is "ankles">><span class="purple"><<He>> pulls your $upperclothes off the bottom of your legs.</span><<upperstrip>><<neutral 5>><<set $upperstatetop to 0>><<set $upperstate to 0>><<uppernaked>><<set $lefthand2 to 0>>
<</if>>
<<elseif $open is 0>>
<<if $position is "wall">>
<<He>> tugs at your $upperclothes, tearing <<upperit>> before <span class="blue">letting go.</span><<set $lefthand2 to 0>><<set $upperintegrity -= 10>><<neutral 1>>
<<elseif $position isnot "wall">>
<<if $upperstate is "waist">><<He>> lifts up your $upperclothes, exposing your midriff.<<set $upperstate to "midriff">><<neutral 1>>
<<elseif $upperstate is "midriff">><<He>> lifts up your $upperclothes, <span class="lewd">exposing your <<breastsstop>></span><<set $upperstate to "chest">><<neutral 2>><<set $upperexposed to 2>><<set $speechbreasts to 1>>
<<elseif $upperstate is "chest">><span class="purple"><<He>> removes your $upperclothes completely.</span><<upperstrip>><<uppernaked>><<set $lefthand2 to 0>><<neutral 3>><<clothesstripstat>>
<</if>>
<</if>>
<</if>>
<<elseif $upperset is $lowerset>>
<<if $open is 1>>
<<if $lowerstate is $upperstatetop and $lowerstate is $upperstate and $skirt is 1>>
<<if $position is "wall">>
<<He>> tugs at your $upperclothes, tearing <<upperit>> before <span class="blue">letting go.</span><<set $lefthand2 to 0>><<set $upperintegrity -= 10>><<neutral 1>>
<<elseif $position isnot "wall">>
<<if $upperstate is "waist">><<He>> pulls your bundled $upperclothes up past your midriff.<<set $upperstate to "midriff">><<neutral 1>>
<<set $lowerstate to "midriff">>
<<set $upperstatetop to "midriff">>
<<elseif $upperstate is "midriff">><<He>> pulls your bundled $upperclothes up past your <<breastsstop>><<set $upperstate to "chest">><<neutral 2>><<set $upperexposed to 2>><<set $speechbreasts to 1>>
<<set $lowerstate to "chest">>
<<set $upperstatetop to "chest">>
<<elseif $upperstate is "chest">><span class="purple"><<He>> pulls your $upperclothes off your body.</span><<upperstrip>><<uppernaked>><<set $lefthand2 to 0>><<neutral 3>><<clothesstripstat>>
<</if>>
<</if>>
<<else>>
<<if $upperstatetop is "chest">><<He>> pulls down the top of your $upperclothes, <span class="lewd">revealing your <<breastsstop>></span><<set $upperstatetop to "midriff">><<neutral 2>><<set $upperexposed to 2>><<set $speechbreasts to 1>>
<<if $upperstate is "chest">>
<<set $upperstate to "midriff">>
<</if>>
<<if $lowerstate is "chest">>
<<set $lowerstate to "midriff">>
<</if>>
<<elseif $upperstatetop is "midriff">><<He>> pulls your $upperclothes down past your midriff.<<set $upperstatetop to "waist">><<neutral 1>>
<<if $upperstate is "midriff">>
<<set $upperstate to "waist">>
<</if>>
<<if $lowerstate is "midriff">>
<<set $lowerstate to "waist">>
<</if>>
<<elseif $upperstatetop is "waist">><<He>> pulls your $upperclothes down to your thighs, revealing your
<<if $understate is "waist">>$underclothes<<neutral 2>>
<<else>><span class="lewd"><<genitalsstop>></span><<neutral 5>><<set $speechgenitals to 1>>
<</if>>
<<set $lowervaginaexposed to 1>><<set $loweranusexposed to 1>><<set $lowerexposed to 2>>
<<set $upperstatetop to "thighs">>
<<set $upperstate to "thighs">>
<<if $lowerstate is "waist">>
<<set $lowerstate to "thighs">>
<</if>>
<<elseif $upperstatetop is "thighs">><<He>> pulls your $upperclothes down to your knees.<<set $upperstatetop to "knees">><<set $upperstate to "knees">><<neutral 1>>
<<if $lowerstate is "thighs">>
<<set $lowerstate to "knees">>
<</if>>
<<elseif $upperstatetop is "knees">><<He>> pulls your $upperclothes down to your ankles.<<set $upperstatetop to "ankles">><<set $upperstate to "ankles">><<neutral 1>>
<<if $lowerstate is "knees">>
<<set $lowerstate to "ankles">>
<</if>>
<<elseif $upperstatetop is "ankles">><span class="purple"><<He>> pulls your $upperclothes off the bottom of your legs.</span><<upperstrip>><<neutral 5>><<set $upperstatetop to 0>><<set $upperstate to 0>><<uppernaked>><<set $lefthand2 to 0>>
<<if $lowerstate is "ankles">>
<<set $lowerstate to 0>><<lowerstrip>><<lowernaked>>
<</if>>
<</if>>
<</if>>
<<else>><<He>> tugs at your $upperclothes, tearing <<upperit>> before <span class="blue">letting go.</span><<set $lefthand2 to 0>><<set $upperintegrity -= 10>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random (1, 100)>>
<<if $righthand2 is "upperclothes">>
<<if $upperclothes is "naked">><span class="purple"><<He>> casts aside the fabric.</span><<set $righthand2 to 0>>
<<elseif $upperstruggle is 1>><<set $upperstruggle to 0>>You manage to keep <<him>> from stripping you of your $upperclothes.<<set $speechstripstruggle to 1>>
<<elseif $rng gte 101>><span class="lblue"><<He>> releases <<his>> hand from your $upperclothes.</span><<set $righthand2 to 0>>
<<elseif $rng lte 100>>
<<if $upperset isnot $lowerset>>
<<if $open is 1>>
<<if $upperstatetop is "chest">><<He>> pulls down your $upperclothes, <span class="lewd">revealing your <<breastsstop>></span><<set $upperstatetop to "midriff">><<neutral 3>><<set $upperexposed to 2>><<set $speechbreasts to 1>>
<<if $upperstate is "chest">>
<<set $upperstate to "midriff">>
<</if>>
<<elseif $upperstatetop is "midriff">><<He>> pulls your $upperclothes down past your midriff.<<set $upperstatetop to "waist">><<neutral 1>>
<<if $upperstate is "midriff">>
<<set $upperstate to "waist">>
<</if>>
<<elseif $upperstatetop is "waist">><<He>> pulls your $upperclothes down to your thighs.
<<set $upperstatetop to "thighs">>
<<set $upperstate to "thighs">>
<<elseif $upperstatetop is "thighs">><<He>> pulls your $upperclothes down to your knees.<<set $upperstatetop to "knees">><<set $upperstate to "knees">><<neutral 1>>
<<elseif $upperstatetop is "knees">><<He>> pulls your $upperclothes down to your ankles.<<set $upperstatetop to "ankles">><<set $upperstate to "ankles">><<neutral 1>>
<<elseif $upperstatetop is "ankles">><span class="purple"><<He>> pulls your $upperclothes off the bottom of your legs.</span><<upperstrip>><<neutral 5>><<set $upperstatetop to 0>><<set $upperstate to 0>><<uppernaked>><<set $righthand2 to 0>>
<</if>>
<<elseif $open is 0>>
<<if $position is "wall">>
<<He>> tugs at your $upperclothes, tearing <<upperit>> before <span class="blue">letting go.</span><<set $righthand2 to 0>><<set $upperintegrity -= 10>><<neutral 1>>
<<elseif $position isnot "wall">>
<<if $upperstate is "waist">><<He>> lifts up your $upperclothes, exposing your midriff.<<set $upperstate to "midriff">><<neutral 1>>
<<elseif $upperstate is "midriff">><<He>> lifts up your $upperclothes, <span class="lewd">exposing your <<breastsstop>></span><<set $upperstate to "chest">><<neutral 2>><<set $upperexposed to 2>><<set $speechbreasts to 1>>
<<elseif $upperstate is "chest">><span class="purple"><<He>> removes your $upperclothes completely.</span><<upperstrip>><<uppernaked>><<set $righthand2 to 0>><<neutral 3>><<clothesstripstat>>
<</if>>
<</if>>
<</if>>
<<elseif $upperset is $lowerset>>
<<if $open is 1>>
<<if $lowerstate is $upperstatetop and $lowerstate is $upperstate and $skirt is 1>>
<<if $position is "wall">>
<<He>> tugs at your $upperclothes, tearing <<upperit>> before <span class="blue">letting go.</span><<set $righthand2 to 0>><<set $upperintegrity -= 10>><<neutral 1>>
<<elseif $position isnot "wall">>
<<if $upperstate is "waist">><<He>> pulls your bundled $upperclothes up past your midriff.<<set $upperstate to "midriff">><<neutral 1>>
<<set $lowerstate to "midriff">>
<<set $upperstatetop to "midriff">>
<<elseif $upperstate is "midriff">><<He>> pulls your bundled $upperclothes up past your <<breastsstop>><<set $upperstate to "chest">><<neutral 2>><<set $upperexposed to 2>><<set $speechbreasts to 1>>
<<set $lowerstate to "chest">>
<<set $upperstatetop to "chest">>
<<elseif $upperstate is "chest">><span class="purple"><<He>> pulls your $upperclothes off your body.</span><<upperstrip>><<uppernaked>><<set $righthand2 to 0>><<neutral 3>><<clothesstripstat>>
<</if>>
<</if>>
<<else>>
<<if $upperstatetop is "chest">><<He>> pulls down the top of your $upperclothes, <span class="lewd">revealing your <<breastsstop>></span><<set $upperstatetop to "midriff">><<set $upperexposed to 2>><<neutral 2>><<set $speechbreasts to 1>>
<<if $upperstate is "chest">>
<<set $upperstate to "midriff">>
<</if>>
<<if $lowerstate is "chest">>
<<set $lowerstate to "midriff">>
<</if>>
<<elseif $upperstatetop is "midriff">><<He>> pulls your $upperclothes down past your midriff.<<set $upperstatetop to "waist">><<neutral 1>>
<<if $upperstate is "midriff">>
<<set $upperstate to "waist">>
<</if>>
<<if $lowerstate is "midriff">>
<<set $lowerstate to "waist">>
<</if>>
<<elseif $upperstatetop is "waist">><<He>> pulls your $upperclothes down to your thighs, revealing your
<<if $understate is "waist">>$underclothes<<neutral 2>>
<<else>><span class="lewd"><<genitalsstop>></span><<neutral 5>><<set $speechgenitals to 1>>
<</if>>
<<set $lowervaginaexposed to 1>><<set $loweranusexposed to 1>><<set $lowerexposed to 2>>
<<set $upperstatetop to "thighs">>
<<set $upperstate to "thighs">>
<<if $lowerstate is "waist">>
<<set $lowerstate to "thighs">>
<</if>>
<<elseif $upperstatetop is "thighs">><<He>> pulls your $upperclothes down to your knees.<<set $upperstatetop to "knees">><<set $upperstate to "knees">><<neutral 1>>
<<if $lowerstate is "thighs">>
<<set $lowerstate to "knees">>
<</if>>
<<elseif $upperstatetop is "knees">><<He>> pulls your $upperclothes down to your ankles.<<set $upperstatetop to "ankles">><<set $upperstate to "ankles">><<neutral 1>>
<<if $lowerstate is "knees">>
<<set $lowerstate to "ankles">>
<</if>>
<<elseif $upperstatetop is "ankles">><span class="purple"><<He>> pulls your $upperclothes off the bottom of your legs.</span><<upperstrip>><<neutral 5>><<set $upperstatetop to 0>><<set $upperstate to 0>><<uppernaked>><<set $righthand2 to 0>>
<<if $lowerstate is "ankles">>
<<set $lowerstate to 0>><<lowerstrip>><<lowernaked>>
<</if>>
<</if>>
<</if>>
<<else>><<He>> tugs at your $upperclothes, tearing <<upperit>> before <span class="blue">letting go.</span><<set $righthand2 to 0>><<set $upperintegrity -= 10>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand2 is 0>>
<<if $enemyanger + $rng lte 20>>
<<if $lowerclothes isnot "naked">><span class="purple"><<He>> grasps your $lowerclothes.</span><<set $lefthand2 to "lowerclothes">><<neutral 1>>
<<elseif $vaginaexist is 1>>
<<He>> <<strokes>> your inner thigh and brushes <<his>> fingers against your clit.<<neutral 10>><<set $speechclit to 1>>
<<elseif $penisexist is 1>>
<<He>> <<strokes>> your inner thigh and brushes <<his>> fingers against your <<glansstop>><<neutral 10>><<set $speechglans to 1>>
<</if>>
<<elseif $enemyanger + $rng lte 30>>
<<if $position is "wall">>
<<if $lowerclothes isnot "naked">><span class="purple"><<He>> grasps your $lowerclothes.</span><<set $lefthand2 to "lowerclothes">><<neutral 1>>
<<elseif $vaginaexist is 1>>
<<He>> <<strokes>> your inner thigh and brushes <<his>> fingers against your clit.<<neutral 10>><<set $speechclit to 1>>
<<elseif $penisexist is 1>>
<<He>> <<strokes>> your inner thigh and brushes <<his>> fingers against your <<glansstop>><<neutral 10>><<set $speechglans to 1>>
<</if>>
<<else>>
<<if $upperclothes isnot "naked">><span class="purple"><<He>> grasps your $upperclothes.</span><<set $lefthand2 to "upperclothes">><<neutral 1>>
<<else>><<He>> <<strokes>> your chest, <<his>> fingers lingering around your nipple.<<neutral 4>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 35>>
<<if $skirt is 1>>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $lefthand2 to "underclothes">><<neutral 1>>
<<elseif $underanusexposed is 1>>
<<if $loweranusexposed is 1>>
<<if $anususe is 0 and $analdisable is "f">><span class="purple"><<He>> presses <<his>> left hand against your <<bottomstop>></span><<set $lefthand2 to "anusentrance">><<set $anususe to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<<elseif $lowerclothes isnot "waist">>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $lefthand2 to "underclothes">><<neutral 1>>
<<elseif $underanusexposed is 1>>
<<if $loweranusexposed is 1>>
<<if $anususe is 0 and $analdisable is "f">><span class="purple"><<He>> presses <<his>> left hand against your <<bottomstop>></span><<set $lefthand2 to "anusentrance">><<set $anususe to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 40>>
<<if $skirt is 1>>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $lefthand2 to "underclothes">><<neutral 1>>
<<elseif $undervaginaexposed is 1>>
<<if $lowervaginaexposed is 1>>
<<if $vaginaexist is 1>>
<<if $vaginause is 0>><span class="purple"><<He>> presses <<his>> left hand against your <<pussycomma>> resting a finger on your entrance.</span><<set $lefthand2 to "vaginaentrance">><<set $vaginause to 1>><<neutral 1>>
<</if>>
<<elseif $penisexist is 1>>
<<if $penisuse is 0>><span class="purple"><<He>> presses <<his>> left hand against your <<penisstop>></span><<set $lefthand2 to "penisentrance">><<set $penisuse to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $lowerclothes isnot "waist">>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $lefthand2 to "underclothes">><<neutral 1>>
<<elseif $undervaginaexposed is 1>>
<<if $lowervaginaexposed is 1>>
<<if $vaginaexist is 1>>
<<if $vaginause is 0>>
<span class="purple"><<He>> presses <<his>> left hand against your <<pussycomma>> resting a finger on your entrance.</span><<set $lefthand2 to "vaginaentrance">><<set $vaginause to 1>><<neutral 1>>
<</if>>
<<elseif $penisexist is 1>>
<<if $penisuse is 0>><span class="purple"><<He>> presses <<his>> left hand against your <<penisstop>></span><<set $lefthand2 to "penisentrance">><<set $penisuse to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 45>>
<<if $position is "wall">>
<<He>> leans against the wall.
<<else>>
<<He>> caresses your tummy.<<neutral 1>>
<</if>>
<<elseif $enemyanger + $rng lte 50>>
<<if $position is "wall">>
<<He>> grips your thigh and pulls, but you're stuck firm.<<neutral 1>>
<<else>>
<<He>> <<strokes>> your hair.<<neutral 1>>
<</if>>
<<elseif $enemyanger + $rng lte 60>>
<<if $position is "wall">>
<<He>> pulls your leg, but you're stuck firm.<<neutral 1>>
<<elseif $uppertype isnot "naked" and $upperstate isnot "chest" and $upperstatetop is "chest">>
<<He>> <<strokes>> your <<breasts>> through your $upperclothes.<<neutral 2>>
<<else>>
<<He>> <<strokes>> your exposed <<breastsstop>><<neutral 4>>
<</if>>
<<elseif $enemyanger + $rng lte 80>><<set $speechbottom to 1>>
<<if $lowerstate is "waist" and $skirt is 0>>
<<He>> fondles your <<bottom>> through your $lowerclothes.<<neutral 2>>
<<elseif $understate is "waist">>
<<He>> fondles your <<bottom>> through your $underclothes.<<neutral 2>>
<<else>>
<<He>> gropes and squeezes your exposed <<bottomstop>><<neutral 4>>
<</if>>
<<elseif $enemyanger + $rng lte 100>>
<<if $penisexist is 1>>
<<if $lowerstate is "waist" and $skirt is 0>>
<<He>> fondles and <<strokes>> your <<penis>> through your $lowerclothes.<<neutral 5>>
<<elseif $understate is "waist">>
<<He>> fondles and <<strokes>> your <<penis>> through your $underclothes.<<neutral 5>>
<<elseif $penisuse is 0>>
<<He>> fondles and <<strokes>> your exposed <<penisstop>><<neutral 10>>
<<else>>
<<He>> fondles and <<strokes>> your <<testiclesstop>><<neutral 10>>
<</if>>
<<elseif $vaginaexist is 1>>
<<if $lowerstate is "waist" and $skirt is 0>>
<<He>> fondles and <<strokes>> your labia through your $lowerclothes.<<neutral 5>>
<<elseif $understate is "waist">>
<<He>> fondles and <<strokes>> your labia through your $underclothes.<<neutral 5>>
<<else>>
<<He>> fondles and <<strokes>> your exposed <<pussystop>><<neutral 10>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 110>>
<<if $lowerclothes isnot "naked">><span class="purple"><<He>> grasps your $lowerclothes.</span><<set $lefthand2 to "lowerclothes">><<neutral 1>>
<<elseif $vaginaexist is 1>><<He>> pinches your clitoris.<<neutral 15>><<bruise vagina>><<set $speechclit to 1>>
<<elseif $penisexist is 1>>
<<if $penisuse is 0>>
<<He>> pinches your glans.<<neutral 15>><<bruise penis>><<set $speechglans to 1>>
<<else>>
<<He>> pinches your shaft.<<neutral 10>><<bruise penis>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 120>>
<<if $position is "wall">>
<<He>> smacks your thigh.<<violence 1>><<bruise thigh>><<hitstat>>
<<else>>
<<if $upperclothes isnot "naked">><span class="purple"><<He>> grasps your $upperclothes.</span><<set $lefthand2 to "upperclothes">><<neutral 1>>
<<else>><span class="purple"><<He>> grabs your throat.</span><<violence 2>><<set $lefthand2 to "throat">>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 125>>
<<if $skirt is 1>>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $lefthand2 to "underclothes">><<neutral 1>>
<<elseif $underanusexposed is 1>>
<<if $loweranusexposed is 1>>
<<if $anususe is 0 and $analdisable is "f">><span class="purple"><<He>> presses <<his>> left hand against your <<bottomstop>></span><<set $lefthand2 to "anusentrance">><<set $anususe to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<<elseif $lowerclothes isnot "waist">>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $lefthand2 to "underclothes">><<neutral 1>>
<<elseif $underanusexposed is 1>>
<<if $loweranusexposed is 1>>
<<if $anususe is 0 and $analdisable is "f">><span class="purple"><<He>> presses <<his>> left hand against your <<bottomstop>></span><<set $lefthand2 to "anusentrance">><<set $anususe to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 130>>
<<if $skirt is 1>>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $lefthand2 to "underclothes">><<neutral 1>>
<<elseif $undervaginaexposed is 1>>
<<if $lowervaginaexposed is 1>>
<<if $vaginaexist is 1>>
<<if $vaginause is 0>><span class="purple"><<He>> presses <<his>> left hand against your <<pussycomma>> <<his>> finger resting on your entrance.</span><<set $lefthand2 to "vaginaentrance">><<set $vaginause to 1>><<neutral 1>>
<</if>>
<<elseif $penisexist is 1>>
<<if $penisuse is 0>><span class="purple"><<He>> presses <<his>> left hand against your <<penisstop>></span><<set $lefthand2 to "penisentrance">><<set $penisuse to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $lowerclothes isnot "waist">>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $lefthand2 to "underclothes">><<neutral 1>>
<<elseif $undervaginaexposed is 1>>
<<if $lowervaginaexposed is 1>>
<<if $vaginaexist is 1>>
<<if $vaginause is 0>>
<span class="purple"><<He>> presses <<his>> left hand against your <<pussycomma>> <<his>> finger resting on your entrance.</span><<set $lefthand2 to "vaginaentrance">><<set $vaginause to 1>><<neutral 1>>
<</if>>
<<elseif $penisexist is 1>>
<<if $penisuse is 0>><span class="purple"><<He>> presses <<his>> left hand against your <<penisstop>></span><<set $lefthand2 to "penisentrance">><<set $penisuse to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 140>>
<<if $position is "wall">>
<<He>> smacks your <<bottomstop>><<violence 1>><<bruise bottom>><<hitstat>>
<<else>>
<<He>> seizes your hair with <<his>> left hand.<<set $lefthand2 to "hair">><<violence 2>><<set $speechhair to 1>>
<</if>>
<<elseif $enemyanger + $rng lte 160 and $lefthand2 isnot "arms" and $righthand2 isnot "arms" and $leftarm isnot "bound" and $rightarm isnot "bound">>
<span class="purple"><<He>> pins down your arms.</span><<set $lefthand2 to "arms">><<set $leftarm to "grappled">><<set $rightarm to "grappled">><<disablearms>><<violence 2>><<bruise leftarm>><<bruise rightarm>><<set $speecharms to 1>>
<<if $vaginause is "cover">><<set $vaginause to 0>>
<</if>>
<<if $vaginause is "cover">><<set $vaginause to 0>>
<</if>>
<<if $anususe is "cover">><<set $anususe to 0>>
<</if>>
<<if $anususe is "cover">><<set $anususe to 0>>
<</if>>
<<if $penisuse is "cover">><<set $penisuse to 0>>
<</if>>
<<if $penisuse is "cover">><<set $penisuse to 0>>
<</if>>
<<elseif $enemyanger + $rng lte 160>><<He>> digs <<his>> nails into your <<bottom>> while groping, giving no heed to you comfort.<<violence 10>><<bruise bottom>><<hitstat>><<set $speechspank to 1>>
<<elseif $enemyanger + $rng lte 175>><<He>> slaps your <<bottomstop>><<violence 10>><<bruise bottom>><<hitstat>><<set $speechspank to 1>>
<<elseif $enemyanger + $rng lte 180>><<He>> smacks your thighs.<<violence 10>><<bruise thigh>><<hitstat>><<set $speechbeat to 1>>
<<elseif $enemyanger + $rng lte 185>>
<<if $position is "wall">>
<<He>> punches your thigh.<<bruise thigh>><<hitstat>><<violence 10>><<set $speechbeat to 1>>
<<else>>
<<He>> punches your tummy.<<violence 20>><<bruise tummy>><<hitstat>><<set $speechbeat to 1>>
<</if>>
<<elseif $enemyanger + $rng lte 190>>
<<if $position is "wall">>
<<He>> slaps your <<bottomstop>><<violence 20>><<bruise bottom>><<hitstat>><<set $speechbeat to 1>>
<<else>>
<<He>> slaps your <<breastsstop>><<violence 20>><<bruise chest>><<hitstat>><<set $speechbeat to 1>>
<</if>>
<<elseif $enemyanger + $rng gte 191>>
<<if $position is "wall">>
<<if $penisexist is 1>>
<<He>> scratches your helpless <<bottomstop>><<violence 20>><<bruise bottom>><<hitstat>><<set $speechbeat to 1>>
<<elseif $vaginaexist is 1>>
<<He>> scratches your helpless <<bottomstop>><<violence 20>><<bruise bottom>><<hitstat>><<set $speechbeat to 1>>
<</if>>
<<else>>
<<set $rng to random(1, 100)>>
<<if $rng gte 81>>
<<He>> punches your nose.<<violence 20>><<bruise face>><<hitstat>><<set $speechbeat to 1>>
<<elseif $rng gte 61>>
<<He>> punches the back of your neck.<<violence 20>><<bruise neck>><<hitstat>><<set $speechbeat to 1>>
<<elseif $rng gte 41>>
<<He>> punches your cheek.<<violence 20>><<bruise face>><<hitstat>><<set $speechbeat to 1>>
<<elseif $rng gte 21>>
<<He>> punches your jaw.<<violence 20>><<bruise face>><<hitstat>><<set $speechbeat to 1>>
<<else>>
<<He>> jabs the front of your neck.<<violence 20>><<bruise neck>><<hitstat>><<set $speechbeat to 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand2 is 0>>
<<if $enemyanger + $rng lte 20>>
<<if $lowerclothes isnot "naked">><span class="purple"><<He>> grasps your $lowerclothes.</span><<set $righthand2 to "lowerclothes">><<neutral 1>>
<<elseif $vaginaexist is 1>><<He>> <<strokes>> your pubic mound and teases your clit.<<neutral 10>><<set $speechclit to 1>>
<<elseif $penisexist is 1>>
<<He>> <<strokes>> your <<testicles>> and teases your glans.<<neutral 10>><<set $speechglans to 1>>
<</if>>
<<elseif $enemyanger + $rng lte 30>>
<<if $position is "wall">>
<<if $lowerclothes isnot "naked">><span class="purple"><<He>> grasps your $lowerclothes.</span><<set $righthand2 to "lowerclothes">><<neutral 1>>
<<elseif $vaginaexist is 1>><<He>> runs <<his>> hand up your thigh and <<strokes>> your clit.<<neutral 10>><<set $speechclit to 1>>
<<elseif $penisexist is 1>><<He>> runs <<his>> hand up your thigh and <<strokes>> your <<glansstop>><<neutral 10>><<set $speechglans to 1>>
<</if>>
<<else>>
<<if $upperclothes isnot "naked">><span class="purple"><<He>> grasps your $upperclothes.</span><<set $righthand2 to "upperclothes">><<neutral 1>>
<<else>><<He>> <<strokes>> your chest and teases your nipple.<<neutral 4>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 35>>
<<if $skirt is 1>>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $righthand2 to "underclothes">><<neutral 1>>
<<elseif $underanusexposed is 1>>
<<if $loweranusexposed is 1>>
<<if $anususe is 0 and $analdisable is "f">><span class="purple"><<He>> presses <<his>> right hand against your <<bottomstop>></span><<set $righthand2 to "anusentrance">><<set $anususe to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<<elseif $lowerclothes isnot "waist">>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $righthand2 to "underclothes">><<neutral 1>>
<<elseif $underanusexposed is 1>>
<<if $loweranusexposed is 1>>
<<if $anususe is 0 and $analdisable is "f">><span class="purple"><<He>> presses <<his>> right hand against your <<bottomstop>></span><<set $righthand2 to "anusentrance">><<set $anususe to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 40>>
<<if $skirt is 1>>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $righthand2 to "underclothes">><<neutral 1>>
<<elseif $undervaginaexposed is 1>>
<<if $lowervaginaexposed is 1>>
<<if $vaginaexist is 1>>
<<if $vaginause is 0>>
<span class="purple"><<He>> presses <<his>> right hand against your <<pussycomma>> resting a finger on your entrance.</span><<set $righthand2 to "vaginaentrance">><<set $vaginause to 1>><<neutral 1>>
<</if>>
<<elseif $penisexist is 1>>
<<if $penisuse is 0>><span class="purple"><<He>> presses <<his>> right hand against your <<penisstop>></span><<set $righthand2 to "penisentrance">><<set $penisuse to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $lowerclothes isnot "waist">>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $righthand2 to "underclothes">><<neutral 1>>
<<elseif $undervaginaexposed is 1>>
<<if $lowervaginaexposed is 1>>
<<if $vaginaexist is 1>>
<<if $vaginause is 0>>
<span class="purple"><<He>> presses <<his>> right hand against your <<pussycomma>> resting a finger above your entrance.</span><<set $righthand2 to "vaginaentrance">><<set $vaginause to 1>><<neutral 1>>
<</if>>
<<elseif $penisexist is 1>>
<<if $penisuse is 0>>
<span class="purple"><<He>> presses <<his>> right hand against your <<penisstop>></span><<set $righthand2 to "penisentrance">><<set $penisuse to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 45>>
<<if $position is "wall">>
<<He>> rests <<his>> right hand against the wall.
<<else>>
<<He>> <<strokes>> your tummy with <<his>> right hand.<<neutral 1>>
<</if>>
<<elseif $enemyanger + $rng lte 50>>
<<if $position is "wall">>
<<He>> pushes your <<bottomcomma>> making sure you're stuck firm.<<neutral 1>>
<<else>>
<<He>> <<strokes>> your cheek.<<neutral 1>>
<</if>>
<<elseif $enemyanger + $rng lte 60>>
<<if $position is "wall">>
<<He>> tugs on your leg, but you're stuck firm.<<neutral 1>>
<<elseif $uppertype isnot "naked" and $upperstate isnot "chest" and $upperstatetop is "chest">>
<<He>> gropes your <<breasts>> through your $upperclothes.<<neutral 2>>
<<else>>
<<He>> gropes your exposed <<breastsstop>><<neutral 4>>
<</if>>
<<elseif $enemyanger + $rng lte 80>><<set $speechbottom to 1>>
<<if $lowerstate is "waist" and $skirt is 0>>
<<He>> gropes your <<bottom>> through your $lowerclothes.<<neutral 2>>
<<elseif $understate is "waist">>
<<He>> gropes your <<bottom>> through your $underclothes.<<neutral 2>>
<<else>>
<<He>> fondles and <<strokes>> your exposed <<bottomstop>><<neutral 4>>
<</if>>
<<elseif $enemyanger + $rng lte 100>>
<<if $penisexist is 1>>
<<if $lowerstate is "waist" and $skirt is 0>>
<<He>> gropes and <<strokes>> your <<penis>> through your $lowerclothes.<<neutral 5>>
<<elseif $understate is "waist">>
<<He>> gropes and <<strokes>> your <<penis>> through your $underclothes.<<neutral 5>>
<<elseif $penisuse is 0>>
<<He>> gropes and <<strokes>> your exposed <<penisstop>><<neutral 10>>
<<else>>
<<He>> cups and <<strokes>> your <<testiclesstop>><<neutral 10>>
<</if>>
<<elseif $vaginaexist is 1>>
<<if $lowerstate is "waist" and $skirt is 0>>
<<He>> gropes and <<strokes>> your labia through your $lowerclothes.<<neutral 5>>
<<elseif $understate is "waist">>
<<He>> gropes and <<strokes>> your labia through your $underclothes.<<neutral 5>>
<<else>>
<<He>> gropes and <<strokes>> your exposed <<pussystop>><<neutral 10>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 110>>
<<if $lowerclothes isnot "naked">><span class="purple"><<He>> grasps your $lowerclothes.</span><<set $righthand2 to "lowerclothes">><<neutral 1>>
<<elseif $vaginaexist is 1>>He pinches your clitoris.<<neutral 15>><<bruise vagina>><<set $speechclit to 1>>
<<elseif $penisexist is 1>>
<<if $penisuse is 0>>
<<He>> pinches your glans.<<neutral 15>><<bruise penis>><<set $speechglans to 1>>
<<else>>
<<He>> pinches your shaft.<<neutral 10>><<bruise penis>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 120>>
<<if $position is "wall">>
<<He>> squeezes your thigh.<<violence 1>><<hitstat>><<bruise thigh>>
<<else>>
<<if $upperclothes isnot "naked">><span class="purple"><<He>> grasps your $upperclothes.</span><<set $righthand2 to "upperclothes">><<neutral 1>>
<<else>><span class="purple"><<He>> grabs your throat.</span><<violence 2>><<set $righthand2 to "throat">>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 125>>
<<if $skirt is 1>>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $righthand2 to "underclothes">><<neutral 1>>
<<elseif $underanusexposed is 1>>
<<if $loweranusexposed is 1>>
<<if $anususe is 0 and $analdisable is "f">><span class="purple"><<He>> presses <<his>> right hand against your <<bottomstop>></span><<set $righthand2 to "anusentrance">><<set $anususe to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<<elseif $lowerclothes isnot "waist">>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $righthand2 to "underclothes">><<neutral 1>>
<<elseif $underanusexposed is 1>>
<<if $loweranusexposed is 1>>
<<if $anususe is 0 and $analdisable is "f">><span class="purple"><<He>> presses <<his>> right hand against your <<bottomstop>></span><<set $righthand2 to "anusentrance">><<set $anususe to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 130>>
<<if $skirt is 1>>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $righthand2 to "underclothes">><<neutral 1>>
<<elseif $undervaginaexposed is 1>>
<<if $lowervaginaexposed is 1>>
<<if $vaginaexist is 1>>
<<if $vaginause is 0>>
<span class="purple"><<He>> presses <<his>> right hand against your <<pussycomma>> <<his>> finger resting on your entrance.</span><<set $righthand2 to "vaginaentrance">><<set $vaginause to 1>><<neutral 1>>
<</if>>
<<elseif $penisexist is 1>>
<<if $penisuse is 0>><span class="purple"><<He>> presses <<his>> right hand against your <<penisstop>></span><<set $righthand2 to "penisentrance">><<set $penisuse to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $lowerclothes isnot "waist">>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $righthand2 to "underclothes">><<neutral 1>>
<<elseif $undervaginaexposed is 1>>
<<if $lowervaginaexposed is 1>>
<<if $vaginaexist is 1>>
<<if $vaginause is 0>>
<span class="purple"><<He>> presses <<his>> right hand against your <<pussycomma>> <<his>> finger resting on your entrance.</span><<set $righthand2 to "vaginaentrance">><<set $vaginause to 1>><<neutral 1>>
<</if>>
<<elseif $penisexist is 1>>
<<if $penisuse is 0>>
<span class="purple"><<He>> presses <<his>> right hand against your <<penisstop>></span><<set $righthand2 to "penisentrance">><<set $penisuse to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 140>>
<<if $position is "wall">>
<<He>> slaps your <<bottomstop>><<violence 1>><<bruise bottom>><<hitstat>>
<<else>>
<span class="purple"><<He>> seizes your hair with <<his>> right hand.</span><<set $righthand2 to "hair">><<violence 2>><<set $speechhair to 1>>
<</if>>
<<elseif $enemyanger + $rng lte 160 and $lefthand2 isnot "arms" and $righthand2 isnot "arms" and $leftarm isnot "bound" and $rightarm isnot "bound">><span class="purple"><<He>> pins down your arms.</span><<set $righthand2 to "arms">><<set $leftarm to "grappled">><<set $rightarm to "grappled">><<disablearms>><<violence 2>><<bruise leftarm>><<bruise rightarm>><<set $speecharms to 1>>
<<if $vaginause is "cover">><<set $vaginause to 0>>
<</if>>
<<if $vaginause is "cover">><<set $vaginause to 0>>
<</if>>
<<if $anususe is "cover">><<set $anususe to 0>>
<</if>>
<<if $anususe is "cover">><<set $anususe to 0>>
<</if>>
<<if $penisuse is "cover">><<set $penisuse to 0>>
<</if>>
<<if $penisuse is "cover">><<set $penisuse to 0>>
<</if>>
<<elseif $enemyanger + $rng lte 160>><<He>> grips your <<bottomcomma>> digging <<his>> nails into your skin.<<violence 10>><<bruise bottom>><<hitstat>><<set $speechspank to 1>>
<<elseif $enemyanger + $rng lte 175>><<He>> spanks your <<bottomstop>><<violence 10>><<bruise bottom>><<hitstat>><<set $speechspank to 1>>
<<elseif $enemyanger + $rng lte 180>><<He>> slaps your thighs.<<violence 10>><<bruise thigh>><<hitstat>><<set $speechbeat to 1>>
<<elseif $enemyanger + $rng lte 185>>
<<if $position is "wall">>
<<He>> beats your thigh.<<bruise thigh>><<hitstat>><<violence 10>><<set $speechbeat to 1>>
<<else>>
<<He>> beats your tummy.<<violence 20>><<bruise tummy>><<hitstat>><<set $speechbeat to 1>>
<</if>>
<<elseif $enemyanger + $rng lte 190>>
<<if $position is "wall">>
<<He>> spanks your <<bottomstop>><<violence 20>><<bruise bottom>><<hitstat>><<set $speechbeat to 1>>
<<else>>
<<He>> spanks your <<breastsstop>><<violence 20>><<bruise chest>><<hitstat>><<set $speechbeat to 1>>
<</if>>
<<elseif $enemyanger + $rng gte 191>>
<<if $position is "wall">>
<<if $penisexist is 1>>
<<He>> jabs your gooch.<<violence 20>><<bruise penis>><<hitstat>><<set $speechbeat to 1>>
<<elseif $vaginaexist is 1>>
<<He>> jabs your gooch.<<violence 20>><<bruise vagina>><<hitstat>><<set $speechbeat to 1>>
<</if>>
<<else>>
<<set $rng to random(1, 100)>>
<<if $rng gte 81>>
<<He>> scratches the side of your face.<<violence 20>><<bruise face>><<hitstat>><<set $speechbeat to 1>>
<<elseif $rng gte 61>>
<<He>> scratches the back of your neck.<<violence 20>><<bruise neck>><<hitstat>><<set $speechbeat to 1>>
<<elseif $rng gte 41>>
<<He>> scratches your cheek.<<violence 20>><<bruise face>><<hitstat>><<set $speechbeat to 1>>
<<elseif $rng gte 21>>
<<He>> scratches your jaw.<<violence 20>><<bruise face>><<hitstat>><<set $speechbeat to 1>>
<<else>>
<<He>> scratches the front of your neck.<<violence 20>><<bruise neck>><<hitstat>><<set $speechbeat to 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis2 is "clothed">>
<<if $pronoun is "m">>
<<if $enemyarousal gte 40>><<He>> unzips <<his>> fly, <span class="blue">revealing <<his>> erect penis.</span><<set $penis2 to 0>>
<</if>>
<<else>>
<<if $enemyarousal gte 40>><<He>> pulls up <<his>> skirt, <span class="blue">revealing <<his>> erect penis.</span><<set $penis2 to 0>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis2 is "thighs">>
<<if $vaginaexist is 1>>
<<if $rng gte 101>><span class="blue"><<He>> angles <<his>> penis towards your <<pussystop>></span><<set $thighuse to 0>><<set $penis2 to "vaginaentrance">><<set $vaginause to "penis">><<set $vaginastate to "entrance">><<set $speechvaginaentrance to 1>>
<<else>>
<<He>> rubs <<his>> penis between your thighs and <<pussystop>><<sex 5>>
<</if>>
<<else>>
<<if $rng gte 101>><<He>> moves <<his>> penis out from between your thighs.<<set $thighuse to 0>><<set $penis2 to 0>>
<<else>>
<<He>> rubs <<his>> penis between your thighs.<<sex 5>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis2 is "cheeks">>
<<if $rng gte 101>><span class="blue"><<He>> angles <<his>> penis towards your anus.</span><<set $penis2 to "anusentrance">><<set $anusstate to "entrance">><<set $bottomuse to 0>><<set $cheekactiondefault to "cheeks">><<set $speechanusentrance to 1>>
<<else>>
<<He>> rubs <<his>> penis between your cheeks.<<submission 3>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis2 is "leftarm">>
<<if $rng gte 1>><<He>> rubs <<his>> penis between your fingers.<<submission 1>>
<<elseif $rng gte 101>><<He>> moves <<his>> penis away from your hand.<<set $penis2 to 0>><<set $leftarm to 0>><<set $leftactiondefault to "leftgrab">>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis2 is "rightarm">>
<<if $rng gte 1>><<He>> rubs <<his>> penis between your fingers.<<submission 1>>
<<elseif $rng gte 101>><<He>> moves <<his>> penis away from your hand.<<set $penis2 to 0>><<set $rightarm to 0>><<set $rightactiondefault to "rightgrab">>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis2 is "botharm">>
<<if $rng gte 1>><<He>> rubs <<his>> penis between your hands.<<submission 2>>
<<elseif $rng gte 101>><<He>> moves <<his>> penis away from your hands.<<set $penis2 to 0>><<set $leftarm to 0>><<set $rightarm to 0>><<set $rightactiondefault to "rightgrab">><<set $leftactiondefault to "leftgrab">>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis2 is "feet">>
<<if $rng gte 1>>
<<He>> rubs <<his>> penis between your feet.<<submission 1>>
<<elseif $rng gte 101>>
<<He>> moves <<his>> penis away from your feet.<<set $penis2 to 0>><<set $feetuse to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis2 is "vagina">>
<<if $rng gte 101>><span class="purple"><<He>> slides <<his>> penis out of your <<pussystop>></span><<sex 30>><<set $penis2 to "vaginaimminent">><<bruise vagina>><<violence 1>><<set $vaginastate to "imminent">>
<<elseif $rng gte 1>>
<<if $enemyanger gte 100>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
<<He>> violates your <<pussy>> with increasing intensity.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues to fuck your <<pussy>> with no regard for your comfort.
<<else>>
<<He>> fucks your <<pussy>> with rough thrusts, giving no regard to your comfort.
<</if>>
<<elseif $enemyanger gte 20>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
You feel <<his>> penis throb as <<he>> pounds away at your <<pussystop>>
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues to violate your <<pussystop>>
<<else>>
<<He>> fucks your <<pussy>> with deep and deliberate thrusts.
<</if>>
<<else>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
<<He>> fucks your <<pussy>> with increasing power.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues thrusting into your <<pussystop>>
<<else>>
<<He>> fucks your <<pussy>> with steady thrusts.
<</if>>
<</if>>
<<sex 30>><<bruise vagina>><<violence 1>><<set $speechvaginapenetrated to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis2 is "vaginaimminent">>
<<if $rng gte 101>><span class="blue"><<He>> stops pressing <<his>> penis against your pussy.</span><<set $penis2 to "vaginaentrance">><<set $vaginastate to "entrance">>
<<elseif $rng gte 1>>
<<if $novaginal is 0>><<set $vaginaactiondefault to "take">>
<<if $vaginalvirginity is 0>>
<<if $enemyanger gte 80>>
<span class="pink"><<He>> thrusts <<his>> penis deep into your <<pussystop>></span>
<<elseif $enemyanger gte 20>>
<span class="pink"><<He>> thrusts <<his>> penis deep into your <<pussystop>></span>
<<else>>
<span class="pink"><<He>> glides <<his>> penis deep into your <<pussystop>></span>
<</if>>
<<sex 30>><<set $penis2 to "vagina">><<vaginalstat>><<bruise vagina>><<violence 1>><<raped>><<vaginaraped>><<set $vaginastate to "penetrated">><<set $speechvaginapenetrated to 1>>
<<elseif $vaginalvirginity is 1>><span class="pink"><<His>> penis thrusts deep into your virgin pussy,</span><span class="red"> breaking your hymen and forever robbing you of your purity.</span><<sex 100>><<set $penis2 to "vagina">><<set $vaginalvirginity to 0>><<bruise vagina>><<vaginalstat>><<violence 100>><<raped>><<vaginaraped>><<set $vaginastate to "penetrated">><<set $speechvaginavirgin to 1>>
<</if>>
<<else>>
Respecting your wishes, <<he>> presses <<his>> penis against your <<pussy>> but does not penetrate.<<sex 15>><<set $speechvaginawithhold to 1>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis2 is "vaginaentrance">>
<<if $rng gte 101>><span class="lblue"><<He>> moves <<his>> penis away from your <<pussystop>></span><<set $penis2 to 0>><<set $vaginause to 0>><<set $vaginastate to 0>>
<<elseif $rng gte 1>>
<<if $lowervaginaexposed is 0>><<He>> rubs <<his>> penis against your <<pussy>> through your $lowerclothes.<<sex 5>><<set $lowerintegrity -= 10>><<set $speechvaginaentrance to 1>>
<<elseif $lowervaginaexposed is 1>><<set $rng to random(1, 100)>>
<<if $undervaginaexposed is 0>><<He>> rubs <<his>> penis against your <<pussy>> through your $underclothes.<<sex 5>><<set $underintegrity -= 10>><<set $speechvaginaentrance to 1>>
<<elseif $undervaginaexposed is 1>>
<<if $rng gte 71>>
<<if $novaginal is 1>>
<span class="purple"><<He>> pushes <<his>> penis against your <<pussystop>></span><<sex 20>><<set $penis2 to "vaginaimminent">><<set $vaginastate to "imminent">><<set $speechvaginaimminent to 1>>
<<else>>
<span class="purple"><<He>> pushes <<his>> penis against your <<pussycomma>> preparing to penetrate you fully.</span><<sex 20>><<set $penis2 to "vaginaimminent">><<set $vaginastate to "imminent">><<set $speechvaginaimminent to 1>>
<</if>>
<<elseif $rng gte 1>><<He>> teases your <<pussy>> without penetrating.<<sex 10>><<set $speechvaginaentrance to 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis2 is "anus">>
<<if $rng gte 101>><span class="purple"><<He>> withdraws <<his>> penis from your anus.</span><<sex 30>><<set $penis2 to "anusimminent">><<bruise anus>><<violence 1>><<set $anusstate to "imminent">>
<<elseif $rng gte 1>>
<<if $enemyanger gte 100>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
<<He>> ravages your <<bottom>> with a violent intensity.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
You feel <<his>> penis ever deeper within you as <<he>> fucks your <<bottomstop>>
<<else>>
<<He>> fucks your <<bottom>> with rough thrusts, intent on showing you who's boss.
<</if>>
<<elseif $enemyanger gte 20>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
You feel <<his>> penis throb within you as <<he>> fucks your <<bottomstop>>
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues to violate your <<bottomcomma>> giving no regard to your comfort.
<<else>>
<<He>> fucks your <<bottom>> with deep and dominating thrusts.
<</if>>
<<else>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
<<He>> fucks your <<bottom>> with increasing power.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues fucking your <<bottomstop>>
<<else>>
<<He>> fucks your <<bottom>> with steady thrusts.
<</if>>
<</if>>
<<sex 30>><<bruise anus>><<violence 1>><<set $speechanuspenetrated to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis2 is "anusimminent">>
<<if $rng gte 101>><span class="blue"><<He>> stops pressing <<his>> penis against your anus.</span><<set $penis2 to "anusentrance">><<set $anusstate to "entrance">>
<<elseif $rng gte 1>>
<<if $noanal is 0>><<set $anusactiondefault to "take">>
<<if $analvirginity is 0>><span class="pink"><<He>> thrusts <<his>> penis deep into your <<bottomstop>></span><<sex 30>><<set $penis2 to "anus">><<bruise anus>><<analstat>><<violence 1>><<raped>><<set $anusstate to "penetrated">><<set $speechanuspenetrated to 1>>
<<elseif $analvirginity is 1>><span class="pink"><<He>> thrusts <<his>> penis deep into your virgin anus,</span> <span class="red">violating you in a way you hadn't conceived of.</span><<sex 100>><<set $penis2 to "anus">><<set $analvirginity to 0>><<bruise anus>><<analstat>><<violence 50>><<raped>><<set $anusstate to "penetrated">><<set $speechanusvirgin to 1>>
<</if>>
<<else>>
Respecting your wishes, <<he>> presses <<his>> penis against your anus but does not penetrate.<<sex 15>><<set $speechanuswithhold to 1>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis2 is "anusentrance">>
<<if $rng gte 101>><span class="lblue"><<He>> moves <<his>> penis away from your <<bottomstop>></span><<set $penis2 to 0>><<set $anususe to 0>><<set $anusstate to 0>>
<<elseif $rng gte 1>>
<<if $loweranusexposed is 0>><<He>> rubs <<his>> penis against your <<bottom>> through your $lowerclothes.<<sex 5>><<set $lowerintegrity -= 10>><<set $speechanusentrance to 1>>
<<elseif $loweranusexposed is 1>><<set $rng to random(1, 100)>>
<<if $underanusexposed is 0>><<He>> rubs <<his>> penis against your <<bottom>> through your $underclothes.<<set $speechanusentrance to 1>><<sex 5>><<set $underintegrity -= 10>>
<<elseif $underanusexposed is 1>>
<<if $rng gte 71>>
<<if $noanal is 1>>
<span class="pink"><<He>> presses <<his>> penis against your anus.</span><<sex 20>><<set $penis2 to "anusimminent">><<set $anusstate to "imminent">><<set $speechanusimminent to 1>>
<<else>>
<span class="pink"><<He>> presses <<his>> penis against your anus, preparing to penetrate you fully.</span><<sex 20>><<set $penis2 to "anusimminent">><<set $anusstate to "imminent">><<set $speechanusimminent to 1>>
<</if>>
<<elseif $rng gte 1>><<His>> penis rubs against your <<bottomstop>><<sex 5>><<set $speechanusentrance to 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis2 is "mouth">>
<<if $rng gte 101>><span class="purple"><<He>> withdraws <<his>> penis from your mouth.</span><<sex 30>><<set $penis2 to "mouthimminent">><<bruise face>><<violence 1>><<set $mouthstate to "imminent">>
<<elseif $rng gte 1>><<He>> continues thrusting into your mouth.<<submission 10>><<bruise face>><<violence 1>><<set $speechmouthpenetrated to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis2 is "mouthimminent">>
<<if $pullaway is 1>><<set $pullaway to 0>>Saliva drips from the tip of <<his>> phallus.
<<else>>
<<if $rng gte 101>><span class="blue"><<He>> stops pressing <<his>> penis against your mouth.</span><<set $penis2 to "mouthentrance">><<submission 5>><<set $mouthstate to "entrance">>
<<elseif $rng lte 20>>
<<if $oralvirginity is 0>><span class="pink"><<He>> thrusts <<his>> penis into your mouth.</span><<submission 10>><<set $penis2 to "mouth">><<bruise face>><<oralstat>><<raped>><<set $mouthstate to "penetrated">><<set $speechmouthpenetrated to 1>>
<<elseif $oralvirginity is 1>><span class="pink"><<He>> thrusts <<his>> penis into your mouth.</span><span class="red"> It tastes strange.</span><<submission 30>><<set $penis2 to "mouth">><<set $oralvirginity to 0>><<bruise face>><<oralstat>><<violence 1>><<raped>><<set $mouthstate to "penetrated">><<set $speechmouthvirgin to 1>>
<</if>>
<<elseif $rng gte 21>>
<<if $mouthsubmit is 1>><<He>> allows you to pleasure <<his>> cock with your mouth.<<submission 5>><<set $speechmouthimminent to 1>>
<<elseif $oralvirginity is 0>><span class="pink"><<He>> thrusts <<his>> penis into your mouth.</span><<submission 10>><<set $penis2 to "mouth">><<oralstat>><<bruise face>><<violence 1>><<raped>><<set $mouthstate to "penetrated">><<set $speechmouthpenetrated to 1>>
<<elseif $oralvirginity is 1>><span class="pink"><<He>> thrusts <<his>> penis into your mouth.</span><span class="red"> It tastes strange.</span><<submission 30>><<set $penis2 to "mouth">><<set $oralvirginity to 0>><<oralstat>><<bruise face>><<violence 1>><<raped>><<set $mouthstate to "penetrated">><<set $speechmouthpenetrated to 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis2 is "mouthentrance">>
<<if $pullaway is 1>><<set $pullaway to 0>><<His>> penis hovers only inches from your face.
<<else>>
<<if $rng gte 101>><span class="lblue"><<He>> moves <<his>> penis away from your mouth.</span><<set $penis2 to 0>><<set $mouthuse to 0>><<set $mouthstate to 0>>
<<elseif $rng gte 1>><span class="purple"><<He>> pushes <<his>> penis against your lips.</span><<set $penis2 to "mouthimminent">><<submission 5>><<set $mouthstate to "imminent">><<set $speechmouthimminent to 1>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis2 is "chest">>
<<if $rng gte 101>><<He>> moves <<his>> penis away from your chest.<<set $penis2 to 0>><<set $chestuse to 0>>
<<elseif $rng gte 1>><<submission 3>>
<<if $breastcup is "none">>
<<He>> rubs <<his>> penis against your <<breastsstop>><<set $speechchestrub to 1>>
<<else>>
<<He>> rubs <<his>> penis between your <<breastsstop>><<set $speechbreastrub to 1>>
<</if>>
<</if>>
<</if>>
<<if $penis2 is "footjob">>
<<if $rng gte 101>>
<span class="blue"><<He>> stops pressing <<his>> foot against your <<genitalsstop>></span><<set $penis2 to 0>>
<<if $penisexist is 1>>
<<set $penisuse to 0>>
<<else>>
<<set $vaginause to 0>>
<</if>>
<<else>>
<<if $penisexist is 1>>
<<He>> presses your <<penis>> against your stomach with <<his>> foot and rubs your glans between <<his>> toes.
<<set $speechpenisfoot to 1>><<neutral 5>><<violence 1>>
<<else>>
<<He>> presses and teases your <<pussy>> with <<his>> foot.
<<set $speechvaginafoot to 1>><<neutral 5>><<violence 1>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis2 is "otherfrot">>
<<if $rng gte 101>><span class="blue"><<He>> shifts <<his>> ass and presses <<his>> anus against your <<penisstop>></span><<set $penisuse to "otheranus">><<set $penis2 to "otheranusentrance">><<set $penisstate to "otheranusentrance">><<set $speechotheranusentrance to 1>>
<<else>>
<<He>> rubs <<his>> ass against your <<penisstop>><<sex 5>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis2 is "otheranus">>
<<if $rng gte 101>><span class="purple"><<He>> moves <<his>> pelvis away, releasing your <<penis>> from <<his>> anus.</span><<sex 30>><<set $penis2 to "otheranusimminent">><<bruise penis>><<violence 1>><<set $penisstate to "otheranusimminent">><<set $speechotheranusimminent to 1>>
<<elseif $rng gte 1>>
<<if $enemyanger gte 100>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
<<His>> continues to fuck your <<penis>> with <<his>> ass, <<his>> movements violent and erratic.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues to ride you, your penis helpless as it's fucked.
<<else>>
<<He>> fucks your <<penis>> with rough movements, intent on showing you who's boss.
<</if>>
<<elseif $enemyanger gte 20>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
You feel <<his>> ass twitch around your length <<he>> fucks you.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues to violate your <<peniscomma>> using you as a sex toy.
<<else>>
<<He>> fucks your <<peniscomma>> taking as much of you into <<his>> ass as <<he>> can.
<</if>>
<<else>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
<<He>> continues riding your <<peniscomma>> <<his>> anus rhythmically pounding your length. <<His>> body jerks whenever you hit a sensitive spot.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues riding your <<peniscomma>> <<his>> anus rhythmically pounding your length.
<<else>>
<<He>> rides your <<penis>> with steady movements.
<</if>>
<</if>>
<<sex 30>><<bruise penis>><<violence 1>><<set $speechotheranus to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis2 is "otheranusimminent">>
<<if $rng gte 101>><span class="blue"><<He>> stops pressing <<his>> ass against your <<penisstop>></span><<set $penis2 to "otheranusentrance">><<set $penisstate to "otheranusentrance">><<set $speechotheranusentrance to 1>>
<<elseif $rng gte 1>>
<<if $nopenile is 0>><<set $penisactiondefault to "otheranustake">>
<<if $penilevirginity is 0>><span class="pink"><<He>> eases your <<penis>> into <<his>> ass, swallowing you to the base.</span><<sex 30>><<set $penis2 to "otheranus">><<penilestat>><<bruise penis>><<violence 1>><<raped>><<penisraped>><<set $penisstate to "otheranus">><<set $speechotheranus to 1>>
<<elseif $penilevirginity is 1>><span class="pink"><<He>> eases your virgin penis into <<his>> ass,</span><span class="red"> separating your foreskin from your glans and forever robbing you of your purity.</span><<sex 100>><<set $penis2 to "otheranus">><<set $penilevirginity to 0>><<bruise penis>><<penilestat>><<violence 100>><<raped>><<penisraped>><<set $penisstate to "otheranus">><<set $speechpenisvirgin to 1>>
<</if>>
<<else>>
Respecting your wishes, <<he>> does not envelope your <<penis>> with <<his>> ass, instead teasing the tip of your glans.<<sex 15>><<set $speechotheranuswithhold to 1>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis2 is "otheranusentrance">>
<<if $rng gte 101>><span class="lblue"><<He>> moves <<his>> ass away from your <<penisstop>></span><<set $penis2 to 0>><<set $penisuse to 0>><<set $penisstate to 0>>
<<elseif $rng gte 1>>
<<if $lowervaginaexposed is 0>><<He>> rubs <<his>> ass against your <<penis>> through your $lowerclothes.<<sex 5>><<set $lowerintegrity -= 10>><<set $speechotheranusentrance to 1>>
<<elseif $lowervaginaexposed is 1>><<set $rng to random(1, 100)>>
<<if $undervaginaexposed is 0>><<He>> rubs <<his>> ass against your <<penis>> through your $underclothes.<<sex 5>><<set $underintegrity -= 10>><<set $speechotheranusentrance to 1>>
<<elseif $undervaginaexposed is 1>>
<<if $rng gte 71>>
<<if $nopenile is 1>>
<span class="purple"><<He>> presses <<his>> ass against your <<penisstop>></span><<sex 20>><<set $penis2 to "otheranusimminent">><<set $penisstate to "otheranusimminent">><<set $speechotheranusimminent to 1>>
<<else>>
<span class="purple"><<He>> presses <<his>> ass against your <<peniscomma>> preparing to take you in fully.</span><<sex 20>><<set $penis2 to "otheranusimminent">><<set $penisstate to "otheranusimminent">><<set $speechotheranusimminent to 1>>
<</if>>
<<elseif $rng gte 1>><<He>> rubs your <<penis>> between <<his>> cheeks.<<sex 10>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis2 is 0>>
<<if $enemyanger + $rng lte 20>>
<<if $lefthand2 is 0>>
<<if $enemyarousal lte 40>><<He>> slowly rubs <<his>> shaft.<<submission 1>>
<<elseif $enemyarousal lte 90>><<He>> quickly rubs <<his>> shaft.<<submission 2>>
<<elseif $enemyarousal gte 91>><<He>> rapidly rubs <<his>> shaft.<<submission 3>>
<</if>>
<<elseif $righthand2 is 0>>
<<if $enemyarousal lte 40>><<He>> slowly rubs <<his>> shaft.<<submission 1>>
<<elseif $enemyarousal lte 90>><<He>> quickly rubs <<his>> shaft.<<submission 2>>
<<elseif $enemyarousal gte 91>><<He>> rapidly rubs <<his>> shaft.<<submission 3>>
<<endif>
<<else>><<He>> rubs <<his>> cock against your thighs.<<submission 2>>
<</if>>
<<elseif $enemyanger + $rng lte 25>>
<<if $position is "wall">>
<<He>> rubs <<his>> cock against your thighs.<<submission 2>>
<<else>>
<<He>> rubs <<his>> cock against your tummy.<<submission 2>>
<</if>>
<<elseif $enemyanger + $rng lte 30>>
<<if $position is "wall">>
<<He>> rubs <<his>> cock against your thighs.<<submission 2>>
<<else>>
<<He>> rubs <<his>> cock against your <<breastsstop>><<submission 2>>
<</if>>
<<elseif $enemyanger + $rng lte 35>><<He>> rubs <<his>> cock against your thighs.<<submission 2>>
<<elseif $enemyanger + $rng lte 40>>
<<if $position is "wall">>
<<He>> rubs <<his>> cock against your thighs.<<submission 2>>
<<elseif $mouth2 is 0>>
<<He>> rubs <<his>> cock against your face.<<submission 2>>
<<else>>
<<He>> rubs <<his>> cock against your thighs.<<submission 2>>
<</if>>
<<elseif $enemyanger + $rng lte 45>>
<<if $penisexist is 1>>
<<if $penisuse is 0>>
<<if $analdisable is "f" and $consensual is 1>>
<span class="blue"><<He>> straddles you, rubbing <<his>> ass against your <<penisstop>></span><<neutral 5>><<set $penisuse to "otheranus">><<set $penis2 to "otheranusentrance">><<set $penisstate to "otheranusentrance">><<set $speechotheranusentrance to 1>>
<</if>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 60>>
<<if $mouthuse is 0>>
<<if $penisbitten is 0>>
<<if $position isnot "wall">>
<span class="blue"><<He>> positions <<his>> penis in front of your mouth.</span><<neutral 5>><<set $mouthuse to "penis">><<set $penis2 to "mouthentrance">><<set $mouthstate to "entrance">><<set $speechmouthentrance to 1>>
<</if>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 80>>
<<if $anususe is 0>>
<<if $analdisable is "f">>
<span class="blue"><<He>> moves between your legs, positioning <<his>> penis in front of your <<bottomstop>></span><<neutral 5>><<set $anususe to "penis">><<set $penis2 to "anusentrance">><<set $anusstate to "entrance">><<set $speechanusentrance to 1>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 100>>
<<if $vaginaexist is 1>>
<<if $vaginause is 0>><span class="blue"><<He>> moves between your legs, positioning <<his>> penis in front of your <<pussystop>></span><<neutral 5>><<set $vaginause to "penis">><<set $penis2 to "vaginaentrance">><<set $vaginastate to "entrance">><<set $speechvaginaentrance to 1>>
<</if>>
<<elseif $penisexist is 1>>
<<if $anususe is 0>>
<<if $analdisable is "f">>
<span class="blue"><<He>> moves between your legs, positioning <<his>> penis in front of your <<bottomstop>></span><<neutral 5>><<set $anususe to "penis">><<set $penis2 to "anusentrance">><<set $anusstate to "entrance">><<set $speechanusentrance to 1>>
<</if>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 120>>
<<He>> slowly traces <<his>> length across your exposed skin.<<neutral 1>>
<<neutral 5>>
<<elseif $enemyanger + $rng lte 140>>
<<if $penisbitten is 0>>
<<if $position isnot "wall">>
<<if $mouthuse is 0>><span class="purple"><<He>> shoves <<his>> penis against your lips.</span><<submission 5>><<set $mouthuse to "penis">><<set $mouthstate to "imminent">><<set $penis2 to "mouthimminent">><<set $speechmouthimminent to 1>>
<<else>>
<<He>> slowly traces <<his>> length across your exposed skin.<<neutral 1>>
<</if>>
<<else>>
<<He>> slowly traces <<his>> length across your exposed skin.<<neutral 1>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 150>><span class="purple"><<He>> presses <<his>> foot against your <<genitalsstop>></span><<neutral 5>><<violence 1>><<set $penis2 to "footjob">>
<<if $penisexist is 1>>
<<set $penisuse to "feet">><<set $speechpenisfoot to 1>>
<<else>>
<<set $vaginause to "feet">><<set $speechvaginafoot to 1>>
<</if>>
<<elseif $enemyanger + $rng lte 170>>
<<if $anususe is 0 and $analdisable is "f">>
<<if $loweranusexposed is 1>>
<<if $underanusexposed is 1>>
<span class="purple"><<He>> presses <<his>> penis against your anus, preparing to penetrate.</span><<sex 5>><<set $anususe to "penis">><<set $penis2 to "anusimminent">><<set $anusstate to "imminent">><<set $speechanusimminent to 1>>
<<elseif $underanusexposed is 0>><span class="blue"><<He>> presses <<his>> penis against your anus through your $underclothes.</span><<sex 3>><<set $penis2 to "anusentrance">><<set $anususe to "penis">><<set $underintegrity -= 10>><<set $anusstate to "entrance">><<set $speechanusentrance to 1>>
<</if>>
<<elseif $loweranusexposed is 0>><span class="blue"><<He>> presses <<his>> penis against your anus through your $lowerclothes.</span><<sex 2>><<set $penis2 to "anusentrance">><<set $anususe to "penis">><<set $lowerintegrity -= 10>><<set $anusstate to "entrance">><<set $speechanusentrance to 1>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng gte 171>>
<<if $vaginaexist is 1>>
<<if $vaginause is 0>>
<<if $lowervaginaexposed is 1>>
<<if $undervaginaexposed is 1>><span class="purple"><<He>> presses <<his>> penis against your <<pussycomma>> preparing to penetrate.</span><<sex 5>><<set $vaginause to "penis">><<set $penis2 to "vaginaimminent">><<set $vaginastate to "imminent">><<set $speechvaginaimminent to 1>>
<<elseif $undervaginaexposed is 0>><span class="blue"><<He>> presses <<his>> penis against your <<pussy>> through your $underclothes.</span><<set $underintegrity -= 10>><<sex 3>><<set $penis2 to "vaginaentrance">><<set $vaginause to "penis">><<set $vaginastate to "entrance">><<set $speechvaginaentrance to 1>>
<</if>>
<<elseif $lowervaginaexposed is 0>><span class="blue"><<He>> presses <<his>> penis against your <<pussy>> through your $lowerclothes.</span><<sex 2>><<set $penis2 to "vaginaentrance">><<set $vaginause to "penis">><<set $lowerintegrity -= 10>><<set $vaginastate to "entrance">><<set $speechvaginaentrance to 1>>
<</if>>
<</if>>
<<elseif $penisexist is 1>>
<<if $anususe is 0 and $analdisable is "f">>
<<if $loweranusexposed is 1>>
<<if $underanusexposed is 1>><span class="purple"><<He>> presses <<his>> penis against your anus, preparing to penetrate.</span><<sex 5>><<set $anususe to "penis">><<set $penis2 to "anusimminent">><<set $anusstate to "imminent">><<set $speechanusimminent to 1>>
<<elseif $underanusexposed is 0>><span class="blue"><<He>> presses <<his>> penis against your anus through your $underclothes.</span><<sex 3>><<set $penis2 to "anusentrance">><<set $anususe to "penis">><<set $underintegrity -= 10>><<set $anusstate to "entrance">><<set $speechanusentrance to 1>>
<</if>>
<<elseif $loweranusexposed is 0>><span class="blue"><<He>> presses <<his>> penis against your anus through your $lowerclothes.</span><<sex 2>><<set $penis2 to "anusentrance">><<set $anususe to "penis">><<set $lowerintegrity -= 10>><<set $anusstate to "entrance">><<set $speechanusentrance to 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<set $rng to random(1, 100)>>
<<if $vagina2 is "clothed">>
<<if $pronoun is "f">>
<<if $enemyarousal gte 40>><span class="blue"><<He>> lifts up <<his>> skirt, revealing <<his>> moistened pussy.</span><<set $vagina2 to 0>>
<</if>>
<<else>>
<<if $enemyarousal gte 40>><span class="blue"><<He>> unzips <<his>> fly, revealing <<his>> moistened pussy.</span><<set $vagina2 to 0>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $vagina2 is "frot">>
<<if $rng gte 101>><span class="blue"><<He>> moves <<his>> clit away and presses <<his>> hungry pussy against your <<penisstop>></span><<set $penisuse to "othervagina">><<set $vagina2 to "penisentrance">><<set $penisstate to "entrance">><<set $speechpenisentrance to 1>>
<<else>>
<<He>> rubs <<his>> clit against your glans.<<sex 5>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $vagina2 is "penis">>
<<if $rng gte 101>><span class="purple"><<He>> moves <<his>> pelvis away, releasing your <<penis>> from <<his>> vagina.</span><<sex 30>><<set $vagina2 to "penisimminent">><<bruise penis>><<violence 1>><<set $penistate to "imminent">><<set $speechpenisimminent to 1>>
<<elseif $rng gte 1>>
<<if $enemyanger gte 100>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
<<His>> continues to fuck your <<peniscomma>> <<his>> movements violent and erratic as <<his>> pussy slides along your length.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues to ride you, your penis helpless as it's fucked.
<<else>>
<<He>> fucks your <<penis>> with rough movements, intent on showing you who's boss.
<</if>>
<<elseif $enemyanger gte 20>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
You feel <<his>> vagina twitch and throb around your length <<he>> fucks you.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues to violate your <<peniscomma>> using you as a sex toy.
<<else>>
<<He>> fucks your <<peniscomma>> taking as much of you into <<his>> vagina as <<he>> can.
<</if>>
<<else>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
<<He>> continues riding your <<peniscomma>> <<his>> vagina rhythmically kneading and squeezing your length. <<His>> body jerks whenever you hit a sensitive spot.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues riding your <<peniscomma>> <<his>> vagina rhythmically kneading and squeezing your length.
<<else>>
<<He>> rides your <<penis>> with steady movements.
<</if>>
<</if>>
<<sex 30>><<bruise penis>><<violence 1>><<set $speechpenispenetrated to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $vagina2 is "penisimminent">>
<<if $rng gte 101>><span class="blue"><<He>> stops pressing <<his>> pussy against your <<penisstop>></span><<set $vagina2 to "penisentrance">><<set $penisstate to "entrance">><<set $speechpenisentrance to 1>>
<<elseif $rng gte 1>>
<<if $nopenile is 0>><<set $penisactiondefault to "take">>
<<if $penilevirginity is 0>><span class="pink"><<He>> eases your <<penis>> into <<his>> pussy, swallowing you to the base.</span><<sex 30>><<set $vagina2 to "penis">><<penilestat>><<bruise penis>><<violence 1>><<raped>><<penisraped>><<set $penisstate to "penetrated">><<set $speechpenispenetrated to 1>>
<<elseif $penilevirginity is 1>><span class="pink"><<He>> eases your virgin penis into <<his>> pussy,</span><span class="red"> separating your foreskin from your glans and forever robbing you of your purity.</span><<sex 100>><<set $vagina2 to "penis">><<set $penilevirginity to 0>><<bruise penis>><<penilestat>><<violence 100>><<raped>><<penisraped>><<set $penisstate to "penetrated">><<set $speechpenisvirgin to 1>>
<</if>>
<<else>>
Respecting your wishes, <<he>> does not envelope your <<penis>> with <<his>> vagina, instead teasing the tip of your glans.<<sex 15>><<set $speechpeniswithhold to 1>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $vagina2 is "penisentrance">>
<<if $rng gte 101>><span class="lblue"><<He>> moves <<his>> pussy away from your <<penisstop>></span><<set $vagina2 to 0>><<set $penisuse to 0>><<set $penisstate to 0>>
<<elseif $rng gte 1>>
<<if $lowervaginaexposed is 0>><<He>> rubs <<his>> pussy against your <<penis>> through your $lowerclothes.<<sex 5>><<set $lowerintegrity -= 10>><<set $speechpenisentrance to 1>>
<<elseif $lowervaginaexposed is 1>><<set $rng to random(1, 100)>>
<<if $undervaginaexposed is 0>><<He>> rubs <<his>> pussy against your <<penis>> through your $underclothes.<<sex 5>><<set $underintegrity -= 10>><<set $speechpenisentrance to 1>>
<<elseif $undervaginaexposed is 1>>
<<if $rng gte 71>>
<<if $nopenile is 1>>
<span class="purple"><<He>> presses <<his>> pussy against your <<penisstop>></span><<sex 20>><<set $vagina2 to "penisimminent">><<set $penisstate to "imminent">><<set $speechpenisimminent to 1>>
<<else>>
<span class="purple"><<He>> presses <<his>> pussy against your <<peniscomma>> preparing to envelope you fully.</span><<sex 20>><<set $vagina2 to "penisimminent">><<set $penisstate to "imminent">><<set $speechpenisimminent to 1>>
<</if>>
<<elseif $rng gte 1>><<He>> teases your <<penis>> with <<his>> labia.<<sex 10>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $vagina2 is "lefthand">>
<<if $rng lte 80>>
<<He>> strokes <<his>> pussy with <<his>> left hand.<<neutral 1>><<set $enemyarousal += 20>>
<<else>>
<span class="blue"><<He>> moves <<his>> left hand away from <<his>> pussy.</span>
<<set $lefthand2 to 0>><<set $vagina2 to 0>>
<</if>>
<</if>>
<<if $vagina2 is "righthand">>
<<if $rng lte 80>>
<<He>> strokes <<his>> pussy with <<his>> right hand.<<neutral 1>><<set $enemyarousal += 20>>
<<else>>
<span class="blue"><<He>> moves <<his>> right hand away from <<his>> pussy.</span>
<<set $righthand2 to 0>><<set $vagina2 to 0>>
<</if>>
<</if>>
<<if $vagina2 is "mouth">>
<<if $enemyanger gte 100>>
<<He>> covers your mouth with <<his>> pussy, making it difficult to breathe.<<violence 3>><<bruise face>><<set $speechvaginamouth to 1>>
<<else>>
<<if $mouthsubmit is 1>>
<<if $rng gte 1>>
<<He>> rubs <<his>> pussy against your lips.
<<if $enemyarousal gte (($enemyarousalmax / 5) * 3)>>
You can taste <<his>> juices.
<</if>>
<<sex 3>><<set $speechvaginamouth to 1>>
<<else>><<He>> moves <<his>> pussy away from your face.<<set $mouthuse to 0>><<set $mouthstate to 0>><<set $vagina2 to 0>>
<</if>>
<<else>>
<<if $rng gte 1>>
<<He>> rubs <<his>> pussy against your lips.
<<if $enemyarousal gte (($enemyarousalmax / 5) * 3)>>
You can taste <<his>> juices.
<</if>>
<<sex 3>><<set $speechvaginamouth to 1>>
<<else>><<He>> moves <<his>> pussy away from your face.<<set $mouthuse to 0>><<set $mouthstate to 0>><<set $vagina2 to 0>>
<</if>>
<</if>>
<</if>>
<</if>>
<<if $vagina2 is "vagina">>
<<if $rng gte 1>>
<<He>> kneads your pussies together.<<sex 20>><<set $speechvaginavagina to 1>>
<<else>>
<span class="lblue"><<He>> moves <<his>> pussy away from yours.</span><<set $vaginause to 0>><<set $vagina2 to 0>>
<</if>>
<</if>>
<<if $vagina2 is "leftarm">>
<<if $rng gte 1>>
<<He>> rubs <<his>> pussy against your fingers.<<submission 2>>
<<else>>
<<He>> moves your hand away from <<his>> pussy.<<set $leftarm to 0>><<set $vagina2 to 0>><<set $leftactiondefault to "leftplay">>
<</if>>
<</if>>
<<if $vagina2 is "rightarm">>
<<if $rng gte 1>>
<<He>> rubs <<his>> pussy against your fingers.<<submission 2>>
<<else>>
<<He>> moves your hand away from <<his>> pussy.<<set $rightarm to 0>><<set $vagina2 to 0>><<set $rightactiondefault to "rightplay">>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $vagina2 is "feet">>
<<if $rng gte 1>>
<<He>> rubs <<his>> pussy against your feet.<<submission 2>>
<<else>>
<<He>> moves your feet away from <<his>> pussy.<<set $feetuse to 0>><<set $vagina2 to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $vagina2 is "footjob">>
<<if $rng gte 101>>
<span class="blue"><<He>> stops pressing <<his>> foot against your <<genitalsstop>></span><<set $vagina2 to 0>>
<<if $penisexist is 1>>
<<set $penisuse to 0>>
<<else>>
<<set $vaginause to 0>>
<</if>>
<<else>>
<<if $penisexist is 1>>
<<He>> presses your penis against your stomach with <<his>> foot and rubs your glans between <<his>> toes.
<<set $speechpenisfoot to 1>><<neutral 5>><<violence 1>>
<<else>>
<<He>> rubs <<his>> foot against your <<pussystop>>
<<set $speechvaginafoot to 1>><<neutral 5>><<violence 1>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $vagina2 is "otherfrot">>
<<if $rng gte 101>><span class="blue"><<He>> shifts <<his>> ass and presses <<his>> anus against your <<penisstop>></span><<set $penisuse to "otheranus">><<set $vagina2 to "otheranusentrance">><<set $penisstate to "otheranusentrance">><<set $speechotheranusentrance to 1>>
<<else>>
<<He>> rubs <<his>> ass against your <<penisstop>><<sex 5>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $vagina2 is "otheranus">>
<<if $rng gte 101>><span class="purple"><<He>> moves <<his>> pelvis away, releasing your <<penis>> from <<his>> anus.</span><<sex 30>><<set $vagina2 to "otheranusimminent">><<bruise penis>><<violence 1>><<set $penisstate to "otheranusimminent">><<set $speechotheranusimminent to 1>>
<<elseif $rng gte 1>>
<<if $enemyanger gte 100>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
<<His>> continues to fuck your <<penis>> with <<his>> ass, <<his>> movements violent and erratic. Fluid from <<his>> pussy drools onto your length.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues to ride you, your penis helpless as it's fucked.
<<else>>
<<He>> fucks your <<penis>> with rough movements, intent on showing you who's boss.
<</if>>
<<elseif $enemyanger gte 20>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
You feel <<his>> ass twitch around your length as <<he>> fucks you.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues to violate your <<peniscomma>> using you as a sex toy.
<<else>>
<<He>> fucks your <<peniscomma>> taking as much of you into <<his>> ass as <<he>> can.
<</if>>
<<else>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
<<He>> continues riding your <<peniscomma>> <<his>> anus rhythmically pounding your length. <<His>> body jerks whenever you hit a sensitive spot.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues riding your <<peniscomma>> <<his>> anus rhythmically pounding your length.
<<else>>
<<He>> rides your <<penis>> with steady movements.
<</if>>
<</if>>
<<sex 30>><<bruise penis>><<violence 1>><<set $speechotheranus to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $vagina2 is "otheranusimminent">>
<<if $rng gte 101>><span class="blue"><<He>> stops pressing <<his>> ass against your <<penisstop>></span><<set $vagina2 to "otheranusentrance">><<set $penisstate to "otheranusentrance">><<set $speechotheranusentrance to 1>>
<<elseif $rng gte 1>>
<<if $nopenile is 0>><<set $penisactiondefault to "take">>
<<if $penilevirginity is 0>><span class="pink"><<He>> eases your <<penis>> into <<his>> ass, swallowing you to the base.</span><<sex 30>><<set $vagina2 to "otheranus">><<penilestat>><<bruise penis>><<violence 1>><<raped>><<penisraped>><<set $penisstate to "otheranus">><<set $speechotheranus to 1>>
<<elseif $penilevirginity is 1>><span class="pink"><<He>> eases your virgin penis into <<his>> ass,</span><span class="red"> separating your foreskin from your glans and forever robbing you of your purity.</span><<sex 100>><<set $vagina2 to "otheranus">><<set $penilevirginity to 0>><<bruise penis>><<penilestat>><<violence 100>><<raped>><<penisraped>><<set $penisstate to "otheranus">><<set $speechpenisvirgin to 1>>
<</if>>
<<else>>
Respecting your wishes, <<he>> does not envelope your <<penis>> with <<his>> ass, instead teasing the tip of your glans.<<sex 15>><<set $speechotheranuswithhold to 1>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $vagina2 is "otheranusentrance">>
<<if $rng gte 101>><span class="lblue"><<He>> moves <<his>> ass away from your <<penisstop>></span><<set $vagina2 to 0>><<set $penisuse to 0>><<set $penisstate to 0>>
<<elseif $rng gte 1>>
<<if $lowervaginaexposed is 0>><<He>> rubs <<his>> ass against your <<penis>> through your $lowerclothes.<<sex 5>><<set $lowerintegrity -= 10>><<set $speechotheranusentrance to 1>>
<<elseif $lowervaginaexposed is 1>><<set $rng to random(1, 100)>>
<<if $undervaginaexposed is 0>><<He>> rubs <<his>> ass against your <<penis>> through your $underclothes.<<sex 5>><<set $underintegrity -= 10>><<set $speechotheranusentrance to 1>>
<<elseif $undervaginaexposed is 1>>
<<if $rng gte 71>>
<<if $nopenile is 1>>
<span class="purple"><<He>> presses <<his>> ass against your <<penisstop>></span><<sex 20>><<set $vagina2 to "otheranusimminent">><<set $penisstate to "otheranusimminent">><<set $speechotheranusimminent to 1>>
<<else>>
<span class="purple"><<He>> presses <<his>> ass against your <<peniscomma>> preparing to take you in fully.</span><<sex 20>><<set $vagina2 to "otheranusimminent">><<set $penisstate to "otheranusimminent">><<set $speechotheranusimminent to 1>>
<</if>>
<<elseif $rng gte 1>><<He>> rubs your <<penis>> between <<his>> cheeks.<<sex 10>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<if $vagina2 is 0>>
<<if $enemyanger + $rng lte 20>><<He>> sways <<his>> hips suggestively.<<neutral 1>><<set $speechvaginaflaunt to 1>>
<<elseif $enemyanger + $rng lte 40>><<He>> twirls on the spot.<<neutral 3>><<set $speechvaginaflaunt to 1>>
<<elseif $enemyanger + $rng lte 50>>
<<if $penisexist is 1>>
<<if $penisuse is 0 and $analdisable is "f">>
<span class="blue"><<He>> straddles you, rubbing <<his>> ass against your <<penisstop>></span><<neutral 5>><<set $penisuse to "otheranus">><<set $vagina2 to "otheranusentrance">><<set $penisstate to "otheranusentrance">><<set $speechotheranusentrance to 1>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 60>><<He>> rubs <<his>> pussy against your thigh.<<neutral 10>>
<<elseif $enemyanger + $rng lte 80 and $lefthand2 is 0>>
<span class="lblue"><<He>> presses <<his>> fingers against <<his>> labia.</span><<neutral 1>><<set $enemyarousal += 10>><<set $vagina2 to "lefthand">><<set $lefthand2 to "othervagina">>
<<elseif $enemyanger + $rng lte 80 and $righthand2 is 0>>
<span class="lblue"><<He>> presses <<his>> fingers against <<his>> labia.</span><<neutral 1>><<set $enemyarousal += 10>><<set $vagina2 to "righthand">><<set $righthand2 to "othervagina">>
<<elseif $enemyanger + $rng lte 80>>
<<He>> rubs <<his>> pussy against your thigh.<<neutral 2>>
<<elseif $enemyanger + $rng lte 100 and $penisuse is 0 and $undervaginaexposed is 1 and $lowervaginaexposed is 1>>
<<set $penisuse to "othervagina">><<set $vagina2 to "penisentrance">><<set $penisstate to "entrance">><span class="blue"><<He>> straddles you, <<his>> pussy hovering close to your <<penisstop>></span>
<<elseif $enemyanger + $rng lte 120 and $penisuse is 0 and $penisexist is 1 and $undervaginaexposed is 1 and $lowervaginaexposed is 1>>
<<set $penisuse to "othervagina">><<set $vagina2 to "penisimminent">><<set $penisstate to "imminent">><span class="purple"><<He>> wraps <<his>> legs around your pelvis, pressing <<his>> pussy against your <<genitalsstop>></span>
<<elseif $enemyanger + $rng lte 120 and $vaginause is 0 and $vaginaexist is 1 and $undervaginaexposed is 1 and $lowervaginaexposed is 1>>
<<set $vaginause to "othervagina">><<set $vagina2 to "vagina">><<sex 20>><<He>> pushes <<his>> pussy against yours.
<<elseif $enemyanger + $rng lte 140>>
<<if $position is "wall">>
<<He>> sits on your protruding <<bottomcomma>> pressing down on you painfully.<<violence 3>>
<<elseif $mouth2 is 0>>
<<He>> rubs <<his>> clit against your face.<<violence 3>>
<<else>>
<<He>> frots against your thigh while squeezing it with <<his>> own.<<violence 3>>
<</if>>
<<elseif $enemyanger + $rng lte 160>><span class="purple"><<He>> presses <<his>> foot against your <<genitalsstop>></span><<neutral 5>><<set $vagina2 to "footjob">>
<<if $penisexist is 1>>
<<set $penisuse to "feet">><<set $speechpenisfoot to 1>>
<<else>>
<<set $vaginause to "feet">><<set $speechvaginafoot to 1>>
<</if>>
<<elseif $enemyanger + $rng lte 180>>
<<if $position is "wall">>
<<He>> kicks you in the <<bottomstop>><<violence 10>><<hitstat>><<bruise bottom>>
<<else>>
<<He>> kicks you in the stomach.<<violence 10>><<hitstat>><<bruise face>>
<</if>>
<<elseif $enemyanger + $rng lte 200 and $mouthuse is 0>>
<<if $pullaway is 1>><<set $pullaway to 0>>
Saliva drips from her pussy.
<<else>>
<<if $position is "wall">>
<<if $penisexist is 1>>
<<He>> kicks your <<penisstop>><<violence 20>><<hitstat>><<bruise penis>><<set $speechbeat to 1>>
<<elseif $vaginaexist is 1>>
<<He>> kicks your <<pussystop>><<violence 20>><<hitstat>><<bruise vagina>><<set $speechbeat to 1>>
<</if>>
<<else>>
<span class="purple"><<He>> wraps <<his>> legs around your head and presses <<his>> pussy against your mouth.</span>
<<submission 5>><<set $mouthuse to "othervagina">><<set $vagina2 to "mouth">><<set $mouthstate to "othervagina">><<violence 3>><<bruise face>><<set $speechvaginamouth to 1>>
<</if>>
<</if>>
<<else>>
<<if $position is "wall">>
<<if $penisexist is 1>>
<<He>> kicks your <<penisstop>><<violence 20>><<hitstat>><<bruise penis>><<set $speechbeat to 1>>
<<elseif $vaginaexist is 1>>
<<He>> kicks your <<pussystop>><<violence 20>><<hitstat>><<bruise vagina>><<set $speechbeat to 1>>
<</if>>
<<else>>
<<He>> kicks you in the face.<<violence 10>><<bruise face>><<set $speechbeat to 1>><<hitstat>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth2 is "thigh">>
<<He>> kisses and licks your thigh.<<neutral 5>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth2 is "bottom">>
<<He>> kisses and licks your <<bottomstop>><<neutral 5>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth2 is "anus">>
<<if $rng gte 101>><span class="purple"><<He>> retracts <<his>> tongue from your anus.</span><<sex 30>><<set $mouth2 to "anusimminent">><<bruise anus>><<violence 1>><<set $anusstate to "othermouthimminent">>
<<elseif $rng gte 1>>
<<if $enemyarousal lte ($enemyarousalmax / 5)>>
<<He>> caresses your anus with <<his>> tongue.<<sex 30>><<bruise anus>><<violence 1>>
<<elseif $enemyarousal lte (($enemyarousalmax / 5) * 2)>>
<<His>> tongue probes inside your <<bottomstop>><<sex 30>><<bruise anus>><<violence 1>>
<<elseif $enemyarousal lte (($enemyarousalmax / 5) * 3)>>
<<He>> circles <<his>> tongue inside your <<bottomstop>><<sex 30>><<bruise anus>><<violence 1>>
<<elseif $enemyarousal lte (($enemyarousalmax / 5) * 4)>>
<<He>> presses <<his>> mouth firmly against your <<bottomcomma>> letting <<him>> push <<his>> tongue deeper into your anus.<<sex 30>><<bruise anus>><<violence 1>>
<<else>>
Repeatedly thrusting and retracting, <<he>> fucks your <<bottom>> with <<his>> tongue.<<sex 30>><<bruise anus>><<violence 1>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth2 is "anusimminent">>
<<if $rng gte 101>><span class="blue"><<He>> stops pressing <<his>> tongue against your anus.</span><<set $mouth2 to "anusentrance">><<set $anusstate to "othermouthentrance">>
<<elseif $rng gte 1>>
<<if $noanal is 0>>
<<if $analvirginity is 0>><span class="pink"><<He>> pushes <<his>> tongue into your anus.</span><<sex 30>><<set $mouth2 to "anus">><<analstat>><<bruise anus>><<violence 1>><<raped>><<set $anusstate to "othermouth">>
<<elseif $analvirginity is 1>><span class="pink"><<He>> pushes <<his>> tongue into your virgin anus,</span><span class="red"> violating you in a way you hadn't conceived of.</span><<sex 100>><<set $mouth2 to "anus">><<set $analvirginity to 0>><<bruise anus>><<analstat>><<violence 100>><<raped>><<set $anusstate to "othermouth">>
<</if>>
<<else>>
Respecting your wishes, <<he>> does not penetrate your <<bottom>> with <<his>> tongue, instead licking your anus.<<sex 15>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth2 is "anusentrance">>
<<if $rng gte 101>><span class="lblue"><<He>> moves <<his>> head away from your <<bottomstop>></span><<set $mouth2 to 0>><<set $anususe to 0>><<set $anusstate to 0>>
<<if $vagina2 is "othermouth">>
<<set $vagina2 to 0>>
<</if>>
<<if $penis2 is "othermouth">>
<<set $penis2 to 0>>
<</if>>
<<elseif $rng gte 1>>
<<if $loweranusexposed is 0>><<He>> circles <<his>> tongue around your anus through your $lowerclothes.<<sex 5>><<set $lowerintegrity -= 10>>
<<elseif $loweranusexposed is 1>><<set $rng to random(1, 100)>>
<<if $underanusexposed is 0>><<He>> circles <<his>> tongue around your anus through your $underclothes.<<sex 5>><<set $underintegrity -= 10>>
<<elseif $underanusexposed is 1>>
<<if $rng gte 71>>
<<if $noanal is 1>>
<span class="purple"><<He>> presses <<his>> tongue against your anus.</span><<sex 20>><<set $mouth2 to "anusimminent">><<set $anusstate to "othermouthimminent">>
<<else>>
<span class="purple"><<He>> presses <<his>> tongue against your anus, preparing to penetrate you.</span><<sex 20>><<set $mouth2 to "anusimminent">><<set $anusstate to "othermouthimminent">>
<</if>>
<<elseif $rng gte 1>><<He>> kisses and licks your <<bottomstop>><<sex 10>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth2 is "vagina">>
<<if $rng gte 101>><span class="purple"><<He>> retracts <<his>> tongue from your <<pussystop>></span><<sex 30>><<set $mouth2 to "vaginaimminent">><<bruise vagina>><<violence 1>><<set $vaginastate to "othermouthimminent">>
<<elseif $rng gte 1>>
<<if $enemyarousal lte ($enemyarousalmax / 5)>>
<<He>> caresses your vagina with <<his>> tongue.<<sex 30>><<bruise vagina>><<violence 1>>
<<elseif $enemyarousal lte (($enemyarousalmax / 5) * 2)>>
<<He>> presses down on your clit with <<his>> teeth while exploring your vagina with <<his>> tongue.<<sex 30>><<bruise vagina>><<violence 1>>
<<elseif $enemyarousal lte (($enemyarousalmax / 5) * 3)>>
<<He>> circles <<his>> tongue around your vagina.<<sex 30>><<bruise vagina>><<violence 1>>
<<elseif $enemyarousal lte (($enemyarousalmax / 5) * 4)>>
<<He>> presses <<his>> mouth firmly against your <<pussycomma>> then pushes <<his>> tongue deeper into your vagina. <<He>> slowly pulls out again, then takes a deep breath.<<sex 30>><<bruise vagina>><<violence 1>>
<<else>>
Repeatedly thrusting and retracting, <<he>> fucks your <<pussy>> with <<his>> tongue.<<sex 30>><<bruise vagina>><<violence 1>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth2 is "vaginaimminent">>
<<if $rng gte 101>><span class="blue"><<He>> stops pressing <<his>> tongue against your <<pussystop>></span><<set $mouth2 to "vaginaentrance">><<set $vaginastate to "othermouthentrance">>
<<elseif $rng gte 1>>
<<if $novaginal is 0>>
<<if $vaginalvirginity is 0>><span class="pink"><<He>> pushes <<his>> tongue between your <<pussy>> lips.</span><<sex 30>><<set $mouth2 to "vagina">><<vaginalstat>><<bruise vagina>><<violence 1>><<raped>><<vaginaraped>><<set $vaginastate to "othermouth">>
<<elseif $vaginalvirginity is 1>><span class="pink"><<He>> pushes <<his>> tongue into your virgin pussy,</span><span class="red"> breaking your hymen and forever robbing you of your purity.</span><<sex 100>><<set $mouth2 to "vagina">><<set $vaginalvirginity to 0>><<bruise vagina>><<vaginalstat>><<violence 100>><<raped>><<vaginaraped>><<set $vaginastate to "othermouth">>
<</if>>
<<else>>
Respecting your wishes, <<he>> does not penetrate your <<pussy>> with <<his>> tongue, instead running <<his>> tongue up and down your labia.<<sex 15>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth2 is "vaginaentrance">>
<<if $rng gte 101>><span class="lblue"><<He>> moves <<his>> head away from your <<pussystop>></span><<set $mouth2 to 0>><<set $vaginause to 0>><<set $vaginastate to 0>>
<<if $vagina2 is "othermouth">>
<<set $vagina2 to 0>>
<</if>>
<<if $penis2 is "othermouth">>
<<set $penis2 to 0>>
<</if>>
<<elseif $rng gte 1>>
<<if $lowervaginaexposed is 0>><<He>> traces the outline of your <<pussy>> with <<his>> tongue through your $lowerclothes.<<sex 5>><<set $lowerintegrity -= 10>>
<<elseif $lowervaginaexposed is 1>><<set $rng to random(1, 100)>>
<<if $undervaginaexposed is 0>><<He>> traces the outline of your <<pussy>> with <<his>> tongue through your $underclothes.<<sex 5>><<set $underintegrity -= 10>>
<<elseif $undervaginaexposed is 1>>
<<if $rng gte 71>>
<<if $novaginal is 1>>
<span class="purple"><<He>> presses <<his>> lips against your <<pussystop>></span><<sex 20>><<set $mouth2 to "vaginaimminent">><<set $vaginastate to "othermouthimminent">>
<<else>>
<span class="purple"><<He>> presses <<his>> lips against your <<pussycomma>> preparing to fuck you with <<his>> tongue.</span><<sex 20>><<set $mouth2 to "vaginaimminent">><<set $vaginastate to "othermouthimminent">>
<</if>>
<<elseif $rng gte 1>><<He>> blows on your clit and runs <<his>> tongue around your labia.<<sex 10>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth2 is "penis">>
<<if $rng gte 101>><span class="purple"><<He>> moves <<his>> head back, releasing your <<penis>> from <<his>> mouth.</span><<sex 30>><<set $mouth2 to "penisimminent">><<bruise penis>><<violence 1>><<set $penisstate to "othermouthimminent">>
<<elseif $rng gte 1>>
<<if $enemyarousal lte ($enemyarousalmax / 5)>>
<<He>> slowly caresses your shaft with <<his>> tongue.<<sex 30>><<bruise penis>><<violence 1>>
<<elseif $enemyarousal lte (($enemyarousalmax / 5) * 2)>>
Eyes fixed on your face, <<he>> wraps <<his>> tongue around your <<penis>> and sucks.<<sex 30>><<bruise penis>><<violence 1>>
<<elseif $enemyarousal lte (($enemyarousalmax / 5) * 3)>>
<<He>> squeezes <<his>> lips around your <<peniscomma>> and circles <<his>> tongue around your glans.<<sex 30>><<bruise penis>><<violence 1>>
<<elseif $enemyarousal lte (($enemyarousalmax / 5) * 4)>>
<<He>> takes you deeper into <<his>> mouth, until your <<penis>> disappears inside <<him>> completely. <<He>> slowly pushes you out again, then takes a deep breath.<<sex 30>><<bruise penis>><<violence 1>>
<<else>>
<<He>> repeatedly swallows and expels your <<peniscomma>> fucking you with <<his>> mouth.<<sex 30>><<bruise penis>><<violence 1>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth2 is "penisimminent">>
<<if $rng gte 101>><span class="blue"><<He>> stops pressing <<his>> lips against your <<penisstop>></span><<set $mouth2 to "penisentrance">><<set $penisstate to "othermouthentrance">>
<<elseif $rng gte 1>>
<<if $nopenile is 0>>
<<if $penilevirginity is 0>><span class="pink"><<He>> pushes <<his>> lips against your <<peniscomma>> taking you into <<his>> mouth.</span><<sex 30>><<set $mouth2 to "penis">><<penilestat>><<bruise penis>><<violence 1>><<raped>><<penisraped>><<set $penisstate to "othermouth">>
<<elseif $penilevirginity is 1>><span class="pink"><<He>> pushes <<his>> lips against your virgin penis, taking you into <<his>> mouth,</span><span class="red"> separating your foreskin from your glans and forever robbing you of your purity.</span><<sex 100>><<set $mouth2 to "penis">><<set $penilevirginity to 0>><<bruise penis>><<penilestat>><<violence 100>><<raped>><<penisraped>><<set $penisstate to "othermouth">>
<</if>>
<<else>>
Respecting your wishes, <<he>> does not envelope your <<penis>> with <<his>> mouth, instead kissing the tip of your glans.<<sex 15>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth2 is "penisentrance">>
<<if $rng gte 101>><span class="lblue"><<He>> moves <<his>> head away from your <<penisstop>></span><<set $mouth2 to 0>><<set $penisuse to 0>><<set $penisstate to 0>>
<<if $vagina2 is "othermouth">>
<<set $vagina2 to 0>>
<</if>>
<<if $penis2 is "othermouth">>
<<set $penis2 to 0>>
<</if>>
<<elseif $rng gte 1>>
<<if $lowervaginaexposed is 0>><<He>> traces the outline of your <<penis>> with <<his>> tongue through your $lowerclothes.<<sex 5>><<set $lowerintegrity -= 10>>
<<elseif $lowervaginaexposed is 1>><<set $rng to random(1, 100)>>
<<if $undervaginaexposed is 0>><<He>> traces the outline of your <<penis>> with <<his>> tongue through your $underclothes.<<sex 5>><<set $underintegrity -= 10>>
<<elseif $undervaginaexposed is 1>>
<<if $rng gte 71>>
<<if $nopenile is 1>>
<span class="purple"><<He>> presses <<his>> lips against your <<penisstop>></span><<sex 20>><<set $mouth2 to "penisimminent">><<set $penisstate to "othermouthimminent">>
<<else>>
<span class="purple"><<He>> presses <<his>> lips against your <<peniscomma>> preparing to take you in <<his>> mouth proper.</span><<sex 20>><<set $mouth2 to "penisimminent">><<set $penisstate to "othermouthimminent">>
<</if>>
<<elseif $rng gte 1>><<He>> blows on and licks the tip of your <<penisstop>><<sex 10>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth2 is "kiss">>
<<if $speechvaginavirgin isnot 1 and $speechpenisvirgin isnot 1 and $speechanusvirgin isnot 1 and $speechmouthvirgin isnot 1>>
<<if $rng gte 101>>
<span class="lblue"><<He>> pulls <<his>> mouth away from yours.</span><<set $mouth2 to 0>><<set $mouthuse to 0>><<set $mouthstate to 0>>
<<else>>
<<if $enemyanger lte 20>>
<<He>> explores your mouth with <<his>> tongue.<<sex 2>>
<<else>>
<<He>> thrusts <<his>> tongue deep into your mouth.<<violence 1>>
<</if>>
<</if>>
<<else>>
<span class="lblue"><<He>> pulls <<his>> mouth away from yours.</span><<set $mouthuse to 0>><<set $mouth2 to 0>><<set $mouthstate to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth2 is "kissimminent">>
<<if $speechvaginavirgin isnot 1 and $speechpenisvirgin isnot 1 and $speechanusvirgin isnot 1 and $speechmouthvirgin isnot 1>>
<<if $rng gte 101>>
<span class="lblue"><<He>> pulls <<his>> mouth away from yours.</span><<set $mouth2 to 0>><<set $mouthuse to 0>><<set $mouthstate to 0>>
<<elseif $rng lte 100>>
<<He>> pushes <<his>> tongue between your lips.<<set $mouth2 to "kiss">><<set $mouthstate to "kiss">><<sex 2>>
<<else>>
<<if $enemyanger lte 20>>
<<He>> gently probes your lips with <<his>> tongue.<<sex 2>>
<<else>>
<<He>> bites and toys with your lips.<<violence 1>>
<</if>>
<</if>>
<<else>>
<span class="lblue"><<He>> pulls <<his>> mouth away from yours.</span><<set $mouthuse to 0>><<set $mouth2 to 0>><<set $mouthstate to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth2 is "kissentrance">>
<<if $speechvaginavirgin isnot 1 and $speechpenisvirgin isnot 1 and $speechanusvirgin isnot 1 and $speechmouthvirgin isnot 1>>
<<if $rng gte 101>>
<span class="lblue"><<He>> pulls <<his>> mouth away from yours.</span><<set $mouth2 to 0>><<set $mouthuse to 0>><<set $mouthstate to 0>>
<<elseif $rng lte 100>>
<<He>> pulls you closer and presses your lips together in a kiss.<<set $mouth2 to "kissimminent">><<set $mouthstate to "kissimminent">><<sex 2>>
<<else>>
<<if $enemyanger lte 20>>
<<He>> gently brushes <<his>> lips against yours.<<sex 1>>
<<else>>
<<He>> bites your lower lip.<<violence 1>>
<</if>>
<</if>>
<<else>>
<span class="lblue"><<He>> pulls <<his>> mouth away from yours.</span><<set $mouthuse to 0>><<set $mouth2 to 0>><<set $mouthstate to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth2 is 0>>
<<if $speechvaginavirgin is 1>>
<<if $enemyanger lte 60>>
<<He>> speaks. "You were a virgin! I can't believe my luck!"
<<else>>
<<He>> speaks. "I felt your hymen tear bitch. Something to remember me by."
<</if>>
<<elseif $speechpenisvirgin is 1>>
<<if $enemyanger lte 60>>
<<He>> speaks. "AHH! This was your first time wasn't it? It feels so good!"
<<else>>
<<He>> speaks. "How's it feel to have your virgin dick broken in? Feels amazing for me."
<</if>>
<<elseif $speechanusvirgin is 1>>
<<if $enemyanger lte 60>>
<<He>> speaks. "It's so tight! This must be the first time your ass has been used like this."
<<else>>
<<He>> speaks. "It's so tight! This must be the first time your ass has been used like this. I've got plenty more work to do before you're properly broken in."
<</if>>
<<elseif $speechmouthvirgin is 1>>
<<if $enemyanger lte 60>>
<<He>> speaks. "Is this the first time you've tasted dick?"
<<else>>
<<He>> speaks. "Is this the first time you've tasted dick? You'll be a cum-addicted cock slave soon."
<</if>>
<<elseif $speechcum is 1 and $rng gte 61 and $speechorgasmrepeat lte 1 and $speechorgasmcount lte 6>>
<<cumspeech>>
<<elseif $rng gte 61>>
<<combatspeech>><<neutral 1>>
<<elseif $rng gte 91>>
<<basespeech>><<neutral 1>>
<<else>>
<<set $rng to random(1, 100)>>
<<if $enemyanger + $rng lte 20>><<He>> <<admires>> your body.<<neutral 1>>
<<elseif $enemyanger + $rng lte 25>>
<<if $position is "wall">>
<<He>> <<admires>> your helpless <<bottomstop>><<neutral 1>>
<<else>>
<<He>> <<admires>> your hair.<<neutral 1>>
<</if>>
<<elseif $enemyanger + $rng lte 30>>
<<if $position is "wall">>
<<He>> <<admires>> your helpless hips.<<neutral 1>>
<<else>>
<<He>> <<admires>> your chest.<<neutral 1>>
<</if>>
<<elseif $enemyanger + $rng lte 35>>
<<He>> <<admires>> your legs.<<neutral 1>>
<<elseif $enemyanger + $rng lte 40>>
<<if $position is "wall">>
<<He>> <<admires>> your helpless legs.<<neutral 1>>
<<else>>
<<He>> <<admires>> your face.<<neutral 1>>
<</if>>
<<elseif $enemyanger + $rng lte 45>>
<<if $position is "wall">>
<<He>> kisses your helpless thighs.<<neutral 3>>
<<else>>
<<He>> kisses you on the forehead.<<neutral 3>>
<</if>>
<<elseif $enemyanger + $rng lte 50>>
<<if $position is "wall">>
<<He>> kisses you on the hips.<<neutral 3>>
<<else>>
<<He>> kisses you on the cheek.<<neutral 3>>
<</if>>
<<elseif $enemyanger + $rng lte 55>>
<<if $position is "wall">>
<<He>> licks your helpless thighs.<<neutral 3>>
<<else>>
<<He>> kisses your neck.<<neutral 3>>
<</if>>
<<elseif $enemyanger + $rng lte 60>>
<<if $position is "wall">>
<<He>> licks your helpless hips.<<neutral 3>>
<<else>>
<<He>> licks your cheek.<<neutral 3>>
<</if>>
<<elseif $enemyanger + $rng lte 80>><<neutral 10>>
<<if $position is "wall">>
<<He>> licks your helpless legs.<<neutral 3>>
<<else>>
<<if $mouthuse is 0>>
<span class="blue"><<He>> moves <<his>> lips close to yours, about to kiss.</span><<set $mouthuse to "kiss">><<set $mouthstate to "kissentrance">><<set $mouth2 to "kissentrance">><<sex 1>>
<<else>>
<<He>> licks your cheek.
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 84>><<neutral 10>>
<<if $anususe is 0 and $vagina2 is 0 and $analdisable is "f">>
<span class="blue"><<He>> kneels behind you. You feel <<his>> breath on your <<bottomstop>></span><<set $anususe to "othermouth">><<set $anusstate to "othermouthentrance">><<set $mouth2 to "anusentrance">><<set $vagina2 to "othermouth">><<sex 1>>
<<elseif $anususe is 0 and $penis2 is 0 and $analdisable is "f">>
<span class="blue"><<He>> kneels behind you. You feel <<his>> breath on your <<bottomstop>></span><<set $anususe to "othermouth">><<set $anusstate to "othermouthentrance">><<set $mouth2 to "anusentrance">><<set $penis2 to "othermouth">><<sex 1>>
<</if>>
<<elseif $enemyanger + $rng lte 92>><<neutral 10>>
<<if $vaginause is 0 and $vagina2 is 0 and $vaginaexist is 1>>
<span class="blue"><<He>> kneels beside you. You feel <<his>> breath on your <<pussystop>></span><<set $vaginause to "othermouth">><<set $vaginastate to "othermouthentrance">><<set $mouth2 to "vaginaentrance">><<set $vagina2 to "othermouth">><<sex 1>>
<<elseif $vaginause is 0 and $penis2 is 0 and $vaginaexist is 1>>
<span class="blue"><<He>> kneels beside you. You feel <<his>> breath on your <<pussystop>></span><<set $vaginause to "othermouth">><<set $vaginastate to "othermouthentrance">><<set $mouth2 to "vaginaentrance">><<set $penis2 to "othermouth">><<sex 1>>
<<else>>
<<He>> breathes on your skin, making your hair stand on end.<<neutral 1>>
<</if>>
<<elseif $enemyanger + $rng lte 100>><<neutral 10>>
<<if $penisuse is 0 and $penis2 is 0 and $penisexist is 1>>
<span class="blue"><<He>> kneels beside you. You feel <<his>> breath on your <<penisstop>></span><<set $penisuse to "othermouth">><<set $penisstate to "othermouthentrance">><<set $mouth2 to "penisentrance">><<set $vagina2 to "othermouth">><<sex 1>>
<<elseif $penisuse is 0 and $vagina2 is 0 and $penisexist is 1>>
<span class="blue"><<He>> kneels beside you. You feel <<his>> breath on your <<penisstop>></span><<set $penisuse to "othermouth">><<set $penisstate to "othermouthentrance">><<set $mouth2 to "penisentrance">><<set $penis2 to "othermouth">><<sex 1>>
<<else>>
<<He>> breathes on your skin, making your hair stand on end.<<neutral 1>>
<</if>>
<<elseif $enemyanger + $rng lte 105>>
<<if $position is "wall">>
<<He>> kisses and caresses your helpless thighs with <<his>> tongue.<<neutral 10>>
<<else>>
<<He>> kisses and caresses your nipple with <<his>> tongue.<<neutral 10>>
<</if>>
<<elseif $enemyanger + $rng lte 110>>
<<if $position is "wall">>
<<He>> kisses and gently bites your helpless <<bottomstop>><<neutral 10>>
<<else>>
<<He>> kisses and gently bites you on the neck.<<neutral 10>>
<</if>>
<<elseif $enemyanger + $rng lte 115>>
<<He>> spits on your <<genitalsstop>><<neutral 5>>
<<elseif $enemyanger + $rng lte 120>>
<<He>> spits on your <<bottomstop>><<neutral 5>>
<<elseif $enemyanger + $rng lte 130>>
<<He>> spits on your stomach.<<neutral 5>>
<<elseif $enemyanger + $rng lte 140>>
<<if $position is "wall">>
<<He>> spits on your helpless thighs.<<neutral 5>>
<<else>>
<<He>> spits on your face.<<neutral 5>>
<</if>>
<<elseif $enemyanger + $rng lte 150>>
<<He>> bites your <<bottomstop>><<violence 10>><<hitstat>><<bruise bottom>>
<<elseif $enemyanger + $rng lte 160>>
<<if $position is "wall">>
<<He>> bites your thighs.<<violence 10>><<hitstat>><<bruise thigh>>
<<else>>
<<He>> bites your shoulders.<<violence 10>><<hitstat>><<bruise leftarm>><<bruise rightarm>>
<</if>>
<<elseif $enemyanger + $rng lte 170>>
<<if $position is "wall">>
<<He>> bites your hips.<<violence 10>><<hitstat>><<bruise tummy>>
<<else>>
<<He>> bites your neck.<<violence 10>><<hitstat>><<bruise neck>>
<</if>>
<<elseif $enemyanger + $rng lte 180>>
<<if $position is "wall">>
<<He>> bites your thighs.<<violence 10>><<hitstat>><<bruise thigh>>
<<else>>
<<He>> bites your cheek.<<violence 10>><<hitstat>><<bruise face>>
<</if>>
<<elseif $enemyanger + $rng gte 190>>
<<if $position is "wall">>
<<He>> bites your <<bottomstop>><<violence 10>><<hitstat>><<bruise bottom>>
<<else>>
<<He>> bites your <<breastsstop>><<violence 10>><<hitstat>><<bruise chest>>
<</if>>
<</if>>
<</if>>
<</if>>
<<manend>>
<<set $pullaway to 0>>
<</nobr>><</widget>>
:: Widgets Combat Man 3 [widget]
<<widget "man3">><<nobr>>
<<if $pronoun3 is "m">>
<<set $pronoun to "m">>
<</if>>
<<if $pronoun3 is "f">>
<<set $pronoun to "f">>
<</if>>
<<if $pronoun3 is "i">>
<<set $pronoun to "i">>
<</if>>
<<if $pronoun3 is "n">>
<<set $pronoun to "n">>
<</if>>
<<if $pronoun3 is "t">>
<<set $pronoun to "t">>
<</if>>
<<man3speech>>
<<set $intro3 to 1>>
<<if $lefthand3 is "spank">><<bruise bottom>><<hitstat>><<set $speechspank to 1>>
<<He>> spanks your <<bottom>>
<<if $lowerclothes isnot "naked" and $lowerstate is "waist">>
through your $lowerclothes.
<<elseif $underclothes isnot "naked" and $understate is "waist">>
through your $underclothes.
<<else>>
reddening your exposed skin.
<</if>>
<<violence 5>>
<</if>>
<<if $righthand3 is "spank">><<bruise bottom>><<hitstat>>
<<He>> spanks your <<bottom>><<set $speechspank to 1>>
<<if $lowerclothes isnot "naked" and $lowerstate is "waist">>
through your $lowerclothes.
<<elseif $underclothes isnot "naked" and $understate is "waist">>
through your $underclothes.
<<else>>
reddening your exposed skin.
<</if>>
<<violence 5>>
<</if>>
<<if $lefthand3 is "arms">>
<<if $enemytrust gte 20 and $enemyanger lte 20>><span class="lblue"><<He>> releases your arms.</span><<set $lefthand3 to 0>><<set $leftarm to 0>><<set $rightarm to 0>>
<<else>><<He>> grips your arms.
<<violence 6>><<bruise leftarm>><<bruise rightarm>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand3 is "arms">>
<<if $enemytrust gte 20 and $enemyanger lte 20>><span class="lblue"><<He>> releases your arms.</span><<set $righthand3 to 0>><<set $leftarm to 0>><<set $rightarm to 0>>
<<else>><<He>> grips your arms.
<<violence 6>><<bruise leftarm>><<bruise rightarm>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand3 is "leftarm">>
<<if $enemytrust gte 20 and $enemyanger lte 20>><span class="lblue"><<He>> releases your left arm.</span><<set $lefthand3 to 0>><<set $leftarm to 0>>
<<else>><<He>> grips your left arm.<<violence 3>><<bruise leftarm>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand3 is "leftarm">>
<<if $enemytrust gte 20 and $enemyanger lte 20>><span class="lblue"><<He>> releases your left arm.</span><<set $righthand3 to 0>><<set $leftarm to 0>>
<<else>><<He>> grips your left arm.<<violence 3>><<bruise leftarm>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand3 is "rightarm">>
<<if $enemytrust gte 20 and $enemyanger lte 20>><span class="lblue"><<He>> releases your right arm.</span><<set $lefthand3 to 0>><<set $rightarm to 0>>
<<else>><<He>> grips your right arm.<<violence 3>><<bruise rightarm>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand3 is "rightarm">>
<<if $enemytrust gte 20 and $enemyanger lte 20>><span class="lblue"><<He>> releases your right arm.</span><<set $righthand3 to 0>><<set $rightarm to 0>>
<<else>><<He>> grips your right arm.<<violence 3>><<bruise rightarm>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand3 is "vaginaentrance">>
<<if $rng gte 101>><span class="blue"><<He>> moves <<his>> left hand away from your <<pussystop>></span><<set $lefthand3 to 0>><<set $vaginause to 0>>
<<elseif $rng gte 81>><<He>> <<strokes>> your labia.<<neutral 10>>
<<elseif $rng gte 21>><<He>> gives your clitoris a tweak.<<set $speechclit to 1>><<neutral 10>>
<<elseif $rng lte 20>><span class="pink"><<He>> plunges a finger into your <<pussystop>></span><<neutral 15>><<set $lefthand3 to "vagina">><<set $speechvagina to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand3 is "vaginaentrance">>
<<if $rng gte 101>><span class="blue"><<He>> moves <<his>> right hand away from your <<pussystop>></span><<set $righthand3 to 0>><<set $vaginause to 0>>
<<elseif $rng gte 51>><<He>> <<strokes>> your labia.<<neutral 10>>
<<elseif $rng gte 21>><<He>> gives your clitoris a tweak.<<neutral 10>><<set $speechclit to 1>>
<<elseif $rng lte 20>><span class="pink"><<He>> plunges a finger into your warm <<pussystop>></span><<neutral 15>><<set $righthand3 to "vagina">><<set $speechvagina to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand3 is "penisentrance">>
<<if $rng gte 101>><span class="blue"><<He>> moves <<his>> left hand away from your <<penisstop>></span><<set $lefthand3 to 0>><<set $penisuse to 0>>
<<elseif $rng gte 51>><<He>> <<strokes>> your shaft.<<neutral 10>>
<<elseif $rng gte 21>><<He>> rubs your glans.<<neutral 10>><<set $speechglans to 1>>
<<elseif $rng lte 20>><span class="pink"><<He>> wraps <<his>> fingers around your <<penisstop>></span><<neutral 15>><<set $lefthand3 to "penis">><<set $speechpenis to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand3 is "penisentrance">>
<<if $rng gte 101>><span class="blue"><<He>> moves <<his>> right hand away from your <<penisstop>></span><<set $righthand3 to 0>><<set $penisuse to 0>>
<<elseif $rng gte 51>><<He>> <<strokes>> your shaft.<<neutral 10>>
<<elseif $rng gte 21>><<He>> rubs your glans.<<neutral 10>><<set $speechglans to 1>>
<<elseif $rng lte 20>><span class="pink"><<He>> wraps <<his>> fingers around your penis.</span><<neutral 15>><<set $righthand3 to "penis">><<set $speechpenis to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand3 is "vagina">>
<<if $rng gte 101>><span class="purple"><<He>> slides <<his>> finger out of your <<pussystop>></span><<set $lefthand3 to "vaginaentrance">><<neutral 15>>
<<elseif $rng lte 100>><<He>> <<strokes>> the inside of your <<pussycomma>><<neutral 20>><<set $speechvagina to 1>>
<<if $arousal gte 8000>>
causing involuntary shudders.
<<elseif $arousal gte 2000>>
coaxing out lewd fluid.
<<else>>
eager to explore it.
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand3 is "vagina">>
<<if $rng gte 101>><span class="purple"><<He>> slides <<his>> finger out of your <<pussystop>></span><<set $righthand3 to "vaginaentrance">><<neutral 15>>
<<elseif $rng lte 100>><<He>> <<strokes>> the inside of your <<pussycomma>><<neutral 20>><<set $speechvagina to 1>>
<<if $arousal gte 8000>>
causing you involuntary shudders.
<<elseif $arousal gte 2000>>
coaxing out lewd fluid.
<<else>>
invading your body in a most sordid manner.
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand3 is "penis">>
<<if $rng gte 101>><span class="purple"><<He>> releases your <<penis>> from <<his>> grip.</span><<set $lefthand3 to "penisentrance">><<neutral 15>>
<<elseif $rng lte 100>><<He>> massages the length of your <<peniscomma>><<neutral 20>><<set $speechpenis to 1>>
<<if $arousal gte 8000>>
causing you involuntary shudders.
<<elseif $arousal gte 2000>>
coaxing out lewd fluid.
<<else>>
exploiting your body's natural reactions in a most sordid manner.
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand3 is "penis">>
<<if $rng gte 101>><span class="purple"><<He>> releases your <<penis>> from <<his>> grip.</span><<set $righthand3 to "penisentrance">><<neutral 15>>
<<elseif $rng lte 100>><<He>> massages the length of your <<peniscomma>><<neutral 20>><<set $speechpenis to 1>>
<<if $arousal gte 8000>>
causing you involuntary shudders.
<<elseif $arousal gte 2000>>
coaxing out lewd fluid.
<<else>>
exploiting your body's natural reactions in a most sordid manner.
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand3 is "anusentrance">>
<<if $rng gte 101>><span class="blue"><<He>> moves <<his>> left hand away from your ass.</span><<set $lefthand3 to 0>><<set $vaginause to 0>>
<<elseif $rng gte 21>><<He>> <<strokes>> your anus.<<neutral 10>>
<<elseif $rng lte 20>><span class="pink"><<He>> plunges a finger into your ass.</span><<neutral 15>><<set $lefthand3 to "anus">><<set $speechanus to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand3 is "anusentrance">>
<<if $rng gte 101>><span class="blue"><<He>> moves <<his>> hand away from your ass.</span><<set $righthand3 to 0>><<set $vaginause to 0>>
<<elseif $rng gte 21>><<He>> <<strokes>> your anus.<<neutral 10>>
<<elseif $rng lte 20>><span class="pink"><<He>> plunges a finger into your ass.</span><<neutral 15>><<set $righthand3 to "anus">><<set $speechanus to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand3 is "anus">>
<<if $rng gte 101>><span class="purple"><<He>> slides <<his>> finger out of your ass.</span><<set $lefthand3 to "anusentrance">><<neutral 15>>
<<elseif $rng lte 100>><<He>> rhythmically slides <<his>> finger in and out of your ass,<<neutral 20>><<set $speechanus to 1>>
<<if $playergender is "m">>
teasing your prostate.
<<else>>
teasing your anus.
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand3 is "anus">>
<<if $rng gte 101>><span class="purple"><<He>> slides <<his>> finger out of your ass.</span><<set $righthand3 to "anusentrance">><<neutral 15>>
<<elseif $rng lte 100>><<He>> rhythmically slides <<his>> finger in and out of your ass,<<neutral 20>><<set $speechanus to 1>>
<<if $playergender is "m">>
teasing your prostate.
<<else>>
teasing your anus.
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand3 is "mouth">>
<<if $enemyanger lte 20 and $enemytrust gte 20>><span class="teal">Made confident by your accommodating behaviour, <<he>> releases <<his>> hand from your mouth.</span><<set $lefthand3 to 0>><<set $mouthuse to 0>>
<<else>><<He>> continues to clasp your mouth shut.<<violence 1>><<bruise face>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand3 is "mouth">>
<<if $enemyanger lte 20 and $enemytrust gte 20>><span class="teal">Made confident by your accommodating behaviour, <<he>> releases <<his>> hand from your mouth.</span><<set $righthand3 to 0>><<set $mouthuse to 0>>
<<else>><<He>> continues to clasp your mouth shut.<<violence 1>><<bruise face>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand3 is "throat">>
<<if $enemyanger gte 100>><<set $strangle += 1>>
<<if $strangle is 0>><<He>> strangles your throat.<<violence 5>><<bruise neck>><<bruise neck>><<set $speechthroat to 1>>
<<elseif $strangle lte 2>><span class="purple"><<He>> strangles your throat. You can't breathe!</span><<set $speechthroat to 1>>
<<violence 10>><<bruise neck>><<bruise neck>>
<<elseif $strangle lte 4>><span class="pink"><<He>> strangles your throat. You feel light-headed.</span><<set $speechthroat to 1>>
<<violence 20>><<bruise neck>><<bruise neck>>
<<elseif $strangle lte 6>><span class="pink"><<He>> strangles your throat. You see stars.</span><<set $speechthroat to 1>>
<<violence 40>><<bruise neck>><<bruise neck>>
<<elseif $strangle gte 8>><span class="red"><<He>> strangles your throat. You are suffocating.</span><<set $speechthroat to 1>>
<<violence 100>><<bruise neck>><<bruise neck>>
<</if>>
<<elseif $rng gte 81>><span class="teal"><<He>> releases <<his>> hand from your throat.</span> You gasp for air.
<<set $lefthand3 to 0>>
<<else>><<He>> holds you down by your throat.<<violence 1>>
<</if>><<bruise neck>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand3 is "throat">>
<<if $enemyanger gte 100>><<set $strangle += 1>>
<<if $strangle is 0>><<He>> strangles your throat.<<violence 5>><<bruise neck>><<bruise neck>><<set $speechthroat to 1>>
<<elseif $strangle lte 2>><<He>> strangles your throat. <span class="purple">You can't breathe!</span><<set $speechthroat to 1>>
<<violence 10>><<bruise neck>><<bruise neck>>
<<elseif $strangle lte 4>><<He>> strangles your throat. <span class="pink">You feel light-headed.</span><<set $speechthroat to 1>>
<<violence 20>><<bruise neck>><<bruise neck>>
<<elseif $strangle lte 6>><<He>> strangles your throat. <span class="pink">You see stars.</span> <<set $speechthroat to 1>>
<<violence 40>><<bruise neck>><<bruise neck>>
<<elseif $strangle gte 7>><<He>> strangles your throat. <span class="red">You are suffocating.</span><<set $speechthroat to 1>>
<<violence 100>><<bruise neck>><<bruise neck>>
<</if>>
<<elseif $rng gte 81>><span class="teal"><<He>> releases <<his>> hand from your throat.</span> You gasp for air.
<<set $righthand3 to 0>>
<<else>><<He>> holds you down by your throat.<<violence 1>>
<</if>><<bruise neck>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand3 is "underclothes" and $undertype is "chastity">>
<span class="blue"><<He>> tries to loosen your $underclothes.</span> <<His>> rough handling leaves you feeling more frustrated and aroused. <<He>> gives up after a few moments of impotent tugging, looking disappointed.<<neutral 1>><<set $enemyanger += 5>><<set $arousal += 5>><<set $lefthand3 to 0>><<set $speechchastity to 1>><<set $underintegrity -= 10>>
<</if>>
<<if $righthand3 is "underclothes" and $undertype is "chastity">>
<span class="blue"><<He>> tries to loosen your $underclothes.</span> <<His>> rough handling leaves you feeling more frustrated and aroused.<<He>> gives up after a few moments of impotent tugging, looking disappointed.<<neutral 1>><<set $enemyanger += 5>><<set $arousal += 5>><<set $righthand3 to 0>><<set $speechchastity to 1>><<set $underintegrity -= 10>>
<</if>>
<<if $lefthand3 is "underclothes">>
<<if $underclothes is "naked">><span class="purple"><<He>> casts aside the fabric.</span><<set $lefthand3 to 0>>
<<elseif $understruggle is 1>>You manage to keep <<him>> from pulling down your $underclothes.<<set $understruggle to 0>><<set $speechstripstruggle to 1>>
<<elseif $rng gte 101>><span class="blue"><<He>> releases <<his>> hand from your $underclothes.</span><<set $lefthand3 to 0>>
<<elseif $rng lte 100>>
<<if $skirt is 1>>
<<if $understate is "waist">><<He>> pulls your $underclothes down your thighs, <span class="lewd">revealing your <<genitalsstop>></span><<set $understate to "thighs">><<neutral 5>><<set $undervaginaexposed to 1>><<set $underanusexposed to 1>><<set $underexposed to 1>><<set $speechgenitals to 1>>
<<elseif $understate is "thighs">><<He>> pulls your $underclothes down to your knees.<<set $understate to "knees">><<neutral 1>>
<<elseif $understate is "knees">><<He>> pulls your $underclothes down to your ankles.<<set $understate to "ankles">><<neutral 1>>
<<elseif $understate is "ankles">><span class="purple"><<He> pulls your $underclothes off your legs.</span><<understrip>><<undernaked>><<neutral 3>><<set $lefthand3 to 0>><<clothesstripstat>>
<</if>>
<<elseif $lowerstate isnot "waist">>
<<if $understate is "waist">><<He>> pulls your $underclothes down your thighs, <span class="lewd">revealing your <<genitalsstop>></span><<set $understate to "thighs">><<neutral 5>><<set $undervaginaexposed to 1>><<set $underanusexposed to 1>><<set $underexposed to 1>><<set $speechgenitals to 1>>
<<elseif $understate is "thighs">><<He>> pulls your $underclothes down to your knees.<<set $understate to "knees">><<neutral 1>>
<<elseif $understate is "knees">><<He>> pulls your $underclothes down to your ankles.<<set $understate to "ankles">><<neutral 5>>
<<elseif $understate is "ankles">><span class="purple"><<He>> pulls your $underclothes off your legs.</span><<understrip>><<undernaked>><<neutral 3>><<set $lefthand3 to 0>><<clothesstripstat>>
<</if>>
<<else>><<He>> tugs on your $underclothes.<<neutral 1>><<set $underintegrity -= 10>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand3 is "underclothes">>
<<if $underclothes is "naked">><span class="purple"><<He>> casts aside the fabric.</span><<set $righthand3 to 0>>
<<elseif $understruggle is 1>>You manage to keep <<him>> from pulling down your $underclothes.<<set $understruggle to 0>><<set $speechstripstruggle to 1>>
<<elseif $rng gte 101>><span class="purple"><<He>> releases <<his>> hand from your $underclothes.</span><<set $righthand3 to 0>><<set $skirtuse to 0>>
<<elseif $rng lte 100>>
<<if $skirt is 1>>
<<if $understate is "waist">><<He>> pulls your $underclothes down your thighs, <span class="lewd">revealing your <<genitalsstop>></span><<set $understate to "thighs">><<neutral 5>><<set $undervaginaexposed to 1>><<set $underanusexposed to 1>><<set $underexposed to 1>><<set $speechgenitals to 1>>
<<elseif $understate is "thighs">><<He>> pulls your $underclothes down to your knees.<<set $understate to "knees">><<neutral 1>>
<<elseif $understate is "knees">><<He>> pulls your $underclothes down to your ankles.<<set $understate to "ankles">><<neutral 1>>
<<elseif $understate is "ankles">><span class="purple"><<He>> pulls your $underclothes off your legs.</span><<understrip>><<undernaked>><<neutral 3>><<set $righthand3 to 0>><<clothesstripstat>>
<</if>>
<<elseif $lowerstate isnot "waist">>
<<if $understate is "waist">><<He>> pulls your $underclothes down your thighs, <span class="lewd">revealing your <<genitalsstop>></span><<set $understate to "thighs">><<neutral 5>><<set $undervaginaexposed to 1>><<set $underanusexposed to 1>><<set $underexposed to 1>><<set $speechgenitals to 1>>
<<elseif $understate is "thighs">><<He>> pulls your $underclothes down to your knees.<<set $understate to "knees">><<neutral 1>>
<<elseif $understate is "knees">><<He>> pulls your $underclothes down to your ankles.<<set $understate to "ankles">><<neutral 5>>
<<elseif $understate is "ankles">><span class="purple"><<He>> pulls your $underclothes off your legs.</span><<understrip>><<undernaked>><<neutral 3>><<set $righthand3 to 0>><<clothesstripstat>>
<</if>>
<<else>><<He>> tugs on your $underclothes.<<neutral 1>><<set $underintegrity -= 10>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand3 is "hair">>
<<if $rng gte 101>><span class="lblue"><<He>> releases <<his>> hand from your hair.</span><<set $lefthand3 to 0>>
<<elseif $enemyanger gte 61>>With your hair in <<his>> grip, <<he>> yanks back your head.<<violence 4>><<set $speechhair to 1>>
<<elseif $enemyanger gte 21>>
<<He>> strokes your hair while holding it bunched in <<his>> grip.<<set $speechhair to 1>><<neutral 1>>
<<else>><span class="lblue"><<He>> releases <<his>> hand from your hair.</span><<set $lefthand3 to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand3 is "hair">>
<<if $rng gte 101>><span class="lblue"><<He>> releases <<his>> hand from your hair.</span><<set $righthand3 to 0>>
<<elseif $enemyanger gte 61>>With your hair in <<his>> grip, <<he>> yanks back your head.<<violence 4>><<set $speechhair to 1>>
<<elseif $enemyanger gte 21>>
<<He>> strokes your hair while holding it bunched in <<his>> grip.<<set $speechhair to 1>><<neutral 1>>
<<else>><span class="lblue"><<He>> releases <<his>> hand from your hair.</span><<set $righthand3 to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand3 is "lowerclothes">>
<<if $lowerclothes is "naked">><span class="purple"><<He>> casts aside the fabric.</span><<set $lefthand3 to 0>>
<<elseif $lowerstruggle is 1>><<set $lowerstruggle to 0>>You manage to keep <<him>> from stripping you of your $lowerclothes.<<set $speechstripstruggle to 1>>
<<elseif $rng gte 101>><<He>> releases <<his>> hand from your
$lowerclothes.<<set $lefthand3 to 0>>
<<elseif $rng lte 100>>
<<if $skirt is 1>>
<<if $skirtdown is 1>><<He>> lifts up your skirt,
exposing your
<<if $understate is "waist">>$underclothes.<<neutral 2>>
<<else>><span class="lewd"><<genitalsstop>></span><<neutral 5>><<set $speechgenitals to 1>>
<</if>><<set $skirtdown to 0>><<set $lowervaginaexposed to 1>><<set $loweranusexposed to 1>><<set $lowerexposed to 2>>
<<elseif $skirtdown is 0>>
<<if $lowerset is $upperset>>
<<if $upperstate is "waist">>
<<if $position is "wall">>
<<He>> tugs at your $upperclothes, tearing <<upperit>> before <span class="blue">letting go.</span><<set $lefthand3 to 0>><<neutral 1>><<set $lowerintegrity -= 10>>
<<else>>
<<He>> lifts your $upperclothes above your midriff.<<set $lowerstate to "midriff">><<set $upperstate to "midriff">><<neutral 1>>
<<if $upperstatetop is "waist">>
<<set $upperstatetop to "midriff">>
<</if>>
<</if>>
<<elseif $upperstate is "midriff">><<He>> lifts up your $upperclothes, <span class="lewd">exposing your <<breastsstop>></span><<set $lowerstate to "chest">><<set $upperstate to "chest">><<neutral 2>><<set $upperexposed to 2>><<set $speechbreasts to 1>>
<<if $upperstatetop is "midriff">>
<<set $upperstatetop to "chest">>
<</if>>
<<elseif $upperstate is "chest">><span class="purple"><<He>> pulls your $upperclothes off completely.</span><<lowerstrip>><<upperstrip>><<set $lowerstate to 0>><<set $upperstate to 0>><<uppernaked>><<lowernaked>><<set $lefthand3 to 0>><<neutral 3>><<clothesstripstat>>
<<if $upperstatetop is "chest">>
<<set $upperstatetop to 0>>
<</if>>
<</if>>
<<elseif $lowerset isnot $upperset>>
<<if $lowerstate is "waist">><<He>> pulls your $lowerclothes down to your thighs.
<<neutral 1>><<set $lowerstate to "thighs">>
<<elseif $lowerstate is "thighs">><<He>> pulls your $lowerclothes down to your knees.<<set $lowerstate to "knees">><<neutral 1>>
<<elseif $lowerstate is "knees">><<He>> pulls your $lowerclothes down to your ankles.<<set $lowerstate to "ankles">><<neutral 1>>
<<elseif $lowerstate is "ankles">><span class="purple"><<He>> completely pulls your $lowerclothes off your legs.</span><<lowerstrip>><<lowernaked>><<set $lefthand3 to 0>><<neutral 3>><<clothesstripstat>>
<</if>>
<</if>>
<</if>>
<<elseif $upperset is $lowerset>>
<<if $open is 1>>
<<if $upperstatetop is "chest">><<He>> tugs your $lowerclothes, pulling down your $upperclothes and <span class="lewd">revealing your <<breastsstop>></span><<set $upperstatetop to "midriff">><<neutral 3>><<set $upperexposed to 2>><<set $speechbreasts to 1>>
<<if $upperstate is "chest">>
<<set $upperstate to "midriff">>
<</if>>
<<if $lowerstate is "chest">>
<<set $lowerstate to "midriff">>
<</if>>
<<elseif $upperstatetop is "midriff">><<He>> tugs your $lowerclothes, pulling down your $upperclothes passed your midriff.<<set $upperstatetop to "waist">><<neutral 1>>
<<if $upperstate is "midriff">>
<<set $upperstate to "waist">>
<</if>>
<<if $lowerstate is "midriff">>
<<set $lowerstate to "waist">>
<</if>>
<<elseif $upperstatetop is "waist">><<He>> pulls your $upperclothes down to your thighs, revealing your
<<if $understate is "waist">>$underclothes<<neutral 2>>
<<else>><span class="lewd"><<genitalsstop>></span><<neutral 5>><<set $speechgenitals to 1>>
<</if>>
<<set $lowervaginaexposed to 1>><<set $loweranusexposed to 1>>
<<set $upperstatetop to "thighs">>
<<set $upperstate to "thighs">>
<<if $lowerstate is "waist">>
<<set $lowerstate to "thighs">>
<</if>>
<<elseif $upperstatetop is "thighs">><<He>> pulls your $upperclothes down to your knees.<<set $upperstatetop to "knees">><<set $upperstate to "knees">><<neutral 1>>
<<if $lowerstate is "thighs">>
<<set $lowerstate to "knees">>
<</if>>
<<elseif $upperstatetop is "knees">><<He>> pulls your $upperclothes down to your ankles.<<set $upperstatetop to "ankles">><<set $upperstate to "ankles">><<neutral 1>>
<<if $lowerstate is "knees">>
<<set $lowerstate to "ankles">>
<</if>>
<<elseif $upperstatetop is "ankles">><span class="purple"><<He>> pulls your $upperclothes off the bottom of your legs.</span><<upperstrip>><<neutral 5>><<set $upperstatetop to 0>><<set $upperstate to 0>><<uppernaked>>
<<if $lowerstate is "ankles">>
<<set $lowerstate to 0>><<lowerstrip>><<lowernaked>>
<</if>>
<</if>>
<<else>>
<<He>> tugs at your $lowerclothes, tearing <<lowerit>> before <span class="blue">letting go.</span><<set $lefthand3 to 0>><<set $lowerintegrity -= 10>><<neutral 1>>
<</if>>
<<elseif $upperset isnot $lowerset>>
<<if $lowerstate is "waist">><<He>> pulls down your $lowerclothes, exposing your
<<if $understate is "waist">>$underclothes.<<neutral 2>><<set $lowervaginaexposed to 1>><<set $loweranusexposed to 1>><<set $lowerexposed to 2>>
<<else>><span class="lewd"><<genitalsstop>></span><<neutral 5>><<set $speechgenitals to 1>>
<</if>>
<<set $lowervaginaexposed to 1>><<set $loweranusexposed to 1>><<set $lowerexposed to 2>>
<<set $lowerstate to "thighs">>
<<elseif $lowerstate is "thighs">><<He>> pulls your $lowerclothes down to your knees.<<set $lowerstate to "knees">><<neutral 1>>
<<elseif $lowerstate is "knees">><<He>> pulls your $lowerclothes down to your ankles.<<set $lowerstate to "ankles">><<neutral 1>>
<<elseif $lowerstate is "ankles">><span class="purple"><<He>> completely pulls your $lowerclothes off your legs.</span><<lowerstrip>><<lowernaked>><<set $lefthand3 to 0>><<neutral 3>><<clothesstripstat>>
<</if>>
<<else>><<He>> tugs at your $lowerclothes, tearing <<lowerit>> before <span class="blue">letting go.</span><<set $lefthand3 to 0>><<neutral 1>><<set $lowerintegrity -= 10>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand3 is "lowerclothes">>
<<if $lowerclothes is "naked">><span class="purple"><<He>> casts aside the fabric.</span><<set $righthand3 to 0>>
<<elseif $lowerstruggle is 1>><<set $lowerstruggle to 0>>You manage to keep <<him>> from stripping you of your $lowerclothes.<<set $speechstripstruggle to 1>>
<<elseif $rng gte 101>><span class="lblue"><<He>> releases <<his>> hand from your
$lowerclothes.</span><<set $righthand3 to 0>>
<<elseif $rng lte 100>>
<<if $skirt is 1>>
<<if $skirtdown is 1>><<He>> lifts up your skirt,
exposing your
<<if $understate is "waist">>$underclothes.<<neutral 2>>
<<else>><span class="lewd"><<genitalsstop>></span><<neutral 5>><<set $speechgenitals to 1>>
<</if>><<set $skirtdown to 0>><<set $lowervaginaexposed to 1>><<set $loweranusexposed to 1>><<set $lowerexposed to 2>>
<<elseif $skirtdown is 0>>
<<if $lowerset is $upperset>>
<<if $upperstate is "waist">>
<<if $position is "wall">>
<<He>> tugs at your $upperclothes, tearing <<upperit>> before <span class="blue">letting go.</span><<set $righthand3 to 0>><<neutral 1>><<set $lowerintegrity -= 10>>
<<else>>
<<He>> lifts your $upperclothes above your midriff.<<set $lowerstate to "midriff">><<set $upperstate to "midriff">><<neutral 1>>
<<if $upperstatetop is "waist">>
<<set $upperstatetop to "midriff">>
<</if>>
<</if>>
<<elseif $upperstate is "midriff">><<He>> lifts up your $upperclothes, <span class="lewd">exposing your <<breastsstop>></span><<set $lowerstate to "chest">><<set $upperstate to "chest">><<neutral 2>><<set $upperexposed to 2>><<set $speechbreasts to 1>>
<<if $upperstatetop is "midriff">>
<<set $upperstatetop to "chest">>
<</if>>
<<elseif $upperstate is "chest">><span class="purple"><<He>> pulls your $upperclothes off completely.</span><<set $lowerstate to 0>><<set $upperstate to 0>><<lowerstrip>><<upperstrip>><<uppernaked>><<lowernaked>><<set $righthand3 to 0>><<neutral 3>><<clothesstripstat>>
<<if $upperstatetop is "chest">>
<<set $upperstatetop to 0>>
<</if>>
<</if>>
<<elseif $lowerset isnot $upperset>>
<<if $lowerstate is "waist">><<He>> pulls your $lowerclothes down to your thighs.
<<neutral 1>><<set $lowerstate to "thighs">>
<<elseif $lowerstate is "thighs">><<He>> pulls your $lowerclothes down to your knees.<<set $lowerstate to "knees">><<neutral 1>>
<<elseif $lowerstate is "knees">><<He>> pulls your $lowerclothes down to your ankles.<<set $lowerstate to "ankles">><<neutral 1>>
<<elseif $lowerstate is "ankles">><span class="purple"><<He>> pulls your $lowerclothes off your legs.</span><<lowerstrip>><<lowernaked>><<set $righthand3 to 0>><<neutral 3>><<clothesstripstat>>
<</if>>
<</if>>
<</if>>
<<elseif $upperset is $lowerset>>
<<if $open is 1>>
<<if $upperstatetop is "chest">><<He>> tugs your $lowerclothes, pulling down your $upperclothes and <span class="lewd">revealing your <<breastsstop>></span><<set $upperstatetop to "midriff">><<neutral 3>><<set $upperexposed to 2>><<set $speechbreasts to 1>>
<<if $upperstate is "chest">>
<<set $upperstate to "midriff">>
<</if>>
<<if $lowerstate is "chest">>
<<set $lowerstate to "midriff">>
<</if>>
<<elseif $upperstatetop is "midriff">><<He>> tugs your $lowerclothes, pulling down your $upperclothes pass your midriff.<<set $upperstatetop to "waist">><<neutral 1>>
<<if $upperstate is "midriff">>
<<set $upperstate to "waist">>
<</if>>
<<if $lowerstate is "midriff">>
<<set $lowerstate to "waist">>
<</if>>
<<elseif $upperstatetop is "waist">><<He>> pulls your $upperclothes down to your thighs, revealing your
<<if $understate is "waist">>$underclothes<<neutral 2>>
<<else>><span class="lewd"><<genitalsstop>></span><<neutral 5>><<set $speechgenitals to 1>>
<</if>>
<<set $lowervaginaexposed to 1>><<set $loweranusexposed to 1>><<set $lowerexposed to 2>>
<<set $upperstatetop to "thighs">><<set $upperstate to "thighs">>
<<if $lowerstate is "waist">>
<<set $lowerstate to "thighs">>
<</if>>
<<elseif $upperstatetop is "thighs">><<He>> pulls your $upperclothes down to your knees.<<set $upperstatetop to "knees">><<set $upperstate to "knees">><<neutral 1>>
<<if $lowerstate is "thighs">>
<<set $lowerstate to "knees">>
<</if>>
<<elseif $upperstatetop is "knees">><<He>> pulls your $upperclothes down to your ankles.<<set $upperstatetop to "ankles">><<set $upperstate to "ankles">><<neutral 1>>
<<if $lowerstate is "knees">>
<<set $lowerstate to "ankles">>
<</if>>
<<elseif $upperstatetop is "ankles">><span class="purple"><<He>> pulls your $upperclothes off the bottom of your legs.</span><<upperstrip>><<neutral 5>><<set $upperstatetop to 0>><<set $upperstate to 0>><<uppernaked>>
<<if $lowerstate is "ankles">>
<<set $lowerstate to 0>><<lowerstrip>><<lowernaked>>
<</if>>
<</if>>
<<else>>
<<He>> tugs at your $lowerclothes, tearing <<lowerit>> before <span class="blue">letting go.</span><<set $righthand3 to 0>><<set $lowerintegrity -= 10>><<neutral 1>>
<</if>>
<<elseif $upperset isnot $lowerset>>
<<if $lowerstate is "waist">><<He>> pulls down your $lowerclothes, exposing your
<<if $understate is "waist">>$underclothes.<<neutral 2>><<set $lowervaginaexposed to 1>><<set $loweranusexposed to 1>>
<<else>><span class="lewd"><<genitalsstop>></span><<neutral 5>><<set $speechgenitals to 1>>
<</if>>
<<set $lowervaginaexposed to 1>><<set $loweranusexposed to 1>><<set $lowerexposed to 2>>
<<set $lowerstate to "thighs">>
<<elseif $lowerstate is "thighs">><<He>> pulls your $lowerclothes down to your knees.<<set $lowerstate to "knees">><<neutral 1>>
<<elseif $lowerstate is "knees">><<He>> pulls your $lowerclothes down to your ankles.<<set $lowerstate to "ankles">><<neutral 1>>
<<elseif $lowerstate is "ankles">><span class="purple"><<He>> pulls your $lowerclothes off your legs.</span><<lowerstrip>><<lowernaked>><<set $righthand3 to 0>><<neutral 3>><<clothesstripstat>>
<</if>>
<<else>><<He>> tugs at your $lowerclothes, tearing <<lowerit>> before <span class="blue">letting go.</span><<set $righthand3 to 0>><<neutral 1>><<set $lowerintegrity -= 10>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand3 is "upperclothes">>
<<if $upperclothes is "naked">><span class="purple"><<He>> casts aside the fabric.</span><<set $lefthand3 to 0>>
<<elseif $upperstruggle is 1>><<set $upperstruggle to 0>>You manage to keep <<him>> from stripping you of your $upperclothes.<<set $speechstripstruggle to 1>>
<<elseif $rng gte 101>><span class="lblue"><<He>> releases <<his>> hand from your $upperclothes.</span><<set $lefthand3 to 0>>
<<elseif $rng lte 100>>
<<if $upperset isnot $lowerset>>
<<if $open is 1>>
<<if $upperstatetop is "chest">><<He>> pulls down your $upperclothes, <span class="lewd">revealing your <<breastsstop>></span><<set $upperstatetop to "midriff">><<neutral 3>><<set $upperexposed to 2>><<set $speechbreasts to 1>>
<<if $upperstate is "chest">>
<<set $upperstate to "midriff">>
<</if>>
<<elseif $upperstatetop is "midriff">><<He>> pulls your $upperclothes down past your midriff.<<set $upperstatetop to "waist">><<neutral 1>>
<<if $upperstate is "midriff">>
<<set $upperstate to "waist">>
<</if>>
<<elseif $upperstatetop is "waist">><<He>> pulls your $upperclothes down to your thighs.
<<set $upperstatetop to "thighs">>
<<set $upperstate to "thighs">>
<<elseif $upperstatetop is "thighs">><<He>> pulls your $upperclothes down to your knees.<<set $upperstatetop to "knees">><<set $upperstate to "knees">><<neutral 1>>
<<elseif $upperstatetop is "knees">><<He>> pulls your $upperclothes down to your ankles.<<set $upperstatetop to "ankles">><<set $upperstate to "ankles">><<neutral 1>>
<<elseif $upperstatetop is "ankles">><span class="purple"><<He>> pulls your $upperclothes off the bottom of your legs.</span><<upperstrip>><<neutral 5>><<set $upperstatetop to 0>><<set $upperstate to 0>><<uppernaked>><<set $lefthand3 to 0>>
<</if>>
<<elseif $open is 0>>
<<if $position is "wall">>
<<He>> tugs at your $upperclothes, tearing <<upperit>> before <span class="blue">letting go.</span><<set $lefthand3 to 0>><<set $upperintegrity -= 10>><<neutral 1>>
<<elseif $position isnot "wall">>
<<if $upperstate is "waist">><<He>> lifts up your $upperclothes, exposing your midriff.<<set $upperstate to "midriff">><<neutral 1>>
<<elseif $upperstate is "midriff">><<He>> lifts up your $upperclothes, <span class="lewd">exposing your <<breastsstop>></span><<set $upperstate to "chest">><<neutral 2>><<set $upperexposed to 2>><<set $speechbreasts to 1>>
<<elseif $upperstate is "chest">><span class="purple"><<He>> removes your $upperclothes completely.</span><<upperstrip>><<uppernaked>><<set $lefthand3 to 0>><<neutral 3>><<clothesstripstat>>
<</if>>
<</if>>
<</if>>
<<elseif $upperset is $lowerset>>
<<if $open is 1>>
<<if $lowerstate is $upperstatetop and $lowerstate is $upperstate and $skirt is 1>>
<<if $position is "wall">>
<<He>> tugs at your $upperclothes, tearing <<upperit>> before <span class="blue">letting go.</span><<set $lefthand3 to 0>><<set $upperintegrity -= 10>><<neutral 1>>
<<elseif $position isnot "wall">>
<<if $upperstate is "waist">><<He>> pulls your bundled $upperclothes up past your midriff.<<set $upperstate to "midriff">><<neutral 1>>
<<set $lowerstate to "midriff">>
<<set $upperstatetop to "midriff">>
<<elseif $upperstate is "midriff">><<He>> pulls your bundled $upperclothes up past your <<breastsstop>><<set $upperstate to "chest">><<neutral 2>><<set $upperexposed to 2>><<set $speechbreasts to 1>>
<<set $lowerstate to "chest">>
<<set $upperstatetop to "chest">>
<<elseif $upperstate is "chest">><span class="purple"><<He>> pulls your $upperclothes off your body.</span><<upperstrip>><<uppernaked>><<set $lefthand3 to 0>><<neutral 3>><<clothesstripstat>>
<</if>>
<</if>>
<<else>>
<<if $upperstatetop is "chest">><<He>> pulls down the top of your $upperclothes, <span class="lewd">revealing your <<breastsstop>></span><<set $upperstatetop to "midriff">><<neutral 2>><<set $upperexposed to 2>><<set $speechbreasts to 1>>
<<if $upperstate is "chest">>
<<set $upperstate to "midriff">>
<</if>>
<<if $lowerstate is "chest">>
<<set $lowerstate to "midriff">>
<</if>>
<<elseif $upperstatetop is "midriff">><<He>> pulls your $upperclothes down past your midriff.<<set $upperstatetop to "waist">><<neutral 1>>
<<if $upperstate is "midriff">>
<<set $upperstate to "waist">>
<</if>>
<<if $lowerstate is "midriff">>
<<set $lowerstate to "waist">>
<</if>>
<<elseif $upperstatetop is "waist">><<He>> pulls your $upperclothes down to your thighs, revealing your
<<if $understate is "waist">>$underclothes<<neutral 2>>
<<else>><span class="lewd"><<genitalsstop>></span><<neutral 5>><<set $speechgenitals to 1>>
<</if>>
<<set $lowervaginaexposed to 1>><<set $loweranusexposed to 1>><<set $lowerexposed to 2>>
<<set $upperstatetop to "thighs">>
<<set $upperstate to "thighs">>
<<if $lowerstate is "waist">>
<<set $lowerstate to "thighs">>
<</if>>
<<elseif $upperstatetop is "thighs">><<He>> pulls your $upperclothes down to your knees.<<set $upperstatetop to "knees">><<set $upperstate to "knees">><<neutral 1>>
<<if $lowerstate is "thighs">>
<<set $lowerstate to "knees">>
<</if>>
<<elseif $upperstatetop is "knees">><<He>> pulls your $upperclothes down to your ankles.<<set $upperstatetop to "ankles">><<set $upperstate to "ankles">><<neutral 1>>
<<if $lowerstate is "knees">>
<<set $lowerstate to "ankles">>
<</if>>
<<elseif $upperstatetop is "ankles">><span class="purple"><<He>> pulls your $upperclothes off the bottom of your legs.</span><<upperstrip>><<neutral 5>><<set $upperstatetop to 0>><<set $upperstate to 0>><<uppernaked>><<set $lefthand3 to 0>>
<<if $lowerstate is "ankles">>
<<set $lowerstate to 0>><<lowerstrip>><<lowernaked>>
<</if>>
<</if>>
<</if>>
<<else>><<He>> tugs at your $upperclothes, tearing <<upperit>> before <span class="blue">letting go.</span><<set $lefthand3 to 0>><<set $upperintegrity -= 10>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random (1, 100)>>
<<if $righthand3 is "upperclothes">>
<<if $upperclothes is "naked">><span class="purple"><<He>> casts aside the fabric.</span><<set $righthand3 to 0>>
<<elseif $upperstruggle is 1>><<set $upperstruggle to 0>>You manage to keep <<him>> from stripping you of your $upperclothes.<<set $speechstripstruggle to 1>>
<<elseif $rng gte 101>><span class="lblue"><<He>> releases <<his>> hand from your $upperclothes.</span><<set $righthand3 to 0>>
<<elseif $rng lte 100>>
<<if $upperset isnot $lowerset>>
<<if $open is 1>>
<<if $upperstatetop is "chest">><<He>> pulls down your $upperclothes, <span class="lewd">revealing your <<breastsstop>></span><<set $upperstatetop to "midriff">><<neutral 3>><<set $upperexposed to 2>><<set $speechbreasts to 1>>
<<if $upperstate is "chest">>
<<set $upperstate to "midriff">>
<</if>>
<<elseif $upperstatetop is "midriff">><<He>> pulls your $upperclothes down past your midriff.<<set $upperstatetop to "waist">><<neutral 1>>
<<if $upperstate is "midriff">>
<<set $upperstate to "waist">>
<</if>>
<<elseif $upperstatetop is "waist">><<He>> pulls your $upperclothes down to your thighs.
<<set $upperstatetop to "thighs">>
<<set $upperstate to "thighs">>
<<elseif $upperstatetop is "thighs">><<He>> pulls your $upperclothes down to your knees.<<set $upperstatetop to "knees">><<set $upperstate to "knees">><<neutral 1>>
<<elseif $upperstatetop is "knees">><<He>> pulls your $upperclothes down to your ankles.<<set $upperstatetop to "ankles">><<set $upperstate to "ankles">><<neutral 1>>
<<elseif $upperstatetop is "ankles">><span class="purple"><<He>> pulls your $upperclothes off the bottom of your legs.</span><<upperstrip>><<neutral 5>><<set $upperstatetop to 0>><<set $upperstate to 0>><<uppernaked>><<set $righthand3 to 0>>
<</if>>
<<elseif $open is 0>>
<<if $position is "wall">>
<<He>> tugs at your $upperclothes, tearing <<upperit>> before <span class="blue">letting go.</span><<set $righthand3 to 0>><<set $upperintegrity -= 10>><<neutral 1>>
<<elseif $position isnot "wall">>
<<if $upperstate is "waist">><<He>> lifts up your $upperclothes, exposing your midriff.<<set $upperstate to "midriff">><<neutral 1>>
<<elseif $upperstate is "midriff">><<He>> lifts up your $upperclothes, <span class="lewd">exposing your <<breastsstop>></span><<set $upperstate to "chest">><<neutral 2>><<set $upperexposed to 2>><<set $speechbreasts to 1>>
<<elseif $upperstate is "chest">><span class="purple"><<He>> removes your $upperclothes completely.</span><<upperstrip>><<uppernaked>><<set $righthand3 to 0>><<neutral 3>><<clothesstripstat>>
<</if>>
<</if>>
<</if>>
<<elseif $upperset is $lowerset>>
<<if $open is 1>>
<<if $lowerstate is $upperstatetop and $lowerstate is $upperstate and $skirt is 1>>
<<if $position is "wall">>
<<He>> tugs at your $upperclothes, tearing <<upperit>> before <span class="blue">letting go.</span><<set $righthand3 to 0>><<set $upperintegrity -= 10>><<neutral 1>>
<<elseif $position isnot "wall">>
<<if $upperstate is "waist">><<He>> pulls your bundled $upperclothes up past your midriff.<<set $upperstate to "midriff">><<neutral 1>>
<<set $lowerstate to "midriff">>
<<set $upperstatetop to "midriff">>
<<elseif $upperstate is "midriff">><<He>> pulls your bundled $upperclothes up past your <<breastsstop>><<set $upperstate to "chest">><<neutral 2>><<set $upperexposed to 2>><<set $speechbreasts to 1>>
<<set $lowerstate to "chest">>
<<set $upperstatetop to "chest">>
<<elseif $upperstate is "chest">><span class="purple"><<He>> pulls your $upperclothes off your body.</span><<upperstrip>><<uppernaked>><<set $righthand3 to 0>><<neutral 3>><<clothesstripstat>>
<</if>>
<</if>>
<<else>>
<<if $upperstatetop is "chest">><<He>> pulls down the top of your $upperclothes, <span class="lewd">revealing your <<breastsstop>></span><<set $upperstatetop to "midriff">><<set $upperexposed to 2>><<neutral 2>><<set $speechbreasts to 1>>
<<if $upperstate is "chest">>
<<set $upperstate to "midriff">>
<</if>>
<<if $lowerstate is "chest">>
<<set $lowerstate to "midriff">>
<</if>>
<<elseif $upperstatetop is "midriff">><<He>> pulls your $upperclothes down past your midriff.<<set $upperstatetop to "waist">><<neutral 1>>
<<if $upperstate is "midriff">>
<<set $upperstate to "waist">>
<</if>>
<<if $lowerstate is "midriff">>
<<set $lowerstate to "waist">>
<</if>>
<<elseif $upperstatetop is "waist">><<He>> pulls your $upperclothes down to your thighs, revealing your
<<if $understate is "waist">>$underclothes<<neutral 2>>
<<else>><span class="lewd"><<genitalsstop>></span><<neutral 5>><<set $speechgenitals to 1>>
<</if>>
<<set $lowervaginaexposed to 1>><<set $loweranusexposed to 1>><<set $lowerexposed to 2>>
<<set $upperstatetop to "thighs">>
<<set $upperstate to "thighs">>
<<if $lowerstate is "waist">>
<<set $lowerstate to "thighs">>
<</if>>
<<elseif $upperstatetop is "thighs">><<He>> pulls your $upperclothes down to your knees.<<set $upperstatetop to "knees">><<set $upperstate to "knees">><<neutral 1>>
<<if $lowerstate is "thighs">>
<<set $lowerstate to "knees">>
<</if>>
<<elseif $upperstatetop is "knees">><<He>> pulls your $upperclothes down to your ankles.<<set $upperstatetop to "ankles">><<set $upperstate to "ankles">><<neutral 1>>
<<if $lowerstate is "knees">>
<<set $lowerstate to "ankles">>
<</if>>
<<elseif $upperstatetop is "ankles">><span class="purple"><<He>> pulls your $upperclothes off the bottom of your legs.</span><<upperstrip>><<neutral 5>><<set $upperstatetop to 0>><<set $upperstate to 0>><<uppernaked>><<set $righthand3 to 0>>
<<if $lowerstate is "ankles">>
<<set $lowerstate to 0>><<lowerstrip>><<lowernaked>>
<</if>>
<</if>>
<</if>>
<<else>><<He>> tugs at your $upperclothes, tearing <<upperit>> before <span class="blue">letting go.</span><<set $righthand3 to 0>><<set $upperintegrity -= 10>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand3 is 0>>
<<if $enemyanger + $rng lte 20>>
<<if $lowerclothes isnot "naked">><span class="purple"><<He>> grasps your $lowerclothes.</span><<set $lefthand3 to "lowerclothes">><<neutral 1>>
<<elseif $vaginaexist is 1>>
<<He>> <<strokes>> your inner thigh and brushes <<his>> fingers against your clit.<<neutral 10>><<set $speechclit to 1>>
<<elseif $penisexist is 1>>
<<He>> <<strokes>> your inner thigh and brushes <<his>> fingers against your <<glansstop>><<neutral 10>><<set $speechglans to 1>>
<</if>>
<<elseif $enemyanger + $rng lte 30>>
<<if $position is "wall">>
<<if $lowerclothes isnot "naked">><span class="purple"><<He>> grasps your $lowerclothes.</span><<set $lefthand3 to "lowerclothes">><<neutral 1>>
<<elseif $vaginaexist is 1>>
<<He>> <<strokes>> your inner thigh and brushes <<his>> fingers against your clit.<<neutral 10>><<set $speechclit to 1>>
<<elseif $penisexist is 1>>
<<He>> <<strokes>> your inner thigh and brushes <<his>> fingers against your <<glansstop>><<neutral 10>><<set $speechglans to 1>>
<</if>>
<<else>>
<<if $upperclothes isnot "naked">><span class="purple"><<He>> grasps your $upperclothes.</span><<set $lefthand3 to "upperclothes">><<neutral 1>>
<<else>><<He>> <<strokes>> your chest, <<his>> fingers lingering around your nipple.<<neutral 4>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 35>>
<<if $skirt is 1>>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $lefthand3 to "underclothes">><<neutral 1>>
<<elseif $underanusexposed is 1>>
<<if $loweranusexposed is 1>>
<<if $anususe is 0 and $analdisable is "f">><span class="purple"><<He>> presses <<his>> left hand against your <<bottomstop>></span><<set $lefthand3 to "anusentrance">><<set $anususe to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<<elseif $lowerclothes isnot "waist">>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $lefthand3 to "underclothes">><<neutral 1>>
<<elseif $underanusexposed is 1>>
<<if $loweranusexposed is 1>>
<<if $anususe is 0 and $analdisable is "f">><span class="purple"><<He>> presses <<his>> left hand against your <<bottomstop>></span><<set $lefthand3 to "anusentrance">><<set $anususe to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 40>>
<<if $skirt is 1>>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $lefthand3 to "underclothes">><<neutral 1>>
<<elseif $undervaginaexposed is 1>>
<<if $lowervaginaexposed is 1>>
<<if $vaginaexist is 1>>
<<if $vaginause is 0>><span class="purple"><<He>> presses <<his>> left hand against your <<pussycomma>> resting a finger on your entrance.</span><<set $lefthand3 to "vaginaentrance">><<set $vaginause to 1>><<neutral 1>>
<</if>>
<<elseif $penisexist is 1>>
<<if $penisuse is 0>><span class="purple"><<He>> presses <<his>> left hand against your <<penisstop>></span><<set $lefthand3 to "penisentrance">><<set $penisuse to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $lowerclothes isnot "waist">>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $lefthand3 to "underclothes">><<neutral 1>>
<<elseif $undervaginaexposed is 1>>
<<if $lowervaginaexposed is 1>>
<<if $vaginaexist is 1>>
<<if $vaginause is 0>>
<span class="purple"><<He>> presses <<his>> left hand against your <<pussycomma>> resting a finger on your entrance.</span><<set $lefthand3 to "vaginaentrance">><<set $vaginause to 1>><<neutral 1>>
<</if>>
<<elseif $penisexist is 1>>
<<if $penisuse is 0>><span class="purple"><<He>> presses <<his>> left hand against your <<penisstop>></span><<set $lefthand3 to "penisentrance">><<set $penisuse to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 45>>
<<if $position is "wall">>
<<He>> leans against the wall.
<<else>>
<<He>> caresses your tummy.<<neutral 1>>
<</if>>
<<elseif $enemyanger + $rng lte 50>>
<<if $position is "wall">>
<<He>> grips your thigh and pulls, but you're stuck firm.<<neutral 1>>
<<else>>
<<He>> <<strokes>> your hair.<<neutral 1>>
<</if>>
<<elseif $enemyanger + $rng lte 60>>
<<if $position is "wall">>
<<He>> pulls your leg, but you're stuck firm.<<neutral 1>>
<<elseif $uppertype isnot "naked" and $upperstate isnot "chest" and $upperstatetop is "chest">>
<<He>> <<strokes>> your <<breasts>> through your $upperclothes.<<neutral 2>>
<<else>>
<<He>> <<strokes>> your exposed <<breastsstop>><<neutral 4>>
<</if>>
<<elseif $enemyanger + $rng lte 80>><<set $speechbottom to 1>>
<<if $lowerstate is "waist" and $skirt is 0>>
<<He>> fondles your <<bottom>> through your $lowerclothes.<<neutral 2>>
<<elseif $understate is "waist">>
<<He>> fondles your <<bottom>> through your $underclothes.<<neutral 2>>
<<else>>
<<He>> gropes and squeezes your exposed <<bottomstop>><<neutral 4>>
<</if>>
<<elseif $enemyanger + $rng lte 100>>
<<if $penisexist is 1>>
<<if $lowerstate is "waist" and $skirt is 0>>
<<He>> fondles and <<strokes>> your <<penis>> through your $lowerclothes.<<neutral 5>>
<<elseif $understate is "waist">>
<<He>> fondles and <<strokes>> your <<penis>> through your $underclothes.<<neutral 5>>
<<elseif $penisuse is 0>>
<<He>> fondles and <<strokes>> your exposed <<penisstop>><<neutral 10>>
<<else>>
<<He>> fondles and <<strokes>> your <<testiclesstop>><<neutral 10>>
<</if>>
<<elseif $vaginaexist is 1>>
<<if $lowerstate is "waist" and $skirt is 0>>
<<He>> fondles and <<strokes>> your labia through your $lowerclothes.<<neutral 5>>
<<elseif $understate is "waist">>
<<He>> fondles and <<strokes>> your labia through your $underclothes.<<neutral 5>>
<<else>>
<<He>> fondles and <<strokes>> your exposed <<pussystop>><<neutral 10>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 110>>
<<if $lowerclothes isnot "naked">><span class="purple"><<He>> grasps your $lowerclothes.</span><<set $lefthand3 to "lowerclothes">><<neutral 1>>
<<elseif $vaginaexist is 1>><<He>> pinches your clitoris.<<neutral 15>><<bruise vagina>><<set $speechclit to 1>>
<<elseif $penisexist is 1>>
<<if $penisuse is 0>>
<<He>> pinches your glans.<<neutral 15>><<bruise penis>><<set $speechglans to 1>>
<<else>>
<<He>> pinches your shaft.<<neutral 10>><<bruise penis>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 120>>
<<if $position is "wall">>
<<He>> smacks your thigh.<<violence 1>><<bruise thigh>><<hitstat>>
<<else>>
<<if $upperclothes isnot "naked">><span class="purple"><<He>> grasps your $upperclothes.</span><<set $lefthand3 to "upperclothes">><<neutral 1>>
<<else>><span class="purple"><<He>> grabs your throat.</span><<violence 2>><<set $lefthand3 to "throat">>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 125>>
<<if $skirt is 1>>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $lefthand3 to "underclothes">><<neutral 1>>
<<elseif $underanusexposed is 1>>
<<if $loweranusexposed is 1>>
<<if $anususe is 0 and $analdisable is "f">><span class="purple"><<He>> presses <<his>> left hand against your <<bottomstop>></span><<set $lefthand3 to "anusentrance">><<set $anususe to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<<elseif $lowerclothes isnot "waist">>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $lefthand3 to "underclothes">><<neutral 1>>
<<elseif $underanusexposed is 1>>
<<if $loweranusexposed is 1>>
<<if $anususe is 0 and $analdisable is "f">><span class="purple"><<He>> presses <<his>> left hand against your <<bottomstop>></span><<set $lefthand3 to "anusentrance">><<set $anususe to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 130>>
<<if $skirt is 1>>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $lefthand3 to "underclothes">><<neutral 1>>
<<elseif $undervaginaexposed is 1>>
<<if $lowervaginaexposed is 1>>
<<if $vaginaexist is 1>>
<<if $vaginause is 0>><span class="purple"><<He>> presses <<his>> left hand against your <<pussycomma>> <<his>> finger resting on your entrance.</span><<set $lefthand3 to "vaginaentrance">><<set $vaginause to 1>><<neutral 1>>
<</if>>
<<elseif $penisexist is 1>>
<<if $penisuse is 0>><span class="purple"><<He>> presses <<his>> left hand against your <<penisstop>></span><<set $lefthand3 to "penisentrance">><<set $penisuse to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $lowerclothes isnot "waist">>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $lefthand3 to "underclothes">><<neutral 1>>
<<elseif $undervaginaexposed is 1>>
<<if $lowervaginaexposed is 1>>
<<if $vaginaexist is 1>>
<<if $vaginause is 0>>
<span class="purple"><<He>> presses <<his>> left hand against your <<pussycomma>> <<his>> finger resting on your entrance.</span><<set $lefthand3 to "vaginaentrance">><<set $vaginause to 1>><<neutral 1>>
<</if>>
<<elseif $penisexist is 1>>
<<if $penisuse is 0>><span class="purple"><<He>> presses <<his>> left hand against your <<penisstop>></span><<set $lefthand3 to "penisentrance">><<set $penisuse to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 140>>
<<if $position is "wall">>
<<He>> smacks your <<bottomstop>><<violence 1>><<bruise bottom>><<hitstat>>
<<else>>
<<He>> seizes your hair with <<his>> left hand.<<set $lefthand3 to "hair">><<violence 2>><<set $speechhair to 1>>
<</if>>
<<elseif $enemyanger + $rng lte 160 and $lefthand3 isnot "arms" and $righthand3 isnot "arms" and $leftarm isnot "bound" and $rightarm isnot "bound">>
<span class="purple"><<He>> pins down your arms.</span><<set $lefthand3 to "arms">><<set $leftarm to "grappled">><<set $rightarm to "grappled">><<disablearms>><<violence 2>><<bruise leftarm>><<bruise rightarm>><<set $speecharms to 1>>
<<if $vaginause is "cover">><<set $vaginause to 0>>
<</if>>
<<if $vaginause is "cover">><<set $vaginause to 0>>
<</if>>
<<if $anususe is "cover">><<set $anususe to 0>>
<</if>>
<<if $anususe is "cover">><<set $anususe to 0>>
<</if>>
<<if $penisuse is "cover">><<set $penisuse to 0>>
<</if>>
<<if $penisuse is "cover">><<set $penisuse to 0>>
<</if>>
<<elseif $enemyanger + $rng lte 160>><<He>> digs <<his>> nails into your <<bottom>> while groping, giving no heed to you comfort.<<violence 10>><<bruise bottom>><<hitstat>><<set $speechspank to 1>>
<<elseif $enemyanger + $rng lte 175>><<He>> slaps your <<bottomstop>><<violence 10>><<bruise bottom>><<hitstat>><<set $speechspank to 1>>
<<elseif $enemyanger + $rng lte 180>><<He>> smacks your thighs.<<violence 10>><<bruise thigh>><<hitstat>><<set $speechbeat to 1>>
<<elseif $enemyanger + $rng lte 185>>
<<if $position is "wall">>
<<He>> punches your thigh.<<bruise thigh>><<hitstat>><<violence 10>><<set $speechbeat to 1>>
<<else>>
<<He>> punches your tummy.<<violence 20>><<bruise tummy>><<hitstat>><<set $speechbeat to 1>>
<</if>>
<<elseif $enemyanger + $rng lte 190>>
<<if $position is "wall">>
<<He>> slaps your <<bottomstop>><<violence 20>><<bruise bottom>><<hitstat>><<set $speechbeat to 1>>
<<else>>
<<He>> slaps your <<breastsstop>><<violence 20>><<bruise chest>><<hitstat>><<set $speechbeat to 1>>
<</if>>
<<elseif $enemyanger + $rng gte 191>>
<<if $position is "wall">>
<<if $penisexist is 1>>
<<He>> scratches your helpless <<bottomstop>><<violence 20>><<bruise bottom>><<hitstat>><<set $speechbeat to 1>>
<<elseif $vaginaexist is 1>>
<<He>> scratches your helpless <<bottomstop>><<violence 20>><<bruise bottom>><<hitstat>><<set $speechbeat to 1>>
<</if>>
<<else>>
<<set $rng to random(1, 100)>>
<<if $rng gte 81>>
<<He>> punches your nose.<<violence 20>><<bruise face>><<hitstat>><<set $speechbeat to 1>>
<<elseif $rng gte 61>>
<<He>> punches the back of your neck.<<violence 20>><<bruise neck>><<hitstat>><<set $speechbeat to 1>>
<<elseif $rng gte 41>>
<<He>> punches your cheek.<<violence 20>><<bruise face>><<hitstat>><<set $speechbeat to 1>>
<<elseif $rng gte 21>>
<<He>> punches your jaw.<<violence 20>><<bruise face>><<hitstat>><<set $speechbeat to 1>>
<<else>>
<<He>> jabs the front of your neck.<<violence 20>><<bruise neck>><<hitstat>><<set $speechbeat to 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand3 is 0>>
<<if $enemyanger + $rng lte 20>>
<<if $lowerclothes isnot "naked">><span class="purple"><<He>> grasps your $lowerclothes.</span><<set $righthand3 to "lowerclothes">><<neutral 1>>
<<elseif $vaginaexist is 1>><<He>> <<strokes>> your pubic mound and teases your clit.<<neutral 10>><<set $speechclit to 1>>
<<elseif $penisexist is 1>>
<<He>> <<strokes>> your <<testicles>> and teases your glans.<<neutral 10>><<set $speechglans to 1>>
<</if>>
<<elseif $enemyanger + $rng lte 30>>
<<if $position is "wall">>
<<if $lowerclothes isnot "naked">><span class="purple"><<He>> grasps your $lowerclothes.</span><<set $righthand3 to "lowerclothes">><<neutral 1>>
<<elseif $vaginaexist is 1>><<He>> runs <<his>> hand up your thigh and <<strokes>> your clit.<<neutral 10>><<set $speechclit to 1>>
<<elseif $penisexist is 1>><<He>> runs <<his>> hand up your thigh and <<strokes>> your <<glansstop>><<neutral 10>><<set $speechglans to 1>>
<</if>>
<<else>>
<<if $upperclothes isnot "naked">><span class="purple"><<He>> grasps your $upperclothes.</span><<set $righthand3 to "upperclothes">><<neutral 1>>
<<else>><<He>> <<strokes>> your chest and teases your nipple.<<neutral 4>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 35>>
<<if $skirt is 1>>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $righthand3 to "underclothes">><<neutral 1>>
<<elseif $underanusexposed is 1>>
<<if $loweranusexposed is 1>>
<<if $anususe is 0 and $analdisable is "f">><span class="purple"><<He>> presses <<his>> right hand against your <<bottomstop>></span><<set $righthand3 to "anusentrance">><<set $anususe to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<<elseif $lowerclothes isnot "waist">>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $righthand3 to "underclothes">><<neutral 1>>
<<elseif $underanusexposed is 1>>
<<if $loweranusexposed is 1>>
<<if $anususe is 0 and $analdisable is "f">><span class="purple"><<He>> presses <<his>> right hand against your <<bottomstop>></span><<set $righthand3 to "anusentrance">><<set $anususe to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 40>>
<<if $skirt is 1>>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $righthand3 to "underclothes">><<neutral 1>>
<<elseif $undervaginaexposed is 1>>
<<if $lowervaginaexposed is 1>>
<<if $vaginaexist is 1>>
<<if $vaginause is 0>>
<span class="purple"><<He>> presses <<his>> right hand against your <<pussycomma>> resting a finger on your entrance.</span><<set $righthand3 to "vaginaentrance">><<set $vaginause to 1>><<neutral 1>>
<</if>>
<<elseif $penisexist is 1>>
<<if $penisuse is 0>><span class="purple"><<He>> presses <<his>> right hand against your <<penisstop>></span><<set $righthand3 to "penisentrance">><<set $penisuse to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $lowerclothes isnot "waist">>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $righthand3 to "underclothes">><<neutral 1>>
<<elseif $undervaginaexposed is 1>>
<<if $lowervaginaexposed is 1>>
<<if $vaginaexist is 1>>
<<if $vaginause is 0>>
<span class="purple"><<He>> presses <<his>> right hand against your <<pussycomma>> resting a finger above your entrance.</span><<set $righthand3 to "vaginaentrance">><<set $vaginause to 1>><<neutral 1>>
<</if>>
<<elseif $penisexist is 1>>
<<if $penisuse is 0>>
<span class="purple"><<He>> presses <<his>> right hand against your <<penisstop>></span><<set $righthand3 to "penisentrance">><<set $penisuse to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 45>>
<<if $position is "wall">>
<<He>> rests <<his>> right hand against the wall.
<<else>>
<<He>> <<strokes>> your tummy with <<his>> right hand.<<neutral 1>>
<</if>>
<<elseif $enemyanger + $rng lte 50>>
<<if $position is "wall">>
<<He>> pushes your <<bottomcomma>> making sure you're stuck firm.<<neutral 1>>
<<else>>
<<He>> <<strokes>> your cheek.<<neutral 1>>
<</if>>
<<elseif $enemyanger + $rng lte 60>>
<<if $position is "wall">>
<<He>> tugs on your leg, but you're stuck firm.<<neutral 1>>
<<elseif $uppertype isnot "naked" and $upperstate isnot "chest" and $upperstatetop is "chest">>
<<He>> gropes your <<breasts>> through your $upperclothes.<<neutral 2>>
<<else>>
<<He>> gropes your exposed <<breastsstop>><<neutral 4>>
<</if>>
<<elseif $enemyanger + $rng lte 80>><<set $speechbottom to 1>>
<<if $lowerstate is "waist" and $skirt is 0>>
<<He>> gropes your <<bottom>> through your $lowerclothes.<<neutral 2>>
<<elseif $understate is "waist">>
<<He>> gropes your <<bottom>> through your $underclothes.<<neutral 2>>
<<else>>
<<He>> fondles and <<strokes>> your exposed <<bottomstop>><<neutral 4>>
<</if>>
<<elseif $enemyanger + $rng lte 100>>
<<if $penisexist is 1>>
<<if $lowerstate is "waist" and $skirt is 0>>
<<He>> gropes and <<strokes>> your <<penis>> through your $lowerclothes.<<neutral 5>>
<<elseif $understate is "waist">>
<<He>> gropes and <<strokes>> your <<penis>> through your $underclothes.<<neutral 5>>
<<elseif $penisuse is 0>>
<<He>> gropes and <<strokes>> your exposed <<penisstop>><<neutral 10>>
<<else>>
<<He>> cups and <<strokes>> your <<testiclesstop>><<neutral 10>>
<</if>>
<<elseif $vaginaexist is 1>>
<<if $lowerstate is "waist" and $skirt is 0>>
<<He>> gropes and <<strokes>> your labia through your $lowerclothes.<<neutral 5>>
<<elseif $understate is "waist">>
<<He>> gropes and <<strokes>> your labia through your $underclothes.<<neutral 5>>
<<else>>
<<He>> gropes and <<strokes>> your exposed <<pussystop>><<neutral 10>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 110>>
<<if $lowerclothes isnot "naked">><span class="purple"><<He>> grasps your $lowerclothes.</span><<set $righthand3 to "lowerclothes">><<neutral 1>>
<<elseif $vaginaexist is 1>>He pinches your clitoris.<<neutral 15>><<bruise vagina>><<set $speechclit to 1>>
<<elseif $penisexist is 1>>
<<if $penisuse is 0>>
<<He>> pinches your glans.<<neutral 15>><<bruise penis>><<set $speechglans to 1>>
<<else>>
<<He>> pinches your shaft.<<neutral 10>><<bruise penis>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 120>>
<<if $position is "wall">>
<<He>> squeezes your thigh.<<violence 1>><<hitstat>><<bruise thigh>>
<<else>>
<<if $upperclothes isnot "naked">><span class="purple"><<He>> grasps your $upperclothes.</span><<set $righthand3 to "upperclothes">><<neutral 1>>
<<else>><span class="purple"><<He>> grabs your throat.</span><<violence 2>><<set $righthand3 to "throat">>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 125>>
<<if $skirt is 1>>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $righthand3 to "underclothes">><<neutral 1>>
<<elseif $underanusexposed is 1>>
<<if $loweranusexposed is 1>>
<<if $anususe is 0 and $analdisable is "f">><span class="purple"><<He>> presses <<his>> right hand against your <<bottomstop>></span><<set $righthand3 to "anusentrance">><<set $anususe to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<<elseif $lowerclothes isnot "waist">>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $righthand3 to "underclothes">><<neutral 1>>
<<elseif $underanusexposed is 1>>
<<if $loweranusexposed is 1>>
<<if $anususe is 0 and $analdisable is "f">><span class="purple"><<He>> presses <<his>> right hand against your <<bottomstop>></span><<set $righthand3 to "anusentrance">><<set $anususe to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 130>>
<<if $skirt is 1>>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $righthand3 to "underclothes">><<neutral 1>>
<<elseif $undervaginaexposed is 1>>
<<if $lowervaginaexposed is 1>>
<<if $vaginaexist is 1>>
<<if $vaginause is 0>>
<span class="purple"><<He>> presses <<his>> right hand against your <<pussycomma>> <<his>> finger resting on your entrance.</span><<set $righthand3 to "vaginaentrance">><<set $vaginause to 1>><<neutral 1>>
<</if>>
<<elseif $penisexist is 1>>
<<if $penisuse is 0>><span class="purple"><<He>> presses <<his>> right hand against your <<penisstop>></span><<set $righthand3 to "penisentrance">><<set $penisuse to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $lowerclothes isnot "waist">>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $righthand3 to "underclothes">><<neutral 1>>
<<elseif $undervaginaexposed is 1>>
<<if $lowervaginaexposed is 1>>
<<if $vaginaexist is 1>>
<<if $vaginause is 0>>
<span class="purple"><<He>> presses <<his>> right hand against your <<pussycomma>> <<his>> finger resting on your entrance.</span><<set $righthand3 to "vaginaentrance">><<set $vaginause to 1>><<neutral 1>>
<</if>>
<<elseif $penisexist is 1>>
<<if $penisuse is 0>>
<span class="purple"><<He>> presses <<his>> right hand against your <<penisstop>></span><<set $righthand3 to "penisentrance">><<set $penisuse to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 140>>
<<if $position is "wall">>
<<He>> slaps your <<bottomstop>><<violence 1>><<bruise bottom>><<hitstat>>
<<else>>
<span class="purple"><<He>> seizes your hair with <<his>> right hand.</span><<set $righthand3 to "hair">><<violence 2>><<set $speechhair to 1>>
<</if>>
<<elseif $enemyanger + $rng lte 160 and $lefthand3 isnot "arms" and $righthand3 isnot "arms" and $leftarm isnot "bound" and $rightarm isnot "bound">><span class="purple"><<He>> pins down your arms.</span><<set $righthand3 to "arms">><<set $leftarm to "grappled">><<set $rightarm to "grappled">><<disablearms>><<violence 2>><<bruise leftarm>><<bruise rightarm>><<set $speecharms to 1>>
<<if $vaginause is "cover">><<set $vaginause to 0>>
<</if>>
<<if $vaginause is "cover">><<set $vaginause to 0>>
<</if>>
<<if $anususe is "cover">><<set $anususe to 0>>
<</if>>
<<if $anususe is "cover">><<set $anususe to 0>>
<</if>>
<<if $penisuse is "cover">><<set $penisuse to 0>>
<</if>>
<<if $penisuse is "cover">><<set $penisuse to 0>>
<</if>>
<<elseif $enemyanger + $rng lte 160>><<He>> grips your <<bottomcomma>> digging <<his>> nails into your skin.<<violence 10>><<bruise bottom>><<hitstat>><<set $speechspank to 1>>
<<elseif $enemyanger + $rng lte 175>><<He>> spanks your <<bottomstop>><<violence 10>><<bruise bottom>><<hitstat>><<set $speechspank to 1>>
<<elseif $enemyanger + $rng lte 180>><<He>> slaps your thighs.<<violence 10>><<bruise thigh>><<hitstat>><<set $speechbeat to 1>>
<<elseif $enemyanger + $rng lte 185>>
<<if $position is "wall">>
<<He>> beats your thigh.<<bruise thigh>><<hitstat>><<violence 10>><<set $speechbeat to 1>>
<<else>>
<<He>> beats your tummy.<<violence 20>><<bruise tummy>><<hitstat>><<set $speechbeat to 1>>
<</if>>
<<elseif $enemyanger + $rng lte 190>>
<<if $position is "wall">>
<<He>> spanks your <<bottomstop>><<violence 20>><<bruise bottom>><<hitstat>><<set $speechbeat to 1>>
<<else>>
<<He>> spanks your <<breastsstop>><<violence 20>><<bruise chest>><<hitstat>><<set $speechbeat to 1>>
<</if>>
<<elseif $enemyanger + $rng gte 191>>
<<if $position is "wall">>
<<if $penisexist is 1>>
<<He>> jabs your gooch.<<violence 20>><<bruise penis>><<hitstat>><<set $speechbeat to 1>>
<<elseif $vaginaexist is 1>>
<<He>> jabs your gooch.<<violence 20>><<bruise vagina>><<hitstat>><<set $speechbeat to 1>>
<</if>>
<<else>>
<<set $rng to random(1, 100)>>
<<if $rng gte 81>>
<<He>> scratches the side of your face.<<violence 20>><<bruise face>><<hitstat>><<set $speechbeat to 1>>
<<elseif $rng gte 61>>
<<He>> scratches the back of your neck.<<violence 20>><<bruise neck>><<hitstat>><<set $speechbeat to 1>>
<<elseif $rng gte 41>>
<<He>> scratches your cheek.<<violence 20>><<bruise face>><<hitstat>><<set $speechbeat to 1>>
<<elseif $rng gte 21>>
<<He>> scratches your jaw.<<violence 20>><<bruise face>><<hitstat>><<set $speechbeat to 1>>
<<else>>
<<He>> scratches the front of your neck.<<violence 20>><<bruise neck>><<hitstat>><<set $speechbeat to 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis3 is "clothed">>
<<if $pronoun is "m">>
<<if $enemyarousal gte 40>><<He>> unzips <<his>> fly, <span class="blue">revealing <<his>> erect penis.</span><<set $penis3 to 0>>
<</if>>
<<else>>
<<if $enemyarousal gte 40>><<He>> pulls up <<his>> skirt, <span class="blue">revealing <<his>> erect penis.</span><<set $penis3 to 0>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis3 is "thighs">>
<<if $vaginaexist is 1>>
<<if $rng gte 101>><span class="blue"><<He>> angles <<his>> penis towards your <<pussystop>></span><<set $thighuse to 0>><<set $penis3 to "vaginaentrance">><<set $vaginause to "penis">><<set $vaginastate to "entrance">><<set $speechvaginaentrance to 1>>
<<else>>
<<He>> rubs <<his>> penis between your thighs and <<pussystop>><<sex 5>>
<</if>>
<<else>>
<<if $rng gte 101>><<He>> moves <<his>> penis out from between your thighs.<<set $thighuse to 0>><<set $penis3 to 0>>
<<else>>
<<He>> rubs <<his>> penis between your thighs.<<sex 5>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis3 is "cheeks">>
<<if $rng gte 101>><span class="blue"><<He>> angles <<his>> penis towards your anus.</span><<set $penis3 to "anusentrance">><<set $anusstate to "entrance">><<set $bottomuse to 0>><<set $cheekactiondefault to "cheeks">><<set $speechanusentrance to 1>>
<<else>>
<<He>> rubs <<his>> penis between your cheeks.<<submission 3>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis3 is "leftarm">>
<<if $rng gte 1>><<He>> rubs <<his>> penis between your fingers.<<submission 1>>
<<elseif $rng gte 101>><<He>> moves <<his>> penis away from your hand.<<set $penis3 to 0>><<set $leftarm to 0>><<set $leftactiondefault to "leftgrab">>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis3 is "rightarm">>
<<if $rng gte 1>><<He>> rubs <<his>> penis between your fingers.<<submission 1>>
<<elseif $rng gte 101>><<He>> moves <<his>> penis away from your hand.<<set $penis3 to 0>><<set $rightarm to 0>><<set $rightactiondefault to "rightgrab">>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis3 is "botharm">>
<<if $rng gte 1>><<He>> rubs <<his>> penis between your hands.<<submission 2>>
<<elseif $rng gte 101>><<He>> moves <<his>> penis away from your hands.<<set $penis3 to 0>><<set $leftarm to 0>><<set $rightarm to 0>><<set $rightactiondefault to "rightgrab">><<set $leftactiondefault to "leftgrab">>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis3 is "feet">>
<<if $rng gte 1>>
<<He>> rubs <<his>> penis between your feet.<<submission 1>>
<<elseif $rng gte 101>>
<<He>> moves <<his>> penis away from your feet.<<set $penis3 to 0>><<set $feetuse to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis3 is "vagina">>
<<if $rng gte 101>><span class="purple"><<He>> slides <<his>> penis out of your <<pussystop>></span><<sex 30>><<set $penis3 to "vaginaimminent">><<bruise vagina>><<violence 1>><<set $vaginastate to "imminent">>
<<elseif $rng gte 1>>
<<if $enemyanger gte 100>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
<<He>> violates your <<pussy>> with increasing intensity.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues to fuck your <<pussy>> with no regard for your comfort.
<<else>>
<<He>> fucks your <<pussy>> with rough thrusts, giving no regard to your comfort.
<</if>>
<<elseif $enemyanger gte 20>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
You feel <<his>> penis throb as <<he>> pounds away at your <<pussystop>>
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues to violate your <<pussystop>>
<<else>>
<<He>> fucks your <<pussy>> with deep and deliberate thrusts.
<</if>>
<<else>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
<<He>> fucks your <<pussy>> with increasing power.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues thrusting into your <<pussystop>>
<<else>>
<<He>> fucks your <<pussy>> with steady thrusts.
<</if>>
<</if>>
<<sex 30>><<bruise vagina>><<violence 1>><<set $speechvaginapenetrated to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis3 is "vaginaimminent">>
<<if $rng gte 101>><span class="blue"><<He>> stops pressing <<his>> penis against your pussy.</span><<set $penis3 to "vaginaentrance">><<set $vaginastate to "entrance">>
<<elseif $rng gte 1>>
<<if $novaginal is 0>><<set $vaginaactiondefault to "take">>
<<if $vaginalvirginity is 0>>
<<if $enemyanger gte 80>>
<span class="pink"><<He>> thrusts <<his>> penis deep into your <<pussystop>></span>
<<elseif $enemyanger gte 20>>
<span class="pink"><<He>> thrusts <<his>> penis deep into your <<pussystop>></span>
<<else>>
<span class="pink"><<He>> glides <<his>> penis deep into your <<pussystop>></span>
<</if>>
<<sex 30>><<set $penis3 to "vagina">><<vaginalstat>><<bruise vagina>><<violence 1>><<raped>><<vaginaraped>><<set $vaginastate to "penetrated">><<set $speechvaginapenetrated to 1>>
<<elseif $vaginalvirginity is 1>><span class="pink"><<His>> penis thrusts deep into your virgin pussy,</span><span class="red"> breaking your hymen and forever robbing you of your purity.</span><<sex 100>><<set $penis3 to "vagina">><<set $vaginalvirginity to 0>><<bruise vagina>><<vaginalstat>><<violence 100>><<raped>><<vaginaraped>><<set $vaginastate to "penetrated">><<set $speechvaginavirgin to 1>>
<</if>>
<<else>>
Respecting your wishes, <<he>> presses <<his>> penis against your <<pussy>> but does not penetrate.<<sex 15>><<set $speechvaginawithhold to 1>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis3 is "vaginaentrance">>
<<if $rng gte 101>><span class="lblue"><<He>> moves <<his>> penis away from your <<pussystop>></span><<set $penis3 to 0>><<set $vaginause to 0>><<set $vaginastate to 0>>
<<elseif $rng gte 1>>
<<if $lowervaginaexposed is 0>><<He>> rubs <<his>> penis against your <<pussy>> through your $lowerclothes.<<sex 5>><<set $lowerintegrity -= 10>><<set $speechvaginaentrance to 1>>
<<elseif $lowervaginaexposed is 1>><<set $rng to random(1, 100)>>
<<if $undervaginaexposed is 0>><<He>> rubs <<his>> penis against your <<pussy>> through your $underclothes.<<sex 5>><<set $underintegrity -= 10>><<set $speechvaginaentrance to 1>>
<<elseif $undervaginaexposed is 1>>
<<if $rng gte 71>>
<<if $novaginal is 1>>
<span class="purple"><<He>> pushes <<his>> penis against your <<pussystop>></span><<sex 20>><<set $penis3 to "vaginaimminent">><<set $vaginastate to "imminent">><<set $speechvaginaimminent to 1>>
<<else>>
<span class="purple"><<He>> pushes <<his>> penis against your <<pussycomma>> preparing to penetrate you fully.</span><<sex 20>><<set $penis3 to "vaginaimminent">><<set $vaginastate to "imminent">><<set $speechvaginaimminent to 1>>
<</if>>
<<elseif $rng gte 1>><<He>> teases your <<pussy>> without penetrating.<<sex 10>><<set $speechvaginaentrance to 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis3 is "anus">>
<<if $rng gte 101>><span class="purple"><<He>> withdraws <<his>> penis from your anus.</span><<sex 30>><<set $penis3 to "anusimminent">><<bruise anus>><<violence 1>><<set $anusstate to "imminent">>
<<elseif $rng gte 1>>
<<if $enemyanger gte 100>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
<<He>> ravages your <<bottom>> with a violent intensity.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
You feel <<his>> penis ever deeper within you as <<he>> fucks your <<bottomstop>>
<<else>>
<<He>> fucks your <<bottom>> with rough thrusts, intent on showing you who's boss.
<</if>>
<<elseif $enemyanger gte 20>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
You feel <<his>> penis throb within you as <<he>> fucks your <<bottomstop>>
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues to violate your <<bottomcomma>> giving no regard to your comfort.
<<else>>
<<He>> fucks your <<bottom>> with deep and dominating thrusts.
<</if>>
<<else>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
<<He>> fucks your <<bottom>> with increasing power.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues fucking your <<bottomstop>>
<<else>>
<<He>> fucks your <<bottom>> with steady thrusts.
<</if>>
<</if>>
<<sex 30>><<bruise anus>><<violence 1>><<set $speechanuspenetrated to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis3 is "anusimminent">>
<<if $rng gte 101>><span class="blue"><<He>> stops pressing <<his>> penis against your anus.</span><<set $penis3 to "anusentrance">><<set $anusstate to "entrance">>
<<elseif $rng gte 1>>
<<if $noanal is 0>><<set $anusactiondefault to "take">>
<<if $analvirginity is 0>><span class="pink"><<He>> thrusts <<his>> penis deep into your <<bottomstop>></span><<sex 30>><<set $penis3 to "anus">><<bruise anus>><<analstat>><<violence 1>><<raped>><<set $anusstate to "penetrated">><<set $speechanuspenetrated to 1>>
<<elseif $analvirginity is 1>><span class="pink"><<He>> thrusts <<his>> penis deep into your virgin anus,</span> <span class="red">violating you in a way you hadn't conceived of.</span><<sex 100>><<set $penis3 to "anus">><<set $analvirginity to 0>><<bruise anus>><<analstat>><<violence 50>><<raped>><<set $anusstate to "penetrated">><<set $speechanusvirgin to 1>>
<</if>>
<<else>>
Respecting your wishes, <<he>> presses <<his>> penis against your anus but does not penetrate.<<sex 15>><<set $speechanuswithhold to 1>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis3 is "anusentrance">>
<<if $rng gte 101>><span class="lblue"><<He>> moves <<his>> penis away from your <<bottomstop>></span><<set $penis3 to 0>><<set $anususe to 0>><<set $anusstate to 0>>
<<elseif $rng gte 1>>
<<if $loweranusexposed is 0>><<He>> rubs <<his>> penis against your <<bottom>> through your $lowerclothes.<<sex 5>><<set $lowerintegrity -= 10>><<set $speechanusentrance to 1>>
<<elseif $loweranusexposed is 1>><<set $rng to random(1, 100)>>
<<if $underanusexposed is 0>><<He>> rubs <<his>> penis against your <<bottom>> through your $underclothes.<<set $speechanusentrance to 1>><<sex 5>><<set $underintegrity -= 10>>
<<elseif $underanusexposed is 1>>
<<if $rng gte 71>>
<<if $noanal is 1>>
<span class="pink"><<He>> presses <<his>> penis against your anus.</span><<sex 20>><<set $penis3 to "anusimminent">><<set $anusstate to "imminent">><<set $speechanusimminent to 1>>
<<else>>
<span class="pink"><<He>> presses <<his>> penis against your anus, preparing to penetrate you fully.</span><<sex 20>><<set $penis3 to "anusimminent">><<set $anusstate to "imminent">><<set $speechanusimminent to 1>>
<</if>>
<<elseif $rng gte 1>><<His>> penis rubs against your <<bottomstop>><<sex 5>><<set $speechanusentrance to 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis3 is "mouth">>
<<if $rng gte 101>><span class="purple"><<He>> withdraws <<his>> penis from your mouth.</span><<sex 30>><<set $penis3 to "mouthimminent">><<bruise face>><<violence 1>><<set $mouthstate to "imminent">>
<<elseif $rng gte 1>><<He>> continues thrusting into your mouth.<<submission 10>><<bruise face>><<violence 1>><<set $speechmouthpenetrated to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis3 is "mouthimminent">>
<<if $pullaway is 1>><<set $pullaway to 0>>Saliva drips from the tip of <<his>> phallus.
<<else>>
<<if $rng gte 101>><span class="blue"><<He>> stops pressing <<his>> penis against your mouth.</span><<set $penis3 to "mouthentrance">><<submission 5>><<set $mouthstate to "entrance">>
<<elseif $rng lte 20>>
<<if $oralvirginity is 0>><span class="pink"><<He>> thrusts <<his>> penis into your mouth.</span><<submission 10>><<set $penis3 to "mouth">><<bruise face>><<oralstat>><<raped>><<set $mouthstate to "penetrated">><<set $speechmouthpenetrated to 1>>
<<elseif $oralvirginity is 1>><span class="pink"><<He>> thrusts <<his>> penis into your mouth.</span><span class="red"> It tastes strange.</span><<submission 30>><<set $penis3 to "mouth">><<set $oralvirginity to 0>><<bruise face>><<oralstat>><<violence 1>><<raped>><<set $mouthstate to "penetrated">><<set $speechmouthvirgin to 1>>
<</if>>
<<elseif $rng gte 21>>
<<if $mouthsubmit is 1>><<He>> allows you to pleasure <<his>> cock with your mouth.<<submission 5>><<set $speechmouthimminent to 1>>
<<elseif $oralvirginity is 0>><span class="pink"><<He>> thrusts <<his>> penis into your mouth.</span><<submission 10>><<set $penis3 to "mouth">><<oralstat>><<bruise face>><<violence 1>><<raped>><<set $mouthstate to "penetrated">><<set $speechmouthpenetrated to 1>>
<<elseif $oralvirginity is 1>><span class="pink"><<He>> thrusts <<his>> penis into your mouth.</span><span class="red"> It tastes strange.</span><<submission 30>><<set $penis3 to "mouth">><<set $oralvirginity to 0>><<oralstat>><<bruise face>><<violence 1>><<raped>><<set $mouthstate to "penetrated">><<set $speechmouthpenetrated to 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis3 is "mouthentrance">>
<<if $pullaway is 1>><<set $pullaway to 0>><<His>> penis hovers only inches from your face.
<<else>>
<<if $rng gte 101>><span class="lblue"><<He>> moves <<his>> penis away from your mouth.</span><<set $penis3 to 0>><<set $mouthuse to 0>><<set $mouthstate to 0>>
<<elseif $rng gte 1>><span class="purple"><<He>> pushes <<his>> penis against your lips.</span><<set $penis3 to "mouthimminent">><<submission 5>><<set $mouthstate to "imminent">><<set $speechmouthimminent to 1>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis3 is "chest">>
<<if $rng gte 101>><<He>> moves <<his>> penis away from your chest.<<set $penis3 to 0>><<set $chestuse to 0>>
<<elseif $rng gte 1>><<submission 3>>
<<if $breastcup is "none">>
<<He>> rubs <<his>> penis against your <<breastsstop>><<set $speechchestrub to 1>>
<<else>>
<<He>> rubs <<his>> penis between your <<breastsstop>><<set $speechbreastrub to 1>>
<</if>>
<</if>>
<</if>>
<<if $penis3 is "footjob">>
<<if $rng gte 101>>
<span class="blue"><<He>> stops pressing <<his>> foot against your <<genitalsstop>></span><<set $penis3 to 0>>
<<if $penisexist is 1>>
<<set $penisuse to 0>>
<<else>>
<<set $vaginause to 0>>
<</if>>
<<else>>
<<if $penisexist is 1>>
<<He>> presses your <<penis>> against your stomach with <<his>> foot and rubs your glans between <<his>> toes.
<<set $speechpenisfoot to 1>><<neutral 5>><<violence 1>>
<<else>>
<<He>> presses and teases your <<pussy>> with <<his>> foot.
<<set $speechvaginafoot to 1>><<neutral 5>><<violence 1>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis3 is "otherfrot">>
<<if $rng gte 101>><span class="blue"><<He>> shifts <<his>> ass and presses <<his>> anus against your <<penisstop>></span><<set $penisuse to "otheranus">><<set $penis3 to "otheranusentrance">><<set $penisstate to "otheranusentrance">><<set $speechotheranusentrance to 1>>
<<else>>
<<He>> rubs <<his>> ass against your <<penisstop>><<sex 5>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis3 is "otheranus">>
<<if $rng gte 101>><span class="purple"><<He>> moves <<his>> pelvis away, releasing your <<penis>> from <<his>> anus.</span><<sex 30>><<set $penis3 to "otheranusimminent">><<bruise penis>><<violence 1>><<set $penisstate to "otheranusimminent">><<set $speechotheranusimminent to 1>>
<<elseif $rng gte 1>>
<<if $enemyanger gte 100>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
<<His>> continues to fuck your <<penis>> with <<his>> ass, <<his>> movements violent and erratic.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues to ride you, your penis helpless as it's fucked.
<<else>>
<<He>> fucks your <<penis>> with rough movements, intent on showing you who's boss.
<</if>>
<<elseif $enemyanger gte 20>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
You feel <<his>> ass twitch around your length <<he>> fucks you.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues to violate your <<peniscomma>> using you as a sex toy.
<<else>>
<<He>> fucks your <<peniscomma>> taking as much of you into <<his>> ass as <<he>> can.
<</if>>
<<else>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
<<He>> continues riding your <<peniscomma>> <<his>> anus rhythmically pounding your length. <<His>> body jerks whenever you hit a sensitive spot.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues riding your <<peniscomma>> <<his>> anus rhythmically pounding your length.
<<else>>
<<He>> rides your <<penis>> with steady movements.
<</if>>
<</if>>
<<sex 30>><<bruise penis>><<violence 1>><<set $speechotheranus to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis3 is "otheranusimminent">>
<<if $rng gte 101>><span class="blue"><<He>> stops pressing <<his>> ass against your <<penisstop>></span><<set $penis3 to "otheranusentrance">><<set $penisstate to "otheranusentrance">><<set $speechotheranusentrance to 1>>
<<elseif $rng gte 1>>
<<if $nopenile is 0>><<set $penisactiondefault to "otheranustake">>
<<if $penilevirginity is 0>><span class="pink"><<He>> eases your <<penis>> into <<his>> ass, swallowing you to the base.</span><<sex 30>><<set $penis3 to "otheranus">><<penilestat>><<bruise penis>><<violence 1>><<raped>><<penisraped>><<set $penisstate to "otheranus">><<set $speechotheranus to 1>>
<<elseif $penilevirginity is 1>><span class="pink"><<He>> eases your virgin penis into <<his>> ass,</span><span class="red"> separating your foreskin from your glans and forever robbing you of your purity.</span><<sex 100>><<set $penis3 to "otheranus">><<set $penilevirginity to 0>><<bruise penis>><<penilestat>><<violence 100>><<raped>><<penisraped>><<set $penisstate to "otheranus">><<set $speechpenisvirgin to 1>>
<</if>>
<<else>>
Respecting your wishes, <<he>> does not envelope your <<penis>> with <<his>> ass, instead teasing the tip of your glans.<<sex 15>><<set $speechotheranuswithhold to 1>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis3 is "otheranusentrance">>
<<if $rng gte 101>><span class="lblue"><<He>> moves <<his>> ass away from your <<penisstop>></span><<set $penis3 to 0>><<set $penisuse to 0>><<set $penisstate to 0>>
<<elseif $rng gte 1>>
<<if $lowervaginaexposed is 0>><<He>> rubs <<his>> ass against your <<penis>> through your $lowerclothes.<<sex 5>><<set $lowerintegrity -= 10>><<set $speechotheranusentrance to 1>>
<<elseif $lowervaginaexposed is 1>><<set $rng to random(1, 100)>>
<<if $undervaginaexposed is 0>><<He>> rubs <<his>> ass against your <<penis>> through your $underclothes.<<sex 5>><<set $underintegrity -= 10>><<set $speechotheranusentrance to 1>>
<<elseif $undervaginaexposed is 1>>
<<if $rng gte 71>>
<<if $nopenile is 1>>
<span class="purple"><<He>> presses <<his>> ass against your <<penisstop>></span><<sex 20>><<set $penis3 to "otheranusimminent">><<set $penisstate to "otheranusimminent">><<set $speechotheranusimminent to 1>>
<<else>>
<span class="purple"><<He>> presses <<his>> ass against your <<peniscomma>> preparing to take you in fully.</span><<sex 20>><<set $penis3 to "otheranusimminent">><<set $penisstate to "otheranusimminent">><<set $speechotheranusimminent to 1>>
<</if>>
<<elseif $rng gte 1>><<He>> rubs your <<penis>> between <<his>> cheeks.<<sex 10>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis3 is 0>>
<<if $enemyanger + $rng lte 20>>
<<if $lefthand3 is 0>>
<<if $enemyarousal lte 40>><<He>> slowly rubs <<his>> shaft.<<submission 1>>
<<elseif $enemyarousal lte 90>><<He>> quickly rubs <<his>> shaft.<<submission 2>>
<<elseif $enemyarousal gte 91>><<He>> rapidly rubs <<his>> shaft.<<submission 3>>
<</if>>
<<elseif $righthand3 is 0>>
<<if $enemyarousal lte 40>><<He>> slowly rubs <<his>> shaft.<<submission 1>>
<<elseif $enemyarousal lte 90>><<He>> quickly rubs <<his>> shaft.<<submission 2>>
<<elseif $enemyarousal gte 91>><<He>> rapidly rubs <<his>> shaft.<<submission 3>>
<<endif>
<<else>><<He>> rubs <<his>> cock against your thighs.<<submission 2>>
<</if>>
<<elseif $enemyanger + $rng lte 25>>
<<if $position is "wall">>
<<He>> rubs <<his>> cock against your thighs.<<submission 2>>
<<else>>
<<He>> rubs <<his>> cock against your tummy.<<submission 2>>
<</if>>
<<elseif $enemyanger + $rng lte 30>>
<<if $position is "wall">>
<<He>> rubs <<his>> cock against your thighs.<<submission 2>>
<<else>>
<<He>> rubs <<his>> cock against your <<breastsstop>><<submission 2>>
<</if>>
<<elseif $enemyanger + $rng lte 35>><<He>> rubs <<his>> cock against your thighs.<<submission 2>>
<<elseif $enemyanger + $rng lte 40>>
<<if $position is "wall">>
<<He>> rubs <<his>> cock against your thighs.<<submission 2>>
<<elseif $mouth3 is 0>>
<<He>> rubs <<his>> cock against your face.<<submission 2>>
<<else>>
<<He>> rubs <<his>> cock against your thighs.<<submission 2>>
<</if>>
<<elseif $enemyanger + $rng lte 45>>
<<if $penisexist is 1>>
<<if $penisuse is 0>>
<<if $analdisable is "f" and $consensual is 1>>
<span class="blue"><<He>> straddles you, rubbing <<his>> ass against your <<penisstop>></span><<neutral 5>><<set $penisuse to "otheranus">><<set $penis3 to "otheranusentrance">><<set $penisstate to "otheranusentrance">><<set $speechotheranusentrance to 1>>
<</if>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 60>>
<<if $mouthuse is 0>>
<<if $penisbitten is 0>>
<<if $position isnot "wall">>
<span class="blue"><<He>> positions <<his>> penis in front of your mouth.</span><<neutral 5>><<set $mouthuse to "penis">><<set $penis3 to "mouthentrance">><<set $mouthstate to "entrance">><<set $speechmouthentrance to 1>>
<</if>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 80>>
<<if $anususe is 0>>
<<if $analdisable is "f">>
<span class="blue"><<He>> moves between your legs, positioning <<his>> penis in front of your <<bottomstop>></span><<neutral 5>><<set $anususe to "penis">><<set $penis3 to "anusentrance">><<set $anusstate to "entrance">><<set $speechanusentrance to 1>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 100>>
<<if $vaginaexist is 1>>
<<if $vaginause is 0>><span class="blue"><<He>> moves between your legs, positioning <<his>> penis in front of your <<pussystop>></span><<neutral 5>><<set $vaginause to "penis">><<set $penis3 to "vaginaentrance">><<set $vaginastate to "entrance">><<set $speechvaginaentrance to 1>>
<</if>>
<<elseif $penisexist is 1>>
<<if $anususe is 0>>
<<if $analdisable is "f">>
<span class="blue"><<He>> moves between your legs, positioning <<his>> penis in front of your <<bottomstop>></span><<neutral 5>><<set $anususe to "penis">><<set $penis3 to "anusentrance">><<set $anusstate to "entrance">><<set $speechanusentrance to 1>>
<</if>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 120>>
<<He>> slowly traces <<his>> length across your exposed skin.<<neutral 1>>
<<neutral 5>>
<<elseif $enemyanger + $rng lte 140>>
<<if $penisbitten is 0>>
<<if $position isnot "wall">>
<<if $mouthuse is 0>><span class="purple"><<He>> shoves <<his>> penis against your lips.</span><<submission 5>><<set $mouthuse to "penis">><<set $mouthstate to "imminent">><<set $penis3 to "mouthimminent">><<set $speechmouthimminent to 1>>
<<else>>
<<He>> slowly traces <<his>> length across your exposed skin.<<neutral 1>>
<</if>>
<<else>>
<<He>> slowly traces <<his>> length across your exposed skin.<<neutral 1>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 150>><span class="purple"><<He>> presses <<his>> foot against your <<genitalsstop>></span><<neutral 5>><<violence 1>><<set $penis3 to "footjob">>
<<if $penisexist is 1>>
<<set $penisuse to "feet">><<set $speechpenisfoot to 1>>
<<else>>
<<set $vaginause to "feet">><<set $speechvaginafoot to 1>>
<</if>>
<<elseif $enemyanger + $rng lte 170>>
<<if $anususe is 0 and $analdisable is "f">>
<<if $loweranusexposed is 1>>
<<if $underanusexposed is 1>>
<span class="purple"><<He>> presses <<his>> penis against your anus, preparing to penetrate.</span><<sex 5>><<set $anususe to "penis">><<set $penis3 to "anusimminent">><<set $anusstate to "imminent">><<set $speechanusimminent to 1>>
<<elseif $underanusexposed is 0>><span class="blue"><<He>> presses <<his>> penis against your anus through your $underclothes.</span><<sex 3>><<set $penis3 to "anusentrance">><<set $anususe to "penis">><<set $underintegrity -= 10>><<set $anusstate to "entrance">><<set $speechanusentrance to 1>>
<</if>>
<<elseif $loweranusexposed is 0>><span class="blue"><<He>> presses <<his>> penis against your anus through your $lowerclothes.</span><<sex 2>><<set $penis3 to "anusentrance">><<set $anususe to "penis">><<set $lowerintegrity -= 10>><<set $anusstate to "entrance">><<set $speechanusentrance to 1>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng gte 171>>
<<if $vaginaexist is 1>>
<<if $vaginause is 0>>
<<if $lowervaginaexposed is 1>>
<<if $undervaginaexposed is 1>><span class="purple"><<He>> presses <<his>> penis against your <<pussycomma>> preparing to penetrate.</span><<sex 5>><<set $vaginause to "penis">><<set $penis3 to "vaginaimminent">><<set $vaginastate to "imminent">><<set $speechvaginaimminent to 1>>
<<elseif $undervaginaexposed is 0>><span class="blue"><<He>> presses <<his>> penis against your <<pussy>> through your $underclothes.</span><<set $underintegrity -= 10>><<sex 3>><<set $penis3 to "vaginaentrance">><<set $vaginause to "penis">><<set $vaginastate to "entrance">><<set $speechvaginaentrance to 1>>
<</if>>
<<elseif $lowervaginaexposed is 0>><span class="blue"><<He>> presses <<his>> penis against your <<pussy>> through your $lowerclothes.</span><<sex 2>><<set $penis3 to "vaginaentrance">><<set $vaginause to "penis">><<set $lowerintegrity -= 10>><<set $vaginastate to "entrance">><<set $speechvaginaentrance to 1>>
<</if>>
<</if>>
<<elseif $penisexist is 1>>
<<if $anususe is 0 and $analdisable is "f">>
<<if $loweranusexposed is 1>>
<<if $underanusexposed is 1>><span class="purple"><<He>> presses <<his>> penis against your anus, preparing to penetrate.</span><<sex 5>><<set $anususe to "penis">><<set $penis3 to "anusimminent">><<set $anusstate to "imminent">><<set $speechanusimminent to 1>>
<<elseif $underanusexposed is 0>><span class="blue"><<He>> presses <<his>> penis against your anus through your $underclothes.</span><<sex 3>><<set $penis3 to "anusentrance">><<set $anususe to "penis">><<set $underintegrity -= 10>><<set $anusstate to "entrance">><<set $speechanusentrance to 1>>
<</if>>
<<elseif $loweranusexposed is 0>><span class="blue"><<He>> presses <<his>> penis against your anus through your $lowerclothes.</span><<sex 2>><<set $penis3 to "anusentrance">><<set $anususe to "penis">><<set $lowerintegrity -= 10>><<set $anusstate to "entrance">><<set $speechanusentrance to 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<set $rng to random(1, 100)>>
<<if $vagina3 is "clothed">>
<<if $pronoun is "f">>
<<if $enemyarousal gte 40>><span class="blue"><<He>> lifts up <<his>> skirt, revealing <<his>> moistened pussy.</span><<set $vagina3 to 0>>
<</if>>
<<else>>
<<if $enemyarousal gte 40>><span class="blue"><<He>> unzips <<his>> fly, revealing <<his>> moistened pussy.</span><<set $vagina3 to 0>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $vagina3 is "frot">>
<<if $rng gte 101>><span class="blue"><<He>> moves <<his>> clit away and presses <<his>> hungry pussy against your <<penisstop>></span><<set $penisuse to "othervagina">><<set $vagina3 to "penisentrance">><<set $penisstate to "entrance">><<set $speechpenisentrance to 1>>
<<else>>
<<He>> rubs <<his>> clit against your glans.<<sex 5>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $vagina3 is "penis">>
<<if $rng gte 101>><span class="purple"><<He>> moves <<his>> pelvis away, releasing your <<penis>> from <<his>> vagina.</span><<sex 30>><<set $vagina3 to "penisimminent">><<bruise penis>><<violence 1>><<set $penistate to "imminent">><<set $speechpenisimminent to 1>>
<<elseif $rng gte 1>>
<<if $enemyanger gte 100>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
<<His>> continues to fuck your <<peniscomma>> <<his>> movements violent and erratic as <<his>> pussy slides along your length.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues to ride you, your penis helpless as it's fucked.
<<else>>
<<He>> fucks your <<penis>> with rough movements, intent on showing you who's boss.
<</if>>
<<elseif $enemyanger gte 20>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
You feel <<his>> vagina twitch and throb around your length <<he>> fucks you.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues to violate your <<peniscomma>> using you as a sex toy.
<<else>>
<<He>> fucks your <<peniscomma>> taking as much of you into <<his>> vagina as <<he>> can.
<</if>>
<<else>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
<<He>> continues riding your <<peniscomma>> <<his>> vagina rhythmically kneading and squeezing your length. <<His>> body jerks whenever you hit a sensitive spot.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues riding your <<peniscomma>> <<his>> vagina rhythmically kneading and squeezing your length.
<<else>>
<<He>> rides your <<penis>> with steady movements.
<</if>>
<</if>>
<<sex 30>><<bruise penis>><<violence 1>><<set $speechpenispenetrated to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $vagina3 is "penisimminent">>
<<if $rng gte 101>><span class="blue"><<He>> stops pressing <<his>> pussy against your <<penisstop>></span><<set $vagina3 to "penisentrance">><<set $penisstate to "entrance">><<set $speechpenisentrance to 1>>
<<elseif $rng gte 1>>
<<if $nopenile is 0>><<set $penisactiondefault to "take">>
<<if $penilevirginity is 0>><span class="pink"><<He>> eases your <<penis>> into <<his>> pussy, swallowing you to the base.</span><<sex 30>><<set $vagina3 to "penis">><<penilestat>><<bruise penis>><<violence 1>><<raped>><<penisraped>><<set $penisstate to "penetrated">><<set $speechpenispenetrated to 1>>
<<elseif $penilevirginity is 1>><span class="pink"><<He>> eases your virgin penis into <<his>> pussy,</span><span class="red"> separating your foreskin from your glans and forever robbing you of your purity.</span><<sex 100>><<set $vagina3 to "penis">><<set $penilevirginity to 0>><<bruise penis>><<penilestat>><<violence 100>><<raped>><<penisraped>><<set $penisstate to "penetrated">><<set $speechpenisvirgin to 1>>
<</if>>
<<else>>
Respecting your wishes, <<he>> does not envelope your <<penis>> with <<his>> vagina, instead teasing the tip of your glans.<<sex 15>><<set $speechpeniswithhold to 1>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $vagina3 is "penisentrance">>
<<if $rng gte 101>><span class="lblue"><<He>> moves <<his>> pussy away from your <<penisstop>></span><<set $vagina3 to 0>><<set $penisuse to 0>><<set $penisstate to 0>>
<<elseif $rng gte 1>>
<<if $lowervaginaexposed is 0>><<He>> rubs <<his>> pussy against your <<penis>> through your $lowerclothes.<<sex 5>><<set $lowerintegrity -= 10>><<set $speechpenisentrance to 1>>
<<elseif $lowervaginaexposed is 1>><<set $rng to random(1, 100)>>
<<if $undervaginaexposed is 0>><<He>> rubs <<his>> pussy against your <<penis>> through your $underclothes.<<sex 5>><<set $underintegrity -= 10>><<set $speechpenisentrance to 1>>
<<elseif $undervaginaexposed is 1>>
<<if $rng gte 71>>
<<if $nopenile is 1>>
<span class="purple"><<He>> presses <<his>> pussy against your <<penisstop>></span><<sex 20>><<set $vagina3 to "penisimminent">><<set $penisstate to "imminent">><<set $speechpenisimminent to 1>>
<<else>>
<span class="purple"><<He>> presses <<his>> pussy against your <<peniscomma>> preparing to envelope you fully.</span><<sex 20>><<set $vagina3 to "penisimminent">><<set $penisstate to "imminent">><<set $speechpenisimminent to 1>>
<</if>>
<<elseif $rng gte 1>><<He>> teases your <<penis>> with <<his>> labia.<<sex 10>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $vagina3 is "lefthand">>
<<if $rng lte 80>>
<<He>> strokes <<his>> pussy with <<his>> left hand.<<neutral 1>><<set $enemyarousal += 20>>
<<else>>
<span class="blue"><<He>> moves <<his>> left hand away from <<his>> pussy.</span>
<<set $lefthand3 to 0>><<set $vagina3 to 0>>
<</if>>
<</if>>
<<if $vagina3 is "righthand">>
<<if $rng lte 80>>
<<He>> strokes <<his>> pussy with <<his>> right hand.<<neutral 1>><<set $enemyarousal += 20>>
<<else>>
<span class="blue"><<He>> moves <<his>> right hand away from <<his>> pussy.</span>
<<set $righthand3 to 0>><<set $vagina3 to 0>>
<</if>>
<</if>>
<<if $vagina3 is "mouth">>
<<if $enemyanger gte 100>>
<<He>> covers your mouth with <<his>> pussy, making it difficult to breathe.<<violence 3>><<bruise face>><<set $speechvaginamouth to 1>>
<<else>>
<<if $mouthsubmit is 1>>
<<if $rng gte 1>>
<<He>> rubs <<his>> pussy against your lips.
<<if $enemyarousal gte (($enemyarousalmax / 5) * 3)>>
You can taste <<his>> juices.
<</if>>
<<sex 3>><<set $speechvaginamouth to 1>>
<<else>><<He>> moves <<his>> pussy away from your face.<<set $mouthuse to 0>><<set $mouthstate to 0>><<set $vagina3 to 0>>
<</if>>
<<else>>
<<if $rng gte 1>>
<<He>> rubs <<his>> pussy against your lips.
<<if $enemyarousal gte (($enemyarousalmax / 5) * 3)>>
You can taste <<his>> juices.
<</if>>
<<sex 3>><<set $speechvaginamouth to 1>>
<<else>><<He>> moves <<his>> pussy away from your face.<<set $mouthuse to 0>><<set $mouthstate to 0>><<set $vagina3 to 0>>
<</if>>
<</if>>
<</if>>
<</if>>
<<if $vagina3 is "vagina">>
<<if $rng gte 1>>
<<He>> kneads your pussies together.<<sex 20>><<set $speechvaginavagina to 1>>
<<else>>
<span class="lblue"><<He>> moves <<his>> pussy away from yours.</span><<set $vaginause to 0>><<set $vagina3 to 0>>
<</if>>
<</if>>
<<if $vagina3 is "leftarm">>
<<if $rng gte 1>>
<<He>> rubs <<his>> pussy against your fingers.<<submission 2>>
<<else>>
<<He>> moves your hand away from <<his>> pussy.<<set $leftarm to 0>><<set $vagina3 to 0>><<set $leftactiondefault to "leftplay">>
<</if>>
<</if>>
<<if $vagina3 is "rightarm">>
<<if $rng gte 1>>
<<He>> rubs <<his>> pussy against your fingers.<<submission 2>>
<<else>>
<<He>> moves your hand away from <<his>> pussy.<<set $rightarm to 0>><<set $vagina3 to 0>><<set $rightactiondefault to "rightplay">>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $vagina3 is "feet">>
<<if $rng gte 1>>
<<He>> rubs <<his>> pussy against your feet.<<submission 2>>
<<else>>
<<He>> moves your feet away from <<his>> pussy.<<set $feetuse to 0>><<set $vagina3 to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $vagina3 is "footjob">>
<<if $rng gte 101>>
<span class="blue"><<He>> stops pressing <<his>> foot against your <<genitalsstop>></span><<set $vagina3 to 0>>
<<if $penisexist is 1>>
<<set $penisuse to 0>>
<<else>>
<<set $vaginause to 0>>
<</if>>
<<else>>
<<if $penisexist is 1>>
<<He>> presses your penis against your stomach with <<his>> foot and rubs your glans between <<his>> toes.
<<set $speechpenisfoot to 1>><<neutral 5>><<violence 1>>
<<else>>
<<He>> rubs <<his>> foot against your <<pussystop>>
<<set $speechvaginafoot to 1>><<neutral 5>><<violence 1>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $vagina3 is "otherfrot">>
<<if $rng gte 101>><span class="blue"><<He>> shifts <<his>> ass and presses <<his>> anus against your <<penisstop>></span><<set $penisuse to "otheranus">><<set $vagina3 to "otheranusentrance">><<set $penisstate to "otheranusentrance">><<set $speechotheranusentrance to 1>>
<<else>>
<<He>> rubs <<his>> ass against your <<penisstop>><<sex 5>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $vagina3 is "otheranus">>
<<if $rng gte 101>><span class="purple"><<He>> moves <<his>> pelvis away, releasing your <<penis>> from <<his>> anus.</span><<sex 30>><<set $vagina3 to "otheranusimminent">><<bruise penis>><<violence 1>><<set $penisstate to "otheranusimminent">><<set $speechotheranusimminent to 1>>
<<elseif $rng gte 1>>
<<if $enemyanger gte 100>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
<<His>> continues to fuck your <<penis>> with <<his>> ass, <<his>> movements violent and erratic. Fluid from <<his>> pussy drools onto your length.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues to ride you, your penis helpless as it's fucked.
<<else>>
<<He>> fucks your <<penis>> with rough movements, intent on showing you who's boss.
<</if>>
<<elseif $enemyanger gte 20>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
You feel <<his>> ass twitch around your length as <<he>> fucks you.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues to violate your <<peniscomma>> using you as a sex toy.
<<else>>
<<He>> fucks your <<peniscomma>> taking as much of you into <<his>> ass as <<he>> can.
<</if>>
<<else>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
<<He>> continues riding your <<peniscomma>> <<his>> anus rhythmically pounding your length. <<His>> body jerks whenever you hit a sensitive spot.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues riding your <<peniscomma>> <<his>> anus rhythmically pounding your length.
<<else>>
<<He>> rides your <<penis>> with steady movements.
<</if>>
<</if>>
<<sex 30>><<bruise penis>><<violence 1>><<set $speechotheranus to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $vagina3 is "otheranusimminent">>
<<if $rng gte 101>><span class="blue"><<He>> stops pressing <<his>> ass against your <<penisstop>></span><<set $vagina3 to "otheranusentrance">><<set $penisstate to "otheranusentrance">><<set $speechotheranusentrance to 1>>
<<elseif $rng gte 1>>
<<if $nopenile is 0>><<set $penisactiondefault to "take">>
<<if $penilevirginity is 0>><span class="pink"><<He>> eases your <<penis>> into <<his>> ass, swallowing you to the base.</span><<sex 30>><<set $vagina3 to "otheranus">><<penilestat>><<bruise penis>><<violence 1>><<raped>><<penisraped>><<set $penisstate to "otheranus">><<set $speechotheranus to 1>>
<<elseif $penilevirginity is 1>><span class="pink"><<He>> eases your virgin penis into <<his>> ass,</span><span class="red"> separating your foreskin from your glans and forever robbing you of your purity.</span><<sex 100>><<set $vagina3 to "otheranus">><<set $penilevirginity to 0>><<bruise penis>><<penilestat>><<violence 100>><<raped>><<penisraped>><<set $penisstate to "otheranus">><<set $speechpenisvirgin to 1>>
<</if>>
<<else>>
Respecting your wishes, <<he>> does not envelope your <<penis>> with <<his>> ass, instead teasing the tip of your glans.<<sex 15>><<set $speechotheranuswithhold to 1>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $vagina3 is "otheranusentrance">>
<<if $rng gte 101>><span class="lblue"><<He>> moves <<his>> ass away from your <<penisstop>></span><<set $vagina3 to 0>><<set $penisuse to 0>><<set $penisstate to 0>>
<<elseif $rng gte 1>>
<<if $lowervaginaexposed is 0>><<He>> rubs <<his>> ass against your <<penis>> through your $lowerclothes.<<sex 5>><<set $lowerintegrity -= 10>><<set $speechotheranusentrance to 1>>
<<elseif $lowervaginaexposed is 1>><<set $rng to random(1, 100)>>
<<if $undervaginaexposed is 0>><<He>> rubs <<his>> ass against your <<penis>> through your $underclothes.<<sex 5>><<set $underintegrity -= 10>><<set $speechotheranusentrance to 1>>
<<elseif $undervaginaexposed is 1>>
<<if $rng gte 71>>
<<if $nopenile is 1>>
<span class="purple"><<He>> presses <<his>> ass against your <<penisstop>></span><<sex 20>><<set $vagina3 to "otheranusimminent">><<set $penisstate to "otheranusimminent">><<set $speechotheranusimminent to 1>>
<<else>>
<span class="purple"><<He>> presses <<his>> ass against your <<peniscomma>> preparing to take you in fully.</span><<sex 20>><<set $vagina3 to "otheranusimminent">><<set $penisstate to "otheranusimminent">><<set $speechotheranusimminent to 1>>
<</if>>
<<elseif $rng gte 1>><<He>> rubs your <<penis>> between <<his>> cheeks.<<sex 10>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<if $vagina3 is 0>>
<<if $enemyanger + $rng lte 20>><<He>> sways <<his>> hips suggestively.<<neutral 1>><<set $speechvaginaflaunt to 1>>
<<elseif $enemyanger + $rng lte 40>><<He>> twirls on the spot.<<neutral 3>><<set $speechvaginaflaunt to 1>>
<<elseif $enemyanger + $rng lte 50>>
<<if $penisexist is 1>>
<<if $penisuse is 0 and $analdisable is "f">>
<span class="blue"><<He>> straddles you, rubbing <<his>> ass against your <<penisstop>></span><<neutral 5>><<set $penisuse to "otheranus">><<set $vagina3 to "otheranusentrance">><<set $penisstate to "otheranusentrance">><<set $speechotheranusentrance to 1>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 60>><<He>> rubs <<his>> pussy against your thigh.<<neutral 10>>
<<elseif $enemyanger + $rng lte 80 and $lefthand3 is 0>>
<span class="lblue"><<He>> presses <<his>> fingers against <<his>> labia.</span><<neutral 1>><<set $enemyarousal += 10>><<set $vagina3 to "lefthand">><<set $lefthand3 to "othervagina">>
<<elseif $enemyanger + $rng lte 80 and $righthand3 is 0>>
<span class="lblue"><<He>> presses <<his>> fingers against <<his>> labia.</span><<neutral 1>><<set $enemyarousal += 10>><<set $vagina3 to "righthand">><<set $righthand3 to "othervagina">>
<<elseif $enemyanger + $rng lte 80>>
<<He>> rubs <<his>> pussy against your thigh.<<neutral 2>>
<<elseif $enemyanger + $rng lte 100 and $penisuse is 0 and $undervaginaexposed is 1 and $lowervaginaexposed is 1>>
<<set $penisuse to "othervagina">><<set $vagina3 to "penisentrance">><<set $penisstate to "entrance">><span class="blue"><<He>> straddles you, <<his>> pussy hovering close to your <<penisstop>></span>
<<elseif $enemyanger + $rng lte 120 and $penisuse is 0 and $penisexist is 1 and $undervaginaexposed is 1 and $lowervaginaexposed is 1>>
<<set $penisuse to "othervagina">><<set $vagina3 to "penisimminent">><<set $penisstate to "imminent">><span class="purple"><<He>> wraps <<his>> legs around your pelvis, pressing <<his>> pussy against your <<genitalsstop>></span>
<<elseif $enemyanger + $rng lte 120 and $vaginause is 0 and $vaginaexist is 1 and $undervaginaexposed is 1 and $lowervaginaexposed is 1>>
<<set $vaginause to "othervagina">><<set $vagina3 to "vagina">><<sex 20>><<He>> pushes <<his>> pussy against yours.
<<elseif $enemyanger + $rng lte 140>>
<<if $position is "wall">>
<<He>> sits on your protruding <<bottomcomma>> pressing down on you painfully.<<violence 3>>
<<elseif $mouth3 is 0>>
<<He>> rubs <<his>> clit against your face.<<violence 3>>
<<else>>
<<He>> frots against your thigh while squeezing it with <<his>> own.<<violence 3>>
<</if>>
<<elseif $enemyanger + $rng lte 160>><span class="purple"><<He>> presses <<his>> foot against your <<genitalsstop>></span><<neutral 5>><<set $vagina3 to "footjob">>
<<if $penisexist is 1>>
<<set $penisuse to "feet">><<set $speechpenisfoot to 1>>
<<else>>
<<set $vaginause to "feet">><<set $speechvaginafoot to 1>>
<</if>>
<<elseif $enemyanger + $rng lte 180>>
<<if $position is "wall">>
<<He>> kicks you in the <<bottomstop>><<violence 10>><<hitstat>><<bruise bottom>>
<<else>>
<<He>> kicks you in the stomach.<<violence 10>><<hitstat>><<bruise face>>
<</if>>
<<elseif $enemyanger + $rng lte 200 and $mouthuse is 0>>
<<if $pullaway is 1>><<set $pullaway to 0>>
Saliva drips from her pussy.
<<else>>
<<if $position is "wall">>
<<if $penisexist is 1>>
<<He>> kicks your <<penisstop>><<violence 20>><<hitstat>><<bruise penis>><<set $speechbeat to 1>>
<<elseif $vaginaexist is 1>>
<<He>> kicks your <<pussystop>><<violence 20>><<hitstat>><<bruise vagina>><<set $speechbeat to 1>>
<</if>>
<<else>>
<span class="purple"><<He>> wraps <<his>> legs around your head and presses <<his>> pussy against your mouth.</span>
<<submission 5>><<set $mouthuse to "othervagina">><<set $vagina3 to "mouth">><<set $mouthstate to "othervagina">><<violence 3>><<bruise face>><<set $speechvaginamouth to 1>>
<</if>>
<</if>>
<<else>>
<<if $position is "wall">>
<<if $penisexist is 1>>
<<He>> kicks your <<penisstop>><<violence 20>><<hitstat>><<bruise penis>><<set $speechbeat to 1>>
<<elseif $vaginaexist is 1>>
<<He>> kicks your <<pussystop>><<violence 20>><<hitstat>><<bruise vagina>><<set $speechbeat to 1>>
<</if>>
<<else>>
<<He>> kicks you in the face.<<violence 10>><<bruise face>><<set $speechbeat to 1>><<hitstat>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth3 is "thigh">>
<<He>> kisses and licks your thigh.<<neutral 5>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth3 is "bottom">>
<<He>> kisses and licks your <<bottomstop>><<neutral 5>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth3 is "anus">>
<<if $rng gte 101>><span class="purple"><<He>> retracts <<his>> tongue from your anus.</span><<sex 30>><<set $mouth3 to "anusimminent">><<bruise anus>><<violence 1>><<set $anusstate to "othermouthimminent">>
<<elseif $rng gte 1>>
<<if $enemyarousal lte ($enemyarousalmax / 5)>>
<<He>> caresses your anus with <<his>> tongue.<<sex 30>><<bruise anus>><<violence 1>>
<<elseif $enemyarousal lte (($enemyarousalmax / 5) * 2)>>
<<His>> tongue probes inside your <<bottomstop>><<sex 30>><<bruise anus>><<violence 1>>
<<elseif $enemyarousal lte (($enemyarousalmax / 5) * 3)>>
<<He>> circles <<his>> tongue inside your <<bottomstop>><<sex 30>><<bruise anus>><<violence 1>>
<<elseif $enemyarousal lte (($enemyarousalmax / 5) * 4)>>
<<He>> presses <<his>> mouth firmly against your <<bottomcomma>> letting <<him>> push <<his>> tongue deeper into your anus.<<sex 30>><<bruise anus>><<violence 1>>
<<else>>
Repeatedly thrusting and retracting, <<he>> fucks your <<bottom>> with <<his>> tongue.<<sex 30>><<bruise anus>><<violence 1>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth3 is "anusimminent">>
<<if $rng gte 101>><span class="blue"><<He>> stops pressing <<his>> tongue against your anus.</span><<set $mouth3 to "anusentrance">><<set $anusstate to "othermouthentrance">>
<<elseif $rng gte 1>>
<<if $noanal is 0>>
<<if $analvirginity is 0>><span class="pink"><<He>> pushes <<his>> tongue into your anus.</span><<sex 30>><<set $mouth3 to "anus">><<analstat>><<bruise anus>><<violence 1>><<raped>><<set $anusstate to "othermouth">>
<<elseif $analvirginity is 1>><span class="pink"><<He>> pushes <<his>> tongue into your virgin anus,</span><span class="red"> violating you in a way you hadn't conceived of.</span><<sex 100>><<set $mouth3 to "anus">><<set $analvirginity to 0>><<bruise anus>><<analstat>><<violence 100>><<raped>><<set $anusstate to "othermouth">>
<</if>>
<<else>>
Respecting your wishes, <<he>> does not penetrate your <<bottom>> with <<his>> tongue, instead licking your anus.<<sex 15>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth3 is "anusentrance">>
<<if $rng gte 101>><span class="lblue"><<He>> moves <<his>> head away from your <<bottomstop>></span><<set $mouth3 to 0>><<set $anususe to 0>><<set $anusstate to 0>>
<<if $vagina3 is "othermouth">>
<<set $vagina3 to 0>>
<</if>>
<<if $penis3 is "othermouth">>
<<set $penis3 to 0>>
<</if>>
<<elseif $rng gte 1>>
<<if $loweranusexposed is 0>><<He>> circles <<his>> tongue around your anus through your $lowerclothes.<<sex 5>><<set $lowerintegrity -= 10>>
<<elseif $loweranusexposed is 1>><<set $rng to random(1, 100)>>
<<if $underanusexposed is 0>><<He>> circles <<his>> tongue around your anus through your $underclothes.<<sex 5>><<set $underintegrity -= 10>>
<<elseif $underanusexposed is 1>>
<<if $rng gte 71>>
<<if $noanal is 1>>
<span class="purple"><<He>> presses <<his>> tongue against your anus.</span><<sex 20>><<set $mouth3 to "anusimminent">><<set $anusstate to "othermouthimminent">>
<<else>>
<span class="purple"><<He>> presses <<his>> tongue against your anus, preparing to penetrate you.</span><<sex 20>><<set $mouth3 to "anusimminent">><<set $anusstate to "othermouthimminent">>
<</if>>
<<elseif $rng gte 1>><<He>> kisses and licks your <<bottomstop>><<sex 10>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth3 is "vagina">>
<<if $rng gte 101>><span class="purple"><<He>> retracts <<his>> tongue from your <<pussystop>></span><<sex 30>><<set $mouth3 to "vaginaimminent">><<bruise vagina>><<violence 1>><<set $vaginastate to "othermouthimminent">>
<<elseif $rng gte 1>>
<<if $enemyarousal lte ($enemyarousalmax / 5)>>
<<He>> caresses your vagina with <<his>> tongue.<<sex 30>><<bruise vagina>><<violence 1>>
<<elseif $enemyarousal lte (($enemyarousalmax / 5) * 2)>>
<<He>> presses down on your clit with <<his>> teeth while exploring your vagina with <<his>> tongue.<<sex 30>><<bruise vagina>><<violence 1>>
<<elseif $enemyarousal lte (($enemyarousalmax / 5) * 3)>>
<<He>> circles <<his>> tongue around your vagina.<<sex 30>><<bruise vagina>><<violence 1>>
<<elseif $enemyarousal lte (($enemyarousalmax / 5) * 4)>>
<<He>> presses <<his>> mouth firmly against your <<pussycomma>> then pushes <<his>> tongue deeper into your vagina. <<He>> slowly pulls out again, then takes a deep breath.<<sex 30>><<bruise vagina>><<violence 1>>
<<else>>
Repeatedly thrusting and retracting, <<he>> fucks your <<pussy>> with <<his>> tongue.<<sex 30>><<bruise vagina>><<violence 1>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth3 is "vaginaimminent">>
<<if $rng gte 101>><span class="blue"><<He>> stops pressing <<his>> tongue against your <<pussystop>></span><<set $mouth3 to "vaginaentrance">><<set $vaginastate to "othermouthentrance">>
<<elseif $rng gte 1>>
<<if $novaginal is 0>>
<<if $vaginalvirginity is 0>><span class="pink"><<He>> pushes <<his>> tongue between your <<pussy>> lips.</span><<sex 30>><<set $mouth3 to "vagina">><<vaginalstat>><<bruise vagina>><<violence 1>><<raped>><<vaginaraped>><<set $vaginastate to "othermouth">>
<<elseif $vaginalvirginity is 1>><span class="pink"><<He>> pushes <<his>> tongue into your virgin pussy,</span><span class="red"> breaking your hymen and forever robbing you of your purity.</span><<sex 100>><<set $mouth3 to "vagina">><<set $vaginalvirginity to 0>><<bruise vagina>><<vaginalstat>><<violence 100>><<raped>><<vaginaraped>><<set $vaginastate to "othermouth">>
<</if>>
<<else>>
Respecting your wishes, <<he>> does not penetrate your <<pussy>> with <<his>> tongue, instead running <<his>> tongue up and down your labia.<<sex 15>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth3 is "vaginaentrance">>
<<if $rng gte 101>><span class="lblue"><<He>> moves <<his>> head away from your <<pussystop>></span><<set $mouth3 to 0>><<set $vaginause to 0>><<set $vaginastate to 0>>
<<if $vagina3 is "othermouth">>
<<set $vagina3 to 0>>
<</if>>
<<if $penis3 is "othermouth">>
<<set $penis3 to 0>>
<</if>>
<<elseif $rng gte 1>>
<<if $lowervaginaexposed is 0>><<He>> traces the outline of your <<pussy>> with <<his>> tongue through your $lowerclothes.<<sex 5>><<set $lowerintegrity -= 10>>
<<elseif $lowervaginaexposed is 1>><<set $rng to random(1, 100)>>
<<if $undervaginaexposed is 0>><<He>> traces the outline of your <<pussy>> with <<his>> tongue through your $underclothes.<<sex 5>><<set $underintegrity -= 10>>
<<elseif $undervaginaexposed is 1>>
<<if $rng gte 71>>
<<if $novaginal is 1>>
<span class="purple"><<He>> presses <<his>> lips against your <<pussystop>></span><<sex 20>><<set $mouth3 to "vaginaimminent">><<set $vaginastate to "othermouthimminent">>
<<else>>
<span class="purple"><<He>> presses <<his>> lips against your <<pussycomma>> preparing to fuck you with <<his>> tongue.</span><<sex 20>><<set $mouth3 to "vaginaimminent">><<set $vaginastate to "othermouthimminent">>
<</if>>
<<elseif $rng gte 1>><<He>> blows on your clit and runs <<his>> tongue around your labia.<<sex 10>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth3 is "penis">>
<<if $rng gte 101>><span class="purple"><<He>> moves <<his>> head back, releasing your <<penis>> from <<his>> mouth.</span><<sex 30>><<set $mouth3 to "penisimminent">><<bruise penis>><<violence 1>><<set $penisstate to "othermouthimminent">>
<<elseif $rng gte 1>>
<<if $enemyarousal lte ($enemyarousalmax / 5)>>
<<He>> slowly caresses your shaft with <<his>> tongue.<<sex 30>><<bruise penis>><<violence 1>>
<<elseif $enemyarousal lte (($enemyarousalmax / 5) * 2)>>
Eyes fixed on your face, <<he>> wraps <<his>> tongue around your <<penis>> and sucks.<<sex 30>><<bruise penis>><<violence 1>>
<<elseif $enemyarousal lte (($enemyarousalmax / 5) * 3)>>
<<He>> squeezes <<his>> lips around your <<peniscomma>> and circles <<his>> tongue around your glans.<<sex 30>><<bruise penis>><<violence 1>>
<<elseif $enemyarousal lte (($enemyarousalmax / 5) * 4)>>
<<He>> takes you deeper into <<his>> mouth, until your <<penis>> disappears inside <<him>> completely. <<He>> slowly pushes you out again, then takes a deep breath.<<sex 30>><<bruise penis>><<violence 1>>
<<else>>
<<He>> repeatedly swallows and expels your <<peniscomma>> fucking you with <<his>> mouth.<<sex 30>><<bruise penis>><<violence 1>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth3 is "penisimminent">>
<<if $rng gte 101>><span class="blue"><<He>> stops pressing <<his>> lips against your <<penisstop>></span><<set $mouth3 to "penisentrance">><<set $penisstate to "othermouthentrance">>
<<elseif $rng gte 1>>
<<if $nopenile is 0>>
<<if $penilevirginity is 0>><span class="pink"><<He>> pushes <<his>> lips against your <<peniscomma>> taking you into <<his>> mouth.</span><<sex 30>><<set $mouth3 to "penis">><<penilestat>><<bruise penis>><<violence 1>><<raped>><<penisraped>><<set $penisstate to "othermouth">>
<<elseif $penilevirginity is 1>><span class="pink"><<He>> pushes <<his>> lips against your virgin penis, taking you into <<his>> mouth,</span><span class="red"> separating your foreskin from your glans and forever robbing you of your purity.</span><<sex 100>><<set $mouth3 to "penis">><<set $penilevirginity to 0>><<bruise penis>><<penilestat>><<violence 100>><<raped>><<penisraped>><<set $penisstate to "othermouth">>
<</if>>
<<else>>
Respecting your wishes, <<he>> does not envelope your <<penis>> with <<his>> mouth, instead kissing the tip of your glans.<<sex 15>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth3 is "penisentrance">>
<<if $rng gte 101>><span class="lblue"><<He>> moves <<his>> head away from your <<penisstop>></span><<set $mouth3 to 0>><<set $penisuse to 0>><<set $penisstate to 0>>
<<if $vagina3 is "othermouth">>
<<set $vagina3 to 0>>
<</if>>
<<if $penis3 is "othermouth">>
<<set $penis3 to 0>>
<</if>>
<<elseif $rng gte 1>>
<<if $lowervaginaexposed is 0>><<He>> traces the outline of your <<penis>> with <<his>> tongue through your $lowerclothes.<<sex 5>><<set $lowerintegrity -= 10>>
<<elseif $lowervaginaexposed is 1>><<set $rng to random(1, 100)>>
<<if $undervaginaexposed is 0>><<He>> traces the outline of your <<penis>> with <<his>> tongue through your $underclothes.<<sex 5>><<set $underintegrity -= 10>>
<<elseif $undervaginaexposed is 1>>
<<if $rng gte 71>>
<<if $nopenile is 1>>
<span class="purple"><<He>> presses <<his>> lips against your <<penisstop>></span><<sex 20>><<set $mouth3 to "penisimminent">><<set $penisstate to "othermouthimminent">>
<<else>>
<span class="purple"><<He>> presses <<his>> lips against your <<peniscomma>> preparing to take you in <<his>> mouth proper.</span><<sex 20>><<set $mouth3 to "penisimminent">><<set $penisstate to "othermouthimminent">>
<</if>>
<<elseif $rng gte 1>><<He>> blows on and licks the tip of your <<penisstop>><<sex 10>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth3 is "kiss">>
<<if $speechvaginavirgin isnot 1 and $speechpenisvirgin isnot 1 and $speechanusvirgin isnot 1 and $speechmouthvirgin isnot 1>>
<<if $rng gte 101>>
<span class="lblue"><<He>> pulls <<his>> mouth away from yours.</span><<set $mouth3 to 0>><<set $mouthuse to 0>><<set $mouthstate to 0>>
<<else>>
<<if $enemyanger lte 20>>
<<He>> explores your mouth with <<his>> tongue.<<sex 2>>
<<else>>
<<He>> thrusts <<his>> tongue deep into your mouth.<<violence 1>>
<</if>>
<</if>>
<<else>>
<span class="lblue"><<He>> pulls <<his>> mouth away from yours.</span><<set $mouthuse to 0>><<set $mouth3 to 0>><<set $mouthstate to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth3 is "kissimminent">>
<<if $speechvaginavirgin isnot 1 and $speechpenisvirgin isnot 1 and $speechanusvirgin isnot 1 and $speechmouthvirgin isnot 1>>
<<if $rng gte 101>>
<span class="lblue"><<He>> pulls <<his>> mouth away from yours.</span><<set $mouth3 to 0>><<set $mouthuse to 0>><<set $mouthstate to 0>>
<<elseif $rng lte 100>>
<<He>> pushes <<his>> tongue between your lips.<<set $mouth3 to "kiss">><<set $mouthstate to "kiss">><<sex 2>>
<<else>>
<<if $enemyanger lte 20>>
<<He>> gently probes your lips with <<his>> tongue.<<sex 2>>
<<else>>
<<He>> bites and toys with your lips.<<violence 1>>
<</if>>
<</if>>
<<else>>
<span class="lblue"><<He>> pulls <<his>> mouth away from yours.</span><<set $mouthuse to 0>><<set $mouth3 to 0>><<set $mouthstate to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth3 is "kissentrance">>
<<if $speechvaginavirgin isnot 1 and $speechpenisvirgin isnot 1 and $speechanusvirgin isnot 1 and $speechmouthvirgin isnot 1>>
<<if $rng gte 101>>
<span class="lblue"><<He>> pulls <<his>> mouth away from yours.</span><<set $mouth3 to 0>><<set $mouthuse to 0>><<set $mouthstate to 0>>
<<elseif $rng lte 100>>
<<He>> pulls you closer and presses your lips together in a kiss.<<set $mouth3 to "kissimminent">><<set $mouthstate to "kissimminent">><<sex 2>>
<<else>>
<<if $enemyanger lte 20>>
<<He>> gently brushes <<his>> lips against yours.<<sex 1>>
<<else>>
<<He>> bites your lower lip.<<violence 1>>
<</if>>
<</if>>
<<else>>
<span class="lblue"><<He>> pulls <<his>> mouth away from yours.</span><<set $mouthuse to 0>><<set $mouth3 to 0>><<set $mouthstate to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth3 is 0>>
<<if $speechvaginavirgin is 1>>
<<if $enemyanger lte 60>>
<<He>> speaks. "You were a virgin! I can't believe my luck!"
<<else>>
<<He>> speaks. "I felt your hymen tear bitch. Something to remember me by."
<</if>>
<<elseif $speechpenisvirgin is 1>>
<<if $enemyanger lte 60>>
<<He>> speaks. "AHH! This was your first time wasn't it? It feels so good!"
<<else>>
<<He>> speaks. "How's it feel to have your virgin dick broken in? Feels amazing for me."
<</if>>
<<elseif $speechanusvirgin is 1>>
<<if $enemyanger lte 60>>
<<He>> speaks. "It's so tight! This must be the first time your ass has been used like this."
<<else>>
<<He>> speaks. "It's so tight! This must be the first time your ass has been used like this. I've got plenty more work to do before you're properly broken in."
<</if>>
<<elseif $speechmouthvirgin is 1>>
<<if $enemyanger lte 60>>
<<He>> speaks. "Is this the first time you've tasted dick?"
<<else>>
<<He>> speaks. "Is this the first time you've tasted dick? You'll be a cum-addicted cock slave soon."
<</if>>
<<elseif $speechcum is 1 and $rng gte 61 and $speechorgasmrepeat lte 1 and $speechorgasmcount lte 6>>
<<cumspeech>>
<<elseif $rng gte 61>>
<<combatspeech>><<neutral 1>>
<<elseif $rng gte 91>>
<<basespeech>><<neutral 1>>
<<else>>
<<set $rng to random(1, 100)>>
<<if $enemyanger + $rng lte 20>><<He>> <<admires>> your body.<<neutral 1>>
<<elseif $enemyanger + $rng lte 25>>
<<if $position is "wall">>
<<He>> <<admires>> your helpless <<bottomstop>><<neutral 1>>
<<else>>
<<He>> <<admires>> your hair.<<neutral 1>>
<</if>>
<<elseif $enemyanger + $rng lte 30>>
<<if $position is "wall">>
<<He>> <<admires>> your helpless hips.<<neutral 1>>
<<else>>
<<He>> <<admires>> your chest.<<neutral 1>>
<</if>>
<<elseif $enemyanger + $rng lte 35>>
<<He>> <<admires>> your legs.<<neutral 1>>
<<elseif $enemyanger + $rng lte 40>>
<<if $position is "wall">>
<<He>> <<admires>> your helpless legs.<<neutral 1>>
<<else>>
<<He>> <<admires>> your face.<<neutral 1>>
<</if>>
<<elseif $enemyanger + $rng lte 45>>
<<if $position is "wall">>
<<He>> kisses your helpless thighs.<<neutral 3>>
<<else>>
<<He>> kisses you on the forehead.<<neutral 3>>
<</if>>
<<elseif $enemyanger + $rng lte 50>>
<<if $position is "wall">>
<<He>> kisses you on the hips.<<neutral 3>>
<<else>>
<<He>> kisses you on the cheek.<<neutral 3>>
<</if>>
<<elseif $enemyanger + $rng lte 55>>
<<if $position is "wall">>
<<He>> licks your helpless thighs.<<neutral 3>>
<<else>>
<<He>> kisses your neck.<<neutral 3>>
<</if>>
<<elseif $enemyanger + $rng lte 60>>
<<if $position is "wall">>
<<He>> licks your helpless hips.<<neutral 3>>
<<else>>
<<He>> licks your cheek.<<neutral 3>>
<</if>>
<<elseif $enemyanger + $rng lte 80>><<neutral 10>>
<<if $position is "wall">>
<<He>> licks your helpless legs.<<neutral 3>>
<<else>>
<<if $mouthuse is 0>>
<span class="blue"><<He>> moves <<his>> lips close to yours, about to kiss.</span><<set $mouthuse to "kiss">><<set $mouthstate to "kissentrance">><<set $mouth3 to "kissentrance">><<sex 1>>
<<else>>
<<He>> licks your cheek.
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 84>><<neutral 10>>
<<if $anususe is 0 and $vagina3 is 0 and $analdisable is "f">>
<span class="blue"><<He>> kneels behind you. You feel <<his>> breath on your <<bottomstop>></span><<set $anususe to "othermouth">><<set $anusstate to "othermouthentrance">><<set $mouth3 to "anusentrance">><<set $vagina3 to "othermouth">><<sex 1>>
<<elseif $anususe is 0 and $penis3 is 0 and $analdisable is "f">>
<span class="blue"><<He>> kneels behind you. You feel <<his>> breath on your <<bottomstop>></span><<set $anususe to "othermouth">><<set $anusstate to "othermouthentrance">><<set $mouth3 to "anusentrance">><<set $penis3 to "othermouth">><<sex 1>>
<</if>>
<<elseif $enemyanger + $rng lte 92>><<neutral 10>>
<<if $vaginause is 0 and $vagina3 is 0 and $vaginaexist is 1>>
<span class="blue"><<He>> kneels beside you. You feel <<his>> breath on your <<pussystop>></span><<set $vaginause to "othermouth">><<set $vaginastate to "othermouthentrance">><<set $mouth3 to "vaginaentrance">><<set $vagina3 to "othermouth">><<sex 1>>
<<elseif $vaginause is 0 and $penis3 is 0 and $vaginaexist is 1>>
<span class="blue"><<He>> kneels beside you. You feel <<his>> breath on your <<pussystop>></span><<set $vaginause to "othermouth">><<set $vaginastate to "othermouthentrance">><<set $mouth3 to "vaginaentrance">><<set $penis3 to "othermouth">><<sex 1>>
<<else>>
<<He>> breathes on your skin, making your hair stand on end.<<neutral 1>>
<</if>>
<<elseif $enemyanger + $rng lte 100>><<neutral 10>>
<<if $penisuse is 0 and $penis3 is 0 and $penisexist is 1>>
<span class="blue"><<He>> kneels beside you. You feel <<his>> breath on your <<penisstop>></span><<set $penisuse to "othermouth">><<set $penisstate to "othermouthentrance">><<set $mouth3 to "penisentrance">><<set $vagina3 to "othermouth">><<sex 1>>
<<elseif $penisuse is 0 and $vagina3 is 0 and $penisexist is 1>>
<span class="blue"><<He>> kneels beside you. You feel <<his>> breath on your <<penisstop>></span><<set $penisuse to "othermouth">><<set $penisstate to "othermouthentrance">><<set $mouth3 to "penisentrance">><<set $penis3 to "othermouth">><<sex 1>>
<<else>>
<<He>> breathes on your skin, making your hair stand on end.<<neutral 1>>
<</if>>
<<elseif $enemyanger + $rng lte 105>>
<<if $position is "wall">>
<<He>> kisses and caresses your helpless thighs with <<his>> tongue.<<neutral 10>>
<<else>>
<<He>> kisses and caresses your nipple with <<his>> tongue.<<neutral 10>>
<</if>>
<<elseif $enemyanger + $rng lte 110>>
<<if $position is "wall">>
<<He>> kisses and gently bites your helpless <<bottomstop>><<neutral 10>>
<<else>>
<<He>> kisses and gently bites you on the neck.<<neutral 10>>
<</if>>
<<elseif $enemyanger + $rng lte 115>>
<<He>> spits on your <<genitalsstop>><<neutral 5>>
<<elseif $enemyanger + $rng lte 120>>
<<He>> spits on your <<bottomstop>><<neutral 5>>
<<elseif $enemyanger + $rng lte 130>>
<<He>> spits on your stomach.<<neutral 5>>
<<elseif $enemyanger + $rng lte 140>>
<<if $position is "wall">>
<<He>> spits on your helpless thighs.<<neutral 5>>
<<else>>
<<He>> spits on your face.<<neutral 5>>
<</if>>
<<elseif $enemyanger + $rng lte 150>>
<<He>> bites your <<bottomstop>><<violence 10>><<hitstat>><<bruise bottom>>
<<elseif $enemyanger + $rng lte 160>>
<<if $position is "wall">>
<<He>> bites your thighs.<<violence 10>><<hitstat>><<bruise thigh>>
<<else>>
<<He>> bites your shoulders.<<violence 10>><<hitstat>><<bruise leftarm>><<bruise rightarm>>
<</if>>
<<elseif $enemyanger + $rng lte 170>>
<<if $position is "wall">>
<<He>> bites your hips.<<violence 10>><<hitstat>><<bruise tummy>>
<<else>>
<<He>> bites your neck.<<violence 10>><<hitstat>><<bruise neck>>
<</if>>
<<elseif $enemyanger + $rng lte 180>>
<<if $position is "wall">>
<<He>> bites your thighs.<<violence 10>><<hitstat>><<bruise thigh>>
<<else>>
<<He>> bites your cheek.<<violence 10>><<hitstat>><<bruise face>>
<</if>>
<<elseif $enemyanger + $rng gte 190>>
<<if $position is "wall">>
<<He>> bites your <<bottomstop>><<violence 10>><<hitstat>><<bruise bottom>>
<<else>>
<<He>> bites your <<breastsstop>><<violence 10>><<hitstat>><<bruise chest>>
<</if>>
<</if>>
<</if>>
<</if>>
<<manend>>
<<set $pullaway to 0>>
<</nobr>><</widget>>
:: Widgets Combat Man 4 [widget]
<<widget "man4">><<nobr>>
<<if $pronoun4 is "m">>
<<set $pronoun to "m">>
<</if>>
<<if $pronoun4 is "f">>
<<set $pronoun to "f">>
<</if>>
<<if $pronoun4 is "i">>
<<set $pronoun to "i">>
<</if>>
<<if $pronoun4 is "n">>
<<set $pronoun to "n">>
<</if>>
<<if $pronoun4 is "t">>
<<set $pronoun to "t">>
<</if>>
<<man4speech>>
<<set $intro4 to 1>>
<<if $lefthand4 is "spank">><<bruise bottom>><<hitstat>><<set $speechspank to 1>>
<<He>> spanks your <<bottom>>
<<if $lowerclothes isnot "naked" and $lowerstate is "waist">>
through your $lowerclothes.
<<elseif $underclothes isnot "naked" and $understate is "waist">>
through your $underclothes.
<<else>>
reddening your exposed skin.
<</if>>
<<violence 5>>
<</if>>
<<if $righthand4 is "spank">><<bruise bottom>><<hitstat>>
<<He>> spanks your <<bottom>><<set $speechspank to 1>>
<<if $lowerclothes isnot "naked" and $lowerstate is "waist">>
through your $lowerclothes.
<<elseif $underclothes isnot "naked" and $understate is "waist">>
through your $underclothes.
<<else>>
reddening your exposed skin.
<</if>>
<<violence 5>>
<</if>>
<<if $lefthand4 is "arms">>
<<if $enemytrust gte 20 and $enemyanger lte 20>><span class="lblue"><<He>> releases your arms.</span><<set $lefthand4 to 0>><<set $leftarm to 0>><<set $rightarm to 0>>
<<else>><<He>> grips your arms.
<<violence 6>><<bruise leftarm>><<bruise rightarm>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand4 is "arms">>
<<if $enemytrust gte 20 and $enemyanger lte 20>><span class="lblue"><<He>> releases your arms.</span><<set $righthand4 to 0>><<set $leftarm to 0>><<set $rightarm to 0>>
<<else>><<He>> grips your arms.
<<violence 6>><<bruise leftarm>><<bruise rightarm>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand4 is "leftarm">>
<<if $enemytrust gte 20 and $enemyanger lte 20>><span class="lblue"><<He>> releases your left arm.</span><<set $lefthand4 to 0>><<set $leftarm to 0>>
<<else>><<He>> grips your left arm.<<violence 3>><<bruise leftarm>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand4 is "leftarm">>
<<if $enemytrust gte 20 and $enemyanger lte 20>><span class="lblue"><<He>> releases your left arm.</span><<set $righthand4 to 0>><<set $leftarm to 0>>
<<else>><<He>> grips your left arm.<<violence 3>><<bruise leftarm>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand4 is "rightarm">>
<<if $enemytrust gte 20 and $enemyanger lte 20>><span class="lblue"><<He>> releases your right arm.</span><<set $lefthand4 to 0>><<set $rightarm to 0>>
<<else>><<He>> grips your right arm.<<violence 3>><<bruise rightarm>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand4 is "rightarm">>
<<if $enemytrust gte 20 and $enemyanger lte 20>><span class="lblue"><<He>> releases your right arm.</span><<set $righthand4 to 0>><<set $rightarm to 0>>
<<else>><<He>> grips your right arm.<<violence 3>><<bruise rightarm>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand4 is "vaginaentrance">>
<<if $rng gte 101>><span class="blue"><<He>> moves <<his>> left hand away from your <<pussystop>></span><<set $lefthand4 to 0>><<set $vaginause to 0>>
<<elseif $rng gte 81>><<He>> <<strokes>> your labia.<<neutral 10>>
<<elseif $rng gte 21>><<He>> gives your clitoris a tweak.<<set $speechclit to 1>><<neutral 10>>
<<elseif $rng lte 20>><span class="pink"><<He>> plunges a finger into your <<pussystop>></span><<neutral 15>><<set $lefthand4 to "vagina">><<set $speechvagina to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand4 is "vaginaentrance">>
<<if $rng gte 101>><span class="blue"><<He>> moves <<his>> right hand away from your <<pussystop>></span><<set $righthand4 to 0>><<set $vaginause to 0>>
<<elseif $rng gte 51>><<He>> <<strokes>> your labia.<<neutral 10>>
<<elseif $rng gte 21>><<He>> gives your clitoris a tweak.<<neutral 10>><<set $speechclit to 1>>
<<elseif $rng lte 20>><span class="pink"><<He>> plunges a finger into your warm <<pussystop>></span><<neutral 15>><<set $righthand4 to "vagina">><<set $speechvagina to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand4 is "penisentrance">>
<<if $rng gte 101>><span class="blue"><<He>> moves <<his>> left hand away from your <<penisstop>></span><<set $lefthand4 to 0>><<set $penisuse to 0>>
<<elseif $rng gte 51>><<He>> <<strokes>> your shaft.<<neutral 10>>
<<elseif $rng gte 21>><<He>> rubs your glans.<<neutral 10>><<set $speechglans to 1>>
<<elseif $rng lte 20>><span class="pink"><<He>> wraps <<his>> fingers around your <<penisstop>></span><<neutral 15>><<set $lefthand4 to "penis">><<set $speechpenis to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand4 is "penisentrance">>
<<if $rng gte 101>><span class="blue"><<He>> moves <<his>> right hand away from your <<penisstop>></span><<set $righthand4 to 0>><<set $penisuse to 0>>
<<elseif $rng gte 51>><<He>> <<strokes>> your shaft.<<neutral 10>>
<<elseif $rng gte 21>><<He>> rubs your glans.<<neutral 10>><<set $speechglans to 1>>
<<elseif $rng lte 20>><span class="pink"><<He>> wraps <<his>> fingers around your penis.</span><<neutral 15>><<set $righthand4 to "penis">><<set $speechpenis to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand4 is "vagina">>
<<if $rng gte 101>><span class="purple"><<He>> slides <<his>> finger out of your <<pussystop>></span><<set $lefthand4 to "vaginaentrance">><<neutral 15>>
<<elseif $rng lte 100>><<He>> <<strokes>> the inside of your <<pussycomma>><<neutral 20>><<set $speechvagina to 1>>
<<if $arousal gte 8000>>
causing involuntary shudders.
<<elseif $arousal gte 2000>>
coaxing out lewd fluid.
<<else>>
eager to explore it.
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand4 is "vagina">>
<<if $rng gte 101>><span class="purple"><<He>> slides <<his>> finger out of your <<pussystop>></span><<set $righthand4 to "vaginaentrance">><<neutral 15>>
<<elseif $rng lte 100>><<He>> <<strokes>> the inside of your <<pussycomma>><<neutral 20>><<set $speechvagina to 1>>
<<if $arousal gte 8000>>
causing you involuntary shudders.
<<elseif $arousal gte 2000>>
coaxing out lewd fluid.
<<else>>
invading your body in a most sordid manner.
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand4 is "penis">>
<<if $rng gte 101>><span class="purple"><<He>> releases your <<penis>> from <<his>> grip.</span><<set $lefthand4 to "penisentrance">><<neutral 15>>
<<elseif $rng lte 100>><<He>> massages the length of your <<peniscomma>><<neutral 20>><<set $speechpenis to 1>>
<<if $arousal gte 8000>>
causing you involuntary shudders.
<<elseif $arousal gte 2000>>
coaxing out lewd fluid.
<<else>>
exploiting your body's natural reactions in a most sordid manner.
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand4 is "penis">>
<<if $rng gte 101>><span class="purple"><<He>> releases your <<penis>> from <<his>> grip.</span><<set $righthand4 to "penisentrance">><<neutral 15>>
<<elseif $rng lte 100>><<He>> massages the length of your <<peniscomma>><<neutral 20>><<set $speechpenis to 1>>
<<if $arousal gte 8000>>
causing you involuntary shudders.
<<elseif $arousal gte 2000>>
coaxing out lewd fluid.
<<else>>
exploiting your body's natural reactions in a most sordid manner.
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand4 is "anusentrance">>
<<if $rng gte 101>><span class="blue"><<He>> moves <<his>> left hand away from your ass.</span><<set $lefthand4 to 0>><<set $vaginause to 0>>
<<elseif $rng gte 21>><<He>> <<strokes>> your anus.<<neutral 10>>
<<elseif $rng lte 20>><span class="pink"><<He>> plunges a finger into your ass.</span><<neutral 15>><<set $lefthand4 to "anus">><<set $speechanus to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand4 is "anusentrance">>
<<if $rng gte 101>><span class="blue"><<He>> moves <<his>> hand away from your ass.</span><<set $righthand4 to 0>><<set $vaginause to 0>>
<<elseif $rng gte 21>><<He>> <<strokes>> your anus.<<neutral 10>>
<<elseif $rng lte 20>><span class="pink"><<He>> plunges a finger into your ass.</span><<neutral 15>><<set $righthand4 to "anus">><<set $speechanus to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand4 is "anus">>
<<if $rng gte 101>><span class="purple"><<He>> slides <<his>> finger out of your ass.</span><<set $lefthand4 to "anusentrance">><<neutral 15>>
<<elseif $rng lte 100>><<He>> rhythmically slides <<his>> finger in and out of your ass,<<neutral 20>><<set $speechanus to 1>>
<<if $playergender is "m">>
teasing your prostate.
<<else>>
teasing your anus.
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand4 is "anus">>
<<if $rng gte 101>><span class="purple"><<He>> slides <<his>> finger out of your ass.</span><<set $righthand4 to "anusentrance">><<neutral 15>>
<<elseif $rng lte 100>><<He>> rhythmically slides <<his>> finger in and out of your ass,<<neutral 20>><<set $speechanus to 1>>
<<if $playergender is "m">>
teasing your prostate.
<<else>>
teasing your anus.
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand4 is "mouth">>
<<if $enemyanger lte 20 and $enemytrust gte 20>><span class="teal">Made confident by your accommodating behaviour, <<he>> releases <<his>> hand from your mouth.</span><<set $lefthand4 to 0>><<set $mouthuse to 0>>
<<else>><<He>> continues to clasp your mouth shut.<<violence 1>><<bruise face>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand4 is "mouth">>
<<if $enemyanger lte 20 and $enemytrust gte 20>><span class="teal">Made confident by your accommodating behaviour, <<he>> releases <<his>> hand from your mouth.</span><<set $righthand4 to 0>><<set $mouthuse to 0>>
<<else>><<He>> continues to clasp your mouth shut.<<violence 1>><<bruise face>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand4 is "throat">>
<<if $enemyanger gte 100>><<set $strangle += 1>>
<<if $strangle is 0>><<He>> strangles your throat.<<violence 5>><<bruise neck>><<bruise neck>><<set $speechthroat to 1>>
<<elseif $strangle lte 2>><span class="purple"><<He>> strangles your throat. You can't breathe!</span><<set $speechthroat to 1>>
<<violence 10>><<bruise neck>><<bruise neck>>
<<elseif $strangle lte 4>><span class="pink"><<He>> strangles your throat. You feel light-headed.</span><<set $speechthroat to 1>>
<<violence 20>><<bruise neck>><<bruise neck>>
<<elseif $strangle lte 6>><span class="pink"><<He>> strangles your throat. You see stars.</span><<set $speechthroat to 1>>
<<violence 40>><<bruise neck>><<bruise neck>>
<<elseif $strangle gte 8>><span class="red"><<He>> strangles your throat. You are suffocating.</span><<set $speechthroat to 1>>
<<violence 100>><<bruise neck>><<bruise neck>>
<</if>>
<<elseif $rng gte 81>><span class="teal"><<He>> releases <<his>> hand from your throat.</span> You gasp for air.
<<set $lefthand4 to 0>>
<<else>><<He>> holds you down by your throat.<<violence 1>>
<</if>><<bruise neck>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand4 is "throat">>
<<if $enemyanger gte 100>><<set $strangle += 1>>
<<if $strangle is 0>><<He>> strangles your throat.<<violence 5>><<bruise neck>><<bruise neck>><<set $speechthroat to 1>>
<<elseif $strangle lte 2>><<He>> strangles your throat. <span class="purple">You can't breathe!</span><<set $speechthroat to 1>>
<<violence 10>><<bruise neck>><<bruise neck>>
<<elseif $strangle lte 4>><<He>> strangles your throat. <span class="pink">You feel light-headed.</span><<set $speechthroat to 1>>
<<violence 20>><<bruise neck>><<bruise neck>>
<<elseif $strangle lte 6>><<He>> strangles your throat. <span class="pink">You see stars.</span> <<set $speechthroat to 1>>
<<violence 40>><<bruise neck>><<bruise neck>>
<<elseif $strangle gte 7>><<He>> strangles your throat. <span class="red">You are suffocating.</span><<set $speechthroat to 1>>
<<violence 100>><<bruise neck>><<bruise neck>>
<</if>>
<<elseif $rng gte 81>><span class="teal"><<He>> releases <<his>> hand from your throat.</span> You gasp for air.
<<set $righthand4 to 0>>
<<else>><<He>> holds you down by your throat.<<violence 1>>
<</if>><<bruise neck>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand4 is "underclothes" and $undertype is "chastity">>
<span class="blue"><<He>> tries to loosen your $underclothes.</span> <<His>> rough handling leaves you feeling more frustrated and aroused. <<He>> gives up after a few moments of impotent tugging, looking disappointed.<<neutral 1>><<set $enemyanger += 5>><<set $arousal += 5>><<set $lefthand4 to 0>><<set $speechchastity to 1>><<set $underintegrity -= 10>>
<</if>>
<<if $righthand4 is "underclothes" and $undertype is "chastity">>
<span class="blue"><<He>> tries to loosen your $underclothes.</span> <<His>> rough handling leaves you feeling more frustrated and aroused.<<He>> gives up after a few moments of impotent tugging, looking disappointed.<<neutral 1>><<set $enemyanger += 5>><<set $arousal += 5>><<set $righthand4 to 0>><<set $speechchastity to 1>><<set $underintegrity -= 10>>
<</if>>
<<if $lefthand4 is "underclothes">>
<<if $underclothes is "naked">><span class="purple"><<He>> casts aside the fabric.</span><<set $lefthand4 to 0>>
<<elseif $understruggle is 1>>You manage to keep <<him>> from pulling down your $underclothes.<<set $understruggle to 0>><<set $speechstripstruggle to 1>>
<<elseif $rng gte 101>><span class="blue"><<He>> releases <<his>> hand from your $underclothes.</span><<set $lefthand4 to 0>>
<<elseif $rng lte 100>>
<<if $skirt is 1>>
<<if $understate is "waist">><<He>> pulls your $underclothes down your thighs, <span class="lewd">revealing your <<genitalsstop>></span><<set $understate to "thighs">><<neutral 5>><<set $undervaginaexposed to 1>><<set $underanusexposed to 1>><<set $underexposed to 1>><<set $speechgenitals to 1>>
<<elseif $understate is "thighs">><<He>> pulls your $underclothes down to your knees.<<set $understate to "knees">><<neutral 1>>
<<elseif $understate is "knees">><<He>> pulls your $underclothes down to your ankles.<<set $understate to "ankles">><<neutral 1>>
<<elseif $understate is "ankles">><span class="purple"><<He> pulls your $underclothes off your legs.</span><<understrip>><<undernaked>><<neutral 3>><<set $lefthand4 to 0>><<clothesstripstat>>
<</if>>
<<elseif $lowerstate isnot "waist">>
<<if $understate is "waist">><<He>> pulls your $underclothes down your thighs, <span class="lewd">revealing your <<genitalsstop>></span><<set $understate to "thighs">><<neutral 5>><<set $undervaginaexposed to 1>><<set $underanusexposed to 1>><<set $underexposed to 1>><<set $speechgenitals to 1>>
<<elseif $understate is "thighs">><<He>> pulls your $underclothes down to your knees.<<set $understate to "knees">><<neutral 1>>
<<elseif $understate is "knees">><<He>> pulls your $underclothes down to your ankles.<<set $understate to "ankles">><<neutral 5>>
<<elseif $understate is "ankles">><span class="purple"><<He>> pulls your $underclothes off your legs.</span><<understrip>><<undernaked>><<neutral 3>><<set $lefthand4 to 0>><<clothesstripstat>>
<</if>>
<<else>><<He>> tugs on your $underclothes.<<neutral 1>><<set $underintegrity -= 10>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand4 is "underclothes">>
<<if $underclothes is "naked">><span class="purple"><<He>> casts aside the fabric.</span><<set $righthand4 to 0>>
<<elseif $understruggle is 1>>You manage to keep <<him>> from pulling down your $underclothes.<<set $understruggle to 0>><<set $speechstripstruggle to 1>>
<<elseif $rng gte 101>><span class="purple"><<He>> releases <<his>> hand from your $underclothes.</span><<set $righthand4 to 0>><<set $skirtuse to 0>>
<<elseif $rng lte 100>>
<<if $skirt is 1>>
<<if $understate is "waist">><<He>> pulls your $underclothes down your thighs, <span class="lewd">revealing your <<genitalsstop>></span><<set $understate to "thighs">><<neutral 5>><<set $undervaginaexposed to 1>><<set $underanusexposed to 1>><<set $underexposed to 1>><<set $speechgenitals to 1>>
<<elseif $understate is "thighs">><<He>> pulls your $underclothes down to your knees.<<set $understate to "knees">><<neutral 1>>
<<elseif $understate is "knees">><<He>> pulls your $underclothes down to your ankles.<<set $understate to "ankles">><<neutral 1>>
<<elseif $understate is "ankles">><span class="purple"><<He>> pulls your $underclothes off your legs.</span><<understrip>><<undernaked>><<neutral 3>><<set $righthand4 to 0>><<clothesstripstat>>
<</if>>
<<elseif $lowerstate isnot "waist">>
<<if $understate is "waist">><<He>> pulls your $underclothes down your thighs, <span class="lewd">revealing your <<genitalsstop>></span><<set $understate to "thighs">><<neutral 5>><<set $undervaginaexposed to 1>><<set $underanusexposed to 1>><<set $underexposed to 1>><<set $speechgenitals to 1>>
<<elseif $understate is "thighs">><<He>> pulls your $underclothes down to your knees.<<set $understate to "knees">><<neutral 1>>
<<elseif $understate is "knees">><<He>> pulls your $underclothes down to your ankles.<<set $understate to "ankles">><<neutral 5>>
<<elseif $understate is "ankles">><span class="purple"><<He>> pulls your $underclothes off your legs.</span><<understrip>><<undernaked>><<neutral 3>><<set $righthand4 to 0>><<clothesstripstat>>
<</if>>
<<else>><<He>> tugs on your $underclothes.<<neutral 1>><<set $underintegrity -= 10>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand4 is "hair">>
<<if $rng gte 101>><span class="lblue"><<He>> releases <<his>> hand from your hair.</span><<set $lefthand4 to 0>>
<<elseif $enemyanger gte 61>>With your hair in <<his>> grip, <<he>> yanks back your head.<<violence 4>><<set $speechhair to 1>>
<<elseif $enemyanger gte 21>>
<<He>> strokes your hair while holding it bunched in <<his>> grip.<<set $speechhair to 1>><<neutral 1>>
<<else>><span class="lblue"><<He>> releases <<his>> hand from your hair.</span><<set $lefthand4 to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand4 is "hair">>
<<if $rng gte 101>><span class="lblue"><<He>> releases <<his>> hand from your hair.</span><<set $righthand4 to 0>>
<<elseif $enemyanger gte 61>>With your hair in <<his>> grip, <<he>> yanks back your head.<<violence 4>><<set $speechhair to 1>>
<<elseif $enemyanger gte 21>>
<<He>> strokes your hair while holding it bunched in <<his>> grip.<<set $speechhair to 1>><<neutral 1>>
<<else>><span class="lblue"><<He>> releases <<his>> hand from your hair.</span><<set $righthand4 to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand4 is "lowerclothes">>
<<if $lowerclothes is "naked">><span class="purple"><<He>> casts aside the fabric.</span><<set $lefthand4 to 0>>
<<elseif $lowerstruggle is 1>><<set $lowerstruggle to 0>>You manage to keep <<him>> from stripping you of your $lowerclothes.<<set $speechstripstruggle to 1>>
<<elseif $rng gte 101>><<He>> releases <<his>> hand from your
$lowerclothes.<<set $lefthand4 to 0>>
<<elseif $rng lte 100>>
<<if $skirt is 1>>
<<if $skirtdown is 1>><<He>> lifts up your skirt,
exposing your
<<if $understate is "waist">>$underclothes.<<neutral 2>>
<<else>><span class="lewd"><<genitalsstop>></span><<neutral 5>><<set $speechgenitals to 1>>
<</if>><<set $skirtdown to 0>><<set $lowervaginaexposed to 1>><<set $loweranusexposed to 1>><<set $lowerexposed to 2>>
<<elseif $skirtdown is 0>>
<<if $lowerset is $upperset>>
<<if $upperstate is "waist">>
<<if $position is "wall">>
<<He>> tugs at your $upperclothes, tearing <<upperit>> before <span class="blue">letting go.</span><<set $lefthand4 to 0>><<neutral 1>><<set $lowerintegrity -= 10>>
<<else>>
<<He>> lifts your $upperclothes above your midriff.<<set $lowerstate to "midriff">><<set $upperstate to "midriff">><<neutral 1>>
<<if $upperstatetop is "waist">>
<<set $upperstatetop to "midriff">>
<</if>>
<</if>>
<<elseif $upperstate is "midriff">><<He>> lifts up your $upperclothes, <span class="lewd">exposing your <<breastsstop>></span><<set $lowerstate to "chest">><<set $upperstate to "chest">><<neutral 2>><<set $upperexposed to 2>><<set $speechbreasts to 1>>
<<if $upperstatetop is "midriff">>
<<set $upperstatetop to "chest">>
<</if>>
<<elseif $upperstate is "chest">><span class="purple"><<He>> pulls your $upperclothes off completely.</span><<lowerstrip>><<upperstrip>><<set $lowerstate to 0>><<set $upperstate to 0>><<uppernaked>><<lowernaked>><<set $lefthand4 to 0>><<neutral 3>><<clothesstripstat>>
<<if $upperstatetop is "chest">>
<<set $upperstatetop to 0>>
<</if>>
<</if>>
<<elseif $lowerset isnot $upperset>>
<<if $lowerstate is "waist">><<He>> pulls your $lowerclothes down to your thighs.
<<neutral 1>><<set $lowerstate to "thighs">>
<<elseif $lowerstate is "thighs">><<He>> pulls your $lowerclothes down to your knees.<<set $lowerstate to "knees">><<neutral 1>>
<<elseif $lowerstate is "knees">><<He>> pulls your $lowerclothes down to your ankles.<<set $lowerstate to "ankles">><<neutral 1>>
<<elseif $lowerstate is "ankles">><span class="purple"><<He>> completely pulls your $lowerclothes off your legs.</span><<lowerstrip>><<lowernaked>><<set $lefthand4 to 0>><<neutral 3>><<clothesstripstat>>
<</if>>
<</if>>
<</if>>
<<elseif $upperset is $lowerset>>
<<if $open is 1>>
<<if $upperstatetop is "chest">><<He>> tugs your $lowerclothes, pulling down your $upperclothes and <span class="lewd">revealing your <<breastsstop>></span><<set $upperstatetop to "midriff">><<neutral 3>><<set $upperexposed to 2>><<set $speechbreasts to 1>>
<<if $upperstate is "chest">>
<<set $upperstate to "midriff">>
<</if>>
<<if $lowerstate is "chest">>
<<set $lowerstate to "midriff">>
<</if>>
<<elseif $upperstatetop is "midriff">><<He>> tugs your $lowerclothes, pulling down your $upperclothes passed your midriff.<<set $upperstatetop to "waist">><<neutral 1>>
<<if $upperstate is "midriff">>
<<set $upperstate to "waist">>
<</if>>
<<if $lowerstate is "midriff">>
<<set $lowerstate to "waist">>
<</if>>
<<elseif $upperstatetop is "waist">><<He>> pulls your $upperclothes down to your thighs, revealing your
<<if $understate is "waist">>$underclothes<<neutral 2>>
<<else>><span class="lewd"><<genitalsstop>></span><<neutral 5>><<set $speechgenitals to 1>>
<</if>>
<<set $lowervaginaexposed to 1>><<set $loweranusexposed to 1>>
<<set $upperstatetop to "thighs">>
<<set $upperstate to "thighs">>
<<if $lowerstate is "waist">>
<<set $lowerstate to "thighs">>
<</if>>
<<elseif $upperstatetop is "thighs">><<He>> pulls your $upperclothes down to your knees.<<set $upperstatetop to "knees">><<set $upperstate to "knees">><<neutral 1>>
<<if $lowerstate is "thighs">>
<<set $lowerstate to "knees">>
<</if>>
<<elseif $upperstatetop is "knees">><<He>> pulls your $upperclothes down to your ankles.<<set $upperstatetop to "ankles">><<set $upperstate to "ankles">><<neutral 1>>
<<if $lowerstate is "knees">>
<<set $lowerstate to "ankles">>
<</if>>
<<elseif $upperstatetop is "ankles">><span class="purple"><<He>> pulls your $upperclothes off the bottom of your legs.</span><<upperstrip>><<neutral 5>><<set $upperstatetop to 0>><<set $upperstate to 0>><<uppernaked>>
<<if $lowerstate is "ankles">>
<<set $lowerstate to 0>><<lowerstrip>><<lowernaked>>
<</if>>
<</if>>
<<else>>
<<He>> tugs at your $lowerclothes, tearing <<lowerit>> before <span class="blue">letting go.</span><<set $lefthand4 to 0>><<set $lowerintegrity -= 10>><<neutral 1>>
<</if>>
<<elseif $upperset isnot $lowerset>>
<<if $lowerstate is "waist">><<He>> pulls down your $lowerclothes, exposing your
<<if $understate is "waist">>$underclothes.<<neutral 2>><<set $lowervaginaexposed to 1>><<set $loweranusexposed to 1>><<set $lowerexposed to 2>>
<<else>><span class="lewd"><<genitalsstop>></span><<neutral 5>><<set $speechgenitals to 1>>
<</if>>
<<set $lowervaginaexposed to 1>><<set $loweranusexposed to 1>><<set $lowerexposed to 2>>
<<set $lowerstate to "thighs">>
<<elseif $lowerstate is "thighs">><<He>> pulls your $lowerclothes down to your knees.<<set $lowerstate to "knees">><<neutral 1>>
<<elseif $lowerstate is "knees">><<He>> pulls your $lowerclothes down to your ankles.<<set $lowerstate to "ankles">><<neutral 1>>
<<elseif $lowerstate is "ankles">><span class="purple"><<He>> completely pulls your $lowerclothes off your legs.</span><<lowerstrip>><<lowernaked>><<set $lefthand4 to 0>><<neutral 3>><<clothesstripstat>>
<</if>>
<<else>><<He>> tugs at your $lowerclothes, tearing <<lowerit>> before <span class="blue">letting go.</span><<set $lefthand4 to 0>><<neutral 1>><<set $lowerintegrity -= 10>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand4 is "lowerclothes">>
<<if $lowerclothes is "naked">><span class="purple"><<He>> casts aside the fabric.</span><<set $righthand4 to 0>>
<<elseif $lowerstruggle is 1>><<set $lowerstruggle to 0>>You manage to keep <<him>> from stripping you of your $lowerclothes.<<set $speechstripstruggle to 1>>
<<elseif $rng gte 101>><span class="lblue"><<He>> releases <<his>> hand from your
$lowerclothes.</span><<set $righthand4 to 0>>
<<elseif $rng lte 100>>
<<if $skirt is 1>>
<<if $skirtdown is 1>><<He>> lifts up your skirt,
exposing your
<<if $understate is "waist">>$underclothes.<<neutral 2>>
<<else>><span class="lewd"><<genitalsstop>></span><<neutral 5>><<set $speechgenitals to 1>>
<</if>><<set $skirtdown to 0>><<set $lowervaginaexposed to 1>><<set $loweranusexposed to 1>><<set $lowerexposed to 2>>
<<elseif $skirtdown is 0>>
<<if $lowerset is $upperset>>
<<if $upperstate is "waist">>
<<if $position is "wall">>
<<He>> tugs at your $upperclothes, tearing <<upperit>> before <span class="blue">letting go.</span><<set $righthand4 to 0>><<neutral 1>><<set $lowerintegrity -= 10>>
<<else>>
<<He>> lifts your $upperclothes above your midriff.<<set $lowerstate to "midriff">><<set $upperstate to "midriff">><<neutral 1>>
<<if $upperstatetop is "waist">>
<<set $upperstatetop to "midriff">>
<</if>>
<</if>>
<<elseif $upperstate is "midriff">><<He>> lifts up your $upperclothes, <span class="lewd">exposing your <<breastsstop>></span><<set $lowerstate to "chest">><<set $upperstate to "chest">><<neutral 2>><<set $upperexposed to 2>><<set $speechbreasts to 1>>
<<if $upperstatetop is "midriff">>
<<set $upperstatetop to "chest">>
<</if>>
<<elseif $upperstate is "chest">><span class="purple"><<He>> pulls your $upperclothes off completely.</span><<set $lowerstate to 0>><<set $upperstate to 0>><<lowerstrip>><<upperstrip>><<uppernaked>><<lowernaked>><<set $righthand4 to 0>><<neutral 3>><<clothesstripstat>>
<<if $upperstatetop is "chest">>
<<set $upperstatetop to 0>>
<</if>>
<</if>>
<<elseif $lowerset isnot $upperset>>
<<if $lowerstate is "waist">><<He>> pulls your $lowerclothes down to your thighs.
<<neutral 1>><<set $lowerstate to "thighs">>
<<elseif $lowerstate is "thighs">><<He>> pulls your $lowerclothes down to your knees.<<set $lowerstate to "knees">><<neutral 1>>
<<elseif $lowerstate is "knees">><<He>> pulls your $lowerclothes down to your ankles.<<set $lowerstate to "ankles">><<neutral 1>>
<<elseif $lowerstate is "ankles">><span class="purple"><<He>> pulls your $lowerclothes off your legs.</span><<lowerstrip>><<lowernaked>><<set $righthand4 to 0>><<neutral 3>><<clothesstripstat>>
<</if>>
<</if>>
<</if>>
<<elseif $upperset is $lowerset>>
<<if $open is 1>>
<<if $upperstatetop is "chest">><<He>> tugs your $lowerclothes, pulling down your $upperclothes and <span class="lewd">revealing your <<breastsstop>></span><<set $upperstatetop to "midriff">><<neutral 3>><<set $upperexposed to 2>><<set $speechbreasts to 1>>
<<if $upperstate is "chest">>
<<set $upperstate to "midriff">>
<</if>>
<<if $lowerstate is "chest">>
<<set $lowerstate to "midriff">>
<</if>>
<<elseif $upperstatetop is "midriff">><<He>> tugs your $lowerclothes, pulling down your $upperclothes pass your midriff.<<set $upperstatetop to "waist">><<neutral 1>>
<<if $upperstate is "midriff">>
<<set $upperstate to "waist">>
<</if>>
<<if $lowerstate is "midriff">>
<<set $lowerstate to "waist">>
<</if>>
<<elseif $upperstatetop is "waist">><<He>> pulls your $upperclothes down to your thighs, revealing your
<<if $understate is "waist">>$underclothes<<neutral 2>>
<<else>><span class="lewd"><<genitalsstop>></span><<neutral 5>><<set $speechgenitals to 1>>
<</if>>
<<set $lowervaginaexposed to 1>><<set $loweranusexposed to 1>><<set $lowerexposed to 2>>
<<set $upperstatetop to "thighs">><<set $upperstate to "thighs">>
<<if $lowerstate is "waist">>
<<set $lowerstate to "thighs">>
<</if>>
<<elseif $upperstatetop is "thighs">><<He>> pulls your $upperclothes down to your knees.<<set $upperstatetop to "knees">><<set $upperstate to "knees">><<neutral 1>>
<<if $lowerstate is "thighs">>
<<set $lowerstate to "knees">>
<</if>>
<<elseif $upperstatetop is "knees">><<He>> pulls your $upperclothes down to your ankles.<<set $upperstatetop to "ankles">><<set $upperstate to "ankles">><<neutral 1>>
<<if $lowerstate is "knees">>
<<set $lowerstate to "ankles">>
<</if>>
<<elseif $upperstatetop is "ankles">><span class="purple"><<He>> pulls your $upperclothes off the bottom of your legs.</span><<upperstrip>><<neutral 5>><<set $upperstatetop to 0>><<set $upperstate to 0>><<uppernaked>>
<<if $lowerstate is "ankles">>
<<set $lowerstate to 0>><<lowerstrip>><<lowernaked>>
<</if>>
<</if>>
<<else>>
<<He>> tugs at your $lowerclothes, tearing <<lowerit>> before <span class="blue">letting go.</span><<set $righthand4 to 0>><<set $lowerintegrity -= 10>><<neutral 1>>
<</if>>
<<elseif $upperset isnot $lowerset>>
<<if $lowerstate is "waist">><<He>> pulls down your $lowerclothes, exposing your
<<if $understate is "waist">>$underclothes.<<neutral 2>><<set $lowervaginaexposed to 1>><<set $loweranusexposed to 1>>
<<else>><span class="lewd"><<genitalsstop>></span><<neutral 5>><<set $speechgenitals to 1>>
<</if>>
<<set $lowervaginaexposed to 1>><<set $loweranusexposed to 1>><<set $lowerexposed to 2>>
<<set $lowerstate to "thighs">>
<<elseif $lowerstate is "thighs">><<He>> pulls your $lowerclothes down to your knees.<<set $lowerstate to "knees">><<neutral 1>>
<<elseif $lowerstate is "knees">><<He>> pulls your $lowerclothes down to your ankles.<<set $lowerstate to "ankles">><<neutral 1>>
<<elseif $lowerstate is "ankles">><span class="purple"><<He>> pulls your $lowerclothes off your legs.</span><<lowerstrip>><<lowernaked>><<set $righthand4 to 0>><<neutral 3>><<clothesstripstat>>
<</if>>
<<else>><<He>> tugs at your $lowerclothes, tearing <<lowerit>> before <span class="blue">letting go.</span><<set $righthand4 to 0>><<neutral 1>><<set $lowerintegrity -= 10>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand4 is "upperclothes">>
<<if $upperclothes is "naked">><span class="purple"><<He>> casts aside the fabric.</span><<set $lefthand4 to 0>>
<<elseif $upperstruggle is 1>><<set $upperstruggle to 0>>You manage to keep <<him>> from stripping you of your $upperclothes.<<set $speechstripstruggle to 1>>
<<elseif $rng gte 101>><span class="lblue"><<He>> releases <<his>> hand from your $upperclothes.</span><<set $lefthand4 to 0>>
<<elseif $rng lte 100>>
<<if $upperset isnot $lowerset>>
<<if $open is 1>>
<<if $upperstatetop is "chest">><<He>> pulls down your $upperclothes, <span class="lewd">revealing your <<breastsstop>></span><<set $upperstatetop to "midriff">><<neutral 3>><<set $upperexposed to 2>><<set $speechbreasts to 1>>
<<if $upperstate is "chest">>
<<set $upperstate to "midriff">>
<</if>>
<<elseif $upperstatetop is "midriff">><<He>> pulls your $upperclothes down past your midriff.<<set $upperstatetop to "waist">><<neutral 1>>
<<if $upperstate is "midriff">>
<<set $upperstate to "waist">>
<</if>>
<<elseif $upperstatetop is "waist">><<He>> pulls your $upperclothes down to your thighs.
<<set $upperstatetop to "thighs">>
<<set $upperstate to "thighs">>
<<elseif $upperstatetop is "thighs">><<He>> pulls your $upperclothes down to your knees.<<set $upperstatetop to "knees">><<set $upperstate to "knees">><<neutral 1>>
<<elseif $upperstatetop is "knees">><<He>> pulls your $upperclothes down to your ankles.<<set $upperstatetop to "ankles">><<set $upperstate to "ankles">><<neutral 1>>
<<elseif $upperstatetop is "ankles">><span class="purple"><<He>> pulls your $upperclothes off the bottom of your legs.</span><<upperstrip>><<neutral 5>><<set $upperstatetop to 0>><<set $upperstate to 0>><<uppernaked>><<set $lefthand4 to 0>>
<</if>>
<<elseif $open is 0>>
<<if $position is "wall">>
<<He>> tugs at your $upperclothes, tearing <<upperit>> before <span class="blue">letting go.</span><<set $lefthand4 to 0>><<set $upperintegrity -= 10>><<neutral 1>>
<<elseif $position isnot "wall">>
<<if $upperstate is "waist">><<He>> lifts up your $upperclothes, exposing your midriff.<<set $upperstate to "midriff">><<neutral 1>>
<<elseif $upperstate is "midriff">><<He>> lifts up your $upperclothes, <span class="lewd">exposing your <<breastsstop>></span><<set $upperstate to "chest">><<neutral 2>><<set $upperexposed to 2>><<set $speechbreasts to 1>>
<<elseif $upperstate is "chest">><span class="purple"><<He>> removes your $upperclothes completely.</span><<upperstrip>><<uppernaked>><<set $lefthand4 to 0>><<neutral 3>><<clothesstripstat>>
<</if>>
<</if>>
<</if>>
<<elseif $upperset is $lowerset>>
<<if $open is 1>>
<<if $lowerstate is $upperstatetop and $lowerstate is $upperstate and $skirt is 1>>
<<if $position is "wall">>
<<He>> tugs at your $upperclothes, tearing <<upperit>> before <span class="blue">letting go.</span><<set $lefthand4 to 0>><<set $upperintegrity -= 10>><<neutral 1>>
<<elseif $position isnot "wall">>
<<if $upperstate is "waist">><<He>> pulls your bundled $upperclothes up past your midriff.<<set $upperstate to "midriff">><<neutral 1>>
<<set $lowerstate to "midriff">>
<<set $upperstatetop to "midriff">>
<<elseif $upperstate is "midriff">><<He>> pulls your bundled $upperclothes up past your <<breastsstop>><<set $upperstate to "chest">><<neutral 2>><<set $upperexposed to 2>><<set $speechbreasts to 1>>
<<set $lowerstate to "chest">>
<<set $upperstatetop to "chest">>
<<elseif $upperstate is "chest">><span class="purple"><<He>> pulls your $upperclothes off your body.</span><<upperstrip>><<uppernaked>><<set $lefthand4 to 0>><<neutral 3>><<clothesstripstat>>
<</if>>
<</if>>
<<else>>
<<if $upperstatetop is "chest">><<He>> pulls down the top of your $upperclothes, <span class="lewd">revealing your <<breastsstop>></span><<set $upperstatetop to "midriff">><<neutral 2>><<set $upperexposed to 2>><<set $speechbreasts to 1>>
<<if $upperstate is "chest">>
<<set $upperstate to "midriff">>
<</if>>
<<if $lowerstate is "chest">>
<<set $lowerstate to "midriff">>
<</if>>
<<elseif $upperstatetop is "midriff">><<He>> pulls your $upperclothes down past your midriff.<<set $upperstatetop to "waist">><<neutral 1>>
<<if $upperstate is "midriff">>
<<set $upperstate to "waist">>
<</if>>
<<if $lowerstate is "midriff">>
<<set $lowerstate to "waist">>
<</if>>
<<elseif $upperstatetop is "waist">><<He>> pulls your $upperclothes down to your thighs, revealing your
<<if $understate is "waist">>$underclothes<<neutral 2>>
<<else>><span class="lewd"><<genitalsstop>></span><<neutral 5>><<set $speechgenitals to 1>>
<</if>>
<<set $lowervaginaexposed to 1>><<set $loweranusexposed to 1>><<set $lowerexposed to 2>>
<<set $upperstatetop to "thighs">>
<<set $upperstate to "thighs">>
<<if $lowerstate is "waist">>
<<set $lowerstate to "thighs">>
<</if>>
<<elseif $upperstatetop is "thighs">><<He>> pulls your $upperclothes down to your knees.<<set $upperstatetop to "knees">><<set $upperstate to "knees">><<neutral 1>>
<<if $lowerstate is "thighs">>
<<set $lowerstate to "knees">>
<</if>>
<<elseif $upperstatetop is "knees">><<He>> pulls your $upperclothes down to your ankles.<<set $upperstatetop to "ankles">><<set $upperstate to "ankles">><<neutral 1>>
<<if $lowerstate is "knees">>
<<set $lowerstate to "ankles">>
<</if>>
<<elseif $upperstatetop is "ankles">><span class="purple"><<He>> pulls your $upperclothes off the bottom of your legs.</span><<upperstrip>><<neutral 5>><<set $upperstatetop to 0>><<set $upperstate to 0>><<uppernaked>><<set $lefthand4 to 0>>
<<if $lowerstate is "ankles">>
<<set $lowerstate to 0>><<lowerstrip>><<lowernaked>>
<</if>>
<</if>>
<</if>>
<<else>><<He>> tugs at your $upperclothes, tearing <<upperit>> before <span class="blue">letting go.</span><<set $lefthand4 to 0>><<set $upperintegrity -= 10>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random (1, 100)>>
<<if $righthand4 is "upperclothes">>
<<if $upperclothes is "naked">><span class="purple"><<He>> casts aside the fabric.</span><<set $righthand4 to 0>>
<<elseif $upperstruggle is 1>><<set $upperstruggle to 0>>You manage to keep <<him>> from stripping you of your $upperclothes.<<set $speechstripstruggle to 1>>
<<elseif $rng gte 101>><span class="lblue"><<He>> releases <<his>> hand from your $upperclothes.</span><<set $righthand4 to 0>>
<<elseif $rng lte 100>>
<<if $upperset isnot $lowerset>>
<<if $open is 1>>
<<if $upperstatetop is "chest">><<He>> pulls down your $upperclothes, <span class="lewd">revealing your <<breastsstop>></span><<set $upperstatetop to "midriff">><<neutral 3>><<set $upperexposed to 2>><<set $speechbreasts to 1>>
<<if $upperstate is "chest">>
<<set $upperstate to "midriff">>
<</if>>
<<elseif $upperstatetop is "midriff">><<He>> pulls your $upperclothes down past your midriff.<<set $upperstatetop to "waist">><<neutral 1>>
<<if $upperstate is "midriff">>
<<set $upperstate to "waist">>
<</if>>
<<elseif $upperstatetop is "waist">><<He>> pulls your $upperclothes down to your thighs.
<<set $upperstatetop to "thighs">>
<<set $upperstate to "thighs">>
<<elseif $upperstatetop is "thighs">><<He>> pulls your $upperclothes down to your knees.<<set $upperstatetop to "knees">><<set $upperstate to "knees">><<neutral 1>>
<<elseif $upperstatetop is "knees">><<He>> pulls your $upperclothes down to your ankles.<<set $upperstatetop to "ankles">><<set $upperstate to "ankles">><<neutral 1>>
<<elseif $upperstatetop is "ankles">><span class="purple"><<He>> pulls your $upperclothes off the bottom of your legs.</span><<upperstrip>><<neutral 5>><<set $upperstatetop to 0>><<set $upperstate to 0>><<uppernaked>><<set $righthand4 to 0>>
<</if>>
<<elseif $open is 0>>
<<if $position is "wall">>
<<He>> tugs at your $upperclothes, tearing <<upperit>> before <span class="blue">letting go.</span><<set $righthand4 to 0>><<set $upperintegrity -= 10>><<neutral 1>>
<<elseif $position isnot "wall">>
<<if $upperstate is "waist">><<He>> lifts up your $upperclothes, exposing your midriff.<<set $upperstate to "midriff">><<neutral 1>>
<<elseif $upperstate is "midriff">><<He>> lifts up your $upperclothes, <span class="lewd">exposing your <<breastsstop>></span><<set $upperstate to "chest">><<neutral 2>><<set $upperexposed to 2>><<set $speechbreasts to 1>>
<<elseif $upperstate is "chest">><span class="purple"><<He>> removes your $upperclothes completely.</span><<upperstrip>><<uppernaked>><<set $righthand4 to 0>><<neutral 3>><<clothesstripstat>>
<</if>>
<</if>>
<</if>>
<<elseif $upperset is $lowerset>>
<<if $open is 1>>
<<if $lowerstate is $upperstatetop and $lowerstate is $upperstate and $skirt is 1>>
<<if $position is "wall">>
<<He>> tugs at your $upperclothes, tearing <<upperit>> before <span class="blue">letting go.</span><<set $righthand4 to 0>><<set $upperintegrity -= 10>><<neutral 1>>
<<elseif $position isnot "wall">>
<<if $upperstate is "waist">><<He>> pulls your bundled $upperclothes up past your midriff.<<set $upperstate to "midriff">><<neutral 1>>
<<set $lowerstate to "midriff">>
<<set $upperstatetop to "midriff">>
<<elseif $upperstate is "midriff">><<He>> pulls your bundled $upperclothes up past your <<breastsstop>><<set $upperstate to "chest">><<neutral 2>><<set $upperexposed to 2>><<set $speechbreasts to 1>>
<<set $lowerstate to "chest">>
<<set $upperstatetop to "chest">>
<<elseif $upperstate is "chest">><span class="purple"><<He>> pulls your $upperclothes off your body.</span><<upperstrip>><<uppernaked>><<set $righthand4 to 0>><<neutral 3>><<clothesstripstat>>
<</if>>
<</if>>
<<else>>
<<if $upperstatetop is "chest">><<He>> pulls down the top of your $upperclothes, <span class="lewd">revealing your <<breastsstop>></span><<set $upperstatetop to "midriff">><<set $upperexposed to 2>><<neutral 2>><<set $speechbreasts to 1>>
<<if $upperstate is "chest">>
<<set $upperstate to "midriff">>
<</if>>
<<if $lowerstate is "chest">>
<<set $lowerstate to "midriff">>
<</if>>
<<elseif $upperstatetop is "midriff">><<He>> pulls your $upperclothes down past your midriff.<<set $upperstatetop to "waist">><<neutral 1>>
<<if $upperstate is "midriff">>
<<set $upperstate to "waist">>
<</if>>
<<if $lowerstate is "midriff">>
<<set $lowerstate to "waist">>
<</if>>
<<elseif $upperstatetop is "waist">><<He>> pulls your $upperclothes down to your thighs, revealing your
<<if $understate is "waist">>$underclothes<<neutral 2>>
<<else>><span class="lewd"><<genitalsstop>></span><<neutral 5>><<set $speechgenitals to 1>>
<</if>>
<<set $lowervaginaexposed to 1>><<set $loweranusexposed to 1>><<set $lowerexposed to 2>>
<<set $upperstatetop to "thighs">>
<<set $upperstate to "thighs">>
<<if $lowerstate is "waist">>
<<set $lowerstate to "thighs">>
<</if>>
<<elseif $upperstatetop is "thighs">><<He>> pulls your $upperclothes down to your knees.<<set $upperstatetop to "knees">><<set $upperstate to "knees">><<neutral 1>>
<<if $lowerstate is "thighs">>
<<set $lowerstate to "knees">>
<</if>>
<<elseif $upperstatetop is "knees">><<He>> pulls your $upperclothes down to your ankles.<<set $upperstatetop to "ankles">><<set $upperstate to "ankles">><<neutral 1>>
<<if $lowerstate is "knees">>
<<set $lowerstate to "ankles">>
<</if>>
<<elseif $upperstatetop is "ankles">><span class="purple"><<He>> pulls your $upperclothes off the bottom of your legs.</span><<upperstrip>><<neutral 5>><<set $upperstatetop to 0>><<set $upperstate to 0>><<uppernaked>><<set $righthand4 to 0>>
<<if $lowerstate is "ankles">>
<<set $lowerstate to 0>><<lowerstrip>><<lowernaked>>
<</if>>
<</if>>
<</if>>
<<else>><<He>> tugs at your $upperclothes, tearing <<upperit>> before <span class="blue">letting go.</span><<set $righthand4 to 0>><<set $upperintegrity -= 10>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand4 is 0>>
<<if $enemyanger + $rng lte 20>>
<<if $lowerclothes isnot "naked">><span class="purple"><<He>> grasps your $lowerclothes.</span><<set $lefthand4 to "lowerclothes">><<neutral 1>>
<<elseif $vaginaexist is 1>>
<<He>> <<strokes>> your inner thigh and brushes <<his>> fingers against your clit.<<neutral 10>><<set $speechclit to 1>>
<<elseif $penisexist is 1>>
<<He>> <<strokes>> your inner thigh and brushes <<his>> fingers against your <<glansstop>><<neutral 10>><<set $speechglans to 1>>
<</if>>
<<elseif $enemyanger + $rng lte 30>>
<<if $position is "wall">>
<<if $lowerclothes isnot "naked">><span class="purple"><<He>> grasps your $lowerclothes.</span><<set $lefthand4 to "lowerclothes">><<neutral 1>>
<<elseif $vaginaexist is 1>>
<<He>> <<strokes>> your inner thigh and brushes <<his>> fingers against your clit.<<neutral 10>><<set $speechclit to 1>>
<<elseif $penisexist is 1>>
<<He>> <<strokes>> your inner thigh and brushes <<his>> fingers against your <<glansstop>><<neutral 10>><<set $speechglans to 1>>
<</if>>
<<else>>
<<if $upperclothes isnot "naked">><span class="purple"><<He>> grasps your $upperclothes.</span><<set $lefthand4 to "upperclothes">><<neutral 1>>
<<else>><<He>> <<strokes>> your chest, <<his>> fingers lingering around your nipple.<<neutral 4>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 35>>
<<if $skirt is 1>>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $lefthand4 to "underclothes">><<neutral 1>>
<<elseif $underanusexposed is 1>>
<<if $loweranusexposed is 1>>
<<if $anususe is 0 and $analdisable is "f">><span class="purple"><<He>> presses <<his>> left hand against your <<bottomstop>></span><<set $lefthand4 to "anusentrance">><<set $anususe to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<<elseif $lowerclothes isnot "waist">>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $lefthand4 to "underclothes">><<neutral 1>>
<<elseif $underanusexposed is 1>>
<<if $loweranusexposed is 1>>
<<if $anususe is 0 and $analdisable is "f">><span class="purple"><<He>> presses <<his>> left hand against your <<bottomstop>></span><<set $lefthand4 to "anusentrance">><<set $anususe to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 40>>
<<if $skirt is 1>>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $lefthand4 to "underclothes">><<neutral 1>>
<<elseif $undervaginaexposed is 1>>
<<if $lowervaginaexposed is 1>>
<<if $vaginaexist is 1>>
<<if $vaginause is 0>><span class="purple"><<He>> presses <<his>> left hand against your <<pussycomma>> resting a finger on your entrance.</span><<set $lefthand4 to "vaginaentrance">><<set $vaginause to 1>><<neutral 1>>
<</if>>
<<elseif $penisexist is 1>>
<<if $penisuse is 0>><span class="purple"><<He>> presses <<his>> left hand against your <<penisstop>></span><<set $lefthand4 to "penisentrance">><<set $penisuse to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $lowerclothes isnot "waist">>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $lefthand4 to "underclothes">><<neutral 1>>
<<elseif $undervaginaexposed is 1>>
<<if $lowervaginaexposed is 1>>
<<if $vaginaexist is 1>>
<<if $vaginause is 0>>
<span class="purple"><<He>> presses <<his>> left hand against your <<pussycomma>> resting a finger on your entrance.</span><<set $lefthand4 to "vaginaentrance">><<set $vaginause to 1>><<neutral 1>>
<</if>>
<<elseif $penisexist is 1>>
<<if $penisuse is 0>><span class="purple"><<He>> presses <<his>> left hand against your <<penisstop>></span><<set $lefthand4 to "penisentrance">><<set $penisuse to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 45>>
<<if $position is "wall">>
<<He>> leans against the wall.
<<else>>
<<He>> caresses your tummy.<<neutral 1>>
<</if>>
<<elseif $enemyanger + $rng lte 50>>
<<if $position is "wall">>
<<He>> grips your thigh and pulls, but you're stuck firm.<<neutral 1>>
<<else>>
<<He>> <<strokes>> your hair.<<neutral 1>>
<</if>>
<<elseif $enemyanger + $rng lte 60>>
<<if $position is "wall">>
<<He>> pulls your leg, but you're stuck firm.<<neutral 1>>
<<elseif $uppertype isnot "naked" and $upperstate isnot "chest" and $upperstatetop is "chest">>
<<He>> <<strokes>> your <<breasts>> through your $upperclothes.<<neutral 2>>
<<else>>
<<He>> <<strokes>> your exposed <<breastsstop>><<neutral 4>>
<</if>>
<<elseif $enemyanger + $rng lte 80>><<set $speechbottom to 1>>
<<if $lowerstate is "waist" and $skirt is 0>>
<<He>> fondles your <<bottom>> through your $lowerclothes.<<neutral 2>>
<<elseif $understate is "waist">>
<<He>> fondles your <<bottom>> through your $underclothes.<<neutral 2>>
<<else>>
<<He>> gropes and squeezes your exposed <<bottomstop>><<neutral 4>>
<</if>>
<<elseif $enemyanger + $rng lte 100>>
<<if $penisexist is 1>>
<<if $lowerstate is "waist" and $skirt is 0>>
<<He>> fondles and <<strokes>> your <<penis>> through your $lowerclothes.<<neutral 5>>
<<elseif $understate is "waist">>
<<He>> fondles and <<strokes>> your <<penis>> through your $underclothes.<<neutral 5>>
<<elseif $penisuse is 0>>
<<He>> fondles and <<strokes>> your exposed <<penisstop>><<neutral 10>>
<<else>>
<<He>> fondles and <<strokes>> your <<testiclesstop>><<neutral 10>>
<</if>>
<<elseif $vaginaexist is 1>>
<<if $lowerstate is "waist" and $skirt is 0>>
<<He>> fondles and <<strokes>> your labia through your $lowerclothes.<<neutral 5>>
<<elseif $understate is "waist">>
<<He>> fondles and <<strokes>> your labia through your $underclothes.<<neutral 5>>
<<else>>
<<He>> fondles and <<strokes>> your exposed <<pussystop>><<neutral 10>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 110>>
<<if $lowerclothes isnot "naked">><span class="purple"><<He>> grasps your $lowerclothes.</span><<set $lefthand4 to "lowerclothes">><<neutral 1>>
<<elseif $vaginaexist is 1>><<He>> pinches your clitoris.<<neutral 15>><<bruise vagina>><<set $speechclit to 1>>
<<elseif $penisexist is 1>>
<<if $penisuse is 0>>
<<He>> pinches your glans.<<neutral 15>><<bruise penis>><<set $speechglans to 1>>
<<else>>
<<He>> pinches your shaft.<<neutral 10>><<bruise penis>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 120>>
<<if $position is "wall">>
<<He>> smacks your thigh.<<violence 1>><<bruise thigh>><<hitstat>>
<<else>>
<<if $upperclothes isnot "naked">><span class="purple"><<He>> grasps your $upperclothes.</span><<set $lefthand4 to "upperclothes">><<neutral 1>>
<<else>><span class="purple"><<He>> grabs your throat.</span><<violence 2>><<set $lefthand4 to "throat">>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 125>>
<<if $skirt is 1>>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $lefthand4 to "underclothes">><<neutral 1>>
<<elseif $underanusexposed is 1>>
<<if $loweranusexposed is 1>>
<<if $anususe is 0 and $analdisable is "f">><span class="purple"><<He>> presses <<his>> left hand against your <<bottomstop>></span><<set $lefthand4 to "anusentrance">><<set $anususe to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<<elseif $lowerclothes isnot "waist">>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $lefthand4 to "underclothes">><<neutral 1>>
<<elseif $underanusexposed is 1>>
<<if $loweranusexposed is 1>>
<<if $anususe is 0 and $analdisable is "f">><span class="purple"><<He>> presses <<his>> left hand against your <<bottomstop>></span><<set $lefthand4 to "anusentrance">><<set $anususe to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 130>>
<<if $skirt is 1>>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $lefthand4 to "underclothes">><<neutral 1>>
<<elseif $undervaginaexposed is 1>>
<<if $lowervaginaexposed is 1>>
<<if $vaginaexist is 1>>
<<if $vaginause is 0>><span class="purple"><<He>> presses <<his>> left hand against your <<pussycomma>> <<his>> finger resting on your entrance.</span><<set $lefthand4 to "vaginaentrance">><<set $vaginause to 1>><<neutral 1>>
<</if>>
<<elseif $penisexist is 1>>
<<if $penisuse is 0>><span class="purple"><<He>> presses <<his>> left hand against your <<penisstop>></span><<set $lefthand4 to "penisentrance">><<set $penisuse to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $lowerclothes isnot "waist">>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $lefthand4 to "underclothes">><<neutral 1>>
<<elseif $undervaginaexposed is 1>>
<<if $lowervaginaexposed is 1>>
<<if $vaginaexist is 1>>
<<if $vaginause is 0>>
<span class="purple"><<He>> presses <<his>> left hand against your <<pussycomma>> <<his>> finger resting on your entrance.</span><<set $lefthand4 to "vaginaentrance">><<set $vaginause to 1>><<neutral 1>>
<</if>>
<<elseif $penisexist is 1>>
<<if $penisuse is 0>><span class="purple"><<He>> presses <<his>> left hand against your <<penisstop>></span><<set $lefthand4 to "penisentrance">><<set $penisuse to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 140>>
<<if $position is "wall">>
<<He>> smacks your <<bottomstop>><<violence 1>><<bruise bottom>><<hitstat>>
<<else>>
<<He>> seizes your hair with <<his>> left hand.<<set $lefthand4 to "hair">><<violence 2>><<set $speechhair to 1>>
<</if>>
<<elseif $enemyanger + $rng lte 160 and $lefthand4 isnot "arms" and $righthand4 isnot "arms" and $leftarm isnot "bound" and $rightarm isnot "bound">>
<span class="purple"><<He>> pins down your arms.</span><<set $lefthand4 to "arms">><<set $leftarm to "grappled">><<set $rightarm to "grappled">><<disablearms>><<violence 2>><<bruise leftarm>><<bruise rightarm>><<set $speecharms to 1>>
<<if $vaginause is "cover">><<set $vaginause to 0>>
<</if>>
<<if $vaginause is "cover">><<set $vaginause to 0>>
<</if>>
<<if $anususe is "cover">><<set $anususe to 0>>
<</if>>
<<if $anususe is "cover">><<set $anususe to 0>>
<</if>>
<<if $penisuse is "cover">><<set $penisuse to 0>>
<</if>>
<<if $penisuse is "cover">><<set $penisuse to 0>>
<</if>>
<<elseif $enemyanger + $rng lte 160>><<He>> digs <<his>> nails into your <<bottom>> while groping, giving no heed to you comfort.<<violence 10>><<bruise bottom>><<hitstat>><<set $speechspank to 1>>
<<elseif $enemyanger + $rng lte 175>><<He>> slaps your <<bottomstop>><<violence 10>><<bruise bottom>><<hitstat>><<set $speechspank to 1>>
<<elseif $enemyanger + $rng lte 180>><<He>> smacks your thighs.<<violence 10>><<bruise thigh>><<hitstat>><<set $speechbeat to 1>>
<<elseif $enemyanger + $rng lte 185>>
<<if $position is "wall">>
<<He>> punches your thigh.<<bruise thigh>><<hitstat>><<violence 10>><<set $speechbeat to 1>>
<<else>>
<<He>> punches your tummy.<<violence 20>><<bruise tummy>><<hitstat>><<set $speechbeat to 1>>
<</if>>
<<elseif $enemyanger + $rng lte 190>>
<<if $position is "wall">>
<<He>> slaps your <<bottomstop>><<violence 20>><<bruise bottom>><<hitstat>><<set $speechbeat to 1>>
<<else>>
<<He>> slaps your <<breastsstop>><<violence 20>><<bruise chest>><<hitstat>><<set $speechbeat to 1>>
<</if>>
<<elseif $enemyanger + $rng gte 191>>
<<if $position is "wall">>
<<if $penisexist is 1>>
<<He>> scratches your helpless <<bottomstop>><<violence 20>><<bruise bottom>><<hitstat>><<set $speechbeat to 1>>
<<elseif $vaginaexist is 1>>
<<He>> scratches your helpless <<bottomstop>><<violence 20>><<bruise bottom>><<hitstat>><<set $speechbeat to 1>>
<</if>>
<<else>>
<<set $rng to random(1, 100)>>
<<if $rng gte 81>>
<<He>> punches your nose.<<violence 20>><<bruise face>><<hitstat>><<set $speechbeat to 1>>
<<elseif $rng gte 61>>
<<He>> punches the back of your neck.<<violence 20>><<bruise neck>><<hitstat>><<set $speechbeat to 1>>
<<elseif $rng gte 41>>
<<He>> punches your cheek.<<violence 20>><<bruise face>><<hitstat>><<set $speechbeat to 1>>
<<elseif $rng gte 21>>
<<He>> punches your jaw.<<violence 20>><<bruise face>><<hitstat>><<set $speechbeat to 1>>
<<else>>
<<He>> jabs the front of your neck.<<violence 20>><<bruise neck>><<hitstat>><<set $speechbeat to 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand4 is 0>>
<<if $enemyanger + $rng lte 20>>
<<if $lowerclothes isnot "naked">><span class="purple"><<He>> grasps your $lowerclothes.</span><<set $righthand4 to "lowerclothes">><<neutral 1>>
<<elseif $vaginaexist is 1>><<He>> <<strokes>> your pubic mound and teases your clit.<<neutral 10>><<set $speechclit to 1>>
<<elseif $penisexist is 1>>
<<He>> <<strokes>> your <<testicles>> and teases your glans.<<neutral 10>><<set $speechglans to 1>>
<</if>>
<<elseif $enemyanger + $rng lte 30>>
<<if $position is "wall">>
<<if $lowerclothes isnot "naked">><span class="purple"><<He>> grasps your $lowerclothes.</span><<set $righthand4 to "lowerclothes">><<neutral 1>>
<<elseif $vaginaexist is 1>><<He>> runs <<his>> hand up your thigh and <<strokes>> your clit.<<neutral 10>><<set $speechclit to 1>>
<<elseif $penisexist is 1>><<He>> runs <<his>> hand up your thigh and <<strokes>> your <<glansstop>><<neutral 10>><<set $speechglans to 1>>
<</if>>
<<else>>
<<if $upperclothes isnot "naked">><span class="purple"><<He>> grasps your $upperclothes.</span><<set $righthand4 to "upperclothes">><<neutral 1>>
<<else>><<He>> <<strokes>> your chest and teases your nipple.<<neutral 4>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 35>>
<<if $skirt is 1>>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $righthand4 to "underclothes">><<neutral 1>>
<<elseif $underanusexposed is 1>>
<<if $loweranusexposed is 1>>
<<if $anususe is 0 and $analdisable is "f">><span class="purple"><<He>> presses <<his>> right hand against your <<bottomstop>></span><<set $righthand4 to "anusentrance">><<set $anususe to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<<elseif $lowerclothes isnot "waist">>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $righthand4 to "underclothes">><<neutral 1>>
<<elseif $underanusexposed is 1>>
<<if $loweranusexposed is 1>>
<<if $anususe is 0 and $analdisable is "f">><span class="purple"><<He>> presses <<his>> right hand against your <<bottomstop>></span><<set $righthand4 to "anusentrance">><<set $anususe to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 40>>
<<if $skirt is 1>>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $righthand4 to "underclothes">><<neutral 1>>
<<elseif $undervaginaexposed is 1>>
<<if $lowervaginaexposed is 1>>
<<if $vaginaexist is 1>>
<<if $vaginause is 0>>
<span class="purple"><<He>> presses <<his>> right hand against your <<pussycomma>> resting a finger on your entrance.</span><<set $righthand4 to "vaginaentrance">><<set $vaginause to 1>><<neutral 1>>
<</if>>
<<elseif $penisexist is 1>>
<<if $penisuse is 0>><span class="purple"><<He>> presses <<his>> right hand against your <<penisstop>></span><<set $righthand4 to "penisentrance">><<set $penisuse to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $lowerclothes isnot "waist">>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $righthand4 to "underclothes">><<neutral 1>>
<<elseif $undervaginaexposed is 1>>
<<if $lowervaginaexposed is 1>>
<<if $vaginaexist is 1>>
<<if $vaginause is 0>>
<span class="purple"><<He>> presses <<his>> right hand against your <<pussycomma>> resting a finger above your entrance.</span><<set $righthand4 to "vaginaentrance">><<set $vaginause to 1>><<neutral 1>>
<</if>>
<<elseif $penisexist is 1>>
<<if $penisuse is 0>>
<span class="purple"><<He>> presses <<his>> right hand against your <<penisstop>></span><<set $righthand4 to "penisentrance">><<set $penisuse to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 45>>
<<if $position is "wall">>
<<He>> rests <<his>> right hand against the wall.
<<else>>
<<He>> <<strokes>> your tummy with <<his>> right hand.<<neutral 1>>
<</if>>
<<elseif $enemyanger + $rng lte 50>>
<<if $position is "wall">>
<<He>> pushes your <<bottomcomma>> making sure you're stuck firm.<<neutral 1>>
<<else>>
<<He>> <<strokes>> your cheek.<<neutral 1>>
<</if>>
<<elseif $enemyanger + $rng lte 60>>
<<if $position is "wall">>
<<He>> tugs on your leg, but you're stuck firm.<<neutral 1>>
<<elseif $uppertype isnot "naked" and $upperstate isnot "chest" and $upperstatetop is "chest">>
<<He>> gropes your <<breasts>> through your $upperclothes.<<neutral 2>>
<<else>>
<<He>> gropes your exposed <<breastsstop>><<neutral 4>>
<</if>>
<<elseif $enemyanger + $rng lte 80>><<set $speechbottom to 1>>
<<if $lowerstate is "waist" and $skirt is 0>>
<<He>> gropes your <<bottom>> through your $lowerclothes.<<neutral 2>>
<<elseif $understate is "waist">>
<<He>> gropes your <<bottom>> through your $underclothes.<<neutral 2>>
<<else>>
<<He>> fondles and <<strokes>> your exposed <<bottomstop>><<neutral 4>>
<</if>>
<<elseif $enemyanger + $rng lte 100>>
<<if $penisexist is 1>>
<<if $lowerstate is "waist" and $skirt is 0>>
<<He>> gropes and <<strokes>> your <<penis>> through your $lowerclothes.<<neutral 5>>
<<elseif $understate is "waist">>
<<He>> gropes and <<strokes>> your <<penis>> through your $underclothes.<<neutral 5>>
<<elseif $penisuse is 0>>
<<He>> gropes and <<strokes>> your exposed <<penisstop>><<neutral 10>>
<<else>>
<<He>> cups and <<strokes>> your <<testiclesstop>><<neutral 10>>
<</if>>
<<elseif $vaginaexist is 1>>
<<if $lowerstate is "waist" and $skirt is 0>>
<<He>> gropes and <<strokes>> your labia through your $lowerclothes.<<neutral 5>>
<<elseif $understate is "waist">>
<<He>> gropes and <<strokes>> your labia through your $underclothes.<<neutral 5>>
<<else>>
<<He>> gropes and <<strokes>> your exposed <<pussystop>><<neutral 10>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 110>>
<<if $lowerclothes isnot "naked">><span class="purple"><<He>> grasps your $lowerclothes.</span><<set $righthand4 to "lowerclothes">><<neutral 1>>
<<elseif $vaginaexist is 1>>He pinches your clitoris.<<neutral 15>><<bruise vagina>><<set $speechclit to 1>>
<<elseif $penisexist is 1>>
<<if $penisuse is 0>>
<<He>> pinches your glans.<<neutral 15>><<bruise penis>><<set $speechglans to 1>>
<<else>>
<<He>> pinches your shaft.<<neutral 10>><<bruise penis>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 120>>
<<if $position is "wall">>
<<He>> squeezes your thigh.<<violence 1>><<hitstat>><<bruise thigh>>
<<else>>
<<if $upperclothes isnot "naked">><span class="purple"><<He>> grasps your $upperclothes.</span><<set $righthand4 to "upperclothes">><<neutral 1>>
<<else>><span class="purple"><<He>> grabs your throat.</span><<violence 2>><<set $righthand4 to "throat">>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 125>>
<<if $skirt is 1>>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $righthand4 to "underclothes">><<neutral 1>>
<<elseif $underanusexposed is 1>>
<<if $loweranusexposed is 1>>
<<if $anususe is 0 and $analdisable is "f">><span class="purple"><<He>> presses <<his>> right hand against your <<bottomstop>></span><<set $righthand4 to "anusentrance">><<set $anususe to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<<elseif $lowerclothes isnot "waist">>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $righthand4 to "underclothes">><<neutral 1>>
<<elseif $underanusexposed is 1>>
<<if $loweranusexposed is 1>>
<<if $anususe is 0 and $analdisable is "f">><span class="purple"><<He>> presses <<his>> right hand against your <<bottomstop>></span><<set $righthand4 to "anusentrance">><<set $anususe to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 130>>
<<if $skirt is 1>>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $righthand4 to "underclothes">><<neutral 1>>
<<elseif $undervaginaexposed is 1>>
<<if $lowervaginaexposed is 1>>
<<if $vaginaexist is 1>>
<<if $vaginause is 0>>
<span class="purple"><<He>> presses <<his>> right hand against your <<pussycomma>> <<his>> finger resting on your entrance.</span><<set $righthand4 to "vaginaentrance">><<set $vaginause to 1>><<neutral 1>>
<</if>>
<<elseif $penisexist is 1>>
<<if $penisuse is 0>><span class="purple"><<He>> presses <<his>> right hand against your <<penisstop>></span><<set $righthand4 to "penisentrance">><<set $penisuse to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $lowerclothes isnot "waist">>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $righthand4 to "underclothes">><<neutral 1>>
<<elseif $undervaginaexposed is 1>>
<<if $lowervaginaexposed is 1>>
<<if $vaginaexist is 1>>
<<if $vaginause is 0>>
<span class="purple"><<He>> presses <<his>> right hand against your <<pussycomma>> <<his>> finger resting on your entrance.</span><<set $righthand4 to "vaginaentrance">><<set $vaginause to 1>><<neutral 1>>
<</if>>
<<elseif $penisexist is 1>>
<<if $penisuse is 0>>
<span class="purple"><<He>> presses <<his>> right hand against your <<penisstop>></span><<set $righthand4 to "penisentrance">><<set $penisuse to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 140>>
<<if $position is "wall">>
<<He>> slaps your <<bottomstop>><<violence 1>><<bruise bottom>><<hitstat>>
<<else>>
<span class="purple"><<He>> seizes your hair with <<his>> right hand.</span><<set $righthand4 to "hair">><<violence 2>><<set $speechhair to 1>>
<</if>>
<<elseif $enemyanger + $rng lte 160 and $lefthand4 isnot "arms" and $righthand4 isnot "arms" and $leftarm isnot "bound" and $rightarm isnot "bound">><span class="purple"><<He>> pins down your arms.</span><<set $righthand4 to "arms">><<set $leftarm to "grappled">><<set $rightarm to "grappled">><<disablearms>><<violence 2>><<bruise leftarm>><<bruise rightarm>><<set $speecharms to 1>>
<<if $vaginause is "cover">><<set $vaginause to 0>>
<</if>>
<<if $vaginause is "cover">><<set $vaginause to 0>>
<</if>>
<<if $anususe is "cover">><<set $anususe to 0>>
<</if>>
<<if $anususe is "cover">><<set $anususe to 0>>
<</if>>
<<if $penisuse is "cover">><<set $penisuse to 0>>
<</if>>
<<if $penisuse is "cover">><<set $penisuse to 0>>
<</if>>
<<elseif $enemyanger + $rng lte 160>><<He>> grips your <<bottomcomma>> digging <<his>> nails into your skin.<<violence 10>><<bruise bottom>><<hitstat>><<set $speechspank to 1>>
<<elseif $enemyanger + $rng lte 175>><<He>> spanks your <<bottomstop>><<violence 10>><<bruise bottom>><<hitstat>><<set $speechspank to 1>>
<<elseif $enemyanger + $rng lte 180>><<He>> slaps your thighs.<<violence 10>><<bruise thigh>><<hitstat>><<set $speechbeat to 1>>
<<elseif $enemyanger + $rng lte 185>>
<<if $position is "wall">>
<<He>> beats your thigh.<<bruise thigh>><<hitstat>><<violence 10>><<set $speechbeat to 1>>
<<else>>
<<He>> beats your tummy.<<violence 20>><<bruise tummy>><<hitstat>><<set $speechbeat to 1>>
<</if>>
<<elseif $enemyanger + $rng lte 190>>
<<if $position is "wall">>
<<He>> spanks your <<bottomstop>><<violence 20>><<bruise bottom>><<hitstat>><<set $speechbeat to 1>>
<<else>>
<<He>> spanks your <<breastsstop>><<violence 20>><<bruise chest>><<hitstat>><<set $speechbeat to 1>>
<</if>>
<<elseif $enemyanger + $rng gte 191>>
<<if $position is "wall">>
<<if $penisexist is 1>>
<<He>> jabs your gooch.<<violence 20>><<bruise penis>><<hitstat>><<set $speechbeat to 1>>
<<elseif $vaginaexist is 1>>
<<He>> jabs your gooch.<<violence 20>><<bruise vagina>><<hitstat>><<set $speechbeat to 1>>
<</if>>
<<else>>
<<set $rng to random(1, 100)>>
<<if $rng gte 81>>
<<He>> scratches the side of your face.<<violence 20>><<bruise face>><<hitstat>><<set $speechbeat to 1>>
<<elseif $rng gte 61>>
<<He>> scratches the back of your neck.<<violence 20>><<bruise neck>><<hitstat>><<set $speechbeat to 1>>
<<elseif $rng gte 41>>
<<He>> scratches your cheek.<<violence 20>><<bruise face>><<hitstat>><<set $speechbeat to 1>>
<<elseif $rng gte 21>>
<<He>> scratches your jaw.<<violence 20>><<bruise face>><<hitstat>><<set $speechbeat to 1>>
<<else>>
<<He>> scratches the front of your neck.<<violence 20>><<bruise neck>><<hitstat>><<set $speechbeat to 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis4 is "clothed">>
<<if $pronoun is "m">>
<<if $enemyarousal gte 40>><<He>> unzips <<his>> fly, <span class="blue">revealing <<his>> erect penis.</span><<set $penis4 to 0>>
<</if>>
<<else>>
<<if $enemyarousal gte 40>><<He>> pulls up <<his>> skirt, <span class="blue">revealing <<his>> erect penis.</span><<set $penis4 to 0>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis4 is "thighs">>
<<if $vaginaexist is 1>>
<<if $rng gte 101>><span class="blue"><<He>> angles <<his>> penis towards your <<pussystop>></span><<set $thighuse to 0>><<set $penis4 to "vaginaentrance">><<set $vaginause to "penis">><<set $vaginastate to "entrance">><<set $speechvaginaentrance to 1>>
<<else>>
<<He>> rubs <<his>> penis between your thighs and <<pussystop>><<sex 5>>
<</if>>
<<else>>
<<if $rng gte 101>><<He>> moves <<his>> penis out from between your thighs.<<set $thighuse to 0>><<set $penis4 to 0>>
<<else>>
<<He>> rubs <<his>> penis between your thighs.<<sex 5>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis4 is "cheeks">>
<<if $rng gte 101>><span class="blue"><<He>> angles <<his>> penis towards your anus.</span><<set $penis4 to "anusentrance">><<set $anusstate to "entrance">><<set $bottomuse to 0>><<set $cheekactiondefault to "cheeks">><<set $speechanusentrance to 1>>
<<else>>
<<He>> rubs <<his>> penis between your cheeks.<<submission 3>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis4 is "leftarm">>
<<if $rng gte 1>><<He>> rubs <<his>> penis between your fingers.<<submission 1>>
<<elseif $rng gte 101>><<He>> moves <<his>> penis away from your hand.<<set $penis4 to 0>><<set $leftarm to 0>><<set $leftactiondefault to "leftgrab">>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis4 is "rightarm">>
<<if $rng gte 1>><<He>> rubs <<his>> penis between your fingers.<<submission 1>>
<<elseif $rng gte 101>><<He>> moves <<his>> penis away from your hand.<<set $penis4 to 0>><<set $rightarm to 0>><<set $rightactiondefault to "rightgrab">>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis4 is "botharm">>
<<if $rng gte 1>><<He>> rubs <<his>> penis between your hands.<<submission 2>>
<<elseif $rng gte 101>><<He>> moves <<his>> penis away from your hands.<<set $penis4 to 0>><<set $leftarm to 0>><<set $rightarm to 0>><<set $rightactiondefault to "rightgrab">><<set $leftactiondefault to "leftgrab">>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis4 is "feet">>
<<if $rng gte 1>>
<<He>> rubs <<his>> penis between your feet.<<submission 1>>
<<elseif $rng gte 101>>
<<He>> moves <<his>> penis away from your feet.<<set $penis4 to 0>><<set $feetuse to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis4 is "vagina">>
<<if $rng gte 101>><span class="purple"><<He>> slides <<his>> penis out of your <<pussystop>></span><<sex 30>><<set $penis4 to "vaginaimminent">><<bruise vagina>><<violence 1>><<set $vaginastate to "imminent">>
<<elseif $rng gte 1>>
<<if $enemyanger gte 100>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
<<He>> violates your <<pussy>> with increasing intensity.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues to fuck your <<pussy>> with no regard for your comfort.
<<else>>
<<He>> fucks your <<pussy>> with rough thrusts, giving no regard to your comfort.
<</if>>
<<elseif $enemyanger gte 20>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
You feel <<his>> penis throb as <<he>> pounds away at your <<pussystop>>
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues to violate your <<pussystop>>
<<else>>
<<He>> fucks your <<pussy>> with deep and deliberate thrusts.
<</if>>
<<else>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
<<He>> fucks your <<pussy>> with increasing power.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues thrusting into your <<pussystop>>
<<else>>
<<He>> fucks your <<pussy>> with steady thrusts.
<</if>>
<</if>>
<<sex 30>><<bruise vagina>><<violence 1>><<set $speechvaginapenetrated to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis4 is "vaginaimminent">>
<<if $rng gte 101>><span class="blue"><<He>> stops pressing <<his>> penis against your pussy.</span><<set $penis4 to "vaginaentrance">><<set $vaginastate to "entrance">>
<<elseif $rng gte 1>>
<<if $novaginal is 0>><<set $vaginaactiondefault to "take">>
<<if $vaginalvirginity is 0>>
<<if $enemyanger gte 80>>
<span class="pink"><<He>> thrusts <<his>> penis deep into your <<pussystop>></span>
<<elseif $enemyanger gte 20>>
<span class="pink"><<He>> thrusts <<his>> penis deep into your <<pussystop>></span>
<<else>>
<span class="pink"><<He>> glides <<his>> penis deep into your <<pussystop>></span>
<</if>>
<<sex 30>><<set $penis4 to "vagina">><<vaginalstat>><<bruise vagina>><<violence 1>><<raped>><<vaginaraped>><<set $vaginastate to "penetrated">><<set $speechvaginapenetrated to 1>>
<<elseif $vaginalvirginity is 1>><span class="pink"><<His>> penis thrusts deep into your virgin pussy,</span><span class="red"> breaking your hymen and forever robbing you of your purity.</span><<sex 100>><<set $penis4 to "vagina">><<set $vaginalvirginity to 0>><<bruise vagina>><<vaginalstat>><<violence 100>><<raped>><<vaginaraped>><<set $vaginastate to "penetrated">><<set $speechvaginavirgin to 1>>
<</if>>
<<else>>
Respecting your wishes, <<he>> presses <<his>> penis against your <<pussy>> but does not penetrate.<<sex 15>><<set $speechvaginawithhold to 1>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis4 is "vaginaentrance">>
<<if $rng gte 101>><span class="lblue"><<He>> moves <<his>> penis away from your <<pussystop>></span><<set $penis4 to 0>><<set $vaginause to 0>><<set $vaginastate to 0>>
<<elseif $rng gte 1>>
<<if $lowervaginaexposed is 0>><<He>> rubs <<his>> penis against your <<pussy>> through your $lowerclothes.<<sex 5>><<set $lowerintegrity -= 10>><<set $speechvaginaentrance to 1>>
<<elseif $lowervaginaexposed is 1>><<set $rng to random(1, 100)>>
<<if $undervaginaexposed is 0>><<He>> rubs <<his>> penis against your <<pussy>> through your $underclothes.<<sex 5>><<set $underintegrity -= 10>><<set $speechvaginaentrance to 1>>
<<elseif $undervaginaexposed is 1>>
<<if $rng gte 71>>
<<if $novaginal is 1>>
<span class="purple"><<He>> pushes <<his>> penis against your <<pussystop>></span><<sex 20>><<set $penis4 to "vaginaimminent">><<set $vaginastate to "imminent">><<set $speechvaginaimminent to 1>>
<<else>>
<span class="purple"><<He>> pushes <<his>> penis against your <<pussycomma>> preparing to penetrate you fully.</span><<sex 20>><<set $penis4 to "vaginaimminent">><<set $vaginastate to "imminent">><<set $speechvaginaimminent to 1>>
<</if>>
<<elseif $rng gte 1>><<He>> teases your <<pussy>> without penetrating.<<sex 10>><<set $speechvaginaentrance to 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis4 is "anus">>
<<if $rng gte 101>><span class="purple"><<He>> withdraws <<his>> penis from your anus.</span><<sex 30>><<set $penis4 to "anusimminent">><<bruise anus>><<violence 1>><<set $anusstate to "imminent">>
<<elseif $rng gte 1>>
<<if $enemyanger gte 100>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
<<He>> ravages your <<bottom>> with a violent intensity.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
You feel <<his>> penis ever deeper within you as <<he>> fucks your <<bottomstop>>
<<else>>
<<He>> fucks your <<bottom>> with rough thrusts, intent on showing you who's boss.
<</if>>
<<elseif $enemyanger gte 20>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
You feel <<his>> penis throb within you as <<he>> fucks your <<bottomstop>>
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues to violate your <<bottomcomma>> giving no regard to your comfort.
<<else>>
<<He>> fucks your <<bottom>> with deep and dominating thrusts.
<</if>>
<<else>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
<<He>> fucks your <<bottom>> with increasing power.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues fucking your <<bottomstop>>
<<else>>
<<He>> fucks your <<bottom>> with steady thrusts.
<</if>>
<</if>>
<<sex 30>><<bruise anus>><<violence 1>><<set $speechanuspenetrated to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis4 is "anusimminent">>
<<if $rng gte 101>><span class="blue"><<He>> stops pressing <<his>> penis against your anus.</span><<set $penis4 to "anusentrance">><<set $anusstate to "entrance">>
<<elseif $rng gte 1>>
<<if $noanal is 0>><<set $anusactiondefault to "take">>
<<if $analvirginity is 0>><span class="pink"><<He>> thrusts <<his>> penis deep into your <<bottomstop>></span><<sex 30>><<set $penis4 to "anus">><<bruise anus>><<analstat>><<violence 1>><<raped>><<set $anusstate to "penetrated">><<set $speechanuspenetrated to 1>>
<<elseif $analvirginity is 1>><span class="pink"><<He>> thrusts <<his>> penis deep into your virgin anus,</span> <span class="red">violating you in a way you hadn't conceived of.</span><<sex 100>><<set $penis4 to "anus">><<set $analvirginity to 0>><<bruise anus>><<analstat>><<violence 50>><<raped>><<set $anusstate to "penetrated">><<set $speechanusvirgin to 1>>
<</if>>
<<else>>
Respecting your wishes, <<he>> presses <<his>> penis against your anus but does not penetrate.<<sex 15>><<set $speechanuswithhold to 1>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis4 is "anusentrance">>
<<if $rng gte 101>><span class="lblue"><<He>> moves <<his>> penis away from your <<bottomstop>></span><<set $penis4 to 0>><<set $anususe to 0>><<set $anusstate to 0>>
<<elseif $rng gte 1>>
<<if $loweranusexposed is 0>><<He>> rubs <<his>> penis against your <<bottom>> through your $lowerclothes.<<sex 5>><<set $lowerintegrity -= 10>><<set $speechanusentrance to 1>>
<<elseif $loweranusexposed is 1>><<set $rng to random(1, 100)>>
<<if $underanusexposed is 0>><<He>> rubs <<his>> penis against your <<bottom>> through your $underclothes.<<set $speechanusentrance to 1>><<sex 5>><<set $underintegrity -= 10>>
<<elseif $underanusexposed is 1>>
<<if $rng gte 71>>
<<if $noanal is 1>>
<span class="pink"><<He>> presses <<his>> penis against your anus.</span><<sex 20>><<set $penis4 to "anusimminent">><<set $anusstate to "imminent">><<set $speechanusimminent to 1>>
<<else>>
<span class="pink"><<He>> presses <<his>> penis against your anus, preparing to penetrate you fully.</span><<sex 20>><<set $penis4 to "anusimminent">><<set $anusstate to "imminent">><<set $speechanusimminent to 1>>
<</if>>
<<elseif $rng gte 1>><<His>> penis rubs against your <<bottomstop>><<sex 5>><<set $speechanusentrance to 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis4 is "mouth">>
<<if $rng gte 101>><span class="purple"><<He>> withdraws <<his>> penis from your mouth.</span><<sex 30>><<set $penis4 to "mouthimminent">><<bruise face>><<violence 1>><<set $mouthstate to "imminent">>
<<elseif $rng gte 1>><<He>> continues thrusting into your mouth.<<submission 10>><<bruise face>><<violence 1>><<set $speechmouthpenetrated to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis4 is "mouthimminent">>
<<if $pullaway is 1>><<set $pullaway to 0>>Saliva drips from the tip of <<his>> phallus.
<<else>>
<<if $rng gte 101>><span class="blue"><<He>> stops pressing <<his>> penis against your mouth.</span><<set $penis4 to "mouthentrance">><<submission 5>><<set $mouthstate to "entrance">>
<<elseif $rng lte 20>>
<<if $oralvirginity is 0>><span class="pink"><<He>> thrusts <<his>> penis into your mouth.</span><<submission 10>><<set $penis4 to "mouth">><<bruise face>><<oralstat>><<raped>><<set $mouthstate to "penetrated">><<set $speechmouthpenetrated to 1>>
<<elseif $oralvirginity is 1>><span class="pink"><<He>> thrusts <<his>> penis into your mouth.</span><span class="red"> It tastes strange.</span><<submission 30>><<set $penis4 to "mouth">><<set $oralvirginity to 0>><<bruise face>><<oralstat>><<violence 1>><<raped>><<set $mouthstate to "penetrated">><<set $speechmouthvirgin to 1>>
<</if>>
<<elseif $rng gte 21>>
<<if $mouthsubmit is 1>><<He>> allows you to pleasure <<his>> cock with your mouth.<<submission 5>><<set $speechmouthimminent to 1>>
<<elseif $oralvirginity is 0>><span class="pink"><<He>> thrusts <<his>> penis into your mouth.</span><<submission 10>><<set $penis4 to "mouth">><<oralstat>><<bruise face>><<violence 1>><<raped>><<set $mouthstate to "penetrated">><<set $speechmouthpenetrated to 1>>
<<elseif $oralvirginity is 1>><span class="pink"><<He>> thrusts <<his>> penis into your mouth.</span><span class="red"> It tastes strange.</span><<submission 30>><<set $penis4 to "mouth">><<set $oralvirginity to 0>><<oralstat>><<bruise face>><<violence 1>><<raped>><<set $mouthstate to "penetrated">><<set $speechmouthpenetrated to 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis4 is "mouthentrance">>
<<if $pullaway is 1>><<set $pullaway to 0>><<His>> penis hovers only inches from your face.
<<else>>
<<if $rng gte 101>><span class="lblue"><<He>> moves <<his>> penis away from your mouth.</span><<set $penis4 to 0>><<set $mouthuse to 0>><<set $mouthstate to 0>>
<<elseif $rng gte 1>><span class="purple"><<He>> pushes <<his>> penis against your lips.</span><<set $penis4 to "mouthimminent">><<submission 5>><<set $mouthstate to "imminent">><<set $speechmouthimminent to 1>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis4 is "chest">>
<<if $rng gte 101>><<He>> moves <<his>> penis away from your chest.<<set $penis4 to 0>><<set $chestuse to 0>>
<<elseif $rng gte 1>><<submission 3>>
<<if $breastcup is "none">>
<<He>> rubs <<his>> penis against your <<breastsstop>><<set $speechchestrub to 1>>
<<else>>
<<He>> rubs <<his>> penis between your <<breastsstop>><<set $speechbreastrub to 1>>
<</if>>
<</if>>
<</if>>
<<if $penis4 is "footjob">>
<<if $rng gte 101>>
<span class="blue"><<He>> stops pressing <<his>> foot against your <<genitalsstop>></span><<set $penis4 to 0>>
<<if $penisexist is 1>>
<<set $penisuse to 0>>
<<else>>
<<set $vaginause to 0>>
<</if>>
<<else>>
<<if $penisexist is 1>>
<<He>> presses your <<penis>> against your stomach with <<his>> foot and rubs your glans between <<his>> toes.
<<set $speechpenisfoot to 1>><<neutral 5>><<violence 1>>
<<else>>
<<He>> presses and teases your <<pussy>> with <<his>> foot.
<<set $speechvaginafoot to 1>><<neutral 5>><<violence 1>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis4 is "otherfrot">>
<<if $rng gte 101>><span class="blue"><<He>> shifts <<his>> ass and presses <<his>> anus against your <<penisstop>></span><<set $penisuse to "otheranus">><<set $penis4 to "otheranusentrance">><<set $penisstate to "otheranusentrance">><<set $speechotheranusentrance to 1>>
<<else>>
<<He>> rubs <<his>> ass against your <<penisstop>><<sex 5>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis4 is "otheranus">>
<<if $rng gte 101>><span class="purple"><<He>> moves <<his>> pelvis away, releasing your <<penis>> from <<his>> anus.</span><<sex 30>><<set $penis4 to "otheranusimminent">><<bruise penis>><<violence 1>><<set $penisstate to "otheranusimminent">><<set $speechotheranusimminent to 1>>
<<elseif $rng gte 1>>
<<if $enemyanger gte 100>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
<<His>> continues to fuck your <<penis>> with <<his>> ass, <<his>> movements violent and erratic.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues to ride you, your penis helpless as it's fucked.
<<else>>
<<He>> fucks your <<penis>> with rough movements, intent on showing you who's boss.
<</if>>
<<elseif $enemyanger gte 20>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
You feel <<his>> ass twitch around your length <<he>> fucks you.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues to violate your <<peniscomma>> using you as a sex toy.
<<else>>
<<He>> fucks your <<peniscomma>> taking as much of you into <<his>> ass as <<he>> can.
<</if>>
<<else>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
<<He>> continues riding your <<peniscomma>> <<his>> anus rhythmically pounding your length. <<His>> body jerks whenever you hit a sensitive spot.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues riding your <<peniscomma>> <<his>> anus rhythmically pounding your length.
<<else>>
<<He>> rides your <<penis>> with steady movements.
<</if>>
<</if>>
<<sex 30>><<bruise penis>><<violence 1>><<set $speechotheranus to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis4 is "otheranusimminent">>
<<if $rng gte 101>><span class="blue"><<He>> stops pressing <<his>> ass against your <<penisstop>></span><<set $penis4 to "otheranusentrance">><<set $penisstate to "otheranusentrance">><<set $speechotheranusentrance to 1>>
<<elseif $rng gte 1>>
<<if $nopenile is 0>><<set $penisactiondefault to "otheranustake">>
<<if $penilevirginity is 0>><span class="pink"><<He>> eases your <<penis>> into <<his>> ass, swallowing you to the base.</span><<sex 30>><<set $penis4 to "otheranus">><<penilestat>><<bruise penis>><<violence 1>><<raped>><<penisraped>><<set $penisstate to "otheranus">><<set $speechotheranus to 1>>
<<elseif $penilevirginity is 1>><span class="pink"><<He>> eases your virgin penis into <<his>> ass,</span><span class="red"> separating your foreskin from your glans and forever robbing you of your purity.</span><<sex 100>><<set $penis4 to "otheranus">><<set $penilevirginity to 0>><<bruise penis>><<penilestat>><<violence 100>><<raped>><<penisraped>><<set $penisstate to "otheranus">><<set $speechpenisvirgin to 1>>
<</if>>
<<else>>
Respecting your wishes, <<he>> does not envelope your <<penis>> with <<his>> ass, instead teasing the tip of your glans.<<sex 15>><<set $speechotheranuswithhold to 1>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis4 is "otheranusentrance">>
<<if $rng gte 101>><span class="lblue"><<He>> moves <<his>> ass away from your <<penisstop>></span><<set $penis4 to 0>><<set $penisuse to 0>><<set $penisstate to 0>>
<<elseif $rng gte 1>>
<<if $lowervaginaexposed is 0>><<He>> rubs <<his>> ass against your <<penis>> through your $lowerclothes.<<sex 5>><<set $lowerintegrity -= 10>><<set $speechotheranusentrance to 1>>
<<elseif $lowervaginaexposed is 1>><<set $rng to random(1, 100)>>
<<if $undervaginaexposed is 0>><<He>> rubs <<his>> ass against your <<penis>> through your $underclothes.<<sex 5>><<set $underintegrity -= 10>><<set $speechotheranusentrance to 1>>
<<elseif $undervaginaexposed is 1>>
<<if $rng gte 71>>
<<if $nopenile is 1>>
<span class="purple"><<He>> presses <<his>> ass against your <<penisstop>></span><<sex 20>><<set $penis4 to "otheranusimminent">><<set $penisstate to "otheranusimminent">><<set $speechotheranusimminent to 1>>
<<else>>
<span class="purple"><<He>> presses <<his>> ass against your <<peniscomma>> preparing to take you in fully.</span><<sex 20>><<set $penis4 to "otheranusimminent">><<set $penisstate to "otheranusimminent">><<set $speechotheranusimminent to 1>>
<</if>>
<<elseif $rng gte 1>><<He>> rubs your <<penis>> between <<his>> cheeks.<<sex 10>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis4 is 0>>
<<if $enemyanger + $rng lte 20>>
<<if $lefthand4 is 0>>
<<if $enemyarousal lte 40>><<He>> slowly rubs <<his>> shaft.<<submission 1>>
<<elseif $enemyarousal lte 90>><<He>> quickly rubs <<his>> shaft.<<submission 2>>
<<elseif $enemyarousal gte 91>><<He>> rapidly rubs <<his>> shaft.<<submission 3>>
<</if>>
<<elseif $righthand4 is 0>>
<<if $enemyarousal lte 40>><<He>> slowly rubs <<his>> shaft.<<submission 1>>
<<elseif $enemyarousal lte 90>><<He>> quickly rubs <<his>> shaft.<<submission 2>>
<<elseif $enemyarousal gte 91>><<He>> rapidly rubs <<his>> shaft.<<submission 3>>
<<endif>
<<else>><<He>> rubs <<his>> cock against your thighs.<<submission 2>>
<</if>>
<<elseif $enemyanger + $rng lte 25>>
<<if $position is "wall">>
<<He>> rubs <<his>> cock against your thighs.<<submission 2>>
<<else>>
<<He>> rubs <<his>> cock against your tummy.<<submission 2>>
<</if>>
<<elseif $enemyanger + $rng lte 30>>
<<if $position is "wall">>
<<He>> rubs <<his>> cock against your thighs.<<submission 2>>
<<else>>
<<He>> rubs <<his>> cock against your <<breastsstop>><<submission 2>>
<</if>>
<<elseif $enemyanger + $rng lte 35>><<He>> rubs <<his>> cock against your thighs.<<submission 2>>
<<elseif $enemyanger + $rng lte 40>>
<<if $position is "wall">>
<<He>> rubs <<his>> cock against your thighs.<<submission 2>>
<<elseif $mouth4 is 0>>
<<He>> rubs <<his>> cock against your face.<<submission 2>>
<<else>>
<<He>> rubs <<his>> cock against your thighs.<<submission 2>>
<</if>>
<<elseif $enemyanger + $rng lte 45>>
<<if $penisexist is 1>>
<<if $penisuse is 0>>
<<if $analdisable is "f" and $consensual is 1>>
<span class="blue"><<He>> straddles you, rubbing <<his>> ass against your <<penisstop>></span><<neutral 5>><<set $penisuse to "otheranus">><<set $penis4 to "otheranusentrance">><<set $penisstate to "otheranusentrance">><<set $speechotheranusentrance to 1>>
<</if>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 60>>
<<if $mouthuse is 0>>
<<if $penisbitten is 0>>
<<if $position isnot "wall">>
<span class="blue"><<He>> positions <<his>> penis in front of your mouth.</span><<neutral 5>><<set $mouthuse to "penis">><<set $penis4 to "mouthentrance">><<set $mouthstate to "entrance">><<set $speechmouthentrance to 1>>
<</if>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 80>>
<<if $anususe is 0>>
<<if $analdisable is "f">>
<span class="blue"><<He>> moves between your legs, positioning <<his>> penis in front of your <<bottomstop>></span><<neutral 5>><<set $anususe to "penis">><<set $penis4 to "anusentrance">><<set $anusstate to "entrance">><<set $speechanusentrance to 1>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 100>>
<<if $vaginaexist is 1>>
<<if $vaginause is 0>><span class="blue"><<He>> moves between your legs, positioning <<his>> penis in front of your <<pussystop>></span><<neutral 5>><<set $vaginause to "penis">><<set $penis4 to "vaginaentrance">><<set $vaginastate to "entrance">><<set $speechvaginaentrance to 1>>
<</if>>
<<elseif $penisexist is 1>>
<<if $anususe is 0>>
<<if $analdisable is "f">>
<span class="blue"><<He>> moves between your legs, positioning <<his>> penis in front of your <<bottomstop>></span><<neutral 5>><<set $anususe to "penis">><<set $penis4 to "anusentrance">><<set $anusstate to "entrance">><<set $speechanusentrance to 1>>
<</if>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 120>>
<<He>> slowly traces <<his>> length across your exposed skin.<<neutral 1>>
<<neutral 5>>
<<elseif $enemyanger + $rng lte 140>>
<<if $penisbitten is 0>>
<<if $position isnot "wall">>
<<if $mouthuse is 0>><span class="purple"><<He>> shoves <<his>> penis against your lips.</span><<submission 5>><<set $mouthuse to "penis">><<set $mouthstate to "imminent">><<set $penis4 to "mouthimminent">><<set $speechmouthimminent to 1>>
<<else>>
<<He>> slowly traces <<his>> length across your exposed skin.<<neutral 1>>
<</if>>
<<else>>
<<He>> slowly traces <<his>> length across your exposed skin.<<neutral 1>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 150>><span class="purple"><<He>> presses <<his>> foot against your <<genitalsstop>></span><<neutral 5>><<violence 1>><<set $penis4 to "footjob">>
<<if $penisexist is 1>>
<<set $penisuse to "feet">><<set $speechpenisfoot to 1>>
<<else>>
<<set $vaginause to "feet">><<set $speechvaginafoot to 1>>
<</if>>
<<elseif $enemyanger + $rng lte 170>>
<<if $anususe is 0 and $analdisable is "f">>
<<if $loweranusexposed is 1>>
<<if $underanusexposed is 1>>
<span class="purple"><<He>> presses <<his>> penis against your anus, preparing to penetrate.</span><<sex 5>><<set $anususe to "penis">><<set $penis4 to "anusimminent">><<set $anusstate to "imminent">><<set $speechanusimminent to 1>>
<<elseif $underanusexposed is 0>><span class="blue"><<He>> presses <<his>> penis against your anus through your $underclothes.</span><<sex 3>><<set $penis4 to "anusentrance">><<set $anususe to "penis">><<set $underintegrity -= 10>><<set $anusstate to "entrance">><<set $speechanusentrance to 1>>
<</if>>
<<elseif $loweranusexposed is 0>><span class="blue"><<He>> presses <<his>> penis against your anus through your $lowerclothes.</span><<sex 2>><<set $penis4 to "anusentrance">><<set $anususe to "penis">><<set $lowerintegrity -= 10>><<set $anusstate to "entrance">><<set $speechanusentrance to 1>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng gte 171>>
<<if $vaginaexist is 1>>
<<if $vaginause is 0>>
<<if $lowervaginaexposed is 1>>
<<if $undervaginaexposed is 1>><span class="purple"><<He>> presses <<his>> penis against your <<pussycomma>> preparing to penetrate.</span><<sex 5>><<set $vaginause to "penis">><<set $penis4 to "vaginaimminent">><<set $vaginastate to "imminent">><<set $speechvaginaimminent to 1>>
<<elseif $undervaginaexposed is 0>><span class="blue"><<He>> presses <<his>> penis against your <<pussy>> through your $underclothes.</span><<set $underintegrity -= 10>><<sex 3>><<set $penis4 to "vaginaentrance">><<set $vaginause to "penis">><<set $vaginastate to "entrance">><<set $speechvaginaentrance to 1>>
<</if>>
<<elseif $lowervaginaexposed is 0>><span class="blue"><<He>> presses <<his>> penis against your <<pussy>> through your $lowerclothes.</span><<sex 2>><<set $penis4 to "vaginaentrance">><<set $vaginause to "penis">><<set $lowerintegrity -= 10>><<set $vaginastate to "entrance">><<set $speechvaginaentrance to 1>>
<</if>>
<</if>>
<<elseif $penisexist is 1>>
<<if $anususe is 0 and $analdisable is "f">>
<<if $loweranusexposed is 1>>
<<if $underanusexposed is 1>><span class="purple"><<He>> presses <<his>> penis against your anus, preparing to penetrate.</span><<sex 5>><<set $anususe to "penis">><<set $penis4 to "anusimminent">><<set $anusstate to "imminent">><<set $speechanusimminent to 1>>
<<elseif $underanusexposed is 0>><span class="blue"><<He>> presses <<his>> penis against your anus through your $underclothes.</span><<sex 3>><<set $penis4 to "anusentrance">><<set $anususe to "penis">><<set $underintegrity -= 10>><<set $anusstate to "entrance">><<set $speechanusentrance to 1>>
<</if>>
<<elseif $loweranusexposed is 0>><span class="blue"><<He>> presses <<his>> penis against your anus through your $lowerclothes.</span><<sex 2>><<set $penis4 to "anusentrance">><<set $anususe to "penis">><<set $lowerintegrity -= 10>><<set $anusstate to "entrance">><<set $speechanusentrance to 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<set $rng to random(1, 100)>>
<<if $vagina4 is "clothed">>
<<if $pronoun is "f">>
<<if $enemyarousal gte 40>><span class="blue"><<He>> lifts up <<his>> skirt, revealing <<his>> moistened pussy.</span><<set $vagina4 to 0>>
<</if>>
<<else>>
<<if $enemyarousal gte 40>><span class="blue"><<He>> unzips <<his>> fly, revealing <<his>> moistened pussy.</span><<set $vagina4 to 0>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $vagina4 is "frot">>
<<if $rng gte 101>><span class="blue"><<He>> moves <<his>> clit away and presses <<his>> hungry pussy against your <<penisstop>></span><<set $penisuse to "othervagina">><<set $vagina4 to "penisentrance">><<set $penisstate to "entrance">><<set $speechpenisentrance to 1>>
<<else>>
<<He>> rubs <<his>> clit against your glans.<<sex 5>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $vagina4 is "penis">>
<<if $rng gte 101>><span class="purple"><<He>> moves <<his>> pelvis away, releasing your <<penis>> from <<his>> vagina.</span><<sex 30>><<set $vagina4 to "penisimminent">><<bruise penis>><<violence 1>><<set $penistate to "imminent">><<set $speechpenisimminent to 1>>
<<elseif $rng gte 1>>
<<if $enemyanger gte 100>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
<<His>> continues to fuck your <<peniscomma>> <<his>> movements violent and erratic as <<his>> pussy slides along your length.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues to ride you, your penis helpless as it's fucked.
<<else>>
<<He>> fucks your <<penis>> with rough movements, intent on showing you who's boss.
<</if>>
<<elseif $enemyanger gte 20>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
You feel <<his>> vagina twitch and throb around your length <<he>> fucks you.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues to violate your <<peniscomma>> using you as a sex toy.
<<else>>
<<He>> fucks your <<peniscomma>> taking as much of you into <<his>> vagina as <<he>> can.
<</if>>
<<else>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
<<He>> continues riding your <<peniscomma>> <<his>> vagina rhythmically kneading and squeezing your length. <<His>> body jerks whenever you hit a sensitive spot.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues riding your <<peniscomma>> <<his>> vagina rhythmically kneading and squeezing your length.
<<else>>
<<He>> rides your <<penis>> with steady movements.
<</if>>
<</if>>
<<sex 30>><<bruise penis>><<violence 1>><<set $speechpenispenetrated to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $vagina4 is "penisimminent">>
<<if $rng gte 101>><span class="blue"><<He>> stops pressing <<his>> pussy against your <<penisstop>></span><<set $vagina4 to "penisentrance">><<set $penisstate to "entrance">><<set $speechpenisentrance to 1>>
<<elseif $rng gte 1>>
<<if $nopenile is 0>><<set $penisactiondefault to "take">>
<<if $penilevirginity is 0>><span class="pink"><<He>> eases your <<penis>> into <<his>> pussy, swallowing you to the base.</span><<sex 30>><<set $vagina4 to "penis">><<penilestat>><<bruise penis>><<violence 1>><<raped>><<penisraped>><<set $penisstate to "penetrated">><<set $speechpenispenetrated to 1>>
<<elseif $penilevirginity is 1>><span class="pink"><<He>> eases your virgin penis into <<his>> pussy,</span><span class="red"> separating your foreskin from your glans and forever robbing you of your purity.</span><<sex 100>><<set $vagina4 to "penis">><<set $penilevirginity to 0>><<bruise penis>><<penilestat>><<violence 100>><<raped>><<penisraped>><<set $penisstate to "penetrated">><<set $speechpenisvirgin to 1>>
<</if>>
<<else>>
Respecting your wishes, <<he>> does not envelope your <<penis>> with <<his>> vagina, instead teasing the tip of your glans.<<sex 15>><<set $speechpeniswithhold to 1>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $vagina4 is "penisentrance">>
<<if $rng gte 101>><span class="lblue"><<He>> moves <<his>> pussy away from your <<penisstop>></span><<set $vagina4 to 0>><<set $penisuse to 0>><<set $penisstate to 0>>
<<elseif $rng gte 1>>
<<if $lowervaginaexposed is 0>><<He>> rubs <<his>> pussy against your <<penis>> through your $lowerclothes.<<sex 5>><<set $lowerintegrity -= 10>><<set $speechpenisentrance to 1>>
<<elseif $lowervaginaexposed is 1>><<set $rng to random(1, 100)>>
<<if $undervaginaexposed is 0>><<He>> rubs <<his>> pussy against your <<penis>> through your $underclothes.<<sex 5>><<set $underintegrity -= 10>><<set $speechpenisentrance to 1>>
<<elseif $undervaginaexposed is 1>>
<<if $rng gte 71>>
<<if $nopenile is 1>>
<span class="purple"><<He>> presses <<his>> pussy against your <<penisstop>></span><<sex 20>><<set $vagina4 to "penisimminent">><<set $penisstate to "imminent">><<set $speechpenisimminent to 1>>
<<else>>
<span class="purple"><<He>> presses <<his>> pussy against your <<peniscomma>> preparing to envelope you fully.</span><<sex 20>><<set $vagina4 to "penisimminent">><<set $penisstate to "imminent">><<set $speechpenisimminent to 1>>
<</if>>
<<elseif $rng gte 1>><<He>> teases your <<penis>> with <<his>> labia.<<sex 10>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $vagina4 is "lefthand">>
<<if $rng lte 80>>
<<He>> strokes <<his>> pussy with <<his>> left hand.<<neutral 1>><<set $enemyarousal += 20>>
<<else>>
<span class="blue"><<He>> moves <<his>> left hand away from <<his>> pussy.</span>
<<set $lefthand4 to 0>><<set $vagina4 to 0>>
<</if>>
<</if>>
<<if $vagina4 is "righthand">>
<<if $rng lte 80>>
<<He>> strokes <<his>> pussy with <<his>> right hand.<<neutral 1>><<set $enemyarousal += 20>>
<<else>>
<span class="blue"><<He>> moves <<his>> right hand away from <<his>> pussy.</span>
<<set $righthand4 to 0>><<set $vagina4 to 0>>
<</if>>
<</if>>
<<if $vagina4 is "mouth">>
<<if $enemyanger gte 100>>
<<He>> covers your mouth with <<his>> pussy, making it difficult to breathe.<<violence 3>><<bruise face>><<set $speechvaginamouth to 1>>
<<else>>
<<if $mouthsubmit is 1>>
<<if $rng gte 1>>
<<He>> rubs <<his>> pussy against your lips.
<<if $enemyarousal gte (($enemyarousalmax / 5) * 3)>>
You can taste <<his>> juices.
<</if>>
<<sex 3>><<set $speechvaginamouth to 1>>
<<else>><<He>> moves <<his>> pussy away from your face.<<set $mouthuse to 0>><<set $mouthstate to 0>><<set $vagina4 to 0>>
<</if>>
<<else>>
<<if $rng gte 1>>
<<He>> rubs <<his>> pussy against your lips.
<<if $enemyarousal gte (($enemyarousalmax / 5) * 3)>>
You can taste <<his>> juices.
<</if>>
<<sex 3>><<set $speechvaginamouth to 1>>
<<else>><<He>> moves <<his>> pussy away from your face.<<set $mouthuse to 0>><<set $mouthstate to 0>><<set $vagina4 to 0>>
<</if>>
<</if>>
<</if>>
<</if>>
<<if $vagina4 is "vagina">>
<<if $rng gte 1>>
<<He>> kneads your pussies together.<<sex 20>><<set $speechvaginavagina to 1>>
<<else>>
<span class="lblue"><<He>> moves <<his>> pussy away from yours.</span><<set $vaginause to 0>><<set $vagina4 to 0>>
<</if>>
<</if>>
<<if $vagina4 is "leftarm">>
<<if $rng gte 1>>
<<He>> rubs <<his>> pussy against your fingers.<<submission 2>>
<<else>>
<<He>> moves your hand away from <<his>> pussy.<<set $leftarm to 0>><<set $vagina4 to 0>><<set $leftactiondefault to "leftplay">>
<</if>>
<</if>>
<<if $vagina4 is "rightarm">>
<<if $rng gte 1>>
<<He>> rubs <<his>> pussy against your fingers.<<submission 2>>
<<else>>
<<He>> moves your hand away from <<his>> pussy.<<set $rightarm to 0>><<set $vagina4 to 0>><<set $rightactiondefault to "rightplay">>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $vagina4 is "feet">>
<<if $rng gte 1>>
<<He>> rubs <<his>> pussy against your feet.<<submission 2>>
<<else>>
<<He>> moves your feet away from <<his>> pussy.<<set $feetuse to 0>><<set $vagina4 to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $vagina4 is "footjob">>
<<if $rng gte 101>>
<span class="blue"><<He>> stops pressing <<his>> foot against your <<genitalsstop>></span><<set $vagina4 to 0>>
<<if $penisexist is 1>>
<<set $penisuse to 0>>
<<else>>
<<set $vaginause to 0>>
<</if>>
<<else>>
<<if $penisexist is 1>>
<<He>> presses your penis against your stomach with <<his>> foot and rubs your glans between <<his>> toes.
<<set $speechpenisfoot to 1>><<neutral 5>><<violence 1>>
<<else>>
<<He>> rubs <<his>> foot against your <<pussystop>>
<<set $speechvaginafoot to 1>><<neutral 5>><<violence 1>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $vagina4 is "otherfrot">>
<<if $rng gte 101>><span class="blue"><<He>> shifts <<his>> ass and presses <<his>> anus against your <<penisstop>></span><<set $penisuse to "otheranus">><<set $vagina4 to "otheranusentrance">><<set $penisstate to "otheranusentrance">><<set $speechotheranusentrance to 1>>
<<else>>
<<He>> rubs <<his>> ass against your <<penisstop>><<sex 5>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $vagina4 is "otheranus">>
<<if $rng gte 101>><span class="purple"><<He>> moves <<his>> pelvis away, releasing your <<penis>> from <<his>> anus.</span><<sex 30>><<set $vagina4 to "otheranusimminent">><<bruise penis>><<violence 1>><<set $penisstate to "otheranusimminent">><<set $speechotheranusimminent to 1>>
<<elseif $rng gte 1>>
<<if $enemyanger gte 100>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
<<His>> continues to fuck your <<penis>> with <<his>> ass, <<his>> movements violent and erratic. Fluid from <<his>> pussy drools onto your length.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues to ride you, your penis helpless as it's fucked.
<<else>>
<<He>> fucks your <<penis>> with rough movements, intent on showing you who's boss.
<</if>>
<<elseif $enemyanger gte 20>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
You feel <<his>> ass twitch around your length as <<he>> fucks you.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues to violate your <<peniscomma>> using you as a sex toy.
<<else>>
<<He>> fucks your <<peniscomma>> taking as much of you into <<his>> ass as <<he>> can.
<</if>>
<<else>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
<<He>> continues riding your <<peniscomma>> <<his>> anus rhythmically pounding your length. <<His>> body jerks whenever you hit a sensitive spot.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues riding your <<peniscomma>> <<his>> anus rhythmically pounding your length.
<<else>>
<<He>> rides your <<penis>> with steady movements.
<</if>>
<</if>>
<<sex 30>><<bruise penis>><<violence 1>><<set $speechotheranus to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $vagina4 is "otheranusimminent">>
<<if $rng gte 101>><span class="blue"><<He>> stops pressing <<his>> ass against your <<penisstop>></span><<set $vagina4 to "otheranusentrance">><<set $penisstate to "otheranusentrance">><<set $speechotheranusentrance to 1>>
<<elseif $rng gte 1>>
<<if $nopenile is 0>><<set $penisactiondefault to "take">>
<<if $penilevirginity is 0>><span class="pink"><<He>> eases your <<penis>> into <<his>> ass, swallowing you to the base.</span><<sex 30>><<set $vagina4 to "otheranus">><<penilestat>><<bruise penis>><<violence 1>><<raped>><<penisraped>><<set $penisstate to "otheranus">><<set $speechotheranus to 1>>
<<elseif $penilevirginity is 1>><span class="pink"><<He>> eases your virgin penis into <<his>> ass,</span><span class="red"> separating your foreskin from your glans and forever robbing you of your purity.</span><<sex 100>><<set $vagina4 to "otheranus">><<set $penilevirginity to 0>><<bruise penis>><<penilestat>><<violence 100>><<raped>><<penisraped>><<set $penisstate to "otheranus">><<set $speechpenisvirgin to 1>>
<</if>>
<<else>>
Respecting your wishes, <<he>> does not envelope your <<penis>> with <<his>> ass, instead teasing the tip of your glans.<<sex 15>><<set $speechotheranuswithhold to 1>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $vagina4 is "otheranusentrance">>
<<if $rng gte 101>><span class="lblue"><<He>> moves <<his>> ass away from your <<penisstop>></span><<set $vagina4 to 0>><<set $penisuse to 0>><<set $penisstate to 0>>
<<elseif $rng gte 1>>
<<if $lowervaginaexposed is 0>><<He>> rubs <<his>> ass against your <<penis>> through your $lowerclothes.<<sex 5>><<set $lowerintegrity -= 10>><<set $speechotheranusentrance to 1>>
<<elseif $lowervaginaexposed is 1>><<set $rng to random(1, 100)>>
<<if $undervaginaexposed is 0>><<He>> rubs <<his>> ass against your <<penis>> through your $underclothes.<<sex 5>><<set $underintegrity -= 10>><<set $speechotheranusentrance to 1>>
<<elseif $undervaginaexposed is 1>>
<<if $rng gte 71>>
<<if $nopenile is 1>>
<span class="purple"><<He>> presses <<his>> ass against your <<penisstop>></span><<sex 20>><<set $vagina4 to "otheranusimminent">><<set $penisstate to "otheranusimminent">><<set $speechotheranusimminent to 1>>
<<else>>
<span class="purple"><<He>> presses <<his>> ass against your <<peniscomma>> preparing to take you in fully.</span><<sex 20>><<set $vagina4 to "otheranusimminent">><<set $penisstate to "otheranusimminent">><<set $speechotheranusimminent to 1>>
<</if>>
<<elseif $rng gte 1>><<He>> rubs your <<penis>> between <<his>> cheeks.<<sex 10>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<if $vagina4 is 0>>
<<if $enemyanger + $rng lte 20>><<He>> sways <<his>> hips suggestively.<<neutral 1>><<set $speechvaginaflaunt to 1>>
<<elseif $enemyanger + $rng lte 40>><<He>> twirls on the spot.<<neutral 3>><<set $speechvaginaflaunt to 1>>
<<elseif $enemyanger + $rng lte 50>>
<<if $penisexist is 1>>
<<if $penisuse is 0 and $analdisable is "f">>
<span class="blue"><<He>> straddles you, rubbing <<his>> ass against your <<penisstop>></span><<neutral 5>><<set $penisuse to "otheranus">><<set $vagina4 to "otheranusentrance">><<set $penisstate to "otheranusentrance">><<set $speechotheranusentrance to 1>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 60>><<He>> rubs <<his>> pussy against your thigh.<<neutral 10>>
<<elseif $enemyanger + $rng lte 80 and $lefthand4 is 0>>
<span class="lblue"><<He>> presses <<his>> fingers against <<his>> labia.</span><<neutral 1>><<set $enemyarousal += 10>><<set $vagina4 to "lefthand">><<set $lefthand4 to "othervagina">>
<<elseif $enemyanger + $rng lte 80 and $righthand4 is 0>>
<span class="lblue"><<He>> presses <<his>> fingers against <<his>> labia.</span><<neutral 1>><<set $enemyarousal += 10>><<set $vagina4 to "righthand">><<set $righthand4 to "othervagina">>
<<elseif $enemyanger + $rng lte 80>>
<<He>> rubs <<his>> pussy against your thigh.<<neutral 2>>
<<elseif $enemyanger + $rng lte 100 and $penisuse is 0 and $undervaginaexposed is 1 and $lowervaginaexposed is 1>>
<<set $penisuse to "othervagina">><<set $vagina4 to "penisentrance">><<set $penisstate to "entrance">><span class="blue"><<He>> straddles you, <<his>> pussy hovering close to your <<penisstop>></span>
<<elseif $enemyanger + $rng lte 120 and $penisuse is 0 and $penisexist is 1 and $undervaginaexposed is 1 and $lowervaginaexposed is 1>>
<<set $penisuse to "othervagina">><<set $vagina4 to "penisimminent">><<set $penisstate to "imminent">><span class="purple"><<He>> wraps <<his>> legs around your pelvis, pressing <<his>> pussy against your <<genitalsstop>></span>
<<elseif $enemyanger + $rng lte 120 and $vaginause is 0 and $vaginaexist is 1 and $undervaginaexposed is 1 and $lowervaginaexposed is 1>>
<<set $vaginause to "othervagina">><<set $vagina4 to "vagina">><<sex 20>><<He>> pushes <<his>> pussy against yours.
<<elseif $enemyanger + $rng lte 140>>
<<if $position is "wall">>
<<He>> sits on your protruding <<bottomcomma>> pressing down on you painfully.<<violence 3>>
<<elseif $mouth4 is 0>>
<<He>> rubs <<his>> clit against your face.<<violence 3>>
<<else>>
<<He>> frots against your thigh while squeezing it with <<his>> own.<<violence 3>>
<</if>>
<<elseif $enemyanger + $rng lte 160>><span class="purple"><<He>> presses <<his>> foot against your <<genitalsstop>></span><<neutral 5>><<set $vagina4 to "footjob">>
<<if $penisexist is 1>>
<<set $penisuse to "feet">><<set $speechpenisfoot to 1>>
<<else>>
<<set $vaginause to "feet">><<set $speechvaginafoot to 1>>
<</if>>
<<elseif $enemyanger + $rng lte 180>>
<<if $position is "wall">>
<<He>> kicks you in the <<bottomstop>><<violence 10>><<hitstat>><<bruise bottom>>
<<else>>
<<He>> kicks you in the stomach.<<violence 10>><<hitstat>><<bruise face>>
<</if>>
<<elseif $enemyanger + $rng lte 200 and $mouthuse is 0>>
<<if $pullaway is 1>><<set $pullaway to 0>>
Saliva drips from her pussy.
<<else>>
<<if $position is "wall">>
<<if $penisexist is 1>>
<<He>> kicks your <<penisstop>><<violence 20>><<hitstat>><<bruise penis>><<set $speechbeat to 1>>
<<elseif $vaginaexist is 1>>
<<He>> kicks your <<pussystop>><<violence 20>><<hitstat>><<bruise vagina>><<set $speechbeat to 1>>
<</if>>
<<else>>
<span class="purple"><<He>> wraps <<his>> legs around your head and presses <<his>> pussy against your mouth.</span>
<<submission 5>><<set $mouthuse to "othervagina">><<set $vagina4 to "mouth">><<set $mouthstate to "othervagina">><<violence 3>><<bruise face>><<set $speechvaginamouth to 1>>
<</if>>
<</if>>
<<else>>
<<if $position is "wall">>
<<if $penisexist is 1>>
<<He>> kicks your <<penisstop>><<violence 20>><<hitstat>><<bruise penis>><<set $speechbeat to 1>>
<<elseif $vaginaexist is 1>>
<<He>> kicks your <<pussystop>><<violence 20>><<hitstat>><<bruise vagina>><<set $speechbeat to 1>>
<</if>>
<<else>>
<<He>> kicks you in the face.<<violence 10>><<bruise face>><<set $speechbeat to 1>><<hitstat>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth4 is "thigh">>
<<He>> kisses and licks your thigh.<<neutral 5>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth4 is "bottom">>
<<He>> kisses and licks your <<bottomstop>><<neutral 5>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth4 is "anus">>
<<if $rng gte 101>><span class="purple"><<He>> retracts <<his>> tongue from your anus.</span><<sex 30>><<set $mouth4 to "anusimminent">><<bruise anus>><<violence 1>><<set $anusstate to "othermouthimminent">>
<<elseif $rng gte 1>>
<<if $enemyarousal lte ($enemyarousalmax / 5)>>
<<He>> caresses your anus with <<his>> tongue.<<sex 30>><<bruise anus>><<violence 1>>
<<elseif $enemyarousal lte (($enemyarousalmax / 5) * 2)>>
<<His>> tongue probes inside your <<bottomstop>><<sex 30>><<bruise anus>><<violence 1>>
<<elseif $enemyarousal lte (($enemyarousalmax / 5) * 3)>>
<<He>> circles <<his>> tongue inside your <<bottomstop>><<sex 30>><<bruise anus>><<violence 1>>
<<elseif $enemyarousal lte (($enemyarousalmax / 5) * 4)>>
<<He>> presses <<his>> mouth firmly against your <<bottomcomma>> letting <<him>> push <<his>> tongue deeper into your anus.<<sex 30>><<bruise anus>><<violence 1>>
<<else>>
Repeatedly thrusting and retracting, <<he>> fucks your <<bottom>> with <<his>> tongue.<<sex 30>><<bruise anus>><<violence 1>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth4 is "anusimminent">>
<<if $rng gte 101>><span class="blue"><<He>> stops pressing <<his>> tongue against your anus.</span><<set $mouth4 to "anusentrance">><<set $anusstate to "othermouthentrance">>
<<elseif $rng gte 1>>
<<if $noanal is 0>>
<<if $analvirginity is 0>><span class="pink"><<He>> pushes <<his>> tongue into your anus.</span><<sex 30>><<set $mouth4 to "anus">><<analstat>><<bruise anus>><<violence 1>><<raped>><<set $anusstate to "othermouth">>
<<elseif $analvirginity is 1>><span class="pink"><<He>> pushes <<his>> tongue into your virgin anus,</span><span class="red"> violating you in a way you hadn't conceived of.</span><<sex 100>><<set $mouth4 to "anus">><<set $analvirginity to 0>><<bruise anus>><<analstat>><<violence 100>><<raped>><<set $anusstate to "othermouth">>
<</if>>
<<else>>
Respecting your wishes, <<he>> does not penetrate your <<bottom>> with <<his>> tongue, instead licking your anus.<<sex 15>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth4 is "anusentrance">>
<<if $rng gte 101>><span class="lblue"><<He>> moves <<his>> head away from your <<bottomstop>></span><<set $mouth4 to 0>><<set $anususe to 0>><<set $anusstate to 0>>
<<if $vagina4 is "othermouth">>
<<set $vagina4 to 0>>
<</if>>
<<if $penis4 is "othermouth">>
<<set $penis4 to 0>>
<</if>>
<<elseif $rng gte 1>>
<<if $loweranusexposed is 0>><<He>> circles <<his>> tongue around your anus through your $lowerclothes.<<sex 5>><<set $lowerintegrity -= 10>>
<<elseif $loweranusexposed is 1>><<set $rng to random(1, 100)>>
<<if $underanusexposed is 0>><<He>> circles <<his>> tongue around your anus through your $underclothes.<<sex 5>><<set $underintegrity -= 10>>
<<elseif $underanusexposed is 1>>
<<if $rng gte 71>>
<<if $noanal is 1>>
<span class="purple"><<He>> presses <<his>> tongue against your anus.</span><<sex 20>><<set $mouth4 to "anusimminent">><<set $anusstate to "othermouthimminent">>
<<else>>
<span class="purple"><<He>> presses <<his>> tongue against your anus, preparing to penetrate you.</span><<sex 20>><<set $mouth4 to "anusimminent">><<set $anusstate to "othermouthimminent">>
<</if>>
<<elseif $rng gte 1>><<He>> kisses and licks your <<bottomstop>><<sex 10>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth4 is "vagina">>
<<if $rng gte 101>><span class="purple"><<He>> retracts <<his>> tongue from your <<pussystop>></span><<sex 30>><<set $mouth4 to "vaginaimminent">><<bruise vagina>><<violence 1>><<set $vaginastate to "othermouthimminent">>
<<elseif $rng gte 1>>
<<if $enemyarousal lte ($enemyarousalmax / 5)>>
<<He>> caresses your vagina with <<his>> tongue.<<sex 30>><<bruise vagina>><<violence 1>>
<<elseif $enemyarousal lte (($enemyarousalmax / 5) * 2)>>
<<He>> presses down on your clit with <<his>> teeth while exploring your vagina with <<his>> tongue.<<sex 30>><<bruise vagina>><<violence 1>>
<<elseif $enemyarousal lte (($enemyarousalmax / 5) * 3)>>
<<He>> circles <<his>> tongue around your vagina.<<sex 30>><<bruise vagina>><<violence 1>>
<<elseif $enemyarousal lte (($enemyarousalmax / 5) * 4)>>
<<He>> presses <<his>> mouth firmly against your <<pussycomma>> then pushes <<his>> tongue deeper into your vagina. <<He>> slowly pulls out again, then takes a deep breath.<<sex 30>><<bruise vagina>><<violence 1>>
<<else>>
Repeatedly thrusting and retracting, <<he>> fucks your <<pussy>> with <<his>> tongue.<<sex 30>><<bruise vagina>><<violence 1>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth4 is "vaginaimminent">>
<<if $rng gte 101>><span class="blue"><<He>> stops pressing <<his>> tongue against your <<pussystop>></span><<set $mouth4 to "vaginaentrance">><<set $vaginastate to "othermouthentrance">>
<<elseif $rng gte 1>>
<<if $novaginal is 0>>
<<if $vaginalvirginity is 0>><span class="pink"><<He>> pushes <<his>> tongue between your <<pussy>> lips.</span><<sex 30>><<set $mouth4 to "vagina">><<vaginalstat>><<bruise vagina>><<violence 1>><<raped>><<vaginaraped>><<set $vaginastate to "othermouth">>
<<elseif $vaginalvirginity is 1>><span class="pink"><<He>> pushes <<his>> tongue into your virgin pussy,</span><span class="red"> breaking your hymen and forever robbing you of your purity.</span><<sex 100>><<set $mouth4 to "vagina">><<set $vaginalvirginity to 0>><<bruise vagina>><<vaginalstat>><<violence 100>><<raped>><<vaginaraped>><<set $vaginastate to "othermouth">>
<</if>>
<<else>>
Respecting your wishes, <<he>> does not penetrate your <<pussy>> with <<his>> tongue, instead running <<his>> tongue up and down your labia.<<sex 15>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth4 is "vaginaentrance">>
<<if $rng gte 101>><span class="lblue"><<He>> moves <<his>> head away from your <<pussystop>></span><<set $mouth4 to 0>><<set $vaginause to 0>><<set $vaginastate to 0>>
<<if $vagina4 is "othermouth">>
<<set $vagina4 to 0>>
<</if>>
<<if $penis4 is "othermouth">>
<<set $penis4 to 0>>
<</if>>
<<elseif $rng gte 1>>
<<if $lowervaginaexposed is 0>><<He>> traces the outline of your <<pussy>> with <<his>> tongue through your $lowerclothes.<<sex 5>><<set $lowerintegrity -= 10>>
<<elseif $lowervaginaexposed is 1>><<set $rng to random(1, 100)>>
<<if $undervaginaexposed is 0>><<He>> traces the outline of your <<pussy>> with <<his>> tongue through your $underclothes.<<sex 5>><<set $underintegrity -= 10>>
<<elseif $undervaginaexposed is 1>>
<<if $rng gte 71>>
<<if $novaginal is 1>>
<span class="purple"><<He>> presses <<his>> lips against your <<pussystop>></span><<sex 20>><<set $mouth4 to "vaginaimminent">><<set $vaginastate to "othermouthimminent">>
<<else>>
<span class="purple"><<He>> presses <<his>> lips against your <<pussycomma>> preparing to fuck you with <<his>> tongue.</span><<sex 20>><<set $mouth4 to "vaginaimminent">><<set $vaginastate to "othermouthimminent">>
<</if>>
<<elseif $rng gte 1>><<He>> blows on your clit and runs <<his>> tongue around your labia.<<sex 10>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth4 is "penis">>
<<if $rng gte 101>><span class="purple"><<He>> moves <<his>> head back, releasing your <<penis>> from <<his>> mouth.</span><<sex 30>><<set $mouth4 to "penisimminent">><<bruise penis>><<violence 1>><<set $penisstate to "othermouthimminent">>
<<elseif $rng gte 1>>
<<if $enemyarousal lte ($enemyarousalmax / 5)>>
<<He>> slowly caresses your shaft with <<his>> tongue.<<sex 30>><<bruise penis>><<violence 1>>
<<elseif $enemyarousal lte (($enemyarousalmax / 5) * 2)>>
Eyes fixed on your face, <<he>> wraps <<his>> tongue around your <<penis>> and sucks.<<sex 30>><<bruise penis>><<violence 1>>
<<elseif $enemyarousal lte (($enemyarousalmax / 5) * 3)>>
<<He>> squeezes <<his>> lips around your <<peniscomma>> and circles <<his>> tongue around your glans.<<sex 30>><<bruise penis>><<violence 1>>
<<elseif $enemyarousal lte (($enemyarousalmax / 5) * 4)>>
<<He>> takes you deeper into <<his>> mouth, until your <<penis>> disappears inside <<him>> completely. <<He>> slowly pushes you out again, then takes a deep breath.<<sex 30>><<bruise penis>><<violence 1>>
<<else>>
<<He>> repeatedly swallows and expels your <<peniscomma>> fucking you with <<his>> mouth.<<sex 30>><<bruise penis>><<violence 1>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth4 is "penisimminent">>
<<if $rng gte 101>><span class="blue"><<He>> stops pressing <<his>> lips against your <<penisstop>></span><<set $mouth4 to "penisentrance">><<set $penisstate to "othermouthentrance">>
<<elseif $rng gte 1>>
<<if $nopenile is 0>>
<<if $penilevirginity is 0>><span class="pink"><<He>> pushes <<his>> lips against your <<peniscomma>> taking you into <<his>> mouth.</span><<sex 30>><<set $mouth4 to "penis">><<penilestat>><<bruise penis>><<violence 1>><<raped>><<penisraped>><<set $penisstate to "othermouth">>
<<elseif $penilevirginity is 1>><span class="pink"><<He>> pushes <<his>> lips against your virgin penis, taking you into <<his>> mouth,</span><span class="red"> separating your foreskin from your glans and forever robbing you of your purity.</span><<sex 100>><<set $mouth4 to "penis">><<set $penilevirginity to 0>><<bruise penis>><<penilestat>><<violence 100>><<raped>><<penisraped>><<set $penisstate to "othermouth">>
<</if>>
<<else>>
Respecting your wishes, <<he>> does not envelope your <<penis>> with <<his>> mouth, instead kissing the tip of your glans.<<sex 15>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth4 is "penisentrance">>
<<if $rng gte 101>><span class="lblue"><<He>> moves <<his>> head away from your <<penisstop>></span><<set $mouth4 to 0>><<set $penisuse to 0>><<set $penisstate to 0>>
<<if $vagina4 is "othermouth">>
<<set $vagina4 to 0>>
<</if>>
<<if $penis4 is "othermouth">>
<<set $penis4 to 0>>
<</if>>
<<elseif $rng gte 1>>
<<if $lowervaginaexposed is 0>><<He>> traces the outline of your <<penis>> with <<his>> tongue through your $lowerclothes.<<sex 5>><<set $lowerintegrity -= 10>>
<<elseif $lowervaginaexposed is 1>><<set $rng to random(1, 100)>>
<<if $undervaginaexposed is 0>><<He>> traces the outline of your <<penis>> with <<his>> tongue through your $underclothes.<<sex 5>><<set $underintegrity -= 10>>
<<elseif $undervaginaexposed is 1>>
<<if $rng gte 71>>
<<if $nopenile is 1>>
<span class="purple"><<He>> presses <<his>> lips against your <<penisstop>></span><<sex 20>><<set $mouth4 to "penisimminent">><<set $penisstate to "othermouthimminent">>
<<else>>
<span class="purple"><<He>> presses <<his>> lips against your <<peniscomma>> preparing to take you in <<his>> mouth proper.</span><<sex 20>><<set $mouth4 to "penisimminent">><<set $penisstate to "othermouthimminent">>
<</if>>
<<elseif $rng gte 1>><<He>> blows on and licks the tip of your <<penisstop>><<sex 10>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth4 is "kiss">>
<<if $speechvaginavirgin isnot 1 and $speechpenisvirgin isnot 1 and $speechanusvirgin isnot 1 and $speechmouthvirgin isnot 1>>
<<if $rng gte 101>>
<span class="lblue"><<He>> pulls <<his>> mouth away from yours.</span><<set $mouth4 to 0>><<set $mouthuse to 0>><<set $mouthstate to 0>>
<<else>>
<<if $enemyanger lte 20>>
<<He>> explores your mouth with <<his>> tongue.<<sex 2>>
<<else>>
<<He>> thrusts <<his>> tongue deep into your mouth.<<violence 1>>
<</if>>
<</if>>
<<else>>
<span class="lblue"><<He>> pulls <<his>> mouth away from yours.</span><<set $mouthuse to 0>><<set $mouth4 to 0>><<set $mouthstate to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth4 is "kissimminent">>
<<if $speechvaginavirgin isnot 1 and $speechpenisvirgin isnot 1 and $speechanusvirgin isnot 1 and $speechmouthvirgin isnot 1>>
<<if $rng gte 101>>
<span class="lblue"><<He>> pulls <<his>> mouth away from yours.</span><<set $mouth4 to 0>><<set $mouthuse to 0>><<set $mouthstate to 0>>
<<elseif $rng lte 100>>
<<He>> pushes <<his>> tongue between your lips.<<set $mouth4 to "kiss">><<set $mouthstate to "kiss">><<sex 2>>
<<else>>
<<if $enemyanger lte 20>>
<<He>> gently probes your lips with <<his>> tongue.<<sex 2>>
<<else>>
<<He>> bites and toys with your lips.<<violence 1>>
<</if>>
<</if>>
<<else>>
<span class="lblue"><<He>> pulls <<his>> mouth away from yours.</span><<set $mouthuse to 0>><<set $mouth4 to 0>><<set $mouthstate to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth4 is "kissentrance">>
<<if $speechvaginavirgin isnot 1 and $speechpenisvirgin isnot 1 and $speechanusvirgin isnot 1 and $speechmouthvirgin isnot 1>>
<<if $rng gte 101>>
<span class="lblue"><<He>> pulls <<his>> mouth away from yours.</span><<set $mouth4 to 0>><<set $mouthuse to 0>><<set $mouthstate to 0>>
<<elseif $rng lte 100>>
<<He>> pulls you closer and presses your lips together in a kiss.<<set $mouth4 to "kissimminent">><<set $mouthstate to "kissimminent">><<sex 2>>
<<else>>
<<if $enemyanger lte 20>>
<<He>> gently brushes <<his>> lips against yours.<<sex 1>>
<<else>>
<<He>> bites your lower lip.<<violence 1>>
<</if>>
<</if>>
<<else>>
<span class="lblue"><<He>> pulls <<his>> mouth away from yours.</span><<set $mouthuse to 0>><<set $mouth4 to 0>><<set $mouthstate to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth4 is 0>>
<<if $speechvaginavirgin is 1>>
<<if $enemyanger lte 60>>
<<He>> speaks. "You were a virgin! I can't believe my luck!"
<<else>>
<<He>> speaks. "I felt your hymen tear bitch. Something to remember me by."
<</if>>
<<elseif $speechpenisvirgin is 1>>
<<if $enemyanger lte 60>>
<<He>> speaks. "AHH! This was your first time wasn't it? It feels so good!"
<<else>>
<<He>> speaks. "How's it feel to have your virgin dick broken in? Feels amazing for me."
<</if>>
<<elseif $speechanusvirgin is 1>>
<<if $enemyanger lte 60>>
<<He>> speaks. "It's so tight! This must be the first time your ass has been used like this."
<<else>>
<<He>> speaks. "It's so tight! This must be the first time your ass has been used like this. I've got plenty more work to do before you're properly broken in."
<</if>>
<<elseif $speechmouthvirgin is 1>>
<<if $enemyanger lte 60>>
<<He>> speaks. "Is this the first time you've tasted dick?"
<<else>>
<<He>> speaks. "Is this the first time you've tasted dick? You'll be a cum-addicted cock slave soon."
<</if>>
<<elseif $speechcum is 1 and $rng gte 61 and $speechorgasmrepeat lte 1 and $speechorgasmcount lte 6>>
<<cumspeech>>
<<elseif $rng gte 61>>
<<combatspeech>><<neutral 1>>
<<elseif $rng gte 91>>
<<basespeech>><<neutral 1>>
<<else>>
<<set $rng to random(1, 100)>>
<<if $enemyanger + $rng lte 20>><<He>> <<admires>> your body.<<neutral 1>>
<<elseif $enemyanger + $rng lte 25>>
<<if $position is "wall">>
<<He>> <<admires>> your helpless <<bottomstop>><<neutral 1>>
<<else>>
<<He>> <<admires>> your hair.<<neutral 1>>
<</if>>
<<elseif $enemyanger + $rng lte 30>>
<<if $position is "wall">>
<<He>> <<admires>> your helpless hips.<<neutral 1>>
<<else>>
<<He>> <<admires>> your chest.<<neutral 1>>
<</if>>
<<elseif $enemyanger + $rng lte 35>>
<<He>> <<admires>> your legs.<<neutral 1>>
<<elseif $enemyanger + $rng lte 40>>
<<if $position is "wall">>
<<He>> <<admires>> your helpless legs.<<neutral 1>>
<<else>>
<<He>> <<admires>> your face.<<neutral 1>>
<</if>>
<<elseif $enemyanger + $rng lte 45>>
<<if $position is "wall">>
<<He>> kisses your helpless thighs.<<neutral 3>>
<<else>>
<<He>> kisses you on the forehead.<<neutral 3>>
<</if>>
<<elseif $enemyanger + $rng lte 50>>
<<if $position is "wall">>
<<He>> kisses you on the hips.<<neutral 3>>
<<else>>
<<He>> kisses you on the cheek.<<neutral 3>>
<</if>>
<<elseif $enemyanger + $rng lte 55>>
<<if $position is "wall">>
<<He>> licks your helpless thighs.<<neutral 3>>
<<else>>
<<He>> kisses your neck.<<neutral 3>>
<</if>>
<<elseif $enemyanger + $rng lte 60>>
<<if $position is "wall">>
<<He>> licks your helpless hips.<<neutral 3>>
<<else>>
<<He>> licks your cheek.<<neutral 3>>
<</if>>
<<elseif $enemyanger + $rng lte 80>><<neutral 10>>
<<if $position is "wall">>
<<He>> licks your helpless legs.<<neutral 3>>
<<else>>
<<if $mouthuse is 0>>
<span class="blue"><<He>> moves <<his>> lips close to yours, about to kiss.</span><<set $mouthuse to "kiss">><<set $mouthstate to "kissentrance">><<set $mouth4 to "kissentrance">><<sex 1>>
<<else>>
<<He>> licks your cheek.
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 84>><<neutral 10>>
<<if $anususe is 0 and $vagina4 is 0 and $analdisable is "f">>
<span class="blue"><<He>> kneels behind you. You feel <<his>> breath on your <<bottomstop>></span><<set $anususe to "othermouth">><<set $anusstate to "othermouthentrance">><<set $mouth4 to "anusentrance">><<set $vagina4 to "othermouth">><<sex 1>>
<<elseif $anususe is 0 and $penis4 is 0 and $analdisable is "f">>
<span class="blue"><<He>> kneels behind you. You feel <<his>> breath on your <<bottomstop>></span><<set $anususe to "othermouth">><<set $anusstate to "othermouthentrance">><<set $mouth4 to "anusentrance">><<set $penis4 to "othermouth">><<sex 1>>
<</if>>
<<elseif $enemyanger + $rng lte 92>><<neutral 10>>
<<if $vaginause is 0 and $vagina4 is 0 and $vaginaexist is 1>>
<span class="blue"><<He>> kneels beside you. You feel <<his>> breath on your <<pussystop>></span><<set $vaginause to "othermouth">><<set $vaginastate to "othermouthentrance">><<set $mouth4 to "vaginaentrance">><<set $vagina4 to "othermouth">><<sex 1>>
<<elseif $vaginause is 0 and $penis4 is 0 and $vaginaexist is 1>>
<span class="blue"><<He>> kneels beside you. You feel <<his>> breath on your <<pussystop>></span><<set $vaginause to "othermouth">><<set $vaginastate to "othermouthentrance">><<set $mouth4 to "vaginaentrance">><<set $penis4 to "othermouth">><<sex 1>>
<<else>>
<<He>> breathes on your skin, making your hair stand on end.<<neutral 1>>
<</if>>
<<elseif $enemyanger + $rng lte 100>><<neutral 10>>
<<if $penisuse is 0 and $penis4 is 0 and $penisexist is 1>>
<span class="blue"><<He>> kneels beside you. You feel <<his>> breath on your <<penisstop>></span><<set $penisuse to "othermouth">><<set $penisstate to "othermouthentrance">><<set $mouth4 to "penisentrance">><<set $vagina4 to "othermouth">><<sex 1>>
<<elseif $penisuse is 0 and $vagina4 is 0 and $penisexist is 1>>
<span class="blue"><<He>> kneels beside you. You feel <<his>> breath on your <<penisstop>></span><<set $penisuse to "othermouth">><<set $penisstate to "othermouthentrance">><<set $mouth4 to "penisentrance">><<set $penis4 to "othermouth">><<sex 1>>
<<else>>
<<He>> breathes on your skin, making your hair stand on end.<<neutral 1>>
<</if>>
<<elseif $enemyanger + $rng lte 105>>
<<if $position is "wall">>
<<He>> kisses and caresses your helpless thighs with <<his>> tongue.<<neutral 10>>
<<else>>
<<He>> kisses and caresses your nipple with <<his>> tongue.<<neutral 10>>
<</if>>
<<elseif $enemyanger + $rng lte 110>>
<<if $position is "wall">>
<<He>> kisses and gently bites your helpless <<bottomstop>><<neutral 10>>
<<else>>
<<He>> kisses and gently bites you on the neck.<<neutral 10>>
<</if>>
<<elseif $enemyanger + $rng lte 115>>
<<He>> spits on your <<genitalsstop>><<neutral 5>>
<<elseif $enemyanger + $rng lte 120>>
<<He>> spits on your <<bottomstop>><<neutral 5>>
<<elseif $enemyanger + $rng lte 130>>
<<He>> spits on your stomach.<<neutral 5>>
<<elseif $enemyanger + $rng lte 140>>
<<if $position is "wall">>
<<He>> spits on your helpless thighs.<<neutral 5>>
<<else>>
<<He>> spits on your face.<<neutral 5>>
<</if>>
<<elseif $enemyanger + $rng lte 150>>
<<He>> bites your <<bottomstop>><<violence 10>><<hitstat>><<bruise bottom>>
<<elseif $enemyanger + $rng lte 160>>
<<if $position is "wall">>
<<He>> bites your thighs.<<violence 10>><<hitstat>><<bruise thigh>>
<<else>>
<<He>> bites your shoulders.<<violence 10>><<hitstat>><<bruise leftarm>><<bruise rightarm>>
<</if>>
<<elseif $enemyanger + $rng lte 170>>
<<if $position is "wall">>
<<He>> bites your hips.<<violence 10>><<hitstat>><<bruise tummy>>
<<else>>
<<He>> bites your neck.<<violence 10>><<hitstat>><<bruise neck>>
<</if>>
<<elseif $enemyanger + $rng lte 180>>
<<if $position is "wall">>
<<He>> bites your thighs.<<violence 10>><<hitstat>><<bruise thigh>>
<<else>>
<<He>> bites your cheek.<<violence 10>><<hitstat>><<bruise face>>
<</if>>
<<elseif $enemyanger + $rng gte 190>>
<<if $position is "wall">>
<<He>> bites your <<bottomstop>><<violence 10>><<hitstat>><<bruise bottom>>
<<else>>
<<He>> bites your <<breastsstop>><<violence 10>><<hitstat>><<bruise chest>>
<</if>>
<</if>>
<</if>>
<</if>>
<<manend>>
<<set $pullaway to 0>>
<</nobr>><</widget>>
:: Widgets Combat Man 5 [widget]
<<widget "man5">><<nobr>>
<<if $pronoun5 is "m">>
<<set $pronoun to "m">>
<</if>>
<<if $pronoun5 is "f">>
<<set $pronoun to "f">>
<</if>>
<<if $pronoun5 is "i">>
<<set $pronoun to "i">>
<</if>>
<<if $pronoun5 is "n">>
<<set $pronoun to "n">>
<</if>>
<<if $pronoun5 is "t">>
<<set $pronoun to "t">>
<</if>>
<<man5speech>>
<<set $intro5 to 1>>
<<if $lefthand5 is "spank">><<bruise bottom>><<hitstat>><<set $speechspank to 1>>
<<He>> spanks your <<bottom>>
<<if $lowerclothes isnot "naked" and $lowerstate is "waist">>
through your $lowerclothes.
<<elseif $underclothes isnot "naked" and $understate is "waist">>
through your $underclothes.
<<else>>
reddening your exposed skin.
<</if>>
<<violence 5>>
<</if>>
<<if $righthand5 is "spank">><<bruise bottom>><<hitstat>>
<<He>> spanks your <<bottom>><<set $speechspank to 1>>
<<if $lowerclothes isnot "naked" and $lowerstate is "waist">>
through your $lowerclothes.
<<elseif $underclothes isnot "naked" and $understate is "waist">>
through your $underclothes.
<<else>>
reddening your exposed skin.
<</if>>
<<violence 5>>
<</if>>
<<if $lefthand5 is "arms">>
<<if $enemytrust gte 20 and $enemyanger lte 20>><span class="lblue"><<He>> releases your arms.</span><<set $lefthand5 to 0>><<set $leftarm to 0>><<set $rightarm to 0>>
<<else>><<He>> grips your arms.
<<violence 6>><<bruise leftarm>><<bruise rightarm>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand5 is "arms">>
<<if $enemytrust gte 20 and $enemyanger lte 20>><span class="lblue"><<He>> releases your arms.</span><<set $righthand5 to 0>><<set $leftarm to 0>><<set $rightarm to 0>>
<<else>><<He>> grips your arms.
<<violence 6>><<bruise leftarm>><<bruise rightarm>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand5 is "leftarm">>
<<if $enemytrust gte 20 and $enemyanger lte 20>><span class="lblue"><<He>> releases your left arm.</span><<set $lefthand5 to 0>><<set $leftarm to 0>>
<<else>><<He>> grips your left arm.<<violence 3>><<bruise leftarm>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand5 is "leftarm">>
<<if $enemytrust gte 20 and $enemyanger lte 20>><span class="lblue"><<He>> releases your left arm.</span><<set $righthand5 to 0>><<set $leftarm to 0>>
<<else>><<He>> grips your left arm.<<violence 3>><<bruise leftarm>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand5 is "rightarm">>
<<if $enemytrust gte 20 and $enemyanger lte 20>><span class="lblue"><<He>> releases your right arm.</span><<set $lefthand5 to 0>><<set $rightarm to 0>>
<<else>><<He>> grips your right arm.<<violence 3>><<bruise rightarm>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand5 is "rightarm">>
<<if $enemytrust gte 20 and $enemyanger lte 20>><span class="lblue"><<He>> releases your right arm.</span><<set $righthand5 to 0>><<set $rightarm to 0>>
<<else>><<He>> grips your right arm.<<violence 3>><<bruise rightarm>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand5 is "vaginaentrance">>
<<if $rng gte 101>><span class="blue"><<He>> moves <<his>> left hand away from your <<pussystop>></span><<set $lefthand5 to 0>><<set $vaginause to 0>>
<<elseif $rng gte 81>><<He>> <<strokes>> your labia.<<neutral 10>>
<<elseif $rng gte 21>><<He>> gives your clitoris a tweak.<<set $speechclit to 1>><<neutral 10>>
<<elseif $rng lte 20>><span class="pink"><<He>> plunges a finger into your <<pussystop>></span><<neutral 15>><<set $lefthand5 to "vagina">><<set $speechvagina to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand5 is "vaginaentrance">>
<<if $rng gte 101>><span class="blue"><<He>> moves <<his>> right hand away from your <<pussystop>></span><<set $righthand5 to 0>><<set $vaginause to 0>>
<<elseif $rng gte 51>><<He>> <<strokes>> your labia.<<neutral 10>>
<<elseif $rng gte 21>><<He>> gives your clitoris a tweak.<<neutral 10>><<set $speechclit to 1>>
<<elseif $rng lte 20>><span class="pink"><<He>> plunges a finger into your warm <<pussystop>></span><<neutral 15>><<set $righthand5 to "vagina">><<set $speechvagina to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand5 is "penisentrance">>
<<if $rng gte 101>><span class="blue"><<He>> moves <<his>> left hand away from your <<penisstop>></span><<set $lefthand5 to 0>><<set $penisuse to 0>>
<<elseif $rng gte 51>><<He>> <<strokes>> your shaft.<<neutral 10>>
<<elseif $rng gte 21>><<He>> rubs your glans.<<neutral 10>><<set $speechglans to 1>>
<<elseif $rng lte 20>><span class="pink"><<He>> wraps <<his>> fingers around your <<penisstop>></span><<neutral 15>><<set $lefthand5 to "penis">><<set $speechpenis to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand5 is "penisentrance">>
<<if $rng gte 101>><span class="blue"><<He>> moves <<his>> right hand away from your <<penisstop>></span><<set $righthand5 to 0>><<set $penisuse to 0>>
<<elseif $rng gte 51>><<He>> <<strokes>> your shaft.<<neutral 10>>
<<elseif $rng gte 21>><<He>> rubs your glans.<<neutral 10>><<set $speechglans to 1>>
<<elseif $rng lte 20>><span class="pink"><<He>> wraps <<his>> fingers around your penis.</span><<neutral 15>><<set $righthand5 to "penis">><<set $speechpenis to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand5 is "vagina">>
<<if $rng gte 101>><span class="purple"><<He>> slides <<his>> finger out of your <<pussystop>></span><<set $lefthand5 to "vaginaentrance">><<neutral 15>>
<<elseif $rng lte 100>><<He>> <<strokes>> the inside of your <<pussycomma>><<neutral 20>><<set $speechvagina to 1>>
<<if $arousal gte 8000>>
causing involuntary shudders.
<<elseif $arousal gte 2000>>
coaxing out lewd fluid.
<<else>>
eager to explore it.
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand5 is "vagina">>
<<if $rng gte 101>><span class="purple"><<He>> slides <<his>> finger out of your <<pussystop>></span><<set $righthand5 to "vaginaentrance">><<neutral 15>>
<<elseif $rng lte 100>><<He>> <<strokes>> the inside of your <<pussycomma>><<neutral 20>><<set $speechvagina to 1>>
<<if $arousal gte 8000>>
causing you involuntary shudders.
<<elseif $arousal gte 2000>>
coaxing out lewd fluid.
<<else>>
invading your body in a most sordid manner.
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand5 is "penis">>
<<if $rng gte 101>><span class="purple"><<He>> releases your <<penis>> from <<his>> grip.</span><<set $lefthand5 to "penisentrance">><<neutral 15>>
<<elseif $rng lte 100>><<He>> massages the length of your <<peniscomma>><<neutral 20>><<set $speechpenis to 1>>
<<if $arousal gte 8000>>
causing you involuntary shudders.
<<elseif $arousal gte 2000>>
coaxing out lewd fluid.
<<else>>
exploiting your body's natural reactions in a most sordid manner.
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand5 is "penis">>
<<if $rng gte 101>><span class="purple"><<He>> releases your <<penis>> from <<his>> grip.</span><<set $righthand5 to "penisentrance">><<neutral 15>>
<<elseif $rng lte 100>><<He>> massages the length of your <<peniscomma>><<neutral 20>><<set $speechpenis to 1>>
<<if $arousal gte 8000>>
causing you involuntary shudders.
<<elseif $arousal gte 2000>>
coaxing out lewd fluid.
<<else>>
exploiting your body's natural reactions in a most sordid manner.
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand5 is "anusentrance">>
<<if $rng gte 101>><span class="blue"><<He>> moves <<his>> left hand away from your ass.</span><<set $lefthand5 to 0>><<set $vaginause to 0>>
<<elseif $rng gte 21>><<He>> <<strokes>> your anus.<<neutral 10>>
<<elseif $rng lte 20>><span class="pink"><<He>> plunges a finger into your ass.</span><<neutral 15>><<set $lefthand5 to "anus">><<set $speechanus to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand5 is "anusentrance">>
<<if $rng gte 101>><span class="blue"><<He>> moves <<his>> hand away from your ass.</span><<set $righthand5 to 0>><<set $vaginause to 0>>
<<elseif $rng gte 21>><<He>> <<strokes>> your anus.<<neutral 10>>
<<elseif $rng lte 20>><span class="pink"><<He>> plunges a finger into your ass.</span><<neutral 15>><<set $righthand5 to "anus">><<set $speechanus to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand5 is "anus">>
<<if $rng gte 101>><span class="purple"><<He>> slides <<his>> finger out of your ass.</span><<set $lefthand5 to "anusentrance">><<neutral 15>>
<<elseif $rng lte 100>><<He>> rhythmically slides <<his>> finger in and out of your ass,<<neutral 20>><<set $speechanus to 1>>
<<if $playergender is "m">>
teasing your prostate.
<<else>>
teasing your anus.
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand5 is "anus">>
<<if $rng gte 101>><span class="purple"><<He>> slides <<his>> finger out of your ass.</span><<set $righthand5 to "anusentrance">><<neutral 15>>
<<elseif $rng lte 100>><<He>> rhythmically slides <<his>> finger in and out of your ass,<<neutral 20>><<set $speechanus to 1>>
<<if $playergender is "m">>
teasing your prostate.
<<else>>
teasing your anus.
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand5 is "mouth">>
<<if $enemyanger lte 20 and $enemytrust gte 20>><span class="teal">Made confident by your accommodating behaviour, <<he>> releases <<his>> hand from your mouth.</span><<set $lefthand5 to 0>><<set $mouthuse to 0>>
<<else>><<He>> continues to clasp your mouth shut.<<violence 1>><<bruise face>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand5 is "mouth">>
<<if $enemyanger lte 20 and $enemytrust gte 20>><span class="teal">Made confident by your accommodating behaviour, <<he>> releases <<his>> hand from your mouth.</span><<set $righthand5 to 0>><<set $mouthuse to 0>>
<<else>><<He>> continues to clasp your mouth shut.<<violence 1>><<bruise face>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand5 is "throat">>
<<if $enemyanger gte 100>><<set $strangle += 1>>
<<if $strangle is 0>><<He>> strangles your throat.<<violence 5>><<bruise neck>><<bruise neck>><<set $speechthroat to 1>>
<<elseif $strangle lte 2>><span class="purple"><<He>> strangles your throat. You can't breathe!</span><<set $speechthroat to 1>>
<<violence 10>><<bruise neck>><<bruise neck>>
<<elseif $strangle lte 4>><span class="pink"><<He>> strangles your throat. You feel light-headed.</span><<set $speechthroat to 1>>
<<violence 20>><<bruise neck>><<bruise neck>>
<<elseif $strangle lte 6>><span class="pink"><<He>> strangles your throat. You see stars.</span><<set $speechthroat to 1>>
<<violence 40>><<bruise neck>><<bruise neck>>
<<elseif $strangle gte 8>><span class="red"><<He>> strangles your throat. You are suffocating.</span><<set $speechthroat to 1>>
<<violence 100>><<bruise neck>><<bruise neck>>
<</if>>
<<elseif $rng gte 81>><span class="teal"><<He>> releases <<his>> hand from your throat.</span> You gasp for air.
<<set $lefthand5 to 0>>
<<else>><<He>> holds you down by your throat.<<violence 1>>
<</if>><<bruise neck>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand5 is "throat">>
<<if $enemyanger gte 100>><<set $strangle += 1>>
<<if $strangle is 0>><<He>> strangles your throat.<<violence 5>><<bruise neck>><<bruise neck>><<set $speechthroat to 1>>
<<elseif $strangle lte 2>><<He>> strangles your throat. <span class="purple">You can't breathe!</span><<set $speechthroat to 1>>
<<violence 10>><<bruise neck>><<bruise neck>>
<<elseif $strangle lte 4>><<He>> strangles your throat. <span class="pink">You feel light-headed.</span><<set $speechthroat to 1>>
<<violence 20>><<bruise neck>><<bruise neck>>
<<elseif $strangle lte 6>><<He>> strangles your throat. <span class="pink">You see stars.</span> <<set $speechthroat to 1>>
<<violence 40>><<bruise neck>><<bruise neck>>
<<elseif $strangle gte 7>><<He>> strangles your throat. <span class="red">You are suffocating.</span><<set $speechthroat to 1>>
<<violence 100>><<bruise neck>><<bruise neck>>
<</if>>
<<elseif $rng gte 81>><span class="teal"><<He>> releases <<his>> hand from your throat.</span> You gasp for air.
<<set $righthand5 to 0>>
<<else>><<He>> holds you down by your throat.<<violence 1>>
<</if>><<bruise neck>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand5 is "underclothes" and $undertype is "chastity">>
<span class="blue"><<He>> tries to loosen your $underclothes.</span> <<His>> rough handling leaves you feeling more frustrated and aroused. <<He>> gives up after a few moments of impotent tugging, looking disappointed.<<neutral 1>><<set $enemyanger += 5>><<set $arousal += 5>><<set $lefthand5 to 0>><<set $speechchastity to 1>><<set $underintegrity -= 10>>
<</if>>
<<if $righthand5 is "underclothes" and $undertype is "chastity">>
<span class="blue"><<He>> tries to loosen your $underclothes.</span> <<His>> rough handling leaves you feeling more frustrated and aroused.<<He>> gives up after a few moments of impotent tugging, looking disappointed.<<neutral 1>><<set $enemyanger += 5>><<set $arousal += 5>><<set $righthand5 to 0>><<set $speechchastity to 1>><<set $underintegrity -= 10>>
<</if>>
<<if $lefthand5 is "underclothes">>
<<if $underclothes is "naked">><span class="purple"><<He>> casts aside the fabric.</span><<set $lefthand5 to 0>>
<<elseif $understruggle is 1>>You manage to keep <<him>> from pulling down your $underclothes.<<set $understruggle to 0>><<set $speechstripstruggle to 1>>
<<elseif $rng gte 101>><span class="blue"><<He>> releases <<his>> hand from your $underclothes.</span><<set $lefthand5 to 0>>
<<elseif $rng lte 100>>
<<if $skirt is 1>>
<<if $understate is "waist">><<He>> pulls your $underclothes down your thighs, <span class="lewd">revealing your <<genitalsstop>></span><<set $understate to "thighs">><<neutral 5>><<set $undervaginaexposed to 1>><<set $underanusexposed to 1>><<set $underexposed to 1>><<set $speechgenitals to 1>>
<<elseif $understate is "thighs">><<He>> pulls your $underclothes down to your knees.<<set $understate to "knees">><<neutral 1>>
<<elseif $understate is "knees">><<He>> pulls your $underclothes down to your ankles.<<set $understate to "ankles">><<neutral 1>>
<<elseif $understate is "ankles">><span class="purple"><<He> pulls your $underclothes off your legs.</span><<understrip>><<undernaked>><<neutral 3>><<set $lefthand5 to 0>><<clothesstripstat>>
<</if>>
<<elseif $lowerstate isnot "waist">>
<<if $understate is "waist">><<He>> pulls your $underclothes down your thighs, <span class="lewd">revealing your <<genitalsstop>></span><<set $understate to "thighs">><<neutral 5>><<set $undervaginaexposed to 1>><<set $underanusexposed to 1>><<set $underexposed to 1>><<set $speechgenitals to 1>>
<<elseif $understate is "thighs">><<He>> pulls your $underclothes down to your knees.<<set $understate to "knees">><<neutral 1>>
<<elseif $understate is "knees">><<He>> pulls your $underclothes down to your ankles.<<set $understate to "ankles">><<neutral 5>>
<<elseif $understate is "ankles">><span class="purple"><<He>> pulls your $underclothes off your legs.</span><<understrip>><<undernaked>><<neutral 3>><<set $lefthand5 to 0>><<clothesstripstat>>
<</if>>
<<else>><<He>> tugs on your $underclothes.<<neutral 1>><<set $underintegrity -= 10>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand5 is "underclothes">>
<<if $underclothes is "naked">><span class="purple"><<He>> casts aside the fabric.</span><<set $righthand5 to 0>>
<<elseif $understruggle is 1>>You manage to keep <<him>> from pulling down your $underclothes.<<set $understruggle to 0>><<set $speechstripstruggle to 1>>
<<elseif $rng gte 101>><span class="purple"><<He>> releases <<his>> hand from your $underclothes.</span><<set $righthand5 to 0>><<set $skirtuse to 0>>
<<elseif $rng lte 100>>
<<if $skirt is 1>>
<<if $understate is "waist">><<He>> pulls your $underclothes down your thighs, <span class="lewd">revealing your <<genitalsstop>></span><<set $understate to "thighs">><<neutral 5>><<set $undervaginaexposed to 1>><<set $underanusexposed to 1>><<set $underexposed to 1>><<set $speechgenitals to 1>>
<<elseif $understate is "thighs">><<He>> pulls your $underclothes down to your knees.<<set $understate to "knees">><<neutral 1>>
<<elseif $understate is "knees">><<He>> pulls your $underclothes down to your ankles.<<set $understate to "ankles">><<neutral 1>>
<<elseif $understate is "ankles">><span class="purple"><<He>> pulls your $underclothes off your legs.</span><<understrip>><<undernaked>><<neutral 3>><<set $righthand5 to 0>><<clothesstripstat>>
<</if>>
<<elseif $lowerstate isnot "waist">>
<<if $understate is "waist">><<He>> pulls your $underclothes down your thighs, <span class="lewd">revealing your <<genitalsstop>></span><<set $understate to "thighs">><<neutral 5>><<set $undervaginaexposed to 1>><<set $underanusexposed to 1>><<set $underexposed to 1>><<set $speechgenitals to 1>>
<<elseif $understate is "thighs">><<He>> pulls your $underclothes down to your knees.<<set $understate to "knees">><<neutral 1>>
<<elseif $understate is "knees">><<He>> pulls your $underclothes down to your ankles.<<set $understate to "ankles">><<neutral 5>>
<<elseif $understate is "ankles">><span class="purple"><<He>> pulls your $underclothes off your legs.</span><<understrip>><<undernaked>><<neutral 3>><<set $righthand5 to 0>><<clothesstripstat>>
<</if>>
<<else>><<He>> tugs on your $underclothes.<<neutral 1>><<set $underintegrity -= 10>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand5 is "hair">>
<<if $rng gte 101>><span class="lblue"><<He>> releases <<his>> hand from your hair.</span><<set $lefthand5 to 0>>
<<elseif $enemyanger gte 61>>With your hair in <<his>> grip, <<he>> yanks back your head.<<violence 4>><<set $speechhair to 1>>
<<elseif $enemyanger gte 21>>
<<He>> strokes your hair while holding it bunched in <<his>> grip.<<set $speechhair to 1>><<neutral 1>>
<<else>><span class="lblue"><<He>> releases <<his>> hand from your hair.</span><<set $lefthand5 to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand5 is "hair">>
<<if $rng gte 101>><span class="lblue"><<He>> releases <<his>> hand from your hair.</span><<set $righthand5 to 0>>
<<elseif $enemyanger gte 61>>With your hair in <<his>> grip, <<he>> yanks back your head.<<violence 4>><<set $speechhair to 1>>
<<elseif $enemyanger gte 21>>
<<He>> strokes your hair while holding it bunched in <<his>> grip.<<set $speechhair to 1>><<neutral 1>>
<<else>><span class="lblue"><<He>> releases <<his>> hand from your hair.</span><<set $righthand5 to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand5 is "lowerclothes">>
<<if $lowerclothes is "naked">><span class="purple"><<He>> casts aside the fabric.</span><<set $lefthand5 to 0>>
<<elseif $lowerstruggle is 1>><<set $lowerstruggle to 0>>You manage to keep <<him>> from stripping you of your $lowerclothes.<<set $speechstripstruggle to 1>>
<<elseif $rng gte 101>><<He>> releases <<his>> hand from your
$lowerclothes.<<set $lefthand5 to 0>>
<<elseif $rng lte 100>>
<<if $skirt is 1>>
<<if $skirtdown is 1>><<He>> lifts up your skirt,
exposing your
<<if $understate is "waist">>$underclothes.<<neutral 2>>
<<else>><span class="lewd"><<genitalsstop>></span><<neutral 5>><<set $speechgenitals to 1>>
<</if>><<set $skirtdown to 0>><<set $lowervaginaexposed to 1>><<set $loweranusexposed to 1>><<set $lowerexposed to 2>>
<<elseif $skirtdown is 0>>
<<if $lowerset is $upperset>>
<<if $upperstate is "waist">>
<<if $position is "wall">>
<<He>> tugs at your $upperclothes, tearing <<upperit>> before <span class="blue">letting go.</span><<set $lefthand5 to 0>><<neutral 1>><<set $lowerintegrity -= 10>>
<<else>>
<<He>> lifts your $upperclothes above your midriff.<<set $lowerstate to "midriff">><<set $upperstate to "midriff">><<neutral 1>>
<<if $upperstatetop is "waist">>
<<set $upperstatetop to "midriff">>
<</if>>
<</if>>
<<elseif $upperstate is "midriff">><<He>> lifts up your $upperclothes, <span class="lewd">exposing your <<breastsstop>></span><<set $lowerstate to "chest">><<set $upperstate to "chest">><<neutral 2>><<set $upperexposed to 2>><<set $speechbreasts to 1>>
<<if $upperstatetop is "midriff">>
<<set $upperstatetop to "chest">>
<</if>>
<<elseif $upperstate is "chest">><span class="purple"><<He>> pulls your $upperclothes off completely.</span><<lowerstrip>><<upperstrip>><<set $lowerstate to 0>><<set $upperstate to 0>><<uppernaked>><<lowernaked>><<set $lefthand5 to 0>><<neutral 3>><<clothesstripstat>>
<<if $upperstatetop is "chest">>
<<set $upperstatetop to 0>>
<</if>>
<</if>>
<<elseif $lowerset isnot $upperset>>
<<if $lowerstate is "waist">><<He>> pulls your $lowerclothes down to your thighs.
<<neutral 1>><<set $lowerstate to "thighs">>
<<elseif $lowerstate is "thighs">><<He>> pulls your $lowerclothes down to your knees.<<set $lowerstate to "knees">><<neutral 1>>
<<elseif $lowerstate is "knees">><<He>> pulls your $lowerclothes down to your ankles.<<set $lowerstate to "ankles">><<neutral 1>>
<<elseif $lowerstate is "ankles">><span class="purple"><<He>> completely pulls your $lowerclothes off your legs.</span><<lowerstrip>><<lowernaked>><<set $lefthand5 to 0>><<neutral 3>><<clothesstripstat>>
<</if>>
<</if>>
<</if>>
<<elseif $upperset is $lowerset>>
<<if $open is 1>>
<<if $upperstatetop is "chest">><<He>> tugs your $lowerclothes, pulling down your $upperclothes and <span class="lewd">revealing your <<breastsstop>></span><<set $upperstatetop to "midriff">><<neutral 3>><<set $upperexposed to 2>><<set $speechbreasts to 1>>
<<if $upperstate is "chest">>
<<set $upperstate to "midriff">>
<</if>>
<<if $lowerstate is "chest">>
<<set $lowerstate to "midriff">>
<</if>>
<<elseif $upperstatetop is "midriff">><<He>> tugs your $lowerclothes, pulling down your $upperclothes passed your midriff.<<set $upperstatetop to "waist">><<neutral 1>>
<<if $upperstate is "midriff">>
<<set $upperstate to "waist">>
<</if>>
<<if $lowerstate is "midriff">>
<<set $lowerstate to "waist">>
<</if>>
<<elseif $upperstatetop is "waist">><<He>> pulls your $upperclothes down to your thighs, revealing your
<<if $understate is "waist">>$underclothes<<neutral 2>>
<<else>><span class="lewd"><<genitalsstop>></span><<neutral 5>><<set $speechgenitals to 1>>
<</if>>
<<set $lowervaginaexposed to 1>><<set $loweranusexposed to 1>>
<<set $upperstatetop to "thighs">>
<<set $upperstate to "thighs">>
<<if $lowerstate is "waist">>
<<set $lowerstate to "thighs">>
<</if>>
<<elseif $upperstatetop is "thighs">><<He>> pulls your $upperclothes down to your knees.<<set $upperstatetop to "knees">><<set $upperstate to "knees">><<neutral 1>>
<<if $lowerstate is "thighs">>
<<set $lowerstate to "knees">>
<</if>>
<<elseif $upperstatetop is "knees">><<He>> pulls your $upperclothes down to your ankles.<<set $upperstatetop to "ankles">><<set $upperstate to "ankles">><<neutral 1>>
<<if $lowerstate is "knees">>
<<set $lowerstate to "ankles">>
<</if>>
<<elseif $upperstatetop is "ankles">><span class="purple"><<He>> pulls your $upperclothes off the bottom of your legs.</span><<upperstrip>><<neutral 5>><<set $upperstatetop to 0>><<set $upperstate to 0>><<uppernaked>>
<<if $lowerstate is "ankles">>
<<set $lowerstate to 0>><<lowerstrip>><<lowernaked>>
<</if>>
<</if>>
<<else>>
<<He>> tugs at your $lowerclothes, tearing <<lowerit>> before <span class="blue">letting go.</span><<set $lefthand5 to 0>><<set $lowerintegrity -= 10>><<neutral 1>>
<</if>>
<<elseif $upperset isnot $lowerset>>
<<if $lowerstate is "waist">><<He>> pulls down your $lowerclothes, exposing your
<<if $understate is "waist">>$underclothes.<<neutral 2>><<set $lowervaginaexposed to 1>><<set $loweranusexposed to 1>><<set $lowerexposed to 2>>
<<else>><span class="lewd"><<genitalsstop>></span><<neutral 5>><<set $speechgenitals to 1>>
<</if>>
<<set $lowervaginaexposed to 1>><<set $loweranusexposed to 1>><<set $lowerexposed to 2>>
<<set $lowerstate to "thighs">>
<<elseif $lowerstate is "thighs">><<He>> pulls your $lowerclothes down to your knees.<<set $lowerstate to "knees">><<neutral 1>>
<<elseif $lowerstate is "knees">><<He>> pulls your $lowerclothes down to your ankles.<<set $lowerstate to "ankles">><<neutral 1>>
<<elseif $lowerstate is "ankles">><span class="purple"><<He>> completely pulls your $lowerclothes off your legs.</span><<lowerstrip>><<lowernaked>><<set $lefthand5 to 0>><<neutral 3>><<clothesstripstat>>
<</if>>
<<else>><<He>> tugs at your $lowerclothes, tearing <<lowerit>> before <span class="blue">letting go.</span><<set $lefthand5 to 0>><<neutral 1>><<set $lowerintegrity -= 10>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand5 is "lowerclothes">>
<<if $lowerclothes is "naked">><span class="purple"><<He>> casts aside the fabric.</span><<set $righthand5 to 0>>
<<elseif $lowerstruggle is 1>><<set $lowerstruggle to 0>>You manage to keep <<him>> from stripping you of your $lowerclothes.<<set $speechstripstruggle to 1>>
<<elseif $rng gte 101>><span class="lblue"><<He>> releases <<his>> hand from your
$lowerclothes.</span><<set $righthand5 to 0>>
<<elseif $rng lte 100>>
<<if $skirt is 1>>
<<if $skirtdown is 1>><<He>> lifts up your skirt,
exposing your
<<if $understate is "waist">>$underclothes.<<neutral 2>>
<<else>><span class="lewd"><<genitalsstop>></span><<neutral 5>><<set $speechgenitals to 1>>
<</if>><<set $skirtdown to 0>><<set $lowervaginaexposed to 1>><<set $loweranusexposed to 1>><<set $lowerexposed to 2>>
<<elseif $skirtdown is 0>>
<<if $lowerset is $upperset>>
<<if $upperstate is "waist">>
<<if $position is "wall">>
<<He>> tugs at your $upperclothes, tearing <<upperit>> before <span class="blue">letting go.</span><<set $righthand5 to 0>><<neutral 1>><<set $lowerintegrity -= 10>>
<<else>>
<<He>> lifts your $upperclothes above your midriff.<<set $lowerstate to "midriff">><<set $upperstate to "midriff">><<neutral 1>>
<<if $upperstatetop is "waist">>
<<set $upperstatetop to "midriff">>
<</if>>
<</if>>
<<elseif $upperstate is "midriff">><<He>> lifts up your $upperclothes, <span class="lewd">exposing your <<breastsstop>></span><<set $lowerstate to "chest">><<set $upperstate to "chest">><<neutral 2>><<set $upperexposed to 2>><<set $speechbreasts to 1>>
<<if $upperstatetop is "midriff">>
<<set $upperstatetop to "chest">>
<</if>>
<<elseif $upperstate is "chest">><span class="purple"><<He>> pulls your $upperclothes off completely.</span><<set $lowerstate to 0>><<set $upperstate to 0>><<lowerstrip>><<upperstrip>><<uppernaked>><<lowernaked>><<set $righthand5 to 0>><<neutral 3>><<clothesstripstat>>
<<if $upperstatetop is "chest">>
<<set $upperstatetop to 0>>
<</if>>
<</if>>
<<elseif $lowerset isnot $upperset>>
<<if $lowerstate is "waist">><<He>> pulls your $lowerclothes down to your thighs.
<<neutral 1>><<set $lowerstate to "thighs">>
<<elseif $lowerstate is "thighs">><<He>> pulls your $lowerclothes down to your knees.<<set $lowerstate to "knees">><<neutral 1>>
<<elseif $lowerstate is "knees">><<He>> pulls your $lowerclothes down to your ankles.<<set $lowerstate to "ankles">><<neutral 1>>
<<elseif $lowerstate is "ankles">><span class="purple"><<He>> pulls your $lowerclothes off your legs.</span><<lowerstrip>><<lowernaked>><<set $righthand5 to 0>><<neutral 3>><<clothesstripstat>>
<</if>>
<</if>>
<</if>>
<<elseif $upperset is $lowerset>>
<<if $open is 1>>
<<if $upperstatetop is "chest">><<He>> tugs your $lowerclothes, pulling down your $upperclothes and <span class="lewd">revealing your <<breastsstop>></span><<set $upperstatetop to "midriff">><<neutral 3>><<set $upperexposed to 2>><<set $speechbreasts to 1>>
<<if $upperstate is "chest">>
<<set $upperstate to "midriff">>
<</if>>
<<if $lowerstate is "chest">>
<<set $lowerstate to "midriff">>
<</if>>
<<elseif $upperstatetop is "midriff">><<He>> tugs your $lowerclothes, pulling down your $upperclothes pass your midriff.<<set $upperstatetop to "waist">><<neutral 1>>
<<if $upperstate is "midriff">>
<<set $upperstate to "waist">>
<</if>>
<<if $lowerstate is "midriff">>
<<set $lowerstate to "waist">>
<</if>>
<<elseif $upperstatetop is "waist">><<He>> pulls your $upperclothes down to your thighs, revealing your
<<if $understate is "waist">>$underclothes<<neutral 2>>
<<else>><span class="lewd"><<genitalsstop>></span><<neutral 5>><<set $speechgenitals to 1>>
<</if>>
<<set $lowervaginaexposed to 1>><<set $loweranusexposed to 1>><<set $lowerexposed to 2>>
<<set $upperstatetop to "thighs">><<set $upperstate to "thighs">>
<<if $lowerstate is "waist">>
<<set $lowerstate to "thighs">>
<</if>>
<<elseif $upperstatetop is "thighs">><<He>> pulls your $upperclothes down to your knees.<<set $upperstatetop to "knees">><<set $upperstate to "knees">><<neutral 1>>
<<if $lowerstate is "thighs">>
<<set $lowerstate to "knees">>
<</if>>
<<elseif $upperstatetop is "knees">><<He>> pulls your $upperclothes down to your ankles.<<set $upperstatetop to "ankles">><<set $upperstate to "ankles">><<neutral 1>>
<<if $lowerstate is "knees">>
<<set $lowerstate to "ankles">>
<</if>>
<<elseif $upperstatetop is "ankles">><span class="purple"><<He>> pulls your $upperclothes off the bottom of your legs.</span><<upperstrip>><<neutral 5>><<set $upperstatetop to 0>><<set $upperstate to 0>><<uppernaked>>
<<if $lowerstate is "ankles">>
<<set $lowerstate to 0>><<lowerstrip>><<lowernaked>>
<</if>>
<</if>>
<<else>>
<<He>> tugs at your $lowerclothes, tearing <<lowerit>> before <span class="blue">letting go.</span><<set $righthand5 to 0>><<set $lowerintegrity -= 10>><<neutral 1>>
<</if>>
<<elseif $upperset isnot $lowerset>>
<<if $lowerstate is "waist">><<He>> pulls down your $lowerclothes, exposing your
<<if $understate is "waist">>$underclothes.<<neutral 2>><<set $lowervaginaexposed to 1>><<set $loweranusexposed to 1>>
<<else>><span class="lewd"><<genitalsstop>></span><<neutral 5>><<set $speechgenitals to 1>>
<</if>>
<<set $lowervaginaexposed to 1>><<set $loweranusexposed to 1>><<set $lowerexposed to 2>>
<<set $lowerstate to "thighs">>
<<elseif $lowerstate is "thighs">><<He>> pulls your $lowerclothes down to your knees.<<set $lowerstate to "knees">><<neutral 1>>
<<elseif $lowerstate is "knees">><<He>> pulls your $lowerclothes down to your ankles.<<set $lowerstate to "ankles">><<neutral 1>>
<<elseif $lowerstate is "ankles">><span class="purple"><<He>> pulls your $lowerclothes off your legs.</span><<lowerstrip>><<lowernaked>><<set $righthand5 to 0>><<neutral 3>><<clothesstripstat>>
<</if>>
<<else>><<He>> tugs at your $lowerclothes, tearing <<lowerit>> before <span class="blue">letting go.</span><<set $righthand5 to 0>><<neutral 1>><<set $lowerintegrity -= 10>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand5 is "upperclothes">>
<<if $upperclothes is "naked">><span class="purple"><<He>> casts aside the fabric.</span><<set $lefthand5 to 0>>
<<elseif $upperstruggle is 1>><<set $upperstruggle to 0>>You manage to keep <<him>> from stripping you of your $upperclothes.<<set $speechstripstruggle to 1>>
<<elseif $rng gte 101>><span class="lblue"><<He>> releases <<his>> hand from your $upperclothes.</span><<set $lefthand5 to 0>>
<<elseif $rng lte 100>>
<<if $upperset isnot $lowerset>>
<<if $open is 1>>
<<if $upperstatetop is "chest">><<He>> pulls down your $upperclothes, <span class="lewd">revealing your <<breastsstop>></span><<set $upperstatetop to "midriff">><<neutral 3>><<set $upperexposed to 2>><<set $speechbreasts to 1>>
<<if $upperstate is "chest">>
<<set $upperstate to "midriff">>
<</if>>
<<elseif $upperstatetop is "midriff">><<He>> pulls your $upperclothes down past your midriff.<<set $upperstatetop to "waist">><<neutral 1>>
<<if $upperstate is "midriff">>
<<set $upperstate to "waist">>
<</if>>
<<elseif $upperstatetop is "waist">><<He>> pulls your $upperclothes down to your thighs.
<<set $upperstatetop to "thighs">>
<<set $upperstate to "thighs">>
<<elseif $upperstatetop is "thighs">><<He>> pulls your $upperclothes down to your knees.<<set $upperstatetop to "knees">><<set $upperstate to "knees">><<neutral 1>>
<<elseif $upperstatetop is "knees">><<He>> pulls your $upperclothes down to your ankles.<<set $upperstatetop to "ankles">><<set $upperstate to "ankles">><<neutral 1>>
<<elseif $upperstatetop is "ankles">><span class="purple"><<He>> pulls your $upperclothes off the bottom of your legs.</span><<upperstrip>><<neutral 5>><<set $upperstatetop to 0>><<set $upperstate to 0>><<uppernaked>><<set $lefthand5 to 0>>
<</if>>
<<elseif $open is 0>>
<<if $position is "wall">>
<<He>> tugs at your $upperclothes, tearing <<upperit>> before <span class="blue">letting go.</span><<set $lefthand5 to 0>><<set $upperintegrity -= 10>><<neutral 1>>
<<elseif $position isnot "wall">>
<<if $upperstate is "waist">><<He>> lifts up your $upperclothes, exposing your midriff.<<set $upperstate to "midriff">><<neutral 1>>
<<elseif $upperstate is "midriff">><<He>> lifts up your $upperclothes, <span class="lewd">exposing your <<breastsstop>></span><<set $upperstate to "chest">><<neutral 2>><<set $upperexposed to 2>><<set $speechbreasts to 1>>
<<elseif $upperstate is "chest">><span class="purple"><<He>> removes your $upperclothes completely.</span><<upperstrip>><<uppernaked>><<set $lefthand5 to 0>><<neutral 3>><<clothesstripstat>>
<</if>>
<</if>>
<</if>>
<<elseif $upperset is $lowerset>>
<<if $open is 1>>
<<if $lowerstate is $upperstatetop and $lowerstate is $upperstate and $skirt is 1>>
<<if $position is "wall">>
<<He>> tugs at your $upperclothes, tearing <<upperit>> before <span class="blue">letting go.</span><<set $lefthand5 to 0>><<set $upperintegrity -= 10>><<neutral 1>>
<<elseif $position isnot "wall">>
<<if $upperstate is "waist">><<He>> pulls your bundled $upperclothes up past your midriff.<<set $upperstate to "midriff">><<neutral 1>>
<<set $lowerstate to "midriff">>
<<set $upperstatetop to "midriff">>
<<elseif $upperstate is "midriff">><<He>> pulls your bundled $upperclothes up past your <<breastsstop>><<set $upperstate to "chest">><<neutral 2>><<set $upperexposed to 2>><<set $speechbreasts to 1>>
<<set $lowerstate to "chest">>
<<set $upperstatetop to "chest">>
<<elseif $upperstate is "chest">><span class="purple"><<He>> pulls your $upperclothes off your body.</span><<upperstrip>><<uppernaked>><<set $lefthand5 to 0>><<neutral 3>><<clothesstripstat>>
<</if>>
<</if>>
<<else>>
<<if $upperstatetop is "chest">><<He>> pulls down the top of your $upperclothes, <span class="lewd">revealing your <<breastsstop>></span><<set $upperstatetop to "midriff">><<neutral 2>><<set $upperexposed to 2>><<set $speechbreasts to 1>>
<<if $upperstate is "chest">>
<<set $upperstate to "midriff">>
<</if>>
<<if $lowerstate is "chest">>
<<set $lowerstate to "midriff">>
<</if>>
<<elseif $upperstatetop is "midriff">><<He>> pulls your $upperclothes down past your midriff.<<set $upperstatetop to "waist">><<neutral 1>>
<<if $upperstate is "midriff">>
<<set $upperstate to "waist">>
<</if>>
<<if $lowerstate is "midriff">>
<<set $lowerstate to "waist">>
<</if>>
<<elseif $upperstatetop is "waist">><<He>> pulls your $upperclothes down to your thighs, revealing your
<<if $understate is "waist">>$underclothes<<neutral 2>>
<<else>><span class="lewd"><<genitalsstop>></span><<neutral 5>><<set $speechgenitals to 1>>
<</if>>
<<set $lowervaginaexposed to 1>><<set $loweranusexposed to 1>><<set $lowerexposed to 2>>
<<set $upperstatetop to "thighs">>
<<set $upperstate to "thighs">>
<<if $lowerstate is "waist">>
<<set $lowerstate to "thighs">>
<</if>>
<<elseif $upperstatetop is "thighs">><<He>> pulls your $upperclothes down to your knees.<<set $upperstatetop to "knees">><<set $upperstate to "knees">><<neutral 1>>
<<if $lowerstate is "thighs">>
<<set $lowerstate to "knees">>
<</if>>
<<elseif $upperstatetop is "knees">><<He>> pulls your $upperclothes down to your ankles.<<set $upperstatetop to "ankles">><<set $upperstate to "ankles">><<neutral 1>>
<<if $lowerstate is "knees">>
<<set $lowerstate to "ankles">>
<</if>>
<<elseif $upperstatetop is "ankles">><span class="purple"><<He>> pulls your $upperclothes off the bottom of your legs.</span><<upperstrip>><<neutral 5>><<set $upperstatetop to 0>><<set $upperstate to 0>><<uppernaked>><<set $lefthand5 to 0>>
<<if $lowerstate is "ankles">>
<<set $lowerstate to 0>><<lowerstrip>><<lowernaked>>
<</if>>
<</if>>
<</if>>
<<else>><<He>> tugs at your $upperclothes, tearing <<upperit>> before <span class="blue">letting go.</span><<set $lefthand5 to 0>><<set $upperintegrity -= 10>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random (1, 100)>>
<<if $righthand5 is "upperclothes">>
<<if $upperclothes is "naked">><span class="purple"><<He>> casts aside the fabric.</span><<set $righthand5 to 0>>
<<elseif $upperstruggle is 1>><<set $upperstruggle to 0>>You manage to keep <<him>> from stripping you of your $upperclothes.<<set $speechstripstruggle to 1>>
<<elseif $rng gte 101>><span class="lblue"><<He>> releases <<his>> hand from your $upperclothes.</span><<set $righthand5 to 0>>
<<elseif $rng lte 100>>
<<if $upperset isnot $lowerset>>
<<if $open is 1>>
<<if $upperstatetop is "chest">><<He>> pulls down your $upperclothes, <span class="lewd">revealing your <<breastsstop>></span><<set $upperstatetop to "midriff">><<neutral 3>><<set $upperexposed to 2>><<set $speechbreasts to 1>>
<<if $upperstate is "chest">>
<<set $upperstate to "midriff">>
<</if>>
<<elseif $upperstatetop is "midriff">><<He>> pulls your $upperclothes down past your midriff.<<set $upperstatetop to "waist">><<neutral 1>>
<<if $upperstate is "midriff">>
<<set $upperstate to "waist">>
<</if>>
<<elseif $upperstatetop is "waist">><<He>> pulls your $upperclothes down to your thighs.
<<set $upperstatetop to "thighs">>
<<set $upperstate to "thighs">>
<<elseif $upperstatetop is "thighs">><<He>> pulls your $upperclothes down to your knees.<<set $upperstatetop to "knees">><<set $upperstate to "knees">><<neutral 1>>
<<elseif $upperstatetop is "knees">><<He>> pulls your $upperclothes down to your ankles.<<set $upperstatetop to "ankles">><<set $upperstate to "ankles">><<neutral 1>>
<<elseif $upperstatetop is "ankles">><span class="purple"><<He>> pulls your $upperclothes off the bottom of your legs.</span><<upperstrip>><<neutral 5>><<set $upperstatetop to 0>><<set $upperstate to 0>><<uppernaked>><<set $righthand5 to 0>>
<</if>>
<<elseif $open is 0>>
<<if $position is "wall">>
<<He>> tugs at your $upperclothes, tearing <<upperit>> before <span class="blue">letting go.</span><<set $righthand5 to 0>><<set $upperintegrity -= 10>><<neutral 1>>
<<elseif $position isnot "wall">>
<<if $upperstate is "waist">><<He>> lifts up your $upperclothes, exposing your midriff.<<set $upperstate to "midriff">><<neutral 1>>
<<elseif $upperstate is "midriff">><<He>> lifts up your $upperclothes, <span class="lewd">exposing your <<breastsstop>></span><<set $upperstate to "chest">><<neutral 2>><<set $upperexposed to 2>><<set $speechbreasts to 1>>
<<elseif $upperstate is "chest">><span class="purple"><<He>> removes your $upperclothes completely.</span><<upperstrip>><<uppernaked>><<set $righthand5 to 0>><<neutral 3>><<clothesstripstat>>
<</if>>
<</if>>
<</if>>
<<elseif $upperset is $lowerset>>
<<if $open is 1>>
<<if $lowerstate is $upperstatetop and $lowerstate is $upperstate and $skirt is 1>>
<<if $position is "wall">>
<<He>> tugs at your $upperclothes, tearing <<upperit>> before <span class="blue">letting go.</span><<set $righthand5 to 0>><<set $upperintegrity -= 10>><<neutral 1>>
<<elseif $position isnot "wall">>
<<if $upperstate is "waist">><<He>> pulls your bundled $upperclothes up past your midriff.<<set $upperstate to "midriff">><<neutral 1>>
<<set $lowerstate to "midriff">>
<<set $upperstatetop to "midriff">>
<<elseif $upperstate is "midriff">><<He>> pulls your bundled $upperclothes up past your <<breastsstop>><<set $upperstate to "chest">><<neutral 2>><<set $upperexposed to 2>><<set $speechbreasts to 1>>
<<set $lowerstate to "chest">>
<<set $upperstatetop to "chest">>
<<elseif $upperstate is "chest">><span class="purple"><<He>> pulls your $upperclothes off your body.</span><<upperstrip>><<uppernaked>><<set $righthand5 to 0>><<neutral 3>><<clothesstripstat>>
<</if>>
<</if>>
<<else>>
<<if $upperstatetop is "chest">><<He>> pulls down the top of your $upperclothes, <span class="lewd">revealing your <<breastsstop>></span><<set $upperstatetop to "midriff">><<set $upperexposed to 2>><<neutral 2>><<set $speechbreasts to 1>>
<<if $upperstate is "chest">>
<<set $upperstate to "midriff">>
<</if>>
<<if $lowerstate is "chest">>
<<set $lowerstate to "midriff">>
<</if>>
<<elseif $upperstatetop is "midriff">><<He>> pulls your $upperclothes down past your midriff.<<set $upperstatetop to "waist">><<neutral 1>>
<<if $upperstate is "midriff">>
<<set $upperstate to "waist">>
<</if>>
<<if $lowerstate is "midriff">>
<<set $lowerstate to "waist">>
<</if>>
<<elseif $upperstatetop is "waist">><<He>> pulls your $upperclothes down to your thighs, revealing your
<<if $understate is "waist">>$underclothes<<neutral 2>>
<<else>><span class="lewd"><<genitalsstop>></span><<neutral 5>><<set $speechgenitals to 1>>
<</if>>
<<set $lowervaginaexposed to 1>><<set $loweranusexposed to 1>><<set $lowerexposed to 2>>
<<set $upperstatetop to "thighs">>
<<set $upperstate to "thighs">>
<<if $lowerstate is "waist">>
<<set $lowerstate to "thighs">>
<</if>>
<<elseif $upperstatetop is "thighs">><<He>> pulls your $upperclothes down to your knees.<<set $upperstatetop to "knees">><<set $upperstate to "knees">><<neutral 1>>
<<if $lowerstate is "thighs">>
<<set $lowerstate to "knees">>
<</if>>
<<elseif $upperstatetop is "knees">><<He>> pulls your $upperclothes down to your ankles.<<set $upperstatetop to "ankles">><<set $upperstate to "ankles">><<neutral 1>>
<<if $lowerstate is "knees">>
<<set $lowerstate to "ankles">>
<</if>>
<<elseif $upperstatetop is "ankles">><span class="purple"><<He>> pulls your $upperclothes off the bottom of your legs.</span><<upperstrip>><<neutral 5>><<set $upperstatetop to 0>><<set $upperstate to 0>><<uppernaked>><<set $righthand5 to 0>>
<<if $lowerstate is "ankles">>
<<set $lowerstate to 0>><<lowerstrip>><<lowernaked>>
<</if>>
<</if>>
<</if>>
<<else>><<He>> tugs at your $upperclothes, tearing <<upperit>> before <span class="blue">letting go.</span><<set $righthand5 to 0>><<set $upperintegrity -= 10>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand5 is 0>>
<<if $enemyanger + $rng lte 20>>
<<if $lowerclothes isnot "naked">><span class="purple"><<He>> grasps your $lowerclothes.</span><<set $lefthand5 to "lowerclothes">><<neutral 1>>
<<elseif $vaginaexist is 1>>
<<He>> <<strokes>> your inner thigh and brushes <<his>> fingers against your clit.<<neutral 10>><<set $speechclit to 1>>
<<elseif $penisexist is 1>>
<<He>> <<strokes>> your inner thigh and brushes <<his>> fingers against your <<glansstop>><<neutral 10>><<set $speechglans to 1>>
<</if>>
<<elseif $enemyanger + $rng lte 30>>
<<if $position is "wall">>
<<if $lowerclothes isnot "naked">><span class="purple"><<He>> grasps your $lowerclothes.</span><<set $lefthand5 to "lowerclothes">><<neutral 1>>
<<elseif $vaginaexist is 1>>
<<He>> <<strokes>> your inner thigh and brushes <<his>> fingers against your clit.<<neutral 10>><<set $speechclit to 1>>
<<elseif $penisexist is 1>>
<<He>> <<strokes>> your inner thigh and brushes <<his>> fingers against your <<glansstop>><<neutral 10>><<set $speechglans to 1>>
<</if>>
<<else>>
<<if $upperclothes isnot "naked">><span class="purple"><<He>> grasps your $upperclothes.</span><<set $lefthand5 to "upperclothes">><<neutral 1>>
<<else>><<He>> <<strokes>> your chest, <<his>> fingers lingering around your nipple.<<neutral 4>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 35>>
<<if $skirt is 1>>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $lefthand5 to "underclothes">><<neutral 1>>
<<elseif $underanusexposed is 1>>
<<if $loweranusexposed is 1>>
<<if $anususe is 0 and $analdisable is "f">><span class="purple"><<He>> presses <<his>> left hand against your <<bottomstop>></span><<set $lefthand5 to "anusentrance">><<set $anususe to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<<elseif $lowerclothes isnot "waist">>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $lefthand5 to "underclothes">><<neutral 1>>
<<elseif $underanusexposed is 1>>
<<if $loweranusexposed is 1>>
<<if $anususe is 0 and $analdisable is "f">><span class="purple"><<He>> presses <<his>> left hand against your <<bottomstop>></span><<set $lefthand5 to "anusentrance">><<set $anususe to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 40>>
<<if $skirt is 1>>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $lefthand5 to "underclothes">><<neutral 1>>
<<elseif $undervaginaexposed is 1>>
<<if $lowervaginaexposed is 1>>
<<if $vaginaexist is 1>>
<<if $vaginause is 0>><span class="purple"><<He>> presses <<his>> left hand against your <<pussycomma>> resting a finger on your entrance.</span><<set $lefthand5 to "vaginaentrance">><<set $vaginause to 1>><<neutral 1>>
<</if>>
<<elseif $penisexist is 1>>
<<if $penisuse is 0>><span class="purple"><<He>> presses <<his>> left hand against your <<penisstop>></span><<set $lefthand5 to "penisentrance">><<set $penisuse to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $lowerclothes isnot "waist">>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $lefthand5 to "underclothes">><<neutral 1>>
<<elseif $undervaginaexposed is 1>>
<<if $lowervaginaexposed is 1>>
<<if $vaginaexist is 1>>
<<if $vaginause is 0>>
<span class="purple"><<He>> presses <<his>> left hand against your <<pussycomma>> resting a finger on your entrance.</span><<set $lefthand5 to "vaginaentrance">><<set $vaginause to 1>><<neutral 1>>
<</if>>
<<elseif $penisexist is 1>>
<<if $penisuse is 0>><span class="purple"><<He>> presses <<his>> left hand against your <<penisstop>></span><<set $lefthand5 to "penisentrance">><<set $penisuse to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 45>>
<<if $position is "wall">>
<<He>> leans against the wall.
<<else>>
<<He>> caresses your tummy.<<neutral 1>>
<</if>>
<<elseif $enemyanger + $rng lte 50>>
<<if $position is "wall">>
<<He>> grips your thigh and pulls, but you're stuck firm.<<neutral 1>>
<<else>>
<<He>> <<strokes>> your hair.<<neutral 1>>
<</if>>
<<elseif $enemyanger + $rng lte 60>>
<<if $position is "wall">>
<<He>> pulls your leg, but you're stuck firm.<<neutral 1>>
<<elseif $uppertype isnot "naked" and $upperstate isnot "chest" and $upperstatetop is "chest">>
<<He>> <<strokes>> your <<breasts>> through your $upperclothes.<<neutral 2>>
<<else>>
<<He>> <<strokes>> your exposed <<breastsstop>><<neutral 4>>
<</if>>
<<elseif $enemyanger + $rng lte 80>><<set $speechbottom to 1>>
<<if $lowerstate is "waist" and $skirt is 0>>
<<He>> fondles your <<bottom>> through your $lowerclothes.<<neutral 2>>
<<elseif $understate is "waist">>
<<He>> fondles your <<bottom>> through your $underclothes.<<neutral 2>>
<<else>>
<<He>> gropes and squeezes your exposed <<bottomstop>><<neutral 4>>
<</if>>
<<elseif $enemyanger + $rng lte 100>>
<<if $penisexist is 1>>
<<if $lowerstate is "waist" and $skirt is 0>>
<<He>> fondles and <<strokes>> your <<penis>> through your $lowerclothes.<<neutral 5>>
<<elseif $understate is "waist">>
<<He>> fondles and <<strokes>> your <<penis>> through your $underclothes.<<neutral 5>>
<<elseif $penisuse is 0>>
<<He>> fondles and <<strokes>> your exposed <<penisstop>><<neutral 10>>
<<else>>
<<He>> fondles and <<strokes>> your <<testiclesstop>><<neutral 10>>
<</if>>
<<elseif $vaginaexist is 1>>
<<if $lowerstate is "waist" and $skirt is 0>>
<<He>> fondles and <<strokes>> your labia through your $lowerclothes.<<neutral 5>>
<<elseif $understate is "waist">>
<<He>> fondles and <<strokes>> your labia through your $underclothes.<<neutral 5>>
<<else>>
<<He>> fondles and <<strokes>> your exposed <<pussystop>><<neutral 10>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 110>>
<<if $lowerclothes isnot "naked">><span class="purple"><<He>> grasps your $lowerclothes.</span><<set $lefthand5 to "lowerclothes">><<neutral 1>>
<<elseif $vaginaexist is 1>><<He>> pinches your clitoris.<<neutral 15>><<bruise vagina>><<set $speechclit to 1>>
<<elseif $penisexist is 1>>
<<if $penisuse is 0>>
<<He>> pinches your glans.<<neutral 15>><<bruise penis>><<set $speechglans to 1>>
<<else>>
<<He>> pinches your shaft.<<neutral 10>><<bruise penis>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 120>>
<<if $position is "wall">>
<<He>> smacks your thigh.<<violence 1>><<bruise thigh>><<hitstat>>
<<else>>
<<if $upperclothes isnot "naked">><span class="purple"><<He>> grasps your $upperclothes.</span><<set $lefthand5 to "upperclothes">><<neutral 1>>
<<else>><span class="purple"><<He>> grabs your throat.</span><<violence 2>><<set $lefthand5 to "throat">>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 125>>
<<if $skirt is 1>>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $lefthand5 to "underclothes">><<neutral 1>>
<<elseif $underanusexposed is 1>>
<<if $loweranusexposed is 1>>
<<if $anususe is 0 and $analdisable is "f">><span class="purple"><<He>> presses <<his>> left hand against your <<bottomstop>></span><<set $lefthand5 to "anusentrance">><<set $anususe to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<<elseif $lowerclothes isnot "waist">>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $lefthand5 to "underclothes">><<neutral 1>>
<<elseif $underanusexposed is 1>>
<<if $loweranusexposed is 1>>
<<if $anususe is 0 and $analdisable is "f">><span class="purple"><<He>> presses <<his>> left hand against your <<bottomstop>></span><<set $lefthand5 to "anusentrance">><<set $anususe to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 130>>
<<if $skirt is 1>>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $lefthand5 to "underclothes">><<neutral 1>>
<<elseif $undervaginaexposed is 1>>
<<if $lowervaginaexposed is 1>>
<<if $vaginaexist is 1>>
<<if $vaginause is 0>><span class="purple"><<He>> presses <<his>> left hand against your <<pussycomma>> <<his>> finger resting on your entrance.</span><<set $lefthand5 to "vaginaentrance">><<set $vaginause to 1>><<neutral 1>>
<</if>>
<<elseif $penisexist is 1>>
<<if $penisuse is 0>><span class="purple"><<He>> presses <<his>> left hand against your <<penisstop>></span><<set $lefthand5 to "penisentrance">><<set $penisuse to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $lowerclothes isnot "waist">>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $lefthand5 to "underclothes">><<neutral 1>>
<<elseif $undervaginaexposed is 1>>
<<if $lowervaginaexposed is 1>>
<<if $vaginaexist is 1>>
<<if $vaginause is 0>>
<span class="purple"><<He>> presses <<his>> left hand against your <<pussycomma>> <<his>> finger resting on your entrance.</span><<set $lefthand5 to "vaginaentrance">><<set $vaginause to 1>><<neutral 1>>
<</if>>
<<elseif $penisexist is 1>>
<<if $penisuse is 0>><span class="purple"><<He>> presses <<his>> left hand against your <<penisstop>></span><<set $lefthand5 to "penisentrance">><<set $penisuse to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 140>>
<<if $position is "wall">>
<<He>> smacks your <<bottomstop>><<violence 1>><<bruise bottom>><<hitstat>>
<<else>>
<<He>> seizes your hair with <<his>> left hand.<<set $lefthand5 to "hair">><<violence 2>><<set $speechhair to 1>>
<</if>>
<<elseif $enemyanger + $rng lte 160 and $lefthand5 isnot "arms" and $righthand5 isnot "arms" and $leftarm isnot "bound" and $rightarm isnot "bound">>
<span class="purple"><<He>> pins down your arms.</span><<set $lefthand5 to "arms">><<set $leftarm to "grappled">><<set $rightarm to "grappled">><<disablearms>><<violence 2>><<bruise leftarm>><<bruise rightarm>><<set $speecharms to 1>>
<<if $vaginause is "cover">><<set $vaginause to 0>>
<</if>>
<<if $vaginause is "cover">><<set $vaginause to 0>>
<</if>>
<<if $anususe is "cover">><<set $anususe to 0>>
<</if>>
<<if $anususe is "cover">><<set $anususe to 0>>
<</if>>
<<if $penisuse is "cover">><<set $penisuse to 0>>
<</if>>
<<if $penisuse is "cover">><<set $penisuse to 0>>
<</if>>
<<elseif $enemyanger + $rng lte 160>><<He>> digs <<his>> nails into your <<bottom>> while groping, giving no heed to you comfort.<<violence 10>><<bruise bottom>><<hitstat>><<set $speechspank to 1>>
<<elseif $enemyanger + $rng lte 175>><<He>> slaps your <<bottomstop>><<violence 10>><<bruise bottom>><<hitstat>><<set $speechspank to 1>>
<<elseif $enemyanger + $rng lte 180>><<He>> smacks your thighs.<<violence 10>><<bruise thigh>><<hitstat>><<set $speechbeat to 1>>
<<elseif $enemyanger + $rng lte 185>>
<<if $position is "wall">>
<<He>> punches your thigh.<<bruise thigh>><<hitstat>><<violence 10>><<set $speechbeat to 1>>
<<else>>
<<He>> punches your tummy.<<violence 20>><<bruise tummy>><<hitstat>><<set $speechbeat to 1>>
<</if>>
<<elseif $enemyanger + $rng lte 190>>
<<if $position is "wall">>
<<He>> slaps your <<bottomstop>><<violence 20>><<bruise bottom>><<hitstat>><<set $speechbeat to 1>>
<<else>>
<<He>> slaps your <<breastsstop>><<violence 20>><<bruise chest>><<hitstat>><<set $speechbeat to 1>>
<</if>>
<<elseif $enemyanger + $rng gte 191>>
<<if $position is "wall">>
<<if $penisexist is 1>>
<<He>> scratches your helpless <<bottomstop>><<violence 20>><<bruise bottom>><<hitstat>><<set $speechbeat to 1>>
<<elseif $vaginaexist is 1>>
<<He>> scratches your helpless <<bottomstop>><<violence 20>><<bruise bottom>><<hitstat>><<set $speechbeat to 1>>
<</if>>
<<else>>
<<set $rng to random(1, 100)>>
<<if $rng gte 81>>
<<He>> punches your nose.<<violence 20>><<bruise face>><<hitstat>><<set $speechbeat to 1>>
<<elseif $rng gte 61>>
<<He>> punches the back of your neck.<<violence 20>><<bruise neck>><<hitstat>><<set $speechbeat to 1>>
<<elseif $rng gte 41>>
<<He>> punches your cheek.<<violence 20>><<bruise face>><<hitstat>><<set $speechbeat to 1>>
<<elseif $rng gte 21>>
<<He>> punches your jaw.<<violence 20>><<bruise face>><<hitstat>><<set $speechbeat to 1>>
<<else>>
<<He>> jabs the front of your neck.<<violence 20>><<bruise neck>><<hitstat>><<set $speechbeat to 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand5 is 0>>
<<if $enemyanger + $rng lte 20>>
<<if $lowerclothes isnot "naked">><span class="purple"><<He>> grasps your $lowerclothes.</span><<set $righthand5 to "lowerclothes">><<neutral 1>>
<<elseif $vaginaexist is 1>><<He>> <<strokes>> your pubic mound and teases your clit.<<neutral 10>><<set $speechclit to 1>>
<<elseif $penisexist is 1>>
<<He>> <<strokes>> your <<testicles>> and teases your glans.<<neutral 10>><<set $speechglans to 1>>
<</if>>
<<elseif $enemyanger + $rng lte 30>>
<<if $position is "wall">>
<<if $lowerclothes isnot "naked">><span class="purple"><<He>> grasps your $lowerclothes.</span><<set $righthand5 to "lowerclothes">><<neutral 1>>
<<elseif $vaginaexist is 1>><<He>> runs <<his>> hand up your thigh and <<strokes>> your clit.<<neutral 10>><<set $speechclit to 1>>
<<elseif $penisexist is 1>><<He>> runs <<his>> hand up your thigh and <<strokes>> your <<glansstop>><<neutral 10>><<set $speechglans to 1>>
<</if>>
<<else>>
<<if $upperclothes isnot "naked">><span class="purple"><<He>> grasps your $upperclothes.</span><<set $righthand5 to "upperclothes">><<neutral 1>>
<<else>><<He>> <<strokes>> your chest and teases your nipple.<<neutral 4>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 35>>
<<if $skirt is 1>>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $righthand5 to "underclothes">><<neutral 1>>
<<elseif $underanusexposed is 1>>
<<if $loweranusexposed is 1>>
<<if $anususe is 0 and $analdisable is "f">><span class="purple"><<He>> presses <<his>> right hand against your <<bottomstop>></span><<set $righthand5 to "anusentrance">><<set $anususe to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<<elseif $lowerclothes isnot "waist">>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $righthand5 to "underclothes">><<neutral 1>>
<<elseif $underanusexposed is 1>>
<<if $loweranusexposed is 1>>
<<if $anususe is 0 and $analdisable is "f">><span class="purple"><<He>> presses <<his>> right hand against your <<bottomstop>></span><<set $righthand5 to "anusentrance">><<set $anususe to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 40>>
<<if $skirt is 1>>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $righthand5 to "underclothes">><<neutral 1>>
<<elseif $undervaginaexposed is 1>>
<<if $lowervaginaexposed is 1>>
<<if $vaginaexist is 1>>
<<if $vaginause is 0>>
<span class="purple"><<He>> presses <<his>> right hand against your <<pussycomma>> resting a finger on your entrance.</span><<set $righthand5 to "vaginaentrance">><<set $vaginause to 1>><<neutral 1>>
<</if>>
<<elseif $penisexist is 1>>
<<if $penisuse is 0>><span class="purple"><<He>> presses <<his>> right hand against your <<penisstop>></span><<set $righthand5 to "penisentrance">><<set $penisuse to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $lowerclothes isnot "waist">>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $righthand5 to "underclothes">><<neutral 1>>
<<elseif $undervaginaexposed is 1>>
<<if $lowervaginaexposed is 1>>
<<if $vaginaexist is 1>>
<<if $vaginause is 0>>
<span class="purple"><<He>> presses <<his>> right hand against your <<pussycomma>> resting a finger above your entrance.</span><<set $righthand5 to "vaginaentrance">><<set $vaginause to 1>><<neutral 1>>
<</if>>
<<elseif $penisexist is 1>>
<<if $penisuse is 0>>
<span class="purple"><<He>> presses <<his>> right hand against your <<penisstop>></span><<set $righthand5 to "penisentrance">><<set $penisuse to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 45>>
<<if $position is "wall">>
<<He>> rests <<his>> right hand against the wall.
<<else>>
<<He>> <<strokes>> your tummy with <<his>> right hand.<<neutral 1>>
<</if>>
<<elseif $enemyanger + $rng lte 50>>
<<if $position is "wall">>
<<He>> pushes your <<bottomcomma>> making sure you're stuck firm.<<neutral 1>>
<<else>>
<<He>> <<strokes>> your cheek.<<neutral 1>>
<</if>>
<<elseif $enemyanger + $rng lte 60>>
<<if $position is "wall">>
<<He>> tugs on your leg, but you're stuck firm.<<neutral 1>>
<<elseif $uppertype isnot "naked" and $upperstate isnot "chest" and $upperstatetop is "chest">>
<<He>> gropes your <<breasts>> through your $upperclothes.<<neutral 2>>
<<else>>
<<He>> gropes your exposed <<breastsstop>><<neutral 4>>
<</if>>
<<elseif $enemyanger + $rng lte 80>><<set $speechbottom to 1>>
<<if $lowerstate is "waist" and $skirt is 0>>
<<He>> gropes your <<bottom>> through your $lowerclothes.<<neutral 2>>
<<elseif $understate is "waist">>
<<He>> gropes your <<bottom>> through your $underclothes.<<neutral 2>>
<<else>>
<<He>> fondles and <<strokes>> your exposed <<bottomstop>><<neutral 4>>
<</if>>
<<elseif $enemyanger + $rng lte 100>>
<<if $penisexist is 1>>
<<if $lowerstate is "waist" and $skirt is 0>>
<<He>> gropes and <<strokes>> your <<penis>> through your $lowerclothes.<<neutral 5>>
<<elseif $understate is "waist">>
<<He>> gropes and <<strokes>> your <<penis>> through your $underclothes.<<neutral 5>>
<<elseif $penisuse is 0>>
<<He>> gropes and <<strokes>> your exposed <<penisstop>><<neutral 10>>
<<else>>
<<He>> cups and <<strokes>> your <<testiclesstop>><<neutral 10>>
<</if>>
<<elseif $vaginaexist is 1>>
<<if $lowerstate is "waist" and $skirt is 0>>
<<He>> gropes and <<strokes>> your labia through your $lowerclothes.<<neutral 5>>
<<elseif $understate is "waist">>
<<He>> gropes and <<strokes>> your labia through your $underclothes.<<neutral 5>>
<<else>>
<<He>> gropes and <<strokes>> your exposed <<pussystop>><<neutral 10>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 110>>
<<if $lowerclothes isnot "naked">><span class="purple"><<He>> grasps your $lowerclothes.</span><<set $righthand5 to "lowerclothes">><<neutral 1>>
<<elseif $vaginaexist is 1>>He pinches your clitoris.<<neutral 15>><<bruise vagina>><<set $speechclit to 1>>
<<elseif $penisexist is 1>>
<<if $penisuse is 0>>
<<He>> pinches your glans.<<neutral 15>><<bruise penis>><<set $speechglans to 1>>
<<else>>
<<He>> pinches your shaft.<<neutral 10>><<bruise penis>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 120>>
<<if $position is "wall">>
<<He>> squeezes your thigh.<<violence 1>><<hitstat>><<bruise thigh>>
<<else>>
<<if $upperclothes isnot "naked">><span class="purple"><<He>> grasps your $upperclothes.</span><<set $righthand5 to "upperclothes">><<neutral 1>>
<<else>><span class="purple"><<He>> grabs your throat.</span><<violence 2>><<set $righthand5 to "throat">>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 125>>
<<if $skirt is 1>>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $righthand5 to "underclothes">><<neutral 1>>
<<elseif $underanusexposed is 1>>
<<if $loweranusexposed is 1>>
<<if $anususe is 0 and $analdisable is "f">><span class="purple"><<He>> presses <<his>> right hand against your <<bottomstop>></span><<set $righthand5 to "anusentrance">><<set $anususe to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<<elseif $lowerclothes isnot "waist">>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $righthand5 to "underclothes">><<neutral 1>>
<<elseif $underanusexposed is 1>>
<<if $loweranusexposed is 1>>
<<if $anususe is 0 and $analdisable is "f">><span class="purple"><<He>> presses <<his>> right hand against your <<bottomstop>></span><<set $righthand5 to "anusentrance">><<set $anususe to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 130>>
<<if $skirt is 1>>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $righthand5 to "underclothes">><<neutral 1>>
<<elseif $undervaginaexposed is 1>>
<<if $lowervaginaexposed is 1>>
<<if $vaginaexist is 1>>
<<if $vaginause is 0>>
<span class="purple"><<He>> presses <<his>> right hand against your <<pussycomma>> <<his>> finger resting on your entrance.</span><<set $righthand5 to "vaginaentrance">><<set $vaginause to 1>><<neutral 1>>
<</if>>
<<elseif $penisexist is 1>>
<<if $penisuse is 0>><span class="purple"><<He>> presses <<his>> right hand against your <<penisstop>></span><<set $righthand5 to "penisentrance">><<set $penisuse to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $lowerclothes isnot "waist">>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $righthand5 to "underclothes">><<neutral 1>>
<<elseif $undervaginaexposed is 1>>
<<if $lowervaginaexposed is 1>>
<<if $vaginaexist is 1>>
<<if $vaginause is 0>>
<span class="purple"><<He>> presses <<his>> right hand against your <<pussycomma>> <<his>> finger resting on your entrance.</span><<set $righthand5 to "vaginaentrance">><<set $vaginause to 1>><<neutral 1>>
<</if>>
<<elseif $penisexist is 1>>
<<if $penisuse is 0>>
<span class="purple"><<He>> presses <<his>> right hand against your <<penisstop>></span><<set $righthand5 to "penisentrance">><<set $penisuse to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 140>>
<<if $position is "wall">>
<<He>> slaps your <<bottomstop>><<violence 1>><<bruise bottom>><<hitstat>>
<<else>>
<span class="purple"><<He>> seizes your hair with <<his>> right hand.</span><<set $righthand5 to "hair">><<violence 2>><<set $speechhair to 1>>
<</if>>
<<elseif $enemyanger + $rng lte 160 and $lefthand5 isnot "arms" and $righthand5 isnot "arms" and $leftarm isnot "bound" and $rightarm isnot "bound">><span class="purple"><<He>> pins down your arms.</span><<set $righthand5 to "arms">><<set $leftarm to "grappled">><<set $rightarm to "grappled">><<disablearms>><<violence 2>><<bruise leftarm>><<bruise rightarm>><<set $speecharms to 1>>
<<if $vaginause is "cover">><<set $vaginause to 0>>
<</if>>
<<if $vaginause is "cover">><<set $vaginause to 0>>
<</if>>
<<if $anususe is "cover">><<set $anususe to 0>>
<</if>>
<<if $anususe is "cover">><<set $anususe to 0>>
<</if>>
<<if $penisuse is "cover">><<set $penisuse to 0>>
<</if>>
<<if $penisuse is "cover">><<set $penisuse to 0>>
<</if>>
<<elseif $enemyanger + $rng lte 160>><<He>> grips your <<bottomcomma>> digging <<his>> nails into your skin.<<violence 10>><<bruise bottom>><<hitstat>><<set $speechspank to 1>>
<<elseif $enemyanger + $rng lte 175>><<He>> spanks your <<bottomstop>><<violence 10>><<bruise bottom>><<hitstat>><<set $speechspank to 1>>
<<elseif $enemyanger + $rng lte 180>><<He>> slaps your thighs.<<violence 10>><<bruise thigh>><<hitstat>><<set $speechbeat to 1>>
<<elseif $enemyanger + $rng lte 185>>
<<if $position is "wall">>
<<He>> beats your thigh.<<bruise thigh>><<hitstat>><<violence 10>><<set $speechbeat to 1>>
<<else>>
<<He>> beats your tummy.<<violence 20>><<bruise tummy>><<hitstat>><<set $speechbeat to 1>>
<</if>>
<<elseif $enemyanger + $rng lte 190>>
<<if $position is "wall">>
<<He>> spanks your <<bottomstop>><<violence 20>><<bruise bottom>><<hitstat>><<set $speechbeat to 1>>
<<else>>
<<He>> spanks your <<breastsstop>><<violence 20>><<bruise chest>><<hitstat>><<set $speechbeat to 1>>
<</if>>
<<elseif $enemyanger + $rng gte 191>>
<<if $position is "wall">>
<<if $penisexist is 1>>
<<He>> jabs your gooch.<<violence 20>><<bruise penis>><<hitstat>><<set $speechbeat to 1>>
<<elseif $vaginaexist is 1>>
<<He>> jabs your gooch.<<violence 20>><<bruise vagina>><<hitstat>><<set $speechbeat to 1>>
<</if>>
<<else>>
<<set $rng to random(1, 100)>>
<<if $rng gte 81>>
<<He>> scratches the side of your face.<<violence 20>><<bruise face>><<hitstat>><<set $speechbeat to 1>>
<<elseif $rng gte 61>>
<<He>> scratches the back of your neck.<<violence 20>><<bruise neck>><<hitstat>><<set $speechbeat to 1>>
<<elseif $rng gte 41>>
<<He>> scratches your cheek.<<violence 20>><<bruise face>><<hitstat>><<set $speechbeat to 1>>
<<elseif $rng gte 21>>
<<He>> scratches your jaw.<<violence 20>><<bruise face>><<hitstat>><<set $speechbeat to 1>>
<<else>>
<<He>> scratches the front of your neck.<<violence 20>><<bruise neck>><<hitstat>><<set $speechbeat to 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis5 is "clothed">>
<<if $pronoun is "m">>
<<if $enemyarousal gte 40>><<He>> unzips <<his>> fly, <span class="blue">revealing <<his>> erect penis.</span><<set $penis5 to 0>>
<</if>>
<<else>>
<<if $enemyarousal gte 40>><<He>> pulls up <<his>> skirt, <span class="blue">revealing <<his>> erect penis.</span><<set $penis5 to 0>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis5 is "thighs">>
<<if $vaginaexist is 1>>
<<if $rng gte 101>><span class="blue"><<He>> angles <<his>> penis towards your <<pussystop>></span><<set $thighuse to 0>><<set $penis5 to "vaginaentrance">><<set $vaginause to "penis">><<set $vaginastate to "entrance">><<set $speechvaginaentrance to 1>>
<<else>>
<<He>> rubs <<his>> penis between your thighs and <<pussystop>><<sex 5>>
<</if>>
<<else>>
<<if $rng gte 101>><<He>> moves <<his>> penis out from between your thighs.<<set $thighuse to 0>><<set $penis5 to 0>>
<<else>>
<<He>> rubs <<his>> penis between your thighs.<<sex 5>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis5 is "cheeks">>
<<if $rng gte 101>><span class="blue"><<He>> angles <<his>> penis towards your anus.</span><<set $penis5 to "anusentrance">><<set $anusstate to "entrance">><<set $bottomuse to 0>><<set $cheekactiondefault to "cheeks">><<set $speechanusentrance to 1>>
<<else>>
<<He>> rubs <<his>> penis between your cheeks.<<submission 3>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis5 is "leftarm">>
<<if $rng gte 1>><<He>> rubs <<his>> penis between your fingers.<<submission 1>>
<<elseif $rng gte 101>><<He>> moves <<his>> penis away from your hand.<<set $penis5 to 0>><<set $leftarm to 0>><<set $leftactiondefault to "leftgrab">>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis5 is "rightarm">>
<<if $rng gte 1>><<He>> rubs <<his>> penis between your fingers.<<submission 1>>
<<elseif $rng gte 101>><<He>> moves <<his>> penis away from your hand.<<set $penis5 to 0>><<set $rightarm to 0>><<set $rightactiondefault to "rightgrab">>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis5 is "botharm">>
<<if $rng gte 1>><<He>> rubs <<his>> penis between your hands.<<submission 2>>
<<elseif $rng gte 101>><<He>> moves <<his>> penis away from your hands.<<set $penis5 to 0>><<set $leftarm to 0>><<set $rightarm to 0>><<set $rightactiondefault to "rightgrab">><<set $leftactiondefault to "leftgrab">>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis5 is "feet">>
<<if $rng gte 1>>
<<He>> rubs <<his>> penis between your feet.<<submission 1>>
<<elseif $rng gte 101>>
<<He>> moves <<his>> penis away from your feet.<<set $penis5 to 0>><<set $feetuse to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis5 is "vagina">>
<<if $rng gte 101>><span class="purple"><<He>> slides <<his>> penis out of your <<pussystop>></span><<sex 30>><<set $penis5 to "vaginaimminent">><<bruise vagina>><<violence 1>><<set $vaginastate to "imminent">>
<<elseif $rng gte 1>>
<<if $enemyanger gte 100>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
<<He>> violates your <<pussy>> with increasing intensity.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues to fuck your <<pussy>> with no regard for your comfort.
<<else>>
<<He>> fucks your <<pussy>> with rough thrusts, giving no regard to your comfort.
<</if>>
<<elseif $enemyanger gte 20>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
You feel <<his>> penis throb as <<he>> pounds away at your <<pussystop>>
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues to violate your <<pussystop>>
<<else>>
<<He>> fucks your <<pussy>> with deep and deliberate thrusts.
<</if>>
<<else>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
<<He>> fucks your <<pussy>> with increasing power.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues thrusting into your <<pussystop>>
<<else>>
<<He>> fucks your <<pussy>> with steady thrusts.
<</if>>
<</if>>
<<sex 30>><<bruise vagina>><<violence 1>><<set $speechvaginapenetrated to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis5 is "vaginaimminent">>
<<if $rng gte 101>><span class="blue"><<He>> stops pressing <<his>> penis against your pussy.</span><<set $penis5 to "vaginaentrance">><<set $vaginastate to "entrance">>
<<elseif $rng gte 1>>
<<if $novaginal is 0>><<set $vaginaactiondefault to "take">>
<<if $vaginalvirginity is 0>>
<<if $enemyanger gte 80>>
<span class="pink"><<He>> thrusts <<his>> penis deep into your <<pussystop>></span>
<<elseif $enemyanger gte 20>>
<span class="pink"><<He>> thrusts <<his>> penis deep into your <<pussystop>></span>
<<else>>
<span class="pink"><<He>> glides <<his>> penis deep into your <<pussystop>></span>
<</if>>
<<sex 30>><<set $penis5 to "vagina">><<vaginalstat>><<bruise vagina>><<violence 1>><<raped>><<vaginaraped>><<set $vaginastate to "penetrated">><<set $speechvaginapenetrated to 1>>
<<elseif $vaginalvirginity is 1>><span class="pink"><<His>> penis thrusts deep into your virgin pussy,</span><span class="red"> breaking your hymen and forever robbing you of your purity.</span><<sex 100>><<set $penis5 to "vagina">><<set $vaginalvirginity to 0>><<bruise vagina>><<vaginalstat>><<violence 100>><<raped>><<vaginaraped>><<set $vaginastate to "penetrated">><<set $speechvaginavirgin to 1>>
<</if>>
<<else>>
Respecting your wishes, <<he>> presses <<his>> penis against your <<pussy>> but does not penetrate.<<sex 15>><<set $speechvaginawithhold to 1>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis5 is "vaginaentrance">>
<<if $rng gte 101>><span class="lblue"><<He>> moves <<his>> penis away from your <<pussystop>></span><<set $penis5 to 0>><<set $vaginause to 0>><<set $vaginastate to 0>>
<<elseif $rng gte 1>>
<<if $lowervaginaexposed is 0>><<He>> rubs <<his>> penis against your <<pussy>> through your $lowerclothes.<<sex 5>><<set $lowerintegrity -= 10>><<set $speechvaginaentrance to 1>>
<<elseif $lowervaginaexposed is 1>><<set $rng to random(1, 100)>>
<<if $undervaginaexposed is 0>><<He>> rubs <<his>> penis against your <<pussy>> through your $underclothes.<<sex 5>><<set $underintegrity -= 10>><<set $speechvaginaentrance to 1>>
<<elseif $undervaginaexposed is 1>>
<<if $rng gte 71>>
<<if $novaginal is 1>>
<span class="purple"><<He>> pushes <<his>> penis against your <<pussystop>></span><<sex 20>><<set $penis5 to "vaginaimminent">><<set $vaginastate to "imminent">><<set $speechvaginaimminent to 1>>
<<else>>
<span class="purple"><<He>> pushes <<his>> penis against your <<pussycomma>> preparing to penetrate you fully.</span><<sex 20>><<set $penis5 to "vaginaimminent">><<set $vaginastate to "imminent">><<set $speechvaginaimminent to 1>>
<</if>>
<<elseif $rng gte 1>><<He>> teases your <<pussy>> without penetrating.<<sex 10>><<set $speechvaginaentrance to 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis5 is "anus">>
<<if $rng gte 101>><span class="purple"><<He>> withdraws <<his>> penis from your anus.</span><<sex 30>><<set $penis5 to "anusimminent">><<bruise anus>><<violence 1>><<set $anusstate to "imminent">>
<<elseif $rng gte 1>>
<<if $enemyanger gte 100>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
<<He>> ravages your <<bottom>> with a violent intensity.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
You feel <<his>> penis ever deeper within you as <<he>> fucks your <<bottomstop>>
<<else>>
<<He>> fucks your <<bottom>> with rough thrusts, intent on showing you who's boss.
<</if>>
<<elseif $enemyanger gte 20>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
You feel <<his>> penis throb within you as <<he>> fucks your <<bottomstop>>
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues to violate your <<bottomcomma>> giving no regard to your comfort.
<<else>>
<<He>> fucks your <<bottom>> with deep and dominating thrusts.
<</if>>
<<else>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
<<He>> fucks your <<bottom>> with increasing power.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues fucking your <<bottomstop>>
<<else>>
<<He>> fucks your <<bottom>> with steady thrusts.
<</if>>
<</if>>
<<sex 30>><<bruise anus>><<violence 1>><<set $speechanuspenetrated to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis5 is "anusimminent">>
<<if $rng gte 101>><span class="blue"><<He>> stops pressing <<his>> penis against your anus.</span><<set $penis5 to "anusentrance">><<set $anusstate to "entrance">>
<<elseif $rng gte 1>>
<<if $noanal is 0>><<set $anusactiondefault to "take">>
<<if $analvirginity is 0>><span class="pink"><<He>> thrusts <<his>> penis deep into your <<bottomstop>></span><<sex 30>><<set $penis5 to "anus">><<bruise anus>><<analstat>><<violence 1>><<raped>><<set $anusstate to "penetrated">><<set $speechanuspenetrated to 1>>
<<elseif $analvirginity is 1>><span class="pink"><<He>> thrusts <<his>> penis deep into your virgin anus,</span> <span class="red">violating you in a way you hadn't conceived of.</span><<sex 100>><<set $penis5 to "anus">><<set $analvirginity to 0>><<bruise anus>><<analstat>><<violence 50>><<raped>><<set $anusstate to "penetrated">><<set $speechanusvirgin to 1>>
<</if>>
<<else>>
Respecting your wishes, <<he>> presses <<his>> penis against your anus but does not penetrate.<<sex 15>><<set $speechanuswithhold to 1>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis5 is "anusentrance">>
<<if $rng gte 101>><span class="lblue"><<He>> moves <<his>> penis away from your <<bottomstop>></span><<set $penis5 to 0>><<set $anususe to 0>><<set $anusstate to 0>>
<<elseif $rng gte 1>>
<<if $loweranusexposed is 0>><<He>> rubs <<his>> penis against your <<bottom>> through your $lowerclothes.<<sex 5>><<set $lowerintegrity -= 10>><<set $speechanusentrance to 1>>
<<elseif $loweranusexposed is 1>><<set $rng to random(1, 100)>>
<<if $underanusexposed is 0>><<He>> rubs <<his>> penis against your <<bottom>> through your $underclothes.<<set $speechanusentrance to 1>><<sex 5>><<set $underintegrity -= 10>>
<<elseif $underanusexposed is 1>>
<<if $rng gte 71>>
<<if $noanal is 1>>
<span class="pink"><<He>> presses <<his>> penis against your anus.</span><<sex 20>><<set $penis5 to "anusimminent">><<set $anusstate to "imminent">><<set $speechanusimminent to 1>>
<<else>>
<span class="pink"><<He>> presses <<his>> penis against your anus, preparing to penetrate you fully.</span><<sex 20>><<set $penis5 to "anusimminent">><<set $anusstate to "imminent">><<set $speechanusimminent to 1>>
<</if>>
<<elseif $rng gte 1>><<His>> penis rubs against your <<bottomstop>><<sex 5>><<set $speechanusentrance to 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis5 is "mouth">>
<<if $rng gte 101>><span class="purple"><<He>> withdraws <<his>> penis from your mouth.</span><<sex 30>><<set $penis5 to "mouthimminent">><<bruise face>><<violence 1>><<set $mouthstate to "imminent">>
<<elseif $rng gte 1>><<He>> continues thrusting into your mouth.<<submission 10>><<bruise face>><<violence 1>><<set $speechmouthpenetrated to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis5 is "mouthimminent">>
<<if $pullaway is 1>><<set $pullaway to 0>>Saliva drips from the tip of <<his>> phallus.
<<else>>
<<if $rng gte 101>><span class="blue"><<He>> stops pressing <<his>> penis against your mouth.</span><<set $penis5 to "mouthentrance">><<submission 5>><<set $mouthstate to "entrance">>
<<elseif $rng lte 20>>
<<if $oralvirginity is 0>><span class="pink"><<He>> thrusts <<his>> penis into your mouth.</span><<submission 10>><<set $penis5 to "mouth">><<bruise face>><<oralstat>><<raped>><<set $mouthstate to "penetrated">><<set $speechmouthpenetrated to 1>>
<<elseif $oralvirginity is 1>><span class="pink"><<He>> thrusts <<his>> penis into your mouth.</span><span class="red"> It tastes strange.</span><<submission 30>><<set $penis5 to "mouth">><<set $oralvirginity to 0>><<bruise face>><<oralstat>><<violence 1>><<raped>><<set $mouthstate to "penetrated">><<set $speechmouthvirgin to 1>>
<</if>>
<<elseif $rng gte 21>>
<<if $mouthsubmit is 1>><<He>> allows you to pleasure <<his>> cock with your mouth.<<submission 5>><<set $speechmouthimminent to 1>>
<<elseif $oralvirginity is 0>><span class="pink"><<He>> thrusts <<his>> penis into your mouth.</span><<submission 10>><<set $penis5 to "mouth">><<oralstat>><<bruise face>><<violence 1>><<raped>><<set $mouthstate to "penetrated">><<set $speechmouthpenetrated to 1>>
<<elseif $oralvirginity is 1>><span class="pink"><<He>> thrusts <<his>> penis into your mouth.</span><span class="red"> It tastes strange.</span><<submission 30>><<set $penis5 to "mouth">><<set $oralvirginity to 0>><<oralstat>><<bruise face>><<violence 1>><<raped>><<set $mouthstate to "penetrated">><<set $speechmouthpenetrated to 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis5 is "mouthentrance">>
<<if $pullaway is 1>><<set $pullaway to 0>><<His>> penis hovers only inches from your face.
<<else>>
<<if $rng gte 101>><span class="lblue"><<He>> moves <<his>> penis away from your mouth.</span><<set $penis5 to 0>><<set $mouthuse to 0>><<set $mouthstate to 0>>
<<elseif $rng gte 1>><span class="purple"><<He>> pushes <<his>> penis against your lips.</span><<set $penis5 to "mouthimminent">><<submission 5>><<set $mouthstate to "imminent">><<set $speechmouthimminent to 1>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis5 is "chest">>
<<if $rng gte 101>><<He>> moves <<his>> penis away from your chest.<<set $penis5 to 0>><<set $chestuse to 0>>
<<elseif $rng gte 1>><<submission 3>>
<<if $breastcup is "none">>
<<He>> rubs <<his>> penis against your <<breastsstop>><<set $speechchestrub to 1>>
<<else>>
<<He>> rubs <<his>> penis between your <<breastsstop>><<set $speechbreastrub to 1>>
<</if>>
<</if>>
<</if>>
<<if $penis5 is "footjob">>
<<if $rng gte 101>>
<span class="blue"><<He>> stops pressing <<his>> foot against your <<genitalsstop>></span><<set $penis5 to 0>>
<<if $penisexist is 1>>
<<set $penisuse to 0>>
<<else>>
<<set $vaginause to 0>>
<</if>>
<<else>>
<<if $penisexist is 1>>
<<He>> presses your <<penis>> against your stomach with <<his>> foot and rubs your glans between <<his>> toes.
<<set $speechpenisfoot to 1>><<neutral 5>><<violence 1>>
<<else>>
<<He>> presses and teases your <<pussy>> with <<his>> foot.
<<set $speechvaginafoot to 1>><<neutral 5>><<violence 1>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis5 is "otherfrot">>
<<if $rng gte 101>><span class="blue"><<He>> shifts <<his>> ass and presses <<his>> anus against your <<penisstop>></span><<set $penisuse to "otheranus">><<set $penis5 to "otheranusentrance">><<set $penisstate to "otheranusentrance">><<set $speechotheranusentrance to 1>>
<<else>>
<<He>> rubs <<his>> ass against your <<penisstop>><<sex 5>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis5 is "otheranus">>
<<if $rng gte 101>><span class="purple"><<He>> moves <<his>> pelvis away, releasing your <<penis>> from <<his>> anus.</span><<sex 30>><<set $penis5 to "otheranusimminent">><<bruise penis>><<violence 1>><<set $penisstate to "otheranusimminent">><<set $speechotheranusimminent to 1>>
<<elseif $rng gte 1>>
<<if $enemyanger gte 100>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
<<His>> continues to fuck your <<penis>> with <<his>> ass, <<his>> movements violent and erratic.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues to ride you, your penis helpless as it's fucked.
<<else>>
<<He>> fucks your <<penis>> with rough movements, intent on showing you who's boss.
<</if>>
<<elseif $enemyanger gte 20>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
You feel <<his>> ass twitch around your length <<he>> fucks you.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues to violate your <<peniscomma>> using you as a sex toy.
<<else>>
<<He>> fucks your <<peniscomma>> taking as much of you into <<his>> ass as <<he>> can.
<</if>>
<<else>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
<<He>> continues riding your <<peniscomma>> <<his>> anus rhythmically pounding your length. <<His>> body jerks whenever you hit a sensitive spot.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues riding your <<peniscomma>> <<his>> anus rhythmically pounding your length.
<<else>>
<<He>> rides your <<penis>> with steady movements.
<</if>>
<</if>>
<<sex 30>><<bruise penis>><<violence 1>><<set $speechotheranus to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis5 is "otheranusimminent">>
<<if $rng gte 101>><span class="blue"><<He>> stops pressing <<his>> ass against your <<penisstop>></span><<set $penis5 to "otheranusentrance">><<set $penisstate to "otheranusentrance">><<set $speechotheranusentrance to 1>>
<<elseif $rng gte 1>>
<<if $nopenile is 0>><<set $penisactiondefault to "otheranustake">>
<<if $penilevirginity is 0>><span class="pink"><<He>> eases your <<penis>> into <<his>> ass, swallowing you to the base.</span><<sex 30>><<set $penis5 to "otheranus">><<penilestat>><<bruise penis>><<violence 1>><<raped>><<penisraped>><<set $penisstate to "otheranus">><<set $speechotheranus to 1>>
<<elseif $penilevirginity is 1>><span class="pink"><<He>> eases your virgin penis into <<his>> ass,</span><span class="red"> separating your foreskin from your glans and forever robbing you of your purity.</span><<sex 100>><<set $penis5 to "otheranus">><<set $penilevirginity to 0>><<bruise penis>><<penilestat>><<violence 100>><<raped>><<penisraped>><<set $penisstate to "otheranus">><<set $speechpenisvirgin to 1>>
<</if>>
<<else>>
Respecting your wishes, <<he>> does not envelope your <<penis>> with <<his>> ass, instead teasing the tip of your glans.<<sex 15>><<set $speechotheranuswithhold to 1>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis5 is "otheranusentrance">>
<<if $rng gte 101>><span class="lblue"><<He>> moves <<his>> ass away from your <<penisstop>></span><<set $penis5 to 0>><<set $penisuse to 0>><<set $penisstate to 0>>
<<elseif $rng gte 1>>
<<if $lowervaginaexposed is 0>><<He>> rubs <<his>> ass against your <<penis>> through your $lowerclothes.<<sex 5>><<set $lowerintegrity -= 10>><<set $speechotheranusentrance to 1>>
<<elseif $lowervaginaexposed is 1>><<set $rng to random(1, 100)>>
<<if $undervaginaexposed is 0>><<He>> rubs <<his>> ass against your <<penis>> through your $underclothes.<<sex 5>><<set $underintegrity -= 10>><<set $speechotheranusentrance to 1>>
<<elseif $undervaginaexposed is 1>>
<<if $rng gte 71>>
<<if $nopenile is 1>>
<span class="purple"><<He>> presses <<his>> ass against your <<penisstop>></span><<sex 20>><<set $penis5 to "otheranusimminent">><<set $penisstate to "otheranusimminent">><<set $speechotheranusimminent to 1>>
<<else>>
<span class="purple"><<He>> presses <<his>> ass against your <<peniscomma>> preparing to take you in fully.</span><<sex 20>><<set $penis5 to "otheranusimminent">><<set $penisstate to "otheranusimminent">><<set $speechotheranusimminent to 1>>
<</if>>
<<elseif $rng gte 1>><<He>> rubs your <<penis>> between <<his>> cheeks.<<sex 10>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis5 is 0>>
<<if $enemyanger + $rng lte 20>>
<<if $lefthand5 is 0>>
<<if $enemyarousal lte 40>><<He>> slowly rubs <<his>> shaft.<<submission 1>>
<<elseif $enemyarousal lte 90>><<He>> quickly rubs <<his>> shaft.<<submission 2>>
<<elseif $enemyarousal gte 91>><<He>> rapidly rubs <<his>> shaft.<<submission 3>>
<</if>>
<<elseif $righthand5 is 0>>
<<if $enemyarousal lte 40>><<He>> slowly rubs <<his>> shaft.<<submission 1>>
<<elseif $enemyarousal lte 90>><<He>> quickly rubs <<his>> shaft.<<submission 2>>
<<elseif $enemyarousal gte 91>><<He>> rapidly rubs <<his>> shaft.<<submission 3>>
<<endif>
<<else>><<He>> rubs <<his>> cock against your thighs.<<submission 2>>
<</if>>
<<elseif $enemyanger + $rng lte 25>>
<<if $position is "wall">>
<<He>> rubs <<his>> cock against your thighs.<<submission 2>>
<<else>>
<<He>> rubs <<his>> cock against your tummy.<<submission 2>>
<</if>>
<<elseif $enemyanger + $rng lte 30>>
<<if $position is "wall">>
<<He>> rubs <<his>> cock against your thighs.<<submission 2>>
<<else>>
<<He>> rubs <<his>> cock against your <<breastsstop>><<submission 2>>
<</if>>
<<elseif $enemyanger + $rng lte 35>><<He>> rubs <<his>> cock against your thighs.<<submission 2>>
<<elseif $enemyanger + $rng lte 40>>
<<if $position is "wall">>
<<He>> rubs <<his>> cock against your thighs.<<submission 2>>
<<elseif $mouth5 is 0>>
<<He>> rubs <<his>> cock against your face.<<submission 2>>
<<else>>
<<He>> rubs <<his>> cock against your thighs.<<submission 2>>
<</if>>
<<elseif $enemyanger + $rng lte 45>>
<<if $penisexist is 1>>
<<if $penisuse is 0>>
<<if $analdisable is "f" and $consensual is 1>>
<span class="blue"><<He>> straddles you, rubbing <<his>> ass against your <<penisstop>></span><<neutral 5>><<set $penisuse to "otheranus">><<set $penis5 to "otheranusentrance">><<set $penisstate to "otheranusentrance">><<set $speechotheranusentrance to 1>>
<</if>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 60>>
<<if $mouthuse is 0>>
<<if $penisbitten is 0>>
<<if $position isnot "wall">>
<span class="blue"><<He>> positions <<his>> penis in front of your mouth.</span><<neutral 5>><<set $mouthuse to "penis">><<set $penis5 to "mouthentrance">><<set $mouthstate to "entrance">><<set $speechmouthentrance to 1>>
<</if>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 80>>
<<if $anususe is 0>>
<<if $analdisable is "f">>
<span class="blue"><<He>> moves between your legs, positioning <<his>> penis in front of your <<bottomstop>></span><<neutral 5>><<set $anususe to "penis">><<set $penis5 to "anusentrance">><<set $anusstate to "entrance">><<set $speechanusentrance to 1>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 100>>
<<if $vaginaexist is 1>>
<<if $vaginause is 0>><span class="blue"><<He>> moves between your legs, positioning <<his>> penis in front of your <<pussystop>></span><<neutral 5>><<set $vaginause to "penis">><<set $penis5 to "vaginaentrance">><<set $vaginastate to "entrance">><<set $speechvaginaentrance to 1>>
<</if>>
<<elseif $penisexist is 1>>
<<if $anususe is 0>>
<<if $analdisable is "f">>
<span class="blue"><<He>> moves between your legs, positioning <<his>> penis in front of your <<bottomstop>></span><<neutral 5>><<set $anususe to "penis">><<set $penis5 to "anusentrance">><<set $anusstate to "entrance">><<set $speechanusentrance to 1>>
<</if>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 120>>
<<He>> slowly traces <<his>> length across your exposed skin.<<neutral 1>>
<<neutral 5>>
<<elseif $enemyanger + $rng lte 140>>
<<if $penisbitten is 0>>
<<if $position isnot "wall">>
<<if $mouthuse is 0>><span class="purple"><<He>> shoves <<his>> penis against your lips.</span><<submission 5>><<set $mouthuse to "penis">><<set $mouthstate to "imminent">><<set $penis5 to "mouthimminent">><<set $speechmouthimminent to 1>>
<<else>>
<<He>> slowly traces <<his>> length across your exposed skin.<<neutral 1>>
<</if>>
<<else>>
<<He>> slowly traces <<his>> length across your exposed skin.<<neutral 1>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 150>><span class="purple"><<He>> presses <<his>> foot against your <<genitalsstop>></span><<neutral 5>><<violence 1>><<set $penis5 to "footjob">>
<<if $penisexist is 1>>
<<set $penisuse to "feet">><<set $speechpenisfoot to 1>>
<<else>>
<<set $vaginause to "feet">><<set $speechvaginafoot to 1>>
<</if>>
<<elseif $enemyanger + $rng lte 170>>
<<if $anususe is 0 and $analdisable is "f">>
<<if $loweranusexposed is 1>>
<<if $underanusexposed is 1>>
<span class="purple"><<He>> presses <<his>> penis against your anus, preparing to penetrate.</span><<sex 5>><<set $anususe to "penis">><<set $penis5 to "anusimminent">><<set $anusstate to "imminent">><<set $speechanusimminent to 1>>
<<elseif $underanusexposed is 0>><span class="blue"><<He>> presses <<his>> penis against your anus through your $underclothes.</span><<sex 3>><<set $penis5 to "anusentrance">><<set $anususe to "penis">><<set $underintegrity -= 10>><<set $anusstate to "entrance">><<set $speechanusentrance to 1>>
<</if>>
<<elseif $loweranusexposed is 0>><span class="blue"><<He>> presses <<his>> penis against your anus through your $lowerclothes.</span><<sex 2>><<set $penis5 to "anusentrance">><<set $anususe to "penis">><<set $lowerintegrity -= 10>><<set $anusstate to "entrance">><<set $speechanusentrance to 1>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng gte 171>>
<<if $vaginaexist is 1>>
<<if $vaginause is 0>>
<<if $lowervaginaexposed is 1>>
<<if $undervaginaexposed is 1>><span class="purple"><<He>> presses <<his>> penis against your <<pussycomma>> preparing to penetrate.</span><<sex 5>><<set $vaginause to "penis">><<set $penis5 to "vaginaimminent">><<set $vaginastate to "imminent">><<set $speechvaginaimminent to 1>>
<<elseif $undervaginaexposed is 0>><span class="blue"><<He>> presses <<his>> penis against your <<pussy>> through your $underclothes.</span><<set $underintegrity -= 10>><<sex 3>><<set $penis5 to "vaginaentrance">><<set $vaginause to "penis">><<set $vaginastate to "entrance">><<set $speechvaginaentrance to 1>>
<</if>>
<<elseif $lowervaginaexposed is 0>><span class="blue"><<He>> presses <<his>> penis against your <<pussy>> through your $lowerclothes.</span><<sex 2>><<set $penis5 to "vaginaentrance">><<set $vaginause to "penis">><<set $lowerintegrity -= 10>><<set $vaginastate to "entrance">><<set $speechvaginaentrance to 1>>
<</if>>
<</if>>
<<elseif $penisexist is 1>>
<<if $anususe is 0 and $analdisable is "f">>
<<if $loweranusexposed is 1>>
<<if $underanusexposed is 1>><span class="purple"><<He>> presses <<his>> penis against your anus, preparing to penetrate.</span><<sex 5>><<set $anususe to "penis">><<set $penis5 to "anusimminent">><<set $anusstate to "imminent">><<set $speechanusimminent to 1>>
<<elseif $underanusexposed is 0>><span class="blue"><<He>> presses <<his>> penis against your anus through your $underclothes.</span><<sex 3>><<set $penis5 to "anusentrance">><<set $anususe to "penis">><<set $underintegrity -= 10>><<set $anusstate to "entrance">><<set $speechanusentrance to 1>>
<</if>>
<<elseif $loweranusexposed is 0>><span class="blue"><<He>> presses <<his>> penis against your anus through your $lowerclothes.</span><<sex 2>><<set $penis5 to "anusentrance">><<set $anususe to "penis">><<set $lowerintegrity -= 10>><<set $anusstate to "entrance">><<set $speechanusentrance to 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<set $rng to random(1, 100)>>
<<if $vagina5 is "clothed">>
<<if $pronoun is "f">>
<<if $enemyarousal gte 40>><span class="blue"><<He>> lifts up <<his>> skirt, revealing <<his>> moistened pussy.</span><<set $vagina5 to 0>>
<</if>>
<<else>>
<<if $enemyarousal gte 40>><span class="blue"><<He>> unzips <<his>> fly, revealing <<his>> moistened pussy.</span><<set $vagina5 to 0>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $vagina5 is "frot">>
<<if $rng gte 101>><span class="blue"><<He>> moves <<his>> clit away and presses <<his>> hungry pussy against your <<penisstop>></span><<set $penisuse to "othervagina">><<set $vagina5 to "penisentrance">><<set $penisstate to "entrance">><<set $speechpenisentrance to 1>>
<<else>>
<<He>> rubs <<his>> clit against your glans.<<sex 5>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $vagina5 is "penis">>
<<if $rng gte 101>><span class="purple"><<He>> moves <<his>> pelvis away, releasing your <<penis>> from <<his>> vagina.</span><<sex 30>><<set $vagina5 to "penisimminent">><<bruise penis>><<violence 1>><<set $penistate to "imminent">><<set $speechpenisimminent to 1>>
<<elseif $rng gte 1>>
<<if $enemyanger gte 100>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
<<His>> continues to fuck your <<peniscomma>> <<his>> movements violent and erratic as <<his>> pussy slides along your length.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues to ride you, your penis helpless as it's fucked.
<<else>>
<<He>> fucks your <<penis>> with rough movements, intent on showing you who's boss.
<</if>>
<<elseif $enemyanger gte 20>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
You feel <<his>> vagina twitch and throb around your length <<he>> fucks you.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues to violate your <<peniscomma>> using you as a sex toy.
<<else>>
<<He>> fucks your <<peniscomma>> taking as much of you into <<his>> vagina as <<he>> can.
<</if>>
<<else>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
<<He>> continues riding your <<peniscomma>> <<his>> vagina rhythmically kneading and squeezing your length. <<His>> body jerks whenever you hit a sensitive spot.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues riding your <<peniscomma>> <<his>> vagina rhythmically kneading and squeezing your length.
<<else>>
<<He>> rides your <<penis>> with steady movements.
<</if>>
<</if>>
<<sex 30>><<bruise penis>><<violence 1>><<set $speechpenispenetrated to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $vagina5 is "penisimminent">>
<<if $rng gte 101>><span class="blue"><<He>> stops pressing <<his>> pussy against your <<penisstop>></span><<set $vagina5 to "penisentrance">><<set $penisstate to "entrance">><<set $speechpenisentrance to 1>>
<<elseif $rng gte 1>>
<<if $nopenile is 0>><<set $penisactiondefault to "take">>
<<if $penilevirginity is 0>><span class="pink"><<He>> eases your <<penis>> into <<his>> pussy, swallowing you to the base.</span><<sex 30>><<set $vagina5 to "penis">><<penilestat>><<bruise penis>><<violence 1>><<raped>><<penisraped>><<set $penisstate to "penetrated">><<set $speechpenispenetrated to 1>>
<<elseif $penilevirginity is 1>><span class="pink"><<He>> eases your virgin penis into <<his>> pussy,</span><span class="red"> separating your foreskin from your glans and forever robbing you of your purity.</span><<sex 100>><<set $vagina5 to "penis">><<set $penilevirginity to 0>><<bruise penis>><<penilestat>><<violence 100>><<raped>><<penisraped>><<set $penisstate to "penetrated">><<set $speechpenisvirgin to 1>>
<</if>>
<<else>>
Respecting your wishes, <<he>> does not envelope your <<penis>> with <<his>> vagina, instead teasing the tip of your glans.<<sex 15>><<set $speechpeniswithhold to 1>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $vagina5 is "penisentrance">>
<<if $rng gte 101>><span class="lblue"><<He>> moves <<his>> pussy away from your <<penisstop>></span><<set $vagina5 to 0>><<set $penisuse to 0>><<set $penisstate to 0>>
<<elseif $rng gte 1>>
<<if $lowervaginaexposed is 0>><<He>> rubs <<his>> pussy against your <<penis>> through your $lowerclothes.<<sex 5>><<set $lowerintegrity -= 10>><<set $speechpenisentrance to 1>>
<<elseif $lowervaginaexposed is 1>><<set $rng to random(1, 100)>>
<<if $undervaginaexposed is 0>><<He>> rubs <<his>> pussy against your <<penis>> through your $underclothes.<<sex 5>><<set $underintegrity -= 10>><<set $speechpenisentrance to 1>>
<<elseif $undervaginaexposed is 1>>
<<if $rng gte 71>>
<<if $nopenile is 1>>
<span class="purple"><<He>> presses <<his>> pussy against your <<penisstop>></span><<sex 20>><<set $vagina5 to "penisimminent">><<set $penisstate to "imminent">><<set $speechpenisimminent to 1>>
<<else>>
<span class="purple"><<He>> presses <<his>> pussy against your <<peniscomma>> preparing to envelope you fully.</span><<sex 20>><<set $vagina5 to "penisimminent">><<set $penisstate to "imminent">><<set $speechpenisimminent to 1>>
<</if>>
<<elseif $rng gte 1>><<He>> teases your <<penis>> with <<his>> labia.<<sex 10>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $vagina5 is "lefthand">>
<<if $rng lte 80>>
<<He>> strokes <<his>> pussy with <<his>> left hand.<<neutral 1>><<set $enemyarousal += 20>>
<<else>>
<span class="blue"><<He>> moves <<his>> left hand away from <<his>> pussy.</span>
<<set $lefthand5 to 0>><<set $vagina5 to 0>>
<</if>>
<</if>>
<<if $vagina5 is "righthand">>
<<if $rng lte 80>>
<<He>> strokes <<his>> pussy with <<his>> right hand.<<neutral 1>><<set $enemyarousal += 20>>
<<else>>
<span class="blue"><<He>> moves <<his>> right hand away from <<his>> pussy.</span>
<<set $righthand5 to 0>><<set $vagina5 to 0>>
<</if>>
<</if>>
<<if $vagina5 is "mouth">>
<<if $enemyanger gte 100>>
<<He>> covers your mouth with <<his>> pussy, making it difficult to breathe.<<violence 3>><<bruise face>><<set $speechvaginamouth to 1>>
<<else>>
<<if $mouthsubmit is 1>>
<<if $rng gte 1>>
<<He>> rubs <<his>> pussy against your lips.
<<if $enemyarousal gte (($enemyarousalmax / 5) * 3)>>
You can taste <<his>> juices.
<</if>>
<<sex 3>><<set $speechvaginamouth to 1>>
<<else>><<He>> moves <<his>> pussy away from your face.<<set $mouthuse to 0>><<set $mouthstate to 0>><<set $vagina5 to 0>>
<</if>>
<<else>>
<<if $rng gte 1>>
<<He>> rubs <<his>> pussy against your lips.
<<if $enemyarousal gte (($enemyarousalmax / 5) * 3)>>
You can taste <<his>> juices.
<</if>>
<<sex 3>><<set $speechvaginamouth to 1>>
<<else>><<He>> moves <<his>> pussy away from your face.<<set $mouthuse to 0>><<set $mouthstate to 0>><<set $vagina5 to 0>>
<</if>>
<</if>>
<</if>>
<</if>>
<<if $vagina5 is "vagina">>
<<if $rng gte 1>>
<<He>> kneads your pussies together.<<sex 20>><<set $speechvaginavagina to 1>>
<<else>>
<span class="lblue"><<He>> moves <<his>> pussy away from yours.</span><<set $vaginause to 0>><<set $vagina5 to 0>>
<</if>>
<</if>>
<<if $vagina5 is "leftarm">>
<<if $rng gte 1>>
<<He>> rubs <<his>> pussy against your fingers.<<submission 2>>
<<else>>
<<He>> moves your hand away from <<his>> pussy.<<set $leftarm to 0>><<set $vagina5 to 0>><<set $leftactiondefault to "leftplay">>
<</if>>
<</if>>
<<if $vagina5 is "rightarm">>
<<if $rng gte 1>>
<<He>> rubs <<his>> pussy against your fingers.<<submission 2>>
<<else>>
<<He>> moves your hand away from <<his>> pussy.<<set $rightarm to 0>><<set $vagina5 to 0>><<set $rightactiondefault to "rightplay">>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $vagina5 is "feet">>
<<if $rng gte 1>>
<<He>> rubs <<his>> pussy against your feet.<<submission 2>>
<<else>>
<<He>> moves your feet away from <<his>> pussy.<<set $feetuse to 0>><<set $vagina5 to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $vagina5 is "footjob">>
<<if $rng gte 101>>
<span class="blue"><<He>> stops pressing <<his>> foot against your <<genitalsstop>></span><<set $vagina5 to 0>>
<<if $penisexist is 1>>
<<set $penisuse to 0>>
<<else>>
<<set $vaginause to 0>>
<</if>>
<<else>>
<<if $penisexist is 1>>
<<He>> presses your penis against your stomach with <<his>> foot and rubs your glans between <<his>> toes.
<<set $speechpenisfoot to 1>><<neutral 5>><<violence 1>>
<<else>>
<<He>> rubs <<his>> foot against your <<pussystop>>
<<set $speechvaginafoot to 1>><<neutral 5>><<violence 1>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $vagina5 is "otherfrot">>
<<if $rng gte 101>><span class="blue"><<He>> shifts <<his>> ass and presses <<his>> anus against your <<penisstop>></span><<set $penisuse to "otheranus">><<set $vagina5 to "otheranusentrance">><<set $penisstate to "otheranusentrance">><<set $speechotheranusentrance to 1>>
<<else>>
<<He>> rubs <<his>> ass against your <<penisstop>><<sex 5>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $vagina5 is "otheranus">>
<<if $rng gte 101>><span class="purple"><<He>> moves <<his>> pelvis away, releasing your <<penis>> from <<his>> anus.</span><<sex 30>><<set $vagina5 to "otheranusimminent">><<bruise penis>><<violence 1>><<set $penisstate to "otheranusimminent">><<set $speechotheranusimminent to 1>>
<<elseif $rng gte 1>>
<<if $enemyanger gte 100>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
<<His>> continues to fuck your <<penis>> with <<his>> ass, <<his>> movements violent and erratic. Fluid from <<his>> pussy drools onto your length.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues to ride you, your penis helpless as it's fucked.
<<else>>
<<He>> fucks your <<penis>> with rough movements, intent on showing you who's boss.
<</if>>
<<elseif $enemyanger gte 20>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
You feel <<his>> ass twitch around your length as <<he>> fucks you.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues to violate your <<peniscomma>> using you as a sex toy.
<<else>>
<<He>> fucks your <<peniscomma>> taking as much of you into <<his>> ass as <<he>> can.
<</if>>
<<else>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
<<He>> continues riding your <<peniscomma>> <<his>> anus rhythmically pounding your length. <<His>> body jerks whenever you hit a sensitive spot.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues riding your <<peniscomma>> <<his>> anus rhythmically pounding your length.
<<else>>
<<He>> rides your <<penis>> with steady movements.
<</if>>
<</if>>
<<sex 30>><<bruise penis>><<violence 1>><<set $speechotheranus to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $vagina5 is "otheranusimminent">>
<<if $rng gte 101>><span class="blue"><<He>> stops pressing <<his>> ass against your <<penisstop>></span><<set $vagina5 to "otheranusentrance">><<set $penisstate to "otheranusentrance">><<set $speechotheranusentrance to 1>>
<<elseif $rng gte 1>>
<<if $nopenile is 0>><<set $penisactiondefault to "take">>
<<if $penilevirginity is 0>><span class="pink"><<He>> eases your <<penis>> into <<his>> ass, swallowing you to the base.</span><<sex 30>><<set $vagina5 to "otheranus">><<penilestat>><<bruise penis>><<violence 1>><<raped>><<penisraped>><<set $penisstate to "otheranus">><<set $speechotheranus to 1>>
<<elseif $penilevirginity is 1>><span class="pink"><<He>> eases your virgin penis into <<his>> ass,</span><span class="red"> separating your foreskin from your glans and forever robbing you of your purity.</span><<sex 100>><<set $vagina5 to "otheranus">><<set $penilevirginity to 0>><<bruise penis>><<penilestat>><<violence 100>><<raped>><<penisraped>><<set $penisstate to "otheranus">><<set $speechpenisvirgin to 1>>
<</if>>
<<else>>
Respecting your wishes, <<he>> does not envelope your <<penis>> with <<his>> ass, instead teasing the tip of your glans.<<sex 15>><<set $speechotheranuswithhold to 1>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $vagina5 is "otheranusentrance">>
<<if $rng gte 101>><span class="lblue"><<He>> moves <<his>> ass away from your <<penisstop>></span><<set $vagina5 to 0>><<set $penisuse to 0>><<set $penisstate to 0>>
<<elseif $rng gte 1>>
<<if $lowervaginaexposed is 0>><<He>> rubs <<his>> ass against your <<penis>> through your $lowerclothes.<<sex 5>><<set $lowerintegrity -= 10>><<set $speechotheranusentrance to 1>>
<<elseif $lowervaginaexposed is 1>><<set $rng to random(1, 100)>>
<<if $undervaginaexposed is 0>><<He>> rubs <<his>> ass against your <<penis>> through your $underclothes.<<sex 5>><<set $underintegrity -= 10>><<set $speechotheranusentrance to 1>>
<<elseif $undervaginaexposed is 1>>
<<if $rng gte 71>>
<<if $nopenile is 1>>
<span class="purple"><<He>> presses <<his>> ass against your <<penisstop>></span><<sex 20>><<set $vagina5 to "otheranusimminent">><<set $penisstate to "otheranusimminent">><<set $speechotheranusimminent to 1>>
<<else>>
<span class="purple"><<He>> presses <<his>> ass against your <<peniscomma>> preparing to take you in fully.</span><<sex 20>><<set $vagina5 to "otheranusimminent">><<set $penisstate to "otheranusimminent">><<set $speechotheranusimminent to 1>>
<</if>>
<<elseif $rng gte 1>><<He>> rubs your <<penis>> between <<his>> cheeks.<<sex 10>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<if $vagina5 is 0>>
<<if $enemyanger + $rng lte 20>><<He>> sways <<his>> hips suggestively.<<neutral 1>><<set $speechvaginaflaunt to 1>>
<<elseif $enemyanger + $rng lte 40>><<He>> twirls on the spot.<<neutral 3>><<set $speechvaginaflaunt to 1>>
<<elseif $enemyanger + $rng lte 50>>
<<if $penisexist is 1>>
<<if $penisuse is 0 and $analdisable is "f">>
<span class="blue"><<He>> straddles you, rubbing <<his>> ass against your <<penisstop>></span><<neutral 5>><<set $penisuse to "otheranus">><<set $vagina5 to "otheranusentrance">><<set $penisstate to "otheranusentrance">><<set $speechotheranusentrance to 1>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 60>><<He>> rubs <<his>> pussy against your thigh.<<neutral 10>>
<<elseif $enemyanger + $rng lte 80 and $lefthand5 is 0>>
<span class="lblue"><<He>> presses <<his>> fingers against <<his>> labia.</span><<neutral 1>><<set $enemyarousal += 10>><<set $vagina5 to "lefthand">><<set $lefthand5 to "othervagina">>
<<elseif $enemyanger + $rng lte 80 and $righthand5 is 0>>
<span class="lblue"><<He>> presses <<his>> fingers against <<his>> labia.</span><<neutral 1>><<set $enemyarousal += 10>><<set $vagina5 to "righthand">><<set $righthand5 to "othervagina">>
<<elseif $enemyanger + $rng lte 80>>
<<He>> rubs <<his>> pussy against your thigh.<<neutral 2>>
<<elseif $enemyanger + $rng lte 100 and $penisuse is 0 and $undervaginaexposed is 1 and $lowervaginaexposed is 1>>
<<set $penisuse to "othervagina">><<set $vagina5 to "penisentrance">><<set $penisstate to "entrance">><span class="blue"><<He>> straddles you, <<his>> pussy hovering close to your <<penisstop>></span>
<<elseif $enemyanger + $rng lte 120 and $penisuse is 0 and $penisexist is 1 and $undervaginaexposed is 1 and $lowervaginaexposed is 1>>
<<set $penisuse to "othervagina">><<set $vagina5 to "penisimminent">><<set $penisstate to "imminent">><span class="purple"><<He>> wraps <<his>> legs around your pelvis, pressing <<his>> pussy against your <<genitalsstop>></span>
<<elseif $enemyanger + $rng lte 120 and $vaginause is 0 and $vaginaexist is 1 and $undervaginaexposed is 1 and $lowervaginaexposed is 1>>
<<set $vaginause to "othervagina">><<set $vagina5 to "vagina">><<sex 20>><<He>> pushes <<his>> pussy against yours.
<<elseif $enemyanger + $rng lte 140>>
<<if $position is "wall">>
<<He>> sits on your protruding <<bottomcomma>> pressing down on you painfully.<<violence 3>>
<<elseif $mouth5 is 0>>
<<He>> rubs <<his>> clit against your face.<<violence 3>>
<<else>>
<<He>> frots against your thigh while squeezing it with <<his>> own.<<violence 3>>
<</if>>
<<elseif $enemyanger + $rng lte 160>><span class="purple"><<He>> presses <<his>> foot against your <<genitalsstop>></span><<neutral 5>><<set $vagina5 to "footjob">>
<<if $penisexist is 1>>
<<set $penisuse to "feet">><<set $speechpenisfoot to 1>>
<<else>>
<<set $vaginause to "feet">><<set $speechvaginafoot to 1>>
<</if>>
<<elseif $enemyanger + $rng lte 180>>
<<if $position is "wall">>
<<He>> kicks you in the <<bottomstop>><<violence 10>><<hitstat>><<bruise bottom>>
<<else>>
<<He>> kicks you in the stomach.<<violence 10>><<hitstat>><<bruise face>>
<</if>>
<<elseif $enemyanger + $rng lte 200 and $mouthuse is 0>>
<<if $pullaway is 1>><<set $pullaway to 0>>
Saliva drips from her pussy.
<<else>>
<<if $position is "wall">>
<<if $penisexist is 1>>
<<He>> kicks your <<penisstop>><<violence 20>><<hitstat>><<bruise penis>><<set $speechbeat to 1>>
<<elseif $vaginaexist is 1>>
<<He>> kicks your <<pussystop>><<violence 20>><<hitstat>><<bruise vagina>><<set $speechbeat to 1>>
<</if>>
<<else>>
<span class="purple"><<He>> wraps <<his>> legs around your head and presses <<his>> pussy against your mouth.</span>
<<submission 5>><<set $mouthuse to "othervagina">><<set $vagina5 to "mouth">><<set $mouthstate to "othervagina">><<violence 3>><<bruise face>><<set $speechvaginamouth to 1>>
<</if>>
<</if>>
<<else>>
<<if $position is "wall">>
<<if $penisexist is 1>>
<<He>> kicks your <<penisstop>><<violence 20>><<hitstat>><<bruise penis>><<set $speechbeat to 1>>
<<elseif $vaginaexist is 1>>
<<He>> kicks your <<pussystop>><<violence 20>><<hitstat>><<bruise vagina>><<set $speechbeat to 1>>
<</if>>
<<else>>
<<He>> kicks you in the face.<<violence 10>><<bruise face>><<set $speechbeat to 1>><<hitstat>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth5 is "thigh">>
<<He>> kisses and licks your thigh.<<neutral 5>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth5 is "bottom">>
<<He>> kisses and licks your <<bottomstop>><<neutral 5>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth5 is "anus">>
<<if $rng gte 101>><span class="purple"><<He>> retracts <<his>> tongue from your anus.</span><<sex 30>><<set $mouth5 to "anusimminent">><<bruise anus>><<violence 1>><<set $anusstate to "othermouthimminent">>
<<elseif $rng gte 1>>
<<if $enemyarousal lte ($enemyarousalmax / 5)>>
<<He>> caresses your anus with <<his>> tongue.<<sex 30>><<bruise anus>><<violence 1>>
<<elseif $enemyarousal lte (($enemyarousalmax / 5) * 2)>>
<<His>> tongue probes inside your <<bottomstop>><<sex 30>><<bruise anus>><<violence 1>>
<<elseif $enemyarousal lte (($enemyarousalmax / 5) * 3)>>
<<He>> circles <<his>> tongue inside your <<bottomstop>><<sex 30>><<bruise anus>><<violence 1>>
<<elseif $enemyarousal lte (($enemyarousalmax / 5) * 4)>>
<<He>> presses <<his>> mouth firmly against your <<bottomcomma>> letting <<him>> push <<his>> tongue deeper into your anus.<<sex 30>><<bruise anus>><<violence 1>>
<<else>>
Repeatedly thrusting and retracting, <<he>> fucks your <<bottom>> with <<his>> tongue.<<sex 30>><<bruise anus>><<violence 1>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth5 is "anusimminent">>
<<if $rng gte 101>><span class="blue"><<He>> stops pressing <<his>> tongue against your anus.</span><<set $mouth5 to "anusentrance">><<set $anusstate to "othermouthentrance">>
<<elseif $rng gte 1>>
<<if $noanal is 0>>
<<if $analvirginity is 0>><span class="pink"><<He>> pushes <<his>> tongue into your anus.</span><<sex 30>><<set $mouth5 to "anus">><<analstat>><<bruise anus>><<violence 1>><<raped>><<set $anusstate to "othermouth">>
<<elseif $analvirginity is 1>><span class="pink"><<He>> pushes <<his>> tongue into your virgin anus,</span><span class="red"> violating you in a way you hadn't conceived of.</span><<sex 100>><<set $mouth5 to "anus">><<set $analvirginity to 0>><<bruise anus>><<analstat>><<violence 100>><<raped>><<set $anusstate to "othermouth">>
<</if>>
<<else>>
Respecting your wishes, <<he>> does not penetrate your <<bottom>> with <<his>> tongue, instead licking your anus.<<sex 15>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth5 is "anusentrance">>
<<if $rng gte 101>><span class="lblue"><<He>> moves <<his>> head away from your <<bottomstop>></span><<set $mouth5 to 0>><<set $anususe to 0>><<set $anusstate to 0>>
<<if $vagina5 is "othermouth">>
<<set $vagina5 to 0>>
<</if>>
<<if $penis5 is "othermouth">>
<<set $penis5 to 0>>
<</if>>
<<elseif $rng gte 1>>
<<if $loweranusexposed is 0>><<He>> circles <<his>> tongue around your anus through your $lowerclothes.<<sex 5>><<set $lowerintegrity -= 10>>
<<elseif $loweranusexposed is 1>><<set $rng to random(1, 100)>>
<<if $underanusexposed is 0>><<He>> circles <<his>> tongue around your anus through your $underclothes.<<sex 5>><<set $underintegrity -= 10>>
<<elseif $underanusexposed is 1>>
<<if $rng gte 71>>
<<if $noanal is 1>>
<span class="purple"><<He>> presses <<his>> tongue against your anus.</span><<sex 20>><<set $mouth5 to "anusimminent">><<set $anusstate to "othermouthimminent">>
<<else>>
<span class="purple"><<He>> presses <<his>> tongue against your anus, preparing to penetrate you.</span><<sex 20>><<set $mouth5 to "anusimminent">><<set $anusstate to "othermouthimminent">>
<</if>>
<<elseif $rng gte 1>><<He>> kisses and licks your <<bottomstop>><<sex 10>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth5 is "vagina">>
<<if $rng gte 101>><span class="purple"><<He>> retracts <<his>> tongue from your <<pussystop>></span><<sex 30>><<set $mouth5 to "vaginaimminent">><<bruise vagina>><<violence 1>><<set $vaginastate to "othermouthimminent">>
<<elseif $rng gte 1>>
<<if $enemyarousal lte ($enemyarousalmax / 5)>>
<<He>> caresses your vagina with <<his>> tongue.<<sex 30>><<bruise vagina>><<violence 1>>
<<elseif $enemyarousal lte (($enemyarousalmax / 5) * 2)>>
<<He>> presses down on your clit with <<his>> teeth while exploring your vagina with <<his>> tongue.<<sex 30>><<bruise vagina>><<violence 1>>
<<elseif $enemyarousal lte (($enemyarousalmax / 5) * 3)>>
<<He>> circles <<his>> tongue around your vagina.<<sex 30>><<bruise vagina>><<violence 1>>
<<elseif $enemyarousal lte (($enemyarousalmax / 5) * 4)>>
<<He>> presses <<his>> mouth firmly against your <<pussycomma>> then pushes <<his>> tongue deeper into your vagina. <<He>> slowly pulls out again, then takes a deep breath.<<sex 30>><<bruise vagina>><<violence 1>>
<<else>>
Repeatedly thrusting and retracting, <<he>> fucks your <<pussy>> with <<his>> tongue.<<sex 30>><<bruise vagina>><<violence 1>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth5 is "vaginaimminent">>
<<if $rng gte 101>><span class="blue"><<He>> stops pressing <<his>> tongue against your <<pussystop>></span><<set $mouth5 to "vaginaentrance">><<set $vaginastate to "othermouthentrance">>
<<elseif $rng gte 1>>
<<if $novaginal is 0>>
<<if $vaginalvirginity is 0>><span class="pink"><<He>> pushes <<his>> tongue between your <<pussy>> lips.</span><<sex 30>><<set $mouth5 to "vagina">><<vaginalstat>><<bruise vagina>><<violence 1>><<raped>><<vaginaraped>><<set $vaginastate to "othermouth">>
<<elseif $vaginalvirginity is 1>><span class="pink"><<He>> pushes <<his>> tongue into your virgin pussy,</span><span class="red"> breaking your hymen and forever robbing you of your purity.</span><<sex 100>><<set $mouth5 to "vagina">><<set $vaginalvirginity to 0>><<bruise vagina>><<vaginalstat>><<violence 100>><<raped>><<vaginaraped>><<set $vaginastate to "othermouth">>
<</if>>
<<else>>
Respecting your wishes, <<he>> does not penetrate your <<pussy>> with <<his>> tongue, instead running <<his>> tongue up and down your labia.<<sex 15>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth5 is "vaginaentrance">>
<<if $rng gte 101>><span class="lblue"><<He>> moves <<his>> head away from your <<pussystop>></span><<set $mouth5 to 0>><<set $vaginause to 0>><<set $vaginastate to 0>>
<<if $vagina5 is "othermouth">>
<<set $vagina5 to 0>>
<</if>>
<<if $penis5 is "othermouth">>
<<set $penis5 to 0>>
<</if>>
<<elseif $rng gte 1>>
<<if $lowervaginaexposed is 0>><<He>> traces the outline of your <<pussy>> with <<his>> tongue through your $lowerclothes.<<sex 5>><<set $lowerintegrity -= 10>>
<<elseif $lowervaginaexposed is 1>><<set $rng to random(1, 100)>>
<<if $undervaginaexposed is 0>><<He>> traces the outline of your <<pussy>> with <<his>> tongue through your $underclothes.<<sex 5>><<set $underintegrity -= 10>>
<<elseif $undervaginaexposed is 1>>
<<if $rng gte 71>>
<<if $novaginal is 1>>
<span class="purple"><<He>> presses <<his>> lips against your <<pussystop>></span><<sex 20>><<set $mouth5 to "vaginaimminent">><<set $vaginastate to "othermouthimminent">>
<<else>>
<span class="purple"><<He>> presses <<his>> lips against your <<pussycomma>> preparing to fuck you with <<his>> tongue.</span><<sex 20>><<set $mouth5 to "vaginaimminent">><<set $vaginastate to "othermouthimminent">>
<</if>>
<<elseif $rng gte 1>><<He>> blows on your clit and runs <<his>> tongue around your labia.<<sex 10>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth5 is "penis">>
<<if $rng gte 101>><span class="purple"><<He>> moves <<his>> head back, releasing your <<penis>> from <<his>> mouth.</span><<sex 30>><<set $mouth5 to "penisimminent">><<bruise penis>><<violence 1>><<set $penisstate to "othermouthimminent">>
<<elseif $rng gte 1>>
<<if $enemyarousal lte ($enemyarousalmax / 5)>>
<<He>> slowly caresses your shaft with <<his>> tongue.<<sex 30>><<bruise penis>><<violence 1>>
<<elseif $enemyarousal lte (($enemyarousalmax / 5) * 2)>>
Eyes fixed on your face, <<he>> wraps <<his>> tongue around your <<penis>> and sucks.<<sex 30>><<bruise penis>><<violence 1>>
<<elseif $enemyarousal lte (($enemyarousalmax / 5) * 3)>>
<<He>> squeezes <<his>> lips around your <<peniscomma>> and circles <<his>> tongue around your glans.<<sex 30>><<bruise penis>><<violence 1>>
<<elseif $enemyarousal lte (($enemyarousalmax / 5) * 4)>>
<<He>> takes you deeper into <<his>> mouth, until your <<penis>> disappears inside <<him>> completely. <<He>> slowly pushes you out again, then takes a deep breath.<<sex 30>><<bruise penis>><<violence 1>>
<<else>>
<<He>> repeatedly swallows and expels your <<peniscomma>> fucking you with <<his>> mouth.<<sex 30>><<bruise penis>><<violence 1>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth5 is "penisimminent">>
<<if $rng gte 101>><span class="blue"><<He>> stops pressing <<his>> lips against your <<penisstop>></span><<set $mouth5 to "penisentrance">><<set $penisstate to "othermouthentrance">>
<<elseif $rng gte 1>>
<<if $nopenile is 0>>
<<if $penilevirginity is 0>><span class="pink"><<He>> pushes <<his>> lips against your <<peniscomma>> taking you into <<his>> mouth.</span><<sex 30>><<set $mouth5 to "penis">><<penilestat>><<bruise penis>><<violence 1>><<raped>><<penisraped>><<set $penisstate to "othermouth">>
<<elseif $penilevirginity is 1>><span class="pink"><<He>> pushes <<his>> lips against your virgin penis, taking you into <<his>> mouth,</span><span class="red"> separating your foreskin from your glans and forever robbing you of your purity.</span><<sex 100>><<set $mouth5 to "penis">><<set $penilevirginity to 0>><<bruise penis>><<penilestat>><<violence 100>><<raped>><<penisraped>><<set $penisstate to "othermouth">>
<</if>>
<<else>>
Respecting your wishes, <<he>> does not envelope your <<penis>> with <<his>> mouth, instead kissing the tip of your glans.<<sex 15>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth5 is "penisentrance">>
<<if $rng gte 101>><span class="lblue"><<He>> moves <<his>> head away from your <<penisstop>></span><<set $mouth5 to 0>><<set $penisuse to 0>><<set $penisstate to 0>>
<<if $vagina5 is "othermouth">>
<<set $vagina5 to 0>>
<</if>>
<<if $penis5 is "othermouth">>
<<set $penis5 to 0>>
<</if>>
<<elseif $rng gte 1>>
<<if $lowervaginaexposed is 0>><<He>> traces the outline of your <<penis>> with <<his>> tongue through your $lowerclothes.<<sex 5>><<set $lowerintegrity -= 10>>
<<elseif $lowervaginaexposed is 1>><<set $rng to random(1, 100)>>
<<if $undervaginaexposed is 0>><<He>> traces the outline of your <<penis>> with <<his>> tongue through your $underclothes.<<sex 5>><<set $underintegrity -= 10>>
<<elseif $undervaginaexposed is 1>>
<<if $rng gte 71>>
<<if $nopenile is 1>>
<span class="purple"><<He>> presses <<his>> lips against your <<penisstop>></span><<sex 20>><<set $mouth5 to "penisimminent">><<set $penisstate to "othermouthimminent">>
<<else>>
<span class="purple"><<He>> presses <<his>> lips against your <<peniscomma>> preparing to take you in <<his>> mouth proper.</span><<sex 20>><<set $mouth5 to "penisimminent">><<set $penisstate to "othermouthimminent">>
<</if>>
<<elseif $rng gte 1>><<He>> blows on and licks the tip of your <<penisstop>><<sex 10>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth5 is "kiss">>
<<if $speechvaginavirgin isnot 1 and $speechpenisvirgin isnot 1 and $speechanusvirgin isnot 1 and $speechmouthvirgin isnot 1>>
<<if $rng gte 101>>
<span class="lblue"><<He>> pulls <<his>> mouth away from yours.</span><<set $mouth5 to 0>><<set $mouthuse to 0>><<set $mouthstate to 0>>
<<else>>
<<if $enemyanger lte 20>>
<<He>> explores your mouth with <<his>> tongue.<<sex 2>>
<<else>>
<<He>> thrusts <<his>> tongue deep into your mouth.<<violence 1>>
<</if>>
<</if>>
<<else>>
<span class="lblue"><<He>> pulls <<his>> mouth away from yours.</span><<set $mouthuse to 0>><<set $mouth5 to 0>><<set $mouthstate to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth5 is "kissimminent">>
<<if $speechvaginavirgin isnot 1 and $speechpenisvirgin isnot 1 and $speechanusvirgin isnot 1 and $speechmouthvirgin isnot 1>>
<<if $rng gte 101>>
<span class="lblue"><<He>> pulls <<his>> mouth away from yours.</span><<set $mouth5 to 0>><<set $mouthuse to 0>><<set $mouthstate to 0>>
<<elseif $rng lte 100>>
<<He>> pushes <<his>> tongue between your lips.<<set $mouth5 to "kiss">><<set $mouthstate to "kiss">><<sex 2>>
<<else>>
<<if $enemyanger lte 20>>
<<He>> gently probes your lips with <<his>> tongue.<<sex 2>>
<<else>>
<<He>> bites and toys with your lips.<<violence 1>>
<</if>>
<</if>>
<<else>>
<span class="lblue"><<He>> pulls <<his>> mouth away from yours.</span><<set $mouthuse to 0>><<set $mouth5 to 0>><<set $mouthstate to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth5 is "kissentrance">>
<<if $speechvaginavirgin isnot 1 and $speechpenisvirgin isnot 1 and $speechanusvirgin isnot 1 and $speechmouthvirgin isnot 1>>
<<if $rng gte 101>>
<span class="lblue"><<He>> pulls <<his>> mouth away from yours.</span><<set $mouth5 to 0>><<set $mouthuse to 0>><<set $mouthstate to 0>>
<<elseif $rng lte 100>>
<<He>> pulls you closer and presses your lips together in a kiss.<<set $mouth5 to "kissimminent">><<set $mouthstate to "kissimminent">><<sex 2>>
<<else>>
<<if $enemyanger lte 20>>
<<He>> gently brushes <<his>> lips against yours.<<sex 1>>
<<else>>
<<He>> bites your lower lip.<<violence 1>>
<</if>>
<</if>>
<<else>>
<span class="lblue"><<He>> pulls <<his>> mouth away from yours.</span><<set $mouthuse to 0>><<set $mouth5 to 0>><<set $mouthstate to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth5 is 0>>
<<if $speechvaginavirgin is 1>>
<<if $enemyanger lte 60>>
<<He>> speaks. "You were a virgin! I can't believe my luck!"
<<else>>
<<He>> speaks. "I felt your hymen tear bitch. Something to remember me by."
<</if>>
<<elseif $speechpenisvirgin is 1>>
<<if $enemyanger lte 60>>
<<He>> speaks. "AHH! This was your first time wasn't it? It feels so good!"
<<else>>
<<He>> speaks. "How's it feel to have your virgin dick broken in? Feels amazing for me."
<</if>>
<<elseif $speechanusvirgin is 1>>
<<if $enemyanger lte 60>>
<<He>> speaks. "It's so tight! This must be the first time your ass has been used like this."
<<else>>
<<He>> speaks. "It's so tight! This must be the first time your ass has been used like this. I've got plenty more work to do before you're properly broken in."
<</if>>
<<elseif $speechmouthvirgin is 1>>
<<if $enemyanger lte 60>>
<<He>> speaks. "Is this the first time you've tasted dick?"
<<else>>
<<He>> speaks. "Is this the first time you've tasted dick? You'll be a cum-addicted cock slave soon."
<</if>>
<<elseif $speechcum is 1 and $rng gte 61 and $speechorgasmrepeat lte 1 and $speechorgasmcount lte 6>>
<<cumspeech>>
<<elseif $rng gte 61>>
<<combatspeech>><<neutral 1>>
<<elseif $rng gte 91>>
<<basespeech>><<neutral 1>>
<<else>>
<<set $rng to random(1, 100)>>
<<if $enemyanger + $rng lte 20>><<He>> <<admires>> your body.<<neutral 1>>
<<elseif $enemyanger + $rng lte 25>>
<<if $position is "wall">>
<<He>> <<admires>> your helpless <<bottomstop>><<neutral 1>>
<<else>>
<<He>> <<admires>> your hair.<<neutral 1>>
<</if>>
<<elseif $enemyanger + $rng lte 30>>
<<if $position is "wall">>
<<He>> <<admires>> your helpless hips.<<neutral 1>>
<<else>>
<<He>> <<admires>> your chest.<<neutral 1>>
<</if>>
<<elseif $enemyanger + $rng lte 35>>
<<He>> <<admires>> your legs.<<neutral 1>>
<<elseif $enemyanger + $rng lte 40>>
<<if $position is "wall">>
<<He>> <<admires>> your helpless legs.<<neutral 1>>
<<else>>
<<He>> <<admires>> your face.<<neutral 1>>
<</if>>
<<elseif $enemyanger + $rng lte 45>>
<<if $position is "wall">>
<<He>> kisses your helpless thighs.<<neutral 3>>
<<else>>
<<He>> kisses you on the forehead.<<neutral 3>>
<</if>>
<<elseif $enemyanger + $rng lte 50>>
<<if $position is "wall">>
<<He>> kisses you on the hips.<<neutral 3>>
<<else>>
<<He>> kisses you on the cheek.<<neutral 3>>
<</if>>
<<elseif $enemyanger + $rng lte 55>>
<<if $position is "wall">>
<<He>> licks your helpless thighs.<<neutral 3>>
<<else>>
<<He>> kisses your neck.<<neutral 3>>
<</if>>
<<elseif $enemyanger + $rng lte 60>>
<<if $position is "wall">>
<<He>> licks your helpless hips.<<neutral 3>>
<<else>>
<<He>> licks your cheek.<<neutral 3>>
<</if>>
<<elseif $enemyanger + $rng lte 80>><<neutral 10>>
<<if $position is "wall">>
<<He>> licks your helpless legs.<<neutral 3>>
<<else>>
<<if $mouthuse is 0>>
<span class="blue"><<He>> moves <<his>> lips close to yours, about to kiss.</span><<set $mouthuse to "kiss">><<set $mouthstate to "kissentrance">><<set $mouth5 to "kissentrance">><<sex 1>>
<<else>>
<<He>> licks your cheek.
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 84>><<neutral 10>>
<<if $anususe is 0 and $vagina5 is 0 and $analdisable is "f">>
<span class="blue"><<He>> kneels behind you. You feel <<his>> breath on your <<bottomstop>></span><<set $anususe to "othermouth">><<set $anusstate to "othermouthentrance">><<set $mouth5 to "anusentrance">><<set $vagina5 to "othermouth">><<sex 1>>
<<elseif $anususe is 0 and $penis5 is 0 and $analdisable is "f">>
<span class="blue"><<He>> kneels behind you. You feel <<his>> breath on your <<bottomstop>></span><<set $anususe to "othermouth">><<set $anusstate to "othermouthentrance">><<set $mouth5 to "anusentrance">><<set $penis5 to "othermouth">><<sex 1>>
<</if>>
<<elseif $enemyanger + $rng lte 92>><<neutral 10>>
<<if $vaginause is 0 and $vagina5 is 0 and $vaginaexist is 1>>
<span class="blue"><<He>> kneels beside you. You feel <<his>> breath on your <<pussystop>></span><<set $vaginause to "othermouth">><<set $vaginastate to "othermouthentrance">><<set $mouth5 to "vaginaentrance">><<set $vagina5 to "othermouth">><<sex 1>>
<<elseif $vaginause is 0 and $penis5 is 0 and $vaginaexist is 1>>
<span class="blue"><<He>> kneels beside you. You feel <<his>> breath on your <<pussystop>></span><<set $vaginause to "othermouth">><<set $vaginastate to "othermouthentrance">><<set $mouth5 to "vaginaentrance">><<set $penis5 to "othermouth">><<sex 1>>
<<else>>
<<He>> breathes on your skin, making your hair stand on end.<<neutral 1>>
<</if>>
<<elseif $enemyanger + $rng lte 100>><<neutral 10>>
<<if $penisuse is 0 and $penis5 is 0 and $penisexist is 1>>
<span class="blue"><<He>> kneels beside you. You feel <<his>> breath on your <<penisstop>></span><<set $penisuse to "othermouth">><<set $penisstate to "othermouthentrance">><<set $mouth5 to "penisentrance">><<set $vagina5 to "othermouth">><<sex 1>>
<<elseif $penisuse is 0 and $vagina5 is 0 and $penisexist is 1>>
<span class="blue"><<He>> kneels beside you. You feel <<his>> breath on your <<penisstop>></span><<set $penisuse to "othermouth">><<set $penisstate to "othermouthentrance">><<set $mouth5 to "penisentrance">><<set $penis5 to "othermouth">><<sex 1>>
<<else>>
<<He>> breathes on your skin, making your hair stand on end.<<neutral 1>>
<</if>>
<<elseif $enemyanger + $rng lte 105>>
<<if $position is "wall">>
<<He>> kisses and caresses your helpless thighs with <<his>> tongue.<<neutral 10>>
<<else>>
<<He>> kisses and caresses your nipple with <<his>> tongue.<<neutral 10>>
<</if>>
<<elseif $enemyanger + $rng lte 110>>
<<if $position is "wall">>
<<He>> kisses and gently bites your helpless <<bottomstop>><<neutral 10>>
<<else>>
<<He>> kisses and gently bites you on the neck.<<neutral 10>>
<</if>>
<<elseif $enemyanger + $rng lte 115>>
<<He>> spits on your <<genitalsstop>><<neutral 5>>
<<elseif $enemyanger + $rng lte 120>>
<<He>> spits on your <<bottomstop>><<neutral 5>>
<<elseif $enemyanger + $rng lte 130>>
<<He>> spits on your stomach.<<neutral 5>>
<<elseif $enemyanger + $rng lte 140>>
<<if $position is "wall">>
<<He>> spits on your helpless thighs.<<neutral 5>>
<<else>>
<<He>> spits on your face.<<neutral 5>>
<</if>>
<<elseif $enemyanger + $rng lte 150>>
<<He>> bites your <<bottomstop>><<violence 10>><<hitstat>><<bruise bottom>>
<<elseif $enemyanger + $rng lte 160>>
<<if $position is "wall">>
<<He>> bites your thighs.<<violence 10>><<hitstat>><<bruise thigh>>
<<else>>
<<He>> bites your shoulders.<<violence 10>><<hitstat>><<bruise leftarm>><<bruise rightarm>>
<</if>>
<<elseif $enemyanger + $rng lte 170>>
<<if $position is "wall">>
<<He>> bites your hips.<<violence 10>><<hitstat>><<bruise tummy>>
<<else>>
<<He>> bites your neck.<<violence 10>><<hitstat>><<bruise neck>>
<</if>>
<<elseif $enemyanger + $rng lte 180>>
<<if $position is "wall">>
<<He>> bites your thighs.<<violence 10>><<hitstat>><<bruise thigh>>
<<else>>
<<He>> bites your cheek.<<violence 10>><<hitstat>><<bruise face>>
<</if>>
<<elseif $enemyanger + $rng gte 190>>
<<if $position is "wall">>
<<He>> bites your <<bottomstop>><<violence 10>><<hitstat>><<bruise bottom>>
<<else>>
<<He>> bites your <<breastsstop>><<violence 10>><<hitstat>><<bruise chest>>
<</if>>
<</if>>
<</if>>
<</if>>
<<manend>>
<<set $pullaway to 0>>
<</nobr>><</widget>>
:: Widgets Combat Man 6 [widget]
<<widget "man6">><<nobr>>
<<if $pronoun6 is "m">>
<<set $pronoun to "m">>
<</if>>
<<if $pronoun6 is "f">>
<<set $pronoun to "f">>
<</if>>
<<if $pronoun6 is "i">>
<<set $pronoun to "i">>
<</if>>
<<if $pronoun6 is "n">>
<<set $pronoun to "n">>
<</if>>
<<if $pronoun6 is "t">>
<<set $pronoun to "t">>
<</if>>
<<man6speech>>
<<set $intro6 to 1>>
<<if $lefthand6 is "spank">><<bruise bottom>><<hitstat>><<set $speechspank to 1>>
<<He>> spanks your <<bottom>>
<<if $lowerclothes isnot "naked" and $lowerstate is "waist">>
through your $lowerclothes.
<<elseif $underclothes isnot "naked" and $understate is "waist">>
through your $underclothes.
<<else>>
reddening your exposed skin.
<</if>>
<<violence 5>>
<</if>>
<<if $righthand6 is "spank">><<bruise bottom>><<hitstat>>
<<He>> spanks your <<bottom>><<set $speechspank to 1>>
<<if $lowerclothes isnot "naked" and $lowerstate is "waist">>
through your $lowerclothes.
<<elseif $underclothes isnot "naked" and $understate is "waist">>
through your $underclothes.
<<else>>
reddening your exposed skin.
<</if>>
<<violence 5>>
<</if>>
<<if $lefthand6 is "arms">>
<<if $enemytrust gte 20 and $enemyanger lte 20>><span class="lblue"><<He>> releases your arms.</span><<set $lefthand6 to 0>><<set $leftarm to 0>><<set $rightarm to 0>>
<<else>><<He>> grips your arms.
<<violence 6>><<bruise leftarm>><<bruise rightarm>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand6 is "arms">>
<<if $enemytrust gte 20 and $enemyanger lte 20>><span class="lblue"><<He>> releases your arms.</span><<set $righthand6 to 0>><<set $leftarm to 0>><<set $rightarm to 0>>
<<else>><<He>> grips your arms.
<<violence 6>><<bruise leftarm>><<bruise rightarm>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand6 is "leftarm">>
<<if $enemytrust gte 20 and $enemyanger lte 20>><span class="lblue"><<He>> releases your left arm.</span><<set $lefthand6 to 0>><<set $leftarm to 0>>
<<else>><<He>> grips your left arm.<<violence 3>><<bruise leftarm>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand6 is "leftarm">>
<<if $enemytrust gte 20 and $enemyanger lte 20>><span class="lblue"><<He>> releases your left arm.</span><<set $righthand6 to 0>><<set $leftarm to 0>>
<<else>><<He>> grips your left arm.<<violence 3>><<bruise leftarm>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand6 is "rightarm">>
<<if $enemytrust gte 20 and $enemyanger lte 20>><span class="lblue"><<He>> releases your right arm.</span><<set $lefthand6 to 0>><<set $rightarm to 0>>
<<else>><<He>> grips your right arm.<<violence 3>><<bruise rightarm>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand6 is "rightarm">>
<<if $enemytrust gte 20 and $enemyanger lte 20>><span class="lblue"><<He>> releases your right arm.</span><<set $righthand6 to 0>><<set $rightarm to 0>>
<<else>><<He>> grips your right arm.<<violence 3>><<bruise rightarm>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand6 is "vaginaentrance">>
<<if $rng gte 101>><span class="blue"><<He>> moves <<his>> left hand away from your <<pussystop>></span><<set $lefthand6 to 0>><<set $vaginause to 0>>
<<elseif $rng gte 81>><<He>> <<strokes>> your labia.<<neutral 10>>
<<elseif $rng gte 21>><<He>> gives your clitoris a tweak.<<set $speechclit to 1>><<neutral 10>>
<<elseif $rng lte 20>><span class="pink"><<He>> plunges a finger into your <<pussystop>></span><<neutral 15>><<set $lefthand6 to "vagina">><<set $speechvagina to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand6 is "vaginaentrance">>
<<if $rng gte 101>><span class="blue"><<He>> moves <<his>> right hand away from your <<pussystop>></span><<set $righthand6 to 0>><<set $vaginause to 0>>
<<elseif $rng gte 51>><<He>> <<strokes>> your labia.<<neutral 10>>
<<elseif $rng gte 21>><<He>> gives your clitoris a tweak.<<neutral 10>><<set $speechclit to 1>>
<<elseif $rng lte 20>><span class="pink"><<He>> plunges a finger into your warm <<pussystop>></span><<neutral 15>><<set $righthand6 to "vagina">><<set $speechvagina to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand6 is "penisentrance">>
<<if $rng gte 101>><span class="blue"><<He>> moves <<his>> left hand away from your <<penisstop>></span><<set $lefthand6 to 0>><<set $penisuse to 0>>
<<elseif $rng gte 51>><<He>> <<strokes>> your shaft.<<neutral 10>>
<<elseif $rng gte 21>><<He>> rubs your glans.<<neutral 10>><<set $speechglans to 1>>
<<elseif $rng lte 20>><span class="pink"><<He>> wraps <<his>> fingers around your <<penisstop>></span><<neutral 15>><<set $lefthand6 to "penis">><<set $speechpenis to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand6 is "penisentrance">>
<<if $rng gte 101>><span class="blue"><<He>> moves <<his>> right hand away from your <<penisstop>></span><<set $righthand6 to 0>><<set $penisuse to 0>>
<<elseif $rng gte 51>><<He>> <<strokes>> your shaft.<<neutral 10>>
<<elseif $rng gte 21>><<He>> rubs your glans.<<neutral 10>><<set $speechglans to 1>>
<<elseif $rng lte 20>><span class="pink"><<He>> wraps <<his>> fingers around your penis.</span><<neutral 15>><<set $righthand6 to "penis">><<set $speechpenis to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand6 is "vagina">>
<<if $rng gte 101>><span class="purple"><<He>> slides <<his>> finger out of your <<pussystop>></span><<set $lefthand6 to "vaginaentrance">><<neutral 15>>
<<elseif $rng lte 100>><<He>> <<strokes>> the inside of your <<pussycomma>><<neutral 20>><<set $speechvagina to 1>>
<<if $arousal gte 8000>>
causing involuntary shudders.
<<elseif $arousal gte 2000>>
coaxing out lewd fluid.
<<else>>
eager to explore it.
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand6 is "vagina">>
<<if $rng gte 101>><span class="purple"><<He>> slides <<his>> finger out of your <<pussystop>></span><<set $righthand6 to "vaginaentrance">><<neutral 15>>
<<elseif $rng lte 100>><<He>> <<strokes>> the inside of your <<pussycomma>><<neutral 20>><<set $speechvagina to 1>>
<<if $arousal gte 8000>>
causing you involuntary shudders.
<<elseif $arousal gte 2000>>
coaxing out lewd fluid.
<<else>>
invading your body in a most sordid manner.
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand6 is "penis">>
<<if $rng gte 101>><span class="purple"><<He>> releases your <<penis>> from <<his>> grip.</span><<set $lefthand6 to "penisentrance">><<neutral 15>>
<<elseif $rng lte 100>><<He>> massages the length of your <<peniscomma>><<neutral 20>><<set $speechpenis to 1>>
<<if $arousal gte 8000>>
causing you involuntary shudders.
<<elseif $arousal gte 2000>>
coaxing out lewd fluid.
<<else>>
exploiting your body's natural reactions in a most sordid manner.
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand6 is "penis">>
<<if $rng gte 101>><span class="purple"><<He>> releases your <<penis>> from <<his>> grip.</span><<set $righthand6 to "penisentrance">><<neutral 15>>
<<elseif $rng lte 100>><<He>> massages the length of your <<peniscomma>><<neutral 20>><<set $speechpenis to 1>>
<<if $arousal gte 8000>>
causing you involuntary shudders.
<<elseif $arousal gte 2000>>
coaxing out lewd fluid.
<<else>>
exploiting your body's natural reactions in a most sordid manner.
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand6 is "anusentrance">>
<<if $rng gte 101>><span class="blue"><<He>> moves <<his>> left hand away from your ass.</span><<set $lefthand6 to 0>><<set $vaginause to 0>>
<<elseif $rng gte 21>><<He>> <<strokes>> your anus.<<neutral 10>>
<<elseif $rng lte 20>><span class="pink"><<He>> plunges a finger into your ass.</span><<neutral 15>><<set $lefthand6 to "anus">><<set $speechanus to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand6 is "anusentrance">>
<<if $rng gte 101>><span class="blue"><<He>> moves <<his>> hand away from your ass.</span><<set $righthand6 to 0>><<set $vaginause to 0>>
<<elseif $rng gte 21>><<He>> <<strokes>> your anus.<<neutral 10>>
<<elseif $rng lte 20>><span class="pink"><<He>> plunges a finger into your ass.</span><<neutral 15>><<set $righthand6 to "anus">><<set $speechanus to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand6 is "anus">>
<<if $rng gte 101>><span class="purple"><<He>> slides <<his>> finger out of your ass.</span><<set $lefthand6 to "anusentrance">><<neutral 15>>
<<elseif $rng lte 100>><<He>> rhythmically slides <<his>> finger in and out of your ass,<<neutral 20>><<set $speechanus to 1>>
<<if $playergender is "m">>
teasing your prostate.
<<else>>
teasing your anus.
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand6 is "anus">>
<<if $rng gte 101>><span class="purple"><<He>> slides <<his>> finger out of your ass.</span><<set $righthand6 to "anusentrance">><<neutral 15>>
<<elseif $rng lte 100>><<He>> rhythmically slides <<his>> finger in and out of your ass,<<neutral 20>><<set $speechanus to 1>>
<<if $playergender is "m">>
teasing your prostate.
<<else>>
teasing your anus.
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand6 is "mouth">>
<<if $enemyanger lte 20 and $enemytrust gte 20>><span class="teal">Made confident by your accommodating behaviour, <<he>> releases <<his>> hand from your mouth.</span><<set $lefthand6 to 0>><<set $mouthuse to 0>>
<<else>><<He>> continues to clasp your mouth shut.<<violence 1>><<bruise face>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand6 is "mouth">>
<<if $enemyanger lte 20 and $enemytrust gte 20>><span class="teal">Made confident by your accommodating behaviour, <<he>> releases <<his>> hand from your mouth.</span><<set $righthand6 to 0>><<set $mouthuse to 0>>
<<else>><<He>> continues to clasp your mouth shut.<<violence 1>><<bruise face>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand6 is "throat">>
<<if $enemyanger gte 100>><<set $strangle += 1>>
<<if $strangle is 0>><<He>> strangles your throat.<<violence 5>><<bruise neck>><<bruise neck>><<set $speechthroat to 1>>
<<elseif $strangle lte 2>><span class="purple"><<He>> strangles your throat. You can't breathe!</span><<set $speechthroat to 1>>
<<violence 10>><<bruise neck>><<bruise neck>>
<<elseif $strangle lte 4>><span class="pink"><<He>> strangles your throat. You feel light-headed.</span><<set $speechthroat to 1>>
<<violence 20>><<bruise neck>><<bruise neck>>
<<elseif $strangle lte 6>><span class="pink"><<He>> strangles your throat. You see stars.</span><<set $speechthroat to 1>>
<<violence 40>><<bruise neck>><<bruise neck>>
<<elseif $strangle gte 8>><span class="red"><<He>> strangles your throat. You are suffocating.</span><<set $speechthroat to 1>>
<<violence 100>><<bruise neck>><<bruise neck>>
<</if>>
<<elseif $rng gte 81>><span class="teal"><<He>> releases <<his>> hand from your throat.</span> You gasp for air.
<<set $lefthand6 to 0>>
<<else>><<He>> holds you down by your throat.<<violence 1>>
<</if>><<bruise neck>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand6 is "throat">>
<<if $enemyanger gte 100>><<set $strangle += 1>>
<<if $strangle is 0>><<He>> strangles your throat.<<violence 5>><<bruise neck>><<bruise neck>><<set $speechthroat to 1>>
<<elseif $strangle lte 2>><<He>> strangles your throat. <span class="purple">You can't breathe!</span><<set $speechthroat to 1>>
<<violence 10>><<bruise neck>><<bruise neck>>
<<elseif $strangle lte 4>><<He>> strangles your throat. <span class="pink">You feel light-headed.</span><<set $speechthroat to 1>>
<<violence 20>><<bruise neck>><<bruise neck>>
<<elseif $strangle lte 6>><<He>> strangles your throat. <span class="pink">You see stars.</span> <<set $speechthroat to 1>>
<<violence 40>><<bruise neck>><<bruise neck>>
<<elseif $strangle gte 7>><<He>> strangles your throat. <span class="red">You are suffocating.</span><<set $speechthroat to 1>>
<<violence 100>><<bruise neck>><<bruise neck>>
<</if>>
<<elseif $rng gte 81>><span class="teal"><<He>> releases <<his>> hand from your throat.</span> You gasp for air.
<<set $righthand6 to 0>>
<<else>><<He>> holds you down by your throat.<<violence 1>>
<</if>><<bruise neck>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand6 is "underclothes" and $undertype is "chastity">>
<span class="blue"><<He>> tries to loosen your $underclothes.</span> <<His>> rough handling leaves you feeling more frustrated and aroused. <<He>> gives up after a few moments of impotent tugging, looking disappointed.<<neutral 1>><<set $enemyanger += 5>><<set $arousal += 5>><<set $lefthand6 to 0>><<set $speechchastity to 1>><<set $underintegrity -= 10>>
<</if>>
<<if $righthand6 is "underclothes" and $undertype is "chastity">>
<span class="blue"><<He>> tries to loosen your $underclothes.</span> <<His>> rough handling leaves you feeling more frustrated and aroused.<<He>> gives up after a few moments of impotent tugging, looking disappointed.<<neutral 1>><<set $enemyanger += 5>><<set $arousal += 5>><<set $righthand6 to 0>><<set $speechchastity to 1>><<set $underintegrity -= 10>>
<</if>>
<<if $lefthand6 is "underclothes">>
<<if $underclothes is "naked">><span class="purple"><<He>> casts aside the fabric.</span><<set $lefthand6 to 0>>
<<elseif $understruggle is 1>>You manage to keep <<him>> from pulling down your $underclothes.<<set $understruggle to 0>><<set $speechstripstruggle to 1>>
<<elseif $rng gte 101>><span class="blue"><<He>> releases <<his>> hand from your $underclothes.</span><<set $lefthand6 to 0>>
<<elseif $rng lte 100>>
<<if $skirt is 1>>
<<if $understate is "waist">><<He>> pulls your $underclothes down your thighs, <span class="lewd">revealing your <<genitalsstop>></span><<set $understate to "thighs">><<neutral 5>><<set $undervaginaexposed to 1>><<set $underanusexposed to 1>><<set $underexposed to 1>><<set $speechgenitals to 1>>
<<elseif $understate is "thighs">><<He>> pulls your $underclothes down to your knees.<<set $understate to "knees">><<neutral 1>>
<<elseif $understate is "knees">><<He>> pulls your $underclothes down to your ankles.<<set $understate to "ankles">><<neutral 1>>
<<elseif $understate is "ankles">><span class="purple"><<He> pulls your $underclothes off your legs.</span><<understrip>><<undernaked>><<neutral 3>><<set $lefthand6 to 0>><<clothesstripstat>>
<</if>>
<<elseif $lowerstate isnot "waist">>
<<if $understate is "waist">><<He>> pulls your $underclothes down your thighs, <span class="lewd">revealing your <<genitalsstop>></span><<set $understate to "thighs">><<neutral 5>><<set $undervaginaexposed to 1>><<set $underanusexposed to 1>><<set $underexposed to 1>><<set $speechgenitals to 1>>
<<elseif $understate is "thighs">><<He>> pulls your $underclothes down to your knees.<<set $understate to "knees">><<neutral 1>>
<<elseif $understate is "knees">><<He>> pulls your $underclothes down to your ankles.<<set $understate to "ankles">><<neutral 5>>
<<elseif $understate is "ankles">><span class="purple"><<He>> pulls your $underclothes off your legs.</span><<understrip>><<undernaked>><<neutral 3>><<set $lefthand6 to 0>><<clothesstripstat>>
<</if>>
<<else>><<He>> tugs on your $underclothes.<<neutral 1>><<set $underintegrity -= 10>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand6 is "underclothes">>
<<if $underclothes is "naked">><span class="purple"><<He>> casts aside the fabric.</span><<set $righthand6 to 0>>
<<elseif $understruggle is 1>>You manage to keep <<him>> from pulling down your $underclothes.<<set $understruggle to 0>><<set $speechstripstruggle to 1>>
<<elseif $rng gte 101>><span class="purple"><<He>> releases <<his>> hand from your $underclothes.</span><<set $righthand6 to 0>><<set $skirtuse to 0>>
<<elseif $rng lte 100>>
<<if $skirt is 1>>
<<if $understate is "waist">><<He>> pulls your $underclothes down your thighs, <span class="lewd">revealing your <<genitalsstop>></span><<set $understate to "thighs">><<neutral 5>><<set $undervaginaexposed to 1>><<set $underanusexposed to 1>><<set $underexposed to 1>><<set $speechgenitals to 1>>
<<elseif $understate is "thighs">><<He>> pulls your $underclothes down to your knees.<<set $understate to "knees">><<neutral 1>>
<<elseif $understate is "knees">><<He>> pulls your $underclothes down to your ankles.<<set $understate to "ankles">><<neutral 1>>
<<elseif $understate is "ankles">><span class="purple"><<He>> pulls your $underclothes off your legs.</span><<understrip>><<undernaked>><<neutral 3>><<set $righthand6 to 0>><<clothesstripstat>>
<</if>>
<<elseif $lowerstate isnot "waist">>
<<if $understate is "waist">><<He>> pulls your $underclothes down your thighs, <span class="lewd">revealing your <<genitalsstop>></span><<set $understate to "thighs">><<neutral 5>><<set $undervaginaexposed to 1>><<set $underanusexposed to 1>><<set $underexposed to 1>><<set $speechgenitals to 1>>
<<elseif $understate is "thighs">><<He>> pulls your $underclothes down to your knees.<<set $understate to "knees">><<neutral 1>>
<<elseif $understate is "knees">><<He>> pulls your $underclothes down to your ankles.<<set $understate to "ankles">><<neutral 5>>
<<elseif $understate is "ankles">><span class="purple"><<He>> pulls your $underclothes off your legs.</span><<understrip>><<undernaked>><<neutral 3>><<set $righthand6 to 0>><<clothesstripstat>>
<</if>>
<<else>><<He>> tugs on your $underclothes.<<neutral 1>><<set $underintegrity -= 10>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand6 is "hair">>
<<if $rng gte 101>><span class="lblue"><<He>> releases <<his>> hand from your hair.</span><<set $lefthand6 to 0>>
<<elseif $enemyanger gte 61>>With your hair in <<his>> grip, <<he>> yanks back your head.<<violence 4>><<set $speechhair to 1>>
<<elseif $enemyanger gte 21>>
<<He>> strokes your hair while holding it bunched in <<his>> grip.<<set $speechhair to 1>><<neutral 1>>
<<else>><span class="lblue"><<He>> releases <<his>> hand from your hair.</span><<set $lefthand6 to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand6 is "hair">>
<<if $rng gte 101>><span class="lblue"><<He>> releases <<his>> hand from your hair.</span><<set $righthand6 to 0>>
<<elseif $enemyanger gte 61>>With your hair in <<his>> grip, <<he>> yanks back your head.<<violence 4>><<set $speechhair to 1>>
<<elseif $enemyanger gte 21>>
<<He>> strokes your hair while holding it bunched in <<his>> grip.<<set $speechhair to 1>><<neutral 1>>
<<else>><span class="lblue"><<He>> releases <<his>> hand from your hair.</span><<set $righthand6 to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand6 is "lowerclothes">>
<<if $lowerclothes is "naked">><span class="purple"><<He>> casts aside the fabric.</span><<set $lefthand6 to 0>>
<<elseif $lowerstruggle is 1>><<set $lowerstruggle to 0>>You manage to keep <<him>> from stripping you of your $lowerclothes.<<set $speechstripstruggle to 1>>
<<elseif $rng gte 101>><<He>> releases <<his>> hand from your
$lowerclothes.<<set $lefthand6 to 0>>
<<elseif $rng lte 100>>
<<if $skirt is 1>>
<<if $skirtdown is 1>><<He>> lifts up your skirt,
exposing your
<<if $understate is "waist">>$underclothes.<<neutral 2>>
<<else>><span class="lewd"><<genitalsstop>></span><<neutral 5>><<set $speechgenitals to 1>>
<</if>><<set $skirtdown to 0>><<set $lowervaginaexposed to 1>><<set $loweranusexposed to 1>><<set $lowerexposed to 2>>
<<elseif $skirtdown is 0>>
<<if $lowerset is $upperset>>
<<if $upperstate is "waist">>
<<if $position is "wall">>
<<He>> tugs at your $upperclothes, tearing <<upperit>> before <span class="blue">letting go.</span><<set $lefthand6 to 0>><<neutral 1>><<set $lowerintegrity -= 10>>
<<else>>
<<He>> lifts your $upperclothes above your midriff.<<set $lowerstate to "midriff">><<set $upperstate to "midriff">><<neutral 1>>
<<if $upperstatetop is "waist">>
<<set $upperstatetop to "midriff">>
<</if>>
<</if>>
<<elseif $upperstate is "midriff">><<He>> lifts up your $upperclothes, <span class="lewd">exposing your <<breastsstop>></span><<set $lowerstate to "chest">><<set $upperstate to "chest">><<neutral 2>><<set $upperexposed to 2>><<set $speechbreasts to 1>>
<<if $upperstatetop is "midriff">>
<<set $upperstatetop to "chest">>
<</if>>
<<elseif $upperstate is "chest">><span class="purple"><<He>> pulls your $upperclothes off completely.</span><<lowerstrip>><<upperstrip>><<set $lowerstate to 0>><<set $upperstate to 0>><<uppernaked>><<lowernaked>><<set $lefthand6 to 0>><<neutral 3>><<clothesstripstat>>
<<if $upperstatetop is "chest">>
<<set $upperstatetop to 0>>
<</if>>
<</if>>
<<elseif $lowerset isnot $upperset>>
<<if $lowerstate is "waist">><<He>> pulls your $lowerclothes down to your thighs.
<<neutral 1>><<set $lowerstate to "thighs">>
<<elseif $lowerstate is "thighs">><<He>> pulls your $lowerclothes down to your knees.<<set $lowerstate to "knees">><<neutral 1>>
<<elseif $lowerstate is "knees">><<He>> pulls your $lowerclothes down to your ankles.<<set $lowerstate to "ankles">><<neutral 1>>
<<elseif $lowerstate is "ankles">><span class="purple"><<He>> completely pulls your $lowerclothes off your legs.</span><<lowerstrip>><<lowernaked>><<set $lefthand6 to 0>><<neutral 3>><<clothesstripstat>>
<</if>>
<</if>>
<</if>>
<<elseif $upperset is $lowerset>>
<<if $open is 1>>
<<if $upperstatetop is "chest">><<He>> tugs your $lowerclothes, pulling down your $upperclothes and <span class="lewd">revealing your <<breastsstop>></span><<set $upperstatetop to "midriff">><<neutral 3>><<set $upperexposed to 2>><<set $speechbreasts to 1>>
<<if $upperstate is "chest">>
<<set $upperstate to "midriff">>
<</if>>
<<if $lowerstate is "chest">>
<<set $lowerstate to "midriff">>
<</if>>
<<elseif $upperstatetop is "midriff">><<He>> tugs your $lowerclothes, pulling down your $upperclothes passed your midriff.<<set $upperstatetop to "waist">><<neutral 1>>
<<if $upperstate is "midriff">>
<<set $upperstate to "waist">>
<</if>>
<<if $lowerstate is "midriff">>
<<set $lowerstate to "waist">>
<</if>>
<<elseif $upperstatetop is "waist">><<He>> pulls your $upperclothes down to your thighs, revealing your
<<if $understate is "waist">>$underclothes<<neutral 2>>
<<else>><span class="lewd"><<genitalsstop>></span><<neutral 5>><<set $speechgenitals to 1>>
<</if>>
<<set $lowervaginaexposed to 1>><<set $loweranusexposed to 1>>
<<set $upperstatetop to "thighs">>
<<set $upperstate to "thighs">>
<<if $lowerstate is "waist">>
<<set $lowerstate to "thighs">>
<</if>>
<<elseif $upperstatetop is "thighs">><<He>> pulls your $upperclothes down to your knees.<<set $upperstatetop to "knees">><<set $upperstate to "knees">><<neutral 1>>
<<if $lowerstate is "thighs">>
<<set $lowerstate to "knees">>
<</if>>
<<elseif $upperstatetop is "knees">><<He>> pulls your $upperclothes down to your ankles.<<set $upperstatetop to "ankles">><<set $upperstate to "ankles">><<neutral 1>>
<<if $lowerstate is "knees">>
<<set $lowerstate to "ankles">>
<</if>>
<<elseif $upperstatetop is "ankles">><span class="purple"><<He>> pulls your $upperclothes off the bottom of your legs.</span><<upperstrip>><<neutral 5>><<set $upperstatetop to 0>><<set $upperstate to 0>><<uppernaked>>
<<if $lowerstate is "ankles">>
<<set $lowerstate to 0>><<lowerstrip>><<lowernaked>>
<</if>>
<</if>>
<<else>>
<<He>> tugs at your $lowerclothes, tearing <<lowerit>> before <span class="blue">letting go.</span><<set $lefthand6 to 0>><<set $lowerintegrity -= 10>><<neutral 1>>
<</if>>
<<elseif $upperset isnot $lowerset>>
<<if $lowerstate is "waist">><<He>> pulls down your $lowerclothes, exposing your
<<if $understate is "waist">>$underclothes.<<neutral 2>><<set $lowervaginaexposed to 1>><<set $loweranusexposed to 1>><<set $lowerexposed to 2>>
<<else>><span class="lewd"><<genitalsstop>></span><<neutral 5>><<set $speechgenitals to 1>>
<</if>>
<<set $lowervaginaexposed to 1>><<set $loweranusexposed to 1>><<set $lowerexposed to 2>>
<<set $lowerstate to "thighs">>
<<elseif $lowerstate is "thighs">><<He>> pulls your $lowerclothes down to your knees.<<set $lowerstate to "knees">><<neutral 1>>
<<elseif $lowerstate is "knees">><<He>> pulls your $lowerclothes down to your ankles.<<set $lowerstate to "ankles">><<neutral 1>>
<<elseif $lowerstate is "ankles">><span class="purple"><<He>> completely pulls your $lowerclothes off your legs.</span><<lowerstrip>><<lowernaked>><<set $lefthand6 to 0>><<neutral 3>><<clothesstripstat>>
<</if>>
<<else>><<He>> tugs at your $lowerclothes, tearing <<lowerit>> before <span class="blue">letting go.</span><<set $lefthand6 to 0>><<neutral 1>><<set $lowerintegrity -= 10>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand6 is "lowerclothes">>
<<if $lowerclothes is "naked">><span class="purple"><<He>> casts aside the fabric.</span><<set $righthand6 to 0>>
<<elseif $lowerstruggle is 1>><<set $lowerstruggle to 0>>You manage to keep <<him>> from stripping you of your $lowerclothes.<<set $speechstripstruggle to 1>>
<<elseif $rng gte 101>><span class="lblue"><<He>> releases <<his>> hand from your
$lowerclothes.</span><<set $righthand6 to 0>>
<<elseif $rng lte 100>>
<<if $skirt is 1>>
<<if $skirtdown is 1>><<He>> lifts up your skirt,
exposing your
<<if $understate is "waist">>$underclothes.<<neutral 2>>
<<else>><span class="lewd"><<genitalsstop>></span><<neutral 5>><<set $speechgenitals to 1>>
<</if>><<set $skirtdown to 0>><<set $lowervaginaexposed to 1>><<set $loweranusexposed to 1>><<set $lowerexposed to 2>>
<<elseif $skirtdown is 0>>
<<if $lowerset is $upperset>>
<<if $upperstate is "waist">>
<<if $position is "wall">>
<<He>> tugs at your $upperclothes, tearing <<upperit>> before <span class="blue">letting go.</span><<set $righthand6 to 0>><<neutral 1>><<set $lowerintegrity -= 10>>
<<else>>
<<He>> lifts your $upperclothes above your midriff.<<set $lowerstate to "midriff">><<set $upperstate to "midriff">><<neutral 1>>
<<if $upperstatetop is "waist">>
<<set $upperstatetop to "midriff">>
<</if>>
<</if>>
<<elseif $upperstate is "midriff">><<He>> lifts up your $upperclothes, <span class="lewd">exposing your <<breastsstop>></span><<set $lowerstate to "chest">><<set $upperstate to "chest">><<neutral 2>><<set $upperexposed to 2>><<set $speechbreasts to 1>>
<<if $upperstatetop is "midriff">>
<<set $upperstatetop to "chest">>
<</if>>
<<elseif $upperstate is "chest">><span class="purple"><<He>> pulls your $upperclothes off completely.</span><<set $lowerstate to 0>><<set $upperstate to 0>><<lowerstrip>><<upperstrip>><<uppernaked>><<lowernaked>><<set $righthand6 to 0>><<neutral 3>><<clothesstripstat>>
<<if $upperstatetop is "chest">>
<<set $upperstatetop to 0>>
<</if>>
<</if>>
<<elseif $lowerset isnot $upperset>>
<<if $lowerstate is "waist">><<He>> pulls your $lowerclothes down to your thighs.
<<neutral 1>><<set $lowerstate to "thighs">>
<<elseif $lowerstate is "thighs">><<He>> pulls your $lowerclothes down to your knees.<<set $lowerstate to "knees">><<neutral 1>>
<<elseif $lowerstate is "knees">><<He>> pulls your $lowerclothes down to your ankles.<<set $lowerstate to "ankles">><<neutral 1>>
<<elseif $lowerstate is "ankles">><span class="purple"><<He>> pulls your $lowerclothes off your legs.</span><<lowerstrip>><<lowernaked>><<set $righthand6 to 0>><<neutral 3>><<clothesstripstat>>
<</if>>
<</if>>
<</if>>
<<elseif $upperset is $lowerset>>
<<if $open is 1>>
<<if $upperstatetop is "chest">><<He>> tugs your $lowerclothes, pulling down your $upperclothes and <span class="lewd">revealing your <<breastsstop>></span><<set $upperstatetop to "midriff">><<neutral 3>><<set $upperexposed to 2>><<set $speechbreasts to 1>>
<<if $upperstate is "chest">>
<<set $upperstate to "midriff">>
<</if>>
<<if $lowerstate is "chest">>
<<set $lowerstate to "midriff">>
<</if>>
<<elseif $upperstatetop is "midriff">><<He>> tugs your $lowerclothes, pulling down your $upperclothes pass your midriff.<<set $upperstatetop to "waist">><<neutral 1>>
<<if $upperstate is "midriff">>
<<set $upperstate to "waist">>
<</if>>
<<if $lowerstate is "midriff">>
<<set $lowerstate to "waist">>
<</if>>
<<elseif $upperstatetop is "waist">><<He>> pulls your $upperclothes down to your thighs, revealing your
<<if $understate is "waist">>$underclothes<<neutral 2>>
<<else>><span class="lewd"><<genitalsstop>></span><<neutral 5>><<set $speechgenitals to 1>>
<</if>>
<<set $lowervaginaexposed to 1>><<set $loweranusexposed to 1>><<set $lowerexposed to 2>>
<<set $upperstatetop to "thighs">><<set $upperstate to "thighs">>
<<if $lowerstate is "waist">>
<<set $lowerstate to "thighs">>
<</if>>
<<elseif $upperstatetop is "thighs">><<He>> pulls your $upperclothes down to your knees.<<set $upperstatetop to "knees">><<set $upperstate to "knees">><<neutral 1>>
<<if $lowerstate is "thighs">>
<<set $lowerstate to "knees">>
<</if>>
<<elseif $upperstatetop is "knees">><<He>> pulls your $upperclothes down to your ankles.<<set $upperstatetop to "ankles">><<set $upperstate to "ankles">><<neutral 1>>
<<if $lowerstate is "knees">>
<<set $lowerstate to "ankles">>
<</if>>
<<elseif $upperstatetop is "ankles">><span class="purple"><<He>> pulls your $upperclothes off the bottom of your legs.</span><<upperstrip>><<neutral 5>><<set $upperstatetop to 0>><<set $upperstate to 0>><<uppernaked>>
<<if $lowerstate is "ankles">>
<<set $lowerstate to 0>><<lowerstrip>><<lowernaked>>
<</if>>
<</if>>
<<else>>
<<He>> tugs at your $lowerclothes, tearing <<lowerit>> before <span class="blue">letting go.</span><<set $righthand6 to 0>><<set $lowerintegrity -= 10>><<neutral 1>>
<</if>>
<<elseif $upperset isnot $lowerset>>
<<if $lowerstate is "waist">><<He>> pulls down your $lowerclothes, exposing your
<<if $understate is "waist">>$underclothes.<<neutral 2>><<set $lowervaginaexposed to 1>><<set $loweranusexposed to 1>>
<<else>><span class="lewd"><<genitalsstop>></span><<neutral 5>><<set $speechgenitals to 1>>
<</if>>
<<set $lowervaginaexposed to 1>><<set $loweranusexposed to 1>><<set $lowerexposed to 2>>
<<set $lowerstate to "thighs">>
<<elseif $lowerstate is "thighs">><<He>> pulls your $lowerclothes down to your knees.<<set $lowerstate to "knees">><<neutral 1>>
<<elseif $lowerstate is "knees">><<He>> pulls your $lowerclothes down to your ankles.<<set $lowerstate to "ankles">><<neutral 1>>
<<elseif $lowerstate is "ankles">><span class="purple"><<He>> pulls your $lowerclothes off your legs.</span><<lowerstrip>><<lowernaked>><<set $righthand6 to 0>><<neutral 3>><<clothesstripstat>>
<</if>>
<<else>><<He>> tugs at your $lowerclothes, tearing <<lowerit>> before <span class="blue">letting go.</span><<set $righthand6 to 0>><<neutral 1>><<set $lowerintegrity -= 10>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand6 is "upperclothes">>
<<if $upperclothes is "naked">><span class="purple"><<He>> casts aside the fabric.</span><<set $lefthand6 to 0>>
<<elseif $upperstruggle is 1>><<set $upperstruggle to 0>>You manage to keep <<him>> from stripping you of your $upperclothes.<<set $speechstripstruggle to 1>>
<<elseif $rng gte 101>><span class="lblue"><<He>> releases <<his>> hand from your $upperclothes.</span><<set $lefthand6 to 0>>
<<elseif $rng lte 100>>
<<if $upperset isnot $lowerset>>
<<if $open is 1>>
<<if $upperstatetop is "chest">><<He>> pulls down your $upperclothes, <span class="lewd">revealing your <<breastsstop>></span><<set $upperstatetop to "midriff">><<neutral 3>><<set $upperexposed to 2>><<set $speechbreasts to 1>>
<<if $upperstate is "chest">>
<<set $upperstate to "midriff">>
<</if>>
<<elseif $upperstatetop is "midriff">><<He>> pulls your $upperclothes down past your midriff.<<set $upperstatetop to "waist">><<neutral 1>>
<<if $upperstate is "midriff">>
<<set $upperstate to "waist">>
<</if>>
<<elseif $upperstatetop is "waist">><<He>> pulls your $upperclothes down to your thighs.
<<set $upperstatetop to "thighs">>
<<set $upperstate to "thighs">>
<<elseif $upperstatetop is "thighs">><<He>> pulls your $upperclothes down to your knees.<<set $upperstatetop to "knees">><<set $upperstate to "knees">><<neutral 1>>
<<elseif $upperstatetop is "knees">><<He>> pulls your $upperclothes down to your ankles.<<set $upperstatetop to "ankles">><<set $upperstate to "ankles">><<neutral 1>>
<<elseif $upperstatetop is "ankles">><span class="purple"><<He>> pulls your $upperclothes off the bottom of your legs.</span><<upperstrip>><<neutral 5>><<set $upperstatetop to 0>><<set $upperstate to 0>><<uppernaked>><<set $lefthand6 to 0>>
<</if>>
<<elseif $open is 0>>
<<if $position is "wall">>
<<He>> tugs at your $upperclothes, tearing <<upperit>> before <span class="blue">letting go.</span><<set $lefthand6 to 0>><<set $upperintegrity -= 10>><<neutral 1>>
<<elseif $position isnot "wall">>
<<if $upperstate is "waist">><<He>> lifts up your $upperclothes, exposing your midriff.<<set $upperstate to "midriff">><<neutral 1>>
<<elseif $upperstate is "midriff">><<He>> lifts up your $upperclothes, <span class="lewd">exposing your <<breastsstop>></span><<set $upperstate to "chest">><<neutral 2>><<set $upperexposed to 2>><<set $speechbreasts to 1>>
<<elseif $upperstate is "chest">><span class="purple"><<He>> removes your $upperclothes completely.</span><<upperstrip>><<uppernaked>><<set $lefthand6 to 0>><<neutral 3>><<clothesstripstat>>
<</if>>
<</if>>
<</if>>
<<elseif $upperset is $lowerset>>
<<if $open is 1>>
<<if $lowerstate is $upperstatetop and $lowerstate is $upperstate and $skirt is 1>>
<<if $position is "wall">>
<<He>> tugs at your $upperclothes, tearing <<upperit>> before <span class="blue">letting go.</span><<set $lefthand6 to 0>><<set $upperintegrity -= 10>><<neutral 1>>
<<elseif $position isnot "wall">>
<<if $upperstate is "waist">><<He>> pulls your bundled $upperclothes up past your midriff.<<set $upperstate to "midriff">><<neutral 1>>
<<set $lowerstate to "midriff">>
<<set $upperstatetop to "midriff">>
<<elseif $upperstate is "midriff">><<He>> pulls your bundled $upperclothes up past your <<breastsstop>><<set $upperstate to "chest">><<neutral 2>><<set $upperexposed to 2>><<set $speechbreasts to 1>>
<<set $lowerstate to "chest">>
<<set $upperstatetop to "chest">>
<<elseif $upperstate is "chest">><span class="purple"><<He>> pulls your $upperclothes off your body.</span><<upperstrip>><<uppernaked>><<set $lefthand6 to 0>><<neutral 3>><<clothesstripstat>>
<</if>>
<</if>>
<<else>>
<<if $upperstatetop is "chest">><<He>> pulls down the top of your $upperclothes, <span class="lewd">revealing your <<breastsstop>></span><<set $upperstatetop to "midriff">><<neutral 2>><<set $upperexposed to 2>><<set $speechbreasts to 1>>
<<if $upperstate is "chest">>
<<set $upperstate to "midriff">>
<</if>>
<<if $lowerstate is "chest">>
<<set $lowerstate to "midriff">>
<</if>>
<<elseif $upperstatetop is "midriff">><<He>> pulls your $upperclothes down past your midriff.<<set $upperstatetop to "waist">><<neutral 1>>
<<if $upperstate is "midriff">>
<<set $upperstate to "waist">>
<</if>>
<<if $lowerstate is "midriff">>
<<set $lowerstate to "waist">>
<</if>>
<<elseif $upperstatetop is "waist">><<He>> pulls your $upperclothes down to your thighs, revealing your
<<if $understate is "waist">>$underclothes<<neutral 2>>
<<else>><span class="lewd"><<genitalsstop>></span><<neutral 5>><<set $speechgenitals to 1>>
<</if>>
<<set $lowervaginaexposed to 1>><<set $loweranusexposed to 1>><<set $lowerexposed to 2>>
<<set $upperstatetop to "thighs">>
<<set $upperstate to "thighs">>
<<if $lowerstate is "waist">>
<<set $lowerstate to "thighs">>
<</if>>
<<elseif $upperstatetop is "thighs">><<He>> pulls your $upperclothes down to your knees.<<set $upperstatetop to "knees">><<set $upperstate to "knees">><<neutral 1>>
<<if $lowerstate is "thighs">>
<<set $lowerstate to "knees">>
<</if>>
<<elseif $upperstatetop is "knees">><<He>> pulls your $upperclothes down to your ankles.<<set $upperstatetop to "ankles">><<set $upperstate to "ankles">><<neutral 1>>
<<if $lowerstate is "knees">>
<<set $lowerstate to "ankles">>
<</if>>
<<elseif $upperstatetop is "ankles">><span class="purple"><<He>> pulls your $upperclothes off the bottom of your legs.</span><<upperstrip>><<neutral 5>><<set $upperstatetop to 0>><<set $upperstate to 0>><<uppernaked>><<set $lefthand6 to 0>>
<<if $lowerstate is "ankles">>
<<set $lowerstate to 0>><<lowerstrip>><<lowernaked>>
<</if>>
<</if>>
<</if>>
<<else>><<He>> tugs at your $upperclothes, tearing <<upperit>> before <span class="blue">letting go.</span><<set $lefthand6 to 0>><<set $upperintegrity -= 10>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random (1, 100)>>
<<if $righthand6 is "upperclothes">>
<<if $upperclothes is "naked">><span class="purple"><<He>> casts aside the fabric.</span><<set $righthand6 to 0>>
<<elseif $upperstruggle is 1>><<set $upperstruggle to 0>>You manage to keep <<him>> from stripping you of your $upperclothes.<<set $speechstripstruggle to 1>>
<<elseif $rng gte 101>><span class="lblue"><<He>> releases <<his>> hand from your $upperclothes.</span><<set $righthand6 to 0>>
<<elseif $rng lte 100>>
<<if $upperset isnot $lowerset>>
<<if $open is 1>>
<<if $upperstatetop is "chest">><<He>> pulls down your $upperclothes, <span class="lewd">revealing your <<breastsstop>></span><<set $upperstatetop to "midriff">><<neutral 3>><<set $upperexposed to 2>><<set $speechbreasts to 1>>
<<if $upperstate is "chest">>
<<set $upperstate to "midriff">>
<</if>>
<<elseif $upperstatetop is "midriff">><<He>> pulls your $upperclothes down past your midriff.<<set $upperstatetop to "waist">><<neutral 1>>
<<if $upperstate is "midriff">>
<<set $upperstate to "waist">>
<</if>>
<<elseif $upperstatetop is "waist">><<He>> pulls your $upperclothes down to your thighs.
<<set $upperstatetop to "thighs">>
<<set $upperstate to "thighs">>
<<elseif $upperstatetop is "thighs">><<He>> pulls your $upperclothes down to your knees.<<set $upperstatetop to "knees">><<set $upperstate to "knees">><<neutral 1>>
<<elseif $upperstatetop is "knees">><<He>> pulls your $upperclothes down to your ankles.<<set $upperstatetop to "ankles">><<set $upperstate to "ankles">><<neutral 1>>
<<elseif $upperstatetop is "ankles">><span class="purple"><<He>> pulls your $upperclothes off the bottom of your legs.</span><<upperstrip>><<neutral 5>><<set $upperstatetop to 0>><<set $upperstate to 0>><<uppernaked>><<set $righthand6 to 0>>
<</if>>
<<elseif $open is 0>>
<<if $position is "wall">>
<<He>> tugs at your $upperclothes, tearing <<upperit>> before <span class="blue">letting go.</span><<set $righthand6 to 0>><<set $upperintegrity -= 10>><<neutral 1>>
<<elseif $position isnot "wall">>
<<if $upperstate is "waist">><<He>> lifts up your $upperclothes, exposing your midriff.<<set $upperstate to "midriff">><<neutral 1>>
<<elseif $upperstate is "midriff">><<He>> lifts up your $upperclothes, <span class="lewd">exposing your <<breastsstop>></span><<set $upperstate to "chest">><<neutral 2>><<set $upperexposed to 2>><<set $speechbreasts to 1>>
<<elseif $upperstate is "chest">><span class="purple"><<He>> removes your $upperclothes completely.</span><<upperstrip>><<uppernaked>><<set $righthand6 to 0>><<neutral 3>><<clothesstripstat>>
<</if>>
<</if>>
<</if>>
<<elseif $upperset is $lowerset>>
<<if $open is 1>>
<<if $lowerstate is $upperstatetop and $lowerstate is $upperstate and $skirt is 1>>
<<if $position is "wall">>
<<He>> tugs at your $upperclothes, tearing <<upperit>> before <span class="blue">letting go.</span><<set $righthand6 to 0>><<set $upperintegrity -= 10>><<neutral 1>>
<<elseif $position isnot "wall">>
<<if $upperstate is "waist">><<He>> pulls your bundled $upperclothes up past your midriff.<<set $upperstate to "midriff">><<neutral 1>>
<<set $lowerstate to "midriff">>
<<set $upperstatetop to "midriff">>
<<elseif $upperstate is "midriff">><<He>> pulls your bundled $upperclothes up past your <<breastsstop>><<set $upperstate to "chest">><<neutral 2>><<set $upperexposed to 2>><<set $speechbreasts to 1>>
<<set $lowerstate to "chest">>
<<set $upperstatetop to "chest">>
<<elseif $upperstate is "chest">><span class="purple"><<He>> pulls your $upperclothes off your body.</span><<upperstrip>><<uppernaked>><<set $righthand6 to 0>><<neutral 3>><<clothesstripstat>>
<</if>>
<</if>>
<<else>>
<<if $upperstatetop is "chest">><<He>> pulls down the top of your $upperclothes, <span class="lewd">revealing your <<breastsstop>></span><<set $upperstatetop to "midriff">><<set $upperexposed to 2>><<neutral 2>><<set $speechbreasts to 1>>
<<if $upperstate is "chest">>
<<set $upperstate to "midriff">>
<</if>>
<<if $lowerstate is "chest">>
<<set $lowerstate to "midriff">>
<</if>>
<<elseif $upperstatetop is "midriff">><<He>> pulls your $upperclothes down past your midriff.<<set $upperstatetop to "waist">><<neutral 1>>
<<if $upperstate is "midriff">>
<<set $upperstate to "waist">>
<</if>>
<<if $lowerstate is "midriff">>
<<set $lowerstate to "waist">>
<</if>>
<<elseif $upperstatetop is "waist">><<He>> pulls your $upperclothes down to your thighs, revealing your
<<if $understate is "waist">>$underclothes<<neutral 2>>
<<else>><span class="lewd"><<genitalsstop>></span><<neutral 5>><<set $speechgenitals to 1>>
<</if>>
<<set $lowervaginaexposed to 1>><<set $loweranusexposed to 1>><<set $lowerexposed to 2>>
<<set $upperstatetop to "thighs">>
<<set $upperstate to "thighs">>
<<if $lowerstate is "waist">>
<<set $lowerstate to "thighs">>
<</if>>
<<elseif $upperstatetop is "thighs">><<He>> pulls your $upperclothes down to your knees.<<set $upperstatetop to "knees">><<set $upperstate to "knees">><<neutral 1>>
<<if $lowerstate is "thighs">>
<<set $lowerstate to "knees">>
<</if>>
<<elseif $upperstatetop is "knees">><<He>> pulls your $upperclothes down to your ankles.<<set $upperstatetop to "ankles">><<set $upperstate to "ankles">><<neutral 1>>
<<if $lowerstate is "knees">>
<<set $lowerstate to "ankles">>
<</if>>
<<elseif $upperstatetop is "ankles">><span class="purple"><<He>> pulls your $upperclothes off the bottom of your legs.</span><<upperstrip>><<neutral 5>><<set $upperstatetop to 0>><<set $upperstate to 0>><<uppernaked>><<set $righthand6 to 0>>
<<if $lowerstate is "ankles">>
<<set $lowerstate to 0>><<lowerstrip>><<lowernaked>>
<</if>>
<</if>>
<</if>>
<<else>><<He>> tugs at your $upperclothes, tearing <<upperit>> before <span class="blue">letting go.</span><<set $righthand6 to 0>><<set $upperintegrity -= 10>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $lefthand6 is 0>>
<<if $enemyanger + $rng lte 20>>
<<if $lowerclothes isnot "naked">><span class="purple"><<He>> grasps your $lowerclothes.</span><<set $lefthand6 to "lowerclothes">><<neutral 1>>
<<elseif $vaginaexist is 1>>
<<He>> <<strokes>> your inner thigh and brushes <<his>> fingers against your clit.<<neutral 10>><<set $speechclit to 1>>
<<elseif $penisexist is 1>>
<<He>> <<strokes>> your inner thigh and brushes <<his>> fingers against your <<glansstop>><<neutral 10>><<set $speechglans to 1>>
<</if>>
<<elseif $enemyanger + $rng lte 30>>
<<if $position is "wall">>
<<if $lowerclothes isnot "naked">><span class="purple"><<He>> grasps your $lowerclothes.</span><<set $lefthand6 to "lowerclothes">><<neutral 1>>
<<elseif $vaginaexist is 1>>
<<He>> <<strokes>> your inner thigh and brushes <<his>> fingers against your clit.<<neutral 10>><<set $speechclit to 1>>
<<elseif $penisexist is 1>>
<<He>> <<strokes>> your inner thigh and brushes <<his>> fingers against your <<glansstop>><<neutral 10>><<set $speechglans to 1>>
<</if>>
<<else>>
<<if $upperclothes isnot "naked">><span class="purple"><<He>> grasps your $upperclothes.</span><<set $lefthand6 to "upperclothes">><<neutral 1>>
<<else>><<He>> <<strokes>> your chest, <<his>> fingers lingering around your nipple.<<neutral 4>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 35>>
<<if $skirt is 1>>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $lefthand6 to "underclothes">><<neutral 1>>
<<elseif $underanusexposed is 1>>
<<if $loweranusexposed is 1>>
<<if $anususe is 0 and $analdisable is "f">><span class="purple"><<He>> presses <<his>> left hand against your <<bottomstop>></span><<set $lefthand6 to "anusentrance">><<set $anususe to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<<elseif $lowerclothes isnot "waist">>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $lefthand6 to "underclothes">><<neutral 1>>
<<elseif $underanusexposed is 1>>
<<if $loweranusexposed is 1>>
<<if $anususe is 0 and $analdisable is "f">><span class="purple"><<He>> presses <<his>> left hand against your <<bottomstop>></span><<set $lefthand6 to "anusentrance">><<set $anususe to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 40>>
<<if $skirt is 1>>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $lefthand6 to "underclothes">><<neutral 1>>
<<elseif $undervaginaexposed is 1>>
<<if $lowervaginaexposed is 1>>
<<if $vaginaexist is 1>>
<<if $vaginause is 0>><span class="purple"><<He>> presses <<his>> left hand against your <<pussycomma>> resting a finger on your entrance.</span><<set $lefthand6 to "vaginaentrance">><<set $vaginause to 1>><<neutral 1>>
<</if>>
<<elseif $penisexist is 1>>
<<if $penisuse is 0>><span class="purple"><<He>> presses <<his>> left hand against your <<penisstop>></span><<set $lefthand6 to "penisentrance">><<set $penisuse to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $lowerclothes isnot "waist">>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $lefthand6 to "underclothes">><<neutral 1>>
<<elseif $undervaginaexposed is 1>>
<<if $lowervaginaexposed is 1>>
<<if $vaginaexist is 1>>
<<if $vaginause is 0>>
<span class="purple"><<He>> presses <<his>> left hand against your <<pussycomma>> resting a finger on your entrance.</span><<set $lefthand6 to "vaginaentrance">><<set $vaginause to 1>><<neutral 1>>
<</if>>
<<elseif $penisexist is 1>>
<<if $penisuse is 0>><span class="purple"><<He>> presses <<his>> left hand against your <<penisstop>></span><<set $lefthand6 to "penisentrance">><<set $penisuse to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 45>>
<<if $position is "wall">>
<<He>> leans against the wall.
<<else>>
<<He>> caresses your tummy.<<neutral 1>>
<</if>>
<<elseif $enemyanger + $rng lte 50>>
<<if $position is "wall">>
<<He>> grips your thigh and pulls, but you're stuck firm.<<neutral 1>>
<<else>>
<<He>> <<strokes>> your hair.<<neutral 1>>
<</if>>
<<elseif $enemyanger + $rng lte 60>>
<<if $position is "wall">>
<<He>> pulls your leg, but you're stuck firm.<<neutral 1>>
<<elseif $uppertype isnot "naked" and $upperstate isnot "chest" and $upperstatetop is "chest">>
<<He>> <<strokes>> your <<breasts>> through your $upperclothes.<<neutral 2>>
<<else>>
<<He>> <<strokes>> your exposed <<breastsstop>><<neutral 4>>
<</if>>
<<elseif $enemyanger + $rng lte 80>><<set $speechbottom to 1>>
<<if $lowerstate is "waist" and $skirt is 0>>
<<He>> fondles your <<bottom>> through your $lowerclothes.<<neutral 2>>
<<elseif $understate is "waist">>
<<He>> fondles your <<bottom>> through your $underclothes.<<neutral 2>>
<<else>>
<<He>> gropes and squeezes your exposed <<bottomstop>><<neutral 4>>
<</if>>
<<elseif $enemyanger + $rng lte 100>>
<<if $penisexist is 1>>
<<if $lowerstate is "waist" and $skirt is 0>>
<<He>> fondles and <<strokes>> your <<penis>> through your $lowerclothes.<<neutral 5>>
<<elseif $understate is "waist">>
<<He>> fondles and <<strokes>> your <<penis>> through your $underclothes.<<neutral 5>>
<<elseif $penisuse is 0>>
<<He>> fondles and <<strokes>> your exposed <<penisstop>><<neutral 10>>
<<else>>
<<He>> fondles and <<strokes>> your <<testiclesstop>><<neutral 10>>
<</if>>
<<elseif $vaginaexist is 1>>
<<if $lowerstate is "waist" and $skirt is 0>>
<<He>> fondles and <<strokes>> your labia through your $lowerclothes.<<neutral 5>>
<<elseif $understate is "waist">>
<<He>> fondles and <<strokes>> your labia through your $underclothes.<<neutral 5>>
<<else>>
<<He>> fondles and <<strokes>> your exposed <<pussystop>><<neutral 10>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 110>>
<<if $lowerclothes isnot "naked">><span class="purple"><<He>> grasps your $lowerclothes.</span><<set $lefthand6 to "lowerclothes">><<neutral 1>>
<<elseif $vaginaexist is 1>><<He>> pinches your clitoris.<<neutral 15>><<bruise vagina>><<set $speechclit to 1>>
<<elseif $penisexist is 1>>
<<if $penisuse is 0>>
<<He>> pinches your glans.<<neutral 15>><<bruise penis>><<set $speechglans to 1>>
<<else>>
<<He>> pinches your shaft.<<neutral 10>><<bruise penis>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 120>>
<<if $position is "wall">>
<<He>> smacks your thigh.<<violence 1>><<bruise thigh>><<hitstat>>
<<else>>
<<if $upperclothes isnot "naked">><span class="purple"><<He>> grasps your $upperclothes.</span><<set $lefthand6 to "upperclothes">><<neutral 1>>
<<else>><span class="purple"><<He>> grabs your throat.</span><<violence 2>><<set $lefthand6 to "throat">>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 125>>
<<if $skirt is 1>>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $lefthand6 to "underclothes">><<neutral 1>>
<<elseif $underanusexposed is 1>>
<<if $loweranusexposed is 1>>
<<if $anususe is 0 and $analdisable is "f">><span class="purple"><<He>> presses <<his>> left hand against your <<bottomstop>></span><<set $lefthand6 to "anusentrance">><<set $anususe to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<<elseif $lowerclothes isnot "waist">>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $lefthand6 to "underclothes">><<neutral 1>>
<<elseif $underanusexposed is 1>>
<<if $loweranusexposed is 1>>
<<if $anususe is 0 and $analdisable is "f">><span class="purple"><<He>> presses <<his>> left hand against your <<bottomstop>></span><<set $lefthand6 to "anusentrance">><<set $anususe to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 130>>
<<if $skirt is 1>>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $lefthand6 to "underclothes">><<neutral 1>>
<<elseif $undervaginaexposed is 1>>
<<if $lowervaginaexposed is 1>>
<<if $vaginaexist is 1>>
<<if $vaginause is 0>><span class="purple"><<He>> presses <<his>> left hand against your <<pussycomma>> <<his>> finger resting on your entrance.</span><<set $lefthand6 to "vaginaentrance">><<set $vaginause to 1>><<neutral 1>>
<</if>>
<<elseif $penisexist is 1>>
<<if $penisuse is 0>><span class="purple"><<He>> presses <<his>> left hand against your <<penisstop>></span><<set $lefthand6 to "penisentrance">><<set $penisuse to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $lowerclothes isnot "waist">>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $lefthand6 to "underclothes">><<neutral 1>>
<<elseif $undervaginaexposed is 1>>
<<if $lowervaginaexposed is 1>>
<<if $vaginaexist is 1>>
<<if $vaginause is 0>>
<span class="purple"><<He>> presses <<his>> left hand against your <<pussycomma>> <<his>> finger resting on your entrance.</span><<set $lefthand6 to "vaginaentrance">><<set $vaginause to 1>><<neutral 1>>
<</if>>
<<elseif $penisexist is 1>>
<<if $penisuse is 0>><span class="purple"><<He>> presses <<his>> left hand against your <<penisstop>></span><<set $lefthand6 to "penisentrance">><<set $penisuse to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 140>>
<<if $position is "wall">>
<<He>> smacks your <<bottomstop>><<violence 1>><<bruise bottom>><<hitstat>>
<<else>>
<<He>> seizes your hair with <<his>> left hand.<<set $lefthand6 to "hair">><<violence 2>><<set $speechhair to 1>>
<</if>>
<<elseif $enemyanger + $rng lte 160 and $lefthand6 isnot "arms" and $righthand6 isnot "arms" and $leftarm isnot "bound" and $rightarm isnot "bound">>
<span class="purple"><<He>> pins down your arms.</span><<set $lefthand6 to "arms">><<set $leftarm to "grappled">><<set $rightarm to "grappled">><<disablearms>><<violence 2>><<bruise leftarm>><<bruise rightarm>><<set $speecharms to 1>>
<<if $vaginause is "cover">><<set $vaginause to 0>>
<</if>>
<<if $vaginause is "cover">><<set $vaginause to 0>>
<</if>>
<<if $anususe is "cover">><<set $anususe to 0>>
<</if>>
<<if $anususe is "cover">><<set $anususe to 0>>
<</if>>
<<if $penisuse is "cover">><<set $penisuse to 0>>
<</if>>
<<if $penisuse is "cover">><<set $penisuse to 0>>
<</if>>
<<elseif $enemyanger + $rng lte 160>><<He>> digs <<his>> nails into your <<bottom>> while groping, giving no heed to you comfort.<<violence 10>><<bruise bottom>><<hitstat>><<set $speechspank to 1>>
<<elseif $enemyanger + $rng lte 175>><<He>> slaps your <<bottomstop>><<violence 10>><<bruise bottom>><<hitstat>><<set $speechspank to 1>>
<<elseif $enemyanger + $rng lte 180>><<He>> smacks your thighs.<<violence 10>><<bruise thigh>><<hitstat>><<set $speechbeat to 1>>
<<elseif $enemyanger + $rng lte 185>>
<<if $position is "wall">>
<<He>> punches your thigh.<<bruise thigh>><<hitstat>><<violence 10>><<set $speechbeat to 1>>
<<else>>
<<He>> punches your tummy.<<violence 20>><<bruise tummy>><<hitstat>><<set $speechbeat to 1>>
<</if>>
<<elseif $enemyanger + $rng lte 190>>
<<if $position is "wall">>
<<He>> slaps your <<bottomstop>><<violence 20>><<bruise bottom>><<hitstat>><<set $speechbeat to 1>>
<<else>>
<<He>> slaps your <<breastsstop>><<violence 20>><<bruise chest>><<hitstat>><<set $speechbeat to 1>>
<</if>>
<<elseif $enemyanger + $rng gte 191>>
<<if $position is "wall">>
<<if $penisexist is 1>>
<<He>> scratches your helpless <<bottomstop>><<violence 20>><<bruise bottom>><<hitstat>><<set $speechbeat to 1>>
<<elseif $vaginaexist is 1>>
<<He>> scratches your helpless <<bottomstop>><<violence 20>><<bruise bottom>><<hitstat>><<set $speechbeat to 1>>
<</if>>
<<else>>
<<set $rng to random(1, 100)>>
<<if $rng gte 81>>
<<He>> punches your nose.<<violence 20>><<bruise face>><<hitstat>><<set $speechbeat to 1>>
<<elseif $rng gte 61>>
<<He>> punches the back of your neck.<<violence 20>><<bruise neck>><<hitstat>><<set $speechbeat to 1>>
<<elseif $rng gte 41>>
<<He>> punches your cheek.<<violence 20>><<bruise face>><<hitstat>><<set $speechbeat to 1>>
<<elseif $rng gte 21>>
<<He>> punches your jaw.<<violence 20>><<bruise face>><<hitstat>><<set $speechbeat to 1>>
<<else>>
<<He>> jabs the front of your neck.<<violence 20>><<bruise neck>><<hitstat>><<set $speechbeat to 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $righthand6 is 0>>
<<if $enemyanger + $rng lte 20>>
<<if $lowerclothes isnot "naked">><span class="purple"><<He>> grasps your $lowerclothes.</span><<set $righthand6 to "lowerclothes">><<neutral 1>>
<<elseif $vaginaexist is 1>><<He>> <<strokes>> your pubic mound and teases your clit.<<neutral 10>><<set $speechclit to 1>>
<<elseif $penisexist is 1>>
<<He>> <<strokes>> your <<testicles>> and teases your glans.<<neutral 10>><<set $speechglans to 1>>
<</if>>
<<elseif $enemyanger + $rng lte 30>>
<<if $position is "wall">>
<<if $lowerclothes isnot "naked">><span class="purple"><<He>> grasps your $lowerclothes.</span><<set $righthand6 to "lowerclothes">><<neutral 1>>
<<elseif $vaginaexist is 1>><<He>> runs <<his>> hand up your thigh and <<strokes>> your clit.<<neutral 10>><<set $speechclit to 1>>
<<elseif $penisexist is 1>><<He>> runs <<his>> hand up your thigh and <<strokes>> your <<glansstop>><<neutral 10>><<set $speechglans to 1>>
<</if>>
<<else>>
<<if $upperclothes isnot "naked">><span class="purple"><<He>> grasps your $upperclothes.</span><<set $righthand6 to "upperclothes">><<neutral 1>>
<<else>><<He>> <<strokes>> your chest and teases your nipple.<<neutral 4>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 35>>
<<if $skirt is 1>>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $righthand6 to "underclothes">><<neutral 1>>
<<elseif $underanusexposed is 1>>
<<if $loweranusexposed is 1>>
<<if $anususe is 0 and $analdisable is "f">><span class="purple"><<He>> presses <<his>> right hand against your <<bottomstop>></span><<set $righthand6 to "anusentrance">><<set $anususe to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<<elseif $lowerclothes isnot "waist">>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $righthand6 to "underclothes">><<neutral 1>>
<<elseif $underanusexposed is 1>>
<<if $loweranusexposed is 1>>
<<if $anususe is 0 and $analdisable is "f">><span class="purple"><<He>> presses <<his>> right hand against your <<bottomstop>></span><<set $righthand6 to "anusentrance">><<set $anususe to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 40>>
<<if $skirt is 1>>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $righthand6 to "underclothes">><<neutral 1>>
<<elseif $undervaginaexposed is 1>>
<<if $lowervaginaexposed is 1>>
<<if $vaginaexist is 1>>
<<if $vaginause is 0>>
<span class="purple"><<He>> presses <<his>> right hand against your <<pussycomma>> resting a finger on your entrance.</span><<set $righthand6 to "vaginaentrance">><<set $vaginause to 1>><<neutral 1>>
<</if>>
<<elseif $penisexist is 1>>
<<if $penisuse is 0>><span class="purple"><<He>> presses <<his>> right hand against your <<penisstop>></span><<set $righthand6 to "penisentrance">><<set $penisuse to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $lowerclothes isnot "waist">>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $righthand6 to "underclothes">><<neutral 1>>
<<elseif $undervaginaexposed is 1>>
<<if $lowervaginaexposed is 1>>
<<if $vaginaexist is 1>>
<<if $vaginause is 0>>
<span class="purple"><<He>> presses <<his>> right hand against your <<pussycomma>> resting a finger above your entrance.</span><<set $righthand6 to "vaginaentrance">><<set $vaginause to 1>><<neutral 1>>
<</if>>
<<elseif $penisexist is 1>>
<<if $penisuse is 0>>
<span class="purple"><<He>> presses <<his>> right hand against your <<penisstop>></span><<set $righthand6 to "penisentrance">><<set $penisuse to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 45>>
<<if $position is "wall">>
<<He>> rests <<his>> right hand against the wall.
<<else>>
<<He>> <<strokes>> your tummy with <<his>> right hand.<<neutral 1>>
<</if>>
<<elseif $enemyanger + $rng lte 50>>
<<if $position is "wall">>
<<He>> pushes your <<bottomcomma>> making sure you're stuck firm.<<neutral 1>>
<<else>>
<<He>> <<strokes>> your cheek.<<neutral 1>>
<</if>>
<<elseif $enemyanger + $rng lte 60>>
<<if $position is "wall">>
<<He>> tugs on your leg, but you're stuck firm.<<neutral 1>>
<<elseif $uppertype isnot "naked" and $upperstate isnot "chest" and $upperstatetop is "chest">>
<<He>> gropes your <<breasts>> through your $upperclothes.<<neutral 2>>
<<else>>
<<He>> gropes your exposed <<breastsstop>><<neutral 4>>
<</if>>
<<elseif $enemyanger + $rng lte 80>><<set $speechbottom to 1>>
<<if $lowerstate is "waist" and $skirt is 0>>
<<He>> gropes your <<bottom>> through your $lowerclothes.<<neutral 2>>
<<elseif $understate is "waist">>
<<He>> gropes your <<bottom>> through your $underclothes.<<neutral 2>>
<<else>>
<<He>> fondles and <<strokes>> your exposed <<bottomstop>><<neutral 4>>
<</if>>
<<elseif $enemyanger + $rng lte 100>>
<<if $penisexist is 1>>
<<if $lowerstate is "waist" and $skirt is 0>>
<<He>> gropes and <<strokes>> your <<penis>> through your $lowerclothes.<<neutral 5>>
<<elseif $understate is "waist">>
<<He>> gropes and <<strokes>> your <<penis>> through your $underclothes.<<neutral 5>>
<<elseif $penisuse is 0>>
<<He>> gropes and <<strokes>> your exposed <<penisstop>><<neutral 10>>
<<else>>
<<He>> cups and <<strokes>> your <<testiclesstop>><<neutral 10>>
<</if>>
<<elseif $vaginaexist is 1>>
<<if $lowerstate is "waist" and $skirt is 0>>
<<He>> gropes and <<strokes>> your labia through your $lowerclothes.<<neutral 5>>
<<elseif $understate is "waist">>
<<He>> gropes and <<strokes>> your labia through your $underclothes.<<neutral 5>>
<<else>>
<<He>> gropes and <<strokes>> your exposed <<pussystop>><<neutral 10>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 110>>
<<if $lowerclothes isnot "naked">><span class="purple"><<He>> grasps your $lowerclothes.</span><<set $righthand6 to "lowerclothes">><<neutral 1>>
<<elseif $vaginaexist is 1>>He pinches your clitoris.<<neutral 15>><<bruise vagina>><<set $speechclit to 1>>
<<elseif $penisexist is 1>>
<<if $penisuse is 0>>
<<He>> pinches your glans.<<neutral 15>><<bruise penis>><<set $speechglans to 1>>
<<else>>
<<He>> pinches your shaft.<<neutral 10>><<bruise penis>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 120>>
<<if $position is "wall">>
<<He>> squeezes your thigh.<<violence 1>><<hitstat>><<bruise thigh>>
<<else>>
<<if $upperclothes isnot "naked">><span class="purple"><<He>> grasps your $upperclothes.</span><<set $righthand6 to "upperclothes">><<neutral 1>>
<<else>><span class="purple"><<He>> grabs your throat.</span><<violence 2>><<set $righthand6 to "throat">>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 125>>
<<if $skirt is 1>>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $righthand6 to "underclothes">><<neutral 1>>
<<elseif $underanusexposed is 1>>
<<if $loweranusexposed is 1>>
<<if $anususe is 0 and $analdisable is "f">><span class="purple"><<He>> presses <<his>> right hand against your <<bottomstop>></span><<set $righthand6 to "anusentrance">><<set $anususe to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<<elseif $lowerclothes isnot "waist">>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $righthand6 to "underclothes">><<neutral 1>>
<<elseif $underanusexposed is 1>>
<<if $loweranusexposed is 1>>
<<if $anususe is 0 and $analdisable is "f">><span class="purple"><<He>> presses <<his>> right hand against your <<bottomstop>></span><<set $righthand6 to "anusentrance">><<set $anususe to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 130>>
<<if $skirt is 1>>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $righthand6 to "underclothes">><<neutral 1>>
<<elseif $undervaginaexposed is 1>>
<<if $lowervaginaexposed is 1>>
<<if $vaginaexist is 1>>
<<if $vaginause is 0>>
<span class="purple"><<He>> presses <<his>> right hand against your <<pussycomma>> <<his>> finger resting on your entrance.</span><<set $righthand6 to "vaginaentrance">><<set $vaginause to 1>><<neutral 1>>
<</if>>
<<elseif $penisexist is 1>>
<<if $penisuse is 0>><span class="purple"><<He>> presses <<his>> right hand against your <<penisstop>></span><<set $righthand6 to "penisentrance">><<set $penisuse to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $lowerclothes isnot "waist">>
<<if $underclothes isnot "naked">><span class="purple"><<He>> grasps your $underclothes.</span><<set $righthand6 to "underclothes">><<neutral 1>>
<<elseif $undervaginaexposed is 1>>
<<if $lowervaginaexposed is 1>>
<<if $vaginaexist is 1>>
<<if $vaginause is 0>>
<span class="purple"><<He>> presses <<his>> right hand against your <<pussycomma>> <<his>> finger resting on your entrance.</span><<set $righthand6 to "vaginaentrance">><<set $vaginause to 1>><<neutral 1>>
<</if>>
<<elseif $penisexist is 1>>
<<if $penisuse is 0>>
<span class="purple"><<He>> presses <<his>> right hand against your <<penisstop>></span><<set $righthand6 to "penisentrance">><<set $penisuse to 1>><<neutral 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 140>>
<<if $position is "wall">>
<<He>> slaps your <<bottomstop>><<violence 1>><<bruise bottom>><<hitstat>>
<<else>>
<span class="purple"><<He>> seizes your hair with <<his>> right hand.</span><<set $righthand6 to "hair">><<violence 2>><<set $speechhair to 1>>
<</if>>
<<elseif $enemyanger + $rng lte 160 and $lefthand6 isnot "arms" and $righthand6 isnot "arms" and $leftarm isnot "bound" and $rightarm isnot "bound">><span class="purple"><<He>> pins down your arms.</span><<set $righthand6 to "arms">><<set $leftarm to "grappled">><<set $rightarm to "grappled">><<disablearms>><<violence 2>><<bruise leftarm>><<bruise rightarm>><<set $speecharms to 1>>
<<if $vaginause is "cover">><<set $vaginause to 0>>
<</if>>
<<if $vaginause is "cover">><<set $vaginause to 0>>
<</if>>
<<if $anususe is "cover">><<set $anususe to 0>>
<</if>>
<<if $anususe is "cover">><<set $anususe to 0>>
<</if>>
<<if $penisuse is "cover">><<set $penisuse to 0>>
<</if>>
<<if $penisuse is "cover">><<set $penisuse to 0>>
<</if>>
<<elseif $enemyanger + $rng lte 160>><<He>> grips your <<bottomcomma>> digging <<his>> nails into your skin.<<violence 10>><<bruise bottom>><<hitstat>><<set $speechspank to 1>>
<<elseif $enemyanger + $rng lte 175>><<He>> spanks your <<bottomstop>><<violence 10>><<bruise bottom>><<hitstat>><<set $speechspank to 1>>
<<elseif $enemyanger + $rng lte 180>><<He>> slaps your thighs.<<violence 10>><<bruise thigh>><<hitstat>><<set $speechbeat to 1>>
<<elseif $enemyanger + $rng lte 185>>
<<if $position is "wall">>
<<He>> beats your thigh.<<bruise thigh>><<hitstat>><<violence 10>><<set $speechbeat to 1>>
<<else>>
<<He>> beats your tummy.<<violence 20>><<bruise tummy>><<hitstat>><<set $speechbeat to 1>>
<</if>>
<<elseif $enemyanger + $rng lte 190>>
<<if $position is "wall">>
<<He>> spanks your <<bottomstop>><<violence 20>><<bruise bottom>><<hitstat>><<set $speechbeat to 1>>
<<else>>
<<He>> spanks your <<breastsstop>><<violence 20>><<bruise chest>><<hitstat>><<set $speechbeat to 1>>
<</if>>
<<elseif $enemyanger + $rng gte 191>>
<<if $position is "wall">>
<<if $penisexist is 1>>
<<He>> jabs your gooch.<<violence 20>><<bruise penis>><<hitstat>><<set $speechbeat to 1>>
<<elseif $vaginaexist is 1>>
<<He>> jabs your gooch.<<violence 20>><<bruise vagina>><<hitstat>><<set $speechbeat to 1>>
<</if>>
<<else>>
<<set $rng to random(1, 100)>>
<<if $rng gte 81>>
<<He>> scratches the side of your face.<<violence 20>><<bruise face>><<hitstat>><<set $speechbeat to 1>>
<<elseif $rng gte 61>>
<<He>> scratches the back of your neck.<<violence 20>><<bruise neck>><<hitstat>><<set $speechbeat to 1>>
<<elseif $rng gte 41>>
<<He>> scratches your cheek.<<violence 20>><<bruise face>><<hitstat>><<set $speechbeat to 1>>
<<elseif $rng gte 21>>
<<He>> scratches your jaw.<<violence 20>><<bruise face>><<hitstat>><<set $speechbeat to 1>>
<<else>>
<<He>> scratches the front of your neck.<<violence 20>><<bruise neck>><<hitstat>><<set $speechbeat to 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis6 is "clothed">>
<<if $pronoun is "m">>
<<if $enemyarousal gte 40>><<He>> unzips <<his>> fly, <span class="blue">revealing <<his>> erect penis.</span><<set $penis6 to 0>>
<</if>>
<<else>>
<<if $enemyarousal gte 40>><<He>> pulls up <<his>> skirt, <span class="blue">revealing <<his>> erect penis.</span><<set $penis6 to 0>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis6 is "thighs">>
<<if $vaginaexist is 1>>
<<if $rng gte 101>><span class="blue"><<He>> angles <<his>> penis towards your <<pussystop>></span><<set $thighuse to 0>><<set $penis6 to "vaginaentrance">><<set $vaginause to "penis">><<set $vaginastate to "entrance">><<set $speechvaginaentrance to 1>>
<<else>>
<<He>> rubs <<his>> penis between your thighs and <<pussystop>><<sex 5>>
<</if>>
<<else>>
<<if $rng gte 101>><<He>> moves <<his>> penis out from between your thighs.<<set $thighuse to 0>><<set $penis6 to 0>>
<<else>>
<<He>> rubs <<his>> penis between your thighs.<<sex 5>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis6 is "cheeks">>
<<if $rng gte 101>><span class="blue"><<He>> angles <<his>> penis towards your anus.</span><<set $penis6 to "anusentrance">><<set $anusstate to "entrance">><<set $bottomuse to 0>><<set $cheekactiondefault to "cheeks">><<set $speechanusentrance to 1>>
<<else>>
<<He>> rubs <<his>> penis between your cheeks.<<submission 3>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis6 is "leftarm">>
<<if $rng gte 1>><<He>> rubs <<his>> penis between your fingers.<<submission 1>>
<<elseif $rng gte 101>><<He>> moves <<his>> penis away from your hand.<<set $penis6 to 0>><<set $leftarm to 0>><<set $leftactiondefault to "leftgrab">>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis6 is "rightarm">>
<<if $rng gte 1>><<He>> rubs <<his>> penis between your fingers.<<submission 1>>
<<elseif $rng gte 101>><<He>> moves <<his>> penis away from your hand.<<set $penis6 to 0>><<set $rightarm to 0>><<set $rightactiondefault to "rightgrab">>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis6 is "botharm">>
<<if $rng gte 1>><<He>> rubs <<his>> penis between your hands.<<submission 2>>
<<elseif $rng gte 101>><<He>> moves <<his>> penis away from your hands.<<set $penis6 to 0>><<set $leftarm to 0>><<set $rightarm to 0>><<set $rightactiondefault to "rightgrab">><<set $leftactiondefault to "leftgrab">>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis6 is "feet">>
<<if $rng gte 1>>
<<He>> rubs <<his>> penis between your feet.<<submission 1>>
<<elseif $rng gte 101>>
<<He>> moves <<his>> penis away from your feet.<<set $penis6 to 0>><<set $feetuse to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis6 is "vagina">>
<<if $rng gte 101>><span class="purple"><<He>> slides <<his>> penis out of your <<pussystop>></span><<sex 30>><<set $penis6 to "vaginaimminent">><<bruise vagina>><<violence 1>><<set $vaginastate to "imminent">>
<<elseif $rng gte 1>>
<<if $enemyanger gte 100>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
<<He>> violates your <<pussy>> with increasing intensity.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues to fuck your <<pussy>> with no regard for your comfort.
<<else>>
<<He>> fucks your <<pussy>> with rough thrusts, giving no regard to your comfort.
<</if>>
<<elseif $enemyanger gte 20>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
You feel <<his>> penis throb as <<he>> pounds away at your <<pussystop>>
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues to violate your <<pussystop>>
<<else>>
<<He>> fucks your <<pussy>> with deep and deliberate thrusts.
<</if>>
<<else>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
<<He>> fucks your <<pussy>> with increasing power.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues thrusting into your <<pussystop>>
<<else>>
<<He>> fucks your <<pussy>> with steady thrusts.
<</if>>
<</if>>
<<sex 30>><<bruise vagina>><<violence 1>><<set $speechvaginapenetrated to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis6 is "vaginaimminent">>
<<if $rng gte 101>><span class="blue"><<He>> stops pressing <<his>> penis against your pussy.</span><<set $penis6 to "vaginaentrance">><<set $vaginastate to "entrance">>
<<elseif $rng gte 1>>
<<if $novaginal is 0>><<set $vaginaactiondefault to "take">>
<<if $vaginalvirginity is 0>>
<<if $enemyanger gte 80>>
<span class="pink"><<He>> thrusts <<his>> penis deep into your <<pussystop>></span>
<<elseif $enemyanger gte 20>>
<span class="pink"><<He>> thrusts <<his>> penis deep into your <<pussystop>></span>
<<else>>
<span class="pink"><<He>> glides <<his>> penis deep into your <<pussystop>></span>
<</if>>
<<sex 30>><<set $penis6 to "vagina">><<vaginalstat>><<bruise vagina>><<violence 1>><<raped>><<vaginaraped>><<set $vaginastate to "penetrated">><<set $speechvaginapenetrated to 1>>
<<elseif $vaginalvirginity is 1>><span class="pink"><<His>> penis thrusts deep into your virgin pussy,</span><span class="red"> breaking your hymen and forever robbing you of your purity.</span><<sex 100>><<set $penis6 to "vagina">><<set $vaginalvirginity to 0>><<bruise vagina>><<vaginalstat>><<violence 100>><<raped>><<vaginaraped>><<set $vaginastate to "penetrated">><<set $speechvaginavirgin to 1>>
<</if>>
<<else>>
Respecting your wishes, <<he>> presses <<his>> penis against your <<pussy>> but does not penetrate.<<sex 15>><<set $speechvaginawithhold to 1>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis6 is "vaginaentrance">>
<<if $rng gte 101>><span class="lblue"><<He>> moves <<his>> penis away from your <<pussystop>></span><<set $penis6 to 0>><<set $vaginause to 0>><<set $vaginastate to 0>>
<<elseif $rng gte 1>>
<<if $lowervaginaexposed is 0>><<He>> rubs <<his>> penis against your <<pussy>> through your $lowerclothes.<<sex 5>><<set $lowerintegrity -= 10>><<set $speechvaginaentrance to 1>>
<<elseif $lowervaginaexposed is 1>><<set $rng to random(1, 100)>>
<<if $undervaginaexposed is 0>><<He>> rubs <<his>> penis against your <<pussy>> through your $underclothes.<<sex 5>><<set $underintegrity -= 10>><<set $speechvaginaentrance to 1>>
<<elseif $undervaginaexposed is 1>>
<<if $rng gte 71>>
<<if $novaginal is 1>>
<span class="purple"><<He>> pushes <<his>> penis against your <<pussystop>></span><<sex 20>><<set $penis6 to "vaginaimminent">><<set $vaginastate to "imminent">><<set $speechvaginaimminent to 1>>
<<else>>
<span class="purple"><<He>> pushes <<his>> penis against your <<pussycomma>> preparing to penetrate you fully.</span><<sex 20>><<set $penis6 to "vaginaimminent">><<set $vaginastate to "imminent">><<set $speechvaginaimminent to 1>>
<</if>>
<<elseif $rng gte 1>><<He>> teases your <<pussy>> without penetrating.<<sex 10>><<set $speechvaginaentrance to 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis6 is "anus">>
<<if $rng gte 101>><span class="purple"><<He>> withdraws <<his>> penis from your anus.</span><<sex 30>><<set $penis6 to "anusimminent">><<bruise anus>><<violence 1>><<set $anusstate to "imminent">>
<<elseif $rng gte 1>>
<<if $enemyanger gte 100>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
<<He>> ravages your <<bottom>> with a violent intensity.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
You feel <<his>> penis ever deeper within you as <<he>> fucks your <<bottomstop>>
<<else>>
<<He>> fucks your <<bottom>> with rough thrusts, intent on showing you who's boss.
<</if>>
<<elseif $enemyanger gte 20>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
You feel <<his>> penis throb within you as <<he>> fucks your <<bottomstop>>
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues to violate your <<bottomcomma>> giving no regard to your comfort.
<<else>>
<<He>> fucks your <<bottom>> with deep and dominating thrusts.
<</if>>
<<else>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
<<He>> fucks your <<bottom>> with increasing power.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues fucking your <<bottomstop>>
<<else>>
<<He>> fucks your <<bottom>> with steady thrusts.
<</if>>
<</if>>
<<sex 30>><<bruise anus>><<violence 1>><<set $speechanuspenetrated to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis6 is "anusimminent">>
<<if $rng gte 101>><span class="blue"><<He>> stops pressing <<his>> penis against your anus.</span><<set $penis6 to "anusentrance">><<set $anusstate to "entrance">>
<<elseif $rng gte 1>>
<<if $noanal is 0>><<set $anusactiondefault to "take">>
<<if $analvirginity is 0>><span class="pink"><<He>> thrusts <<his>> penis deep into your <<bottomstop>></span><<sex 30>><<set $penis6 to "anus">><<bruise anus>><<analstat>><<violence 1>><<raped>><<set $anusstate to "penetrated">><<set $speechanuspenetrated to 1>>
<<elseif $analvirginity is 1>><span class="pink"><<He>> thrusts <<his>> penis deep into your virgin anus,</span> <span class="red">violating you in a way you hadn't conceived of.</span><<sex 100>><<set $penis6 to "anus">><<set $analvirginity to 0>><<bruise anus>><<analstat>><<violence 50>><<raped>><<set $anusstate to "penetrated">><<set $speechanusvirgin to 1>>
<</if>>
<<else>>
Respecting your wishes, <<he>> presses <<his>> penis against your anus but does not penetrate.<<sex 15>><<set $speechanuswithhold to 1>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis6 is "anusentrance">>
<<if $rng gte 101>><span class="lblue"><<He>> moves <<his>> penis away from your <<bottomstop>></span><<set $penis6 to 0>><<set $anususe to 0>><<set $anusstate to 0>>
<<elseif $rng gte 1>>
<<if $loweranusexposed is 0>><<He>> rubs <<his>> penis against your <<bottom>> through your $lowerclothes.<<sex 5>><<set $lowerintegrity -= 10>><<set $speechanusentrance to 1>>
<<elseif $loweranusexposed is 1>><<set $rng to random(1, 100)>>
<<if $underanusexposed is 0>><<He>> rubs <<his>> penis against your <<bottom>> through your $underclothes.<<set $speechanusentrance to 1>><<sex 5>><<set $underintegrity -= 10>>
<<elseif $underanusexposed is 1>>
<<if $rng gte 71>>
<<if $noanal is 1>>
<span class="pink"><<He>> presses <<his>> penis against your anus.</span><<sex 20>><<set $penis6 to "anusimminent">><<set $anusstate to "imminent">><<set $speechanusimminent to 1>>
<<else>>
<span class="pink"><<He>> presses <<his>> penis against your anus, preparing to penetrate you fully.</span><<sex 20>><<set $penis6 to "anusimminent">><<set $anusstate to "imminent">><<set $speechanusimminent to 1>>
<</if>>
<<elseif $rng gte 1>><<His>> penis rubs against your <<bottomstop>><<sex 5>><<set $speechanusentrance to 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis6 is "mouth">>
<<if $rng gte 101>><span class="purple"><<He>> withdraws <<his>> penis from your mouth.</span><<sex 30>><<set $penis6 to "mouthimminent">><<bruise face>><<violence 1>><<set $mouthstate to "imminent">>
<<elseif $rng gte 1>><<He>> continues thrusting into your mouth.<<submission 10>><<bruise face>><<violence 1>><<set $speechmouthpenetrated to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis6 is "mouthimminent">>
<<if $pullaway is 1>><<set $pullaway to 0>>Saliva drips from the tip of <<his>> phallus.
<<else>>
<<if $rng gte 101>><span class="blue"><<He>> stops pressing <<his>> penis against your mouth.</span><<set $penis6 to "mouthentrance">><<submission 5>><<set $mouthstate to "entrance">>
<<elseif $rng lte 20>>
<<if $oralvirginity is 0>><span class="pink"><<He>> thrusts <<his>> penis into your mouth.</span><<submission 10>><<set $penis6 to "mouth">><<bruise face>><<oralstat>><<raped>><<set $mouthstate to "penetrated">><<set $speechmouthpenetrated to 1>>
<<elseif $oralvirginity is 1>><span class="pink"><<He>> thrusts <<his>> penis into your mouth.</span><span class="red"> It tastes strange.</span><<submission 30>><<set $penis6 to "mouth">><<set $oralvirginity to 0>><<bruise face>><<oralstat>><<violence 1>><<raped>><<set $mouthstate to "penetrated">><<set $speechmouthvirgin to 1>>
<</if>>
<<elseif $rng gte 21>>
<<if $mouthsubmit is 1>><<He>> allows you to pleasure <<his>> cock with your mouth.<<submission 5>><<set $speechmouthimminent to 1>>
<<elseif $oralvirginity is 0>><span class="pink"><<He>> thrusts <<his>> penis into your mouth.</span><<submission 10>><<set $penis6 to "mouth">><<oralstat>><<bruise face>><<violence 1>><<raped>><<set $mouthstate to "penetrated">><<set $speechmouthpenetrated to 1>>
<<elseif $oralvirginity is 1>><span class="pink"><<He>> thrusts <<his>> penis into your mouth.</span><span class="red"> It tastes strange.</span><<submission 30>><<set $penis6 to "mouth">><<set $oralvirginity to 0>><<oralstat>><<bruise face>><<violence 1>><<raped>><<set $mouthstate to "penetrated">><<set $speechmouthpenetrated to 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis6 is "mouthentrance">>
<<if $pullaway is 1>><<set $pullaway to 0>><<His>> penis hovers only inches from your face.
<<else>>
<<if $rng gte 101>><span class="lblue"><<He>> moves <<his>> penis away from your mouth.</span><<set $penis6 to 0>><<set $mouthuse to 0>><<set $mouthstate to 0>>
<<elseif $rng gte 1>><span class="purple"><<He>> pushes <<his>> penis against your lips.</span><<set $penis6 to "mouthimminent">><<submission 5>><<set $mouthstate to "imminent">><<set $speechmouthimminent to 1>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis6 is "chest">>
<<if $rng gte 101>><<He>> moves <<his>> penis away from your chest.<<set $penis6 to 0>><<set $chestuse to 0>>
<<elseif $rng gte 1>><<submission 3>>
<<if $breastcup is "none">>
<<He>> rubs <<his>> penis against your <<breastsstop>><<set $speechchestrub to 1>>
<<else>>
<<He>> rubs <<his>> penis between your <<breastsstop>><<set $speechbreastrub to 1>>
<</if>>
<</if>>
<</if>>
<<if $penis6 is "footjob">>
<<if $rng gte 101>>
<span class="blue"><<He>> stops pressing <<his>> foot against your <<genitalsstop>></span><<set $penis6 to 0>>
<<if $penisexist is 1>>
<<set $penisuse to 0>>
<<else>>
<<set $vaginause to 0>>
<</if>>
<<else>>
<<if $penisexist is 1>>
<<He>> presses your <<penis>> against your stomach with <<his>> foot and rubs your glans between <<his>> toes.
<<set $speechpenisfoot to 1>><<neutral 5>><<violence 1>>
<<else>>
<<He>> presses and teases your <<pussy>> with <<his>> foot.
<<set $speechvaginafoot to 1>><<neutral 5>><<violence 1>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis6 is "otherfrot">>
<<if $rng gte 101>><span class="blue"><<He>> shifts <<his>> ass and presses <<his>> anus against your <<penisstop>></span><<set $penisuse to "otheranus">><<set $penis6 to "otheranusentrance">><<set $penisstate to "otheranusentrance">><<set $speechotheranusentrance to 1>>
<<else>>
<<He>> rubs <<his>> ass against your <<penisstop>><<sex 5>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis6 is "otheranus">>
<<if $rng gte 101>><span class="purple"><<He>> moves <<his>> pelvis away, releasing your <<penis>> from <<his>> anus.</span><<sex 30>><<set $penis6 to "otheranusimminent">><<bruise penis>><<violence 1>><<set $penisstate to "otheranusimminent">><<set $speechotheranusimminent to 1>>
<<elseif $rng gte 1>>
<<if $enemyanger gte 100>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
<<His>> continues to fuck your <<penis>> with <<his>> ass, <<his>> movements violent and erratic.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues to ride you, your penis helpless as it's fucked.
<<else>>
<<He>> fucks your <<penis>> with rough movements, intent on showing you who's boss.
<</if>>
<<elseif $enemyanger gte 20>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
You feel <<his>> ass twitch around your length <<he>> fucks you.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues to violate your <<peniscomma>> using you as a sex toy.
<<else>>
<<He>> fucks your <<peniscomma>> taking as much of you into <<his>> ass as <<he>> can.
<</if>>
<<else>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
<<He>> continues riding your <<peniscomma>> <<his>> anus rhythmically pounding your length. <<His>> body jerks whenever you hit a sensitive spot.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues riding your <<peniscomma>> <<his>> anus rhythmically pounding your length.
<<else>>
<<He>> rides your <<penis>> with steady movements.
<</if>>
<</if>>
<<sex 30>><<bruise penis>><<violence 1>><<set $speechotheranus to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis6 is "otheranusimminent">>
<<if $rng gte 101>><span class="blue"><<He>> stops pressing <<his>> ass against your <<penisstop>></span><<set $penis6 to "otheranusentrance">><<set $penisstate to "otheranusentrance">><<set $speechotheranusentrance to 1>>
<<elseif $rng gte 1>>
<<if $nopenile is 0>><<set $penisactiondefault to "otheranustake">>
<<if $penilevirginity is 0>><span class="pink"><<He>> eases your <<penis>> into <<his>> ass, swallowing you to the base.</span><<sex 30>><<set $penis6 to "otheranus">><<penilestat>><<bruise penis>><<violence 1>><<raped>><<penisraped>><<set $penisstate to "otheranus">><<set $speechotheranus to 1>>
<<elseif $penilevirginity is 1>><span class="pink"><<He>> eases your virgin penis into <<his>> ass,</span><span class="red"> separating your foreskin from your glans and forever robbing you of your purity.</span><<sex 100>><<set $penis6 to "otheranus">><<set $penilevirginity to 0>><<bruise penis>><<penilestat>><<violence 100>><<raped>><<penisraped>><<set $penisstate to "otheranus">><<set $speechpenisvirgin to 1>>
<</if>>
<<else>>
Respecting your wishes, <<he>> does not envelope your <<penis>> with <<his>> ass, instead teasing the tip of your glans.<<sex 15>><<set $speechotheranuswithhold to 1>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis6 is "otheranusentrance">>
<<if $rng gte 101>><span class="lblue"><<He>> moves <<his>> ass away from your <<penisstop>></span><<set $penis6 to 0>><<set $penisuse to 0>><<set $penisstate to 0>>
<<elseif $rng gte 1>>
<<if $lowervaginaexposed is 0>><<He>> rubs <<his>> ass against your <<penis>> through your $lowerclothes.<<sex 5>><<set $lowerintegrity -= 10>><<set $speechotheranusentrance to 1>>
<<elseif $lowervaginaexposed is 1>><<set $rng to random(1, 100)>>
<<if $undervaginaexposed is 0>><<He>> rubs <<his>> ass against your <<penis>> through your $underclothes.<<sex 5>><<set $underintegrity -= 10>><<set $speechotheranusentrance to 1>>
<<elseif $undervaginaexposed is 1>>
<<if $rng gte 71>>
<<if $nopenile is 1>>
<span class="purple"><<He>> presses <<his>> ass against your <<penisstop>></span><<sex 20>><<set $penis6 to "otheranusimminent">><<set $penisstate to "otheranusimminent">><<set $speechotheranusimminent to 1>>
<<else>>
<span class="purple"><<He>> presses <<his>> ass against your <<peniscomma>> preparing to take you in fully.</span><<sex 20>><<set $penis6 to "otheranusimminent">><<set $penisstate to "otheranusimminent">><<set $speechotheranusimminent to 1>>
<</if>>
<<elseif $rng gte 1>><<He>> rubs your <<penis>> between <<his>> cheeks.<<sex 10>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $penis6 is 0>>
<<if $enemyanger + $rng lte 20>>
<<if $lefthand6 is 0>>
<<if $enemyarousal lte 40>><<He>> slowly rubs <<his>> shaft.<<submission 1>>
<<elseif $enemyarousal lte 90>><<He>> quickly rubs <<his>> shaft.<<submission 2>>
<<elseif $enemyarousal gte 91>><<He>> rapidly rubs <<his>> shaft.<<submission 3>>
<</if>>
<<elseif $righthand6 is 0>>
<<if $enemyarousal lte 40>><<He>> slowly rubs <<his>> shaft.<<submission 1>>
<<elseif $enemyarousal lte 90>><<He>> quickly rubs <<his>> shaft.<<submission 2>>
<<elseif $enemyarousal gte 91>><<He>> rapidly rubs <<his>> shaft.<<submission 3>>
<<endif>
<<else>><<He>> rubs <<his>> cock against your thighs.<<submission 2>>
<</if>>
<<elseif $enemyanger + $rng lte 25>>
<<if $position is "wall">>
<<He>> rubs <<his>> cock against your thighs.<<submission 2>>
<<else>>
<<He>> rubs <<his>> cock against your tummy.<<submission 2>>
<</if>>
<<elseif $enemyanger + $rng lte 30>>
<<if $position is "wall">>
<<He>> rubs <<his>> cock against your thighs.<<submission 2>>
<<else>>
<<He>> rubs <<his>> cock against your <<breastsstop>><<submission 2>>
<</if>>
<<elseif $enemyanger + $rng lte 35>><<He>> rubs <<his>> cock against your thighs.<<submission 2>>
<<elseif $enemyanger + $rng lte 40>>
<<if $position is "wall">>
<<He>> rubs <<his>> cock against your thighs.<<submission 2>>
<<elseif $mouth6 is 0>>
<<He>> rubs <<his>> cock against your face.<<submission 2>>
<<else>>
<<He>> rubs <<his>> cock against your thighs.<<submission 2>>
<</if>>
<<elseif $enemyanger + $rng lte 45>>
<<if $penisexist is 1>>
<<if $penisuse is 0>>
<<if $analdisable is "f" and $consensual is 1>>
<span class="blue"><<He>> straddles you, rubbing <<his>> ass against your <<penisstop>></span><<neutral 5>><<set $penisuse to "otheranus">><<set $penis6 to "otheranusentrance">><<set $penisstate to "otheranusentrance">><<set $speechotheranusentrance to 1>>
<</if>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 60>>
<<if $mouthuse is 0>>
<<if $penisbitten is 0>>
<<if $position isnot "wall">>
<span class="blue"><<He>> positions <<his>> penis in front of your mouth.</span><<neutral 5>><<set $mouthuse to "penis">><<set $penis6 to "mouthentrance">><<set $mouthstate to "entrance">><<set $speechmouthentrance to 1>>
<</if>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 80>>
<<if $anususe is 0>>
<<if $analdisable is "f">>
<span class="blue"><<He>> moves between your legs, positioning <<his>> penis in front of your <<bottomstop>></span><<neutral 5>><<set $anususe to "penis">><<set $penis6 to "anusentrance">><<set $anusstate to "entrance">><<set $speechanusentrance to 1>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 100>>
<<if $vaginaexist is 1>>
<<if $vaginause is 0>><span class="blue"><<He>> moves between your legs, positioning <<his>> penis in front of your <<pussystop>></span><<neutral 5>><<set $vaginause to "penis">><<set $penis6 to "vaginaentrance">><<set $vaginastate to "entrance">><<set $speechvaginaentrance to 1>>
<</if>>
<<elseif $penisexist is 1>>
<<if $anususe is 0>>
<<if $analdisable is "f">>
<span class="blue"><<He>> moves between your legs, positioning <<his>> penis in front of your <<bottomstop>></span><<neutral 5>><<set $anususe to "penis">><<set $penis6 to "anusentrance">><<set $anusstate to "entrance">><<set $speechanusentrance to 1>>
<</if>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 120>>
<<He>> slowly traces <<his>> length across your exposed skin.<<neutral 1>>
<<neutral 5>>
<<elseif $enemyanger + $rng lte 140>>
<<if $penisbitten is 0>>
<<if $position isnot "wall">>
<<if $mouthuse is 0>><span class="purple"><<He>> shoves <<his>> penis against your lips.</span><<submission 5>><<set $mouthuse to "penis">><<set $mouthstate to "imminent">><<set $penis6 to "mouthimminent">><<set $speechmouthimminent to 1>>
<<else>>
<<He>> slowly traces <<his>> length across your exposed skin.<<neutral 1>>
<</if>>
<<else>>
<<He>> slowly traces <<his>> length across your exposed skin.<<neutral 1>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 150>><span class="purple"><<He>> presses <<his>> foot against your <<genitalsstop>></span><<neutral 5>><<violence 1>><<set $penis6 to "footjob">>
<<if $penisexist is 1>>
<<set $penisuse to "feet">><<set $speechpenisfoot to 1>>
<<else>>
<<set $vaginause to "feet">><<set $speechvaginafoot to 1>>
<</if>>
<<elseif $enemyanger + $rng lte 170>>
<<if $anususe is 0 and $analdisable is "f">>
<<if $loweranusexposed is 1>>
<<if $underanusexposed is 1>>
<span class="purple"><<He>> presses <<his>> penis against your anus, preparing to penetrate.</span><<sex 5>><<set $anususe to "penis">><<set $penis6 to "anusimminent">><<set $anusstate to "imminent">><<set $speechanusimminent to 1>>
<<elseif $underanusexposed is 0>><span class="blue"><<He>> presses <<his>> penis against your anus through your $underclothes.</span><<sex 3>><<set $penis6 to "anusentrance">><<set $anususe to "penis">><<set $underintegrity -= 10>><<set $anusstate to "entrance">><<set $speechanusentrance to 1>>
<</if>>
<<elseif $loweranusexposed is 0>><span class="blue"><<He>> presses <<his>> penis against your anus through your $lowerclothes.</span><<sex 2>><<set $penis6 to "anusentrance">><<set $anususe to "penis">><<set $lowerintegrity -= 10>><<set $anusstate to "entrance">><<set $speechanusentrance to 1>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng gte 171>>
<<if $vaginaexist is 1>>
<<if $vaginause is 0>>
<<if $lowervaginaexposed is 1>>
<<if $undervaginaexposed is 1>><span class="purple"><<He>> presses <<his>> penis against your <<pussycomma>> preparing to penetrate.</span><<sex 5>><<set $vaginause to "penis">><<set $penis6 to "vaginaimminent">><<set $vaginastate to "imminent">><<set $speechvaginaimminent to 1>>
<<elseif $undervaginaexposed is 0>><span class="blue"><<He>> presses <<his>> penis against your <<pussy>> through your $underclothes.</span><<set $underintegrity -= 10>><<sex 3>><<set $penis6 to "vaginaentrance">><<set $vaginause to "penis">><<set $vaginastate to "entrance">><<set $speechvaginaentrance to 1>>
<</if>>
<<elseif $lowervaginaexposed is 0>><span class="blue"><<He>> presses <<his>> penis against your <<pussy>> through your $lowerclothes.</span><<sex 2>><<set $penis6 to "vaginaentrance">><<set $vaginause to "penis">><<set $lowerintegrity -= 10>><<set $vaginastate to "entrance">><<set $speechvaginaentrance to 1>>
<</if>>
<</if>>
<<elseif $penisexist is 1>>
<<if $anususe is 0 and $analdisable is "f">>
<<if $loweranusexposed is 1>>
<<if $underanusexposed is 1>><span class="purple"><<He>> presses <<his>> penis against your anus, preparing to penetrate.</span><<sex 5>><<set $anususe to "penis">><<set $penis6 to "anusimminent">><<set $anusstate to "imminent">><<set $speechanusimminent to 1>>
<<elseif $underanusexposed is 0>><span class="blue"><<He>> presses <<his>> penis against your anus through your $underclothes.</span><<sex 3>><<set $penis6 to "anusentrance">><<set $anususe to "penis">><<set $underintegrity -= 10>><<set $anusstate to "entrance">><<set $speechanusentrance to 1>>
<</if>>
<<elseif $loweranusexposed is 0>><span class="blue"><<He>> presses <<his>> penis against your anus through your $lowerclothes.</span><<sex 2>><<set $penis6 to "anusentrance">><<set $anususe to "penis">><<set $lowerintegrity -= 10>><<set $anusstate to "entrance">><<set $speechanusentrance to 1>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<set $rng to random(1, 100)>>
<<if $vagina6 is "clothed">>
<<if $pronoun is "f">>
<<if $enemyarousal gte 40>><span class="blue"><<He>> lifts up <<his>> skirt, revealing <<his>> moistened pussy.</span><<set $vagina6 to 0>>
<</if>>
<<else>>
<<if $enemyarousal gte 40>><span class="blue"><<He>> unzips <<his>> fly, revealing <<his>> moistened pussy.</span><<set $vagina6 to 0>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $vagina6 is "frot">>
<<if $rng gte 101>><span class="blue"><<He>> moves <<his>> clit away and presses <<his>> hungry pussy against your <<penisstop>></span><<set $penisuse to "othervagina">><<set $vagina6 to "penisentrance">><<set $penisstate to "entrance">><<set $speechpenisentrance to 1>>
<<else>>
<<He>> rubs <<his>> clit against your glans.<<sex 5>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $vagina6 is "penis">>
<<if $rng gte 101>><span class="purple"><<He>> moves <<his>> pelvis away, releasing your <<penis>> from <<his>> vagina.</span><<sex 30>><<set $vagina6 to "penisimminent">><<bruise penis>><<violence 1>><<set $penistate to "imminent">><<set $speechpenisimminent to 1>>
<<elseif $rng gte 1>>
<<if $enemyanger gte 100>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
<<His>> continues to fuck your <<peniscomma>> <<his>> movements violent and erratic as <<his>> pussy slides along your length.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues to ride you, your penis helpless as it's fucked.
<<else>>
<<He>> fucks your <<penis>> with rough movements, intent on showing you who's boss.
<</if>>
<<elseif $enemyanger gte 20>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
You feel <<his>> vagina twitch and throb around your length <<he>> fucks you.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues to violate your <<peniscomma>> using you as a sex toy.
<<else>>
<<He>> fucks your <<peniscomma>> taking as much of you into <<his>> vagina as <<he>> can.
<</if>>
<<else>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
<<He>> continues riding your <<peniscomma>> <<his>> vagina rhythmically kneading and squeezing your length. <<His>> body jerks whenever you hit a sensitive spot.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues riding your <<peniscomma>> <<his>> vagina rhythmically kneading and squeezing your length.
<<else>>
<<He>> rides your <<penis>> with steady movements.
<</if>>
<</if>>
<<sex 30>><<bruise penis>><<violence 1>><<set $speechpenispenetrated to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $vagina6 is "penisimminent">>
<<if $rng gte 101>><span class="blue"><<He>> stops pressing <<his>> pussy against your <<penisstop>></span><<set $vagina6 to "penisentrance">><<set $penisstate to "entrance">><<set $speechpenisentrance to 1>>
<<elseif $rng gte 1>>
<<if $nopenile is 0>><<set $penisactiondefault to "take">>
<<if $penilevirginity is 0>><span class="pink"><<He>> eases your <<penis>> into <<his>> pussy, swallowing you to the base.</span><<sex 30>><<set $vagina6 to "penis">><<penilestat>><<bruise penis>><<violence 1>><<raped>><<penisraped>><<set $penisstate to "penetrated">><<set $speechpenispenetrated to 1>>
<<elseif $penilevirginity is 1>><span class="pink"><<He>> eases your virgin penis into <<his>> pussy,</span><span class="red"> separating your foreskin from your glans and forever robbing you of your purity.</span><<sex 100>><<set $vagina6 to "penis">><<set $penilevirginity to 0>><<bruise penis>><<penilestat>><<violence 100>><<raped>><<penisraped>><<set $penisstate to "penetrated">><<set $speechpenisvirgin to 1>>
<</if>>
<<else>>
Respecting your wishes, <<he>> does not envelope your <<penis>> with <<his>> vagina, instead teasing the tip of your glans.<<sex 15>><<set $speechpeniswithhold to 1>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $vagina6 is "penisentrance">>
<<if $rng gte 101>><span class="lblue"><<He>> moves <<his>> pussy away from your <<penisstop>></span><<set $vagina6 to 0>><<set $penisuse to 0>><<set $penisstate to 0>>
<<elseif $rng gte 1>>
<<if $lowervaginaexposed is 0>><<He>> rubs <<his>> pussy against your <<penis>> through your $lowerclothes.<<sex 5>><<set $lowerintegrity -= 10>><<set $speechpenisentrance to 1>>
<<elseif $lowervaginaexposed is 1>><<set $rng to random(1, 100)>>
<<if $undervaginaexposed is 0>><<He>> rubs <<his>> pussy against your <<penis>> through your $underclothes.<<sex 5>><<set $underintegrity -= 10>><<set $speechpenisentrance to 1>>
<<elseif $undervaginaexposed is 1>>
<<if $rng gte 71>>
<<if $nopenile is 1>>
<span class="purple"><<He>> presses <<his>> pussy against your <<penisstop>></span><<sex 20>><<set $vagina6 to "penisimminent">><<set $penisstate to "imminent">><<set $speechpenisimminent to 1>>
<<else>>
<span class="purple"><<He>> presses <<his>> pussy against your <<peniscomma>> preparing to envelope you fully.</span><<sex 20>><<set $vagina6 to "penisimminent">><<set $penisstate to "imminent">><<set $speechpenisimminent to 1>>
<</if>>
<<elseif $rng gte 1>><<He>> teases your <<penis>> with <<his>> labia.<<sex 10>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $vagina6 is "lefthand">>
<<if $rng lte 80>>
<<He>> strokes <<his>> pussy with <<his>> left hand.<<neutral 1>><<set $enemyarousal += 20>>
<<else>>
<span class="blue"><<He>> moves <<his>> left hand away from <<his>> pussy.</span>
<<set $lefthand6 to 0>><<set $vagina6 to 0>>
<</if>>
<</if>>
<<if $vagina6 is "righthand">>
<<if $rng lte 80>>
<<He>> strokes <<his>> pussy with <<his>> right hand.<<neutral 1>><<set $enemyarousal += 20>>
<<else>>
<span class="blue"><<He>> moves <<his>> right hand away from <<his>> pussy.</span>
<<set $righthand6 to 0>><<set $vagina6 to 0>>
<</if>>
<</if>>
<<if $vagina6 is "mouth">>
<<if $enemyanger gte 100>>
<<He>> covers your mouth with <<his>> pussy, making it difficult to breathe.<<violence 3>><<bruise face>><<set $speechvaginamouth to 1>>
<<else>>
<<if $mouthsubmit is 1>>
<<if $rng gte 1>>
<<He>> rubs <<his>> pussy against your lips.
<<if $enemyarousal gte (($enemyarousalmax / 5) * 3)>>
You can taste <<his>> juices.
<</if>>
<<sex 3>><<set $speechvaginamouth to 1>>
<<else>><<He>> moves <<his>> pussy away from your face.<<set $mouthuse to 0>><<set $mouthstate to 0>><<set $vagina6 to 0>>
<</if>>
<<else>>
<<if $rng gte 1>>
<<He>> rubs <<his>> pussy against your lips.
<<if $enemyarousal gte (($enemyarousalmax / 5) * 3)>>
You can taste <<his>> juices.
<</if>>
<<sex 3>><<set $speechvaginamouth to 1>>
<<else>><<He>> moves <<his>> pussy away from your face.<<set $mouthuse to 0>><<set $mouthstate to 0>><<set $vagina6 to 0>>
<</if>>
<</if>>
<</if>>
<</if>>
<<if $vagina6 is "vagina">>
<<if $rng gte 1>>
<<He>> kneads your pussies together.<<sex 20>><<set $speechvaginavagina to 1>>
<<else>>
<span class="lblue"><<He>> moves <<his>> pussy away from yours.</span><<set $vaginause to 0>><<set $vagina6 to 0>>
<</if>>
<</if>>
<<if $vagina6 is "leftarm">>
<<if $rng gte 1>>
<<He>> rubs <<his>> pussy against your fingers.<<submission 2>>
<<else>>
<<He>> moves your hand away from <<his>> pussy.<<set $leftarm to 0>><<set $vagina6 to 0>><<set $leftactiondefault to "leftplay">>
<</if>>
<</if>>
<<if $vagina6 is "rightarm">>
<<if $rng gte 1>>
<<He>> rubs <<his>> pussy against your fingers.<<submission 2>>
<<else>>
<<He>> moves your hand away from <<his>> pussy.<<set $rightarm to 0>><<set $vagina6 to 0>><<set $rightactiondefault to "rightplay">>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $vagina6 is "feet">>
<<if $rng gte 1>>
<<He>> rubs <<his>> pussy against your feet.<<submission 2>>
<<else>>
<<He>> moves your feet away from <<his>> pussy.<<set $feetuse to 0>><<set $vagina6 to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $vagina6 is "footjob">>
<<if $rng gte 101>>
<span class="blue"><<He>> stops pressing <<his>> foot against your <<genitalsstop>></span><<set $vagina6 to 0>>
<<if $penisexist is 1>>
<<set $penisuse to 0>>
<<else>>
<<set $vaginause to 0>>
<</if>>
<<else>>
<<if $penisexist is 1>>
<<He>> presses your penis against your stomach with <<his>> foot and rubs your glans between <<his>> toes.
<<set $speechpenisfoot to 1>><<neutral 5>><<violence 1>>
<<else>>
<<He>> rubs <<his>> foot against your <<pussystop>>
<<set $speechvaginafoot to 1>><<neutral 5>><<violence 1>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $vagina6 is "otherfrot">>
<<if $rng gte 101>><span class="blue"><<He>> shifts <<his>> ass and presses <<his>> anus against your <<penisstop>></span><<set $penisuse to "otheranus">><<set $vagina6 to "otheranusentrance">><<set $penisstate to "otheranusentrance">><<set $speechotheranusentrance to 1>>
<<else>>
<<He>> rubs <<his>> ass against your <<penisstop>><<sex 5>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $vagina6 is "otheranus">>
<<if $rng gte 101>><span class="purple"><<He>> moves <<his>> pelvis away, releasing your <<penis>> from <<his>> anus.</span><<sex 30>><<set $vagina6 to "otheranusimminent">><<bruise penis>><<violence 1>><<set $penisstate to "otheranusimminent">><<set $speechotheranusimminent to 1>>
<<elseif $rng gte 1>>
<<if $enemyanger gte 100>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
<<His>> continues to fuck your <<penis>> with <<his>> ass, <<his>> movements violent and erratic. Fluid from <<his>> pussy drools onto your length.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues to ride you, your penis helpless as it's fucked.
<<else>>
<<He>> fucks your <<penis>> with rough movements, intent on showing you who's boss.
<</if>>
<<elseif $enemyanger gte 20>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
You feel <<his>> ass twitch around your length as <<he>> fucks you.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues to violate your <<peniscomma>> using you as a sex toy.
<<else>>
<<He>> fucks your <<peniscomma>> taking as much of you into <<his>> ass as <<he>> can.
<</if>>
<<else>>
<<if $enemyarousal gte (($enemyarousalmax / 5) * 4)>>
<<He>> continues riding your <<peniscomma>> <<his>> anus rhythmically pounding your length. <<His>> body jerks whenever you hit a sensitive spot.
<<elseif $enemyarousal gte (($enemyarousalmax / 5) * 2)>>
<<He>> continues riding your <<peniscomma>> <<his>> anus rhythmically pounding your length.
<<else>>
<<He>> rides your <<penis>> with steady movements.
<</if>>
<</if>>
<<sex 30>><<bruise penis>><<violence 1>><<set $speechotheranus to 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $vagina6 is "otheranusimminent">>
<<if $rng gte 101>><span class="blue"><<He>> stops pressing <<his>> ass against your <<penisstop>></span><<set $vagina6 to "otheranusentrance">><<set $penisstate to "otheranusentrance">><<set $speechotheranusentrance to 1>>
<<elseif $rng gte 1>>
<<if $nopenile is 0>><<set $penisactiondefault to "take">>
<<if $penilevirginity is 0>><span class="pink"><<He>> eases your <<penis>> into <<his>> ass, swallowing you to the base.</span><<sex 30>><<set $vagina6 to "otheranus">><<penilestat>><<bruise penis>><<violence 1>><<raped>><<penisraped>><<set $penisstate to "otheranus">><<set $speechotheranus to 1>>
<<elseif $penilevirginity is 1>><span class="pink"><<He>> eases your virgin penis into <<his>> ass,</span><span class="red"> separating your foreskin from your glans and forever robbing you of your purity.</span><<sex 100>><<set $vagina6 to "otheranus">><<set $penilevirginity to 0>><<bruise penis>><<penilestat>><<violence 100>><<raped>><<penisraped>><<set $penisstate to "otheranus">><<set $speechpenisvirgin to 1>>
<</if>>
<<else>>
Respecting your wishes, <<he>> does not envelope your <<penis>> with <<his>> ass, instead teasing the tip of your glans.<<sex 15>><<set $speechotheranuswithhold to 1>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $vagina6 is "otheranusentrance">>
<<if $rng gte 101>><span class="lblue"><<He>> moves <<his>> ass away from your <<penisstop>></span><<set $vagina6 to 0>><<set $penisuse to 0>><<set $penisstate to 0>>
<<elseif $rng gte 1>>
<<if $lowervaginaexposed is 0>><<He>> rubs <<his>> ass against your <<penis>> through your $lowerclothes.<<sex 5>><<set $lowerintegrity -= 10>><<set $speechotheranusentrance to 1>>
<<elseif $lowervaginaexposed is 1>><<set $rng to random(1, 100)>>
<<if $undervaginaexposed is 0>><<He>> rubs <<his>> ass against your <<penis>> through your $underclothes.<<sex 5>><<set $underintegrity -= 10>><<set $speechotheranusentrance to 1>>
<<elseif $undervaginaexposed is 1>>
<<if $rng gte 71>>
<<if $nopenile is 1>>
<span class="purple"><<He>> presses <<his>> ass against your <<penisstop>></span><<sex 20>><<set $vagina6 to "otheranusimminent">><<set $penisstate to "otheranusimminent">><<set $speechotheranusimminent to 1>>
<<else>>
<span class="purple"><<He>> presses <<his>> ass against your <<peniscomma>> preparing to take you in fully.</span><<sex 20>><<set $vagina6 to "otheranusimminent">><<set $penisstate to "otheranusimminent">><<set $speechotheranusimminent to 1>>
<</if>>
<<elseif $rng gte 1>><<He>> rubs your <<penis>> between <<his>> cheeks.<<sex 10>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<if $vagina6 is 0>>
<<if $enemyanger + $rng lte 20>><<He>> sways <<his>> hips suggestively.<<neutral 1>><<set $speechvaginaflaunt to 1>>
<<elseif $enemyanger + $rng lte 40>><<He>> twirls on the spot.<<neutral 3>><<set $speechvaginaflaunt to 1>>
<<elseif $enemyanger + $rng lte 50>>
<<if $penisexist is 1>>
<<if $penisuse is 0 and $analdisable is "f">>
<span class="blue"><<He>> straddles you, rubbing <<his>> ass against your <<penisstop>></span><<neutral 5>><<set $penisuse to "otheranus">><<set $vagina6 to "otheranusentrance">><<set $penisstate to "otheranusentrance">><<set $speechotheranusentrance to 1>>
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 60>><<He>> rubs <<his>> pussy against your thigh.<<neutral 10>>
<<elseif $enemyanger + $rng lte 80 and $lefthand6 is 0>>
<span class="lblue"><<He>> presses <<his>> fingers against <<his>> labia.</span><<neutral 1>><<set $enemyarousal += 10>><<set $vagina6 to "lefthand">><<set $lefthand6 to "othervagina">>
<<elseif $enemyanger + $rng lte 80 and $righthand6 is 0>>
<span class="lblue"><<He>> presses <<his>> fingers against <<his>> labia.</span><<neutral 1>><<set $enemyarousal += 10>><<set $vagina6 to "righthand">><<set $righthand6 to "othervagina">>
<<elseif $enemyanger + $rng lte 80>>
<<He>> rubs <<his>> pussy against your thigh.<<neutral 2>>
<<elseif $enemyanger + $rng lte 100 and $penisuse is 0 and $undervaginaexposed is 1 and $lowervaginaexposed is 1>>
<<set $penisuse to "othervagina">><<set $vagina6 to "penisentrance">><<set $penisstate to "entrance">><span class="blue"><<He>> straddles you, <<his>> pussy hovering close to your <<penisstop>></span>
<<elseif $enemyanger + $rng lte 120 and $penisuse is 0 and $penisexist is 1 and $undervaginaexposed is 1 and $lowervaginaexposed is 1>>
<<set $penisuse to "othervagina">><<set $vagina6 to "penisimminent">><<set $penisstate to "imminent">><span class="purple"><<He>> wraps <<his>> legs around your pelvis, pressing <<his>> pussy against your <<genitalsstop>></span>
<<elseif $enemyanger + $rng lte 120 and $vaginause is 0 and $vaginaexist is 1 and $undervaginaexposed is 1 and $lowervaginaexposed is 1>>
<<set $vaginause to "othervagina">><<set $vagina6 to "vagina">><<sex 20>><<He>> pushes <<his>> pussy against yours.
<<elseif $enemyanger + $rng lte 140>>
<<if $position is "wall">>
<<He>> sits on your protruding <<bottomcomma>> pressing down on you painfully.<<violence 3>>
<<elseif $mouth6 is 0>>
<<He>> rubs <<his>> clit against your face.<<violence 3>>
<<else>>
<<He>> frots against your thigh while squeezing it with <<his>> own.<<violence 3>>
<</if>>
<<elseif $enemyanger + $rng lte 160>><span class="purple"><<He>> presses <<his>> foot against your <<genitalsstop>></span><<neutral 5>><<set $vagina6 to "footjob">>
<<if $penisexist is 1>>
<<set $penisuse to "feet">><<set $speechpenisfoot to 1>>
<<else>>
<<set $vaginause to "feet">><<set $speechvaginafoot to 1>>
<</if>>
<<elseif $enemyanger + $rng lte 180>>
<<if $position is "wall">>
<<He>> kicks you in the <<bottomstop>><<violence 10>><<hitstat>><<bruise bottom>>
<<else>>
<<He>> kicks you in the stomach.<<violence 10>><<hitstat>><<bruise face>>
<</if>>
<<elseif $enemyanger + $rng lte 200 and $mouthuse is 0>>
<<if $pullaway is 1>><<set $pullaway to 0>>
Saliva drips from her pussy.
<<else>>
<<if $position is "wall">>
<<if $penisexist is 1>>
<<He>> kicks your <<penisstop>><<violence 20>><<hitstat>><<bruise penis>><<set $speechbeat to 1>>
<<elseif $vaginaexist is 1>>
<<He>> kicks your <<pussystop>><<violence 20>><<hitstat>><<bruise vagina>><<set $speechbeat to 1>>
<</if>>
<<else>>
<span class="purple"><<He>> wraps <<his>> legs around your head and presses <<his>> pussy against your mouth.</span>
<<submission 5>><<set $mouthuse to "othervagina">><<set $vagina6 to "mouth">><<set $mouthstate to "othervagina">><<violence 3>><<bruise face>><<set $speechvaginamouth to 1>>
<</if>>
<</if>>
<<else>>
<<if $position is "wall">>
<<if $penisexist is 1>>
<<He>> kicks your <<penisstop>><<violence 20>><<hitstat>><<bruise penis>><<set $speechbeat to 1>>
<<elseif $vaginaexist is 1>>
<<He>> kicks your <<pussystop>><<violence 20>><<hitstat>><<bruise vagina>><<set $speechbeat to 1>>
<</if>>
<<else>>
<<He>> kicks you in the face.<<violence 10>><<bruise face>><<set $speechbeat to 1>><<hitstat>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth6 is "thigh">>
<<He>> kisses and licks your thigh.<<neutral 5>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth6 is "bottom">>
<<He>> kisses and licks your <<bottomstop>><<neutral 5>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth6 is "anus">>
<<if $rng gte 101>><span class="purple"><<He>> retracts <<his>> tongue from your anus.</span><<sex 30>><<set $mouth6 to "anusimminent">><<bruise anus>><<violence 1>><<set $anusstate to "othermouthimminent">>
<<elseif $rng gte 1>>
<<if $enemyarousal lte ($enemyarousalmax / 5)>>
<<He>> caresses your anus with <<his>> tongue.<<sex 30>><<bruise anus>><<violence 1>>
<<elseif $enemyarousal lte (($enemyarousalmax / 5) * 2)>>
<<His>> tongue probes inside your <<bottomstop>><<sex 30>><<bruise anus>><<violence 1>>
<<elseif $enemyarousal lte (($enemyarousalmax / 5) * 3)>>
<<He>> circles <<his>> tongue inside your <<bottomstop>><<sex 30>><<bruise anus>><<violence 1>>
<<elseif $enemyarousal lte (($enemyarousalmax / 5) * 4)>>
<<He>> presses <<his>> mouth firmly against your <<bottomcomma>> letting <<him>> push <<his>> tongue deeper into your anus.<<sex 30>><<bruise anus>><<violence 1>>
<<else>>
Repeatedly thrusting and retracting, <<he>> fucks your <<bottom>> with <<his>> tongue.<<sex 30>><<bruise anus>><<violence 1>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth6 is "anusimminent">>
<<if $rng gte 101>><span class="blue"><<He>> stops pressing <<his>> tongue against your anus.</span><<set $mouth6 to "anusentrance">><<set $anusstate to "othermouthentrance">>
<<elseif $rng gte 1>>
<<if $noanal is 0>>
<<if $analvirginity is 0>><span class="pink"><<He>> pushes <<his>> tongue into your anus.</span><<sex 30>><<set $mouth6 to "anus">><<analstat>><<bruise anus>><<violence 1>><<raped>><<set $anusstate to "othermouth">>
<<elseif $analvirginity is 1>><span class="pink"><<He>> pushes <<his>> tongue into your virgin anus,</span><span class="red"> violating you in a way you hadn't conceived of.</span><<sex 100>><<set $mouth6 to "anus">><<set $analvirginity to 0>><<bruise anus>><<analstat>><<violence 100>><<raped>><<set $anusstate to "othermouth">>
<</if>>
<<else>>
Respecting your wishes, <<he>> does not penetrate your <<bottom>> with <<his>> tongue, instead licking your anus.<<sex 15>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth6 is "anusentrance">>
<<if $rng gte 101>><span class="lblue"><<He>> moves <<his>> head away from your <<bottomstop>></span><<set $mouth6 to 0>><<set $anususe to 0>><<set $anusstate to 0>>
<<if $vagina6 is "othermouth">>
<<set $vagina6 to 0>>
<</if>>
<<if $penis6 is "othermouth">>
<<set $penis6 to 0>>
<</if>>
<<elseif $rng gte 1>>
<<if $loweranusexposed is 0>><<He>> circles <<his>> tongue around your anus through your $lowerclothes.<<sex 5>><<set $lowerintegrity -= 10>>
<<elseif $loweranusexposed is 1>><<set $rng to random(1, 100)>>
<<if $underanusexposed is 0>><<He>> circles <<his>> tongue around your anus through your $underclothes.<<sex 5>><<set $underintegrity -= 10>>
<<elseif $underanusexposed is 1>>
<<if $rng gte 71>>
<<if $noanal is 1>>
<span class="purple"><<He>> presses <<his>> tongue against your anus.</span><<sex 20>><<set $mouth6 to "anusimminent">><<set $anusstate to "othermouthimminent">>
<<else>>
<span class="purple"><<He>> presses <<his>> tongue against your anus, preparing to penetrate you.</span><<sex 20>><<set $mouth6 to "anusimminent">><<set $anusstate to "othermouthimminent">>
<</if>>
<<elseif $rng gte 1>><<He>> kisses and licks your <<bottomstop>><<sex 10>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth6 is "vagina">>
<<if $rng gte 101>><span class="purple"><<He>> retracts <<his>> tongue from your <<pussystop>></span><<sex 30>><<set $mouth6 to "vaginaimminent">><<bruise vagina>><<violence 1>><<set $vaginastate to "othermouthimminent">>
<<elseif $rng gte 1>>
<<if $enemyarousal lte ($enemyarousalmax / 5)>>
<<He>> caresses your vagina with <<his>> tongue.<<sex 30>><<bruise vagina>><<violence 1>>
<<elseif $enemyarousal lte (($enemyarousalmax / 5) * 2)>>
<<He>> presses down on your clit with <<his>> teeth while exploring your vagina with <<his>> tongue.<<sex 30>><<bruise vagina>><<violence 1>>
<<elseif $enemyarousal lte (($enemyarousalmax / 5) * 3)>>
<<He>> circles <<his>> tongue around your vagina.<<sex 30>><<bruise vagina>><<violence 1>>
<<elseif $enemyarousal lte (($enemyarousalmax / 5) * 4)>>
<<He>> presses <<his>> mouth firmly against your <<pussycomma>> then pushes <<his>> tongue deeper into your vagina. <<He>> slowly pulls out again, then takes a deep breath.<<sex 30>><<bruise vagina>><<violence 1>>
<<else>>
Repeatedly thrusting and retracting, <<he>> fucks your <<pussy>> with <<his>> tongue.<<sex 30>><<bruise vagina>><<violence 1>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth6 is "vaginaimminent">>
<<if $rng gte 101>><span class="blue"><<He>> stops pressing <<his>> tongue against your <<pussystop>></span><<set $mouth6 to "vaginaentrance">><<set $vaginastate to "othermouthentrance">>
<<elseif $rng gte 1>>
<<if $novaginal is 0>>
<<if $vaginalvirginity is 0>><span class="pink"><<He>> pushes <<his>> tongue between your <<pussy>> lips.</span><<sex 30>><<set $mouth6 to "vagina">><<vaginalstat>><<bruise vagina>><<violence 1>><<raped>><<vaginaraped>><<set $vaginastate to "othermouth">>
<<elseif $vaginalvirginity is 1>><span class="pink"><<He>> pushes <<his>> tongue into your virgin pussy,</span><span class="red"> breaking your hymen and forever robbing you of your purity.</span><<sex 100>><<set $mouth6 to "vagina">><<set $vaginalvirginity to 0>><<bruise vagina>><<vaginalstat>><<violence 100>><<raped>><<vaginaraped>><<set $vaginastate to "othermouth">>
<</if>>
<<else>>
Respecting your wishes, <<he>> does not penetrate your <<pussy>> with <<his>> tongue, instead running <<his>> tongue up and down your labia.<<sex 15>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth6 is "vaginaentrance">>
<<if $rng gte 101>><span class="lblue"><<He>> moves <<his>> head away from your <<pussystop>></span><<set $mouth6 to 0>><<set $vaginause to 0>><<set $vaginastate to 0>>
<<if $vagina6 is "othermouth">>
<<set $vagina6 to 0>>
<</if>>
<<if $penis6 is "othermouth">>
<<set $penis6 to 0>>
<</if>>
<<elseif $rng gte 1>>
<<if $lowervaginaexposed is 0>><<He>> traces the outline of your <<pussy>> with <<his>> tongue through your $lowerclothes.<<sex 5>><<set $lowerintegrity -= 10>>
<<elseif $lowervaginaexposed is 1>><<set $rng to random(1, 100)>>
<<if $undervaginaexposed is 0>><<He>> traces the outline of your <<pussy>> with <<his>> tongue through your $underclothes.<<sex 5>><<set $underintegrity -= 10>>
<<elseif $undervaginaexposed is 1>>
<<if $rng gte 71>>
<<if $novaginal is 1>>
<span class="purple"><<He>> presses <<his>> lips against your <<pussystop>></span><<sex 20>><<set $mouth6 to "vaginaimminent">><<set $vaginastate to "othermouthimminent">>
<<else>>
<span class="purple"><<He>> presses <<his>> lips against your <<pussycomma>> preparing to fuck you with <<his>> tongue.</span><<sex 20>><<set $mouth6 to "vaginaimminent">><<set $vaginastate to "othermouthimminent">>
<</if>>
<<elseif $rng gte 1>><<He>> blows on your clit and runs <<his>> tongue around your labia.<<sex 10>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth6 is "penis">>
<<if $rng gte 101>><span class="purple"><<He>> moves <<his>> head back, releasing your <<penis>> from <<his>> mouth.</span><<sex 30>><<set $mouth6 to "penisimminent">><<bruise penis>><<violence 1>><<set $penisstate to "othermouthimminent">>
<<elseif $rng gte 1>>
<<if $enemyarousal lte ($enemyarousalmax / 5)>>
<<He>> slowly caresses your shaft with <<his>> tongue.<<sex 30>><<bruise penis>><<violence 1>>
<<elseif $enemyarousal lte (($enemyarousalmax / 5) * 2)>>
Eyes fixed on your face, <<he>> wraps <<his>> tongue around your <<penis>> and sucks.<<sex 30>><<bruise penis>><<violence 1>>
<<elseif $enemyarousal lte (($enemyarousalmax / 5) * 3)>>
<<He>> squeezes <<his>> lips around your <<peniscomma>> and circles <<his>> tongue around your glans.<<sex 30>><<bruise penis>><<violence 1>>
<<elseif $enemyarousal lte (($enemyarousalmax / 5) * 4)>>
<<He>> takes you deeper into <<his>> mouth, until your <<penis>> disappears inside <<him>> completely. <<He>> slowly pushes you out again, then takes a deep breath.<<sex 30>><<bruise penis>><<violence 1>>
<<else>>
<<He>> repeatedly swallows and expels your <<peniscomma>> fucking you with <<his>> mouth.<<sex 30>><<bruise penis>><<violence 1>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth6 is "penisimminent">>
<<if $rng gte 101>><span class="blue"><<He>> stops pressing <<his>> lips against your <<penisstop>></span><<set $mouth6 to "penisentrance">><<set $penisstate to "othermouthentrance">>
<<elseif $rng gte 1>>
<<if $nopenile is 0>>
<<if $penilevirginity is 0>><span class="pink"><<He>> pushes <<his>> lips against your <<peniscomma>> taking you into <<his>> mouth.</span><<sex 30>><<set $mouth6 to "penis">><<penilestat>><<bruise penis>><<violence 1>><<raped>><<penisraped>><<set $penisstate to "othermouth">>
<<elseif $penilevirginity is 1>><span class="pink"><<He>> pushes <<his>> lips against your virgin penis, taking you into <<his>> mouth,</span><span class="red"> separating your foreskin from your glans and forever robbing you of your purity.</span><<sex 100>><<set $mouth6 to "penis">><<set $penilevirginity to 0>><<bruise penis>><<penilestat>><<violence 100>><<raped>><<penisraped>><<set $penisstate to "othermouth">>
<</if>>
<<else>>
Respecting your wishes, <<he>> does not envelope your <<penis>> with <<his>> mouth, instead kissing the tip of your glans.<<sex 15>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth6 is "penisentrance">>
<<if $rng gte 101>><span class="lblue"><<He>> moves <<his>> head away from your <<penisstop>></span><<set $mouth6 to 0>><<set $penisuse to 0>><<set $penisstate to 0>>
<<if $vagina6 is "othermouth">>
<<set $vagina6 to 0>>
<</if>>
<<if $penis6 is "othermouth">>
<<set $penis6 to 0>>
<</if>>
<<elseif $rng gte 1>>
<<if $lowervaginaexposed is 0>><<He>> traces the outline of your <<penis>> with <<his>> tongue through your $lowerclothes.<<sex 5>><<set $lowerintegrity -= 10>>
<<elseif $lowervaginaexposed is 1>><<set $rng to random(1, 100)>>
<<if $undervaginaexposed is 0>><<He>> traces the outline of your <<penis>> with <<his>> tongue through your $underclothes.<<sex 5>><<set $underintegrity -= 10>>
<<elseif $undervaginaexposed is 1>>
<<if $rng gte 71>>
<<if $nopenile is 1>>
<span class="purple"><<He>> presses <<his>> lips against your <<penisstop>></span><<sex 20>><<set $mouth6 to "penisimminent">><<set $penisstate to "othermouthimminent">>
<<else>>
<span class="purple"><<He>> presses <<his>> lips against your <<peniscomma>> preparing to take you in <<his>> mouth proper.</span><<sex 20>><<set $mouth6 to "penisimminent">><<set $penisstate to "othermouthimminent">>
<</if>>
<<elseif $rng gte 1>><<He>> blows on and licks the tip of your <<penisstop>><<sex 10>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth6 is "kiss">>
<<if $speechvaginavirgin isnot 1 and $speechpenisvirgin isnot 1 and $speechanusvirgin isnot 1 and $speechmouthvirgin isnot 1>>
<<if $rng gte 101>>
<span class="lblue"><<He>> pulls <<his>> mouth away from yours.</span><<set $mouth6 to 0>><<set $mouthuse to 0>><<set $mouthstate to 0>>
<<else>>
<<if $enemyanger lte 20>>
<<He>> explores your mouth with <<his>> tongue.<<sex 2>>
<<else>>
<<He>> thrusts <<his>> tongue deep into your mouth.<<violence 1>>
<</if>>
<</if>>
<<else>>
<span class="lblue"><<He>> pulls <<his>> mouth away from yours.</span><<set $mouthuse to 0>><<set $mouth6 to 0>><<set $mouthstate to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth6 is "kissimminent">>
<<if $speechvaginavirgin isnot 1 and $speechpenisvirgin isnot 1 and $speechanusvirgin isnot 1 and $speechmouthvirgin isnot 1>>
<<if $rng gte 101>>
<span class="lblue"><<He>> pulls <<his>> mouth away from yours.</span><<set $mouth6 to 0>><<set $mouthuse to 0>><<set $mouthstate to 0>>
<<elseif $rng lte 100>>
<<He>> pushes <<his>> tongue between your lips.<<set $mouth6 to "kiss">><<set $mouthstate to "kiss">><<sex 2>>
<<else>>
<<if $enemyanger lte 20>>
<<He>> gently probes your lips with <<his>> tongue.<<sex 2>>
<<else>>
<<He>> bites and toys with your lips.<<violence 1>>
<</if>>
<</if>>
<<else>>
<span class="lblue"><<He>> pulls <<his>> mouth away from yours.</span><<set $mouthuse to 0>><<set $mouth6 to 0>><<set $mouthstate to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth6 is "kissentrance">>
<<if $speechvaginavirgin isnot 1 and $speechpenisvirgin isnot 1 and $speechanusvirgin isnot 1 and $speechmouthvirgin isnot 1>>
<<if $rng gte 101>>
<span class="lblue"><<He>> pulls <<his>> mouth away from yours.</span><<set $mouth6 to 0>><<set $mouthuse to 0>><<set $mouthstate to 0>>
<<elseif $rng lte 100>>
<<He>> pulls you closer and presses your lips together in a kiss.<<set $mouth6 to "kissimminent">><<set $mouthstate to "kissimminent">><<sex 2>>
<<else>>
<<if $enemyanger lte 20>>
<<He>> gently brushes <<his>> lips against yours.<<sex 1>>
<<else>>
<<He>> bites your lower lip.<<violence 1>>
<</if>>
<</if>>
<<else>>
<span class="lblue"><<He>> pulls <<his>> mouth away from yours.</span><<set $mouthuse to 0>><<set $mouth6 to 0>><<set $mouthstate to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth6 is 0>>
<<if $speechvaginavirgin is 1>>
<<if $enemyanger lte 60>>
<<He>> speaks. "You were a virgin! I can't believe my luck!"
<<else>>
<<He>> speaks. "I felt your hymen tear bitch. Something to remember me by."
<</if>>
<<elseif $speechpenisvirgin is 1>>
<<if $enemyanger lte 60>>
<<He>> speaks. "AHH! This was your first time wasn't it? It feels so good!"
<<else>>
<<He>> speaks. "How's it feel to have your virgin dick broken in? Feels amazing for me."
<</if>>
<<elseif $speechanusvirgin is 1>>
<<if $enemyanger lte 60>>
<<He>> speaks. "It's so tight! This must be the first time your ass has been used like this."
<<else>>
<<He>> speaks. "It's so tight! This must be the first time your ass has been used like this. I've got plenty more work to do before you're properly broken in."
<</if>>
<<elseif $speechmouthvirgin is 1>>
<<if $enemyanger lte 60>>
<<He>> speaks. "Is this the first time you've tasted dick?"
<<else>>
<<He>> speaks. "Is this the first time you've tasted dick? You'll be a cum-addicted cock slave soon."
<</if>>
<<elseif $speechcum is 1 and $rng gte 61 and $speechorgasmrepeat lte 1 and $speechorgasmcount lte 6>>
<<cumspeech>>
<<elseif $rng gte 61>>
<<combatspeech>><<neutral 1>>
<<elseif $rng gte 91>>
<<basespeech>><<neutral 1>>
<<else>>
<<set $rng to random(1, 100)>>
<<if $enemyanger + $rng lte 20>><<He>> <<admires>> your body.<<neutral 1>>
<<elseif $enemyanger + $rng lte 25>>
<<if $position is "wall">>
<<He>> <<admires>> your helpless <<bottomstop>><<neutral 1>>
<<else>>
<<He>> <<admires>> your hair.<<neutral 1>>
<</if>>
<<elseif $enemyanger + $rng lte 30>>
<<if $position is "wall">>
<<He>> <<admires>> your helpless hips.<<neutral 1>>
<<else>>
<<He>> <<admires>> your chest.<<neutral 1>>
<</if>>
<<elseif $enemyanger + $rng lte 35>>
<<He>> <<admires>> your legs.<<neutral 1>>
<<elseif $enemyanger + $rng lte 40>>
<<if $position is "wall">>
<<He>> <<admires>> your helpless legs.<<neutral 1>>
<<else>>
<<He>> <<admires>> your face.<<neutral 1>>
<</if>>
<<elseif $enemyanger + $rng lte 45>>
<<if $position is "wall">>
<<He>> kisses your helpless thighs.<<neutral 3>>
<<else>>
<<He>> kisses you on the forehead.<<neutral 3>>
<</if>>
<<elseif $enemyanger + $rng lte 50>>
<<if $position is "wall">>
<<He>> kisses you on the hips.<<neutral 3>>
<<else>>
<<He>> kisses you on the cheek.<<neutral 3>>
<</if>>
<<elseif $enemyanger + $rng lte 55>>
<<if $position is "wall">>
<<He>> licks your helpless thighs.<<neutral 3>>
<<else>>
<<He>> kisses your neck.<<neutral 3>>
<</if>>
<<elseif $enemyanger + $rng lte 60>>
<<if $position is "wall">>
<<He>> licks your helpless hips.<<neutral 3>>
<<else>>
<<He>> licks your cheek.<<neutral 3>>
<</if>>
<<elseif $enemyanger + $rng lte 80>><<neutral 10>>
<<if $position is "wall">>
<<He>> licks your helpless legs.<<neutral 3>>
<<else>>
<<if $mouthuse is 0>>
<span class="blue"><<He>> moves <<his>> lips close to yours, about to kiss.</span><<set $mouthuse to "kiss">><<set $mouthstate to "kissentrance">><<set $mouth6 to "kissentrance">><<sex 1>>
<<else>>
<<He>> licks your cheek.
<</if>>
<</if>>
<<elseif $enemyanger + $rng lte 84>><<neutral 10>>
<<if $anususe is 0 and $vagina6 is 0 and $analdisable is "f">>
<span class="blue"><<He>> kneels behind you. You feel <<his>> breath on your <<bottomstop>></span><<set $anususe to "othermouth">><<set $anusstate to "othermouthentrance">><<set $mouth6 to "anusentrance">><<set $vagina6 to "othermouth">><<sex 1>>
<<elseif $anususe is 0 and $penis6 is 0 and $analdisable is "f">>
<span class="blue"><<He>> kneels behind you. You feel <<his>> breath on your <<bottomstop>></span><<set $anususe to "othermouth">><<set $anusstate to "othermouthentrance">><<set $mouth6 to "anusentrance">><<set $penis6 to "othermouth">><<sex 1>>
<</if>>
<<elseif $enemyanger + $rng lte 92>><<neutral 10>>
<<if $vaginause is 0 and $vagina6 is 0 and $vaginaexist is 1>>
<span class="blue"><<He>> kneels beside you. You feel <<his>> breath on your <<pussystop>></span><<set $vaginause to "othermouth">><<set $vaginastate to "othermouthentrance">><<set $mouth6 to "vaginaentrance">><<set $vagina6 to "othermouth">><<sex 1>>
<<elseif $vaginause is 0 and $penis6 is 0 and $vaginaexist is 1>>
<span class="blue"><<He>> kneels beside you. You feel <<his>> breath on your <<pussystop>></span><<set $vaginause to "othermouth">><<set $vaginastate to "othermouthentrance">><<set $mouth6 to "vaginaentrance">><<set $penis6 to "othermouth">><<sex 1>>
<<else>>
<<He>> breathes on your skin, making your hair stand on end.<<neutral 1>>
<</if>>
<<elseif $enemyanger + $rng lte 100>><<neutral 10>>
<<if $penisuse is 0 and $penis6 is 0 and $penisexist is 1>>
<span class="blue"><<He>> kneels beside you. You feel <<his>> breath on your <<penisstop>></span><<set $penisuse to "othermouth">><<set $penisstate to "othermouthentrance">><<set $mouth6 to "penisentrance">><<set $vagina6 to "othermouth">><<sex 1>>
<<elseif $penisuse is 0 and $vagina6 is 0 and $penisexist is 1>>
<span class="blue"><<He>> kneels beside you. You feel <<his>> breath on your <<penisstop>></span><<set $penisuse to "othermouth">><<set $penisstate to "othermouthentrance">><<set $mouth6 to "penisentrance">><<set $penis6 to "othermouth">><<sex 1>>
<<else>>
<<He>> breathes on your skin, making your hair stand on end.<<neutral 1>>
<</if>>
<<elseif $enemyanger + $rng lte 105>>
<<if $position is "wall">>
<<He>> kisses and caresses your helpless thighs with <<his>> tongue.<<neutral 10>>
<<else>>
<<He>> kisses and caresses your nipple with <<his>> tongue.<<neutral 10>>
<</if>>
<<elseif $enemyanger + $rng lte 110>>
<<if $position is "wall">>
<<He>> kisses and gently bites your helpless <<bottomstop>><<neutral 10>>
<<else>>
<<He>> kisses and gently bites you on the neck.<<neutral 10>>
<</if>>
<<elseif $enemyanger + $rng lte 115>>
<<He>> spits on your <<genitalsstop>><<neutral 5>>
<<elseif $enemyanger + $rng lte 120>>
<<He>> spits on your <<bottomstop>><<neutral 5>>
<<elseif $enemyanger + $rng lte 130>>
<<He>> spits on your stomach.<<neutral 5>>
<<elseif $enemyanger + $rng lte 140>>
<<if $position is "wall">>
<<He>> spits on your helpless thighs.<<neutral 5>>
<<else>>
<<He>> spits on your face.<<neutral 5>>
<</if>>
<<elseif $enemyanger + $rng lte 150>>
<<He>> bites your <<bottomstop>><<violence 10>><<hitstat>><<bruise bottom>>
<<elseif $enemyanger + $rng lte 160>>
<<if $position is "wall">>
<<He>> bites your thighs.<<violence 10>><<hitstat>><<bruise thigh>>
<<else>>
<<He>> bites your shoulders.<<violence 10>><<hitstat>><<bruise leftarm>><<bruise rightarm>>
<</if>>
<<elseif $enemyanger + $rng lte 170>>
<<if $position is "wall">>
<<He>> bites your hips.<<violence 10>><<hitstat>><<bruise tummy>>
<<else>>
<<He>> bites your neck.<<violence 10>><<hitstat>><<bruise neck>>
<</if>>
<<elseif $enemyanger + $rng lte 180>>
<<if $position is "wall">>
<<He>> bites your thighs.<<violence 10>><<hitstat>><<bruise thigh>>
<<else>>
<<He>> bites your cheek.<<violence 10>><<hitstat>><<bruise face>>
<</if>>
<<elseif $enemyanger + $rng gte 190>>
<<if $position is "wall">>
<<He>> bites your <<bottomstop>><<violence 10>><<hitstat>><<bruise bottom>>
<<else>>
<<He>> bites your <<breastsstop>><<violence 10>><<hitstat>><<bruise chest>>
<</if>>
<</if>>
<</if>>
<</if>>
<<manend>>
<<set $pullaway to 0>>
<</nobr>><</widget>>
:: Widgets NPC Generation [widget]
<<widget "generate1">><<nobr>>
<<set $rng to random(1, 100)>>
<<if $malechance lt $rng>>
<<set $gender1 to "f">><<set $pronoun1 to "f">>
<<else>>
<<set $gender1 to "m">><<set $pronoun1 to "m">>
<</if>>
<<set $lefthand to 0>>
<<set $righthand to 0>>
<<set $mouth to 0>>
<<npcattributes1>>
<<set $npcchild1 to 0>>
<<set $npcadult1 to 1>>
<<set $enemyno += 1>>
<<description1>>
<</nobr>><</widget>>
<<widget "generate2">><<nobr>>
<<set $rng to random(1, 100)>>
<<if $malechance lt $rng>>
<<set $gender2 to "f">><<set $pronoun2 to "f">>
<<else>>
<<set $gender2 to "m">><<set $pronoun2 to "m">>
<</if>>
<<set $lefthand2 to 0>>
<<set $righthand2 to 0>>
<<set $mouth2 to 0>>
<<npcattributes2>>
<<set $npcchild2 to 0>>
<<set $npcadult2 to 1>>
<<set $enemyno += 1>>
<<description2>>
<</nobr>><</widget>>
<<widget "generate3">><<nobr>>
<<set $rng to random(1, 100)>>
<<if $malechance lt $rng>>
<<set $gender3 to "f">><<set $pronoun3 to "f">>
<<else>>
<<set $gender3 to "m">><<set $pronoun3 to "m">>
<</if>>
<<set $lefthand3 to 0>>
<<set $righthand3 to 0>>
<<set $mouth3 to 0>>
<<npcattributes3>>
<<set $npcchild3 to 0>>
<<set $npcadult3 to 1>>
<<set $enemyno += 1>>
<<description3>>
<</nobr>><</widget>>
<<widget "generate4">><<nobr>>
<<set $rng to random(1, 100)>>
<<if $malechance lt $rng>>
<<set $gender4 to "f">><<set $pronoun4 to "f">>
<<else>>
<<set $gender4 to "m">><<set $pronoun4 to "m">>
<</if>>
<<set $lefthand4 to 0>>
<<set $righthand4 to 0>>
<<set $mouth4 to 0>>
<<npcattributes4>>
<<set $npcchild4 to 0>>
<<set $npcadult4 to 1>>
<<set $enemyno += 1>>
<<description4>>
<</nobr>><</widget>>
<<widget "generate5">><<nobr>>
<<set $rng to random(1, 100)>>
<<if $malechance lt $rng>>
<<set $gender5 to "f">><<set $pronoun5 to "f">>
<<else>>
<<set $gender5 to "m">><<set $pronoun5 to "m">>
<</if>>
<<set $lefthand5 to 0>>
<<set $righthand5 to 0>>
<<set $mouth5 to 0>>
<<npcattributes5>>
<<set $npcchild5 to 0>>
<<set $npcadult5 to 1>>
<<set $enemyno += 1>>
<<description5>>
<</nobr>><</widget>>
<<widget "generate6">><<nobr>>
<<set $rng to random(1, 100)>>
<<if $malechance lt $rng>>
<<set $gender6 to "f">><<set $pronoun6 to "f">>
<<else>>
<<set $gender6 to "m">><<set $pronoun6 to "m">>
<</if>>
<<set $lefthand6 to 0>>
<<set $righthand6 to 0>>
<<set $mouth6 to 0>>
<<npcattributes6>>
<<set $npcchild6 to 0>>
<<set $npcadult6 to 1>>
<<set $enemyno += 1>>
<<description6>>
<</nobr>><</widget>>
<<widget "generatey1">><<nobr>>
<<set $rng to random(1, 100)>>
<<if $malechance lt $rng>>
<<set $gender1 to "f">><<set $pronoun1 to "f">>
<<else>>
<<set $gender1 to "m">><<set $pronoun1 to "m">>
<</if>>
<<set $lefthand to 0>>
<<set $righthand to 0>>
<<set $mouth to 0>>
<<npcattributes1>>
<<set $npcchild1 to 0>>
<<set $npcadult1 to 0>>
<<set $enemyno += 1>>
<<description1>>
<</nobr>><</widget>>
<<widget "generatey2">><<nobr>>
<<set $rng to random(1, 100)>>
<<if $malechance lt $rng>>
<<set $gender2 to "f">><<set $pronoun2 to "f">>
<<else>>
<<set $gender2 to "m">><<set $pronoun2 to "m">>
<</if>>
<<set $lefthand2 to 0>>
<<set $righthand2 to 0>>
<<set $mouth2 to 0>>
<<npcattributes2>>
<<set $npcchild2 to 0>>
<<set $npcadult2 to 0>>
<<set $enemyno += 1>>
<<description2>>
<</nobr>><</widget>>
<<widget "generatey3">><<nobr>>
<<set $rng to random(1, 100)>>
<<if $malechance lt $rng>>
<<set $gender3 to "f">><<set $pronoun3 to "f">>
<<else>>
<<set $gender3 to "m">><<set $pronoun3 to "m">>
<</if>>
<<set $lefthand3 to 0>>
<<set $righthand3 to 0>>
<<set $mouth3 to 0>>
<<npcattributes3>>
<<set $npcchild3 to 0>>
<<set $npcadult3 to 0>>
<<set $enemyno += 1>>
<<description3>>
<</nobr>><</widget>>
<<widget "generatey4">><<nobr>>
<<set $rng to random(1, 100)>>
<<if $malechance lt $rng>>
<<set $gender4 to "f">><<set $pronoun4 to "f">>
<<else>>
<<set $gender4 to "m">><<set $pronoun4 to "m">>
<</if>>
<<set $lefthand4 to 0>>
<<set $righthand4 to 0>>
<<set $mouth4 to 0>>
<<npcattributes4>>
<<set $npcchild4 to 0>>
<<set $npcadult4 to 0>>
<<set $enemyno += 1>>
<<description4>>
<</nobr>><</widget>>
<<widget "generatey5">><<nobr>>
<<set $rng to random(1, 100)>>
<<if $malechance lt $rng>>
<<set $gender5 to "f">><<set $pronoun5 to "f">>
<<else>>
<<set $gender5 to "m">><<set $pronoun5 to "m">>
<</if>>
<<set $lefthand5 to 0>>
<<set $righthand5 to 0>>
<<set $mouth5 to 0>>
<<npcattributes5>>
<<set $npcchild5 to 0>>
<<set $npcadult5 to 0>>
<<set $enemyno += 1>>
<<description5>>
<</nobr>><</widget>>
<<widget "generatey6">><<nobr>>
<<set $rng to random(1, 100)>>
<<if $malechance lt $rng>>
<<set $gender6 to "f">><<set $pronoun6 to "f">>
<<else>>
<<set $gender6 to "m">><<set $pronoun6 to "m">>
<</if>>
<<set $lefthand6 to 0>>
<<set $righthand6 to 0>>
<<set $mouth6 to 0>>
<<npcattributes6>>
<<set $npcchild6 to 0>>
<<set $npcadult6 to 0>>
<<set $enemyno += 1>>
<<description6>>
<</nobr>><</widget>>
<<widget "generatec1">><<nobr>>
<<set $rng to random(1, 100)>>
<<if $malechance lt $rng>>
<<set $gender1 to "f">><<set $pronoun1 to "f">>
<<else>>
<<set $gender1 to "m">><<set $pronoun1 to "m">>
<</if>>
<<set $lefthand to 0>>
<<set $righthand to 0>>
<<set $mouth to 0>>
<<npcattributes1>>
<<set $npcchild1 to 1>>
<<set $npcadult1 to 0>>
<<set $enemyno += 1>>
<<description1>>
<</nobr>><</widget>>
<<widget "generatec2">><<nobr>>
<<set $rng to random(1, 100)>>
<<if $malechance lt $rng>>
<<set $gender2 to "f">><<set $pronoun2 to "f">>
<<else>>
<<set $gender2 to "m">><<set $pronoun2 to "m">>
<</if>>
<<set $lefthand2 to 0>>
<<set $righthand2 to 0>>
<<set $mouth2 to 0>>
<<npcattributes2>>
<<set $npcchild2 to 1>>
<<set $npcadult2 to 0>>
<<set $enemyno += 1>>
<<description2>>
<</nobr>><</widget>>
<<widget "generatec3">><<nobr>>
<<set $rng to random(1, 100)>>
<<if $malechance lt $rng>>
<<set $gender3 to "f">><<set $pronoun3 to "f">>
<<else>>
<<set $gender3 to "m">><<set $pronoun3 to "m">>
<</if>>
<<set $lefthand3 to 0>>
<<set $righthand3 to 0>>
<<set $mouth3 to 0>>
<<npcattributes3>>
<<set $npcchild3 to 1>>
<<set $npcadult3 to 0>>
<<set $enemyno += 1>>
<<description3>>
<</nobr>><</widget>>
<<widget "generatec4">><<nobr>>
<<set $rng to random(1, 100)>>
<<if $malechance lt $rng>>
<<set $gender4 to "f">><<set $pronoun4 to "f">>
<<else>>
<<set $gender4 to "m">><<set $pronoun4 to "m">>
<</if>>
<<set $lefthand4 to 0>>
<<set $righthand4 to 0>>
<<set $mouth4 to 0>>
<<npcattributes4>>
<<set $npcchild4 to 1>>
<<set $npcadult4 to 0>>
<<set $enemyno += 1>>
<<description4>>
<</nobr>><</widget>>
<<widget "generatec5">><<nobr>>
<<set $rng to random(1, 100)>>
<<if $malechance lt $rng>>
<<set $gender5 to "f">><<set $pronoun5 to "f">>
<<else>>
<<set $gender5 to "m">><<set $pronoun5 to "m">>
<</if>>
<<set $lefthand5 to 0>>
<<set $righthand5 to 0>>
<<set $mouth5 to 0>>
<<npcattributes5>>
<<set $npcchild5 to 1>>
<<set $npcadult5 to 0>>
<<set $enemyno += 1>>
<<description5>>
<</nobr>><</widget>>
<<widget "generatec6">><<nobr>>
<<set $rng to random(1, 100)>>
<<if $malechance lt $rng>>
<<set $gender6 to "f">><<set $pronoun6 to "f">>
<<else>>
<<set $gender6 to "m">><<set $pronoun6 to "m">>
<</if>>
<<set $lefthand6 to 0>>
<<set $righthand6 to 0>>
<<set $mouth6 to 0>>
<<npcattributes6>>
<<set $npcchild6 to 1>>
<<set $npcadult6 to 0>>
<<set $enemyno += 1>>
<<description6>>
<</nobr>><</widget>>
<<widget "generatel">><<nobr>>
<<if $location is "beach">>
<<if $enemyno is 0>>
<<generatey1>>
<<elseif $enemyno is 1>>
<<generatey2>>
<<elseif $enemyno is 2>>
<<generatey3>>
<<elseif $enemyno is 3>>
<<generatey4>>
<<elseif $enemyno is 4>>
<<generatey5>>
<<elseif $enemyno is 5>>
<<generatey6>>
<</if>>
<<else>>
<<if $enemyno is 0>>
<<generate1>>
<<elseif $enemyno is 1>>
<<generate2>>
<<elseif $enemyno is 2>>
<<generate3>>
<<elseif $enemyno is 3>>
<<generate4>>
<<elseif $enemyno is 4>>
<<generate5>>
<<elseif $enemyno is 5>>
<<generate6>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "generates1">><<nobr>>
<<if $devlevel gte 20>>
<<generate1>>
<<elseif $devlevel gte 12>>
<<generatey1>>
<<elseif $devlevel lte 11>>
<<generatec1>>
<</if>>
<</nobr>><</widget>>
<<widget "generates2">><<nobr>>
<<if $devlevel gte 20>>
<<generate2>>
<<elseif $devlevel gte 12>>
<<generatey2>>
<<elseif $devlevel lte 11>>
<<generatec2>>
<</if>>
<</nobr>><</widget>>
<<widget "generates3">><<nobr>>
<<if $devlevel gte 20>>
<<generate3>>
<<elseif $devlevel gte 12>>
<<generatey3>>
<<elseif $devlevel lte 11>>
<<generatec3>>
<</if>>
<</nobr>><</widget>>
<<widget "generates4">><<nobr>>
<<if $devlevel gte 20>>
<<generate4>>
<<elseif $devlevel gte 12>>
<<generatey4>>
<<elseif $devlevel lte 11>>
<<generatec4>>
<</if>>
<</nobr>><</widget>>
<<widget "generates5">><<nobr>>
<<if $devlevel gte 20>>
<<generate5>>
<<elseif $devlevel gte 12>>
<<generatey5>>
<<elseif $devlevel lte 11>>
<<generatec5>>
<</if>>
<</nobr>><</widget>>
<<widget "generates6">><<nobr>>
<<if $devlevel gte 20>>
<<generate6>>
<<elseif $devlevel gte 12>>
<<generatey6>>
<<elseif $devlevel lte 11>>
<<generatec6>>
<</if>>
<</nobr>><</widget>>
<<widget "generatesm1">><<nobr>>
<<if $devlevel gte 20>>
<<generatem1>>
<<elseif $devlevel gte 12>>
<<generateym1>>
<<elseif $devlevel lte 11>>
<<generatecm1>>
<</if>>
<</nobr>><</widget>>
<<widget "generatesm2">><<nobr>>
<<if $devlevel gte 20>>
<<generatem2>>
<<elseif $devlevel gte 12>>
<<generateym2>>
<<elseif $devlevel lte 11>>
<<generatecm2>>
<</if>>
<</nobr>><</widget>>
<<widget "generatesm3">><<nobr>>
<<if $devlevel gte 20>>
<<generatem3>>
<<elseif $devlevel gte 12>>
<<generateym3>>
<<elseif $devlevel lte 11>>
<<generatecm3>>
<</if>>
<</nobr>><</widget>>
<<widget "generatesm4">><<nobr>>
<<if $devlevel gte 20>>
<<generatem4>>
<<elseif $devlevel gte 12>>
<<generateym4>>
<<elseif $devlevel lte 11>>
<<generatecm4>>
<</if>>
<</nobr>><</widget>>
<<widget "generatesm5">><<nobr>>
<<if $devlevel gte 20>>
<<generatem5>>
<<elseif $devlevel gte 12>>
<<generateym5>>
<<elseif $devlevel lte 11>>
<<generatecm5>>
<</if>>
<</nobr>><</widget>>
<<widget "generatesm6">><<nobr>>
<<if $devlevel gte 20>>
<<generatem6>>
<<elseif $devlevel gte 12>>
<<generateym6>>
<<elseif $devlevel lte 11>>
<<generatecm6>>
<</if>>
<</nobr>><</widget>>
<<widget "generatesf1">><<nobr>>
<<if $devlevel gte 20>>
<<generatef1>>
<<elseif $devlevel gte 12>>
<<generateyf1>>
<<elseif $devlevel lte 11>>
<<generatecf1>>
<</if>>
<</nobr>><</widget>>
<<widget "generatesf2">><<nobr>>
<<if $devlevel gte 20>>
<<generatef2>>
<<elseif $devlevel gte 12>>
<<generateyf2>>
<<elseif $devlevel lte 11>>
<<generatecf2>>
<</if>>
<</nobr>><</widget>>
<<widget "generatesf3">><<nobr>>
<<if $devlevel gte 20>>
<<generatef3>>
<<elseif $devlevel gte 12>>
<<generateyf3>>
<<elseif $devlevel lte 11>>
<<generatecf3>>
<</if>>
<</nobr>><</widget>>
<<widget "generatesf4">><<nobr>>
<<if $devlevel gte 20>>
<<generatef4>>
<<elseif $devlevel gte 12>>
<<generateyf4>>
<<elseif $devlevel lte 11>>
<<generatecf4>>
<</if>>
<</nobr>><</widget>>
<<widget "generatesf5">><<nobr>>
<<if $devlevel gte 20>>
<<generatef5>>
<<elseif $devlevel gte 12>>
<<generateyf5>>
<<elseif $devlevel lte 11>>
<<generatecf5>>
<</if>>
<</nobr>><</widget>>
<<widget "generatesf6">><<nobr>>
<<if $devlevel gte 20>>
<<generatef6>>
<<elseif $devlevel gte 12>>
<<generateyf6>>
<<elseif $devlevel lte 11>>
<<generatecf6>>
<</if>>
<</nobr>><</widget>>
<<widget "generatem1">><<nobr>>
<<set $gender1 to "m">><<set $pronoun1 to "m">>
<<set $lefthand to 0>>
<<set $righthand to 0>>
<<set $mouth to 0>>
<<npcattributes1>>
<<set $npcchild1 to 0>>
<<set $npcadult1 to 1>>
<<set $enemyno += 1>>
<<description1>>
<</nobr>><</widget>>
<<widget "generatem2">><<nobr>>
<<set $gender2 to "m">><<set $pronoun2 to "m">>
<<set $lefthand2 to 0>>
<<set $righthand2 to 0>>
<<set $mouth2 to 0>>
<<npcattributes2>>
<<set $npcchild2 to 0>>
<<set $npcadult2 to 1>>
<<set $enemyno += 1>>
<<description2>>
<</nobr>><</widget>>
<<widget "generatem3">><<nobr>>
<<set $gender3 to "m">><<set $pronoun3 to "m">>
<<set $lefthand3 to 0>>
<<set $righthand3 to 0>>
<<set $mouth3 to 0>>
<<npcattributes3>>
<<set $npcchild3 to 0>>
<<set $npcadult3 to 1>>
<<set $enemyno += 1>>
<<description3>>
<</nobr>><</widget>>
<<widget "generatem4">><<nobr>>
<<set $gender4 to "m">><<set $pronoun4 to "m">>
<<set $lefthand4 to 0>>
<<set $righthand4 to 0>>
<<set $mouth4 to 0>>
<<npcattributes4>>
<<set $npcchild4 to 0>>
<<set $npcadult4 to 1>>
<<set $enemyno += 1>>
<<description4>>
<</nobr>><</widget>>
<<widget "generatem5">><<nobr>>
<<set $gender5 to "m">><<set $pronoun5 to "m">>
<<set $lefthand5 to 0>>
<<set $righthand5 to 0>>
<<set $mouth5 to 0>>
<<npcattributes5>>
<<set $npcchild5 to 0>>
<<set $npcadult5 to 1>>
<<set $enemyno += 1>>
<<description5>>
<</nobr>><</widget>>
<<widget "generatem6">><<nobr>>
<<set $gender6 to "m">><<set $pronoun6 to "m">>
<<set $lefthand6 to 0>>
<<set $righthand6 to 0>>
<<set $mouth6 to 0>>
<<npcattributes6>>
<<set $npcchild6 to 0>>
<<set $npcadult6 to 1>>
<<set $enemyno += 1>>
<<description6>>
<</nobr>><</widget>>
<<widget "generatef1">><<nobr>>
<<set $gender1 to "f">><<set $pronoun1 to "f">>
<<set $lefthand to 0>>
<<set $righthand to 0>>
<<set $mouth to 0>>
<<npcattributes1>>
<<set $npcchild1 to 0>>
<<set $npcadult1 to 1>>
<<set $enemyno += 1>>
<<description1>>
<</nobr>><</widget>>
<<widget "generatef2">><<nobr>>
<<set $gender2 to "f">><<set $pronoun2 to "f">>
<<set $lefthand2 to 0>>
<<set $righthand2 to 0>>
<<set $mouth2 to 0>>
<<npcattributes2>>
<<set $npcchild2 to 0>>
<<set $npcadult2 to 1>>
<<set $enemyno += 1>>
<<description2>>
<</nobr>><</widget>>
<<widget "generatef3">><<nobr>>
<<set $gender3 to "f">><<set $pronoun3 to "f">>
<<set $lefthand3 to 0>>
<<set $righthand3 to 0>>
<<set $mouth3 to 0>>
<<npcattributes3>>
<<set $npcchild3 to 0>>
<<set $npcadult3 to 1>>
<<set $enemyno += 1>>
<<description3>>
<</nobr>><</widget>>
<<widget "generatef4">><<nobr>>
<<set $gender4 to "f">><<set $pronoun4 to "f">>
<<set $lefthand4 to 0>>
<<set $righthand4 to 0>>
<<set $mouth4 to 0>>
<<npcattributes4>>
<<set $npcchild4 to 0>>
<<set $npcadult4 to 1>>
<<set $enemyno += 1>>
<<description4>>
<</nobr>><</widget>>
<<widget "generatef5">><<nobr>>
<<set $gender5 to "f">><<set $pronoun5 to "f">>
<<set $lefthand5 to 0>>
<<set $righthand5 to 0>>
<<set $mouth5 to 0>>
<<npcattributes5>>
<<set $npcchild5 to 0>>
<<set $npcadult5 to 1>>
<<set $enemyno += 1>>
<<description5>>
<</nobr>><</widget>>
<<widget "generatef6">><<nobr>>
<<set $gender6 to "f">><<set $pronoun6 to "f">>
<<set $lefthand6 to 0>>
<<set $righthand6 to 0>>
<<set $mouth6 to 0>>
<<npcattributes6>>
<<set $npcchild6 to 0>>
<<set $npcadult6 to 1>>
<<set $enemyno += 1>>
<<description6>>
<</nobr>><</widget>>
<<widget "generateym1">><<nobr>>
<<set $gender1 to "m">><<set $pronoun1 to "m">>
<<set $lefthand to 0>>
<<set $righthand to 0>>
<<set $mouth to 0>>
<<npcattributes1>>
<<set $npcchild1 to 0>>
<<set $npcadult1 to 0>>
<<set $enemyno += 1>>
<<description1>>
<</nobr>><</widget>>
<<widget "generateym2">><<nobr>>
<<set $gender2 to "m">><<set $pronoun2 to "m">>
<<set $lefthand2 to 0>>
<<set $righthand2 to 0>>
<<set $mouth2 to 0>>
<<npcattributes2>>
<<set $npcchild2 to 0>>
<<set $npcadult2 to 0>>
<<set $enemyno += 1>>
<<description2>>
<</nobr>><</widget>>
<<widget "generateym3">><<nobr>>
<<set $gender3 to "m">><<set $pronoun3 to "m">>
<<set $lefthand3 to 0>>
<<set $righthand3 to 0>>
<<set $mouth3 to 0>>
<<npcattributes3>>
<<set $npcchild3 to 0>>
<<set $npcadult3 to 0>>
<<set $enemyno += 1>>
<<description3>>
<</nobr>><</widget>>
<<widget "generateym4">><<nobr>>
<<set $gender4 to "m">><<set $pronoun4 to "m">>
<<set $lefthand4 to 0>>
<<set $righthand4 to 0>>
<<set $mouth4 to 0>>
<<npcattributes4>>
<<set $npcchild4 to 0>>
<<set $npcadult4 to 0>>
<<set $enemyno += 1>>
<<description4>>
<</nobr>><</widget>>
<<widget "generateym5">><<nobr>>
<<set $gender5 to "m">><<set $pronoun5 to "m">>
<<set $lefthand5 to 0>>
<<set $righthand5 to 0>>
<<set $mouth5 to 0>>
<<npcattributes5>>
<<set $npcchild5 to 0>>
<<set $npcadult5 to 0>>
<<set $enemyno += 1>>
<<description5>>
<</nobr>><</widget>>
<<widget "generateym6">><<nobr>>
<<set $gender6 to "m">><<set $pronoun6 to "m">>
<<set $lefthand6 to 0>>
<<set $righthand6 to 0>>
<<set $mouth6 to 0>>
<<npcattributes6>>
<<set $npcchild6 to 0>>
<<set $npcadult6 to 0>>
<<set $enemyno += 1>>
<<description6>>
<</nobr>><</widget>>
<<widget "generateyf1">><<nobr>>
<<set $gender1 to "f">><<set $pronoun1 to "f">>
<<set $lefthand to 0>>
<<set $righthand to 0>>
<<set $mouth to 0>>
<<npcattributes1>>
<<set $npcchild1 to 0>>
<<set $npcadult1 to 0>>
<<set $enemyno += 1>>
<<description1>>
<</nobr>><</widget>>
<<widget "generateyf2">><<nobr>>
<<set $gender2 to "f">><<set $pronoun2 to "f">>
<<set $lefthand2 to 0>>
<<set $righthand2 to 0>>
<<set $mouth2 to 0>>
<<npcattributes2>>
<<set $npcchild2 to 0>>
<<set $npcadult2 to 0>>
<<set $enemyno += 1>>
<<description2>>
<</nobr>><</widget>>
<<widget "generateyf3">><<nobr>>
<<set $gender3 to "f">><<set $pronoun3 to "f">>
<<set $lefthand3 to 0>>
<<set $righthand3 to 0>>
<<set $mouth3 to 0>>
<<npcattributes3>>
<<set $npcchild3 to 0>>
<<set $npcadult3 to 0>>
<<set $enemyno += 1>>
<<description3>>
<</nobr>><</widget>>
<<widget "generateyf4">><<nobr>>
<<set $gender4 to "f">><<set $pronoun4 to "f">>
<<set $lefthand4 to 0>>
<<set $righthand4 to 0>>
<<set $mouth4 to 0>>
<<npcattributes4>>
<<set $npcchild4 to 0>>
<<set $npcadult4 to 0>>
<<set $enemyno += 1>>
<<description4>>
<</nobr>><</widget>>
<<widget "generateyf5">><<nobr>>
<<set $gender5 to "f">><<set $pronoun5 to "f">>
<<set $lefthand5 to 0>>
<<set $righthand5 to 0>>
<<set $mouth5 to 0>>
<<npcattributes5>>
<<set $npcchild5 to 0>>
<<set $npcadult5 to 0>>
<<set $enemyno += 1>>
<<description5>>
<</nobr>><</widget>>
<<widget "generateyf6">><<nobr>>
<<set $gender6 to "f">><<set $pronoun6 to "f">>
<<set $lefthand6 to 0>>
<<set $righthand6 to 0>>
<<set $mouth6 to 0>>
<<npcattributes6>>
<<set $npcchild6 to 0>>
<<set $npcadult6 to 0>>
<<set $enemyno += 1>>
<<description6>>
<</nobr>><</widget>>
<<widget "generatecm1">><<nobr>>
<<set $gender1 to "m">><<set $pronoun1 to "m">>
<<set $lefthand to 0>>
<<set $righthand to 0>>
<<set $mouth to 0>>
<<npcattributes1>>
<<set $npcchild1 to 1>>
<<set $npcadult1 to 0>>
<<set $enemyno += 1>>
<<description1>>
<</nobr>><</widget>>
<<widget "generatecm2">><<nobr>>
<<set $gender2 to "m">><<set $pronoun2 to "m">>
<<set $lefthand2 to 0>>
<<set $righthand2 to 0>>
<<set $mouth2 to 0>>
<<npcattributes2>>
<<set $npcchild2 to 1>>
<<set $npcadult2 to 0>>
<<set $enemyno += 1>>
<<description2>>
<</nobr>><</widget>>
<<widget "generatecm3">><<nobr>>
<<set $gender3 to "m">><<set $pronoun3 to "m">>
<<set $lefthand3 to 0>>
<<set $righthand3 to 0>>
<<set $mouth3 to 0>>
<<npcattributes3>>
<<set $npcchild3 to 1>>
<<set $npcadult3 to 0>>
<<set $enemyno += 1>>
<<description3>>
<</nobr>><</widget>>
<<widget "generatecm4">><<nobr>>
<<set $gender4 to "m">><<set $pronoun4 to "m">>
<<set $lefthand4 to 0>>
<<set $righthand4 to 0>>
<<set $mouth4 to 0>>
<<npcattributes4>>
<<set $npcchild4 to 1>>
<<set $npcadult4 to 0>>
<<set $enemyno += 1>>
<<description4>>
<</nobr>><</widget>>
<<widget "generatecm5">><<nobr>>
<<set $gender5 to "m">><<set $pronoun5 to "m">>
<<set $lefthand5 to 0>>
<<set $righthand5 to 0>>
<<set $mouth5 to 0>>
<<npcattributes5>>
<<set $npcchild5 to 1>>
<<set $npcadult5 to 0>>
<<set $enemyno += 1>>
<<description5>>
<</nobr>><</widget>>
<<widget "generatecm6">><<nobr>>
<<set $gender6 to "m">><<set $pronoun6 to "m">>
<<set $lefthand6 to 0>>
<<set $righthand6 to 0>>
<<set $mouth6 to 0>>
<<npcattributes6>>
<<set $npcchild6 to 1>>
<<set $npcadult6 to 0>>
<<set $enemyno += 1>>
<<description6>>
<</nobr>><</widget>>
<<widget "generatecf1">><<nobr>>
<<set $gender1 to "f">><<set $pronoun1 to "f">>
<<set $lefthand to 0>>
<<set $righthand to 0>>
<<set $mouth to 0>>
<<npcattributes1>>
<<set $npcchild1 to 1>>
<<set $npcadult1 to 0>>
<<set $enemyno += 1>>
<<description1>>
<</nobr>><</widget>>
<<widget "generatecf2">><<nobr>>
<<set $gender2 to "f">><<set $pronoun2 to "f">>
<<set $lefthand2 to 0>>
<<set $righthand2 to 0>>
<<set $mouth2 to 0>>
<<npcattributes2>>
<<set $npcchild2 to 1>>
<<set $npcadult2 to 0>>
<<set $enemyno += 1>>
<<description2>>
<</nobr>><</widget>>
<<widget "generatecf3">><<nobr>>
<<set $gender3 to "f">><<set $pronoun3 to "f">>
<<set $lefthand3 to 0>>
<<set $righthand3 to 0>>
<<set $mouth3 to 0>>
<<npcattributes3>>
<<set $npcchild3 to 1>>
<<set $npcadult3 to 0>>
<<set $enemyno += 1>>
<<description3>>
<</nobr>><</widget>>
<<widget "generatecf4">><<nobr>>
<<set $gender4 to "f">><<set $pronoun4 to "f">>
<<set $lefthand4 to 0>>
<<set $righthand4 to 0>>
<<set $mouth4 to 0>>
<<npcattributes4>>
<<set $npcchild4 to 1>>
<<set $npcadult4 to 0>>
<<set $enemyno += 1>>
<<description4>>
<</nobr>><</widget>>
<<widget "generatecf5">><<nobr>>
<<set $gender5 to "f">><<set $pronoun5 to "f">>
<<set $lefthand5 to 0>>
<<set $righthand5 to 0>>
<<set $mouth5 to 0>>
<<npcattributes5>>
<<set $npcchild5 to 1>>
<<set $npcadult5 to 0>>
<<set $enemyno += 1>>
<<description5>>
<</nobr>><</widget>>
<<widget "generatecf6">><<nobr>>
<<set $gender6 to "f">><<set $pronoun6 to "f">>
<<set $lefthand6 to 0>>
<<set $righthand6 to 0>>
<<set $mouth6 to 0>>
<<npcattributes6>>
<<set $npcchild6 to 1>>
<<set $npcadult6 to 0>>
<<set $enemyno += 1>>
<<description6>>
<</nobr>><</widget>>
<<widget "npcattributes1">><<nobr>>
<<if $gender1 is "m">>
<<if random(0, 99) gte $cbchance>>
<<set $penis to "clothed">>
<<else>>
<<set $vagina to "clothed">>
<</if>>
<<elseif $gender1 is "f">>
<<if random(0, 99) gte $dgchance>>
<<set $vagina to "clothed">>
<<else>>
<<set $penis to "clothed">>
<</if>>
<</if>>
<<set $npcskinselector to ($whitechance + $blackchance)>>
<<if $npcskinselector is 0>>
<<set $npcskinselector to 1>>
<</if>>
<<set $whitechanceselector to (($whitechance / $npcskinselector) * 100)>>
<<set $blackchanceselector to (($blackchance / $npcskinselector) * 100)>>
<<if random(1, 100) lte $blackchanceselector>>
<<set $npcskin1 to "black">>
<<else>>
<<set $npcskin1 to "white">>
<</if>>
<<set $rng to random(1, 100)>>
<<if $rng gte 91>>
<<if $penis isnot "none">>
<<set $insecurity1 to "penis">>
<<else>>
<<set $insecurity1 to "vagina">>
<</if>>
<<elseif $rng gte 81>>
<<if $vagina isnot "none">>
<<set $insecurity1 to "vagina">>
<<else>>
<<set $insecurity1 to "penis">>
<</if>>
<<elseif $rng gte 61>>
<<set $insecurity1 to "ethics">>
<<elseif $rng gte 41>>
<<set $insecurity1 to "weak">>
<<elseif $rng gte 21>>
<<set $insecurity1 to "skill">>
<<else>>
<<set $insecurity1 to "looks">>
<</if>>
<</nobr>><</widget>>
<<widget "npcattributes2">><<nobr>>
<<if $gender2 is "m">>
<<if random(0, 99) gte $cbchance>>
<<set $penis2 to "clothed">>
<<else>>
<<set $vagina2 to "clothed">>
<</if>>
<<elseif $gender2 is "f">>
<<if random(0, 99) gte $dgchance>>
<<set $vagina2 to "clothed">>
<<else>>
<<set $penis2 to "clothed">>
<</if>>
<</if>>
<<set $npcskinselector to ($whitechance + $blackchance)>>
<<if $npcskinselector is 0>>
<<set $npcskinselector to 1>>
<</if>>
<<set $whitechanceselector to (($whitechance / $npcskinselector) * 100)>>
<<set $blackchanceselector to (($blackchance / $npcskinselector) * 100)>>
<<if random(1, 100) lte $blackchanceselector>>
<<set $npcskin2 to "black">>
<<else>>
<<set $npcskin2 to "white">>
<</if>>
<<set $rng to random(1, 100)>>
<<if $rng gte 91>>
<<if $penis2 isnot "none">>
<<set $insecurity2 to "penis">>
<<else>>
<<set $insecurity2 to "vagina">>
<</if>>
<<elseif $rng gte 81>>
<<if $vagina2 isnot "none">>
<<set $insecurity2 to "vagina">>
<<else>>
<<set $insecurity2 to "penis">>
<</if>>
<<elseif $rng gte 61>>
<<set $insecurity2 to "ethics">>
<<elseif $rng gte 41>>
<<set $insecurity2 to "weak">>
<<elseif $rng gte 21>>
<<set $insecurity2 to "skill">>
<<else>>
<<set $insecurity2 to "looks">>
<</if>>
<</nobr>><</widget>>
<<widget "npcattributes3">><<nobr>>
<<if $gender3 is "m">>
<<if random(0, 99) gte $cbchance>>
<<set $penis3 to "clothed">>
<<else>>
<<set $vagina3 to "clothed">>
<</if>>
<<elseif $gender3 is "f">>
<<if random(0, 99) gte $dgchance>>
<<set $vagina3 to "clothed">>
<<else>>
<<set $penis3 to "clothed">>
<</if>>
<</if>>
<<set $npcskinselector to ($whitechance + $blackchance)>>
<<if $npcskinselector is 0>>
<<set $npcskinselector to 1>>
<</if>>
<<set $whitechanceselector to (($whitechance / $npcskinselector) * 100)>>
<<set $blackchanceselector to (($blackchance / $npcskinselector) * 100)>>
<<if random(1, 100) lte $blackchanceselector>>
<<set $npcskin3 to "black">>
<<else>>
<<set $npcskin3 to "white">>
<</if>>
<<set $rng to random(1, 100)>>
<<if $rng gte 91>>
<<if $penis3 isnot "none">>
<<set $insecurity3 to "penis">>
<<else>>
<<set $insecurity3 to "vagina">>
<</if>>
<<elseif $rng gte 81>>
<<if $vagina3 isnot "none">>
<<set $insecurity3 to "vagina">>
<<else>>
<<set $insecurity3 to "penis">>
<</if>>
<<elseif $rng gte 61>>
<<set $insecurity3 to "ethics">>
<<elseif $rng gte 41>>
<<set $insecurity3 to "weak">>
<<elseif $rng gte 21>>
<<set $insecurity3 to "skill">>
<<else>>
<<set $insecurity3 to "looks">>
<</if>>
<</nobr>><</widget>>
<<widget "npcattributes4">><<nobr>>
<<if $gender4 is "m">>
<<if random(0, 99) gte $cbchance>>
<<set $penis4 to "clothed">>
<<else>>
<<set $vagina4 to "clothed">>
<</if>>
<<elseif $gender4 is "f">>
<<if random(0, 99) gte $dgchance>>
<<set $vagina4 to "clothed">>
<<else>>
<<set $penis4 to "clothed">>
<</if>>
<</if>>
<<set $npcskinselector to ($whitechance + $blackchance)>>
<<if $npcskinselector is 0>>
<<set $npcskinselector to 1>>
<</if>>
<<set $whitechanceselector to (($whitechance / $npcskinselector) * 100)>>
<<set $blackchanceselector to (($blackchance / $npcskinselector) * 100)>>
<<if random(1, 100) lte $blackchanceselector>>
<<set $npcskin4 to "black">>
<<else>>
<<set $npcskin4 to "white">>
<</if>>
<<set $rng to random(1, 100)>>
<<if $rng gte 91>>
<<if $penis4 isnot "none">>
<<set $insecurity4 to "penis">>
<<else>>
<<set $insecurity4 to "vagina">>
<</if>>
<<elseif $rng gte 81>>
<<if $vagina4 isnot "none">>
<<set $insecurity4 to "vagina">>
<<else>>
<<set $insecurity4 to "penis">>
<</if>>
<<elseif $rng gte 61>>
<<set $insecurity4 to "ethics">>
<<elseif $rng gte 41>>
<<set $insecurity4 to "weak">>
<<elseif $rng gte 21>>
<<set $insecurity4 to "skill">>
<<else>>
<<set $insecurity4 to "looks">>
<</if>>
<</nobr>><</widget>>
<<widget "npcattributes5">><<nobr>>
<<if $gender5 is "m">>
<<if random(0, 99) gte $cbchance>>
<<set $penis5 to "clothed">>
<<else>>
<<set $vagina5 to "clothed">>
<</if>>
<<elseif $gender5 is "f">>
<<if random(0, 99) gte $dgchance>>
<<set $vagina5 to "clothed">>
<<else>>
<<set $penis5 to "clothed">>
<</if>>
<</if>>
<<set $npcskinselector to ($whitechance + $blackchance)>>
<<if $npcskinselector is 0>>
<<set $npcskinselector to 1>>
<</if>>
<<set $whitechanceselector to (($whitechance / $npcskinselector) * 100)>>
<<set $blackchanceselector to (($blackchance / $npcskinselector) * 100)>>
<<if random(1, 100) lte $blackchanceselector>>
<<set $npcskin5 to "black">>
<<else>>
<<set $npcskin5 to "white">>
<</if>>
<<set $rng to random(1, 100)>>
<<if $rng gte 91>>
<<if $penis5 isnot "none">>
<<set $insecurity5 to "penis">>
<<else>>
<<set $insecurity5 to "vagina">>
<</if>>
<<elseif $rng gte 81>>
<<if $vagina5 isnot "none">>
<<set $insecurity5 to "vagina">>
<<else>>
<<set $insecurity5 to "penis">>
<</if>>
<<elseif $rng gte 61>>
<<set $insecurity5 to "ethics">>
<<elseif $rng gte 41>>
<<set $insecurity5 to "weak">>
<<elseif $rng gte 21>>
<<set $insecurity5 to "skill">>
<<else>>
<<set $insecurity5 to "looks">>
<</if>>
<</nobr>><</widget>>
<<widget "npcattributes6">><<nobr>>
<<if $gender6 is "m">>
<<if random(0, 99) gte $cbchance>>
<<set $penis6 to "clothed">>
<<else>>
<<set $vagina6 to "clothed">>
<</if>>
<<elseif $gender6 is "f">>
<<if random(0, 99) gte $dgchance>>
<<set $vagina6 to "clothed">>
<<else>>
<<set $penis6 to "clothed">>
<</if>>
<</if>>
<<set $npcskinselector to ($whitechance + $blackchance)>>
<<if $npcskinselector is 0>>
<<set $npcskinselector to 1>>
<</if>>
<<set $whitechanceselector to (($whitechance / $npcskinselector) * 100)>>
<<set $blackchanceselector to (($blackchance / $npcskinselector) * 100)>>
<<if random(1, 100) lte $blackchanceselector>>
<<set $npcskin6 to "black">>
<<else>>
<<set $npcskin6 to "white">>
<</if>>
<<set $rng to random(1, 100)>>
<<if $rng gte 91>>
<<if $penis6 isnot "none">>
<<set $insecurity6 to "penis">>
<<else>>
<<set $insecurity6 to "vagina">>
<</if>>
<<elseif $rng gte 81>>
<<if $vagina6 isnot "none">>
<<set $insecurity6 to "vagina">>
<<else>>
<<set $insecurity6 to "penis">>
<</if>>
<<elseif $rng gte 61>>
<<set $insecurity6 to "ethics">>
<<elseif $rng gte 41>>
<<set $insecurity6 to "weak">>
<<elseif $rng gte 21>>
<<set $insecurity6 to "skill">>
<<else>>
<<set $insecurity6 to "looks">>
<</if>>
<</nobr>><</widget>>
<<widget "description1">><<nobr>>
<<if $npcchild1 is 1>>
<<if $pronoun1 is "f">>
<<set $description1 to either("fit", "mousy", "cute", "graceful", "plump", "lissome", "lithe", "lean", "slim", "slender", "thin", "robust", "toned", "wide-eyed", "shapely", "petite", "slight", "trim", "taut")>>
<<else>>
<<set $description1 to either("fit", "mousy", "cute", "graceful", "plump", "lissome", "lithe", "lean", "slim", "slender", "thin", "robust", "toned", "wide-eyed", "shapely", "petite", "slight", "trim", "taut")>>
<</if>>
<<else>>
<<if $pronoun1 is "f">>
<<set $description1 to either("lush", "plush", "voluptuous", "curvy", "plump", "lissome", "lithe", "lean", "slim", "slender", "thin", "robust", "toned", "muscular", "shapely", "petite", "slight", "trim", "taut")>>
<<else>>
<<set $description1 to either("broad", "rugged", "burly", "bulky", "plump", "lissome", "lithe", "lean", "slim", "slender", "thin", "robust", "toned", "muscular", "lanky", "petite", "slight", "trim", "taut")>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "description2">><<nobr>>
<<if $npcchild2 is 1>>
<<if $pronoun2 is "f">>
<<set $description2 to either("fit", "mousy", "cute", "graceful", "plump", "lissome", "lithe", "lean", "slim", "slender", "thin", "robust", "toned", "wide-eyed", "shapely", "petite", "slight", "trim", "taut")>>
<<else>>
<<set $description2 to either("fit", "mousy", "cute", "graceful", "plump", "lissome", "lithe", "lean", "slim", "slender", "thin", "robust", "toned", "wide-eyed", "shapely", "petite", "slight", "trim", "taut")>>
<</if>>
<<else>>
<<if $pronoun2 is "f">>
<<set $description2 to either("lush", "plush", "voluptuous", "curvy", "plump", "lissome", "lithe", "lean", "slim", "slender", "thin", "robust", "toned", "muscular", "shapely", "petite", "slight", "trim", "taut")>>
<<else>>
<<set $description2 to either("broad", "rugged", "burly", "bulky", "plump", "lissome", "lithe", "lean", "slim", "slender", "thin", "robust", "toned", "muscular", "lanky", "petite", "slight", "trim", "taut")>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "description3">><<nobr>>
<<if $npcchild3 is 1>>
<<if $pronoun3 is "f">>
<<set $description3 to either("fit", "mousy", "cute", "graceful", "plump", "lissome", "lithe", "lean", "slim", "slender", "thin", "robust", "toned", "wide-eyed", "shapely", "petite", "slight", "trim", "taut")>>
<<else>>
<<set $description3 to either("fit", "mousy", "cute", "graceful", "plump", "lissome", "lithe", "lean", "slim", "slender", "thin", "robust", "toned", "wide-eyed", "shapely", "petite", "slight", "trim", "taut")>>
<</if>>
<<else>>
<<if $pronoun3 is "f">>
<<set $description3 to either("lush", "plush", "voluptuous", "curvy", "plump", "lissome", "lithe", "lean", "slim", "slender", "thin", "robust", "toned", "muscular", "shapely", "petite", "slight", "trim", "taut")>>
<<else>>
<<set $description3 to either("broad", "rugged", "burly", "bulky", "plump", "lissome", "lithe", "lean", "slim", "slender", "thin", "robust", "toned", "muscular", "lanky", "petite", "slight", "trim", "taut")>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "description4">><<nobr>>
<<if $npcchild4 is 1>>
<<if $pronoun4 is "f">>
<<set $description4 to either("fit", "mousy", "cute", "graceful", "plump", "lissome", "lithe", "lean", "slim", "slender", "thin", "robust", "toned", "wide-eyed", "shapely", "petite", "slight", "trim", "taut")>>
<<else>>
<<set $description4 to either("fit", "mousy", "cute", "graceful", "plump", "lissome", "lithe", "lean", "slim", "slender", "thin", "robust", "toned", "wide-eyed", "shapely", "petite", "slight", "trim", "taut")>>
<</if>>
<<else>>
<<if $pronoun4 is "f">>
<<set $description4 to either("lush", "plush", "voluptuous", "curvy", "plump", "lissome", "lithe", "lean", "slim", "slender", "thin", "robust", "toned", "muscular", "shapely", "petite", "slight", "trim", "taut")>>
<<else>>
<<set $description4 to either("broad", "rugged", "burly", "bulky", "plump", "lissome", "lithe", "lean", "slim", "slender", "thin", "robust", "toned", "muscular", "lanky", "petite", "slight", "trim", "taut")>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "description5">><<nobr>>
<<if $npcchild5 is 1>>
<<if $pronoun5 is "f">>
<<set $description5 to either("fit", "mousy", "cute", "graceful", "plump", "lissome", "lithe", "lean", "slim", "slender", "thin", "robust", "toned", "wide-eyed", "shapely", "petite", "slight", "trim", "taut")>>
<<else>>
<<set $description5 to either("fit", "mousy", "cute", "graceful", "plump", "lissome", "lithe", "lean", "slim", "slender", "thin", "robust", "toned", "wide-eyed", "shapely", "petite", "slight", "trim", "taut")>>
<</if>>
<<else>>
<<if $pronoun5 is "f">>
<<set $description5 to either("lush", "plush", "voluptuous", "curvy", "plump", "lissome", "lithe", "lean", "slim", "slender", "thin", "robust", "toned", "muscular", "shapely", "petite", "slight", "trim", "taut")>>
<<else>>
<<set $description5 to either("broad", "rugged", "burly", "bulky", "plump", "lissome", "lithe", "lean", "slim", "slender", "thin", "robust", "toned", "muscular", "lanky", "petite", "slight", "trim", "taut")>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "description6">><<nobr>>
<<if $npcchild6 is 1>>
<<if $pronoun6 is "f">>
<<set $description6 to either("fit", "mousy", "cute", "graceful", "plump", "lissome", "lithe", "lean", "slim", "slender", "thin", "robust", "toned", "wide-eyed", "shapely", "petite", "slight", "trim", "taut")>>
<<else>>
<<set $description6 to either("fit", "mousy", "cute", "graceful", "plump", "lissome", "lithe", "lean", "slim", "slender", "thin", "robust", "toned", "wide-eyed", "shapely", "petite", "slight", "trim", "taut")>>
<</if>>
<<else>>
<<if $pronoun6 is "f">>
<<set $description6 to either("lush", "plush", "voluptuous", "curvy", "plump", "lissome", "lithe", "lean", "slim", "slender", "thin", "robust", "toned", "muscular", "shapely", "petite", "slight", "trim", "taut")>>
<<else>>
<<set $description6 to either("broad", "rugged", "burly", "bulky", "plump", "lissome", "lithe", "lean", "slim", "slender", "thin", "robust", "toned", "muscular", "lanky", "petite", "slight", "trim", "taut")>>
<</if>>
<</if>>
<</nobr>><</widget>>
:: Widgets End Event [widget]
<<widget "endevent">><<nobr>>
<<if $dancing is 1>>
<<famedance>>
<</if>>
<<set $molestavoid to 1>>
<<set $phaselast to $phase>>
<<set $phase to 0>>
<<set $phase2 to 0>>
<<set $npc to 0>>
<<endnpc>>
<<set $dancelocation to 0>>
<<set $forceddance to 0>>
<<set $lefthand to "none">>
<<set $lefthand2 to "none">>
<<set $lefthand3 to "none">>
<<set $lefthand4 to "none">>
<<set $lefthand5 to "none">>
<<set $lefthand6 to "none">>
<<set $righthand to "none">>
<<set $righthand2 to "none">>
<<set $righthand3 to "none">>
<<set $righthand4 to "none">>
<<set $righthand5 to "none">>
<<set $righthand6 to "none">>
<<set $penis to "none">>
<<set $penis2 to "none">>
<<set $penis3 to "none">>
<<set $penis4 to "none">>
<<set $penis5 to "none">>
<<set $penis6 to "none">>
<<set $vagina to "none">>
<<set $vagina2 to "none">>
<<set $vagina3 to "none">>
<<set $vagina4 to "none">>
<<set $vagina5 to "none">>
<<set $vagina6 to "none">>
<<set $mouth to "none">>
<<set $mouth2 to "none">>
<<set $mouth3 to "none">>
<<set $mouth4 to "none">>
<<set $mouth5 to "none">>
<<set $mouth6 to "none">>
<<set $gender1 to 0>>
<<set $gender2 to 0>>
<<set $gender3 to 0>>
<<set $gender4 to 0>>
<<set $gender5 to 0>>
<<set $gender6 to 0>>
<<set $pronoun1 to 0>>
<<set $pronoun2 to 0>>
<<set $pronoun3 to 0>>
<<set $pronoun4 to 0>>
<<set $pronoun5 to 0>>
<<set $pronoun6 to 0>>
<<set $description1 to 0>>
<<set $description2 to 0>>
<<set $description3 to 0>>
<<set $description4 to 0>>
<<set $description5 to 0>>
<<set $description6 to 0>>
<<set $consensual to 0>>
<<set $danceaction to 0>>
<<set $danceactiondefault to 0>>
<<set $attention to 0>>
<<set $audience to 0>>
<<set $audienceexcitement to 0>>
<<set $audiencearousal to 0>>
<<set $enemyno to 0>>
<<set $audiencemod to 1>>
<<set $venuemod to 1>>
<<set $danceevent to 0>>
<<set $dancing to 0>>
<<set $privatedanceoffered to 0>>
<<set $trance to 0>>
<<set $robinhugging to 0>>
<<set $robinroomentered to 0>>
<<set $orgasmcurrent to 0>>
<<set $actionuncladoutfit to 0>>
<<set $actionuncladupper to 0>>
<<set $actionuncladlower to 0>>
<<set $actionuncladunder to 0>>
<<set $clothingselector to 0>>
<<set $stealtextskip to 0>>
<<set $trueconsensual to 0>>
<<set $speechcum to 0>>
<<set $speechorgasmcount to 0>>
<<set $insecurity1 to 0>>
<<set $insecurity2 to 0>>
<<set $insecurity3 to 0>>
<<set $insecurity4 to 0>>
<<set $insecurity5 to 0>>
<<set $insecurity6 to 0>>
<</nobr>><</widget>>
:: Widgets NPC Types [widget]
<<widget "npcstrip">><<nobr>>
<<if $enemyno gte 1>><<set $anus to "idle">>
<<if $gender1 is "m">>
<<set $penis to "idle">>
<<elseif $gender1 is "f">>
<<set $vagina to "idle">>
<<elseif $gender1 is "h">>
<<set $penis to "idle">>
<<set $vagina to "idle">>
<</if>>
<<if $uppertype isnot "naked">>
<<set $lefthand to "upperclothes">>
<<elseif $lowertype isnot "naked">>
<<set $lefthand to "lowerclothes">>
<<elseif $undertype isnot "naked" and $undertype isnot "chastity">>
<<set $lefthand to "underclothes">>
<</if>>
<<if $lowertype isnot "naked">>
<<set $righthand to "lowerclothes">>
<<elseif $uppertype isnot "naked">>
<<set $righthand to "upperclothes">>
<<elseif $undertype isnot "naked" and $undertype isnot "chastity">>
<<set $righthand to "underclothes">>
<</if>>
<</if>>
<<if $enemyno gte 2>><<set $anus2 to "idle">>
<<if $gender2 is "m">>
<<set $penis2 to "idle">>
<<elseif $gender2 is "f">>
<<set $vagina2 to "idle">>
<<elseif $gender2 is "h">>
<<set $penis2 to "idle">>
<<set $vagina2 to "idle">>
<</if>>
<<if $uppertype isnot "naked">>
<<set $lefthand2 to "upperclothes">>
<<elseif $lowertype isnot "naked">>
<<set $lefthand2 to "lowerclothes">>
<<elseif $undertype isnot "naked" and $undertype isnot "chastity">>
<<set $lefthand2 to "underclothes">>
<</if>>
<<if $lowertype isnot "naked">>
<<set $righthand2 to "lowerclothes">>
<<elseif $uppertype isnot "naked">>
<<set $righthand2 to "upperclothes">>
<<elseif $undertype isnot "naked" and $undertype isnot "chastity">>
<<set $righthand2 to "underclothes">>
<</if>>
<</if>>
<<if $enemyno gte 3>><<set $anus3 to "idle">>
<<if $gender3 is "m">>
<<set $penis3 to "idle">>
<<elseif $gender3 is "f">>
<<set $vagina3 to "idle">>
<<elseif $gender3 is "h">>
<<set $penis3 to "idle">>
<<set $vagina3 to "idle">>
<</if>>
<<if $uppertype isnot "naked">>
<<set $lefthand3 to "upperclothes">>
<<elseif $lowertype isnot "naked">>
<<set $lefthand3 to "lowerclothes">>
<<elseif $undertype isnot "naked" and $undertype isnot "chastity">>
<<set $lefthand3 to "underclothes">>
<</if>>
<<if $lowertype isnot "naked">>
<<set $righthand3 to "lowerclothes">>
<<elseif $uppertype isnot "naked">>
<<set $righthand3 to "upperclothes">>
<<elseif $undertype isnot "naked" and $undertype isnot "chastity">>
<<set $righthand3 to "underclothes">>
<</if>>
<</if>>
<<if $enemyno gte 4>><<set $anus4 to "idle">>
<<if $gender4 is "m">>
<<set $penis4 to "idle">>
<<elseif $gender4 is "f">>
<<set $vagina4 to "idle">>
<<elseif $gender4 is "h">>
<<set $penis4 to "idle">>
<<set $vagina4 to "idle">>
<</if>>
<<if $uppertype isnot "naked">>
<<set $lefthand4 to "upperclothes">>
<<elseif $lowertype isnot "naked">>
<<set $lefthand4 to "lowerclothes">>
<<elseif $undertype isnot "naked" and $undertype isnot "chastity">>
<<set $lefthand4 to "underclothes">>
<</if>>
<<if $lowertype isnot "naked">>
<<set $righthand4 to "lowerclothes">>
<<elseif $uppertype isnot "naked">>
<<set $righthand4 to "upperclothes">>
<<elseif $undertype isnot "naked" and $undertype isnot "chastity">>
<<set $righthand4 to "underclothes">>
<</if>>
<</if>>
<<if $enemyno gte 5>><<set $anus5 to "idle">>
<<if $gender5 is "m">>
<<set $penis5 to "idle">>
<<elseif $gender5 is "f">>
<<set $vagina5 to "idle">>
<<elseif $gender5 is "h">>
<<set $penis5 to "idle">>
<<set $vagina5 to "idle">>
<</if>>
<<if $uppertype isnot "naked">>
<<set $lefthand5 to "upperclothes">>
<<elseif $lowertype isnot "naked">>
<<set $lefthand5 to "lowerclothes">>
<<elseif $undertype isnot "naked" and $undertype isnot "chastity">>
<<set $lefthand5 to "underclothes">>
<</if>>
<<if $lowertype isnot "naked">>
<<set $righthand5 to "lowerclothes">>
<<elseif $uppertype isnot "naked">>
<<set $righthand5 to "upperclothes">>
<<elseif $undertype isnot "naked" and $undertype isnot "chastity">>
<<set $righthand5 to "underclothes">>
<</if>>
<</if>>
<<if $enemyno gte 6>><<set $anus6 to "idle">>
<<if $gender6 is "m">>
<<set $penis6 to "idle">>
<<elseif $gender6 is "f">>
<<set $vagina6 to "idle">>
<<elseif $gender6 is "h">>
<<set $penis6 to "idle">>
<<set $vagina6 to "idle">>
<</if>>
<<if $uppertype isnot "naked">>
<<set $lefthand6 to "upperclothes">>
<<elseif $lowertype isnot "naked">>
<<set $lefthand6 to "lowerclothes">>
<<elseif $undertype isnot "naked" and $undertype isnot "chastity">>
<<set $lefthand6 to "underclothes">>
<</if>>
<<if $lowertype isnot "naked">>
<<set $righthand6 to "lowerclothes">>
<<elseif $uppertype isnot "naked">>
<<set $righthand6 to "upperclothes">>
<<elseif $undertype isnot "naked" and $undertype isnot "chastity">>
<<set $righthand6 to "underclothes">>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "npcexhibit">><<nobr>>
<</nobr>><</widget>>
<<widget "npcoral">><<nobr>>
<<if $penis isnot "none">>
<<set $penis to "mouthentrance">><<submission 5>><<set $mouthstate to "entrance">><<set $mouthuse to "penis">>
<<He>> presses <<his>> penis against your lips.<br><br>
<<elseif $vagina isnot "none">>
<<submission 5>><<set $mouthuse to "othervagina">><<set $vagina to "mouth">><<set $mouthstate to "othervagina">>
<<He>> presses <<his>> pussy against your lips.<br><br>
<</if>>
<</nobr>><</widget>>
<<widget "npchand">><<nobr>>
<<if $penis isnot "none">>
<<set $leftarm to "penis">><<set $penis to "leftarm">>
<<else>>
<<set $leftarm to "vagina">><<set $vagina to "leftarm">>
<</if>>
<</nobr>><</widget>>
<<widget "npcidlegenitals">><<nobr>>
<<if $penis isnot "none">>
<<set $penis to "idle">>
<</if>>
<<if $penis2 isnot "none">>
<<set $penis2 to "idle">>
<</if>>
<<if $penis3 isnot "none">>
<<set $penis3 to "idle">>
<</if>>
<<if $penis4 isnot "none">>
<<set $penis4 to "idle">>
<</if>>
<<if $penis5 isnot "none">>
<<set $penis5 to "idle">>
<</if>>
<<if $penis6 isnot "none">>
<<set $penis6 to "idle">>
<</if>>
<<if $vagina isnot "none">>
<<set $vagina to "idle">>
<</if>>
<<if $vagina2 isnot "none">>
<<set $vagina2 to "idle">>
<</if>>
<<if $vagina3 isnot "none">>
<<set $vagina3 to "idle">>
<</if>>
<<if $vagina4 isnot "none">>
<<set $vagina4 to "idle">>
<</if>>
<<if $vagina5 isnot "none">>
<<set $vagina5 to "idle">>
<</if>>
<<if $vagina6 isnot "none">>
<<set $vagina6 to "idle">>
<</if>>
<</nobr>><</widget>>
<<widget "npckiss">><<nobr>>
<<set $mouth to "kiss">><<set $mouthstate to "kiss">><<set $mouthuse to "kiss">>
<</nobr>><</widget>>
<<widget "npcexpose">><<nobr>>
<<if $penis isnot "none">>
<<set $penis to 0>>
<</if>>
<<if $penis2 isnot "none">>
<<set $penis2 to 0>>
<</if>>
<<if $penis3 isnot "none">>
<<set $penis3 to 0>>
<</if>>
<<if $penis4 isnot "none">>
<<set $penis4 to 0>>
<</if>>
<<if $penis5 isnot "none">>
<<set $penis5 to 0>>
<</if>>
<<if $penis6 isnot "none">>
<<set $penis6 to 0>>
<</if>>
<<if $vagina isnot "none">>
<<set $vagina to 0>>
<</if>>
<<if $vagina2 isnot "none">>
<<set $vagina2 to 0>>
<</if>>
<<if $vagina3 isnot "none">>
<<set $vagina3 to 0>>
<</if>>
<<if $vagina4 isnot "none">>
<<set $vagina4 to 0>>
<</if>>
<<if $vagina5 isnot "none">>
<<set $vagina5 to 0>>
<</if>>
<<if $vagina6 isnot "none">>
<<set $vagina6 to 0>>
<</if>>
<</nobr>><</widget>>
<<widget "npcspank">><<nobr>>
<<if $rightarm is 0>>
<<set $rightarm to "grappled">>
<<set $lefthand to "arms">>
<</if>>
<<if $leftarm is 0>>
<<set $leftarm to "grappled">>
<<set $lefthand to "arms">>
<</if>>
<<set $righthand to "spank">>
<</nobr>><</widget>>
:: Widgets Combat Img [widget]
<<widget "combatimg">><<nobr>>
<<if window.document.body.clientWidth lt 650>>
<div id="divandroidsex"><<doggyimg>></div>
<<if $ejaculating is 1>>
<div id="divandroidxray"><<ejacimg>></div>
<<elseif $vaginastate is "penetrated" or $anusstate is "penetrated" or $penisstate is "penetrated" or $vaginastate is "tentacle" or $vaginastate is "tentacledeep" or $anusstate is "tentacle" or $anusstate is "tentacledeep" or $penisstate is "tentacle" or $penisstate is "tentacledeep">>
<div id="divandroidxray"><<xrayimg>></div>
<</if>>
<<else>>
<div id="divsex" @class="colourContainerClasses()">
<<doggyimg>>
<<if $ejaculating is 1>>
<<ejacimg>>
<<else>>
<<xrayimg>>
<</if>>
</div>
<</if>>
<</nobr>><</widget>>
<<widget "doggyimg">><<nobr>>
<<voreimg>>
<<closeimg>>
<<if $imgload is 0>>
<<set $imgload to 1>>
<img id="sexbase" src="img/ghost.png">
<img id="sexblush" src="img/ghost.png">
<<else>>
<<set $imgload to 0>>
<img id="sexbase" src="img/ghost2.png">
<img id="sexblush" src="img/ghost.png">
<</if>>
<<if $swarmactive lte 0>>
<<elseif $swarmactive lte 1>>
<img id="sexpenis" src="img/sex/doggy/slime/slimecount1.gif">
<<elseif $swarmactive lte 2>>
<img id="sexpenis" src="img/sex/doggy/slime/slimecount2.gif">
<<elseif $swarmactive lte 3>>
<img id="sexpenis" src="img/sex/doggy/slime/slimecount3.gif">
<<elseif $swarmactive lte 4>>
<img id="sexpenis" src="img/sex/doggy/slime/slimecount4.gif">
<<elseif $swarmactive lte 9>>
<img id="sexpenis" src="img/sex/doggy/slime/slimecount5.gif">
<<elseif $swarmactive gte 10>>
<img id="sexpenis" src="img/sex/doggy/slime/slimecount6.gif">
<</if>>
<<if $thighuse is "othermouth">>
<img id="sexpenis" src="img/sex/doggy/doggyactivepenilemouthentrance.gif">
<</if>>
<<if $penisstate is "othermouthimminent">>
<img id="sexpenis" src="img/sex/doggy/doggyactivepenilemouthimminent.gif">
<</if>>
<<if $penisstate is "othermouthimminent">>
<img id="sexpenis" src="img/sex/doggy/doggyactivepenilemouthentrance.gif">
<</if>>
<<if $mouthstate is "kissimminent">>
<img id="sexpenis" src="img/sex/doggy/doggyactiveoralmouthimminent.gif">
<</if>>
<<if $mouthstate is "kissentrance">>
<img id="sexpenis" src="img/sex/doggy/doggyactiveoralmouthentrance.gif">
<</if>>
<<if $vaginastate is "othermouthimminent">>
<img id="sexpenis" src="img/sex/doggy/doggyactivevaginalmouthimminent.gif">
<</if>>
<<if $vaginastate is "othermouthentrance">>
<img id="sexpenis" src="img/sex/doggy/doggyactivevaginalmouthentrance.gif">
<</if>>
<<if $vaginastate is "imminent">>
<<if $enemytype isnot "beast">>
<img id="sexpenis" src="img/sex/doggy/doggyvaginalimminent.gif">
<</if>>
<<if $enemyarousal gte $enemyarousalmax>>
<img id="sexpenis" src="img/sex/doggy/doggyvaginalimminentcum.gif">
<</if>>
<</if>>
<<if $bottomuse is "othermouth">>
<img id="sexpenis" src="img/sex/doggy/doggyactiveanalmouthentrance.gif">
<</if>>
<<if $anusstate is "othermouthimminent">>
<img id="sexpenis" src="img/sex/doggy/doggyactiveanalmouthimminent.gif">
<</if>>
<<if $anusstate is "othermouthentrance">>
<img id="sexpenis" src="img/sex/doggy/doggyactiveanalmouthentrance.gif">
<</if>>
<<if $anusstate is "imminent">>
<<if $enemytype isnot "beast">>
<img id="sexpenis" src="img/sex/doggy/doggyanalimminent.gif">
<</if>>
<<if $enemyarousal gte $enemyarousalmax>>
<img id="sexpenis" src="img/sex/doggy/doggyanalimminentcum.gif">
<</if>>
<</if>>
<<if $anusstate is "entrance">>
<<if $enemytype isnot "beast">>
<img id="sexpenis" src="img/sex/doggy/doggyanalentrance.gif">
<</if>>
<<if $enemyarousal gte $enemyarousalmax>>
<img id="sexpenis" src="img/sex/doggy/doggyanalentrancecum.gif">
<</if>>
<</if>>
<<if $vaginastate is "entrance">>
<<if $enemytype isnot "beast">>
<img id="sexpenis" src="img/sex/doggy/doggyvaginalentrance.gif">
<</if>>
<<if $enemyarousal gte $enemyarousalmax>>
<img id="sexpenis" src="img/sex/doggy/doggyvaginalentrancecum.gif">
<</if>>
<</if>>
<<if $mouthstate is "imminent">>
<img id="sexpenis" src="img/sex/doggy/doggyoralimminent.gif">
<<if $enemyarousal gte $enemyarousalmax>>
<img id="sexpenis" src="img/sex/doggy/doggyoralentrancecum.gif">
<</if>>
<</if>>
<<if $mouthstate is "entrance">>
<img id="sexpenis" src="img/sex/doggy/doggyoralentrance.gif">
<<if $enemyarousal gte $enemyarousalmax>>
<img id="sexpenis" src="img/sex/doggy/doggyoralentrancecum.gif">
<</if>>
<</if>>
<<if $vaginastate isnot "penetrated"
and $anusstate isnot "penetrated"
and $mouthstate isnot "penetrated"
and $penisstate isnot "penetrated"
and $penisstate isnot "otheranus"
and $rightarm isnot "penis"
and $leftarm isnot "penis"
and $anusstate isnot "cheeks"
and $thighuse isnot "penis"
and $feetuse isnot "penis"
and $vaginastate isnot "othermouth"
and "anusstate" isnot "othermouth"
and $mouthstate isnot "kiss" and $penisstate isnot "othermouth"
and $vaginastate isnot "tentacleentrance"
and $vaginastate isnot "tentacleimminent"
and $vaginastate isnot "tentacle"
and $vaginastate isnot "tentacledeep"
and $vaginause isnot "tentaclerub"
and $penisstate isnot "tentacleentrance"
and $penisstate isnot "tentacleimminent"
and $penisstate isnot "tentacle"
and $penisstate isnot "tentacledeep"
and $penisuse isnot "tentaclerub"
and $anusstate isnot "tentacleentrance"
and $anusstate isnot "tentacleimminent"
and $anusstate isnot "tentacle"
and $anusstate isnot "tentacledeep"
and $anusstate isnot "tentaclerub"
and $mouthstate isnot "tentacleentrance"
and $anusstate isnot "tentacleimminent"
and $anusstate isnot "tentacle"
and $anusstate isnot "tentacledeep"
and $feetstate isnot "tentacle"
and $leftarmstate isnot "tentacle"
and $rightarmstate isnot "tentacle"
and $swarmfront is 0
and $swarmback is 0
and $swarmfrontinside is 0
and $swarmbackinside is 0
and $beaststance isnot "top">>
<<clothesidle>>
<img id="sexbase" src="img/sex/doggy/idle/body/doggyidlebase.gif">
<img id="sexmouth" src="img/sex/doggy/idle/body/doggyidlemouth.png">
<<if $leftarm isnot "bound" and $leftarm isnot "grappled">>
<img id="sexbasefront" src="img/sex/doggy/idle/body/doggyidleleftarm.gif">
<<elseif $upperset is $lowerset and $skirt is 1>>
<img id="sexaboveclothes" src="img/sex/doggy/idle/body/doggyidleleftarmbound.gif">
<<else>>
<img id="sexbase" src="img/sex/doggy/idle/body/doggyidleleftarmbound.gif">
<</if>>
<<if $rightarm isnot "bound" and $rightarm isnot "grappled">>
<img id="sexbaseback" src="img/sex/doggy/idle/body/doggyidlerightarm.gif">
<<else>>
<</if>>
<<if $arousal gte 8000>>
<img id="sexblush" src="img/sex/doggy/idle/body/doggyidleblush5.png">
<<elseif $arousal gte 6000>>
<img id="sexblush" src="img/sex/doggy/idle/body/doggyidleblush4.png">
<<elseif $arousal gte 4000>>
<img id="sexblush" src="img/sex/doggy/idle/body/doggyidleblush3.png">
<<elseif $exposed gte 2>>
<img id="sexblush" src="img/sex/doggy/idle/body/doggyidleblush2.png">
<<elseif $arousal gte 2000>>
<img id="sexblush" src="img/sex/doggy/idle/body/doggyidleblush2.png">
<<elseif $exposed gte 1>>
<img id="sexblush" src="img/sex/doggy/idle/body/doggyidleblush1.png">
<<elseif $arousal gte 100>>
<img id="sexblush" src="img/sex/doggy/idle/body/doggyidleblush1.png">
<</if>>
<<if $pain gte 80>>
<img id="sextears" src="img/sex/doggy/idle/body/doggyidletears4.gif">
<<elseif $pain gte 60>>
<img id="sextears" src="img/sex/doggy/idle/body/doggyidletears3.gif">
<<elseif $pain gte 40>>
<img id="sextears" src="img/sex/doggy/idle/body/doggyidletears2.gif">
<<elseif $pain gte 20>>
<img id="sextears" src="img/sex/doggy/idle/body/doggyidletears1.png">
<</if>>
<<if $pain gte 100>>
<img id="sexsclera" src="img/sex/doggy/idle/eyes/doggyidlesclerabloodshot.png">
<</if>>
<<if $trauma gte $traumamax>>
<img id="sexeyes" class="colour-eye" src="img/sex/doggy/idle/eyes/doggyidlehazelempty.png">
<<else>>
<img id="sexeyes" class="colour-eye" src="img/sex/doggy/idle/eyes/doggyidlehazel.gif">
<</if>>
<<if $penisexist is 1>>
<<if $undertype is "chastity">>
<img id="sexmouth" src="img/sex/doggy/idle/body/doggyidlepenischastity.png">
<<elseif $lowerexposed gte 2 and $underexposed gte 1>>
<<if $penilevirginity is 1>>
<img id="sexmouth" src="img/sex/doggy/idle/body/doggyidlepenisvirgin.png">
<<else>>
<img id="sexmouth" src="img/sex/doggy/idle/body/doggyidlepenis.png">
<</if>>
<</if>>
<</if>>
<<if $hairlength gte 900>>
<img id="sexhair" class="colour-hair" src="img/sex/doggy/idle/hair/red/doggyidlefeetred.gif">
<<elseif $hairlength gte 700>>
<img id="sexhair" class="colour-hair" src="img/sex/doggy/idle/hair/red/doggyidlethighsred.gif">
<<elseif $hairlength gte 600>>
<img id="sexhair" class="colour-hair" src="img/sex/doggy/idle/hair/red/doggyidlenavelred.gif">
<<elseif $hairlength gte 400>>
<img id="sexhair" class="colour-hair" src="img/sex/doggy/idle/hair/red/doggyidlechestred.gif">
<<elseif $hairlength gte 200>>
<img id="sexhair" class="colour-hair" src="img/sex/doggy/idle/hair/red/doggyidleshoulderred.gif">
<<else>>
<img id="sexhair" class="colour-hair" src="img/sex/doggy/idle/hair/red/doggyidleshortred.gif">
<</if>>
<img id="sexlashes" class="colour-hair" src="img/sex/doggy/idle/hair/red/doggyidlelashesred.gif">
<img id="sexbrow" class="colour-hair" src="img/sex/doggy/idle/hair/red/doggyidleoverlayred.gif">
<<if $hairlength gte 200>>
<img id="sexmouth" src="img/sex/doggy/idle/body/doggyidlefaceoverlay.gif">
<<else>>
<img id="sexmouth" src="img/sex/doggy/idle/body/doggyidlefaceoverlayshort.gif">
<</if>>
<<if $collared is 1>>
<img id="sexmouth" src="img/sex/doggy/idle/body/doggyidlecollar.png">
<</if>>
<<breastsidle>>
<<transformationwolfimg>>
<<if $underclothes is "chastity belt">>
<img id="sexbase" src="img/sex/doggy/idle/body/doggyidlechastitybelt.png">
<</if>>
<img id="sexbase" src="img/sex/doggy/idle/body/doggyidleshadow.png">
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<<beastimgvfast>>
<<transformationwolfimgvfast>>
<img id="sexbrow" class="colour-hair" src="img/sex/doggy/active/hair/red/doggyactiveoverlayredvfast.gif">
<img id="sexbase" src="img/sex/doggy/active/body/doggyactivebasevfast.gif">
<img id="sexmouth" src="img/sex/doggy/active/body/doggyactivemouthvfast.gif">
<<if $feetuse is "penis">>
<img id="sexbase" src="img/sex/doggy/active/body/doggyactivefeetjobvfast.gif">
<<if $enemyarousal gte $enemyarousalmax>>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivefeetjobcum.gif">
<</if>>
<<elseif $feetstate is "tentacle">>
<<else>>
<img id="sexbase" src="img/sex/doggy/active/body/doggyactivebaselegsvfast.gif">
<</if>>
<<if $leftarm is "penis">>
<img id="sexbasefront" src="img/sex/doggy/active/body/doggyactivelefthandjobvfast.gif">
<<if $enemyarousal gte $enemyarousalmax>>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivelefthandjobcum.gif">
<</if>>
<<elseif $leftarm is "bound">>
<img id="sexbasefront" src="img/sex/doggy/active/body/doggyactiveleftarmboundvfast.gif">
<<elseif $leftarm is "grappled">>
<img id="sexbasefront" src="img/sex/doggy/active/body/doggyactiveleftarmboundvfast.gif">
<<elseif $leftarmstate is "tentacle">>
<<else>>
<img id="sexbasefront" src="img/sex/doggy/active/body/doggyactivebaseleftarmvfast.gif">
<</if>>
<<if $rightarm is "penis">>
<img id="sexbaseback" src="img/sex/doggy/active/body/doggyactiverighthandjobvfast.gif">
<<if $enemyarousal gte $enemyarousalmax>>
<img id="sextears" src="img/sex/doggy/active/body/doggyactiverighthandjobcum.gif">
<</if>>
<<elseif $rightarm is "bound">>
<<elseif $rightarm is "grappled">>
<<elseif $rightarmstate is "tentacle">>
<<else>>
<img id="sexbaseback" src="img/sex/doggy/active/body/doggyactivebaserightarm.gif">
<</if>>
<<if $anusstate is "cheeks">>
<<if $enemytype isnot "beast">>
<img id="sexbase" src="img/sex/doggy/active/body/doggyactivecheeksvfast.gif">
<</if>>
<<if $enemyarousal gte $enemyarousalmax>>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivecheekscum.gif">
<</if>>
<</if>>
<<tentacleimgvfast>>
<<if $thighuse is "penis">>
<<if $enemytype isnot "beast">>
<img id="sexbase" src="img/sex/doggy/active/body/doggyactivethighsvfast.gif">
<</if>>
<<if $enemyarousal gte $enemyarousalmax>>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivethighscum.gif">
<</if>>
<</if>>
<<if $arousal gte 8000>>
<img id="sexblush" src="img/sex/doggy/active/body/doggyactiveblush5vfast.gif">
<<elseif $arousal gte 6000>>
<img id="sexblush" src="img/sex/doggy/active/body/doggyactiveblush4vfast.gif">
<<elseif $arousal gte 4000>>
<img id="sexblush" src="img/sex/doggy/active/body/doggyactiveblush3vfast.gif">
<<elseif $exposed gte 2>>
<img id="sexblush" src="img/sex/doggy/active/body/doggyactiveblush2vfast.gif">
<<elseif $arousal gte 2000>>
<img id="sexblush" src="img/sex/doggy/active/body/doggyactiveblush2vfast.gif">
<<elseif $exposed gte 1>>
<img id="sexblush" src="img/sex/doggy/active/body/doggyactiveblush1vfast.gif">
<<elseif $arousal gte 100>>
<img id="sexblush" src="img/sex/doggy/active/body/doggyactiveblush1vfast.gif">
<</if>>
<<if $pain gte 80>>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivetears5vfast.gif">
<<elseif $pain gte 60>>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivetears4vfast.gif">
<<elseif $pain gte 40>>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivetears3vfast.gif">
<<elseif $pain gte 20>>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivetears2vfast.gif">
<<else>>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivetears1vfast.gif">
<</if>>
<<if $pain gte 100>>
<img id="sexsclera" src="img/sex/doggy/active/eyes/doggyactivesclerabloodshotvfast.gif">
<</if>>
<<if $trauma gte $traumamax>>
<img id="sexeyes" class="colour-eye" src="img/sex/doggy/active/eyes/doggyactivehazelemptyvfast.gif">
<<else>>
<img id="sexeyes" class="colour-eye" src="img/sex/doggy/active/eyes/doggyactivehazelvfast.gif">
<</if>>
<<if $mouthstate is "kiss">>
<img id="sextears" src="img/sex/doggy/active/body/doggyactiveoralmouthvfast.gif">
<</if>>
<<if $mouthstate is "penetrated">>
<img id="sextears" src="img/sex/doggy/active/body/doggyactiveoralvfast.gif">
<<if $enemyarousal gte $enemyarousalmax>>
<img id="sextears" src="img/sex/doggy/active/body/doggyactiveoralcumvfast.gif">
<</if>>
<</if>>
<<if $vaginastate is "othermouth">>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivevaginalmouthvfast.gif">
<</if>>
<<if $vaginastate is "penetrated">>
<<if $enemytype isnot "beast">>
<<if $anusstate is "penetrated">>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivevaginaldpvfast.gif">
<<else>>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivevaginalvfast.gif">
<</if>>
<</if>>
<<if $enemyarousal gte $enemyarousalmax>>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivevaginalcumvfast.gif">
<</if>>
<</if>>
<<if $anusstate is "othermouth">>
<img id="sextears" src="img/sex/doggy/active/body/doggyactiveanalmouthvfast.gif">
<</if>>
<<if $anusstate is "penetrated">>
<<if $enemytype isnot "beast">>
<img id="sextears" src="img/sex/doggy/active/body/doggyactiveanalvfast.gif">
<</if>>
<<if $enemyarousal gte $enemyarousalmax>>
<img id="sextears" src="img/sex/doggy/active/body/doggyactiveanalcumvfast.gif">
<</if>>
<</if>>
<<if $penisstate is "othermouth">>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivepenilevfast.gif">
<</if>>
<<if $penisstate is "penetrated" or $penisstate is "otheranus">>
<<if $orgasmdown gte 1 and $orgasmcount lte 24>>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivepenilecumvfast.gif">
<<else>>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivepenilevfast.gif">
<</if>>
<</if>>
<<if $penisexist is 1>>
<<if $undertype is "chastity">>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivepenischastityvfast.gif">
<<elseif $penilevirginity is 1>>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivepenisvirginvfast.gif">
<<else>>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivepenisvfast.gif">
<</if>>
<<if $orgasmdown gte 1 and $penisstate isnot "penetrated" and $orgasmcount lte 24>>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivecumvfast.gif">
<</if>>
<</if>>
<<if $hairlength gte 900>>
<img id="sexhair" class="colour-hair" src="img/sex/doggy/active/hair/red/doggyactivefeetredvfast.gif">
<<elseif $hairlength gte 700>>
<img class="colour-hair" id="sexhair" src="img/sex/doggy/active/hair/red/doggyactivethighsredvfast.gif">
<<elseif $hairlength gte 600>>
<img class="colour-hair" id="sexhair" src="img/sex/doggy/active/hair/red/doggyactivenavelredvfast.gif">
<<elseif $hairlength gte 400>>
<img class="colour-hair" id="sexhair" src="img/sex/doggy/active/hair/red/doggyactivechestredvfast.gif">
<<elseif $hairlength gte 200>>
<img class="colour-hair" id="sexhair" src="img/sex/doggy/active/hair/red/doggyactiveshoulderredvfast.gif">
<<else>>
<img class="colour-hair" id="sexhair" src="img/sex/doggy/active/hair/red/doggyactiveshortredvfast.gif">
<</if>>
<img class="colour-hair" id="sexlashes" src="img/sex/doggy/active/hair/red/doggyactivelashesredvfast.gif">
<img id="sexsclera" src="img/sex/doggy/active/body/doggyactivefaceoverlayvfast.gif">
<<if $collared is 1>>
<img id="sexmouth" src="img/sex/doggy/active/body/doggyactivecollarvfast.gif">
<</if>>
<<breastsactivevfast>>
<<if $underclothes is "chastity belt">>
<img id="sexbase" src="img/sex/doggy/active/body/doggyactivechastitybeltvfast.gif">
<</if>>
<img id="sexbase" src="img/sex/doggy/active/body/doggyactiveshadowvfast.gif">
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 3>>
<img id="sexbrow" class="colour-hair" src="img/sex/doggy/active/hair/red/doggyactiveoverlayredfast.gif">
<<beastimgfast>>
<<transformationwolfimgfast>>
<img id="sexbase" src="img/sex/doggy/active/body/doggyactivebasefast.gif">
<img id="sexmouth" src="img/sex/doggy/active/body/doggyactivemouthfast.gif">
<<if $feetuse is "penis">>
<img id="sexbase" src="img/sex/doggy/active/body/doggyactivefeetjobfast.gif">
<<elseif $feetstate is "tentacle">>
<<else>>
<img id="sexbase" src="img/sex/doggy/active/body/doggyactivebaselegsfast.gif">
<</if>>
<<if $leftarm is "penis">>
<img id="sexbasefront" src="img/sex/doggy/active/body/doggyactivelefthandjobfast.gif">
<<elseif $leftarm is "bound">>
<img id="sexbasefront" src="img/sex/doggy/active/body/doggyactiveleftarmboundfast.gif">
<<elseif $leftarm is "grappled">>
<img id="sexbasefront" src="img/sex/doggy/active/body/doggyactiveleftarmboundfast.gif">
<<elseif $leftarmstate is "tentacle">>
<<else>>
<img id="sexbasefront" src="img/sex/doggy/active/body/doggyactivebaseleftarmfast.gif">
<</if>>
<<if $rightarm is "penis">>
<img id="sexbaseback"
src="img/sex/doggy/active/body/doggyactiverighthandjobfast.gif">
<<elseif $rightarm is "bound">>
<<elseif $rightarm is "grappled">>
<<elseif $rightarmstate is "tentacle">>
<<else>>
<img id="sexbaseback" src="img/sex/doggy/active/body/doggyactivebaserightarm.gif">
<</if>>
<<if $anusstate is "cheeks">>
<<if $enemytype isnot "beast">>
<img id="sexbase" src="img/sex/doggy/active/body/doggyactivecheeksfast.gif">
<</if>>
<<if $enemyarousal gte $enemyarousalmax>>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivecheekscum.gif">
<</if>>
<</if>>
<<if $thighuse is "penis">>
<<if $enemytype isnot "beast">>
<img id="sexbase" src="img/sex/doggy/active/body/doggyactivethighsfast.gif">
<</if>>
<<if $enemyarousal gte $enemyarousalmax>>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivethighscum.gif">
<</if>>
<</if>>
<<if $arousal gte 8000>>
<img id="sexblush" src="img/sex/doggy/active/body/doggyactiveblush5fast.gif">
<<elseif $arousal gte 6000>>
<img id="sexblush" src="img/sex/doggy/active/body/doggyactiveblush4fast.gif">
<<elseif $arousal gte 4000>>
<img id="sexblush" src="img/sex/doggy/active/body/doggyactiveblush3fast.gif">
<<elseif $exposed gte 2>>
<img id="sexblush" src="img/sex/doggy/active/body/doggyactiveblush2fast.gif">
<<elseif $arousal gte 2000>>
<img id="sexblush" src="img/sex/doggy/active/body/doggyactiveblush2fast.gif">
<<elseif $exposed gte 1>>
<img id="sexblush" src="img/sex/doggy/active/body/doggyactiveblush1fast.gif">
<<elseif $arousal gte 100>>
<img id="sexblush" src="img/sex/doggy/active/body/doggyactiveblush1fast.gif">
<</if>>
<<if $pain gte 80>>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivetears5fast.gif">
<<elseif $pain gte 60>>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivetears4fast.gif">
<<elseif $pain gte 40>>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivetears3fast.gif">
<<elseif $pain gte 20>>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivetears2fast.gif">
<<else>>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivetears1fast.gif">
<</if>>
<<if $pain gte 100>>
<img id="sexsclera" src="img/sex/doggy/active/eyes/doggyactivesclerabloodshotfast.gif">
<</if>>
<<if $trauma gte $traumamax>>
<img id="sexeyes" class="colour-eye" src="img/sex/doggy/active/eyes/doggyactivehazelemptyfast.gif">
<<else>>
<img id="sexeyes" class="colour-eye" src="img/sex/doggy/active/eyes/doggyactivehazelfast.gif">
<</if>>
<<if $mouthstate is "kiss">>
<img id="sextears" src="img/sex/doggy/active/body/doggyactiveoralmouthfast.gif">
<</if>>
<<if $mouthstate is "penetrated">>
<img id="sextears" src="img/sex/doggy/active/body/doggyactiveoralfast.gif">
<<if $enemyarousal gte $enemyarousalmax>>
<img id="sextears" src="img/sex/doggy/active/body/doggyactiveoralcumfast.gif">
<</if>>
<</if>>
<<tentacleimgfast>>
<<if $vaginastate is "othermouth">>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivevaginalmouthfast.gif">
<</if>>
<<if $vaginastate is "penetrated">>
<<if $enemytype isnot "beast">>
<<if $anusstate is "penetrated">>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivevaginaldpfast.gif">
<<else>>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivevaginalfast.gif">
<</if>>
<</if>>
<<if $enemyarousal gte $enemyarousalmax>>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivevaginalcumfast.gif">
<</if>>
<</if>>
<<if $anusstate is "othermouth">>
<img id="sextears" src="img/sex/doggy/active/body/doggyactiveanalmouthfast.gif">
<</if>>
<<if $anusstate is "penetrated">>
<<if $enemytype isnot "beast">>
<img id="sextears" src="img/sex/doggy/active/body/doggyactiveanalfast.gif">
<</if>>
<<if $enemyarousal gte $enemyarousalmax>>
<img id="sextears" src="img/sex/doggy/active/body/doggyactiveanalcumfast.gif">
<</if>>
<</if>>
<<if $penisstate is "othermouth">>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivepenilefast.gif">
<</if>>
<<if $penisstate is "penetrated" or $penisstate is "otheranus">>
<<if $orgasmdown gte 1 and $orgasmcount lte 24>>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivepenilecumfast.gif">
<<else>>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivepenilefast.gif">
<</if>>
<</if>>
<<if $penisexist is 1>>
<<if $undertype is "chastity">>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivepenischastityfast.gif">
<<elseif $penilevirginity is 1>>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivepenisvirginfast.gif">
<<else>>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivepenisfast.gif">
<</if>>
<<if $orgasmdown gte 1 and $penisstate isnot "penetrated" and $orgasmcount lte 24>>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivecumfast.gif">
<</if>>
<</if>>
<<if $hairlength gte 900>>
<img id="sexhair" class="colour-hair" src="img/sex/doggy/active/hair/red/doggyactivefeetredfast.gif">
<<elseif $hairlength gte 700>>
<img id="sexhair" class="colour-hair" src="img/sex/doggy/active/hair/red/doggyactivethighsredfast.gif">
<<elseif $hairlength gte 600>>
<img id="sexhair" class="colour-hair" src="img/sex/doggy/active/hair/red/doggyactivenavelredfast.gif">
<<elseif $hairlength gte 400>>
<img id="sexhair" class="colour-hair" src="img/sex/doggy/active/hair/red/doggyactivechestredfast.gif">
<<elseif $hairlength gte 200>>
<img id="sexhair" class="colour-hair" src="img/sex/doggy/active/hair/red/doggyactiveshoulderredfast.gif">
<<else>>
<img id="sexhair" class="colour-hair" src="img/sex/doggy/active/hair/red/doggyactiveshortredfast.gif">
<</if>>
<img id="sexlashes" class="colour-hair" src="img/sex/doggy/active/hair/red/doggyactivelashesredfast.gif">
<img id="sexsclera" src="img/sex/doggy/active/body/doggyactivefaceoverlayfast.gif">
<<if $collared is 1>>
<img id="sexmouth" src="img/sex/doggy/active/body/doggyactivecollarfast.gif">
<</if>>
<<breastsactivefast>>
<<if $underclothes is "chastity belt">>
<img id="sexbase" src="img/sex/doggy/active/body/doggyactivechastitybeltfast.gif">
<</if>>
<img id="sexbase" src="img/sex/doggy/active/body/doggyactiveshadowfast.gif">
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<<beastimgmid>>
<<transformationwolfimgmid>>
<img id="sexbrow" class="colour-hair" src="img/sex/doggy/active/hair/red/doggyactiveoverlayredmid.gif">
<img id="sexbase" src="img/sex/doggy/active/body/doggyactivebasemid.gif">
<img id="sexmouth" src="img/sex/doggy/active/body/doggyactivemouthmid.gif">
<<if $feetuse is "penis">>
<img id="sexbase" src="img/sex/doggy/active/body/doggyactivefeetjobmid.gif">
<<elseif $feetstate is "tentacle">>
<<else>>
<img id="sexbase" src="img/sex/doggy/active/body/doggyactivebaselegsmid.gif">
<</if>>
<<if $leftarm is "penis">>
<img id="sexbasefront" src="img/sex/doggy/active/body/doggyactivelefthandjobmid.gif">
<<elseif $leftarm is "bound">>
<img id="sexbasefront" src="img/sex/doggy/active/body/doggyactiveleftarmboundmid.gif">
<<elseif $leftarm is "grappled">>
<img id="sexbasefront" src="img/sex/doggy/active/body/doggyactiveleftarmboundmid.gif">
<<elseif $leftarmstate is "tentacle">>
<<else>>
<img id="sexbasefront" src="img/sex/doggy/active/body/doggyactivebaseleftarmmid.gif">
<</if>>
<<if $rightarm is "penis">>
<img id="sexbaseback"
src="img/sex/doggy/active/body/doggyactiverighthandjobmid.gif">
<<elseif $rightarm is "bound">>
<<elseif $rightarm is "grappled">>
<<elseif $rightarmstate is "tentacle">>
<<else>>
<img id="sexbaseback" src="img/sex/doggy/active/body/doggyactivebaserightarm.gif">
<</if>>
<<if $anusstate is "cheeks">>
<<if $enemytype isnot "beast">>
<img id="sexbase" src="img/sex/doggy/active/body/doggyactivecheeksmid.gif">
<</if>>
<<if $enemyarousal gte $enemyarousalmax>>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivecheekscum.gif">
<</if>>
<</if>>
<<if $thighuse is "penis">>
<<if $enemytype isnot "beast">>
<img id="sexbase" src="img/sex/doggy/active/body/doggyactivethighsmid.gif">
<</if>>
<<if $enemyarousal gte $enemyarousalmax>>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivethighscum.gif">
<</if>>
<</if>>
<<if $arousal gte 8000>>
<img id="sexblush" src="img/sex/doggy/active/body/doggyactiveblush5mid.gif">
<<elseif $arousal gte 6000>>
<img id="sexblush" src="img/sex/doggy/active/body/doggyactiveblush4mid.gif">
<<elseif $arousal gte 4000>>
<img id="sexblush" src="img/sex/doggy/active/body/doggyactiveblush3mid.gif">
<<elseif $exposed gte 2>>
<img id="sexblush" src="img/sex/doggy/active/body/doggyactiveblush2mid.gif">
<<elseif $arousal gte 2000>>
<img id="sexblush" src="img/sex/doggy/active/body/doggyactiveblush2mid.gif">
<<elseif $exposed gte 1>>
<img id="sexblush" src="img/sex/doggy/active/body/doggyactiveblush1mid.gif">
<<elseif $arousal gte 100>>
<img id="sexblush" src="img/sex/doggy/active/body/doggyactiveblush1mid.gif">
<</if>>
<<if $pain gte 80>>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivetears5mid.gif">
<<elseif $pain gte 60>>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivetears4mid.gif">
<<elseif $pain gte 40>>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivetears3mid.gif">
<<elseif $pain gte 20>>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivetears2mid.gif">
<<else>>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivetears1mid.gif">
<</if>>
<<if $pain gte 100>>
<img id="sexsclera" src="img/sex/doggy/active/eyes/doggyactivesclerabloodshotmid.gif">
<</if>>
<<if $trauma gte $traumamax>>
<img id="sexeyes" class="colour-eye" src="img/sex/doggy/active/eyes/doggyactivehazelemptymid.gif">
<<else>>
<img id="sexeyes" class="colour-eye" src="img/sex/doggy/active/eyes/doggyactivehazelmid.gif">
<</if>>
<<if $mouthstate is "kiss">>
<img id="sextears" src="img/sex/doggy/active/body/doggyactiveoralmouthmid.gif">
<</if>>
<<if $mouthstate is "penetrated">>
<img id="sextears" src="img/sex/doggy/active/body/doggyactiveoralmid.gif">
<<if $enemyarousal gte $enemyarousalmax>>
<img id="sextears" src="img/sex/doggy/active/body/doggyactiveoralcummid.gif">
<</if>>
<</if>>
<<tentacleimgmid>>
<<if $vaginastate is "othermouth">>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivevaginalmouthmid.gif">
<</if>>
<<if $vaginastate is "penetrated">>
<<if $enemytype isnot "beast">>
<<if $anusstate is "penetrated">>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivevaginaldpmid.gif">
<<else>>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivevaginalmid.gif">
<</if>>
<</if>>
<<if $enemyarousal gte $enemyarousalmax>>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivevaginalcummid.gif">
<</if>>
<</if>>
<<if $anusstate is "othermouth">>
<img id="sextears" src="img/sex/doggy/active/body/doggyactiveanalmouthmid.gif">
<</if>>
<<if $anusstate is "penetrated">>
<<if $enemytype isnot "beast">>
<img id="sextears" src="img/sex/doggy/active/body/doggyactiveanalmid.gif">
<</if>>
<<if $enemyarousal gte $enemyarousalmax>>
<img id="sextears" src="img/sex/doggy/active/body/doggyactiveanalcummid.gif">
<</if>>
<</if>>
<<if $penisstate is "othermouth">>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivepenilemid.gif">
<</if>>
<<if $penisstate is "penetrated" or $penisstate is "otheranus">>
<<if $orgasmdown gte 1 and $orgasmcount lte 24>>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivepenilecummid.gif">
<<else>>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivepenilemid.gif">
<</if>>
<</if>>
<<if $penisexist is 1>>
<<if $undertype is "chastity">>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivepenischastitymid.gif">
<<elseif $penilevirginity is 1>>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivepenisvirginmid.gif">
<<else>>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivepenismid.gif">
<</if>>
<<if $orgasmdown gte 1 and $penisstate isnot "penetrated" and $orgasmcount lte 24>>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivecummid.gif">
<</if>>
<</if>>
<<if $hairlength gte 900>>
<img id="sexhair" class="colour-hair" src="img/sex/doggy/active/hair/red/doggyactivefeetredmid.gif">
<<elseif $hairlength gte 700>>
<img id="sexhair" class="colour-hair" src="img/sex/doggy/active/hair/red/doggyactivethighsredmid.gif">
<<elseif $hairlength gte 600>>
<img id="sexhair" class="colour-hair" src="img/sex/doggy/active/hair/red/doggyactivenavelredmid.gif">
<<elseif $hairlength gte 400>>
<img id="sexhair" class="colour-hair" src="img/sex/doggy/active/hair/red/doggyactivechestredmid.gif">
<<elseif $hairlength gte 200>>
<img id="sexhair" class="colour-hair" src="img/sex/doggy/active/hair/red/doggyactiveshoulderredmid.gif">
<<else>>
<img id="sexhair" class="colour-hair" src="img/sex/doggy/active/hair/red/doggyactiveshortredmid.gif">
<</if>>
<img id="sexlashes" class="colour-hair" src="img/sex/doggy/active/hair/red/doggyactivelashesredmid.gif">
<img id="sexsclera" src="img/sex/doggy/active/body/doggyactivefaceoverlaymid.gif">
<<if $collared is 1>>
<img id="sexmouth" src="img/sex/doggy/active/body/doggyactivecollarmid.gif">
<</if>>
<<breastsactivemid>>
<<if $underclothes is "chastity belt">>
<img id="sexbase" src="img/sex/doggy/active/body/doggyactivechastitybeltmid.gif">
<</if>>
<img id="sexbase" src="img/sex/doggy/active/body/doggyactiveshadowmid.gif">
<<else>>
<<beastimgslow>>
<<transformationwolfimgslow>>
<img id="sexbrow" class="colour-hair" src="img/sex/doggy/active/hair/red/doggyactiveoverlayredslow.gif">
<img id="sexbase" src="img/sex/doggy/active/body/doggyactivebaseslow.gif">
<img id="sexmouth" src="img/sex/doggy/active/body/doggyactivemouthslow.gif">
<<if $feetuse is "penis">>
<img id="sexbase" src="img/sex/doggy/active/body/doggyactivefeetjobslow.gif">
<<elseif $feetstate is "tentacle">>
<<else>>
<img id="sexbase" src="img/sex/doggy/active/body/doggyactivebaselegsslow.gif">
<</if>>
<<if $leftarm is "penis">>
<img id="sexbasefront" src="img/sex/doggy/active/body/doggyactivelefthandjobslow.gif">
<<elseif $leftarm is "bound">>
<img id="sexbasefront" src="img/sex/doggy/active/body/doggyactiveleftarmboundslow.gif">
<<elseif $leftarm is "grappled">>
<img id="sexbasefront" src="img/sex/doggy/active/body/doggyactiveleftarmboundslow.gif">
<<elseif $leftarmstate is "tentacle">>
<<else>>
<img id="sexbasefront" src="img/sex/doggy/active/body/doggyactivebaseleftarmslow.gif">
<</if>>
<<if $rightarm is "penis">>
<img id="sexbaseback"
src="img/sex/doggy/active/body/doggyactiverighthandjobslow.gif">
<<elseif $rightarm is "bound">>
<<elseif $rightarm is "grappled">>
<<elseif $rightarmstate is "tentacle">>
<<else>>
<img id="sexbaseback" src="img/sex/doggy/active/body/doggyactivebaserightarm.gif">
<</if>>
<<if $anusstate is "cheeks">>
<<if $enemytype isnot "beast">>
<img id="sexbase" src="img/sex/doggy/active/body/doggyactivecheeksslow.gif">
<</if>>
<<if $enemyarousal gte $enemyarousalmax>>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivecheekscum.gif">
<</if>>
<</if>>
<<if $thighuse is "penis">>
<<if $enemytype isnot "beast">>
<img id="sexbase" src="img/sex/doggy/active/body/doggyactivethighsslow.gif">
<</if>>
<<if $enemyarousal gte $enemyarousalmax>>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivethighscum.gif">
<</if>>
<</if>>
<<if $arousal gte 8000>>
<img id="sexblush" src="img/sex/doggy/active/body/doggyactiveblush5slow.gif">
<<elseif $arousal gte 6000>>
<img id="sexblush" src="img/sex/doggy/active/body/doggyactiveblush4slow.gif">
<<elseif $arousal gte 4000>>
<img id="sexblush" src="img/sex/doggy/active/body/doggyactiveblush3slow.gif">
<<elseif $exposed gte 2>>
<img id="sexblush" src="img/sex/doggy/active/body/doggyactiveblush2slow.gif">
<<elseif $arousal gte 2000>>
<img id="sexblush" src="img/sex/doggy/active/body/doggyactiveblush2slow.gif">
<<elseif $exposed gte 1>>
<img id="sexblush" src="img/sex/doggy/active/body/doggyactiveblush1slow.gif">
<<elseif $arousal gte 100>>
<img id="sexblush" src="img/sex/doggy/active/body/doggyactiveblush1slow.gif">
<</if>>
<<if $pain gte 80>>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivetears5slow.gif">
<<elseif $pain gte 60>>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivetears4slow.gif">
<<elseif $pain gte 40>>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivetears3slow.gif">
<<elseif $pain gte 20>>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivetears2slow.gif">
<<else>>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivetears1slow.gif">
<</if>>
<<if $pain gte 100>>
<img id="sexsclera" src="img/sex/doggy/active/eyes/doggyactivesclerabloodshotslow.gif">
<</if>>
<<if $trauma gte $traumamax>>
<img id="sexeyes" class="colour-eye" src="img/sex/doggy/active/eyes/doggyactivehazelemptyslow.gif">
<<else>>
<img id="sexeyes" class="colour-eye" src="img/sex/doggy/active/eyes/doggyactivehazelslow.gif">
<</if>>
<<if $mouthstate is "penetrated">>
<img id="sextears" src="img/sex/doggy/active/body/doggyactiveoralslow.gif">
<<if $enemyarousal gte $enemyarousalmax>>
<img id="sextears" src="img/sex/doggy/active/body/doggyactiveoralcumslow.gif">
<</if>>
<</if>>
<<if $mouthstate is "kiss">>
<img id="sextears" src="img/sex/doggy/active/body/doggyactiveoralmouthslow.gif">
<</if>>
<<tentacleimgslow>>
<<if $vaginastate is "othermouth">>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivevaginalmouthslow.gif">
<</if>>
<<if $vaginastate is "penetrated">>
<<if $enemytype isnot "beast">>
<<if $anusstate is "penetrated">>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivevaginaldpslow.gif">
<<else>>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivevaginalslow.gif">
<</if>>
<</if>>
<<if $enemyarousal gte $enemyarousalmax>>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivevaginalcumslow.gif">
<</if>>
<</if>>
<<if $anusstate is "othermouth">>
<img id="sextears" src="img/sex/doggy/active/body/doggyactiveanalmouthslow.gif">
<</if>>
<<if $anusstate is "penetrated">>
<<if $enemytype isnot "beast">>
<img id="sextears" src="img/sex/doggy/active/body/doggyactiveanalslow.gif">
<</if>>
<<if $enemyarousal gte $enemyarousalmax>>
<img id="sextears" src="img/sex/doggy/active/body/doggyactiveanalcumslow.gif">
<</if>>
<</if>>
<<if $penisstate is "othermouth">>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivepenileslow.gif">
<</if>>
<<if $penisstate is "penetrated" or $penisstate is "otheranus">>
<<if $orgasmdown gte 1 and $orgasmcount lte 24>>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivepenilecumslow.gif">
<<else>>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivepenileslow.gif">
<</if>>
<</if>>
<<if $penisexist is 1>>
<<if $undertype is "chastity">>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivepenischastityslow.gif">
<<elseif $penilevirginity is 1>>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivepenisvirginslow.gif">
<<else>>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivepenisslow.gif">
<</if>>
<<if $orgasmdown gte 1 and $penisstate isnot "penetrated" and $orgasmcount lte 24>>
<img id="sextears" src="img/sex/doggy/active/body/doggyactivecumslow.gif">
<</if>>
<</if>>
<<if $hairlength gte 900>>
<img id="sexhair" class="colour-hair" src="img/sex/doggy/active/hair/red/doggyactivefeetredslow.gif">
<<elseif $hairlength gte 700>>
<img id="sexhair" class="colour-hair" src="img/sex/doggy/active/hair/red/doggyactivethighsredslow.gif">
<<elseif $hairlength gte 600>>
<img id="sexhair" class="colour-hair" src="img/sex/doggy/active/hair/red/doggyactivenavelredslow.gif">
<<elseif $hairlength gte 400>>
<img id="sexhair" class="colour-hair" src="img/sex/doggy/active/hair/red/doggyactivechestredslow.gif">
<<elseif $hairlength gte 200>>
<img id="sexhair" class="colour-hair" src="img/sex/doggy/active/hair/red/doggyactiveshoulderredslow.gif">
<<else>>
<img id="sexhair" class="colour-hair" src="img/sex/doggy/active/hair/red/doggyactiveshortredslow.gif">
<</if>>
<img id="sexlashes" class="colour-hair" src="img/sex/doggy/active/hair/red/doggyactivelashesredslow.gif">
<img id="sexsclera" src="img/sex/doggy/active/body/doggyactivefaceoverlayslow.gif">
<<if $collared is 1>>
<img id="sexmouth" src="img/sex/doggy/active/body/doggyactivecollarslow.gif">
<</if>>
<<breastsactiveslow>>
<<if $underclothes is "chastity belt">>
<img id="sexbase" src="img/sex/doggy/active/body/doggyactivechastitybeltslow.gif">
<</if>>
<img id="sexbase" src="img/sex/doggy/active/body/doggyactiveshadowslow.gif">
<</if>>
<<if $vaginastate isnot "penetrated"
and $anusstate isnot "penetrated"
and $anusstate isnot "cheeks"
and $thighuse isnot "penis"
and $vaginastate isnot "tentacle"
and $vaginastate isnot "tentacledeep"
and $vaginastate isnot "tentacleentrance"
and $vaginastate isnot "tentacleimminent"
and $anusstate isnot "tentacle"
and $anusstate isnot "tentacledeep"
and $anusstate isnot "tentacleentrance"
and $anusstate isnot "tentacleimminent"
and $swarmfront is 0
and $swarmback is 0
and $swarmfrontinside is 0
and $swarmbackinside is 0
and $beaststance isnot "top">>
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<img id="sexbaseoverlay" src="img/sex/doggy/active/body/doggyactivepushlightvfast.gif">
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 3>>
<img id="sexbaseoverlay" src="img/sex/doggy/active/body/doggyactivepushlightfast.gif">
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<img id="sexbaseoverlay" src="img/sex/doggy/active/body/doggyactivepushlightmid.gif">
<<else>>
<img id="sexbaseoverlay" src="img/sex/doggy/active/body/doggyactivepushlightslow.gif">
<</if>>
<<if $position is "wall">>
<img id="foreground" src="img/sex/doggy/doggywall.png">
<</if>>
<</nobr>><</widget>>
<<widget "xrayimg">><<nobr>>
<<if $vaginastate is "penetrated">>
<<xraycum>>
<<if $enemytype is "beast">>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<img id="xrayvaginal" src="img/sex/xraybeastvaginalvfast.gif">
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 3>>
<img id="xrayvaginal" src="img/sex/xraybeastvaginalfast.gif">
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<img id="xrayvaginal" src="img/sex/xraybeastvaginalmid.gif">
<<else>>
<img id="xrayvaginal" src="img/sex/xraybeastvaginalslow.gif">
<</if>>
<<elseif $npcskin1 is "black">>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<img id="xrayvaginal" src="img/sex/black/xrayvaginalvfast.gif">
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 3>>
<img id="xrayvaginal" src="img/sex/black/xrayvaginalfast.gif">
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<img id="xrayvaginal" src="img/sex/black/xrayvaginalmid.gif">
<<else>>
<img id="xrayvaginal" src="img/sex/black/xrayvaginalslow.gif">
<</if>>
<<else>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<img id="xrayvaginal" src="img/sex/xrayvaginalvfast.gif">
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 3>>
<img id="xrayvaginal" src="img/sex/xrayvaginalfast.gif">
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<img id="xrayvaginal" src="img/sex/xrayvaginalmid.gif">
<<else>>
<img id="xrayvaginal" src="img/sex/xrayvaginalslow.gif">
<</if>>
<</if>>
<<elseif $vaginastate is "tentacle">>
<<xraycum>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<img id="xrayvaginal" src="img/sex/xrayvaginaltentaclevfast.gif">
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 3>>
<img id="xrayvaginal" src="img/sex/xrayvaginaltentaclefast.gif">
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<img id="xrayvaginal" src="img/sex/xrayvaginaltentaclemid.gif">
<<else>>
<img id="xrayvaginal" src="img/sex/xrayvaginaltentacleslow.gif">
<</if>>
<<elseif $vaginastate is "tentacledeep">>
<<xraycum>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<img id="xrayvaginal" src="img/sex/xrayvaginaltentaclecumvfast.gif">
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 3>>
<img id="xrayvaginal" src="img/sex/xrayvaginaltentaclecumfast.gif">
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<img id="xrayvaginal" src="img/sex/xrayvaginaltentaclecummid.gif">
<<else>>
<img id="xrayvaginal" src="img/sex/xrayvaginaltentaclecumslow.gif">
<</if>>
<</if>>
<<if window.document.body.clientWidth lt 650>>
<<if $anusstate is "penetrated">>
<<if $enemytype is "beast">>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<img id="xrayandroidanal" src="img/sex/xraybeastanalvfast.gif">
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 3>>
<img id="xrayandroidanal" src="img/sex/xraybeastanalfast.gif">
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<img id="xrayandroidanal" src="img/sex/xraybeastanalmid.gif">
<<else>>
<img id="xrayandroidanal" src="img/sex/xraybeastanalslow.gif">
<</if>>
<<elseif $npcskin1 is "black">>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<img id="xrayandroidanal" src="img/sex/black/xrayanalvfast.gif">
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 3>>
<img id="xrayandroidanal" src="img/sex/black/xrayanalfast.gif">
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<img id="xrayandroidanal" src="img/sex/black/xrayanalmid.gif">
<<else>>
<img id="xrayandroidanal" src="img/sex/black/xrayanalslow.gif">
<</if>>
<<else>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<img id="xrayandroidanal" src="img/sex/xrayanalvfast.gif">
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 3>>
<img id="xrayandroidanal" src="img/sex/xrayanalfast.gif">
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<img id="xrayandroidanal" src="img/sex/xrayanalmid.gif">
<<else>>
<img id="xrayandroidanal" src="img/sex/xrayanalslow.gif">
<</if>>
<</if>>
<<elseif $anusstate is "tentacle">>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<img id="xrayandroidanal" src="img/sex/xrayanaltentaclevfast.gif">
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 3>>
<img id="xrayandroidanal" src="img/sex/xrayanaltentaclefast.gif">
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<img id="xrayandroidanal" src="img/sex/xrayanaltentaclemid.gif">
<<else>>
<img id="xrayandroidanal" src="img/sex/xrayanaltentacleslow.gif">
<</if>>
<<elseif $anusstate is "tentacledeep">>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<img id="xrayandroidanal" src="img/sex/xrayanaltentaclecumvfast.gif">
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 3>>
<img id="xrayandroidanal" src="img/sex/xrayanaltentaclecumfast.gif">
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<img id="xrayandroidanal" src="img/sex/xrayanaltentaclecummid.gif">
<<else>>
<img id="xrayandroidanal" src="img/sex/xrayanaltentaclecumslow.gif">
<</if>>
<</if>>
<<else>>
<<if $anusstate is "penetrated">>
<<if $enemytype is "beast">>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<img id="xrayanal" src="img/sex/xraybeastanalvfast.gif">
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 3>>
<img id="xrayanal" src="img/sex/xraybeastanalfast.gif">
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<img id="xrayanal" src="img/sex/xraybeastanalmid.gif">
<<else>>
<img id="xrayanal" src="img/sex/xraybeastanalslow.gif">
<</if>>
<<elseif $npcskin1 is "black">>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<img id="xrayanal" src="img/sex/black/xrayanalvfast.gif">
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 3>>
<img id="xrayanal" src="img/sex/black/xrayanalfast.gif">
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<img id="xrayanal" src="img/sex/black/xrayanalmid.gif">
<<else>>
<img id="xrayanal" src="img/sex/black/xrayanalslow.gif">
<</if>>
<<else>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<img id="xrayanal" src="img/sex/xrayanalvfast.gif">
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 3>>
<img id="xrayanal" src="img/sex/xrayanalfast.gif">
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<img id="xrayanal" src="img/sex/xrayanalmid.gif">
<<else>>
<img id="xrayanal" src="img/sex/xrayanalslow.gif">
<</if>>
<</if>>
<<elseif $anusstate is "tentacle">>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<img id="xrayanal" src="img/sex/xrayanaltentaclevfast.gif">
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 3>>
<img id="xrayanal" src="img/sex/xrayanaltentaclefast.gif">
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<img id="xrayanal" src="img/sex/xrayanaltentaclemid.gif">
<<else>>
<img id="xrayanal" src="img/sex/xrayanaltentacleslow.gif">
<</if>>
<<elseif $anusstate is "tentacledeep">>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<img id="xrayanal" src="img/sex/xrayanaltentaclecumvfast.gif">
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 3>>
<img id="xrayanal" src="img/sex/xrayanaltentaclecumfast.gif">
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<img id="xrayanal" src="img/sex/xrayanaltentaclecummid.gif">
<<else>>
<img id="xrayanal" src="img/sex/xrayanaltentaclecumslow.gif">
<</if>>
<</if>>
<</if>>
<<if $penisstate is "penetrated">>
<<if $orgasmdown gte 1 and $devstate is 1 and $orgasmcount lte 24>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<img id="xraypenile" src="img/sex/xrayvaginalcumvfast.gif">
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 3>>
<img id="xraypenile" src="img/sex/xrayvaginalcumfast.gif">
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<img id="xraypenile" src="img/sex/xrayvaginalcummid.gif">
<<else>>
<img id="xraypenile" src="img/sex/xrayvaginalcumslow.gif">
<</if>>
<<else>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<img id="xraypenile" src="img/sex/xrayvaginalvfast.gif">
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 3>>
<img id="xraypenile" src="img/sex/xrayvaginalfast.gif">
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<img id="xraypenile" src="img/sex/xrayvaginalmid.gif">
<<else>>
<img id="xraypenile" src="img/sex/xrayvaginalslow.gif">
<</if>>
<</if>>
<<elseif $penisstate is "tentacle">>
<<if $orgasmdown gte 1 and $devstate is 1 and $orgasmcount lte 24>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<img id="xraypenile" src="img/sex/xraypeniletentaclecumvfast.gif">
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 3>>
<img id="xraypenile" src="img/sex/xraypeniletentaclecumfast.gif">
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<img id="xraypenile" src="img/sex/xraypeniletentaclecummid.gif">
<<else>>
<img id="xraypenile" src="img/sex/xraypeniletentaclecumslow.gif">
<</if>>
<<else>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<img id="xraypenile" src="img/sex/xraypeniletentaclevfast.gif">
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 3>>
<img id="xraypenile" src="img/sex/xraypeniletentaclefast.gif">
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<img id="xraypenile" src="img/sex/xraypeniletentaclemid.gif">
<<else>>
<img id="xraypenile" src="img/sex/xraypeniletentacleslow.gif">
<</if>>
<</if>>
<<elseif $penisstate is "tentacledeep">>
<<if $orgasmdown gte 1 and $devstate is 1 and $orgasmcount lte 24>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<img id="xraypenile" src="img/sex/xraypeniletentaclecumvfast.gif">
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 3>>
<img id="xraypenile" src="img/sex/xraypeniletentaclecumfast.gif">
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<img id="xraypenile" src="img/sex/xraypeniletentaclecummid.gif">
<<else>>
<img id="xraypenile" src="img/sex/xraypeniletentaclecumslow.gif">
<</if>>
<<else>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<img id="xraypenile" src="img/sex/xraypeniletentaclevfast.gif">
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 3>>
<img id="xraypenile" src="img/sex/xraypeniletentaclefast.gif">
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<img id="xraypenile" src="img/sex/xraypeniletentaclemid.gif">
<<else>>
<img id="xraypenile" src="img/sex/xraypeniletentacleslow.gif">
<</if>>
<</if>>
<<elseif $penisstate is "otheranus">>
<<if $orgasmdown gte 1 and $devstate is 1 and $orgasmcount lte 24>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<img id="xraypenile" src="img/sex/xrayanalcumvfast.gif">
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 3>>
<img id="xraypenile" src="img/sex/xrayanalcumfast.gif">
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<img id="xraypenile" src="img/sex/xrayanalcummid.gif">
<<else>>
<img id="xraypenile" src="img/sex/xrayanalcumslow.gif">
<</if>>
<<else>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<img id="xraypenile" src="img/sex/xrayanalvfast.gif">
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 3>>
<img id="xraypenile" src="img/sex/xrayanalfast.gif">
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<img id="xraypenile" src="img/sex/xrayanalmid.gif">
<<else>>
<img id="xraypenile" src="img/sex/xrayanalslow.gif">
<</if>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "ejacimg">><<nobr>>
<<if $enemytype is "beast">>
<<if $vaginastate is "penetrated">>
<img id="xrayvaginal" src="img/sex/xraybeastvaginalcumvfast.gif">
<</if>>
<<if window.document.body.clientWidth lt 650>>
<<if $anusstate is "penetrated">>
<img id="xrayandroidanal" src="img/sex/xraybeastanalcumvfast.gif">
<</if>>
<<else>>
<<if $anusstate is "penetrated">>
<img id="xrayanal" src="img/sex/xraybeastanalcumvfast.gif">
<</if>>
<</if>>
<<elseif $npcskin1 is "black">>
<<if $vaginastate is "penetrated">>
<img id="xrayvaginal" src="img/sex/black/xrayvaginalcumvfast.gif">
<</if>>
<<if window.document.body.clientWidth lt 650>>
<<if $anusstate is "penetrated">>
<img id="xrayandroidanal" src="img/sex/black/xrayanalcumvfast.gif">
<</if>>
<<else>>
<<if $anusstate is "penetrated">>
<img id="xrayanal" src="img/sex/black/xrayanalcumvfast.gif">
<</if>>
<</if>>
<<else>>
<<if $vaginastate is "penetrated">>
<img id="xrayvaginal" src="img/sex/xrayvaginalcumvfast.gif">
<</if>>
<<if window.document.body.clientWidth lt 650>>
<<if $anusstate is "penetrated">>
<img id="xrayandroidanal" src="img/sex/xrayanalcumvfast.gif">
<</if>>
<<else>>
<<if $anusstate is "penetrated">>
<img id="xrayanal" src="img/sex/xrayanalcumvfast.gif">
<</if>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "xraycum">><<nobr>>
<<if $vaginasemen + $vaginagoo gte 5>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<img id="xrayvaginalcum" src="img/sex/xraycum5vfast.gif">
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 3>>
<img id="xrayvaginalcum" src="img/sex/xraycum5fast.gif">
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<img id="xrayvaginalcum" src="img/sex/xraycum5mid.gif">
<<else>>
<img id="xrayvaginalcum" src="img/sex/xraycum5slow.gif">
<</if>>
<<elseif $vaginasemen + $vaginagoo is 4>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<img id="xrayvaginalcum" src="img/sex/xraycum4vfast.gif">
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 3>>
<img id="xrayvaginalcum" src="img/sex/xraycum4fast.gif">
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<img id="xrayvaginalcum" src="img/sex/xraycum4mid.gif">
<<else>>
<img id="xrayvaginalcum" src="img/sex/xraycum4slow.gif">
<</if>>
<<elseif $vaginasemen + $vaginagoo is 3>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<img id="xrayvaginalcum" src="img/sex/xraycum3vfast.gif">
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 3>>
<img id="xrayvaginalcum" src="img/sex/xraycum3fast.gif">
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<img id="xrayvaginalcum" src="img/sex/xraycum3mid.gif">
<<else>>
<img id="xrayvaginalcum" src="img/sex/xraycum3slow.gif">
<</if>>
<<elseif $vaginasemen + $vaginagoo is 2>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<img id="xrayvaginalcum" src="img/sex/xraycum2vfast.gif">
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 3>>
<img id="xrayvaginalcum" src="img/sex/xraycum2fast.gif">
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<img id="xrayvaginalcum" src="img/sex/xraycum2mid.gif">
<<else>>
<img id="xrayvaginalcum" src="img/sex/xraycum2slow.gif">
<</if>>
<<elseif $vaginasemen + $vaginagoo is 1>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<img id="xrayvaginalcum" src="img/sex/xraycum1vfast.gif">
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 3>>
<img id="xrayvaginalcum" src="img/sex/xraycum1fast.gif">
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<img id="xrayvaginalcum" src="img/sex/xraycum1mid.gif">
<<else>>
<img id="xrayvaginalcum" src="img/sex/xraycum1slow.gif">
<</if>>
<</if>>
<</nobr>><</widget>>
:: Widgets Actions Left Hand [widget]
<<widget "leftgrab">><<nobr>>
<<if $penis is 0>>
<<if $consensual is 1 and $promiscuity lte 34 and $enemytype is "man" or $consensual is 1 and $deviancy lte 34 and $enemytype isnot "man">>
<<else>>
<<if $leftactiondefault is "leftgrab">>
| <label><span class="sub">Grab <<his>> penis</span> <<radiobutton "$leftaction" "leftgrab" checked>><<handdifficulty>> <<combatpromiscuous3>></label>
<<else>>
| <label><span class="sub">Grab <<his>> penis</span> <<radiobutton "$leftaction" "leftgrab">><<handdifficulty>> <<combatpromiscuous3>></label>
<</if>>
<</if>>
<<if $leftactiondefault is "leftstroke">>
| <label><span class="sub">Stroke <<his>> penis</span> <<radiobutton "$leftaction" "leftstroke" checked>></label>
<<else>>
| <label><span class="sub">Stroke <<his>> penis</span> <<radiobutton "$leftaction" "leftstroke">></label>
<</if>>
<<elseif $penis2 is 0>>
<<if $consensual is 1 and $promiscuity lte 34 and $enemytype is "man" or $consensual is 1 and $deviancy lte 34 and $enemytype isnot "man">>
<<else>>
<<if $leftactiondefault is "leftgrab">>
| <label><span class="sub">Grab <<his>> penis</span> <<radiobutton "$leftaction" "leftgrab" checked>><<handdifficulty>> <<combatpromiscuous3>></label>
<<else>>
| <label><span class="sub">Grab <<his>> penis</span> <<radiobutton "$leftaction" "leftgrab">><<handdifficulty>> <<combatpromiscuous3>></label>
<</if>>
<</if>>
<<if $leftactiondefault is "leftstroke">>
| <label><span class="sub">Stroke <<his>> penis</span> <<radiobutton "$leftaction" "leftstroke" checked>></label>
<<else>>
| <label><span class="sub">Stroke <<his>> penis</span> <<radiobutton "$leftaction" "leftstroke">></label>
<</if>>
<<elseif $penis3 is 0>>
<<if $consensual is 1 and $promiscuity lte 34 and $enemytype is "man" or $consensual is 1 and $deviancy lte 34 and $enemytype isnot "man">>
<<else>>
<<if $leftactiondefault is "leftgrab">>
| <label><span class="sub">Grab <<his>> penis</span> <<radiobutton "$leftaction" "leftgrab" checked>><<handdifficulty>> <<combatpromiscuous3>></label>
<<else>>
| <label><span class="sub">Grab <<his>> penis</span> <<radiobutton "$leftaction" "leftgrab">><<handdifficulty>> <<combatpromiscuous3>></label>
<</if>>
<</if>>
<<if $leftactiondefault is "leftstroke">>
| <label><span class="sub">Stroke <<his>> penis</span> <<radiobutton "$leftaction" "leftstroke" checked>></label>
<<else>>
| <label><span class="sub">Stroke <<his>> penis</span> <<radiobutton "$leftaction" "leftstroke">></label>
<</if>>
<<elseif $penis4 is 0>>
<<if $consensual is 1 and $promiscuity lte 34 and $enemytype is "man" or $consensual is 1 and $deviancy lte 34 and $enemytype isnot "man">>
<<else>>
<<if $leftactiondefault is "leftgrab">>
| <label><span class="sub">Grab <<his>> penis</span> <<radiobutton "$leftaction" "leftgrab" checked>><<handdifficulty>> <<combatpromiscuous3>></label>
<<else>>
| <label><span class="sub">Grab <<his>> penis</span> <<radiobutton "$leftaction" "leftgrab">><<handdifficulty>> <<combatpromiscuous3>></label>
<</if>>
<</if>>
<<if $leftactiondefault is "leftstroke">>
| <label><span class="sub">Stroke <<his>> penis</span> <<radiobutton "$leftaction" "leftstroke" checked>></label>
<<else>>
| <label><span class="sub">Stroke <<his>> penis</span> <<radiobutton "$leftaction" "leftstroke">></label>
<</if>>
<<elseif $penis5 is 0>>
<<if $consensual is 1 and $promiscuity lte 34 and $enemytype is "man" or $consensual is 1 and $deviancy lte 34 and $enemytype isnot "man">>
<<else>>
<<if $leftactiondefault is "leftgrab">>
| <label><span class="sub">Grab <<his>> penis</span> <<radiobutton "$leftaction" "leftgrab" checked>><<handdifficulty>> <<combatpromiscuous3>></label>
<<else>>
| <label><span class="sub">Grab <<his>> penis</span> <<radiobutton "$leftaction" "leftgrab">><<handdifficulty>> <<combatpromiscuous3>></label>
<</if>>
<</if>>
<<if $leftactiondefault is "leftstroke">>
| <label><span class="sub">Stroke <<his>> penis</span> <<radiobutton "$leftaction" "leftstroke" checked>></label>
<<else>>
| <label><span class="sub">Stroke <<his>> penis</span> <<radiobutton "$leftaction" "leftstroke">></label>
<</if>>
<<elseif $penis6 is 0>>
<<if $consensual is 1 and $promiscuity lte 34 and $enemytype is "man" or $consensual is 1 and $deviancy lte 34 and $enemytype isnot "man">>
<<else>>
<<if $leftactiondefault is "leftgrab">>
| <label><span class="sub">Grab <<his>> penis</span> <<radiobutton "$leftaction" "leftgrab" checked>><<handdifficulty>> <<combatpromiscuous3>></label>
<<else>>
| <label><span class="sub">Grab <<his>> penis</span> <<radiobutton "$leftaction" "leftgrab">><<handdifficulty>> <<combatpromiscuous3>></label>
<</if>>
<</if>>
<<if $leftactiondefault is "leftstroke">>
| <label><span class="sub">Stroke <<his>> penis</span> <<radiobutton "$leftaction" "leftstroke" checked>></label>
<<else>>
| <label><span class="sub">Stroke <<his>> penis</span> <<radiobutton "$leftaction" "leftstroke">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "leftplay">><<nobr>>
<<if $consensual is 1 and $promiscuity lte 34 and $enemytype is "man" or $consensual is 1 and $deviancy lte 34 and $enemytype isnot "man">>
<<else>>
<<if $vagina is 0>>
<<if $leftactiondefault is "leftplay">>
| <label><span class="sub">Play with <<his>> pussy</span> <<radiobutton "$leftaction" "leftplay" checked>><<handdifficulty>> <<combatpromiscuous3>></label>
<<else>>
| <label><span class="sub">Play with <<his>> pussy</span> <<radiobutton "$leftaction" "leftplay">><<handdifficulty>> <<combatpromiscuous3>></label>
<</if>>
<<elseif $vagina2 is 0>>
<<if $leftactiondefault is "leftplay">>
| <label><span class="sub">Play with <<his>> pussy</span> <<radiobutton "$leftaction" "leftplay" checked>><<handdifficulty>> <<combatpromiscuous3>></label>
<<else>>
| <label><span class="sub">Play with <<his>> pussy</span> <<radiobutton "$leftaction" "leftplay">><<handdifficulty>> <<combatpromiscuous3>></label>
<</if>>
<<elseif $vagina3 is 0>>
<<if $leftactiondefault is "leftplay">>
| <label><span class="sub">Play with <<his>> pussy</span> <<radiobutton "$leftaction" "leftplay" checked>><<handdifficulty>> <<combatpromiscuous3>></label>
<<else>>
| <label><span class="sub">Play with <<his>> pussy</span> <<radiobutton "$leftaction" "leftplay">><<handdifficulty>> <<combatpromiscuous3>></label>
<</if>>
<<elseif $vagina4 is 0>>
<<if $leftactiondefault is "leftplay">>
| <label><span class="sub">Play with <<his>> pussy</span> <<radiobutton "$leftaction" "leftplay" checked>><<handdifficulty>> <<combatpromiscuous3>></label>
<<else>>
| <label><span class="sub">Play with <<his>> pussy</span> <<radiobutton "$leftaction" "leftplay">><<handdifficulty>> <<combatpromiscuous3>></label>
<</if>>
<<elseif $vagina5 is 0>>
<<if $leftactiondefault is "leftplay">>
| <label><span class="sub">Play with <<his>> pussy</span> <<radiobutton "$leftaction" "leftplay" checked>><<handdifficulty>> <<combatpromiscuous3>></label>
<<else>>
| <label><span class="sub">Play with <<his>> pussy</span> <<radiobutton "$leftaction" "leftplay">><<handdifficulty>> <<combatpromiscuous3>></label>
<</if>>
<<elseif $vagina6 is 0>>
<<if $leftactiondefault is "leftplay">>
| <label><span class="sub">Play with <<his>> pussy</span> <<radiobutton "$leftaction" "leftplay" checked>><<handdifficulty>> <<combatpromiscuous3>></label>
<<else>>
| <label><span class="sub">Play with <<his>> pussy</span> <<radiobutton "$leftaction" "leftplay">><<handdifficulty>> <<combatpromiscuous3>></label>
<</if>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "leftclothes">><<nobr>>
<<if $upperstate is $upperstatebase and $upperstatetop is $upperstatetopbase and $uppertype isnot "naked">>
<<if $leftactiondefault is "upper">>
| <label>Displace your $upperclothes <<radiobutton "$leftaction" "upper" checked>></label>
<<else>>
| <label>Displace your $upperclothes <<radiobutton "$leftaction" "upper">></label>
<</if>>
<</if>>
<<if $lowerstate is $lowerstatebase and $skirt isnot 1 and $lowertype isnot "naked">>
<<if $leftactiondefault is "lower">>
| <label>Displace your $lowerclothes <<radiobutton "$leftaction" "lower" checked>></label>
<<else>>
| <label>Displace your $lowerclothes <<radiobutton "$leftaction" "lower">></label>
<</if>>
<<elseif $skirt is 1 and $skirtdown is 1>>
<<if $leftactiondefault is "lower">>
| <label>Displace your $lowerclothes <<radiobutton "$leftaction" "lower" checked>></label>
<<else>>
| <label>Displace your $lowerclothes <<radiobutton "$leftaction" "lower">></label>
<</if>>
<</if>>
<<if $understate is $understatebase and $undertype isnot "chastity" and $undertype isnot "naked">>
<<if $lowerstate isnot $lowerstatebase or $skirt is 1 or $lowertype is "naked">>
<<if $leftactiondefault is "under">>
| <label>Pull down your $underclothes <<radiobutton "$leftaction" "under" checked>></label>
<<else>>
| <label>Pull down your $underclothes <<radiobutton "$leftaction" "under">></label>
<</if>>
<</if>>
<</if>>
<</nobr>><</widget>>
:: Widgets Actions Right Hand [widget]
<<widget "rightgrab">><<nobr>>
<<if $penis is 0>>
<<if $consensual is 1 and $promiscuity lte 34 and $enemytype is "man" or $consensual is 1 and $deviancy lte 34 and $enemytype isnot "man">>
<<else>>
<<if $rightactiondefault is "rightgrab">>
| <label><span class="sub">Grab <<his>> penis</span> <<radiobutton "$rightaction" "rightgrab" checked>><<handdifficulty>> <<combatpromiscuous3>></label>
<<else>>
| <label><span class="sub">Grab <<his>> penis</span> <<radiobutton "$rightaction" "rightgrab">><<handdifficulty>> <<combatpromiscuous3>></label>
<</if>>
<</if>>
<<if $rightactiondefault is "rightstroke">>
| <label><span class="sub">Stroke <<his>> penis</span> <<radiobutton "$rightaction" "rightstroke" checked>></label>
<<else>>
| <label><span class="sub">Stroke <<his>> penis</span> <<radiobutton "$rightaction" "rightstroke">></label>
<</if>>
<<elseif $penis2 is 0>>
<<if $consensual is 1 and $promiscuity lte 34 and $enemytype is "man" or $consensual is 1 and $deviancy lte 34 and $enemytype isnot "man">>
<<else>>
<<if $rightactiondefault is "rightgrab">>
| <label><span class="sub">Grab <<his>> penis</span> <<radiobutton "$rightaction" "rightgrab" checked>><<handdifficulty>> <<combatpromiscuous3>></label>
<<else>>
| <label><span class="sub">Grab <<his>> penis</span> <<radiobutton "$rightaction" "rightgrab">><<handdifficulty>> <<combatpromiscuous3>></label>
<</if>>
<</if>>
<<if $rightactiondefault is "rightstroke">>
| <label><span class="sub">Stroke <<his>> penis</span> <<radiobutton "$rightaction" "rightstroke" checked>></label>
<<else>>
| <label><span class="sub">Stroke <<his>> penis</span> <<radiobutton "$rightaction" "rightstroke">></label>
<</if>>
<<elseif $penis3 is 0>>
<<if $consensual is 1 and $promiscuity lte 34 and $enemytype is "man" or $consensual is 1 and $deviancy lte 34 and $enemytype isnot "man">>
<<else>>
<<if $rightactiondefault is "rightgrab">>
| <label><span class="sub">Grab <<his>> penis</span> <<radiobutton "$rightaction" "rightgrab" checked>><<handdifficulty>> <<combatpromiscuous3>></label>
<<else>>
| <label><span class="sub">Grab <<his>> penis</span> <<radiobutton "$rightaction" "rightgrab">><<handdifficulty>> <<combatpromiscuous3>></label>
<</if>>
<</if>>
<<if $rightactiondefault is "rightstroke">>
| <label><span class="sub">Stroke <<his>> penis</span> <<radiobutton "$rightaction" "rightstroke" checked>></label>
<<else>>
| <label><span class="sub">Stroke <<his>> penis</span> <<radiobutton "$rightaction" "rightstroke">></label>
<</if>>
<<elseif $penis4 is 0>>
<<if $consensual is 1 and $promiscuity lte 34 and $enemytype is "man" or $consensual is 1 and $deviancy lte 34 and $enemytype isnot "man">>
<<else>>
<<if $rightactiondefault is "rightgrab">>
| <label><span class="sub">Grab <<his>> penis</span> <<radiobutton "$rightaction" "rightgrab" checked>><<handdifficulty>> <<combatpromiscuous3>></label>
<<else>>
| <label><span class="sub">Grab <<his>> penis</span> <<radiobutton "$rightaction" "rightgrab">><<handdifficulty>> <<combatpromiscuous3>></label>
<</if>>
<</if>>
<<if $rightactiondefault is "rightstroke">>
| <label><span class="sub">Stroke <<his>> penis</span> <<radiobutton "$rightaction" "rightstroke" checked>></label>
<<else>>
| <label><span class="sub">Stroke <<his>> penis</span> <<radiobutton "$rightaction" "rightstroke">></label>
<</if>>
<<elseif $penis5 is 0>>
<<if $consensual is 1 and $promiscuity lte 34 and $enemytype is "man" or $consensual is 1 and $deviancy lte 34 and $enemytype isnot "man">>
<<else>>
<<if $rightactiondefault is "rightgrab">>
| <label><span class="sub">Grab <<his>> penis</span> <<radiobutton "$rightaction" "rightgrab" checked>><<handdifficulty>> <<combatpromiscuous3>></label>
<<else>>
| <label><span class="sub">Grab <<his>> penis</span> <<radiobutton "$rightaction" "rightgrab">><<handdifficulty>> <<combatpromiscuous3>></label>
<</if>>
<</if>>
<<if $rightactiondefault is "rightstroke">>
| <label><span class="sub">Stroke <<his>> penis</span> <<radiobutton "$rightaction" "rightstroke" checked>></label>
<<else>>
| <label><span class="sub">Stroke <<his>> penis</span> <<radiobutton "$rightaction" "rightstroke">></label>
<</if>>
<<elseif $penis6 is 0>>
<<if $consensual is 1 and $promiscuity lte 34 and $enemytype is "man" or $consensual is 1 and $deviancy lte 34 and $enemytype isnot "man">>
<<else>>
<<if $rightactiondefault is "rightgrab">>
| <label><span class="sub">Grab <<his>> penis</span> <<radiobutton "$rightaction" "rightgrab" checked>><<handdifficulty>> <<combatpromiscuous3>></label>
<<else>>
| <label><span class="sub">Grab <<his>> penis</span> <<radiobutton "$rightaction" "rightgrab">><<handdifficulty>> <<combatpromiscuous3>></label>
<</if>>
<</if>>
<<if $rightactiondefault is "rightstroke">>
| <label><span class="sub">Stroke <<his>> penis</span> <<radiobutton "$rightaction" "rightstroke" checked>></label>
<<else>>
| <label><span class="sub">Stroke <<his>> penis</span> <<radiobutton "$rightaction" "rightstroke">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "rightplay">><<nobr>>
<<if $consensual is 1 and $promiscuity lte 34 and $enemytype is "man" or $consensual is 1 and $deviancy lte 34 and $enemytype isnot "man">>
<<else>>
<<if $vagina is 0>>
<<if $rightactiondefault is "rightplay">>
| <label><span class="sub">Play with <<his>> pussy</span> <<radiobutton "$rightaction" "rightplay" checked>><<handdifficulty>> <<combatpromiscuous3>></label>
<<else>>
| <label><span class="sub">Play with <<his>> pussy</span> <<radiobutton "$rightaction" "rightplay">><<handdifficulty>> <<combatpromiscuous3>></label>
<</if>>
<<elseif $vagina2 is 0>>
<<if $rightactiondefault is "rightplay">>
| <label><span class="sub">Play with <<his>> pussy</span> <<radiobutton "$rightaction" "rightplay" checked>><<handdifficulty>> <<combatpromiscuous3>></label>
<<else>>
| <label><span class="sub">Play with <<his>> pussy</span> <<radiobutton "$rightaction" "rightplay">><<handdifficulty>> <<combatpromiscuous3>></label>
<</if>>
<<elseif $vagina3 is 0>>
<<if $rightactiondefault is "rightplay">>
| <label><span class="sub">Play with <<his>> pussy</span> <<radiobutton "$rightaction" "rightplay" checked>><<handdifficulty>> <<combatpromiscuous3>></label>
<<else>>
| <label><span class="sub">Play with <<his>> pussy</span> <<radiobutton "$rightaction" "rightplay">><<handdifficulty>> <<combatpromiscuous3>></label>
<</if>>
<<elseif $vagina4 is 0>>
<<if $rightactiondefault is "rightplay">>
| <label><span class="sub">Play with <<his>> pussy</span> <<radiobutton "$rightaction" "rightplay" checked>><<handdifficulty>> <<combatpromiscuous3>></label>
<<else>>
| <label><span class="sub">Play with <<his>> pussy</span> <<radiobutton "$rightaction" "rightplay">><<handdifficulty>> <<combatpromiscuous3>></label>
<</if>>
<<elseif $vagina5 is 0>>
<<if $rightactiondefault is "rightplay">>
| <label><span class="sub">Play with <<his>> pussy</span> <<radiobutton "$rightaction" "rightplay" checked>><<handdifficulty>> <<combatpromiscuous3>></label>
<<else>>
| <label><span class="sub">Play with <<his>> pussy</span> <<radiobutton "$rightaction" "rightplay">><<handdifficulty>> <<combatpromiscuous3>></label>
<</if>>
<<elseif $vagina6 is 0>>
<<if $rightactiondefault is "rightplay">>
| <label><span class="sub">Play with <<his>> pussy</span> <<radiobutton "$rightaction" "rightplay" checked>><<handdifficulty>> <<combatpromiscuous3>></label>
<<else>>
| <label><span class="sub">Play with <<his>> pussy</span> <<radiobutton "$rightaction" "rightplay">><<handdifficulty>> <<combatpromiscuous3>></label>
<</if>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "rightclothes">><<nobr>>
<<if $upperstate is $upperstatebase and $upperstatetop is $upperstatetopbase and $uppertype isnot "naked">>
<<if $rightactiondefault is "upper">>
| <label>Displace your $upperclothes <<radiobutton "$rightaction" "upper" checked>></label>
<<else>>
| <label>Displace your $upperclothes <<radiobutton "$rightaction" "upper">></label>
<</if>>
<</if>>
<<if $lowerstate is $lowerstatebase and $skirt isnot 1 and $lowertype isnot "naked">>
<<if $rightactiondefault is "lower">>
| <label>Displace your $lowerclothes <<radiobutton "$rightaction" "lower" checked>></label>
<<else>>
| <label>Displace your $lowerclothes <<radiobutton "$rightaction" "lower">></label>
<</if>>
<<elseif $skirt is 1 and $skirtdown is 1>>
<<if $rightactiondefault is "lower">>
| <label>Displace your $lowerclothes <<radiobutton "$rightaction" "lower" checked>></label>
<<else>>
| <label>Displace your $lowerclothes <<radiobutton "$rightaction" "lower">></label>
<</if>>
<</if>>
<<if $understate is $understatebase and $undertype isnot "chastity" and $undertype isnot "naked">>
<<if $lowerstate isnot $lowerstatebase or $skirt is 1 or $lowertype is "naked">>
<<if $rightactiondefault is "under">>
| <label>Pull down your $underclothes <<radiobutton "$rightaction" "under" checked>></label>
<<else>>
| <label>Pull down your $underclothes <<radiobutton "$rightaction" "under">></label>
<</if>>
<</if>>
<</if>>
<</nobr>><</widget>>
:: Widgets Actions Feet [widget]
<<widget "feetgrab">><<nobr>>
<<if $consensual is 1 and $promiscuity lte 34 and $enemytype is "man" or $consensual is 1 and $deviancy lte 34 and $enemytype isnot "man">>
<<else>>
<<if $penis is 0>>
<<if $feetactiondefault is "grab">>
| <label><span class="sub">Grab <<his>> penis</span> <<radiobutton "$feetaction" "grab" checked>><<feetdifficulty>> <<combatpromiscuous3>></label>
<<else>>
| <label><span class="sub">Grab <<his>> penis</span> <<radiobutton "$feetaction" "grab">><<feetdifficulty>> <<combatpromiscuous3>></label>
<</if>>
<<elseif $penis2 is 0>>
<<if $feetactiondefault is "grab">>
| <label><span class="sub">Grab <<his>> penis</span> <<radiobutton "$feetaction" "grab" checked>><<feetdifficulty>> <<combatpromiscuous3>></label>
<<else>>
| <label><span class="sub">Grab <<his>> penis</span> <<radiobutton "$feetaction" "grab">><<feetdifficulty>> <<combatpromiscuous3>></label>
<</if>>
<<elseif $penis3 is 0>>
<<if $feetactiondefault is "grab">>
| <label><span class="sub">Grab <<his>> penis</span> <<radiobutton "$feetaction" "grab" checked>><<feetdifficulty>> <<combatpromiscuous3>></label>
<<else>>
| <label><span class="sub">Grab <<his>> penis</span> <<radiobutton "$feetaction" "grab">><<feetdifficulty>> <<combatpromiscuous3>></label>
<</if>>
<<elseif $penis4 is 0>>
<<if $feetactiondefault is "grab">>
| <label><span class="sub">Grab <<his>> penis</span> <<radiobutton "$feetaction" "grab" checked>><<feetdifficulty>> <<combatpromiscuous3>></label>
<<else>>
| <label><span class="sub">Grab <<his>> penis</span> <<radiobutton "$feetaction" "grab">><<feetdifficulty>> <<combatpromiscuous3>></label>
<</if>>
<<elseif $penis5 is 0>>
<<if $feetactiondefault is "grab">>
| <label><span class="sub">Grab <<his>> penis</span> <<radiobutton "$feetaction" "grab" checked>><<feetdifficulty>> <<combatpromiscuous3>></label>
<<else>>
| <label><span class="sub">Grab <<his>> penis</span> <<radiobutton "$feetaction" "grab">><<feetdifficulty>> <<combatpromiscuous3>></label>
<</if>>
<<elseif $penis6 is 0>>
<<if $feetactiondefault is "grab">>
| <label><span class="sub">Grab <<his>> penis</span> <<radiobutton "$feetaction" "grab" checked>><<feetdifficulty>> <<combatpromiscuous3>></label>
<<else>>
| <label><span class="sub">Grab <<his>> penis</span> <<radiobutton "$feetaction" "grab">><<feetdifficulty>> <<combatpromiscuous3>></label>
<</if>>
<</if>>
<<if $vagina is 0>>
<<if $feetactiondefault is "vaginagrab">>
| <label><span class="sub">Press your feet against <<his>> pussy</span> <<radiobutton "$feetaction" "vaginagrab" checked>><<feetdifficulty>> <<combatpromiscuous3>></label>
<<else>>
| <label><span class="sub">Press your feet against <<his>> pussy</span> <<radiobutton "$feetaction" "vaginagrab">><<feetdifficulty>> <<combatpromiscuous3>></label>
<</if>>
<<elseif $vagina2 is 0>>
<<if $feetactiondefault is "vaginagrab">>
| <label><span class="sub">Press your feet against <<his>> pussy</span> <<radiobutton "$feetaction" "vaginagrab" checked>><<feetdifficulty>> <<combatpromiscuous3>></label>
<<else>>
| <label><span class="sub">Press your feet against <<his>> pussy</span> <<radiobutton "$feetaction" "vaginagrab">><<feetdifficulty>> <<combatpromiscuous3>></label>
<</if>>
<<elseif $vagina3 is 0>>
<<if $feetactiondefault is "vaginagrab">>
| <label><span class="sub">Press your feet against <<his>> pussy</span> <<radiobutton "$feetaction" "vaginagrab" checked>><<feetdifficulty>> <<combatpromiscuous3>></label>
<<else>>
| <label><span class="sub">Press your feet against <<his>> pussy</span> <<radiobutton "$feetaction" "vaginagrab">><<feetdifficulty>> <<combatpromiscuous3>></label>
<</if>>
<<elseif $vagina4 is 0>>
<<if $feetactiondefault is "vaginagrab">>
| <label><span class="sub">Press your feet against <<his>> pussy</span> <<radiobutton "$feetaction" "vaginagrab" checked>><<feetdifficulty>> <<combatpromiscuous3>></label>
<<else>>
| <label><span class="sub">Press your feet against <<his>> pussy</span> <<radiobutton "$feetaction" "vaginagrab">><<feetdifficulty>> <<combatpromiscuous3>></label>
<</if>>
<<elseif $vagina5 is 0>>
<<if $feetactiondefault is "vaginagrab">>
| <label><span class="sub">Press your feet against <<his>> pussy</span> <<radiobutton "$feetaction" "vaginagrab" checked>><<feetdifficulty>> <<combatpromiscuous3>></label>
<<else>>
| <label><span class="sub">Press your feet against <<his>> pussy</span> <<radiobutton "$feetaction" "vaginagrab">><<feetdifficulty>> <<combatpromiscuous3>></label>
<</if>>
<<elseif $vagina6 is 0>>
<<if $feetactiondefault is "vaginagrab">>
| <label><span class="sub">Press your feet against <<his>> pussy</span> <<radiobutton "$feetaction" "vaginagrab" checked>><<feetdifficulty>> <<combatpromiscuous3>></label>
<<else>>
| <label><span class="sub">Press your feet against <<his>> pussy</span> <<radiobutton "$feetaction" "vaginagrab">><<feetdifficulty>> <<combatpromiscuous3>></label>
<</if>>
<</if>>
<</if>>
<</nobr>><</widget>>
:: Widgets Actions Mouth [widget]
<<widget "oral">><<nobr>>
<<if $consensual is 1 and $promiscuity lte 54 and $enemytype is "man" or $consensual is 1 and $deviancy lte 54 and $enemytype isnot "man">>
<<elseif $beaststance is "top">>
<<else>>
<<if $penis is 0>>
<<if $mouthactiondefault is "mouth">>
| <label><span class="sub">Move your lips to <<his>> penis</span> <<radiobutton "$mouthaction" "mouth" checked>><<oraldifficulty>> <<combatpromiscuous4>></label>
<<else>>
| <label><span class="sub">Move your lips to <<his>> penis</span> <<radiobutton "$mouthaction" "mouth">><<oraldifficulty>> <<combatpromiscuous4>></label>
<</if>>
<<elseif $penis2 is 0>>
<<if $mouthactiondefault is "mouth">>
| <label><span class="sub">Move your lips to <<his>> penis</span> <<radiobutton "$mouthaction" "mouth" checked>><<oraldifficulty>> <<combatpromiscuous4>></label>
<<else>>
| <label><span class="sub">Move your lips to <<his>> penis</span> <<radiobutton "$mouthaction" "mouth">><<oraldifficulty>> <<combatpromiscuous4>></label>
<</if>>
<<elseif $penis3 is 0>>
<<if $mouthactiondefault is "mouth">>
| <label><span class="sub">Move your lips to <<his>> penis</span> <<radiobutton "$mouthaction" "mouth" checked>><<oraldifficulty>> <<combatpromiscuous4>></label>
<<else>>
| <label><span class="sub">Move your lips to <<his>> penis</span> <<radiobutton "$mouthaction" "mouth">><<oraldifficulty>> <<combatpromiscuous4>></label>
<</if>>
<<elseif $penis4 is 0>>
<<if $mouthactiondefault is "mouth">>
| <label><span class="sub">Move your lips to <<his>> penis</span> <<radiobutton "$mouthaction" "mouth" checked>><<oraldifficulty>> <<combatpromiscuous4>></label>
<<else>>
| <label><span class="sub">Move your lips to <<his>> penis</span> <<radiobutton "$mouthaction" "mouth">><<oraldifficulty>> <<combatpromiscuous4>></label>
<</if>>
<<elseif $penis5 is 0>>
<<if $mouthactiondefault is "mouth">>
| <label><span class="sub">Move your lips to <<his>> penis</span> <<radiobutton "$mouthaction" "mouth" checked>><<oraldifficulty>> <<combatpromiscuous4>></label>
<<else>>
| <label><span class="sub">Move your lips to <<his>> penis</span> <<radiobutton "$mouthaction" "mouth">><<oraldifficulty>> <<combatpromiscuous4>></label>
<</if>>
<<elseif $penis6 is 0>>
<<if $mouthactiondefault is "mouth">>
| <label><span class="sub">Move your lips to <<his>> penis</span> <<radiobutton "$mouthaction" "mouth" checked>><<oraldifficulty>> <<combatpromiscuous4>></label>
<<else>>
| <label><span class="sub">Move your lips to <<his>> penis</span> <<radiobutton "$mouthaction" "mouth">><<oraldifficulty>> <<combatpromiscuous4>></label>
<</if>>
<</if>>
<<if $vagina is 0>>
<<if $mouthactiondefault is "othervagina">>
| <label><span class="sub">Move your mouth to <<his>> pussy</span><<radiobutton "$mouthaction" "othervagina" checked>><<oraldifficulty>> <<combatpromiscuous4>></label>
<<else>>
| <label><span class="sub">Move your mouth to <<his>> pussy</span><<radiobutton "$mouthaction" "othervagina">><<oraldifficulty>> <<combatpromiscuous4>></label>
<</if>>
<<elseif $vagina2 is 0>>
<<if $mouthactiondefault is "othervagina">>
| <label><span class="sub">Move your mouth to <<his>> pussy</span><<radiobutton "$mouthaction" "othervagina">><<oraldifficulty>> <<combatpromiscuous4>></label>
<<else>>
| <label><span class="sub">Move your mouth to <<his>> pussy</span><<radiobutton "$mouthaction" "othervagina" checked>><<oraldifficulty>> <<combatpromiscuous4>></label>
<</if>>
<<elseif $vagina3 is 0>>
<<if $mouthactiondefault is "othervagina">>
| <label><span class="sub">Move your mouth to <<his>> pussy</span><<radiobutton "$mouthaction" "othervagina" checked>><<oraldifficulty>> <<combatpromiscuous4>></label>
<<else>>
| <label><span class="sub">Move your mouth to <<his>> pussy</span><<radiobutton "$mouthaction" "othervagina">><<oraldifficulty>> <<combatpromiscuous4>></label>
<</if>>
<<elseif $vagina4 is 0>>
<<if $mouthactiondefault is "othervagina">>
| <label><span class="sub">Move your mouth to <<his>> pussy</span><<radiobutton "$mouthaction" "othervagina" checked>><<oraldifficulty>> <<combatpromiscuous4>></label>
<<else>>
| <label><span class="sub">Move your mouth to <<his>> pussy</span><<radiobutton "$mouthaction" "othervagina">><<oraldifficulty>> <<combatpromiscuous4>></label>
<</if>>
<<elseif $vagina5 is 0>>
<<if $mouthactiondefault is "othervagina">>
| <label><span class="sub">Move your mouth to <<his>> pussy</span><<radiobutton "$mouthaction" "othervagina" checked>><<oraldifficulty>> <<combatpromiscuous4>></label>
<<else>>
| <label><span class="sub">Move your mouth to <<his>> pussy</span><<radiobutton "$mouthaction" "othervagina">><<oraldifficulty>> <<combatpromiscuous4>></label>
<</if>>
<<elseif $vagina6 is 0>>
<<if $mouthactiondefault is "othervagina">>
| <label><span class="sub">Move your mouth to <<his>> pussy</span><<radiobutton "$mouthaction" "othervagina" checked>><<oraldifficulty>> <<combatpromiscuous4>></label>
<<else>>
| <label><span class="sub">Move your mouth to <<his>> pussy</span><<radiobutton "$mouthaction" "othervagina">><<oraldifficulty>> <<combatpromiscuous4>></label>
<</if>>
<</if>>
<</if>>
<</nobr>><</widget>>
:: Widgets Swarm [widget]
<<widget "swarm">><<nobr>>
<<set $rng to random(1, 100)>>
<<if $swarm1 is "steadied">>
<<set $swarm1 to "contained">>
<<elseif $swarm1 is "contained">>
<<if $rng gte 51>>
<<set $swarm1 to "pending">><<set $swarmpending += 1>>
<</if>>
<<elseif $swarm1 is "pending">>
<<set $swarm1 to "active">><<set $swarmpending -= 1>><<set $swarmactive += 1>><<set $swarmactivate += 1>>
<<elseif $swarm1 is "active">>
<<if $rng lte $swarmactive * 20>>
<<set $rng to random(1, 100)>>
<<if $rng gte 70>>
<<if $chest is "covered">>
<<set $arousal += 10>><<set $swarmchestcover += 1>>
<<else>>
<<set $rng to random(1, 100)>>
<<if $rng lte $swarmactive * 20>>
<<if $uppertype is "naked">>
<<set $swarm1 to "chest">><<neutral 3>><<set $swarmchestgrab += 1>><<set $swarmchestgrabintro += 1>>
<<else>>
<<set $rng to random(1, 100)>>
<<if $rng gte 81>>
<<set $swarm1 to "chest">><<neutral 3>><<set $swarmchestgrab += 1>><<set $swarmchestgrabclothed += 1>>
<<else>>
<<neutral 1>><<set $swarmchestclothed += 1>><<set $upperintegrity -= 2>>
<</if>>
<</if>>
<<else>>
<<set $swarmchestmolest += 1>><<neutral 1>><<set $upperintegrity -= 2>>
<</if>>
<</if>>
<<elseif $rng gte 40 and $analdisable is "f">>
<<if $back is "covered">>
<<set $arousal += 10>><<set $swarmbackcover += 1>>
<<else>>
<<set $rng to random(1, 100)>>
<<if $rng lte $swarmactive * 20>>
<<if $lowertype isnot "naked" and $skirt is 0>><<set $rng to random(1, 100)>>
<<if $rng gte 81>>
<<if $undertype is "naked">>
<<neutral 4>><<set $swarmbackgrablowerclothed += 1>><<set $swarm1 to "back">><<set $swarmback += 1>>
<<elseif $undertype is "chastity" and $analshield is 1>>
<<set $swarm1 to "back">><<set $swarmback += 1>><<neutral 4>><<set $swarmbackgrablowerchastity += 1>>
<<else>>
<<neutral 4>><<set $swarmbackgrabunderclothed += 1>><<set $swarm1 to "back">><<set $swarmback += 1>>
<</if>>
<<else>>
<<neutral 1>><<set $swarmbacklowerclothed += 1>><<set $lowerintegrity -= 2>>
<</if>>
<<else>><<set $rng to random(1, 100)>>
<<if $rng gte 81>>
<<if $undertype is "naked">>
<<set $swarm1 to "back">><<set $swarmback += 1>><<neutral 4>><<set $swarmbackgrab += 1>>
<<elseif $undertype is "chastity" and $analshield is 1>>
<<set $swarm1 to "back">><<set $swarmback += 1>><<neutral 4>><<set $swarmbackgrablowerchastity += 1>>
<<else>>
<<set $swarmbackgrabunderclothed += 1>><<set $swarm1 to "back">><<set $swarmback += 1>><<neutral 4>>
<</if>>
<<else>>
<<if $undertype isnot "naked">>
<<neutral 1>><<set $swarmbackunderclothed += 1>><<set $underintegrity -= 2>>
<<else>>
<<set $swarm1 to "back">><<set $swarmback += 1>><<neutral 4>><<set $swarmbackgrab += 1>>
<</if>>
<</if>>
<</if>>
<<else>>
<<set $swarmbackmolest += 1>><<neutral 1>><<set $lowerintegrity -= 2>><<if $lowertype is "naked">><<set $underintegrity -= 2>><</if>>
<</if>>
<</if>>
<<else>>
<<if $front is "covered">>
<<set $arousal += 10>><<set $swarmfrontcover += 1>>
<<else>>
<<set $rng to random(1, 100)>>
<<if $rng lte $swarmactive * 20>>
<<if $lowertype isnot "naked" and $skirt is 0>><<set $rng to random(1, 100)>>
<<if $rng gte 81>>
<<if $undertype is "naked">>
<<neutral 4>><<set $swarmfrontgrablowerclothed += 1>><<set $swarm1 to "front">><<set $swarmfront +=1>>
<<elseif $undertype is "chastity">>
<<set $swarm1 to "front">><<set $swarmfront +=1>><<neutral 4>><<set $swarmfrontgrablowerchastity += 1>>
<<else>>
<<neutral 4>><<set $swarmfrontgrabunderclothed += 1>><<set $swarm1 to "front">><<set $swarmfront +=1>>
<</if>>
<<else>>
<<neutral 1>><<set $swarmfrontlowerclothed += 1>><<set $lowerintegrity -= 2>>
<</if>>
<<else>><<set $rng to random(1, 100)>>
<<if $rng gte 81>>
<<if $undertype is "naked">>
<<set $swarm1 to "front">><<set $swarmfront +=1>><<neutral 4>><<set $swarmfrontgrab += 1>>
<<elseif $undertype is "chastity">>
<<set $swarm1 to "front">><<set $swarmfront +=1>><<neutral 4>><<set $swarmfrontgrablowerchastity += 1>>
<<else>>
<<set $swarmfrontgrabunderclothed += 1>><<set $swarm1 to "front">><<set $swarmfront +=1>><<neutral 4>>
<</if>>
<<else>>
<<if $undertype isnot "naked">>
<<neutral 1>><<set $swarmfrontunderclothed += 1>><<set $underintegrity -= 2>>
<<else>>
<<set $swarm1 to "front">><<set $swarmfront +=1>><<neutral 4>><<set $swarmfrontgrab += 1>>
<</if>>
<</if>>
<</if>>
<<else>>
<<set $swarmfrontmolest += 1>><<neutral 1>><<set $lowerintegrity -= 2>><<if $lowertype is "naked">><<set $underintegrity -= 2>><</if>>
<</if>>
<</if>>
<</if>>
<<else>>
<<set $arousal += 10>>
<</if>>
<<elseif $swarm1 is "back">>
<<set $swarm1 to "backinside">><<set $swarmbackinside += 1>><<set $swarmbackinsideintro += 1>><<set $swarmback -= 1>>
<<elseif $swarm1 is "front">>
<<set $swarm1 to "frontinside">><<set $swarmfrontinside += 1>><<set $swarmfrontinsideintro += 1>><<set $swarmfront -= 1>>
<<else>>
<</if>>
<<swarm2>>
<<swarm3>>
<<swarm4>>
<<swarm5>>
<<swarm6>>
<<swarm7>>
<<swarm8>>
<<swarm9>>
<<swarm10>>
<<if $swarmpending gte 1>>
There are <<print $swarmcount - $swarmactive>> $swarmname and <span class="blue">$swarmpending of them <<if $swarmpending gte 2>>are<<else>>is<</if>> $swarmmove.</span>
<</if>>
<<if $swarmactivate gte 1>><<set $swarmactivate to 0>>
The $swarmname $swarmspill, surrounding you with more $swarmcreature.
<</if>>
<<if $swarmactive lte 0>>
<<elseif $swarmactive lte 1>>
The $swarmcreature are squirming over you.
<<elseif $swarmactive lte 2>>
The $swarmcreature are swarming over you.
<<elseif $swarmactive lte 3>>
The $swarmcreature teem around you.
<<elseif $swarmactive lte 4>>
You're practically swimming in $swarmcreature.
<<elseif $swarmactive lte 9>>
The $swarmcreature completely surround you.
<<elseif $swarmactive gte 10>>
<span class="pink">The $swarmcreature completely surround you, as if you are in a living pit.<<if $orgasmdown gte 1>> Not an inch of skin is spared the torment.<</if>></span>
<</if>>
<<set $rng to random(1, 100)>>
<<if $rng gte 91 and $leftarm is 0 and $rightarm is 0>>
<<if $rng gte 96>><<set $leftarm to "swarmgrappled">>
<span class="purple">The $swarmcreature swarm over your left arm, restraining it.</span>
<<else>><<set $rightarm to "swarmgrappled">>
<span class="purple">The $swarmcreature swarm over your right arm, restraining it.</span>
<</if>>
<</if>>
<<if $swarmchestcover gte 1>><<set $swarmchestcover to 0>>
You manage to keep them away from your chest.
<</if>>
<<if $swarmchestmolest gte 1>><<set $swarmchestmolest to 0>>
They writhe over your <<print either("chest", "stomach", "back", "neck", "arms")>>.
<</if>>
<<if $swarmchestclothed gte 1>><<set $swarmchestclothed to 0>>
Some of them assault and damage your $upperclothes, trying to get to the skin beneath.
<</if>>
<<if $swarmchestgrabintro gte 1>><<set $swarmchestgrabintro to 0>>
<span class="purple">A number of them take a liking to your <<breastsstop>></span>
<</if>>
<<if $swarmchestgrabclothed gte 1>><<set $swarmchestgrabclothed to 0>>
<span class="purple">Some of them wriggle their way into your $upperclothes, where they take a liking to your <<breastsstop>></span>
<</if>>
<<if $swarmchestgrab gte 1>>
They twist and tease your nipples, keeping them firm.<<neutral 5>><<set $arousal += $swarmchestgrab * 20>>
<</if>>
<<if $swarmbackcover gte 1>><<set $swarmbackcover to 0>>
You manage to keep them away from your butt.
<</if>>
<<if $swarmbackmolest gte 1>><<set $swarmbackmolest to 0>>
They writhe over your <<print either("butt", "thighs", "legs")>>.
<</if>>
<<if $swarmbacklowerclothed gte 1>><<set $swarmbacklowerclothed to 0>>
Some of them burrow into your $lowerclothes, damaging the fabric.
<</if>>
<<if $swarmbackunderclothed gte 1>><<set $swarmbackunderclothed to 0>>
Some of them assail your $underclothes, tearing the fabric.
<</if>>
<<if $swarmbackgrablowerclothed gte 1>><<set $swarmbackgrablowerclothed to 0>>
<span class="purple">Some of them wriggle their way into your $lowerclothes, you feel them moving toward your anus.</span>
<</if>>
<<if $swarmbackgrabunderclothed gte 1>><<set $swarmbackgrabunderclothed to 0>>
<span class="purple">Some of them wriggle their way into your $underclothes, you feel them moving toward your anus.</span>
<</if>>
<<if $swarmbackgrablowerchastity gte 1>><<set $swarmbackgrablowerchastity to 0>>
<span class="purple">Some of them wriggle their way into your $underclothes, you feel them moving toward your <<genitalsstop>></span> <span class="pink">With your chastity belt in the way, you won't be able to get them out!</span> <<if $parasitedisable is "f">>
<<set $analchastityparasite to $swarmcreature>><<set $parasitestat += 1>>
<</if>>
<</if>>
<<if $swarmbackgrab gte 1>><<set $swarmbackgrab to 0>>
<span class="purple">They swarm around your butt, you feel them move toward your anus.</span>
<</if>>
<<if $swarmbackinsideintro gte 1>><<set $swarmbackinsideintro to 0>>
<span class="pink">They start squirming their way into your <<bottomstop>></span>
<</if>>
<<if $swarmbackinside gte 1>><<neutral 10>>
They writhe inside your lower intestine<<if $penisexist is 1>>, blindly teasing your prostate.<<else>>.<</if>><<set $arousal += $swarmbackinside * 20>>
<</if>>
<<if $swarmfrontcover gte 1>><<set $swarmfrontcover to 0>>
You manage to keep them away from your <<genitalsstop>>
<</if>>
<<if $swarmfrontmolest gte 1>><<set $swarmfrontmolest to 0>>
You feel them writhing over your <<if $lowertype isnot "naked" and $skirt isnot 1>><<genitals>> through your $lowerclothes.<<elseif $undertype isnot "naked">><<genitals>> through your $underclothes.<<else>>unprotected <<genitalsstop>><</if>>
<</if>>
<<if $swarmfrontlowerclothed gte 1>><<set $swarmfrontlowerclothed to 0>>
Some of them start tearing into your $lowerclothes.
<</if>>
<<if $swarmfrontunderclothed gte 1>><<set $swarmfrontunderclothed to 0>>
Some of them try to breach your $underclothes, trying to get to the skin beneath.
<</if>>
<<if $swarmfrontgrablowerclothed gte 1>><<set $swarmfrontgrablowerclothed to 0>>
<span class="purple">Some of them wriggle their way into your $lowerclothes, you feel them moving toward your <<genitalsstop>></span>
<</if>>
<<if $swarmfrontgrabunderclothed gte 1>><<set $swarmfrontgrabunderclothed to 0>>
<span class="purple">Some of them wriggle their way into your $underclothes, you feel them moving toward your <<genitalsstop>></span>
<</if>>
<<if $swarmfrontgrablowerchastity gte 1>><<set $swarmfrontgrablowerchastity to 0>>
<span class="purple">Some of them wriggle their way into your $underclothes, you feel them moving toward your <<genitalsstop>></span> <span class="pink">With your chastity belt in the way, you won't be able to get them out!</span>
<<if $parasitedisable is "f">>
<<if $vaginaexist is 1>><<set $vaginalchastityparasite to $swarmcreature>><<set $parasitestat += 1>>
<<elseif $penisexist is 1>><<set $penilechastityparasite to $swarmcreature>><<set $parasitestat += 1>>
<</if>>
<</if>>
<</if>>
<<if $swarmfrontgrab gte 1>><<set $swarmfrontgrab to 0>>
<span class="purple">They swarm around your groin, you feel them move toward your <<genitalsstop>></span>
<</if>>
<<if $swarmfrontinsideintro gte 1>><<set $swarmfrontinsideintro to 0>>
<<if $vaginaexist is 1>>
<span class="pink">They start squirming their way into your pussy!</span>
<<elseif $penisexist is 1>>
<span class="pink">They start enveloping your penis!</span>
<</if>>
<</if>>
<<if $swarmfrontinside gte 1>>
<<if $vaginaexist is 1>>
They writhe and squirm inside your vagina, probing and teasing without mercy.<<neutral 10>><<set $arousal += $swarmfrontinside * 20>>
<<elseif $penisexist is 1>>
They writhe and squirm over your penis, rubbing and teasing the entire length.<<neutral 10>><<set $arousal += $swarmfrontinside * 20>>
<</if>>
<</if>>
<br><br>
<<if $enemytype isnot "tentacles">>
<<if $panicattacks gte 1 and $panicviolence is 0 and $panicparalysis is 0 and $controlled is 0>>
<<set $rng to random(1, 100)>>
<<if $rng is 100>>
<<set $panicparalysis to 10>>
<</if>>
<</if>>
<<if $panicattacks gte 2 and $panicviolence is 0 and $panicparalysis is 0 and $controlled is 0>>
<<set $rng to random(1, 100)>>
<<if $rng is 100>>
<<set $panicviolence to 3>>
<</if>>
<</if>>
<<if $arousal gte 10000>>
<<orgasmpassage>>
<</if>>
<<set $seconds += 10>>
<<if $seconds gte 60>>
<<set $seconds to 0>>
<<pass 1>>
<</if>>
<</if>>
<</nobr>><</widget>>
:: Widgets Swarm2 [widget]
<<widget "swarm2">><<nobr>>
<<set $rng to random(1, 100)>>
<<if $swarm2 is "steadied">>
<<set $swarm2 to "contained">>
<<elseif $swarm2 is "contained">>
<<if $rng gte 51>>
<<set $swarm2 to "pending">><<set $swarmpending += 1>>
<</if>>
<<elseif $swarm2 is "pending">>
<<set $swarm2 to "active">><<set $swarmpending -= 1>><<set $swarmactive += 1>><<set $swarmactivate += 1>>
<<elseif $swarm2 is "active">>
<<if $rng lte $swarmactive * 20>>
<<set $rng to random(1, 100)>>
<<if $rng gte 70>>
<<if $chest is "covered">>
<<set $arousal += 10>><<set $swarmchestcover += 1>>
<<else>>
<<set $rng to random(1, 100)>>
<<if $rng lte $swarmactive * 20>>
<<if $uppertype is "naked">>
<<set $swarm2 to "chest">><<neutral 3>><<set $swarmchestgrab += 1>><<set $swarmchestgrabintro += 1>>
<<else>>
<<set $rng to random(1, 100)>>
<<if $rng gte 81>>
<<set $swarm2 to "chest">><<neutral 3>><<set $swarmchestgrab += 1>><<set $swarmchestgrabclothed += 1>>
<<else>>
<<neutral 1>><<set $swarmchestclothed += 1>><<set $upperintegrity -= 10>>
<</if>>
<</if>>
<<else>>
<<set $swarmchestmolest += 1>><<neutral 1>><<set $upperintegrity -= 5>>
<</if>>
<</if>>
<<elseif $rng gte 40 and $analdisable is "f">>
<<if $back is "covered">>
<<set $arousal += 10>><<set $swarmbackcover += 1>>
<<else>>
<<set $rng to random(1, 100)>>
<<if $rng lte $swarmactive * 20>>
<<if $lowertype isnot "naked" and $skirt is 0>><<set $rng to random(1, 100)>>
<<if $rng gte 81>>
<<if $undertype is "naked">>
<<neutral 4>><<set $swarmbackgrablowerclothed += 1>><<set $swarm2 to "back">><<set $swarmback += 1>>
<<elseif $undertype is "chastity" and $analshield is 1>>
<<set $swarm2 to "back">><<set $swarmback += 1>><<neutral 4>><<set $swarmbackgrablowerchastity += 1>>
<<else>>
<<neutral 4>><<set $swarmbackgrabunderclothed += 1>><<set $swarm2 to "back">><<set $swarmback += 1>>
<</if>>
<<else>>
<<neutral 1>><<set $swarmbacklowerclothed += 1>><<set $lowerintegrity -= 10>>
<</if>>
<<else>><<set $rng to random(1, 100)>>
<<if $rng gte 81>>
<<if $undertype is "naked">>
<<set $swarm2 to "back">><<set $swarmback += 1>><<neutral 4>><<set $swarmbackgrab += 1>>
<<elseif $undertype is "chastity" and $analshield is 1>>
<<set $swarm2 to "back">><<set $swarmback += 1>><<neutral 4>><<set $swarmbackgrablowerchastity += 1>>
<<else>>
<<set $swarmbackgrabunderclothed += 1>><<set $swarm2 to "back">><<set $swarmback += 1>><<neutral 4>>
<</if>>
<<else>>
<<if $undertype isnot "naked">>
<<neutral 1>><<set $swarmbackunderclothed += 1>><<set $underintegrity -= 10>>
<<else>>
<<set $swarm2 to "back">><<set $swarmback += 1>><<neutral 4>><<set $swarmbackgrab += 1>>
<</if>>
<</if>>
<</if>>
<<else>>
<<set $swarmbackmolest += 1>><<neutral 1>><<set $lowerintegrity -= 5>><<if $lowertype is "naked">><<set $underintegrity -= 5>><</if>>
<</if>>
<</if>>
<<else>>
<<if $front is "covered">>
<<set $arousal += 10>><<set $swarmfrontcover += 1>>
<<else>>
<<set $rng to random(1, 100)>>
<<if $rng lte $swarmactive * 20>>
<<if $lowertype isnot "naked" and $skirt is 0>><<set $rng to random(1, 100)>>
<<if $rng gte 81>>
<<if $undertype is "naked">>
<<neutral 4>><<set $swarmfrontgrablowerclothed += 1>><<set $swarm2 to "front">><<set $swarmfront +=1>>
<<elseif $undertype is "chastity">>
<<set $swarm2 to "front">><<set $swarmfront +=1>><<neutral 4>><<set $swarmfrontgrablowerchastity += 1>>
<<else>>
<<neutral 4>><<set $swarmfrontgrabunderclothed += 1>><<set $swarm2 to "front">><<set $swarmfront +=1>>
<</if>>
<<else>>
<<neutral 1>><<set $swarmfrontlowerclothed += 1>><<set $lowerintegrity -= 10>>
<</if>>
<<else>><<set $rng to random(1, 100)>>
<<if $rng gte 81>>
<<if $undertype is "naked">>
<<set $swarm2 to "front">><<set $swarmfront +=1>><<neutral 4>><<set $swarmfrontgrab += 1>>
<<elseif $undertype is "chastity">>
<<set $swarm2 to "front">><<set $swarmfront +=1>><<neutral 4>><<set $swarmfrontgrablowerchastity += 1>>
<<else>>
<<set $swarmfrontgrabunderclothed += 1>><<set $swarm2 to "front">><<set $swarmfront +=1>><<neutral 4>>
<</if>>
<<else>>
<<if $undertype isnot "naked">>
<<neutral 1>><<set $swarmfrontunderclothed += 1>><<set $underintegrity -= 10>>
<<else>>
<<set $swarm2 to "front">><<set $swarmfront +=1>><<neutral 4>><<set $swarmfrontgrab += 1>>
<</if>>
<</if>>
<</if>>
<<else>>
<<set $swarmfrontmolest += 1>><<neutral 1>><<set $lowerintegrity -= 5>><<if $lowertype is "naked">><<set $underintegrity -= 5>><</if>>
<</if>>
<</if>>
<</if>>
<<else>>
<<set $arousal += 10>>
<</if>>
<<elseif $swarm2 is "back">>
<<set $swarm2 to "backinside">><<set $swarmbackinside += 1>><<set $swarmbackinsideintro += 1>><<set $swarmback -= 1>>
<<elseif $swarm2 is "front">>
<<set $swarm2 to "frontinside">><<set $swarmfrontinside += 1>><<set $swarmfrontinsideintro += 1>><<set $swarmfront -= 1>>
<<else>>
<</if>>
<</nobr>><</widget>>
:: Widgets Swarm3 [widget]
<<widget "swarm3">><<nobr>>
<<set $rng to random(1, 100)>>
<<if $swarm3 is "steadied">>
<<set $swarm3 to "contained">>
<<elseif $swarm3 is "contained">>
<<if $rng gte 51>>
<<set $swarm3 to "pending">><<set $swarmpending += 1>>
<</if>>
<<elseif $swarm3 is "pending">>
<<set $swarm3 to "active">><<set $swarmpending -= 1>><<set $swarmactive += 1>><<set $swarmactivate += 1>>
<<elseif $swarm3 is "active">>
<<if $rng lte $swarmactive * 20>>
<<set $rng to random(1, 100)>>
<<if $rng gte 70>>
<<if $chest is "covered">>
<<set $arousal += 10>><<set $swarmchestcover += 1>>
<<else>>
<<set $rng to random(1, 100)>>
<<if $rng lte $swarmactive * 20>>
<<if $uppertype is "naked">>
<<set $swarm3 to "chest">><<neutral 3>><<set $swarmchestgrab += 1>><<set $swarmchestgrabintro += 1>>
<<else>>
<<set $rng to random(1, 100)>>
<<if $rng gte 81>>
<<set $swarm3 to "chest">><<neutral 3>><<set $swarmchestgrab += 1>><<set $swarmchestgrabclothed += 1>>
<<else>>
<<neutral 1>><<set $swarmchestclothed += 1>><<set $upperintegrity -= 10>>
<</if>>
<</if>>
<<else>>
<<set $swarmchestmolest += 1>><<neutral 1>><<set $upperintegrity -= 5>>
<</if>>
<</if>>
<<elseif $rng gte 40 and $analdisable is "f">>
<<if $back is "covered">>
<<set $arousal += 10>><<set $swarmbackcover += 1>>
<<else>>
<<set $rng to random(1, 100)>>
<<if $rng lte $swarmactive * 20>>
<<if $lowertype isnot "naked" and $skirt is 0>><<set $rng to random(1, 100)>>
<<if $rng gte 81>>
<<if $undertype is "naked">>
<<neutral 4>><<set $swarmbackgrablowerclothed += 1>><<set $swarm3 to "back">><<set $swarmback += 1>>
<<elseif $undertype is "chastity" and $analshield is 1>>
<<set $swarm3 to "back">><<set $swarmback += 1>><<neutral 4>><<set $swarmbackgrablowerchastity += 1>>
<<else>>
<<neutral 4>><<set $swarmbackgrabunderclothed += 1>><<set $swarm3 to "back">><<set $swarmback += 1>>
<</if>>
<<else>>
<<neutral 1>><<set $swarmbacklowerclothed += 1>><<set $lowerintegrity -= 10>>
<</if>>
<<else>><<set $rng to random(1, 100)>>
<<if $rng gte 81>>
<<if $undertype is "naked">>
<<set $swarm3 to "back">><<set $swarmback += 1>><<neutral 4>><<set $swarmbackgrab += 1>>
<<elseif $undertype is "chastity" and $analshield is 1>>
<<set $swarm3 to "back">><<set $swarmback += 1>><<neutral 4>><<set $swarmbackgrablowerchastity += 1>>
<<else>>
<<set $swarmbackgrabunderclothed += 1>><<set $swarm3 to "back">><<set $swarmback += 1>><<neutral 4>>
<</if>>
<<else>>
<<if $undertype isnot "naked">>
<<neutral 1>><<set $swarmbackunderclothed += 1>><<set $underintegrity -= 10>>
<<else>>
<<set $swarm3 to "back">><<set $swarmback += 1>><<neutral 4>><<set $swarmbackgrab += 1>>
<</if>>
<</if>>
<</if>>
<<else>>
<<set $swarmbackmolest += 1>><<neutral 1>><<set $lowerintegrity -= 5>><<if $lowertype is "naked">><<set $underintegrity -= 5>><</if>>
<</if>>
<</if>>
<<else>>
<<if $front is "covered">>
<<set $arousal += 10>><<set $swarmfrontcover += 1>>
<<else>>
<<set $rng to random(1, 100)>>
<<if $rng lte $swarmactive * 20>>
<<if $lowertype isnot "naked" and $skirt is 0>><<set $rng to random(1, 100)>>
<<if $rng gte 81>>
<<if $undertype is "naked">>
<<neutral 4>><<set $swarmfrontgrablowerclothed += 1>><<set $swarm3 to "front">><<set $swarmfront +=1>>
<<elseif $undertype is "chastity">>
<<set $swarm3 to "front">><<set $swarmfront +=1>><<neutral 4>><<set $swarmfrontgrablowerchastity += 1>>
<<else>>
<<neutral 4>><<set $swarmfrontgrabunderclothed += 1>><<set $swarm3 to "front">><<set $swarmfront +=1>>
<</if>>
<<else>>
<<neutral 1>><<set $swarmfrontlowerclothed += 1>><<set $lowerintegrity -= 10>>
<</if>>
<<else>><<set $rng to random(1, 100)>>
<<if $rng gte 81>>
<<if $undertype is "naked">>
<<set $swarm3 to "front">><<set $swarmfront +=1>><<neutral 4>><<set $swarmfrontgrab += 1>>
<<elseif $undertype is "chastity">>
<<set $swarm3 to "front">><<set $swarmfront +=1>><<neutral 4>><<set $swarmfrontgrablowerchastity += 1>>
<<else>>
<<set $swarmfrontgrabunderclothed += 1>><<set $swarm3 to "front">><<set $swarmfront +=1>><<neutral 4>>
<</if>>
<<else>>
<<if $undertype isnot "naked">>
<<neutral 1>><<set $swarmfrontunderclothed += 1>><<set $underintegrity -= 10>>
<<else>>
<<set $swarm3 to "front">><<set $swarmfront +=1>><<neutral 4>><<set $swarmfrontgrab += 1>>
<</if>>
<</if>>
<</if>>
<<else>>
<<set $swarmfrontmolest += 1>><<neutral 1>><<set $lowerintegrity -= 5>><<if $lowertype is "naked">><<set $underintegrity -= 5>><</if>>
<</if>>
<</if>>
<</if>>
<<else>>
<<set $arousal += 10>>
<</if>>
<<elseif $swarm3 is "back">>
<<set $swarm3 to "backinside">><<set $swarmbackinside += 1>><<set $swarmbackinsideintro += 1>><<set $swarmback -= 1>>
<<elseif $swarm3 is "front">>
<<set $swarm3 to "frontinside">><<set $swarmfrontinside += 1>><<set $swarmfrontinsideintro += 1>><<set $swarmfront -= 1>>
<<else>>
<</if>>
<</nobr>><</widget>>
:: Widgets Swarm4 [widget]
<<widget "swarm4">><<nobr>>
<<set $rng to random(1, 100)>>
<<if $swarm4 is "steadied">>
<<set $swarm4 to "contained">>
<<elseif $swarm4 is "contained">>
<<if $rng gte 51>>
<<set $swarm4 to "pending">><<set $swarmpending += 1>>
<</if>>
<<elseif $swarm4 is "pending">>
<<set $swarm4 to "active">><<set $swarmpending -= 1>><<set $swarmactive += 1>><<set $swarmactivate += 1>>
<<elseif $swarm4 is "active">>
<<if $rng lte $swarmactive * 20>>
<<set $rng to random(1, 100)>>
<<if $rng gte 70>>
<<if $chest is "covered">>
<<set $arousal += 10>><<set $swarmchestcover += 1>>
<<else>>
<<set $rng to random(1, 100)>>
<<if $rng lte $swarmactive * 20>>
<<if $uppertype is "naked">>
<<set $swarm4 to "chest">><<neutral 3>><<set $swarmchestgrab += 1>><<set $swarmchestgrabintro += 1>>
<<else>>
<<set $rng to random(1, 100)>>
<<if $rng gte 81>>
<<set $swarm4 to "chest">><<neutral 3>><<set $swarmchestgrab += 1>><<set $swarmchestgrabclothed += 1>>
<<else>>
<<neutral 1>><<set $swarmchestclothed += 1>><<set $upperintegrity -= 10>>
<</if>>
<</if>>
<<else>>
<<set $swarmchestmolest += 1>><<neutral 1>><<set $upperintegrity -= 5>>
<</if>>
<</if>>
<<elseif $rng gte 40 and $analdisable is "f">>
<<if $back is "covered">>
<<set $arousal += 10>><<set $swarmbackcover += 1>>
<<else>>
<<set $rng to random(1, 100)>>
<<if $rng lte $swarmactive * 20>>
<<if $lowertype isnot "naked" and $skirt is 0>><<set $rng to random(1, 100)>>
<<if $rng gte 81>>
<<if $undertype is "naked">>
<<neutral 4>><<set $swarmbackgrablowerclothed += 1>><<set $swarm4 to "back">><<set $swarmback += 1>>
<<elseif $undertype is "chastity" and $analshield is 1>>
<<set $swarm4 to "back">><<set $swarmback += 1>><<neutral 4>><<set $swarmbackgrablowerchastity += 1>>
<<else>>
<<neutral 4>><<set $swarmbackgrabunderclothed += 1>><<set $swarm4 to "back">><<set $swarmback += 1>>
<</if>>
<<else>>
<<neutral 1>><<set $swarmbacklowerclothed += 1>><<set $lowerintegrity -= 10>>
<</if>>
<<else>><<set $rng to random(1, 100)>>
<<if $rng gte 81>>
<<if $undertype is "naked">>
<<set $swarm4 to "back">><<set $swarmback += 1>><<neutral 4>><<set $swarmbackgrab += 1>>
<<elseif $undertype is "chastity" and $analshield is 1>>
<<set $swarm4 to "back">><<set $swarmback += 1>><<neutral 4>><<set $swarmbackgrablowerchastity += 1>>
<<else>>
<<set $swarmbackgrabunderclothed += 1>><<set $swarm4 to "back">><<set $swarmback += 1>><<neutral 4>>
<</if>>
<<else>>
<<if $undertype isnot "naked">>
<<neutral 1>><<set $swarmbackunderclothed += 1>><<set $underintegrity -= 10>>
<<else>>
<<set $swarm4 to "back">><<set $swarmback += 1>><<neutral 4>><<set $swarmbackgrab += 1>>
<</if>>
<</if>>
<</if>>
<<else>>
<<set $swarmbackmolest += 1>><<neutral 1>><<set $lowerintegrity -= 5>><<if $lowertype is "naked">><<set $underintegrity -= 5>><</if>>
<</if>>
<</if>>
<<else>>
<<if $front is "covered">>
<<set $arousal += 10>><<set $swarmfrontcover += 1>>
<<else>>
<<set $rng to random(1, 100)>>
<<if $rng lte $swarmactive * 20>>
<<if $lowertype isnot "naked" and $skirt is 0>><<set $rng to random(1, 100)>>
<<if $rng gte 81>>
<<if $undertype is "naked">>
<<neutral 4>><<set $swarmfrontgrablowerclothed += 1>><<set $swarm4 to "front">><<set $swarmfront +=1>>
<<elseif $undertype is "chastity">>
<<set $swarm4 to "front">><<set $swarmfront +=1>><<neutral 4>><<set $swarmfrontgrablowerchastity += 1>>
<<else>>
<<neutral 4>><<set $swarmfrontgrabunderclothed += 1>><<set $swarm4 to "front">><<set $swarmfront +=1>>
<</if>>
<<else>>
<<neutral 1>><<set $swarmfrontlowerclothed += 1>><<set $lowerintegrity -= 10>>
<</if>>
<<else>><<set $rng to random(1, 100)>>
<<if $rng gte 81>>
<<if $undertype is "naked">>
<<set $swarm4 to "front">><<set $swarmfront +=1>><<neutral 4>><<set $swarmfrontgrab += 1>>
<<elseif $undertype is "chastity">>
<<set $swarm4 to "front">><<set $swarmfront +=1>><<neutral 4>><<set $swarmfrontgrablowerchastity += 1>>
<<else>>
<<set $swarmfrontgrabunderclothed += 1>><<set $swarm4 to "front">><<set $swarmfront +=1>><<neutral 4>>
<</if>>
<<else>>
<<if $undertype isnot "naked">>
<<neutral 1>><<set $swarmfrontunderclothed += 1>><<set $underintegrity -= 10>>
<<else>>
<<set $swarm4 to "front">><<set $swarmfront +=1>><<neutral 4>><<set $swarmfrontgrab += 1>>
<</if>>
<</if>>
<</if>>
<<else>>
<<set $swarmfrontmolest += 1>><<neutral 1>><<set $lowerintegrity -= 5>><<if $lowertype is "naked">><<set $underintegrity -= 5>><</if>>
<</if>>
<</if>>
<</if>>
<<else>>
<<set $arousal += 10>>
<</if>>
<<elseif $swarm4 is "back">>
<<set $swarm4 to "backinside">><<set $swarmbackinside += 1>><<set $swarmbackinsideintro += 1>><<set $swarmback -= 1>>
<<elseif $swarm4 is "front">>
<<set $swarm4 to "frontinside">><<set $swarmfrontinside += 1>><<set $swarmfrontinsideintro += 1>><<set $swarmfront -= 1>>
<<else>>
<</if>>
<</nobr>><</widget>>
:: Widgets Swarm5 [widget]
<<widget "swarm5">><<nobr>>
<<set $rng to random(1, 100)>>
<<if $swarm5 is "steadied">>
<<set $swarm5 to "contained">>
<<elseif $swarm5 is "contained">>
<<if $rng gte 51>>
<<set $swarm5 to "pending">><<set $swarmpending += 1>>
<</if>>
<<elseif $swarm5 is "pending">>
<<set $swarm5 to "active">><<set $swarmpending -= 1>><<set $swarmactive += 1>><<set $swarmactivate += 1>>
<<elseif $swarm5 is "active">>
<<if $rng lte $swarmactive * 20>>
<<set $rng to random(1, 100)>>
<<if $rng gte 70>>
<<if $chest is "covered">>
<<set $arousal += 10>><<set $swarmchestcover += 1>>
<<else>>
<<set $rng to random(1, 100)>>
<<if $rng lte $swarmactive * 20>>
<<if $uppertype is "naked">>
<<set $swarm5 to "chest">><<neutral 3>><<set $swarmchestgrab += 1>><<set $swarmchestgrabintro += 1>>
<<else>>
<<set $rng to random(1, 100)>>
<<if $rng gte 81>>
<<set $swarm5 to "chest">><<neutral 3>><<set $swarmchestgrab += 1>><<set $swarmchestgrabclothed += 1>>
<<else>>
<<neutral 1>><<set $swarmchestclothed += 1>><<set $upperintegrity -= 10>>
<</if>>
<</if>>
<<else>>
<<set $swarmchestmolest += 1>><<neutral 1>><<set $upperintegrity -= 5>>
<</if>>
<</if>>
<<elseif $rng gte 40 and $analdisable is "f">>
<<if $back is "covered">>
<<set $arousal += 10>><<set $swarmbackcover += 1>>
<<else>>
<<set $rng to random(1, 100)>>
<<if $rng lte $swarmactive * 20>>
<<if $lowertype isnot "naked" and $skirt is 0>><<set $rng to random(1, 100)>>
<<if $rng gte 81>>
<<if $undertype is "naked">>
<<neutral 4>><<set $swarmbackgrablowerclothed += 1>><<set $swarm5 to "back">><<set $swarmback += 1>>
<<elseif $undertype is "chastity" and $analshield is 1>>
<<set $swarm5 to "back">><<set $swarmback += 1>><<neutral 4>><<set $swarmbackgrablowerchastity += 1>>
<<else>>
<<neutral 4>><<set $swarmbackgrabunderclothed += 1>><<set $swarm5 to "back">><<set $swarmback += 1>>
<</if>>
<<else>>
<<neutral 1>><<set $swarmbacklowerclothed += 1>><<set $lowerintegrity -= 10>>
<</if>>
<<else>><<set $rng to random(1, 100)>>
<<if $rng gte 81>>
<<if $undertype is "naked">>
<<set $swarm5 to "back">><<set $swarmback += 1>><<neutral 4>><<set $swarmbackgrab += 1>>
<<elseif $undertype is "chastity" and $analshield is 1>>
<<set $swarm5 to "back">><<set $swarmback += 1>><<neutral 4>><<set $swarmbackgrablowerchastity += 1>>
<<else>>
<<set $swarmbackgrabunderclothed += 1>><<set $swarm5 to "back">><<set $swarmback += 1>><<neutral 4>>
<</if>>
<<else>>
<<if $undertype isnot "naked">>
<<neutral 1>><<set $swarmbackunderclothed += 1>><<set $underintegrity -= 10>>
<<else>>
<<set $swarm5 to "back">><<set $swarmback += 1>><<neutral 4>><<set $swarmbackgrab += 1>>
<</if>>
<</if>>
<</if>>
<<else>>
<<set $swarmbackmolest += 1>><<neutral 1>><<set $lowerintegrity -= 5>><<if $lowertype is "naked">><<set $underintegrity -= 5>><</if>>
<</if>>
<</if>>
<<else>>
<<if $front is "covered">>
<<set $arousal += 10>><<set $swarmfrontcover += 1>>
<<else>>
<<set $rng to random(1, 100)>>
<<if $rng lte $swarmactive * 20>>
<<if $lowertype isnot "naked" and $skirt is 0>><<set $rng to random(1, 100)>>
<<if $rng gte 81>>
<<if $undertype is "naked">>
<<neutral 4>><<set $swarmfrontgrablowerclothed += 1>><<set $swarm5 to "front">><<set $swarmfront +=1>>
<<elseif $undertype is "chastity">>
<<set $swarm5 to "front">><<set $swarmfront +=1>><<neutral 4>><<set $swarmfrontgrablowerchastity += 1>>
<<else>>
<<neutral 4>><<set $swarmfrontgrabunderclothed += 1>><<set $swarm5 to "front">><<set $swarmfront +=1>>
<</if>>
<<else>>
<<neutral 1>><<set $swarmfrontlowerclothed += 1>><<set $lowerintegrity -= 10>>
<</if>>
<<else>><<set $rng to random(1, 100)>>
<<if $rng gte 81>>
<<if $undertype is "naked">>
<<set $swarm5 to "front">><<set $swarmfront +=1>><<neutral 4>><<set $swarmfrontgrab += 1>>
<<elseif $undertype is "chastity">>
<<set $swarm5 to "front">><<set $swarmfront +=1>><<neutral 4>><<set $swarmfrontgrablowerchastity += 1>>
<<else>>
<<set $swarmfrontgrabunderclothed += 1>><<set $swarm5 to "front">><<set $swarmfront +=1>><<neutral 4>>
<</if>>
<<else>>
<<if $undertype isnot "naked">>
<<neutral 1>><<set $swarmfrontunderclothed += 1>><<set $underintegrity -= 10>>
<<else>>
<<set $swarm5 to "front">><<set $swarmfront +=1>><<neutral 4>><<set $swarmfrontgrab += 1>>
<</if>>
<</if>>
<</if>>
<<else>>
<<set $swarmfrontmolest += 1>><<neutral 1>><<set $lowerintegrity -= 5>><<if $lowertype is "naked">><<set $underintegrity -= 5>><</if>>
<</if>>
<</if>>
<</if>>
<<else>>
<<set $arousal += 10>>
<</if>>
<<elseif $swarm5 is "back">>
<<set $swarm5 to "backinside">><<set $swarmbackinside += 1>><<set $swarmbackinsideintro += 1>><<set $swarmback -= 1>>
<<elseif $swarm5 is "front">>
<<set $swarm5 to "frontinside">><<set $swarmfrontinside += 1>><<set $swarmfrontinsideintro += 1>><<set $swarmfront -= 1>>
<<else>>
<</if>>
<</nobr>><</widget>>
:: Widgets Swarm Actions [widget]
<<widget "swarmactions">><<nobr>>
<<set $chest to 0>>
<<set $front to 0>>
<<set $back to 0>>
<<if $vorecreature is 0>>
<<if $images is 1>><<timed 100ms>>
<<combatimg>>
<br>
<</timed>><</if>>
<</if>>
<<if $enemytype isnot "tentacles">>
<<actioncarry>>
<<actioncarrydrop>>
<</if>>
<<if $trance lte 0>>
<<if $dissociation lte 1>>
<<if $panicparalysis is 0>>
<<if $panicviolence is 0>>
<<if $orgasmdown lte 0>>
<<if $pain lt 100>>
<<if $leftarm is "bound">>
Your left arm is bound and helpless.
<<if $gamemode is "soft">><br>
<label>Wriggle free<<radiobutton "$leftaction" "leftwriggle" checked>></label> |
<</if>>
<br><br>
<<elseif $leftarm is "swarmgrappled">>
<span class="purple">The $swarmcreature are constricting your left arm!</span>
<br><br>
<<elseif $leftarm is 0>>Your left arm is free.<br>
<<if $rightarm is "swarmgrappled">>
<label><span class="brat">Free your right arm</span> <<radiobutton "$leftaction" "leftfree">></label> |
<<elseif $swarmpending gte 1>>
<label>$swarmSteady one of the $swarmname <<radiobutton "$leftaction" "leftswarm">></label> |
<</if>>
<<if $swarmfrontinside lte 0 and $swarmfront lte 0>>
<label>Cover your <<if $vaginaexist is 1>>pussy<<else>>penis<</if>> <<radiobutton "$leftaction" "frontcoverleft">></label> |
<</if>>
<<if $swarmbackinside lte 0 and $swarmback lte 0>>
<label>Cover your butt <<radiobutton "$leftaction" "backcoverleft" checked>></label> |
<</if>>
<<if $swarmchestgrab lte 0>>
<label>Cover your chest <<radiobutton "$leftaction" "chestcoverleft">></label> |
<</if>>
<<if $swarmfrontinside gte 1 and $undertype isnot "chastity">>
<label><span class="brat"><<if $vaginaexist is 1>>Pull the $swarmcreature out of your pussy<<else>>Pull the $swarmcreature off of your penis<</if>></span> <<radiobutton "$leftaction" "frontpurgeleft">></label> |
<</if>>
<<if $swarmfront gte 1 and $undertype isnot "chastity">>
<label><span class="brat"><<if $vaginaexist is 1>>Keep the $swarmcreature away from your pussy<<else>>Keep the $swarmcreature away from your penis<</if>></span> <<radiobutton "$leftaction" "frontclearleft">></label> |
<</if>>
<<if $swarmbackinside gte 1 and $analshield isnot 1>>
<label><span class="brat">Pull the $swarmcreature out of your anus</span> <<radiobutton "$leftaction" "backpurgeleft" checked>></label> |
<</if>>
<<if $swarmback gte 1 and $analshield isnot 1>>
<label><span class="brat">Keep the $swarmcreature away from your butt</span> <<radiobutton "$leftaction" "backclearleft" checked>></label> |
<</if>>
<<if $swarmchestgrab gte 1>>
<label><span class="brat">Clear the $swarmcreature off of your chest</span> <<radiobutton "$leftaction" "chestclearleft">></label> |
<</if>>
<<if $water is 1 and $vorecreature is 0>>
<label><span class="teal">Swim to safety</span> <<radiobutton "$leftaction" "swim" checked>></label> |
<</if>>
<br><br>
<</if>>
<<if $rightarm is "bound">>
Your right arm is bound and helpless.
<<if $gamemode is "soft">><br>
<label>Wriggle free<<radiobutton "$rightaction" "rightwriggle" checked>></label> |
<</if>>
<br><br>
<<elseif $rightarm is "swarmgrappled">>
<span class="purple">The $swarmcreature are constricting your right arm!</span>
<br><br>
<<elseif $rightarm is 0>>Your right arm is free.<br>
<<if $leftarm is "swarmgrappled">>
<label><span class="brat">Free your left arm</span> <<radiobutton "$rightaction" "rightfree">></label> |
<<elseif $swarmpending gte 1>>
<label>$swarmSteady one of the $swarmname <<radiobutton "$rightaction" "rightswarm">></label> |
<</if>>
<<if $swarmfrontinside lte 0 and $swarmfront lte 0>>
<label>Cover your <<if $vaginaexist is 1>>pussy<<else>>penis<</if>> <<radiobutton "$rightaction" "frontcoverright" checked>></label> |
<</if>>
<<if $swarmbackinside lte 0 and $swarmback lte 0>>
<label>Cover your butt <<radiobutton "$rightaction" "backcoverright">></label> |
<</if>>
<<if $swarmchestgrab lte 0>>
<label>Cover your chest <<radiobutton "$rightaction" "chestcoverright">></label> |
<</if>>
<<if $swarmfrontinside gte 1 and $undertype isnot "chastity">>
<label><span class="brat"><<if $vaginaexist is 1>>Pull the $swarmcreature out of your pussy<<else>>Pull the $swarmcreature off of your penis<</if>></span> <<radiobutton "$rightaction" "frontpurgeright" checked>></label> |
<</if>>
<<if $swarmfront gte 1 and $undertype isnot "chastity">>
<label><span class="brat"><<if $vaginaexist is 1>>Keep the $swarmcreature away from your pussy<<else>>Keep the $swarmcreature away from your penis<</if>></span> <<radiobutton "$rightaction" "frontclearright" checked>></label> |
<</if>>
<<if $swarmbackinside gte 1 and $analshield isnot 1>>
<label><span class="brat">Pull the $swarmcreature out of your anus</span> <<radiobutton "$rightaction" "backpurgeright">></label> |
<</if>>
<<if $swarmback gte 1 and $analshield isnot 1>>
<label><span class="brat">Keep the $swarmcreature away from your butt</span> <<radiobutton "$rightaction" "backclearright">></label> |
<</if>>
<<if $swarmchestgrab gte 1>>
<label><span class="brat">Clear the $swarmcreature off of your chest</span> <<radiobutton "$rightaction" "chestclearright">></label> |
<</if>>
<<if $water is 1 and $vorecreature is 0>>
<label><span class="teal">Swim to safety</span> <<radiobutton "$rightaction" "swim" checked>></label> |
<</if>>
<br><br>
<</if>>
<<if $feetuse is 0>>
Your feet are free.<br>
<<if $swarmpending gte 1>>
<label>$swarmSteady one of the $swarmname <<radiobutton "$feetaction" "feetswarm" checked>></label> |
<</if>>
<</if>>
<br><br>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<if $enemytype isnot "tentacles">>
<<combatstate>>
<<carryblock>>
<</if>>
<br>
<</nobr>><</widget>>
:: Widgets Swarm Effects [widget]
<<widget "swarmeffects">><<nobr>>
<<effectspain>>
<<effectsorgasm>>
<<effectsdissociation>>
<<if $leftaction is "rightwriggle">><<set $leftaction to 0>>
<<if $leftarm is "bound">>
<<unbind>><span class="green">You wriggle free from your bonds.</span>
<</if>>
<</if>>
<<if $leftaction is "leftfree">><<set $leftaction to 0>><<set $rightarm to 0>><span class="lblue">You push away the $swarmcreature covering your right arm, freeing it.</span>
<</if>>
<<if $leftaction is "leftswarm">><<set $leftaction to 0>><<set $swarmpending -= 1>><span class="lblue">You $swarmsteady one of the $swarmname with your left hand.</span>
<<if $swarm1 is "pending">><<set $swarm1 to "steadied">>
<<elseif $swarm2 is "pending">><<set $swarm2 to "steadied">>
<<elseif $swarm3 is "pending">><<set $swarm3 to "steadied">>
<<elseif $swarm4 is "pending">><<set $swarm4 to "steadied">>
<<elseif $swarm5 is "pending">><<set $swarm5 to "steadied">>
<<elseif $swarm6 is "pending">><<set $swarm6 to "steadied">>
<<elseif $swarm7 is "pending">><<set $swarm7 to "steadied">>
<<elseif $swarm8 is "pending">><<set $swarm8 to "steadied">>
<<elseif $swarm9 is "pending">><<set $swarm9 to "steadied">>
<<elseif $swarm10 is "pending">><<set $swarm10 to "steadied">>
<</if>>
<</if>>
<<if $leftaction is "frontcoverleft">><<set $leftaction to 0>><<set $front to "covered">>You cover your <<genitalsstop>>with your left hand to prevent the $swarmcreature from violating you.
<</if>>
<<if $leftaction is "backcoverleft">><<set $leftaction to 0>>
<<set $back to "covered">>You cover your butt with your left hand. Hopefully it will keep the $swarmcreature from invading your rear.
<</if>>
<<if $leftaction is "chestcoverleft">><<set $leftaction to 0>>
<<set $chest to "covered">>You cover your chest with your left hand, keeping the $swarmcreature away from your sensitive bust.
<</if>>
<<if $leftaction is "frontpurgeleft">><<set $leftaction to 0>>
<<set $swarmfrontinside -= 1>><span class="teal">You remove some of the $swarmcreature that are <<if $vaginaexist is 1>>penetrating<<else>>wrapped around<</if>> your <<genitalsstop>></span> <<if $swarmfrontinside gte 1>>However, there are still some violating you.<<else>>You think you got them all, for now.<</if>>
<<if $swarm1 is "frontinside">><<set $swarm1 to "active">>
<<elseif $swarm2 is "frontinside">><<set $swarm2 to "active">>
<<elseif $swarm3 is "frontinside">><<set $swarm3 to "active">>
<<elseif $swarm4 is "frontinside">><<set $swarm4 to "active">>
<<elseif $swarm5 is "frontinside">><<set $swarm5 to "active">>
<<elseif $swarm6 is "frontinside">><<set $swarm6 to "active">>
<<elseif $swarm7 is "frontinside">><<set $swarm7 to "active">>
<<elseif $swarm8 is "frontinside">><<set $swarm8 to "active">>
<<elseif $swarm9 is "frontinside">><<set $swarm9 to "active">>
<<elseif $swarm10 is "frontinside">><<set $swarm10 to "active">>
<</if>>
<</if>>
<<if $leftaction is "frontclearleft">><<set $leftaction to 0>>
<<set $swarmfront -= 1>><span class="lblue">You prevent the encroaching $swarmcreature from <<if $vaginaexist is 1>>entering<<else>>enveloping<</if>> your <<genitalsstop>></span> <<if $swarmfront gte 1>><span class="purple">There are so many however, that some make it through your guard.</span><</if>>
<<if $swarm1 is "front">><<set $swarm1 to "active">>
<<elseif $swarm2 is "front">><<set $swarm2 to "active">>
<<elseif $swarm3 is "front">><<set $swarm3 to "active">>
<<elseif $swarm4 is "front">><<set $swarm4 to "active">>
<<elseif $swarm5 is "front">><<set $swarm5 to "active">>
<<elseif $swarm6 is "front">><<set $swarm6 to "active">>
<<elseif $swarm7 is "front">><<set $swarm7 to "active">>
<<elseif $swarm8 is "front">><<set $swarm8 to "active">>
<<elseif $swarm9 is "front">><<set $swarm9 to "active">>
<<elseif $swarm10 is "front">><<set $swarm10 to "active">>
<</if>>
<</if>>
<<if $leftaction is "backpurgeleft">><<set $leftaction to 0>>
<<set $swarmbackinside -= 1>><span class="teal">You extract some of the $swarmcreature from your anus.</span> <<if $swarmbackinside gte 1>>However, there are still some infesting you.<<else>>You think you got them all.<</if>>
<<if $swarm1 is "backinside">><<set $swarm1 to "active">>
<<elseif $swarm2 is "backinside">><<set $swarm2 to "active">>
<<elseif $swarm3 is "backinside">><<set $swarm3 to "active">>
<<elseif $swarm4 is "backinside">><<set $swarm4 to "active">>
<<elseif $swarm5 is "backinside">><<set $swarm5 to "active">>
<<elseif $swarm6 is "backinside">><<set $swarm6 to "active">>
<<elseif $swarm7 is "backinside">><<set $swarm7 to "active">>
<<elseif $swarm8 is "backinside">><<set $swarm8 to "active">>
<<elseif $swarm9 is "backinside">><<set $swarm9 to "active">>
<<elseif $swarm10 is "backinside">><<set $swarm10 to "active">>
<</if>>
<</if>>
<<if $leftaction is "backclearleft">><<set $leftaction to 0>>
<<set $swarmback -= 1>><span class="lblue">You prevent the encroaching $swarmcreature from burrowing into your anus.</span> <<if $swarmback gte 1>><span class="purple">There are so many however, that some make it through your guard.</span><</if>>
<<if $swarm1 is "back">><<set $swarm1 to "active">>
<<elseif $swarm2 is "back">><<set $swarm2 to "active">>
<<elseif $swarm3 is "back">><<set $swarm3 to "active">>
<<elseif $swarm4 is "back">><<set $swarm4 to "active">>
<<elseif $swarm5 is "back">><<set $swarm5 to "active">>
<<elseif $swarm6 is "back">><<set $swarm6 to "active">>
<<elseif $swarm7 is "back">><<set $swarm7 to "active">>
<<elseif $swarm8 is "back">><<set $swarm8 to "active">>
<<elseif $swarm9 is "back">><<set $swarm9 to "active">>
<<elseif $swarm10 is "back">><<set $swarm10 to "active">>
<</if>>
<</if>>
<<if $leftaction is "chestclearleft">><<set $leftaction to 0>>
<<set $swarmchestgrab -= 1>><span class="lblue">You clear away some of the $swarmcreature around your sensitive nipples.</span> <<if $swarmchestgrab gte 1>><span class="purple">Many more remain however.</span><</if>>
<<if $swarm1 is "chest">><<set $swarm1 to "active">>
<<elseif $swarm2 is "chest">><<set $swarm2 to "active">>
<<elseif $swarm3 is "chest">><<set $swarm3 to "active">>
<<elseif $swarm4 is "chest">><<set $swarm4 to "active">>
<<elseif $swarm5 is "chest">><<set $swarm5 to "active">>
<<elseif $swarm6 is "chest">><<set $swarm6 to "active">>
<<elseif $swarm7 is "chest">><<set $swarm7 to "active">>
<<elseif $swarm8 is "chest">><<set $swarm8 to "active">>
<<elseif $swarm9 is "chest">><<set $swarm9 to "active">>
<<elseif $swarm10 is "chest">><<set $swarm10 to "active">>
<</if>>
<</if>>
<<if $leftaction is "swim">><<set $leftaction to 1>><<set $swimdistance -= 1>>
You paddle towards safety with your left arm.
<</if>>
<<if $rightaction is "rightwriggle">><<set $rightaction to 0>>
<<if $rightarm is "bound">>
<<unbind>><span class="green">You wriggle free from your bonds.</span>
<</if>>
<</if>>
<<if $rightaction is "rightfree">><<set $rightaction to 0>><<set $leftarm to 0>><span class="lblue">You push away the $swarmcreature covering your left arm, freeing it.</span>
<</if>>
<<if $rightaction is "rightswarm">><<set $rightaction to 0>><<set $swarmpending -= 1>><span class="lblue">You $swarmsteady one of the $swarmname with your right hand.</span>
<<if $swarm1 is "pending">><<set $swarm1 to "steadied">>
<<elseif $swarm2 is "pending">><<set $swarm2 to "steadied">>
<<elseif $swarm3 is "pending">><<set $swarm3 to "steadied">>
<<elseif $swarm4 is "pending">><<set $swarm4 to "steadied">>
<<elseif $swarm5 is "pending">><<set $swarm5 to "steadied">>
<<elseif $swarm6 is "pending">><<set $swarm6 to "steadied">>
<<elseif $swarm7 is "pending">><<set $swarm7 to "steadied">>
<<elseif $swarm8 is "pending">><<set $swarm8 to "steadied">>
<<elseif $swarm9 is "pending">><<set $swarm9 to "steadied">>
<<elseif $swarm10 is "pending">><<set $swarm10 to "steadied">>
<</if>>
<</if>>
<<if $rightaction is "frontcoverright">><<set $rightaction to 0>><<set $front to "covered">>You cover your <<genitalsstop>>with your right hand to prevent the $swarmcreature from violating you.
<</if>>
<<if $rightaction is "backcoverright">><<set $rightaction to 0>>
<<set $back to "covered">>You cover your butt with your right hand. Hopefully it will keep the $swarmcreature from invading your rear.
<</if>>
<<if $rightaction is "chestcoverright">><<set $rightaction to 0>>
<<set $chest to "covered">>You cover your chest with your right hand, keeping the $swarmcreature away from your sensitive bust.
<</if>>
<<if $rightaction is "frontpurgeright">><<set $rightaction to 0>>
<<set $swarmfrontinside -= 1>><span class="teal">You remove some of the $swarmcreature that are <<if $vaginaexist is 1>>penetrating<<else>>wrapped around<</if>> your <<genitalsstop>></span> <<if $swarmfrontinside gte 1>>However, there are still some violating you.<<else>>You think you got them all, for now.<</if>>
<<if $swarm1 is "frontinside">><<set $swarm1 to "active">>
<<elseif $swarm2 is "frontinside">><<set $swarm2 to "active">>
<<elseif $swarm3 is "frontinside">><<set $swarm3 to "active">>
<<elseif $swarm4 is "frontinside">><<set $swarm4 to "active">>
<<elseif $swarm5 is "frontinside">><<set $swarm5 to "active">>
<<elseif $swarm6 is "frontinside">><<set $swarm6 to "active">>
<<elseif $swarm7 is "frontinside">><<set $swarm7 to "active">>
<<elseif $swarm8 is "frontinside">><<set $swarm8 to "active">>
<<elseif $swarm9 is "frontinside">><<set $swarm9 to "active">>
<<elseif $swarm10 is "frontinside">><<set $swarm10 to "active">>
<</if>>
<</if>>
<<if $rightaction is "frontclearright">><<set $rightaction to 0>>
<<set $swarmfront -= 1>><span class="lblue">You prevent the encroaching $swarmcreature from <<if $vaginaexist is 1>>entering<<else>>enveloping<</if>> your <<genitalsstop>></span><<if $swarmfront gte 1>><span class="purple">There are so many however, that some make it through your guard.</span><</if>>
<<if $swarm1 is "front">><<set $swarm1 to "active">>
<<elseif $swarm2 is "front">><<set $swarm2 to "active">>
<<elseif $swarm3 is "front">><<set $swarm3 to "active">>
<<elseif $swarm4 is "front">><<set $swarm4 to "active">>
<<elseif $swarm5 is "front">><<set $swarm5 to "active">>
<<elseif $swarm6 is "front">><<set $swarm6 to "active">>
<<elseif $swarm7 is "front">><<set $swarm7 to "active">>
<<elseif $swarm8 is "front">><<set $swarm8 to "active">>
<<elseif $swarm9 is "front">><<set $swarm9 to "active">>
<<elseif $swarm10 is "front">><<set $swarm10 to "active">>
<</if>>
<</if>>
<<if $rightaction is "backpurgeright">><<set $rightaction to 0>>
<<set $swarmbackinside -= 1>><span class="teal">You extract some of the $swarmcreature from your anus.</span> <<if $swarmbackinside gte 1>>However, there are still some infesting you.<<else>>You think you got them all.<</if>>
<<if $swarm1 is "backinside">><<set $swarm1 to "active">>
<<elseif $swarm2 is "backinside">><<set $swarm2 to "active">>
<<elseif $swarm3 is "backinside">><<set $swarm3 to "active">>
<<elseif $swarm4 is "backinside">><<set $swarm4 to "active">>
<<elseif $swarm5 is "backinside">><<set $swarm5 to "active">>
<<elseif $swarm6 is "backinside">><<set $swarm6 to "active">>
<<elseif $swarm7 is "backinside">><<set $swarm7 to "active">>
<<elseif $swarm8 is "backinside">><<set $swarm8 to "active">>
<<elseif $swarm9 is "backinside">><<set $swarm9 to "active">>
<<elseif $swarm10 is "backinside">><<set $swarm10 to "active">>
<</if>>
<</if>>
<<if $rightaction is "backclearright">><<set $rightaction to 0>>
<<set $swarmback -= 1>><span class="lblue">You prevent the encroaching $swarmcreature from burrowing into your anus.</span><<if $swarmback gte 1>><span class="purple">There are so many however, that some make it through your guard.</span><</if>>
<<if $swarm1 is "back">><<set $swarm1 to "active">>
<<elseif $swarm2 is "back">><<set $swarm2 to "active">>
<<elseif $swarm3 is "back">><<set $swarm3 to "active">>
<<elseif $swarm4 is "back">><<set $swarm4 to "active">>
<<elseif $swarm5 is "back">><<set $swarm5 to "active">>
<<elseif $swarm6 is "back">><<set $swarm6 to "active">>
<<elseif $swarm7 is "back">><<set $swarm7 to "active">>
<<elseif $swarm8 is "back">><<set $swarm8 to "active">>
<<elseif $swarm9 is "back">><<set $swarm9 to "active">>
<<elseif $swarm10 is "back">><<set $swarm10 to "active">>
<</if>>
<</if>>
<<if $rightaction is "chestclearright">><<set $rightaction to 0>>
<<set $swarmchestgrab -= 1>><span class="lblue">You clear away some of the $swarmcreature around your sensitive nipples.</span> <<if $swarmchestgrab gte 1>><span class="purple">Many more remain however.</span><</if>>
<<if $swarm1 is "chest">><<set $swarm1 to "active">>
<<elseif $swarm2 is "chest">><<set $swarm2 to "active">>
<<elseif $swarm3 is "chest">><<set $swarm3 to "active">>
<<elseif $swarm4 is "chest">><<set $swarm4 to "active">>
<<elseif $swarm5 is "chest">><<set $swarm5 to "active">>
<<elseif $swarm6 is "chest">><<set $swarm6 to "active">>
<<elseif $swarm7 is "chest">><<set $swarm7 to "active">>
<<elseif $swarm8 is "chest">><<set $swarm8 to "active">>
<<elseif $swarm9 is "chest">><<set $swarm9 to "active">>
<<elseif $swarm10 is "chest">><<set $swarm10 to "active">>
<</if>>
<</if>>
<<if $rightaction is "swim">><<set $rightaction to 1>><<set $swimdistance -= 1>>
You paddle towards safety with your right arm.
<</if>>
<<if $feetaction is "feetswarm">><<set $feetaction to 0>>
<<set $swarmpending -= 1>><span class="lblue">You $swarmsteady one of the $swarmname with your feet.</span>
<<if $swarm1 is "pending">><<set $swarm1 to "steadied">>
<<elseif $swarm2 is "pending">><<set $swarm2 to "steadied">>
<<elseif $swarm3 is "pending">><<set $swarm3 to "steadied">>
<<elseif $swarm4 is "pending">><<set $swarm4 to "steadied">>
<<elseif $swarm5 is "pending">><<set $swarm5 to "steadied">>
<<elseif $swarm6 is "pending">><<set $swarm6 to "steadied">>
<<elseif $swarm7 is "pending">><<set $swarm7 to "steadied">>
<<elseif $swarm8 is "pending">><<set $swarm8 to "steadied">>
<<elseif $swarm9 is "pending">><<set $swarm9 to "steadied">>
<<elseif $swarm10 is "pending">><<set $swarm10 to "steadied">>
<</if>>
<</if>>
<br><br>
<</nobr>><</widget>>
:: Widgets Swarm10 [widget]
<<widget "swarm10">><<nobr>>
<<set $rng to random(1, 100)>>
<<if $swarm10 is "steadied">>
<<set $swarm10 to "contained">>
<<elseif $swarm10 is "contained">>
<<if $rng gte 51>>
<<set $swarm10 to "pending">><<set $swarmpending += 1>>
<</if>>
<<elseif $swarm10 is "pending">>
<<set $swarm10 to "active">><<set $swarmpending -= 1>><<set $swarmactive += 1>><<set $swarmactivate += 1>>
<<elseif $swarm10 is "active">>
<<if $rng lte $swarmactive * 20>>
<<set $rng to random(1, 100)>>
<<if $rng gte 70>>
<<if $chest is "covered">>
<<set $arousal += 10>><<set $swarmchestcover += 1>>
<<else>>
<<set $rng to random(1, 100)>>
<<if $rng lte $swarmactive * 20>>
<<if $uppertype is "naked">>
<<set $swarm10 to "chest">><<neutral 3>><<set $swarmchestgrab += 1>><<set $swarmchestgrabintro += 1>>
<<else>>
<<set $rng to random(1, 100)>>
<<if $rng gte 81>>
<<set $swarm10 to "chest">><<neutral 3>><<set $swarmchestgrab += 1>><<set $swarmchestgrabclothed += 1>>
<<else>>
<<neutral 1>><<set $swarmchestclothed += 1>><<set $upperintegrity -= 10>>
<</if>>
<</if>>
<<else>>
<<set $swarmchestmolest += 1>><<neutral 1>><<set $upperintegrity -= 5>>
<</if>>
<</if>>
<<elseif $rng gte 40 and $analdisable is "f">>
<<if $back is "covered">>
<<set $arousal += 10>><<set $swarmbackcover += 1>>
<<else>>
<<set $rng to random(1, 100)>>
<<if $rng lte $swarmactive * 20>>
<<if $lowertype isnot "naked" and $skirt is 0>><<set $rng to random(1, 100)>>
<<if $rng gte 81>>
<<if $undertype is "naked">>
<<neutral 4>><<set $swarmbackgrablowerclothed += 1>><<set $swarm10 to "back">><<set $swarmback += 1>>
<<elseif $undertype is "chastity" and $analshield is 1>>
<<set $swarm10 to "back">><<set $swarmback += 1>><<neutral 4>><<set $swarmbackgrablowerchastity += 1>>
<<else>>
<<neutral 4>><<set $swarmbackgrabunderclothed += 1>><<set $swarm10 to "back">><<set $swarmback += 1>>
<</if>>
<<else>>
<<neutral 1>><<set $swarmbacklowerclothed += 1>><<set $lowerintegrity -= 10>>
<</if>>
<<else>><<set $rng to random(1, 100)>>
<<if $rng gte 81>>
<<if $undertype is "naked">>
<<set $swarm10 to "back">><<set $swarmback += 1>><<neutral 4>><<set $swarmbackgrab += 1>>
<<elseif $undertype is "chastity" and $analshield is 1>>
<<set $swarm10 to "back">><<set $swarmback += 1>><<neutral 4>><<set $swarmbackgrablowerchastity += 1>>
<<else>>
<<set $swarmbackgrabunderclothed += 1>><<set $swarm10 to "back">><<set $swarmback += 1>><<neutral 4>>
<</if>>
<<else>>
<<if $undertype isnot "naked">>
<<neutral 1>><<set $swarmbackunderclothed += 1>><<set $underintegrity -= 10>>
<<else>>
<<set $swarm10 to "back">><<set $swarmback += 1>><<neutral 4>><<set $swarmbackgrab += 1>>
<</if>>
<</if>>
<</if>>
<<else>>
<<set $swarmbackmolest += 1>><<neutral 1>><<set $lowerintegrity -= 5>><<if $lowertype is "naked">><<set $underintegrity -= 5>><</if>>
<</if>>
<</if>>
<<else>>
<<if $front is "covered">>
<<set $arousal += 10>><<set $swarmfrontcover += 1>>
<<else>>
<<set $rng to random(1, 100)>>
<<if $rng lte $swarmactive * 20>>
<<if $lowertype isnot "naked" and $skirt is 0>><<set $rng to random(1, 100)>>
<<if $rng gte 81>>
<<if $undertype is "naked">>
<<neutral 4>><<set $swarmfrontgrablowerclothed += 1>><<set $swarm10 to "front">><<set $swarmfront +=1>>
<<elseif $undertype is "chastity">>
<<set $swarm10 to "front">><<set $swarmfront +=1>><<neutral 4>><<set $swarmfrontgrablowerchastity += 1>>
<<else>>
<<neutral 4>><<set $swarmfrontgrabunderclothed += 1>><<set $swarm10 to "front">><<set $swarmfront +=1>>
<</if>>
<<else>>
<<neutral 1>><<set $swarmfrontlowerclothed += 1>><<set $lowerintegrity -= 10>>
<</if>>
<<else>><<set $rng to random(1, 100)>>
<<if $rng gte 81>>
<<if $undertype is "naked">>
<<set $swarm10 to "front">><<set $swarmfront +=1>><<neutral 4>><<set $swarmfrontgrab += 1>>
<<elseif $undertype is "chastity">>
<<set $swarm10 to "front">><<set $swarmfront +=1>><<neutral 4>><<set $swarmfrontgrablowerchastity += 1>>
<<else>>
<<set $swarmfrontgrabunderclothed += 1>><<set $swarm10 to "front">><<set $swarmfront +=1>><<neutral 4>>
<</if>>
<<else>>
<<if $undertype isnot "naked">>
<<neutral 1>><<set $swarmfrontunderclothed += 1>><<set $underintegrity -= 10>>
<<else>>
<<set $swarm10 to "front">><<set $swarmfront +=1>><<neutral 4>><<set $swarmfrontgrab += 1>>
<</if>>
<</if>>
<</if>>
<<else>>
<<set $swarmfrontmolest += 1>><<neutral 1>><<set $lowerintegrity -= 5>><<if $lowertype is "naked">><<set $underintegrity -= 5>><</if>>
<</if>>
<</if>>
<</if>>
<<else>>
<<set $arousal += 10>>
<</if>>
<<elseif $swarm10 is "back">>
<<set $swarm10 to "backinside">><<set $swarmbackinside += 1>><<set $swarmbackinsideintro += 1>><<set $swarmback -= 1>>
<<elseif $swarm10 is "front">>
<<set $swarm10 to "frontinside">><<set $swarmfrontinside += 1>><<set $swarmfrontinsideintro += 1>><<set $swarmfront -= 1>>
<<else>>
<</if>>
<</nobr>><</widget>>
:: Widgets Swarm9 [widget]
<<widget "swarm9">><<nobr>>
<<set $rng to random(1, 100)>>
<<if $swarm9 is "steadied">>
<<set $swarm9 to "contained">>
<<elseif $swarm9 is "contained">>
<<if $rng gte 51>>
<<set $swarm9 to "pending">><<set $swarmpending += 1>>
<</if>>
<<elseif $swarm9 is "pending">>
<<set $swarm9 to "active">><<set $swarmpending -= 1>><<set $swarmactive += 1>><<set $swarmactivate += 1>>
<<elseif $swarm9 is "active">>
<<if $rng lte $swarmactive * 20>>
<<set $rng to random(1, 100)>>
<<if $rng gte 70>>
<<if $chest is "covered">>
<<set $arousal += 10>><<set $swarmchestcover += 1>>
<<else>>
<<set $rng to random(1, 100)>>
<<if $rng lte $swarmactive * 20>>
<<if $uppertype is "naked">>
<<set $swarm9 to "chest">><<neutral 3>><<set $swarmchestgrab += 1>><<set $swarmchestgrabintro += 1>>
<<else>>
<<set $rng to random(1, 100)>>
<<if $rng gte 81>>
<<set $swarm9 to "chest">><<neutral 3>><<set $swarmchestgrab += 1>><<set $swarmchestgrabclothed += 1>>
<<else>>
<<neutral 1>><<set $swarmchestclothed += 1>><<set $upperintegrity -= 10>>
<</if>>
<</if>>
<<else>>
<<set $swarmchestmolest += 1>><<neutral 1>><<set $upperintegrity -= 5>>
<</if>>
<</if>>
<<elseif $rng gte 40 and $analdisable is "f">>
<<if $back is "covered">>
<<set $arousal += 10>><<set $swarmbackcover += 1>>
<<else>>
<<set $rng to random(1, 100)>>
<<if $rng lte $swarmactive * 20>>
<<if $lowertype isnot "naked" and $skirt is 0>><<set $rng to random(1, 100)>>
<<if $rng gte 81>>
<<if $undertype is "naked">>
<<neutral 4>><<set $swarmbackgrablowerclothed += 1>><<set $swarm9 to "back">><<set $swarmback += 1>>
<<elseif $undertype is "chastity" and $analshield is 1>>
<<set $swarm9 to "back">><<set $swarmback += 1>><<neutral 4>><<set $swarmbackgrablowerchastity += 1>>
<<else>>
<<neutral 4>><<set $swarmbackgrabunderclothed += 1>><<set $swarm9 to "back">><<set $swarmback += 1>>
<</if>>
<<else>>
<<neutral 1>><<set $swarmbacklowerclothed += 1>><<set $lowerintegrity -= 10>>
<</if>>
<<else>><<set $rng to random(1, 100)>>
<<if $rng gte 81>>
<<if $undertype is "naked">>
<<set $swarm9 to "back">><<set $swarmback += 1>><<neutral 4>><<set $swarmbackgrab += 1>>
<<elseif $undertype is "chastity" and $analshield is 1>>
<<set $swarm9 to "back">><<set $swarmback += 1>><<neutral 4>><<set $swarmbackgrablowerchastity += 1>>
<<else>>
<<set $swarmbackgrabunderclothed += 1>><<set $swarm9 to "back">><<set $swarmback += 1>><<neutral 4>>
<</if>>
<<else>>
<<if $undertype isnot "naked">>
<<neutral 1>><<set $swarmbackunderclothed += 1>><<set $underintegrity -= 10>>
<<else>>
<<set $swarm9 to "back">><<set $swarmback += 1>><<neutral 4>><<set $swarmbackgrab += 1>>
<</if>>
<</if>>
<</if>>
<<else>>
<<set $swarmbackmolest += 1>><<neutral 1>><<set $lowerintegrity -= 5>><<if $lowertype is "naked">><<set $underintegrity -= 5>><</if>>
<</if>>
<</if>>
<<else>>
<<if $front is "covered">>
<<set $arousal += 10>><<set $swarmfrontcover += 1>>
<<else>>
<<set $rng to random(1, 100)>>
<<if $rng lte $swarmactive * 20>>
<<if $lowertype isnot "naked" and $skirt is 0>><<set $rng to random(1, 100)>>
<<if $rng gte 81>>
<<if $undertype is "naked">>
<<neutral 4>><<set $swarmfrontgrablowerclothed += 1>><<set $swarm9 to "front">><<set $swarmfront +=1>>
<<elseif $undertype is "chastity">>
<<set $swarm9 to "front">><<set $swarmfront +=1>><<neutral 4>><<set $swarmfrontgrablowerchastity += 1>>
<<else>>
<<neutral 4>><<set $swarmfrontgrabunderclothed += 1>><<set $swarm9 to "front">><<set $swarmfront +=1>>
<</if>>
<<else>>
<<neutral 1>><<set $swarmfrontlowerclothed += 1>><<set $lowerintegrity -= 10>>
<</if>>
<<else>><<set $rng to random(1, 100)>>
<<if $rng gte 81>>
<<if $undertype is "naked">>
<<set $swarm9 to "front">><<set $swarmfront +=1>><<neutral 4>><<set $swarmfrontgrab += 1>>
<<elseif $undertype is "chastity">>
<<set $swarm9 to "front">><<set $swarmfront +=1>><<neutral 4>><<set $swarmfrontgrablowerchastity += 1>>
<<else>>
<<set $swarmfrontgrabunderclothed += 1>><<set $swarm9 to "front">><<set $swarmfront +=1>><<neutral 4>>
<</if>>
<<else>>
<<if $undertype isnot "naked">>
<<neutral 1>><<set $swarmfrontunderclothed += 1>><<set $underintegrity -= 10>>
<<else>>
<<set $swarm9 to "front">><<set $swarmfront +=1>><<neutral 4>><<set $swarmfrontgrab += 1>>
<</if>>
<</if>>
<</if>>
<<else>>
<<set $swarmfrontmolest += 1>><<neutral 1>><<set $lowerintegrity -= 5>><<if $lowertype is "naked">><<set $underintegrity -= 5>><</if>>
<</if>>
<</if>>
<</if>>
<<else>>
<<set $arousal += 10>>
<</if>>
<<elseif $swarm9 is "back">>
<<set $swarm9 to "backinside">><<set $swarmbackinside += 1>><<set $swarmbackinsideintro += 1>><<set $swarmback -= 1>>
<<elseif $swarm9 is "front">>
<<set $swarm9 to "frontinside">><<set $swarmfrontinside += 1>><<set $swarmfrontinsideintro += 1>><<set $swarmfront -= 1>>
<<else>>
<</if>>
<</nobr>><</widget>>
:: Widgets Swarm8 [widget]
<<widget "swarm8">><<nobr>>
<<set $rng to random(1, 100)>>
<<if $swarm8 is "steadied">>
<<set $swarm8 to "contained">>
<<elseif $swarm8 is "contained">>
<<if $rng gte 51>>
<<set $swarm8 to "pending">><<set $swarmpending += 1>>
<</if>>
<<elseif $swarm8 is "pending">>
<<set $swarm8 to "active">><<set $swarmpending -= 1>><<set $swarmactive += 1>><<set $swarmactivate += 1>>
<<elseif $swarm8 is "active">>
<<if $rng lte $swarmactive * 20>>
<<set $rng to random(1, 100)>>
<<if $rng gte 70>>
<<if $chest is "covered">>
<<set $arousal += 10>><<set $swarmchestcover += 1>>
<<else>>
<<set $rng to random(1, 100)>>
<<if $rng lte $swarmactive * 20>>
<<if $uppertype is "naked">>
<<set $swarm8 to "chest">><<neutral 3>><<set $swarmchestgrab += 1>><<set $swarmchestgrabintro += 1>>
<<else>>
<<set $rng to random(1, 100)>>
<<if $rng gte 81>>
<<set $swarm8 to "chest">><<neutral 3>><<set $swarmchestgrab += 1>><<set $swarmchestgrabclothed += 1>>
<<else>>
<<neutral 1>><<set $swarmchestclothed += 1>><<set $upperintegrity -= 10>>
<</if>>
<</if>>
<<else>>
<<set $swarmchestmolest += 1>><<neutral 1>><<set $upperintegrity -= 5>>
<</if>>
<</if>>
<<elseif $rng gte 40 and $analdisable is "f">>
<<if $back is "covered">>
<<set $arousal += 10>><<set $swarmbackcover += 1>>
<<else>>
<<set $rng to random(1, 100)>>
<<if $rng lte $swarmactive * 20>>
<<if $lowertype isnot "naked" and $skirt is 0>><<set $rng to random(1, 100)>>
<<if $rng gte 81>>
<<if $undertype is "naked">>
<<neutral 4>><<set $swarmbackgrablowerclothed += 1>><<set $swarm8 to "back">><<set $swarmback += 1>>
<<elseif $undertype is "chastity" and $analshield is 1>>
<<set $swarm8 to "back">><<set $swarmback += 1>><<neutral 4>><<set $swarmbackgrablowerchastity += 1>>
<<else>>
<<neutral 4>><<set $swarmbackgrabunderclothed += 1>><<set $swarm8 to "back">><<set $swarmback += 1>>
<</if>>
<<else>>
<<neutral 1>><<set $swarmbacklowerclothed += 1>><<set $lowerintegrity -= 10>>
<</if>>
<<else>><<set $rng to random(1, 100)>>
<<if $rng gte 81>>
<<if $undertype is "naked">>
<<set $swarm8 to "back">><<set $swarmback += 1>><<neutral 4>><<set $swarmbackgrab += 1>>
<<elseif $undertype is "chastity" and $analshield is 1>>
<<set $swarm8 to "back">><<set $swarmback += 1>><<neutral 4>><<set $swarmbackgrablowerchastity += 1>>
<<else>>
<<set $swarmbackgrabunderclothed += 1>><<set $swarm8 to "back">><<set $swarmback += 1>><<neutral 4>>
<</if>>
<<else>>
<<if $undertype isnot "naked">>
<<neutral 1>><<set $swarmbackunderclothed += 1>><<set $underintegrity -= 10>>
<<else>>
<<set $swarm8 to "back">><<set $swarmback += 1>><<neutral 4>><<set $swarmbackgrab += 1>>
<</if>>
<</if>>
<</if>>
<<else>>
<<set $swarmbackmolest += 1>><<neutral 1>><<set $lowerintegrity -= 5>><<if $lowertype is "naked">><<set $underintegrity -= 5>><</if>>
<</if>>
<</if>>
<<else>>
<<if $front is "covered">>
<<set $arousal += 10>><<set $swarmfrontcover += 1>>
<<else>>
<<set $rng to random(1, 100)>>
<<if $rng lte $swarmactive * 20>>
<<if $lowertype isnot "naked" and $skirt is 0>><<set $rng to random(1, 100)>>
<<if $rng gte 81>>
<<if $undertype is "naked">>
<<neutral 4>><<set $swarmfrontgrablowerclothed += 1>><<set $swarm8 to "front">><<set $swarmfront +=1>>
<<elseif $undertype is "chastity">>
<<set $swarm8 to "front">><<set $swarmfront +=1>><<neutral 4>><<set $swarmfrontgrablowerchastity += 1>>
<<else>>
<<neutral 4>><<set $swarmfrontgrabunderclothed += 1>><<set $swarm8 to "front">><<set $swarmfront +=1>>
<</if>>
<<else>>
<<neutral 1>><<set $swarmfrontlowerclothed += 1>><<set $lowerintegrity -= 10>>
<</if>>
<<else>><<set $rng to random(1, 100)>>
<<if $rng gte 81>>
<<if $undertype is "naked">>
<<set $swarm8 to "front">><<set $swarmfront +=1>><<neutral 4>><<set $swarmfrontgrab += 1>>
<<elseif $undertype is "chastity">>
<<set $swarm8 to "front">><<set $swarmfront +=1>><<neutral 4>><<set $swarmfrontgrablowerchastity += 1>>
<<else>>
<<set $swarmfrontgrabunderclothed += 1>><<set $swarm8 to "front">><<set $swarmfront +=1>><<neutral 4>>
<</if>>
<<else>>
<<if $undertype isnot "naked">>
<<neutral 1>><<set $swarmfrontunderclothed += 1>><<set $underintegrity -= 10>>
<<else>>
<<set $swarm8 to "front">><<set $swarmfront +=1>><<neutral 4>><<set $swarmfrontgrab += 1>>
<</if>>
<</if>>
<</if>>
<<else>>
<<set $swarmfrontmolest += 1>><<neutral 1>><<set $lowerintegrity -= 5>><<if $lowertype is "naked">><<set $underintegrity -= 5>><</if>>
<</if>>
<</if>>
<</if>>
<<else>>
<<set $arousal += 10>>
<</if>>
<<elseif $swarm8 is "back">>
<<set $swarm8 to "backinside">><<set $swarmbackinside += 1>><<set $swarmbackinsideintro += 1>><<set $swarmback -= 1>>
<<elseif $swarm8 is "front">>
<<set $swarm8 to "frontinside">><<set $swarmfrontinside += 1>><<set $swarmfrontinsideintro += 1>><<set $swarmfront -= 1>>
<<else>>
<</if>>
<</nobr>><</widget>>
:: Widgets Swarm7 [widget]
<<widget "swarm7">><<nobr>>
<<set $rng to random(1, 100)>>
<<if $swarm7 is "steadied">>
<<set $swarm7 to "contained">>
<<elseif $swarm7 is "contained">>
<<if $rng gte 51>>
<<set $swarm7 to "pending">><<set $swarmpending += 1>>
<</if>>
<<elseif $swarm7 is "pending">>
<<set $swarm7 to "active">><<set $swarmpending -= 1>><<set $swarmactive += 1>><<set $swarmactivate += 1>>
<<elseif $swarm7 is "active">>
<<if $rng lte $swarmactive * 20>>
<<set $rng to random(1, 100)>>
<<if $rng gte 70>>
<<if $chest is "covered">>
<<set $arousal += 10>><<set $swarmchestcover += 1>>
<<else>>
<<set $rng to random(1, 100)>>
<<if $rng lte $swarmactive * 20>>
<<if $uppertype is "naked">>
<<set $swarm7 to "chest">><<neutral 3>><<set $swarmchestgrab += 1>><<set $swarmchestgrabintro += 1>>
<<else>>
<<set $rng to random(1, 100)>>
<<if $rng gte 81>>
<<set $swarm7 to "chest">><<neutral 3>><<set $swarmchestgrab += 1>><<set $swarmchestgrabclothed += 1>>
<<else>>
<<neutral 1>><<set $swarmchestclothed += 1>><<set $upperintegrity -= 10>>
<</if>>
<</if>>
<<else>>
<<set $swarmchestmolest += 1>><<neutral 1>><<set $upperintegrity -= 5>>
<</if>>
<</if>>
<<elseif $rng gte 40 and $analdisable is "f">>
<<if $back is "covered">>
<<set $arousal += 10>><<set $swarmbackcover += 1>>
<<else>>
<<set $rng to random(1, 100)>>
<<if $rng lte $swarmactive * 20>>
<<if $lowertype isnot "naked" and $skirt is 0>><<set $rng to random(1, 100)>>
<<if $rng gte 81>>
<<if $undertype is "naked">>
<<neutral 4>><<set $swarmbackgrablowerclothed += 1>><<set $swarm7 to "back">><<set $swarmback += 1>>
<<elseif $undertype is "chastity" and $analshield is 1>>
<<set $swarm7 to "back">><<set $swarmback += 1>><<neutral 4>><<set $swarmbackgrablowerchastity += 1>>
<<else>>
<<neutral 4>><<set $swarmbackgrabunderclothed += 1>><<set $swarm7 to "back">><<set $swarmback += 1>>
<</if>>
<<else>>
<<neutral 1>><<set $swarmbacklowerclothed += 1>><<set $lowerintegrity -= 10>>
<</if>>
<<else>><<set $rng to random(1, 100)>>
<<if $rng gte 81>>
<<if $undertype is "naked">>
<<set $swarm7 to "back">><<set $swarmback += 1>><<neutral 4>><<set $swarmbackgrab += 1>>
<<elseif $undertype is "chastity" and $analshield is 1>>
<<set $swarm7 to "back">><<set $swarmback += 1>><<neutral 4>><<set $swarmbackgrablowerchastity += 1>>
<<else>>
<<set $swarmbackgrabunderclothed += 1>><<set $swarm7 to "back">><<set $swarmback += 1>><<neutral 4>>
<</if>>
<<else>>
<<if $undertype isnot "naked">>
<<neutral 1>><<set $swarmbackunderclothed += 1>><<set $underintegrity -= 10>>
<<else>>
<<set $swarm7 to "back">><<set $swarmback += 1>><<neutral 4>><<set $swarmbackgrab += 1>>
<</if>>
<</if>>
<</if>>
<<else>>
<<set $swarmbackmolest += 1>><<neutral 1>><<set $lowerintegrity -= 5>><<if $lowertype is "naked">><<set $underintegrity -= 5>><</if>>
<</if>>
<</if>>
<<else>>
<<if $front is "covered">>
<<set $arousal += 10>><<set $swarmfrontcover += 1>>
<<else>>
<<set $rng to random(1, 100)>>
<<if $rng lte $swarmactive * 20>>
<<if $lowertype isnot "naked" and $skirt is 0>><<set $rng to random(1, 100)>>
<<if $rng gte 81>>
<<if $undertype is "naked">>
<<neutral 4>><<set $swarmfrontgrablowerclothed += 1>><<set $swarm7 to "front">><<set $swarmfront +=1>>
<<elseif $undertype is "chastity">>
<<set $swarm7 to "front">><<set $swarmfront +=1>><<neutral 4>><<set $swarmfrontgrablowerchastity += 1>>
<<else>>
<<neutral 4>><<set $swarmfrontgrabunderclothed += 1>><<set $swarm7 to "front">><<set $swarmfront +=1>>
<</if>>
<<else>>
<<neutral 1>><<set $swarmfrontlowerclothed += 1>><<set $lowerintegrity -= 10>>
<</if>>
<<else>><<set $rng to random(1, 100)>>
<<if $rng gte 81>>
<<if $undertype is "naked">>
<<set $swarm7 to "front">><<set $swarmfront +=1>><<neutral 4>><<set $swarmfrontgrab += 1>>
<<elseif $undertype is "chastity">>
<<set $swarm7 to "front">><<set $swarmfront +=1>><<neutral 4>><<set $swarmfrontgrablowerchastity += 1>>
<<else>>
<<set $swarmfrontgrabunderclothed += 1>><<set $swarm7 to "front">><<set $swarmfront +=1>><<neutral 4>>
<</if>>
<<else>>
<<if $undertype isnot "naked">>
<<neutral 1>><<set $swarmfrontunderclothed += 1>><<set $underintegrity -= 10>>
<<else>>
<<set $swarm7 to "front">><<set $swarmfront +=1>><<neutral 4>><<set $swarmfrontgrab += 1>>
<</if>>
<</if>>
<</if>>
<<else>>
<<set $swarmfrontmolest += 1>><<neutral 1>><<set $lowerintegrity -= 5>><<if $lowertype is "naked">><<set $underintegrity -= 5>><</if>>
<</if>>
<</if>>
<</if>>
<<else>>
<<set $arousal += 10>>
<</if>>
<<elseif $swarm7 is "back">>
<<set $swarm7 to "backinside">><<set $swarmbackinside += 1>><<set $swarmbackinsideintro += 1>><<set $swarmback -= 1>>
<<elseif $swarm7 is "front">>
<<set $swarm7 to "frontinside">><<set $swarmfrontinside += 1>><<set $swarmfrontinsideintro += 1>><<set $swarmfront -= 1>>
<<else>>
<</if>>
<</nobr>><</widget>>
:: Widgets Swarm6 [widget]
<<widget "swarm6">><<nobr>>
<<set $rng to random(1, 100)>>
<<if $swarm6 is "steadied">>
<<set $swarm6 to "contained">>
<<elseif $swarm6 is "contained">>
<<if $rng gte 51>>
<<set $swarm6 to "pending">><<set $swarmpending += 1>>
<</if>>
<<elseif $swarm6 is "pending">>
<<set $swarm6 to "active">><<set $swarmpending -= 1>><<set $swarmactive += 1>><<set $swarmactivate += 1>>
<<elseif $swarm6 is "active">>
<<if $rng lte $swarmactive * 20>>
<<set $rng to random(1, 100)>>
<<if $rng gte 70>>
<<if $chest is "covered">>
<<set $arousal += 10>><<set $swarmchestcover += 1>>
<<else>>
<<set $rng to random(1, 100)>>
<<if $rng lte $swarmactive * 20>>
<<if $uppertype is "naked">>
<<set $swarm6 to "chest">><<neutral 3>><<set $swarmchestgrab += 1>><<set $swarmchestgrabintro += 1>>
<<else>>
<<set $rng to random(1, 100)>>
<<if $rng gte 81>>
<<set $swarm6 to "chest">><<neutral 3>><<set $swarmchestgrab += 1>><<set $swarmchestgrabclothed += 1>>
<<else>>
<<neutral 1>><<set $swarmchestclothed += 1>><<set $upperintegrity -= 10>>
<</if>>
<</if>>
<<else>>
<<set $swarmchestmolest += 1>><<neutral 1>><<set $upperintegrity -= 5>>
<</if>>
<</if>>
<<elseif $rng gte 40 and $analdisable is "f">>
<<if $back is "covered">>
<<set $arousal += 10>><<set $swarmbackcover += 1>>
<<else>>
<<set $rng to random(1, 100)>>
<<if $rng lte $swarmactive * 20>>
<<if $lowertype isnot "naked" and $skirt is 0>><<set $rng to random(1, 100)>>
<<if $rng gte 81>>
<<if $undertype is "naked">>
<<neutral 4>><<set $swarmbackgrablowerclothed += 1>><<set $swarm6 to "back">><<set $swarmback += 1>>
<<elseif $undertype is "chastity" and $analshield is 1>>
<<set $swarm6 to "back">><<set $swarmback += 1>><<neutral 4>><<set $swarmbackgrablowerchastity += 1>>
<<else>>
<<neutral 4>><<set $swarmbackgrabunderclothed += 1>><<set $swarm6 to "back">><<set $swarmback += 1>>
<</if>>
<<else>>
<<neutral 1>><<set $swarmbacklowerclothed += 1>><<set $lowerintegrity -= 10>>
<</if>>
<<else>><<set $rng to random(1, 100)>>
<<if $rng gte 81>>
<<if $undertype is "naked">>
<<set $swarm6 to "back">><<set $swarmback += 1>><<neutral 4>><<set $swarmbackgrab += 1>>
<<elseif $undertype is "chastity" and $analshield is 1>>
<<set $swarm6 to "back">><<set $swarmback += 1>><<neutral 4>><<set $swarmbackgrablowerchastity += 1>>
<<else>>
<<set $swarmbackgrabunderclothed += 1>><<set $swarm6 to "back">><<set $swarmback += 1>><<neutral 4>>
<</if>>
<<else>>
<<if $undertype isnot "naked">>
<<neutral 1>><<set $swarmbackunderclothed += 1>><<set $underintegrity -= 10>>
<<else>>
<<set $swarm6 to "back">><<set $swarmback += 1>><<neutral 4>><<set $swarmbackgrab += 1>>
<</if>>
<</if>>
<</if>>
<<else>>
<<set $swarmbackmolest += 1>><<neutral 1>><<set $lowerintegrity -= 5>><<if $lowertype is "naked">><<set $underintegrity -= 5>><</if>>
<</if>>
<</if>>
<<else>>
<<if $front is "covered">>
<<set $arousal += 10>><<set $swarmfrontcover += 1>>
<<else>>
<<set $rng to random(1, 100)>>
<<if $rng lte $swarmactive * 20>>
<<if $lowertype isnot "naked" and $skirt is 0>><<set $rng to random(1, 100)>>
<<if $rng gte 81>>
<<if $undertype is "naked">>
<<neutral 4>><<set $swarmfrontgrablowerclothed += 1>><<set $swarm6 to "front">><<set $swarmfront +=1>>
<<elseif $undertype is "chastity">>
<<set $swarm6 to "front">><<set $swarmfront +=1>><<neutral 4>><<set $swarmfrontgrablowerchastity += 1>>
<<else>>
<<neutral 4>><<set $swarmfrontgrabunderclothed += 1>><<set $swarm6 to "front">><<set $swarmfront +=1>>
<</if>>
<<else>>
<<neutral 1>><<set $swarmfrontlowerclothed += 1>><<set $lowerintegrity -= 10>>
<</if>>
<<else>><<set $rng to random(1, 100)>>
<<if $rng gte 81>>
<<if $undertype is "naked">>
<<set $swarm6 to "front">><<set $swarmfront +=1>><<neutral 4>><<set $swarmfrontgrab += 1>>
<<elseif $undertype is "chastity">>
<<set $swarm6 to "front">><<set $swarmfront +=1>><<neutral 4>><<set $swarmfrontgrablowerchastity += 1>>
<<else>>
<<set $swarmfrontgrabunderclothed += 1>><<set $swarm6 to "front">><<set $swarmfront +=1>><<neutral 4>>
<</if>>
<<else>>
<<if $undertype isnot "naked">>
<<neutral 1>><<set $swarmfrontunderclothed += 1>><<set $underintegrity -= 10>>
<<else>>
<<set $swarm6 to "front">><<set $swarmfront +=1>><<neutral 4>><<set $swarmfrontgrab += 1>>
<</if>>
<</if>>
<</if>>
<<else>>
<<set $swarmfrontmolest += 1>><<neutral 1>><<set $lowerintegrity -= 5>><<if $lowertype is "naked">><<set $underintegrity -= 5>><</if>>
<</if>>
<</if>>
<</if>>
<<else>>
<<set $arousal += 10>>
<</if>>
<<elseif $swarm6 is "back">>
<<set $swarm6 to "backinside">><<set $swarmbackinside += 1>><<set $swarmbackinsideintro += 1>><<set $swarmback -= 1>>
<<elseif $swarm6 is "front">>
<<set $swarm6 to "frontinside">><<set $swarmfrontinside += 1>><<set $swarmfrontinsideintro += 1>><<set $swarmfront -= 1>>
<<else>>
<</if>>
<</nobr>><</widget>>
:: Tutorial [nobr]
<<if $molestationstart is 1>>
<<set $molestationstart to 0>>
<<controlloss>>
<<violence 1>>
<<neutral 1>>
<<molested>>
<<set $event to "molestationhome">>
<<set $rescue to 1>>
<<man1init>>
<<He>> reaches toward you.
<</if>>
<<effects>>
<<effectsman>><<man>>
<<stateman>><br>
<br>
__Combat Tutorial__<br>
<<if $gamemode is "soft">>
<i>Your character will be quite passive at first. More actions will become available as you become more promiscuous and comfortable being assertive.<br><br>
<span class="sub">Assertive</span> and <span class="meek">meek</span> actions will arouse your partner, bringing them closer to orgasm. They'll also make them trust you more.<br><br>
<span class="brat">Bratty</span> acts will irritate your partner. Use them too frequently and they will become rougher and less trusting.<br><br>
Some actions have only a chance of working, based on your skill with the bodypart being used and how trusting your partner is.<br><br>
Each part of your body can perform one action per turn. Choose your actions, then click next or press enter to continue.</i><br><br>
<<else>>
<i>There are three common ways to escape an attacker; fight them off, sexually satisfy them, or be rescued.
<span class="def">Defiant</span> acts will hurt them. Hurt them enough and you'll escape. However, <span class="def">defiant</span> acts will anger them, making them more violent.<br><br>
They'll be happy to use you as a passive toy, but <span class="sub">submissive</span> acts will make them cum faster. Once spent, they'll usually leave you alone. Some <span class="sub">submissive</span> acts will occupy their genitals, so they can't use them in more dangerous ways.<br><br>
<span class="meek">Meek</span> acts will endear you to them without being directly sexual. <span class="meek">Meek</span> acts will make them trust you more, and often have effects which may help you.<br><br>
<span class="brat">Bratty</span> acts protect you in ways that defies your attacker's will without hurting them. <span class="brat">Bratty</span> acts will reduce trust and increase anger.<br><br>
Finally, you could scream for help. Whether it will help or make things worse depends on who's around to hear. Screaming at night or in the wilderness will only anger your attacker. You won't be able to scream (or speak) if your attacker has you gagged.
For this encounter, screaming will get you rescued. Each part of your body can perform one action per turn. Choose your actions, then click next or press enter to continue.</i><br><br>
<</if>>
<br><br>
<<actionsman>>
<<if $alarm is 1 and $rescue is 1>>
<span id="next"><<link [[Next|Tutorial Finish]]>><</link>></span><<nexttext>>
<<elseif $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next|Tutorial Finish]]>><</link>></span><<nexttext>>
<<elseif $enemyhealth lte 0>>
<span id="next"><<link [[Next|Tutorial Finish]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next|Tutorial]]>><</link>></span><<nexttext>>
<</if>>
:: Tutorial Finish [nobr]
<<effects>><<set $eventskip to 1>>
<<if $enemyarousal gte $enemyarousalmax>>
<<ejaculation>>
<<if $enemyanger gte 60>>
"That's what you get, slut." <<He>> leaves you lying on the ground.<br><br>
<<else>>
"Good <<girlstop>> Here's a little something for the trouble." <<He>> leaves you lying on the ground.<br><br>
<<tearful>> you climb to your knees. You've gained £5.<br><br><<set $money += 500>>
<</if>><br><br>
<<clotheson>>
<<endcombat>>
<<if $gamemode is "soft">>
<<generate1>><<person1>>A <<person>> rushes over to you. "Are you okay?" <<He>> offers an arm to help you up.<br><br>
<<else>>
<<generate1>><<person1>>A <<person>> rushes over to you. "I saw what that fiend did. Are you okay?" <<He>> offers an arm to help you up.<br><br>
<</if>>
<i>Being attacked will damage your sense of control. You will become more vulnerable to trauma as your control fails.
Actions marked as "promiscuity", "exhibitionism" or "deviancy" will lower stress and trauma. They will also restore your sense of control. Committing these actions with enough frequency will unlock lewder actions of the same type, but make weaker actions lose effectiveness. If you're not careful, you'll be unable to reach the controlled state without shameless and outrageous acts.</i><br><br>
<<link [[Flirt|Tutorial Flirt]]>><</link>><<promiscuous1>><br>
<<link [[Thank them|Tutorial Thank]]>><</link>><br>
<<elseif $enemyhealth lte 0>>
The <<person>> recoils in pain. "You're fucking nuts," <<he>> says, limping away. <<tearful>> you climb to your knees.<br><br>
<<clotheson>>
<<endcombat>>
<<if $gamemode is "soft">>
<<generate1>><<person1>>A <<person>> rushes over to you. "Are you okay?" <<He>> offers an arm to help you up.<br><br>
<<else>>
<<generate1>><<person1>>A <<person>> rushes over to you. "I saw what that fiend did. Are you okay?" <<He>> offers an arm to help you up.<br><br>
<</if>>
<i>Being attacked will damage your sense of control. You will become more vulnerable to trauma as your control fails.
Actions marked as "promiscuity", "exhibitionism" or "deviancy" will lower stress and trauma. They will also restore your sense of control. Committing these actions with enough frequency will unlock lewder actions of the same type, but make weaker actions lose effectiveness. If you're not careful, you'll be unable to reach the controlled state without shameless and outrageous acts.</i><br><br>
<<link [[Flirt|Tutorial Flirt]]>><</link>><<promiscuous1>><br>
<<link [[Thank them|Tutorial Thank]]>><</link>><br>
<<elseif $rescue is 1 and $alarm is 1>><<set $rescued += 1>>
<<He>> notices several heads turning in response to your cry, and relents in <<his>> assault before making a hurried escape.<br><br>
<<tearful>> you climb to your knees.<br><br>
<<clotheson>>
<<endcombat>>
<<if $gamemode is "soft">>
<<generate1>><<person1>>A <<person>> rushes over to you. "Are you okay?" <<He>> offers an arm to help you up.<br><br>
<<else>>
<<generate1>><<person1>>A <<person>> rushes over to you. "I saw what that fiend did. Are you okay?" <<He>> offers an arm to help you up.<br><br>
<</if>>
<i>Being attacked will damage your sense of control. You will become more vulnerable to trauma as your control fails.
Actions marked as "promiscuity", "exhibitionism" or "deviancy" will lower stress and trauma. They will also restore your sense of control. Committing these actions with enough frequency will unlock lewder actions of the same type, but make weaker actions lose effectiveness. If you're not careful, you'll be unable to reach the controlled state without shameless and outrageous acts.</i><br><br>
<<link [[Flirt|Tutorial Flirt]]>><</link>><<promiscuous1>><br>
<<link [[Thank them|Tutorial Thank]]>><</link>><br>
<</if>>
:: Tutorial Flirt [nobr]
<<set $outside to 1>><<set $location to "town">><<effects>><<set $bus to "domus">>
You take <<his>> arm and hoist yourself up and against <<himcomma>> forcing <<him>> to catch you in an embrace to stop you falling. You look <<him>> in the eyes. "I feel safe now," you say.<<promiscuity1>><br><br>
<<He>> blushes. "I-I'm glad you're alright," <<he>> says as <<he>> slowly withdraws <<his>> arms from you, making sure you're steady. "I need to get going. You be careful."<br><br>
<<link [[Next|Domus Street]]>><<endevent>><<set $eventskip to 1>><</link>>
:: Tutorial Thank [nobr]
<<set $outside to 1>><<set $location to "town">><<effects>><<set $bus to "domus">>
You take <<his>> arm and <<he>> helps lift you to your feet. "Thank you," you say. "I'll be okay now." <<He>> nods and you part ways.<br><br>
<<link [[Next|Domus Street]]>><<endevent>><<set $eventskip to 1>><</link>>
:: Widgets Vore [widget]
<<widget "vore">><<nobr>>
<<set $rng to random(1, 100)>>
<<if $vorestage is 1>>
Your thighs are gripped by the $vorecreature's mouth, your shins and feet at the mercy of its probing tongue.<<neutral 5>>
<<elseif $vorestage is 2>>
Your waist is gripped by the $vorecreature's mouth, your delicate parts at the mercy of its probing tongue.<<neutral 5>>
<<elseif $vorestage is 3>>
Your chest is gripped by the $vorecreature's mouth, your body at the mercy of its probing tongue.<<neutral 10>>
<<elseif $vorestage is 4>>
Your shoulders are gripped by the $vorecreature's mouth, your body at the mercy of its probing tongue.<<neutral 10>>
<<elseif $vorestage is 5>>
Your entire body is in the $vorecreature's mouth.<<neutral 15>>
<<elseif $vorestage is 6>>
You are in the $vorecreature's gullet, pushed along by movements in the walls.<<neutral 15>>
<<elseif $vorestage is 7>>
You are in the $vorecreature's stomach, it's a struggle to keep your head above the slimy liquid.<<neutral 20>>
<</if>>
<<if $vorestage is 1>>
<<if ($vorestruggle * $physique) gte $vorestrength>>
<<if $vorestruggle is 2>>
You push down on the $vorecreature's maw with both your arms, <span class="green">preventing it from swallowing you further. </span>
<<elseif $vorestruggle is 1>>
You push down on the $vorecreature's maw with one arm, <span class="green">preventing it from swallowing you further. </span>
<<else>>
There's nothing preventing the $vorecreature from swallowing you further, <span class="green">but it doesn't take advantage of your vulnerability. </span>
<</if>>
<<else>>
<<set $vorestage += 1>>
<<if $vorestruggle is 2>>
You push down on the $vorecreature's maw with both your arms,<span class="blue"> but it isn't enough. </span>You slide deeper into its mouth, until it swallows you up to the waist.
<<elseif $vorestruggle is 1>>
You push down on the $vorecreature's maw with one arm,<span class="blue"> but it isn't enough. </span>You slide deeper into its mouth, until it swallows you up to the waist.
<<else>>
There's nothing preventing the $vorecreature from swallowing you further, <span class="blue">and it takes advantage of your vulnerability. </span>You slide deeper into its mouth, until it swallows you up to the waist.
<</if>>
<</if>>
<<elseif $vorestage is 2>><<set $lowerintegrity -= 1>><<if $lowerintegrity lte 0>><<set $underintegrity -= 1>><</if>>
<<if ($vorestruggle * $physique) gte $vorestrength>>
<<if $vorestruggle is 2>>
You push down on the $vorecreature's maw with both your arms, <span class="green">preventing it from swallowing you further. </span>
<<elseif $vorestruggle is 1>>
You push down on the $vorecreature's maw with one arm, <span class="green">preventing it from swallowing you further. </span>
<<else>>
There's nothing preventing the $vorecreature from swallowing you further, <span class="green">but it doesn't take advantage of your vulnerability. </span>
<</if>>
<<else>>
<<set $vorestage += 1>>
<<if $vorestruggle is 2>>
You push down on the $vorecreature's maw with both your arms,<span class="purple"> but it isn't enough. </span>You slide deeper into its mouth, until it swallows you up to your chest.
<<elseif $vorestruggle is 1>>
You push down on the $vorecreature's maw with one arm,<span class="purple"> but it isn't enough. </span>You slide deeper into its mouth, until it swallows you up to your chest.
<<else>>
There's nothing preventing the $vorecreature from swallowing you further, <span class="purple">and it takes advantage of your vulnerability. </span>You slide deeper into its mouth, until it swallows you up to your chest.
<</if>>
<</if>>
<<elseif $vorestage is 3>><<set $lowerintegrity -= 1>><<if $lowerintegrity lte 0>><<set $underintegrity -= 1>><</if>><<set $upperintegrity -= 1>>
<<if ($vorestruggle * $physique) gte $vorestrength>>
<<if $vorestruggle is 2>>
You push down on the $vorecreature's maw with both your arms, <span class="green">preventing it from swallowing you further. </span>
<<elseif $vorestruggle is 1>>
You push down on the $vorecreature's maw with one arm, <span class="green">preventing it from swallowing you further. </span>
<<else>>
There's nothing preventing the $vorecreature from swallowing you further, <span class="green">but it doesn't take advantage of your vulnerability. </span>
<</if>>
<<else>>
<<set $vorestage += 1>>
<<if $vorestruggle is 2>>
You push down on the $vorecreature's maw with both your arms,<span class="pink"> but it isn't enough. </span>You slide deeper into its mouth, until it swallows you up to your neck.
<<elseif $vorestruggle is 1>>
You push down on the $vorecreature's maw with one arm,<span class="pink"> but it isn't enough. </span>You slide deeper into its mouth, until it swallows you up to your neck.
<<else>>
There's nothing preventing the $vorecreature from swallowing you further, <span class="pink">and it takes advantage of your vulnerability. </span>You slide deeper into its mouth, until it swallows you up to your neck.
<</if>>
<</if>>
<<elseif $vorestage is 4>><<set $lowerintegrity -= 1>><<if $lowerintegrity lte 0>><<set $underintegrity -= 1>><</if>><<set $upperintegrity -= 1>>
<<if ($vorestruggle * $physique) gte $vorestrength>>
<<if $vorestruggle is 2>>
You grab the inside of the $vorecreature's maw with both arms, <span class="green">preventing it from swallowing you further. </span>
<<elseif $vorestruggle is 1>>
You grab the inside of the $vorecreature's maw with one arm, <span class="green">preventing it from swallowing you further. </span>
<<else>>
There's nothing preventing the $vorecreature from swallowing you further, <span class="green">but it doesn't take advantage of your vulnerability. </span>
<</if>>
<<else>>
<<set $vorestage += 1>>
<<if $vorestruggle is 2>>
You grab the inside of the $vorecreature's maw with both your arms,<span class="pink"> but it isn't enough. </span>The last of your body slides into its mouth, its lips closing behind you.
<<elseif $vorestruggle is 1>>
You grab the inside of the $vorecreature's maw with one arm,<span class="pink"> but it isn't enough. </span>The last of your body slides into its mouth, its lips closing behind you.
<<else>>
There's nothing preventing the $vorecreature from swallowing you further, <span class="pink">and it takes advantage of your vulnerability. </span>The last of your body slides into its mouth, its lips closing behind you.
<</if>>
<</if>>
<<elseif $vorestage is 5>><<set $lowerintegrity -= 1>><<if $lowerintegrity lte 0>><<set $underintegrity -= 1>><</if>><<set $upperintegrity -= 1>>
<<if ($vorestruggle * $physique) gte $vorestrength>>
<<if $vorestruggle is 2>>
You grab the inside of the $vorecreature's maw with both arms, <span class="green">preventing it from swallowing you further. </span>
<<elseif $vorestruggle is 1>>
You grab the inside of the $vorecreature's maw with one arm, <span class="green">preventing it from swallowing you further. </span>
<<else>>
There's nothing preventing the $vorecreature from swallowing you further, <span class="green">but it doesn't take advantage of your vulnerability. </span>
<</if>>
<<else>>
<<set $vorestage += 1>>
<<if $vorestruggle is 2>>
You grab the inside of the $vorecreature's maw with both your arms,<span class="pink"> but it isn't enough. </span>The $vorecreature sucks you further down, sliding you into its gullet.
<<elseif $vorestruggle is 1>>
You grab the inside of the $vorecreature's maw with one arm,<span class="pink"> but it isn't enough. </span>The $vorecreature sucks you further down, sliding you into its gullet.
<<else>>
There's nothing preventing the $vorecreature from swallowing you further, <span class="pink">and it takes advantage of your vulnerability. </span>The $vorecreature sucks you further down, sliding you into its gullet.
<</if>>
<</if>>
<<elseif $vorestage is 6>><<set $lowerintegrity -= 1>><<if $lowerintegrity lte 0>><<set $underintegrity -= 1>><</if>><<set $upperintegrity -= 1>>
<<if ($vorestruggle * $physique) gte $vorestrength>>
<<if $vorestruggle is 2>>
You grab the inside of the $vorecreature's maw with both arms, <span class="green">preventing it from swallowing you further. </span>
<<elseif $vorestruggle is 1>>
You grab the inside of the $vorecreature's maw with one arm, <span class="green">preventing it from swallowing you further. </span>
<<else>>
There's nothing preventing the $vorecreature from swallowing you further, <span class="green">but it doesn't take advantage of your vulnerability. </span>
<</if>>
<<else>>
<<set $vorestage += 1>>
<<if $vorestruggle is 2>>
You grab the inside of the $vorecreature's maw with both your arms,<span class="pink"> but it isn't enough. </span>The $vorecreature sucks you further down, depositing you in a fleshy chamber.<<if $leftarm is "grappled">><<set $leftarm to 0>><</if>><<if $rightarm is "grappled">><<set $rightarm to 0>><<swallowed>><</if>>
<<elseif $vorestruggle is 1>>
You grab the inside of the $vorecreature's maw with one arm,<span class="pink"> but it isn't enough. </span>The $vorecreature sucks you further down, depositing you in a fleshy chamber.<<if $leftarm is "trapped">><<set $leftarm to 0>><</if>><<if $rightarm is "trapped">><<set $rightarm to 0>><<swallowed>><</if>>
<<else>>
There's nothing preventing the $vorecreature from swallowing you further, <span class="pink">and it takes advantage of your vulnerability. </span>The $vorecreature sucks you further down, depositing you in a fleshy chamber.<<if $leftarm is "trapped">><<set $leftarm to 0>><</if>><<if $rightarm is "trapped">><<set $rightarm to 0>><</if>><<swallowed>>
<</if>>
<</if>>
<<else>><<set $lowerintegrity -= 5>><<if $lowerintegrity lte 0>><<set $underintegrity -= 5>><</if>><<set $upperintegrity -= 5>>
<</if>>
<br><br>
<<set $vorestruggle to 0>>
<<set $rng to random(1, 100)>>
<<if $vorestage is 1>>
<<if $rng gte 66>>
You feel the $vorecreature licking your feet.<<neutral 5>>
<<elseif $rng gte 33>>
The $vorecreature's tongue protrudes from its maw, and licks your inner thighs.<<neutral 5>>
<<else>>
The $vorecreature's tongue protrudes from its maw, and licks your butt.<<neutral 5>>
<</if>>
<<elseif $vorestage is 2>>
<<if $rng gte 66>>
You feel the $vorecreature licking your butt.<<neutral 5>>
<<elseif $rng gte 33>>
The $vorecreature gently licks your <<groinstop>><<neutral 10>>
<<else>>
The $vorecreature's tongue wraps around your pelvis, and rubs up and down the length of your thighs.<<neutral 5>>
<</if>>
<<elseif $vorestage is 3>>
<<if $rng gte 66>>
The $vorecreature's tongue presses your body against the roof of its maw.<<neutral 5>>
<<elseif $rng gte 33>>
The $vorecreature gently prods your <<groinstop>><<neutral 10>>
<<else>>
The $vorecreature's tongue caresses your inner thighs.<<neutral 5>>
<</if>>
<<elseif $vorestage is 4>>
<<if $rng gte 66>>
The $vorecreature runs the tip of its tongue down the length of your body.<<neutral 5>>
<<elseif $rng gte 33>>
The $vorecreature gently prods your <<groinstop>><<neutral 10>>
<<else>>
The $vorecreature's tongue caresses your inner thighs.<<neutral 10>>
<</if>>
<<elseif $vorestage is 5>>
<<if $rng gte 66>>
The $vorecreature runs the tip of its tongue down the length of your body.<<neutral 10>>
<<elseif $rng gte 33>>
The $vorecreature wraps its tongue around your body.<<neutral 10>>
<<else>>
The $vorecreature flicks your <<groin>> with the tip of its tongue.<<neutral 15>>
<</if>>
<<elseif $vorestage is 6>>
<<if $rng gte 81 and $leftarm is 0>>
A groove in the side of the gullet constricts around your left arm, trapping it.<<set $leftarm to "trapped">><<neutral 10>>
<<elseif $rng gte 61 and $rightarm is 0>>
A groove in the side of the gullet constricts around your right arm, trapping it.<<set $rightarm to "trapped">><<neutral 10>>
<<elseif $rng gte 41>>
The gullet tightens around your entire body, holding you in place.<<neutral 10>>
<<elseif $rng gte 21>>
Valves open at the side of the tube and release a warm liquid, coating you in a slimy goo.<<neutral 15>>
<<elseif $rng gte 1>>
The sides of the gullet push against you, sliding you along the tube.<<neutral 15>>
<</if>>
<<elseif $vorestage is 7>>
<<if $rng gte 81 and $rightarm is 0>>
A groove in the side of the chamber constricts around your right arm, trapping it.<<set $rightarm to "trapped">><<neutral 15>>
<<elseif $rng gte 61>>
More liquid squirts out the side of the chamber, covering you in a slimy goo.<<neutral 15>>
<<elseif $rng gte 41 and $leftarm is 0>>
A groove in the side of the chamber constricts around your left arm, trapping it.<<set $leftarm to "trapped">><<neutral 15>>
<<elseif $rng gte 21>>
The walls close in around you, squeezing your body and stealing your breath. <<neutral 15>>
<<elseif $rng gte 1>>
The entire chamber pulsates and rubs against you.<<neutral 20>>
<</if>>
<</if>>
<br><br>
<<set $rng to random(1, 100)>>
<<if $vorestage lte 5>>
<<if $rng gte 75>>
<<set $vorestrength to random(0, 0)>>
<span class="lblue">The $vorecreature seems content to savour your taste, for now.</span>
<<elseif $rng gte 50>>
<<set $vorestrength to random(-5000, 10000)>>
<span class="blue">The $vorecreature salivates in anticipation.</span>
<<elseif $rng gte 25>>
<<set $vorestrength to random(-5000, 20000)>>
<span class="purple">The $vorecreature prepares to suck you in.</span>
<<elseif $rng gte 1>>
<<set $vorestrength to random(1, 20000)>>
<span class="pink">The $vorecreature prepares to gulp you down.</span>
<</if>>
<br><br>
<<else>>
<<if $rng gte 75>>
<<set $vorestrength to random(0, 0)>>
<<elseif $rng gte 50>>
<<set $vorestrength to random(-5000, 10000)>>
<<elseif $rng gte 25>>
<<set $vorestrength to random(-5000, 20000)>>
<<elseif $rng gte 1>>
<<set $vorestrength to random(1, 20000)>>
<</if>>
<</if>>
<<if $voretrait gte 1>>
<<set $vorestrength -= 2500>>
<</if>>
<<if $enemytype isnot "tentacles">>
<<if $panicattacks gte 1 and $panicviolence is 0 and $panicparalysis is 0 and $controlled is 0>>
<<set $rng to random(1, 100)>>
<<if $rng is 100>>
<<set $panicparalysis to 10>>
<</if>>
<</if>>
<<if $panicattacks gte 2 and $panicviolence is 0 and $panicparalysis is 0 and $controlled is 0>>
<<set $rng to random(1, 100)>>
<<if $rng is 100>>
<<set $panicviolence to 3>>
<</if>>
<</if>>
<<if $arousal gte 10000>>
<<orgasmpassage>>
<</if>>
<<set $seconds += 10>>
<<if $seconds gte 60>>
<<set $seconds to 0>>
<<pass 1>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "swallowed">><<nobr>>
<<if $swallowed isnot 1>><<set $swallowed to 1>>
<<set $swallowedstat += 1>>
<</if>>
<</nobr>><</widget>>
:: Widgets Vore Actions [widget]
<<widget "voreactions">><<nobr>>
<<if $images is 1>><<timed 100ms>>
<<combatimg>>
<br>
<</timed>><</if>>
<<if $enemytype isnot "tentacles">>
<<actioncarry>>
<<actioncarrydrop>>
<</if>>
<<if $trance lte 0>>
<<if $dissociation lte 1>>
<<if $panicparalysis is 0>>
<<if $panicviolence is 0>>
<<if $orgasmdown lte 0>>
<<if $pain lt 100>>
<<if $leftarm is "bound">>
Your left arm is bound and helpless.
<br><br>
<<elseif $leftarm is "trapped">>
<span class="purple">Your left arm is trapped by the $vorecreature.</span>
<br><br>
<<elseif $leftarm is 0>>Your left arm is free.<br>
<<if $leftactiondefault is "leftescape">>
<label><span class="brat">Escape</span> <<radiobutton "$leftaction" "leftescape" checked>></label> |
<<else>>
<label><span class="brat">Escape</span> <<radiobutton "$leftaction" "leftescape">></label> |
<</if>>
<<if $vorestage lte 6>>
<<if $leftactiondefault is "lefthold">>
<label><span class="brat">Hold on</span> <<radiobutton "$leftaction" "lefthold" checked>></label> |
<<else>>
<label><span class="brat">Hold on</span> <<radiobutton "$leftaction" "lefthold">></label> |
<</if>>
<</if>>
<<if $rightarm is "trapped">>
<label><span class="brat">Free your right arm</span> <<radiobutton "$leftaction" "leftvorefree">></label> |
<</if>>
<<if $leftactiondefault is "vorerest">>
<label>Rest <<radiobutton "$leftaction" "vorerest" checked>></label> |
<<else>>
<label>Rest <<radiobutton "$leftaction" "vorerest">></label> |
<</if>>
<br><br>
<</if>>
<<if $rightarm is "bound">>
Your right arm is bound and helpless.
<br><br>
<<elseif $rightarm is "trapped">>
<span class="purple">Your right arm is trapped by the $vorecreature.</span>
<br><br>
<<elseif $rightarm is 0>>Your right arm is free.<br>
<<if $rightactiondefault is "rightescape">>
<label><span class="brat">Escape</span> <<radiobutton "$rightaction" "rightescape" checked>></label> |
<<else>>
<label><span class="brat">Escape</span> <<radiobutton "$rightaction" "rightescape">></label> |
<</if>>
<<if $vorestage lte 6>>
<<if $rightactiondefault is "righthold">>
<label><span class="brat">Hold on</span> <<radiobutton "$rightaction" "righthold" checked>></label> |
<<else>>
<label><span class="brat">Hold on</span> <<radiobutton "$rightaction" "righthold">></label> |
<</if>>
<</if>>
<<if $leftarm is "trapped">>
<label><span class="brat">Free your left arm</span> <<radiobutton "$rightaction" "rightvorefree">></label> |
<</if>>
<<if $rightactiondefault is "vorerest">>
<label>Rest <<radiobutton "$rightaction" "vorerest" checked>></label> |
<<else>>
<label>Rest <<radiobutton "$rightaction" "vorerest">></label> |
<</if>>
<br><br>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<if $enemytype isnot "tentacles">>
<<combatstate>>
<<carryblock>>
<</if>>
<br>
<</nobr>><</widget>>
:: Widgets Vore Effects [widget]
<<widget "voreeffects">><<nobr>>
<<set $rng to random(1, 100)>>
<<effectspain>>
<<effectsorgasm>>
<<effectsdissociation>>
<<if $leftaction is "leftescape" and $rightaction is "rightescape">><<set $leftaction to 0>><<set $rightaction to 0>><<set $leftactiondefault to "leftescape">><<set $rightactiondefault to "rightescape">><<set $attackstat += 2>><<set $leftactiondefault to "leftescape">><<set $rightactiondefault to "rightescape">>
<<if $rng gte 40>>
<<if $leftarm is "trapped">><<set $leftarm to 0>><</if>><<if $rightarm is "trapped">><<set $rightarm to 0>><</if>>
<<if $vorestage is 1>><<set $vorestage -= 1>>
You hit the $vorecreature's maw with both arms, <span class="green">and make it spit you out.</span>
<<elseif $vorestage is 2>><<set $vorestage -= 1>>
You hit the $vorecreature's mouth with both arms. <span class="green">It gags, letting you slide your body out, freeing your <<genitals>> from its maw.</span>
<<elseif $vorestage is 3>><<set $vorestage -= 1>>
You hit the $vorecreature's mouth with both arms. <span class="green">It gags, letting you slide your body out, freeing your <<breasts>> from its maw.</span>
<<elseif $vorestage is 4>><<set $vorestage -= 1>>
You hit the inside of the $vorecreature's mouth with both arms. <span class="green">It gags, letting you slide your body out, freeing your arms from its maw.</span>
<<elseif $vorestage is 5>><<set $vorestage -= 1>>
You hit the inside of the $vorecreature's mouth with both arms. <span class="green">It gags, letting you slide your head back out.</span>
<<elseif $vorestage is 6>><<set $vorestage -= 1>>
You hit the walls of the $vorecreature's gullet with both arms. <span class="green">It convulses, violently pushing you up into its mouth.</span>
<<elseif $vorestage is 7>><<set $vorestage -= 1>>
You pound the walls of the $vorecreature's stomach with both arms. <span class="green">It convulses, violently pushing you up into its gullet.</span>
<</if>>
<<else>>
<<if $vorestage is 1>>
You hit the $vorecreature's maw with both arms, <span class="red">but it doesn't react.</span>
<<elseif $vorestage is 2>>
You hit the $vorecreature's mouth with both arms, <span class="red">but it doesn't react.</span>
<<elseif $vorestage is 3>>
You hit the $vorecreature's mouth with both arms, <span class="red">but it doesn't react.</span>
<<elseif $vorestage is 4>>
You hit the inside of the $vorecreature's mouth with both arms, <span class="red">but it doesn't react.</span>
<<elseif $vorestage is 5>>
You hit the inside of the $vorecreature's mouth with both arms, <span class="red">but it doesn't react.</span>
<<elseif $vorestage is 6>>
You hit the walls of the $vorecreature's gullet with both arms, <span class="red">but it doesn't react.</span>
<<elseif $vorestage is 7>>
You pound the walls of the $vorecreature's stomach with both arms, <span class="red">but it doesn't react.</span>
<</if>>
<</if>>
<<elseif $leftaction is "leftescape">><<set $leftaction to 0>><<set $leftactiondefault to "leftescape">><<set $attackstat += 1>><<set $leftactiondefault to "leftescape">>
<<if $rng gte 20>>
<<if $leftarm is "trapped">><<set $leftarm to 0>><</if>><<if $rightarm is "trapped">><<set $rightarm to 0>><</if>>
<<if $vorestage is 1>><<set $vorestage -= 1>>
You hit the $vorecreature's maw with your left arm, <span class="green">and make it spit you out.</span>
<<elseif $vorestage is 2>><<set $vorestage -= 1>>
You hit the $vorecreature's mouth with your left arm. <span class="green">It gags, letting you slide your body out, freeing your <<genitals>> from its maw.</span>
<<elseif $vorestage is 3>><<set $vorestage -= 1>>
You hit the $vorecreature's mouth with your left arm. <span class="green">It gags, letting you slide your body out, freeing your <<breasts>> from its maw.</span>
<<elseif $vorestage is 4>><<set $vorestage -= 1>>
You hit the inside of the $vorecreature's mouth with your left arm. <span class="green">It gags, letting you slide your body out, freeing your arms from its maw.</span>
<<elseif $vorestage is 5>><<set $vorestage -= 1>>
You hit the inside of the $vorecreature's mouth with your left arm. <span class="green">It gags, letting you slide your head back out.</span>
<<elseif $vorestage is 6>><<set $vorestage -= 1>>
You hit the walls of the $vorecreature's gullet with your left arm. <span class="green">It convulses, violently pushing you up into its mouth.</span>
<<elseif $vorestage is 7>><<set $vorestage -= 1>>
You pound the walls of the $vorecreature's stomach with your left arm. <span class="green">It convulses, violently pushing you up into its gullet.</span>
<</if>>
<<else>>
<<if $vorestage is 1>>
You hit the $vorecreature's maw with your left arm, <span class="red">but it doesn't react.</span>
<<elseif $vorestage is 2>>
You hit the $vorecreature's mouth with your left arm, <span class="red">but it doesn't react.</span>
<<elseif $vorestage is 3>>
You hit the $vorecreature's mouth with your left arm, <span class="red">but it doesn't react.</span>
<<elseif $vorestage is 4>>
You hit the inside of the $vorecreature's mouth with your left arm, <span class="red">but it doesn't react.</span>
<<elseif $vorestage is 5>>
You hit the inside of the $vorecreature's mouth with your left arm, <span class="red">but it doesn't react.</span>
<<elseif $vorestage is 6>>
You hit the walls of the $vorecreature's gullet with your left arm, <span class="red">but it doesn't react.</span>
<<elseif $vorestage is 7>>
You pound the walls of the $vorecreature's stomach with your left arm, <span class="red">but it doesn't react.</span>
<</if>>
<</if>>
<<elseif $rightaction is "rightescape">><<set $rightaction to 0>><<set $rightactiondefault to "rightescape">><<set $attackstat += 1>><<set $rightactiondefault to "rightescape">>
<<if $rng gte 20>>
<<if $leftarm is "trapped">><<set $leftarm to 0>><</if>><<if $rightarm is "trapped">><<set $rightarm to 0>><</if>>
<<if $vorestage is 1>><<set $vorestage -= 1>>
You hit the $vorecreature's maw with your right arm, <span class="green">and make it spit you out.</span>
<<elseif $vorestage is 2>><<set $vorestage -= 1>>
You hit the $vorecreature's mouth with your right arm. <span class="green">It gags, letting you slide your body out, freeing your <<genitals>> from its maw.</span>
<<elseif $vorestage is 3>><<set $vorestage -= 1>>
You hit the $vorecreature's mouth with your right arm. <span class="green">It gags, letting you slide your body out, freeing your <<breasts>> from its maw.</span>
<<elseif $vorestage is 4>><<set $vorestage -= 1>>
You hit the inside of the $vorecreature's mouth with your right arm. <span class="green">It gags, letting you slide your body out, freeing your arms from its maw.</span>
<<elseif $vorestage is 5>><<set $vorestage -= 1>>
You hit the inside of the $vorecreature's mouth with your right arm. <span class="green">It gags, letting you slide your head back out.</span>
<<elseif $vorestage is 6>><<set $vorestage -= 1>>
You hit the walls of the $vorecreature's gullet with your right arm. <span class="green">It convulses, violently pushing you up into its mouth.</span>
<<elseif $vorestage is 7>><<set $vorestage -= 1>>
You pound the walls of the $vorecreature's stomach with your right arm. <span class="green">It convulses, violently pushing you up into its gullet.</span>
<</if>>
<<else>>
<<if $vorestage is 1>>
You hit the $vorecreature's maw with your right arm, <span class="red">but it doesn't react.</span>
<<elseif $vorestage is 2>>
You hit the $vorecreature's mouth with your right arm, <span class="red">but it doesn't react.</span>
<<elseif $vorestage is 3>>
You hit the $vorecreature's mouth with your right arm, <span class="red">but it doesn't react.</span>
<<elseif $vorestage is 4>>
You hit the inside of the $vorecreature's mouth with your right arm, <span class="red">but it doesn't react.</span>
<<elseif $vorestage is 5>>
You hit the inside of the $vorecreature's mouth with your right arm, <span class="red">but it doesn't react.</span>
<<elseif $vorestage is 6>>
You hit the walls of the $vorecreature's gullet with your right arm, <span class="red">but it doesn't react.</span>
<<elseif $vorestage is 7>>
You pound the walls of the $vorecreature's stomach with your right arm, <span class="red">but it doesn't react.</span>
<</if>>
<</if>>
<</if>>
<<if $leftaction is "lefthold" and $rightaction is "righthold">><<set $leftaction to 0>><<set $rightaction to 0>><<set $leftactiondefault to "lefthold">><<set $rightactiondefault to "righthold">><<set $vorestruggle to 2>>
<<if $vorestage is 1>>
You grab hold of the $vorecreature's maw with both arms.
<<elseif $vorestage is 2>>
You grab hold of the $vorecreature's maw with both arms.
<<elseif $vorestage is 3>>
You grab hold of the $vorecreature's maw with both arms.
<<elseif $vorestage is 4>>
You cling to the side of the $vorecreature's mouth with both arms.
<<elseif $vorestage is 5>>
You cling to the side of the $vorecreature's mouth with both arms.
<<elseif $vorestage is 6>>
You cling to the side of the $vorecreature's gullet with both arms.
<</if>>
<<elseif $leftaction is "lefthold">><<set $leftaction to 0>><<set $leftactiondefault to "lefthold">><<set $vorestruggle to 1>>
<<if $vorestage is 1>>
You grab hold of the $vorecreature's maw with your left arm.
<<elseif $vorestage is 2>>
You grab hold of the $vorecreature's maw with your left arm.
<<elseif $vorestage is 3>>
You grab hold of the $vorecreature's maw with your left arm.
<<elseif $vorestage is 4>>
You cling to the side of the $vorecreature's mouth with your left arm.
<<elseif $vorestage is 5>>
You cling to the side of the $vorecreature's mouth with your left arm.
<<elseif $vorestage is 6>>
You cling to the side of the $vorecreature's gullet with your left arm.
<</if>>
<<elseif $rightaction is "righthold">><<set $rightaction to 0>><<set $rightactiondefault to "righthold">><<set $vorestruggle to 1>>
<<if $vorestage is 1>>
You grab hold of the $vorecreature's maw with your right arm.
<<elseif $vorestage is 2>>
You grab hold of the $vorecreature's maw with your right arm.
<<elseif $vorestage is 3>>
You grab hold of the $vorecreature's maw with your right arm.
<<elseif $vorestage is 4>>
You cling to the side of the $vorecreature's mouth with your right arm.
<<elseif $vorestage is 5>>
You cling to the side of the $vorecreature's mouth with your right arm.
<<elseif $vorestage is 6>>
You cling to the side of the $vorecreature's gullet with your right arm.
<</if>>
<</if>>
<<if $leftaction is "leftvorefree">><<set $leftaction to 0>>
<<set $rightarm to 0>><span class="lblue">Using all your strength, you manage to free your right arm from the side of the gullet.</span>
<</if>>
<<if $rightaction is "rightvorefree">><<set $rightaction to 0>>
<<set $leftarm to 0>><span class="lblue">Using all your strength, you manage to free your left arm from the side of the gullet.</span>
<</if>>
<<if $leftaction is "vorerest">><<set $leftaction to 0>><<set $leftactiondefault to "vorerest">>
<</if>>
<<if $rightaction is "vorerest">><<set $rightaction to 0>><<set $rightactiondefault to "vorerest">>
<</if>>
<br><br>
<</nobr>><</widget>>
:: Widgets Vore Img [widget]
<<widget "voreimg">><<nobr>>
<<if $vorestage is 1>>
<img id="foreground" src="img/sex/doggy/vorethighsfront.gif">
<img id="voreback" src="img/sex/doggy/vorethighsback.gif">
<<elseif $vorestage is 2>>
<img id="foreground" src="img/sex/doggy/vorewaistfront.gif">
<img id="voreback" src="img/sex/doggy/vorewaistback.gif">
<<elseif $vorestage is 3>>
<img id="foreground" src="img/sex/doggy/vorechestfront.gif">
<img id="voreback" src="img/sex/doggy/vorechestback.gif">
<<elseif $vorestage is 4>>
<img id="foreground" src="img/sex/doggy/voreshouldersfront.gif">
<img id="voreback" src="img/sex/doggy/voreshouldersback.gif">
<<elseif $vorestage is 5>>
<img id="foreground" src="img/sex/doggy/vorefullfront.gif">
<img id="voreback" src="img/sex/doggy/vorefullback.gif">
<<elseif $vorestage is 6>>
<img id="foreground" src="img/sex/doggy/voregulletfront.gif">
<img id="voreback" src="img/sex/doggy/voregulletback.gif">
<<elseif $vorestage is 7>>
<img id="foreground" src="img/sex/doggy/vorestomachfront.gif">
<img id="voreback" src="img/sex/doggy/vorestomachback.gif">
<</if>>
<</nobr>><</widget>>
:: Widgets Beast Clothing [widget]
<<widget "beastclothing">><<nobr>>
<<set $rng to random(1, 100)>>
<<if $mouth is "lowerclothes">>
<<if $beaststance is "top">>
<<set $mouth to 0>>
<<else>>
<<if $lowerclothes is "naked">><span class="purple"><<He>> spits out the ruined fabric.</span><<set $mouth to 0>>
<<elseif $lowerstruggle is 1>><<set $lowerstruggle to 0>><<He>> tugs at your $lowerclothes, but you keep <<him>> from stripping you.<<set $lowerstruggle to 0>><<neutral 1>><<set $lowerintegrity -= 5>>
<<elseif $rng gte 91>><span class="blue"><<He>> releases your $lowerclothes from <<his>> mouth.</span><<set $mouth to 0>>
<<elseif $rng lte 90>>
<<if $upperset is $lowerset>>
<<if $open is 1>>
<<if $upperstatetop is "chest">><<He>> tugs your $lowerclothes, pulling down your $upperclothes and <span class="lewd">revealing your <<breastsstop>></span><<set $upperstatetop to "midriff">><<set $upperexposed to 2>><<neutral 3>><<set $speechbreasts to 1>>
<<if $upperstate is "chest">>
<<set $upperstate to "midriff">>
<</if>>
<<if $lowerstate is "chest">>
<<set $lowerstate to "midriff">>
<</if>>
<<elseif $upperstatetop is "midriff">><<He>> tugs your $lowerclothes, pulling down your $upperclothes passed your midriff.<<set $upperstatetop to "waist">><<neutral 1>>
<<if $upperstate is "midriff">>
<<set $upperstate to "waist">>
<</if>>
<<if $lowerstate is "midriff">>
<<set $lowerstate to "waist">>
<</if>>
<<elseif $upperstatetop is "waist">><<He>> pulls your $upperclothes down to your thighs, revealing your
<<if $understate is "waist">>$underclothes<<neutral 2>>
<<else>><span class="lewd"><<genitalsstop>></span><<neutral 5>><<set $speechgenitals to 1>>
<</if>>
<<set $upperstatetop to "thighs">><<set $upperstate to "thighs">><<set $lowervaginaexposed to 1>><<set $loweranusexposed to 1>><<set $lowerexposed to 2>>
<<if $lowerstate is "waist">>
<<set $lowerstate to "thighs">>
<</if>>
<<elseif $upperstatetop is "thighs">><<He>> pulls your $upperclothes down to your knees.<<set $upperstatetop to "knees">><<set $upperstate to "knees">><<neutral 1>>
<<if $lowerstate is "thighs">>
<<set $lowerstate to "knees">>
<</if>>
<<elseif $upperstatetop is "knees">><<He>> pulls your $upperclothes down to your ankles.<<set $upperstatetop to "ankles">><<set $upperstate to "ankles">><<neutral 1>>
<<if $lowerstate is "knees">>
<<set $lowerstate to "ankles">>
<</if>>
<<elseif $upperstatetop is "ankles">><span class="purple"><<He>> pulls your $upperclothes off the bottom of your legs.</span><<upperstrip>><<neutral 5>><<set $upperstatetop to 0>><<set $upperstate to 0>><<uppernaked>>
<<if $lowerstate is "ankles">>
<<set $lowerstate to 0>><<lowerstrip>><<lowernaked>>
<</if>>
<</if>>
<<else>>
<<He>> tugs on your $lowerclothes. You hear a tearing sound.<<set $lowerintegrity -= 20>><<neutral 1>>
<</if>>
<<elseif $upperset isnot $lowerset>>
<<if $lowerstate is "waist">><<He>> pulls down your $lowerclothes, exposing your
<<if $understate is "waist">>$underclothes.<<neutral 2>><<set $lowervaginaexposed to 1>><<set $loweranusexposed to 1>>
<<else>><span class="lewd"><<genitalsstop>></span><<neutral 5>><<set $speechgenitals to 1>>
<</if>>
<<set $lowerstate to "thighs">><<set $lowervaginaexposed to 1>><<set $loweranusexposed to 1>><<set $lowerexposed to 2>>
<<elseif $lowerstate is "thighs">><<He>> pulls your $lowerclothes down to your knees.<<set $lowerstate to "knees">><<neutral 1>>
<<elseif $lowerstate is "knees">><<He>> pulls your $lowerclothes down to your ankles.<<set $lowerstate to "ankles">><<neutral 1>>
<<elseif $lowerstate is "ankles">><span class="purple"><<He>> pulls your $lowerclothes off your legs.</span><<lowerstrip>><<lowernaked>><<set $mouth to 0>><<neutral 3>><<clothesstripstat>>
<</if>>
<<else>><<He>> tugs on your $lowerclothes, you hear the fabric tear.<<neutral 1>><<set $lowerintegrity -= 20>>
<</if>>
<</if>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $mouth is "underclothes">>
<<if $underclothes is "naked">><span class="purple"><<He>> spits out the ruined fabric.</span><<set $mouth to 0>>
<<elseif $understruggle is 1>><<He>> tugs on your $underclothes, but you keep <<him>> from stripping you.<<set $understruggle to 0>><<set $speechstripstruggle to 1>><<neutral 1>><<set $underintegrity -= 5>>
<<elseif $rng gte 91>><span class="blue"><<He>> releases your $underclothes from <<his>> mouth.</span><<set $mouth to 0>>
<<elseif $rng lte 90>>
<<if $skirt is 1>>
<<if $understate is "waist">><<He>> pulls your $underclothes down your thighs, <span class="lewd">revealing your <<genitalsstop>></span><<set $understate to "thighs">><<neutral 5>><<set $undervaginaexposed to 1>><<set $underanusexposed to 1>><<set $underexposed to 1>><<set $speechgenitals to 1>>
<<elseif $understate is "thighs">><<He>> pulls your $underclothes down to your knees.<<set $understate to "knees">><<neutral 1>>
<<elseif $understate is "knees">><<He>> pulls your $underclothes down to your ankles.<<set $understate to "ankles">><<neutral 1>>
<<elseif $understate is "ankles">><span class="purple"><<He>> pulls your $underclothes off your legs.</span><<understrip>><<undernaked>><<neutral 3>><<set $mouth to 0>><<clothesstripstat>>
<</if>>
<<elseif $lowerstate isnot "waist">>
<<if $understate is "waist">><<He>> pulls your $underclothes down your thighs, <span class="lewd">revealing your <<genitalsstop>></span><<set $understate to "thighs">><<neutral 5>><<set $undervaginaexposed to 1>><<set $underanusexposed to 1>><<set $underexposed to 1>><<set $speechgenitals to 1>>
<<elseif $understate is "thighs">><<He>> pulls your $underclothes down to your knees.<<set $understate to "knees">><<neutral 1>>
<<elseif $understate is "knees">><<He>> pulls your $underclothes down to your ankles.<<set $understate to "ankles">><<neutral 5>>
<<elseif $understate is "ankles">><span class="purple"><<He>> pulls your $underclothes off your legs.</span><<understrip>><<undernaked>><<neutral 3>><<set $mouth to 0>><<clothesstripstat>>
<</if>>
<<else>><<He>> tears your $underclothes between <<his>> teeth.<<neutral 1>><<set $underintegrity -= 10>>
<</if>>
<</if>>
<</if>>
<</nobr>><</widget>>
:: Widgets Actions Speak [widget]
<<widget "speak">><<nobr>>
<<if $underwater lte 0>>
<<if $consensual is 1>>
<<if $gamemode is "soft" and $trueconsensual isnot 1>>
<<else>>
<<if $mouthactiondefault is "finish">>
| <label><span class="brat">Tell <<him>> you want to stop</span> <<radiobutton "$mouthaction" "finish" checked>><<seductiondifficulty>></label>
<<else>>
| <label><span class="brat">Tell <<him>> you want to stop</span> <<radiobutton "$mouthaction" "finish">><<seductiondifficulty>></label>
<</if>>
<</if>>
<<if $enemytype is "man">>
<<if $vaginaexist is 1 and $vaginalchastity is 0 and $novaginal is 0>>
| <label><span class="brat">Tell <<him>> you don't want anything in your pussy</span> <<radiobutton "$mouthaction" "novaginal">><<seductiondifficulty>></label>
<</if>>
<<if $penisexist is 1 and $penilechastity is 0 and $nopenile is 0>>
| <label><span class="brat">Tell <<him>> you don't want your penis put inside anything</span> <<radiobutton "$mouthaction" "nopenile">><<seductiondifficulty>></label>
<</if>>
<<if $analchastity is 0 and $noanal is 0>>
| <label><span class="brat">Tell <<him>> you don't want anything in your anus</span> <<radiobutton "$mouthaction" "noanal">><<seductiondifficulty>></label>
<</if>>
<</if>>
<<else>>
<<if $mouthactiondefault is "scream">>
| <label><span class="brat">Scream</span> <<radiobutton "$mouthaction" "scream" checked>></label>
<<else>>
| <label><span class="brat">Scream</span> <<radiobutton "$mouthaction" "scream">></label>
<</if>>
<</if>>
<<if $consensual is 0>>
<<if $mouthactiondefault is "plead">>
| <label><span class="meek">Plead</span> <<radiobutton "$mouthaction" "plead" checked>></label>
<<else>>
| <label><span class="meek">Plead</span> <<radiobutton "$mouthaction" "plead">></label>
<</if>>
<</if>>
<<if $consensual is 0 and $angel gte 6 and $angelforgive isnot 1>>
<<if $mouthactiondefault is "forgive">>
| <label><span class="meek">Forgive</span> <<radiobutton "$mouthaction" "forgive" checked>></label>
<<else>>
| <label><span class="meek">Forgive</span> <<radiobutton "$mouthaction" "forgive">></label>
<</if>>
<</if>>
<<if $submissive gte 1150>>
<<if $mouthactiondefault is "moan">>
| <label><span class="sub">Moan</span> <<radiobutton "$mouthaction" "moan" checked>></label>
<<else>>
| <label><span class="sub">Moan</span> <<radiobutton "$mouthaction" "moan">></label>
<</if>>
<<elseif $submissive lte 850 and $consensual is 0>>
<<if $mouthactiondefault is "demand">>
| <label><span class="def">Demand</span> <<radiobutton "$mouthaction" "demand" checked>></label>
<<else>>
| <label><span class="def">Demand</span> <<radiobutton "$mouthaction" "demand">></label>
<</if>>
<</if>>
<<if $awarelevel gte 2 and $enemytype is "man">>
<<if $mouthactiondefault is "mock">>
| <label><span class="brat"><<if $consensual is 1>>Tease their<<else>>Mock their<</if>></span> <<radiobutton "$mouthaction" "mock" checked>></label>
<<else>>
| <label><span class="brat"><<if $consensual is 1>>Tease their<<else>>Mock their<</if>></span> <<radiobutton "$mouthaction" "mock">></label>
<</if>>
<<listbox "$mockaction">>
<<option "ethics" "ethics" `$mockaction is "ethics" ? "selected" : ""`>>
<<option "looks" "looks" `$mockaction is "looks" ? "selected" : ""`>>
<<option "strength" "weak" `$mockaction is "weak" ? "selected" : ""`>>
<<option "skill" "skill" `$mockaction is "skill" ? "selected" : ""`>>
<<option "penis" "penis" `$mockaction is "penis" ? "selected" : ""`>>
<<option "pussy" "vagina" `$mockaction is "vagina" ? "selected" : ""`>>
<</listbox>>
<</if>>
<</if>>
<<if $mouthactiondefault is "rest">>
| <label>Rest <<radiobutton "$mouthaction" "rest" checked>></label>
<<else>>
| <label>Rest <<radiobutton "$mouthaction" "rest">></label>
<</if>>
<</nobr>><</widget>>
:: Widgets End Speech [widget]
<<widget "manend">><<nobr>>
<<set $speechpenispenetrated to 0>>
<<set $speechvaginapenetrated to 0>>
<<set $speechanuspenetrated to 0>>
<<set $speechmouthpenetrated to 0>>
<<set $speechotheranus to 0>>
<<set $speechvaginaimminent to 0>>
<<set $speechpenisimminent to 0>>
<<set $speechanusimminent to 0>>
<<set $speechmouthimminent to 0>>
<<set $speechotheranusimminent to 0>>
<<set $speechvaginaentrance to 0>>
<<set $speechanusentrance to 0>>
<<set $speechmouthentrance to 0>>
<<set $speechpenisentrance to 0>>
<<set $speechotheranusentrance to 0>>
<<set $speechvaginawithhold to 0>>
<<set $speechanuswithhold to 0>>
<<set $speechpeniswithhold to 0>>
<<set $speechotheranuswithhold to 0>>
<<set $speechvagina to 0>>
<<set $speechpenis to 0>>
<<set $speechanus to 0>>
<<set $speechvaginamouth to 0>>
<<set $speechvaginavagina to 0>>
<<set $speechbeat to 0>>
<<set $speechhit to 0>>
<<set $speechthroat to 0>>
<<set $speechvaginafoot to 0>>
<<set $speechpenisfoot to 0>>
<<set $speechchastity to 0>>
<<set $speechstruggle to 0>>
<<set $speechstripstruggle to 0>>
<<set $speechspank to 0>>
<<set $speecharms to 0>>
<<set $speechclit to 0>>
<<set $speechglans to 0>>
<<set $speechbottom to 0>>
<<set $speechhair to 0>>
<<set $speechchestrub to 0>>
<<set $speechbreastrub to 0>>
<<set $speechvaginaflaunt to 0>>
<<set $speechvaginavirgin to 0>>
<<set $speechanusvirgin to 0>>
<<set $speechmouthvirgin to 0>>
<<set $speechpenisvirgin to 0>>
<<set $speechpenisescape to 0>>
<<set $speechvaginaescape to 0>>
<<set $speechanusescape to 0>>
<</nobr>><</widget>>
<<widget "turnend">><<nobr>>
<<set $speechcum to 0>>
<<set $speechorgasmrepeat to 0>>
<<set $speechgenitals to 0>>
<<set $speechbreasts to 0>>
<<set $speechscream to 0>>
<<set $speechapologise to 0>>
<<set $speechplead to 0>>
<<set $speechmoan to 0>>
<<set $speechdemand to 0>>
<<set $speechcoverface to 0>>
<<set $speechcoverpenis to 0>>
<<set $speechcovervagina to 0>>
<<set $speechapologiseno to 0>>
<<set $speechforgive to 0>>
<<set $speechanusescape1 to 0>>
<<set $speechanusescape2 to 0>>
<<set $speechanusescape3 to 0>>
<<set $speechanusescape4 to 0>>
<<set $speechanusescape5 to 0>>
<<set $speechanusescape6 to 0>>
<<set $speechvaginaescape1 to 0>>
<<set $speechvaginaescape2 to 0>>
<<set $speechvaginaescape3 to 0>>
<<set $speechvaginaescape4 to 0>>
<<set $speechvaginaescape5 to 0>>
<<set $speechvaginaescape6 to 0>>
<<set $speechpenisescape1 to 0>>
<<set $speechpenisescape2 to 0>>
<<set $speechpenisescape3 to 0>>
<<set $speechpenisescape4 to 0>>
<<set $speechpenisescape5 to 0>>
<<set $speechpenisescape6 to 0>>
<<if $speechcrossdressangry is 2>>
<<set $speechcrossdressangry to 1>>
<<elseif $speechcrossdressangry is 1>>
<<set $speechcrossdressangry to 0>>
<</if>>
<<if $speechcrossdressaroused is 2>>
<<set $speechcrossdressaroused to 1>>
<<elseif $speechcrossdressaroused is 1>>
<<set $speechcrossdressaroused to 0>>
<</if>>
<<if $speechcrossdressshock is 2>>
<<set $speechcrossdressshock to 1>>
<<elseif $speechcrossdressshock is 1>>
<<set $speechcrossdressshock to 0>>
<</if>>
<<if $speechcrossdressdisappointed is 2>>
<<set $speechcrossdressdisappointed to 1>>
<<elseif $speechcrossdressdisappointed is 1>>
<<set $speechcrossdressdisappointed to 0>>
<</if>>
<</nobr>><</widget>>
<<widget "man1speech">><<nobr>>
<<if $speechpenisescape1 is 1>>
<<set $speechpenisescape to 1>>
<</if>>
<<if $speechvaginaescape1 is 1>>
<<set $speechvaginaescape to 1>>
<</if>>
<<if $speechanusescape1 is 1>>
<<set $speechanusescape to 1>>
<</if>>
<</nobr>><</widget>>
<<widget "man2speech">><<nobr>>
<<if $speechpenisescape2 is 1>>
<<set $speechpenisescape to 1>>
<</if>>
<<if $speechvaginaescape2 is 1>>
<<set $speechvaginaescape to 1>>
<</if>>
<<if $speechanusescape2 is 1>>
<<set $speechanusescape to 1>>
<</if>>
<</nobr>><</widget>>
<<widget "man3speech">><<nobr>>
<<if $speechpenisescape3 is 1>>
<<set $speechpenisescape to 1>>
<</if>>
<<if $speechvaginaescape3 is 1>>
<<set $speechvaginaescape to 1>>
<</if>>
<<if $speechanusescape3 is 1>>
<<set $speechanusescape to 1>>
<</if>>
<</nobr>><</widget>>
<<widget "man4speech">><<nobr>>
<<if $speechpenisescape4 is 1>>
<<set $speechpenisescape to 1>>
<</if>>
<<if $speechvaginaescape4 is 1>>
<<set $speechvaginaescape to 1>>
<</if>>
<<if $speechanusescape4 is 1>>
<<set $speechanusescape to 1>>
<</if>>
<</nobr>><</widget>>
<<widget "man5speech">><<nobr>>
<<if $speechpenisescape5 is 1>>
<<set $speechpenisescape to 1>>
<</if>>
<<if $speechvaginaescape5 is 1>>
<<set $speechvaginaescape to 1>>
<</if>>
<<if $speechanusescape5 is 1>>
<<set $speechanusescape to 1>>
<</if>>
<</nobr>><</widget>>
<<widget "man6speech">><<nobr>>
<<if $speechpenisescape6 is 1>>
<<set $speechpenisescape to 1>>
<</if>>
<<if $speechvaginaescape6 is 1>>
<<set $speechvaginaescape to 1>>
<</if>>
<<if $speechanusescape6 is 1>>
<<set $speechanusescape to 1>>
<</if>>
<</nobr>><</widget>>
:: Widgets Tentacles [widget]
<<widget "tentaclestart">><<nobr>>
<<set $enemyarousalmax to 10000>>
<<if $tentacleno gte 1>>
<<set $tentacle1 to "slimy">>
<<set $tentacle1health to $tentaclehealth>>
<</if>>
<<if $tentacleno gte 2>>
<<set $tentacle2 to "sticky">>
<<set $tentacle2health to $tentaclehealth>>
<</if>>
<<if $tentacleno gte 3>>
<<set $tentacle3 to "thick">>
<<set $tentacle3health to $tentaclehealth>>
<</if>>
<<if $tentacleno gte 4>>
<<set $tentacle4 to "throbbing">>
<<set $tentacle4health to $tentaclehealth>>
<</if>>
<<if $tentacleno gte 5>>
<<set $tentacle5 to "slick">>
<<set $tentacle5health to $tentaclehealth>>
<</if>>
<<if $tentacleno gte 6>>
<<set $tentacle6 to "moist">>
<<set $tentacle6health to $tentaclehealth>>
<</if>>
<<if $tentacleno gte 7>>
<<set $tentacle7 to "quivering">>
<<set $tentacle7health to $tentaclehealth>>
<</if>>
<<if $tentacleno gte 8>>
<<set $tentacle8 to "sodden">>
<<set $tentacle8health to $tentaclehealth>>
<</if>>
<<if $tentacleno gte 9>>
<<set $tentacle9 to "shivering">>
<<set $tentacle9health to $tentaclehealth>>
<</if>>
<<if $tentacleno gte 10>>
<<set $tentacle10 to "shuddering">>
<<set $tentacle10health to $tentaclehealth>>
<</if>>
<<if $tentacleno gte 11>>
<<set $tentacle11 to "convulsing">>
<<set $tentacle11health to $tentaclehealth>>
<</if>>
<<if $tentacleno gte 12>>
<<set $tentacle12 to "undulating">>
<<set $tentacle12health to $tentaclehealth>>
<</if>>
<<if $tentacleno gte 13>>
<<set $tentacle13 to "damp">>
<<set $tentacle13health to $tentaclehealth>>
<</if>>
<<if $tentacleno gte 14>>
<<set $tentacle14 to "bulbous">>
<<set $tentacle14health to $tentaclehealth>>
<</if>>
<<if $tentacleno gte 15>>
<<set $tentacle15 to "gyrating">>
<<set $tentacle15health to $tentaclehealth>>
<</if>>
<<if $tentacleno gte 16>>
<<set $tentacle16 to "large">>
<<set $tentacle16health to $tentaclehealth>>
<</if>>
<</nobr>><</widget>>
<<widget "tentacles">><<nobr>>
<<if $tentacleno gte 1>>
<<tentacle1>><br>
<</if>>
<<if $tentacleno gte 2>>
<<tentacle2>><br>
<</if>>
<<if $tentacleno gte 3>>
<<tentacle3>><br>
<</if>>
<<if $tentacleno gte 4>>
<<tentacle4>><br>
<</if>>
<<if $tentacleno gte 5>>
<<tentacle5>><br>
<</if>>
<<if $tentacleno gte 6>>
<<tentacle6>><br>
<</if>>
<<if $tentacleno gte 7>>
<<tentacle7>><br>
<</if>>
<<if $tentacleno gte 8>>
<<tentacle8>><br>
<</if>>
<<if $tentacleno gte 9>>
<<tentacle9>><br>
<</if>>
<<if $tentacleno gte 10>>
<<tentacle10>><br>
<</if>>
<<if $tentacleno gte 11>>
<<tentacle11>><br>
<</if>>
<<if $tentacleno gte 12>>
<<tentacle12>><br>
<</if>>
<<if $tentacleno gte 13>>
<<tentacle13>><br>
<</if>>
<<if $tentacleno gte 14>>
<<tentacle14>><br>
<</if>>
<<if $tentacleno gte 15>>
<<tentacle15>><br>
<</if>>
<<if $tentacleno gte 16>>
<<tentacle16>><br>
<</if>>
<<set $tentacle1health -= 0.2>>
<<set $tentacle2health -= 0.2>>
<<set $tentacle3health -= 0.2>>
<<set $tentacle4health -= 0.2>>
<<set $tentacle5health -= 0.2>>
<<set $tentacle6health -= 0.2>>
<<set $tentacle7health -= 0.2>>
<<set $tentacle8health -= 0.2>>
<<set $tentacle9health -= 0.2>>
<<set $tentacle10health -= 0.2>>
<<set $tentacle11health -= 0.2>>
<<set $tentacle12health -= 0.2>>
<<set $tentacle13health -= 0.2>>
<<set $tentacle14health -= 0.2>>
<<set $tentacle15health -= 0.2>>
<<set $tentacle16health -= 0.2>>
<<if $panicattacks gte 1 and $panicviolence is 0 and $panicparalysis is 0 and $controlled is 0>>
<<set $rng to random(1, 100)>>
<<if $rng is 100>>
<<set $panicparalysis to 10>>
<</if>>
<</if>>
<<if $panicattacks gte 2 and $panicviolence is 0 and $panicparalysis is 0 and $controlled is 0>>
<<set $rng to random(1, 100)>>
<<if $rng is 100>>
<<set $panicviolence to 3>>
<</if>>
<</if>>
<<if $arousal gte 10000>>
<<orgasmpassage>>
<</if>>
<<set $seconds += 10>>
<<if $seconds gte 60>>
<<set $seconds to 0>>
<<pass 1>>
<</if>>
<br>
<</nobr>><</widget>>
<<widget "effectstentacles">><<nobr>>
<<effectspain>>
<<effectsorgasm>>
<<effectsdissociation>>
<<if $tentacleno gte 1>>
<<effectstentacle1>>
<</if>>
<<if $tentacleno gte 2>>
<<effectstentacle2>>
<</if>>
<<if $tentacleno gte 3>>
<<effectstentacle3>>
<</if>>
<<if $tentacleno gte 4>>
<<effectstentacle4>>
<</if>>
<<if $tentacleno gte 5>>
<<effectstentacle5>>
<</if>>
<<if $tentacleno gte 6>>
<<effectstentacle6>>
<</if>>
<<if $tentacleno gte 7>>
<<effectstentacle7>>
<</if>>
<<if $tentacleno gte 8>>
<<effectstentacle8>>
<</if>>
<<if $tentacleno gte 9>>
<<effectstentacle9>>
<</if>>
<<if $tentacleno gte 10>>
<<effectstentacle10>>
<</if>>
<<if $tentacleno gte 11>>
<<effectstentacle11>>
<</if>>
<<if $tentacleno gte 12>>
<<effectstentacle12>>
<</if>>
<<if $tentacleno gte 13>>
<<effectstentacle13>>
<</if>>
<<if $tentacleno gte 14>>
<<effectstentacle14>>
<</if>>
<<if $tentacleno gte 15>>
<<effectstentacle15>>
<</if>>
<<if $tentacleno gte 16>>
<<effectstentacle16>>
<</if>>
<br><br>
<</nobr>><</widget>>
<<widget "actionstentacles">><<nobr>>
<<set $enemyarousal to $arousal>>
<<if $vorecreature is 0 and $swarmcount lte 0>>
<<if $images is 1>><<timed 100ms>>
<<combatimg>>
<br>
<</timed>><</if>>
<</if>>
<<actioncarry>>
<<actioncarrydrop>>
<<if $trance lte 0>>
<<if $dissociation lte 1>>
<<if $panicparalysis is 0>>
<<if $panicviolence is 0>>
<<if $orgasmdown lte 0>>
<<if $pain lt 100>>
<<if $leftarm is 0>>Your left arm is free.<br><</if>>
<<actionstentacleslefthand>>
<<if $rightarm is 0>>Your right arm is free.<br><</if>>
<<actionstentaclesrighthand>>
<<if $leftleg is 0 and $rightleg is 0>>
Your legs are free.<br>
<<elseif $leftleg is 0>>
Your left leg is free.<br>
<<elseif $rightleg is 0>>
Your right leg is free.<br>
<<elseif $leftleg is "grappled" and $rightleg is "grappled">>
Your legs are entangled and forced apart, leaving you less able to protect your <<genitalsstop>><br>
<</if>>
<<actionstentacleslegs>>
<<if $mouthstate is "tentacleentrance">>
The
<<if $tentacle1head is "mouthentrance">>
$tentacle1
<</if>>
<<if $tentacle2head is "mouthentrance">>
$tentacle2
<</if>>
<<if $tentacle3head is "mouthentrance">>
$tentacle3
<</if>>
<<if $tentacle4head is "mouthentrance">>
$tentacle4
<</if>>
<<if $tentacle5head is "mouthentrance">>
$tentacle5
<</if>>
<<if $tentacle6head is "mouthentrance">>
$tentacle6
<</if>>
<<if $tentacle7head is "mouthentrance">>
$tentacle7
<</if>>
<<if $tentacle8head is "mouthentrance">>
$tentacle8
<</if>>
<<if $tentacle9head is "mouthentrance">>
$tentacle9
<</if>>
<<if $tentacle10head is "mouthentrance">>
$tentacle10
<</if>>
<<if $tentacle11head is "mouthentrance">>
$tentacle11
<</if>>
<<if $tentacle12head is "mouthentrance">>
$tentacle12
<</if>>
<<if $tentacle13head is "mouthentrance">>
$tentacle13
<</if>>
<<if $tentacle14head is "mouthentrance">>
$tentacle14
<</if>>
<<if $tentacle15head is "mouthentrance">>
$tentacle15
<</if>>
<<if $tentacle16head is "mouthentrance">>
$tentacle16
<</if>>
tentacle threatens your mouth.
<br>
<</if>>
<<if $mouthstate is "tentacleimminent">>
The
<<if $tentacle1head is "mouthimminent">>
$tentacle1
<</if>>
<<if $tentacle2head is "mouthimminent">>
$tentacle2
<</if>>
<<if $tentacle3head is "mouthimminent">>
$tentacle3
<</if>>
<<if $tentacle4head is "mouthimminent">>
$tentacle4
<</if>>
<<if $tentacle5head is "mouthimminent">>
$tentacle5
<</if>>
<<if $tentacle6head is "mouthimminent">>
$tentacle6
<</if>>
<<if $tentacle7head is "mouthimminent">>
$tentacle7
<</if>>
<<if $tentacle8head is "mouthimminent">>
$tentacle8
<</if>>
<<if $tentacle9head is "mouthimminent">>
$tentacle9
<</if>>
<<if $tentacle10head is "mouthimminent">>
$tentacle10
<</if>>
<<if $tentacle11head is "mouthimminent">>
$tentacle11
<</if>>
<<if $tentacle12head is "mouthimminent">>
$tentacle12
<</if>>
<<if $tentacle13head is "mouthimminent">>
$tentacle13
<</if>>
<<if $tentacle14head is "mouthimminent">>
$tentacle14
<</if>>
<<if $tentacle15head is "mouthimminent">>
$tentacle15
<</if>>
<<if $tentacle16head is "mouthimminent">>
$tentacle16
<</if>>
tentacle presses against your mouth.
<br>
<</if>>
<<if $mouthstate is "tentacle">>
The
<<if $tentacle1head is "mouth">>
$tentacle1
<</if>>
<<if $tentacle2head is "mouth">>
$tentacle2
<</if>>
<<if $tentacle3head is "mouth">>
$tentacle3
<</if>>
<<if $tentacle4head is "mouth">>
$tentacle4
<</if>>
<<if $tentacle5head is "mouth">>
$tentacle5
<</if>>
<<if $tentacle6head is "mouth">>
$tentacle6
<</if>>
<<if $tentacle7head is "mouth">>
$tentacle7
<</if>>
<<if $tentacle8head is "mouth">>
$tentacle8
<</if>>
<<if $tentacle9head is "mouth">>
$tentacle9
<</if>>
<<if $tentacle10head is "mouth">>
$tentacle10
<</if>>
<<if $tentacle11head is "mouth">>
$tentacle11
<</if>>
<<if $tentacle12head is "mouth">>
$tentacle12
<</if>>
<<if $tentacle13head is "mouth">>
$tentacle13
<</if>>
<<if $tentacle14head is "mouth">>
$tentacle14
<</if>>
<<if $tentacle15head is "mouth">>
$tentacle15
<</if>>
<<if $tentacle16head is "mouth">>
$tentacle16
<</if>>
tentacle thrusts into your mouth.
<br>
<</if>>
<<if $mouthstate is "tentacledeep">>
The
<<if $tentacle1head is "mouthdeep">>
$tentacle1
<</if>>
<<if $tentacle2head is "mouthdeep">>
$tentacle2
<</if>>
<<if $tentacle3head is "mouthdeep">>
$tentacle3
<</if>>
<<if $tentacle4head is "mouthdeep">>
$tentacle4
<</if>>
<<if $tentacle5head is "mouthdeep">>
$tentacle5
<</if>>
<<if $tentacle6head is "mouthdeep">>
$tentacle6
<</if>>
<<if $tentacle7head is "mouthdeep">>
$tentacle7
<</if>>
<<if $tentacle8head is "mouthdeep">>
$tentacle8
<</if>>
<<if $tentacle9head is "mouthdeep">>
$tentacle9
<</if>>
<<if $tentacle10head is "mouthdeep">>
$tentacle10
<</if>>
<<if $tentacle11head is "mouthdeep">>
$tentacle11
<</if>>
<<if $tentacle12head is "mouthdeep">>
$tentacle12
<</if>>
<<if $tentacle13head is "mouthdeep">>
$tentacle13
<</if>>
<<if $tentacle14head is "mouthdeep">>
$tentacle14
<</if>>
<<if $tentacle15head is "mouthdeep">>
$tentacle15
<</if>>
<<if $tentacle16head is "mouthdeep">>
$tentacle16
<</if>>
tentacle thrusts into your mouth, ejaculating down your throat.
<br>
<</if>>
<<actionstentaclesmouth>>
<<if $vaginastate is "tentacleentrance">>
The
<<if $tentacle1head is "vaginaentrance">>
$tentacle1
<</if>>
<<if $tentacle2head is "vaginaentrance">>
$tentacle2
<</if>>
<<if $tentacle3head is "vaginaentrance">>
$tentacle3
<</if>>
<<if $tentacle4head is "vaginaentrance">>
$tentacle4
<</if>>
<<if $tentacle5head is "vaginaentrance">>
$tentacle5
<</if>>
<<if $tentacle6head is "vaginaentrance">>
$tentacle6
<</if>>
<<if $tentacle7head is "vaginaentrance">>
$tentacle7
<</if>>
<<if $tentacle8head is "vaginaentrance">>
$tentacle8
<</if>>
<<if $tentacle9head is "vaginaentrance">>
$tentacle9
<</if>>
<<if $tentacle10head is "vaginaentrance">>
$tentacle10
<</if>>
<<if $tentacle11head is "vaginaentrance">>
$tentacle11
<</if>>
<<if $tentacle12head is "vaginaentrance">>
$tentacle12
<</if>>
<<if $tentacle13head is "vaginaentrance">>
$tentacle13
<</if>>
<<if $tentacle14head is "vaginaentrance">>
$tentacle14
<</if>>
<<if $tentacle15head is "vaginaentrance">>
$tentacle15
<</if>>
<<if $tentacle16head is "vaginaentrance">>
$tentacle16
<</if>>
tentacle threatens your <<pussystop>>
<br>
<</if>>
<<if $vaginastate is "tentacleimminent">>
The
<<if $tentacle1head is "vaginaimminent">>
$tentacle1
<</if>>
<<if $tentacle2head is "vaginaimminent">>
$tentacle2
<</if>>
<<if $tentacle3head is "vaginaimminent">>
$tentacle3
<</if>>
<<if $tentacle4head is "vaginaimminent">>
$tentacle4
<</if>>
<<if $tentacle5head is "vaginaimminent">>
$tentacle5
<</if>>
<<if $tentacle6head is "vaginaimminent">>
$tentacle6
<</if>>
<<if $tentacle7head is "vaginaimminent">>
$tentacle7
<</if>>
<<if $tentacle8head is "vaginaimminent">>
$tentacle8
<</if>>
<<if $tentacle9head is "vaginaimminent">>
$tentacle9
<</if>>
<<if $tentacle10head is "vaginaimminent">>
$tentacle10
<</if>>
<<if $tentacle11head is "vaginaimminent">>
$tentacle11
<</if>>
<<if $tentacle12head is "vaginaimminent">>
$tentacle12
<</if>>
<<if $tentacle13head is "vaginaimminent">>
$tentacle13
<</if>>
<<if $tentacle14head is "vaginaimminent">>
$tentacle14
<</if>>
<<if $tentacle15head is "vaginaimminent">>
$tentacle15
<</if>>
<<if $tentacle16head is "vaginaimminent">>
$tentacle16
<</if>>
tentacle presses against your <<pussycomma>> about to penetrate.
<br>
<</if>>
<<if $vaginastate is "tentacle">>
The
<<if $tentacle1head is "vagina">>
$tentacle1
<</if>>
<<if $tentacle2head is "vagina">>
$tentacle2
<</if>>
<<if $tentacle3head is "vagina">>
$tentacle3
<</if>>
<<if $tentacle4head is "vagina">>
$tentacle4
<</if>>
<<if $tentacle5head is "vagina">>
$tentacle5
<</if>>
<<if $tentacle6head is "vagina">>
$tentacle6
<</if>>
<<if $tentacle7head is "vagina">>
$tentacle7
<</if>>
<<if $tentacle8head is "vagina">>
$tentacle8
<</if>>
<<if $tentacle9head is "vagina">>
$tentacle9
<</if>>
<<if $tentacle10head is "vagina">>
$tentacle10
<</if>>
<<if $tentacle11head is "vagina">>
$tentacle11
<</if>>
<<if $tentacle12head is "vagina">>
$tentacle12
<</if>>
<<if $tentacle13head is "vagina">>
$tentacle13
<</if>>
<<if $tentacle14head is "vagina">>
$tentacle14
<</if>>
<<if $tentacle15head is "vagina">>
$tentacle15
<</if>>
<<if $tentacle16head is "vagina">>
$tentacle16
<</if>>
tentacle thrusts into your <<pussystop>>
<br>
<</if>>
<<if $vaginastate is "tentacledeep">>
The
<<if $tentacle1head is "vaginadeep">>
$tentacle1
<</if>>
<<if $tentacle2head is "vaginadeep">>
$tentacle2
<</if>>
<<if $tentacle3head is "vaginadeep">>
$tentacle3
<</if>>
<<if $tentacle4head is "vaginadeep">>
$tentacle4
<</if>>
<<if $tentacle5head is "vaginadeep">>
$tentacle5
<</if>>
<<if $tentacle6head is "vaginadeep">>
$tentacle6
<</if>>
<<if $tentacle7head is "vaginadeep">>
$tentacle7
<</if>>
<<if $tentacle8head is "vaginadeep">>
$tentacle8
<</if>>
<<if $tentacle9head is "vaginadeep">>
$tentacle9
<</if>>
<<if $tentacle10head is "vaginadeep">>
$tentacle10
<</if>>
<<if $tentacle11head is "vaginadeep">>
$tentacle11
<</if>>
<<if $tentacle12head is "vaginadeep">>
$tentacle12
<</if>>
<<if $tentacle13head is "vaginadeep">>
$tentacle13
<</if>>
<<if $tentacle14head is "vaginadeep">>
$tentacle14
<</if>>
<<if $tentacle15head is "vaginadeep">>
$tentacle15
<</if>>
<<if $tentacle16head is "vaginadeep">>
$tentacle16
<</if>>
tentacle thrusts into your <<pussycomma>> ejaculating deep into your womb.
<br>
<</if>>
<<actionstentaclesvagina>>
<<if $penisstate is "tentacleentrance">>
The
<<if $tentacle1head is "penisentrance">>
$tentacle1
<</if>>
<<if $tentacle2head is "penisentrance">>
$tentacle2
<</if>>
<<if $tentacle3head is "penisentrance">>
$tentacle3
<</if>>
<<if $tentacle4head is "penisentrance">>
$tentacle4
<</if>>
<<if $tentacle5head is "penisentrance">>
$tentacle5
<</if>>
<<if $tentacle6head is "penisentrance">>
$tentacle6
<</if>>
<<if $tentacle7head is "penisentrance">>
$tentacle7
<</if>>
<<if $tentacle8head is "penisentrance">>
$tentacle8
<</if>>
<<if $tentacle9head is "penisentrance">>
$tentacle9
<</if>>
<<if $tentacle10head is "penisentrance">>
$tentacle10
<</if>>
<<if $tentacle11head is "penisentrance">>
$tentacle11
<</if>>
<<if $tentacle12head is "penisentrance">>
$tentacle12
<</if>>
<<if $tentacle13head is "penisentrance">>
$tentacle13
<</if>>
<<if $tentacle14head is "penisentrance">>
$tentacle14
<</if>>
<<if $tentacle15head is "penisentrance">>
$tentacle15
<</if>>
<<if $tentacle16head is "penisentrance">>
$tentacle16
<</if>>
tentacle threatens your <<penisstop>>
<br>
<</if>>
<<if $penisstate is "tentacleimminent">>
The
<<if $tentacle1head is "penisimminent">>
$tentacle1
<</if>>
<<if $tentacle2head is "penisimminent">>
$tentacle2
<</if>>
<<if $tentacle3head is "penisimminent">>
$tentacle3
<</if>>
<<if $tentacle4head is "penisimminent">>
$tentacle4
<</if>>
<<if $tentacle5head is "penisimminent">>
$tentacle5
<</if>>
<<if $tentacle6head is "penisimminent">>
$tentacle6
<</if>>
<<if $tentacle7head is "penisimminent">>
$tentacle7
<</if>>
<<if $tentacle8head is "penisimminent">>
$tentacle8
<</if>>
<<if $tentacle9head is "penisimminent">>
$tentacle9
<</if>>
<<if $tentacle10head is "penisimminent">>
$tentacle10
<</if>>
<<if $tentacle11head is "penisimminent">>
$tentacle11
<</if>>
<<if $tentacle12head is "penisimminent">>
$tentacle12
<</if>>
<<if $tentacle13head is "penisimminent">>
$tentacle13
<</if>>
<<if $tentacle14head is "penisimminent">>
$tentacle14
<</if>>
<<if $tentacle15head is "penisimminent">>
$tentacle15
<</if>>
<<if $tentacle16head is "penisimminent">>
$tentacle16
<</if>>
tentacle presses against your <<peniscomma>> about to engulf.
<br>
<</if>>
<<if $penisstate is "tentacle">>
The
<<if $tentacle1head is "penis">>
$tentacle1
<</if>>
<<if $tentacle2head is "penis">>
$tentacle2
<</if>>
<<if $tentacle3head is "penis">>
$tentacle3
<</if>>
<<if $tentacle4head is "penis">>
$tentacle4
<</if>>
<<if $tentacle5head is "penis">>
$tentacle5
<</if>>
<<if $tentacle6head is "penis">>
$tentacle6
<</if>>
<<if $tentacle7head is "penis">>
$tentacle7
<</if>>
<<if $tentacle8head is "penis">>
$tentacle8
<</if>>
<<if $tentacle9head is "penis">>
$tentacle9
<</if>>
<<if $tentacle10head is "penis">>
$tentacle10
<</if>>
<<if $tentacle11head is "penis">>
$tentacle11
<</if>>
<<if $tentacle12head is "penis">>
$tentacle12
<</if>>
<<if $tentacle13head is "penis">>
$tentacle13
<</if>>
<<if $tentacle14head is "penis">>
$tentacle14
<</if>>
<<if $tentacle15head is "penis">>
$tentacle15
<</if>>
<<if $tentacle16head is "penis">>
$tentacle16
<</if>>
tentacle envelops and pounds your <<penisstop>>
<br>
<</if>>
<<if $penisstate is "tentacledeep">>
The
<<if $tentacle1head is "penisdeep">>
$tentacle1
<</if>>
<<if $tentacle2head is "penisdeep">>
$tentacle2
<</if>>
<<if $tentacle3head is "penisdeep">>
$tentacle3
<</if>>
<<if $tentacle4head is "penisdeep">>
$tentacle4
<</if>>
<<if $tentacle5head is "penisdeep">>
$tentacle5
<</if>>
<<if $tentacle6head is "penisdeep">>
$tentacle6
<</if>>
<<if $tentacle7head is "penisdeep">>
$tentacle7
<</if>>
<<if $tentacle8head is "penisdeep">>
$tentacle8
<</if>>
<<if $tentacle9head is "penisdeep">>
$tentacle9
<</if>>
<<if $tentacle10head is "penisdeep">>
$tentacle10
<</if>>
<<if $tentacle11head is "penisdeep">>
$tentacle11
<</if>>
<<if $tentacle12head is "penisdeep">>
$tentacle12
<</if>>
<<if $tentacle13head is "penisdeep">>
$tentacle13
<</if>>
<<if $tentacle14head is "penisdeep">>
$tentacle14
<</if>>
<<if $tentacle15head is "penisdeep">>
$tentacle15
<</if>>
<<if $tentacle16head is "penisdeep">>
$tentacle16
<</if>>
tentacle envelops and pounds your <<penisstop>>
<br>
<</if>>
<<actionstentaclespenis>>
<<if $anusstate is "tentacleentrance">>
The
<<if $tentacle1head is "anusentrance">>
$tentacle1
<</if>>
<<if $tentacle2head is "anusentrance">>
$tentacle2
<</if>>
<<if $tentacle3head is "anusentrance">>
$tentacle3
<</if>>
<<if $tentacle4head is "anusentrance">>
$tentacle4
<</if>>
<<if $tentacle5head is "anusentrance">>
$tentacle5
<</if>>
<<if $tentacle6head is "anusentrance">>
$tentacle6
<</if>>
<<if $tentacle7head is "anusentrance">>
$tentacle7
<</if>>
<<if $tentacle8head is "anusentrance">>
$tentacle8
<</if>>
<<if $tentacle9head is "anusentrance">>
$tentacle9
<</if>>
<<if $tentacle10head is "anusentrance">>
$tentacle10
<</if>>
<<if $tentacle11head is "anusentrance">>
$tentacle11
<</if>>
<<if $tentacle12head is "anusentrance">>
$tentacle12
<</if>>
<<if $tentacle13head is "anusentrance">>
$tentacle13
<</if>>
<<if $tentacle14head is "anusentrance">>
$tentacle14
<</if>>
<<if $tentacle15head is "anusentrance">>
$tentacle15
<</if>>
<<if $tentacle16head is "anusentrance">>
$tentacle16
<</if>>
tentacle threatens your <<bottomstop>>
<br>
<</if>>
<<if $anusstate is "tentacleimminent">>
The
<<if $tentacle1head is "anusimminent">>
$tentacle1
<</if>>
<<if $tentacle2head is "anusimminent">>
$tentacle2
<</if>>
<<if $tentacle3head is "anusimminent">>
$tentacle3
<</if>>
<<if $tentacle4head is "anusimminent">>
$tentacle4
<</if>>
<<if $tentacle5head is "anusimminent">>
$tentacle5
<</if>>
<<if $tentacle6head is "anusimminent">>
$tentacle6
<</if>>
<<if $tentacle7head is "anusimminent">>
$tentacle7
<</if>>
<<if $tentacle8head is "anusimminent">>
$tentacle8
<</if>>
<<if $tentacle9head is "anusimminent">>
$tentacle9
<</if>>
<<if $tentacle10head is "anusimminent">>
$tentacle10
<</if>>
<<if $tentacle11head is "anusimminent">>
$tentacle11
<</if>>
<<if $tentacle12head is "anusimminent">>
$tentacle12
<</if>>
<<if $tentacle13head is "anusimminent">>
$tentacle13
<</if>>
<<if $tentacle14head is "anusimminent">>
$tentacle14
<</if>>
<<if $tentacle15head is "anusimminent">>
$tentacle15
<</if>>
<<if $tentacle16head is "anusimminent">>
$tentacle16
<</if>>
tentacle presses against your <<bottomcomma>> about to penetrate.
<br>
<</if>>
<<if $anusstate is "tentacle">>
The
<<if $tentacle1head is "anus">>
$tentacle1
<</if>>
<<if $tentacle2head is "anus">>
$tentacle2
<</if>>
<<if $tentacle3head is "anus">>
$tentacle3
<</if>>
<<if $tentacle4head is "anus">>
$tentacle4
<</if>>
<<if $tentacle5head is "anus">>
$tentacle5
<</if>>
<<if $tentacle6head is "anus">>
$tentacle6
<</if>>
<<if $tentacle7head is "anus">>
$tentacle7
<</if>>
<<if $tentacle8head is "anus">>
$tentacle8
<</if>>
<<if $tentacle9head is "anus">>
$tentacle9
<</if>>
<<if $tentacle10head is "anus">>
$tentacle10
<</if>>
<<if $tentacle11head is "anus">>
$tentacle11
<</if>>
<<if $tentacle12head is "anus">>
$tentacle12
<</if>>
<<if $tentacle13head is "anus">>
$tentacle13
<</if>>
<<if $tentacle14head is "anus">>
$tentacle14
<</if>>
<<if $tentacle15head is "anus">>
$tentacle15
<</if>>
<<if $tentacle16head is "anus">>
$tentacle16
<</if>>
tentacle thrusts into your <<bottomstop>>
<br>
<</if>>
<<if $anusstate is "tentacledeep">>
The
<<if $tentacle1head is "anusdeep">>
$tentacle1
<</if>>
<<if $tentacle2head is "anusdeep">>
$tentacle2
<</if>>
<<if $tentacle3head is "anusdeep">>
$tentacle3
<</if>>
<<if $tentacle4head is "anusdeep">>
$tentacle4
<</if>>
<<if $tentacle5head is "anusdeep">>
$tentacle5
<</if>>
<<if $tentacle6head is "anusdeep">>
$tentacle6
<</if>>
<<if $tentacle7head is "anusdeep">>
$tentacle7
<</if>>
<<if $tentacle8head is "anusdeep">>
$tentacle8
<</if>>
<<if $tentacle9head is "anusdeep">>
$tentacle9
<</if>>
<<if $tentacle10head is "anusdeep">>
$tentacle10
<</if>>
<<if $tentacle11head is "anusdeep">>
$tentacle11
<</if>>
<<if $tentacle12head is "anusdeep">>
$tentacle12
<</if>>
<<if $tentacle13head is "anusdeep">>
$tentacle13
<</if>>
<<if $tentacle14head is "anusdeep">>
$tentacle14
<</if>>
<<if $tentacle15head is "anusdeep">>
$tentacle15
<</if>>
<<if $tentacle16head is "anusdeep">>
$tentacle16
<</if>>
tentacle thrusts into your <<bottomcomma>> ejaculating deep into your bowels.
<br>
<</if>>
<<actionstentaclesanus>>
<<if $penisuse is "tentaclerub">>
The
<<if $tentacle1head is "penisrub">>
$tentacle1
<</if>>
<<if $tentacle2head is "penisrub">>
$tentacle2
<</if>>
<<if $tentacle3head is "penisrub">>
$tentacle3
<</if>>
<<if $tentacle4head is "penisrub">>
$tentacle4
<</if>>
<<if $tentacle5head is "penisrub">>
$tentacle5
<</if>>
<<if $tentacle6head is "penisrub">>
$tentacle6
<</if>>
<<if $tentacle7head is "penisrub">>
$tentacle7
<</if>>
<<if $tentacle8head is "penisrub">>
$tentacle8
<</if>>
<<if $tentacle9head is "penisrub">>
$tentacle9
<</if>>
<<if $tentacle10head is "penisrub">>
$tentacle10
<</if>>
<<if $tentacle11head is "penisrub">>
$tentacle11
<</if>>
<<if $tentacle12head is "penisrub">>
$tentacle12
<</if>>
<<if $tentacle13head is "penisrub">>
$tentacle13
<</if>>
<<if $tentacle14head is "penisrub">>
$tentacle14
<</if>>
<<if $tentacle15head is "penisrub">>
$tentacle15
<</if>>
<<if $tentacle16head is "penisrub">>
$tentacle16
<</if>>
tentacle runs between your thighs, coiling around your <<penis>> and pressing against your tummy.
<br>
<</if>>
<<if $vaginause is "tentaclerub">>
The
<<if $tentacle1head is "vaginarub">>
$tentacle1
<</if>>
<<if $tentacle2head is "vaginarub">>
$tentacle2
<</if>>
<<if $tentacle3head is "vaginarub">>
$tentacle3
<</if>>
<<if $tentacle4head is "vaginarub">>
$tentacle4
<</if>>
<<if $tentacle5head is "vaginarub">>
$tentacle5
<</if>>
<<if $tentacle6head is "vaginarub">>
$tentacle6
<</if>>
<<if $tentacle7head is "vaginarub">>
$tentacle7
<</if>>
<<if $tentacle8head is "vaginarub">>
$tentacle8
<</if>>
<<if $tentacle9head is "vaginarub">>
$tentacle9
<</if>>
<<if $tentacle10head is "vaginarub">>
$tentacle10
<</if>>
<<if $tentacle11head is "vaginarub">>
$tentacle11
<</if>>
<<if $tentacle12head is "vaginarub">>
$tentacle12
<</if>>
<<if $tentacle13head is "vaginarub">>
$tentacle13
<</if>>
<<if $tentacle14head is "vaginarub">>
$tentacle14
<</if>>
<<if $tentacle15head is "vaginarub">>
$tentacle15
<</if>>
<<if $tentacle16head is "vaginarub">>
$tentacle16
<</if>>
tentacle runs between your thighs, pressing against your labia and continuing to your tummy.
<br>
<</if>>
<<actionstentaclesthighs>>
<<if $bottomuse is "tentaclerub">>
The
<<if $tentacle1head is "bottomrub">>
$tentacle1
<</if>>
<<if $tentacle2head is "bottomrub">>
$tentacle2
<</if>>
<<if $tentacle3head is "bottomrub">>
$tentacle3
<</if>>
<<if $tentacle4head is "bottomrub">>
$tentacle4
<</if>>
<<if $tentacle5head is "bottomrub">>
$tentacle5
<</if>>
<<if $tentacle6head is "bottomrub">>
$tentacle6
<</if>>
<<if $tentacle7head is "bottomrub">>
$tentacle7
<</if>>
<<if $tentacle8head is "bottomrub">>
$tentacle8
<</if>>
<<if $tentacle9head is "bottomrub">>
$tentacle9
<</if>>
<<if $tentacle10head is "bottomrub">>
$tentacle10
<</if>>
<<if $tentacle11head is "bottomrub">>
$tentacle11
<</if>>
<<if $tentacle12head is "bottomrub">>
$tentacle12
<</if>>
<<if $tentacle13head is "bottomrub">>
$tentacle13
<</if>>
<<if $tentacle14head is "bottomrub">>
$tentacle14
<</if>>
<<if $tentacle15head is "bottomrub">>
$tentacle15
<</if>>
<<if $tentacle16head is "bottomrub">>
$tentacle16
<</if>>
tentacle rubs itself between your butt cheeks.
<br>
<</if>>
<<actionstentaclesbottom>>
<<if $breastuse is "tentacle">>
The
<<if $tentacle1head is "chest">>
$tentacle1
<</if>>
<<if $tentacle2head is "chest">>
$tentacle2
<</if>>
<<if $tentacle3head is "chest">>
$tentacle3
<</if>>
<<if $tentacle4head is "chest">>
$tentacle4
<</if>>
<<if $tentacle5head is "chest">>
$tentacle5
<</if>>
<<if $tentacle6head is "chest">>
$tentacle6
<</if>>
<<if $tentacle7head is "chest">>
$tentacle7
<</if>>
<<if $tentacle8head is "chest">>
$tentacle8
<</if>>
<<if $tentacle9head is "chest">>
$tentacle9
<</if>>
<<if $tentacle10head is "chest">>
$tentacle10
<</if>>
<<if $tentacle11head is "chest">>
$tentacle11
<</if>>
<<if $tentacle12head is "chest">>
$tentacle12
<</if>>
<<if $tentacle13head is "chest">>
$tentacle13
<</if>>
<<if $tentacle14head is "chest">>
$tentacle14
<</if>>
<<if $tentacle15head is "chest">>
$tentacle15
<</if>>
<<if $tentacle16head is "chest">>
$tentacle16
<</if>>
tentacle rubs itself between your <<breastsstop>><br>
<</if>>
<<actionstentacleschest>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<combatstate>>
<<carryblock>>
<br>
<</nobr>><</widget>>
<<widget "actionstentacleschest">><<nobr>>
<<if $tentacleno gte 1>>
<<actionstentacle1chest>>
<</if>>
<<if $tentacleno gte 2>>
<<actionstentacle2chest>>
<</if>>
<<if $tentacleno gte 3>>
<<actionstentacle3chest>>
<</if>>
<<if $tentacleno gte 4>>
<<actionstentacle4chest>>
<</if>>
<<if $tentacleno gte 5>>
<<actionstentacle5chest>>
<</if>>
<<if $tentacleno gte 6>>
<<actionstentacle6chest>>
<</if>>
<<if $tentacleno gte 7>>
<<actionstentacle7chest>>
<</if>>
<<if $tentacleno gte 8>>
<<actionstentacle8chest>>
<</if>>
<<if $tentacleno gte 9>>
<<actionstentacle9chest>>
<</if>>
<<if $tentacleno gte 10>>
<<actionstentacle10chest>>
<</if>>
<<if $tentacleno gte 11>>
<<actionstentacle11chest>>
<</if>>
<<if $tentacleno gte 12>>
<<actionstentacle12chest>>
<</if>>
<<if $tentacleno gte 13>>
<<actionstentacle13chest>>
<</if>>
<<if $tentacleno gte 14>>
<<actionstentacle14chest>>
<</if>>
<<if $tentacleno gte 15>>
<<actionstentacle15chest>>
<</if>>
<<if $tentacleno gte 16>>
<<actionstentacle16chest>>
<</if>>
<br>
<</nobr>><</widget>>
<<widget "actionstentaclesbottom">><<nobr>>
<<if $tentacleno gte 1>>
<<actionstentacle1bottom>>
<</if>>
<<if $tentacleno gte 2>>
<<actionstentacle2bottom>>
<</if>>
<<if $tentacleno gte 3>>
<<actionstentacle3bottom>>
<</if>>
<<if $tentacleno gte 4>>
<<actionstentacle4bottom>>
<</if>>
<<if $tentacleno gte 5>>
<<actionstentacle5bottom>>
<</if>>
<<if $tentacleno gte 6>>
<<actionstentacle6bottom>>
<</if>>
<<if $tentacleno gte 7>>
<<actionstentacle7bottom>>
<</if>>
<<if $tentacleno gte 8>>
<<actionstentacle8bottom>>
<</if>>
<<if $tentacleno gte 9>>
<<actionstentacle9bottom>>
<</if>>
<<if $tentacleno gte 10>>
<<actionstentacle10bottom>>
<</if>>
<<if $tentacleno gte 11>>
<<actionstentacle11bottom>>
<</if>>
<<if $tentacleno gte 12>>
<<actionstentacle12bottom>>
<</if>>
<<if $tentacleno gte 13>>
<<actionstentacle13bottom>>
<</if>>
<<if $tentacleno gte 14>>
<<actionstentacle14bottom>>
<</if>>
<<if $tentacleno gte 15>>
<<actionstentacle15bottom>>
<</if>>
<<if $tentacleno gte 16>>
<<actionstentacle16bottom>>
<</if>>
<br>
<</nobr>><</widget>>
<<widget "actionstentaclesthighs">><<nobr>>
<<if $tentacleno gte 1>>
<<actionstentacle1thighs>>
<</if>>
<<if $tentacleno gte 2>>
<<actionstentacle2thighs>>
<</if>>
<<if $tentacleno gte 3>>
<<actionstentacle3thighs>>
<</if>>
<<if $tentacleno gte 4>>
<<actionstentacle4thighs>>
<</if>>
<<if $tentacleno gte 5>>
<<actionstentacle5thighs>>
<</if>>
<<if $tentacleno gte 6>>
<<actionstentacle6thighs>>
<</if>>
<<if $tentacleno gte 7>>
<<actionstentacle7thighs>>
<</if>>
<<if $tentacleno gte 8>>
<<actionstentacle8thighs>>
<</if>>
<<if $tentacleno gte 9>>
<<actionstentacle9thighs>>
<</if>>
<<if $tentacleno gte 10>>
<<actionstentacle10thighs>>
<</if>>
<<if $tentacleno gte 11>>
<<actionstentacle11thighs>>
<</if>>
<<if $tentacleno gte 12>>
<<actionstentacle12thighs>>
<</if>>
<<if $tentacleno gte 13>>
<<actionstentacle13thighs>>
<</if>>
<<if $tentacleno gte 14>>
<<actionstentacle14thighs>>
<</if>>
<<if $tentacleno gte 15>>
<<actionstentacle15thighs>>
<</if>>
<<if $tentacleno gte 16>>
<<actionstentacle16thighs>>
<</if>>
<br>
<</nobr>><</widget>>
<<widget "actionstentaclesanus">><<nobr>>
<<if $tentacleno gte 1>>
<<actionstentacle1anus>>
<</if>>
<<if $tentacleno gte 2>>
<<actionstentacle2anus>>
<</if>>
<<if $tentacleno gte 3>>
<<actionstentacle3anus>>
<</if>>
<<if $tentacleno gte 4>>
<<actionstentacle4anus>>
<</if>>
<<if $tentacleno gte 5>>
<<actionstentacle5anus>>
<</if>>
<<if $tentacleno gte 6>>
<<actionstentacle6anus>>
<</if>>
<<if $tentacleno gte 7>>
<<actionstentacle7anus>>
<</if>>
<<if $tentacleno gte 8>>
<<actionstentacle8anus>>
<</if>>
<<if $tentacleno gte 9>>
<<actionstentacle9anus>>
<</if>>
<<if $tentacleno gte 10>>
<<actionstentacle10anus>>
<</if>>
<<if $tentacleno gte 11>>
<<actionstentacle11anus>>
<</if>>
<<if $tentacleno gte 12>>
<<actionstentacle12anus>>
<</if>>
<<if $tentacleno gte 13>>
<<actionstentacle13anus>>
<</if>>
<<if $tentacleno gte 14>>
<<actionstentacle14anus>>
<</if>>
<<if $tentacleno gte 15>>
<<actionstentacle15anus>>
<</if>>
<<if $tentacleno gte 16>>
<<actionstentacle16anus>>
<</if>>
<br>
<</nobr>><</widget>>
<<widget "actionstentaclespenis">><<nobr>>
<<if $tentacleno gte 1>>
<<actionstentacle1penis>>
<</if>>
<<if $tentacleno gte 2>>
<<actionstentacle2penis>>
<</if>>
<<if $tentacleno gte 3>>
<<actionstentacle3penis>>
<</if>>
<<if $tentacleno gte 4>>
<<actionstentacle4penis>>
<</if>>
<<if $tentacleno gte 5>>
<<actionstentacle5penis>>
<</if>>
<<if $tentacleno gte 6>>
<<actionstentacle6penis>>
<</if>>
<<if $tentacleno gte 7>>
<<actionstentacle7penis>>
<</if>>
<<if $tentacleno gte 8>>
<<actionstentacle8penis>>
<</if>>
<<if $tentacleno gte 9>>
<<actionstentacle9penis>>
<</if>>
<<if $tentacleno gte 10>>
<<actionstentacle10penis>>
<</if>>
<<if $tentacleno gte 11>>
<<actionstentacle11penis>>
<</if>>
<<if $tentacleno gte 12>>
<<actionstentacle12penis>>
<</if>>
<<if $tentacleno gte 13>>
<<actionstentacle13penis>>
<</if>>
<<if $tentacleno gte 14>>
<<actionstentacle14penis>>
<</if>>
<<if $tentacleno gte 15>>
<<actionstentacle15penis>>
<</if>>
<<if $tentacleno gte 16>>
<<actionstentacle16penis>>
<</if>>
<br>
<</nobr>><</widget>>
<<widget "actionstentaclesvagina">><<nobr>>
<<if $tentacleno gte 1>>
<<actionstentacle1vagina>>
<</if>>
<<if $tentacleno gte 2>>
<<actionstentacle2vagina>>
<</if>>
<<if $tentacleno gte 3>>
<<actionstentacle3vagina>>
<</if>>
<<if $tentacleno gte 4>>
<<actionstentacle4vagina>>
<</if>>
<<if $tentacleno gte 5>>
<<actionstentacle5vagina>>
<</if>>
<<if $tentacleno gte 6>>
<<actionstentacle6vagina>>
<</if>>
<<if $tentacleno gte 7>>
<<actionstentacle7vagina>>
<</if>>
<<if $tentacleno gte 8>>
<<actionstentacle8vagina>>
<</if>>
<<if $tentacleno gte 9>>
<<actionstentacle9vagina>>
<</if>>
<<if $tentacleno gte 10>>
<<actionstentacle10vagina>>
<</if>>
<<if $tentacleno gte 11>>
<<actionstentacle11vagina>>
<</if>>
<<if $tentacleno gte 12>>
<<actionstentacle12vagina>>
<</if>>
<<if $tentacleno gte 13>>
<<actionstentacle13vagina>>
<</if>>
<<if $tentacleno gte 14>>
<<actionstentacle14vagina>>
<</if>>
<<if $tentacleno gte 15>>
<<actionstentacle15vagina>>
<</if>>
<<if $tentacleno gte 16>>
<<actionstentacle16vagina>>
<</if>>
<br>
<</nobr>><</widget>>
<<widget "actionstentaclesmouth">><<nobr>>
<<if $tentacleno gte 1>>
<<actionstentacle1mouth>>
<</if>>
<<if $tentacleno gte 2>>
<<actionstentacle2mouth>>
<</if>>
<<if $tentacleno gte 3>>
<<actionstentacle3mouth>>
<</if>>
<<if $tentacleno gte 4>>
<<actionstentacle4mouth>>
<</if>>
<<if $tentacleno gte 5>>
<<actionstentacle5mouth>>
<</if>>
<<if $tentacleno gte 6>>
<<actionstentacle6mouth>>
<</if>>
<<if $tentacleno gte 7>>
<<actionstentacle7mouth>>
<</if>>
<<if $tentacleno gte 8>>
<<actionstentacle8mouth>>
<</if>>
<<if $tentacleno gte 9>>
<<actionstentacle9mouth>>
<</if>>
<<if $tentacleno gte 10>>
<<actionstentacle10mouth>>
<</if>>
<<if $tentacleno gte 11>>
<<actionstentacle11mouth>>
<</if>>
<<if $tentacleno gte 12>>
<<actionstentacle12mouth>>
<</if>>
<<if $tentacleno gte 13>>
<<actionstentacle13mouth>>
<</if>>
<<if $tentacleno gte 14>>
<<actionstentacle14mouth>>
<</if>>
<<if $tentacleno gte 15>>
<<actionstentacle15mouth>>
<</if>>
<<if $tentacleno gte 16>>
<<actionstentacle16mouth>>
<</if>>
<br>
<</nobr>><</widget>>
<<widget "actionstentacleslegs">><<nobr>>
<<if $tentacleno gte 1>>
<<actionstentacle1legs>><br>
<</if>>
<<if $tentacleno gte 2>>
<<actionstentacle2legs>><br>
<</if>>
<<if $tentacleno gte 3>>
<<actionstentacle3legs>><br>
<</if>>
<<if $tentacleno gte 4>>
<<actionstentacle4legs>><br>
<</if>>
<<if $tentacleno gte 5>>
<<actionstentacle5legs>><br>
<</if>>
<<if $tentacleno gte 6>>
<<actionstentacle6legs>><br>
<</if>>
<<if $tentacleno gte 7>>
<<actionstentacle7legs>><br>
<</if>>
<<if $tentacleno gte 8>>
<<actionstentacle8legs>><br>
<</if>>
<<if $tentacleno gte 9>>
<<actionstentacle9legs>><br>
<</if>>
<<if $tentacleno gte 10>>
<<actionstentacle10legs>><br>
<</if>>
<<if $tentacleno gte 11>>
<<actionstentacle11legs>><br>
<</if>>
<<if $tentacleno gte 12>>
<<actionstentacle12legs>><br>
<</if>>
<<if $tentacleno gte 13>>
<<actionstentacle13legs>><br>
<</if>>
<<if $tentacleno gte 14>>
<<actionstentacle14legs>><br>
<</if>>
<<if $tentacleno gte 15>>
<<actionstentacle15legs>><br>
<</if>>
<<if $tentacleno gte 16>>
<<actionstentacle16legs>><br>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentaclesrighthand">><<nobr>>
<<if $tentacleno gte 1>>
<<actionstentacle1righthand>><br>
<</if>>
<<if $tentacleno gte 2>>
<<actionstentacle2righthand>><br>
<</if>>
<<if $tentacleno gte 3>>
<<actionstentacle3righthand>><br>
<</if>>
<<if $tentacleno gte 4>>
<<actionstentacle4righthand>><br>
<</if>>
<<if $tentacleno gte 5>>
<<actionstentacle5righthand>><br>
<</if>>
<<if $tentacleno gte 6>>
<<actionstentacle6righthand>><br>
<</if>>
<<if $tentacleno gte 7>>
<<actionstentacle7righthand>><br>
<</if>>
<<if $tentacleno gte 8>>
<<actionstentacle8righthand>><br>
<</if>>
<<if $tentacleno gte 9>>
<<actionstentacle9righthand>><br>
<</if>>
<<if $tentacleno gte 10>>
<<actionstentacle10righthand>><br>
<</if>>
<<if $tentacleno gte 11>>
<<actionstentacle11righthand>><br>
<</if>>
<<if $tentacleno gte 12>>
<<actionstentacle12righthand>><br>
<</if>>
<<if $tentacleno gte 13>>
<<actionstentacle13righthand>><br>
<</if>>
<<if $tentacleno gte 14>>
<<actionstentacle14righthand>><br>
<</if>>
<<if $tentacleno gte 15>>
<<actionstentacle15righthand>><br>
<</if>>
<<if $tentacleno gte 16>>
<<actionstentacle16righthand>><br>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacleslefthand">><<nobr>>
<<if $tentacleno gte 1>>
<<actionstentacle1lefthand>><br>
<</if>>
<<if $tentacleno gte 2>>
<<actionstentacle2lefthand>><br>
<</if>>
<<if $tentacleno gte 3>>
<<actionstentacle3lefthand>><br>
<</if>>
<<if $tentacleno gte 4>>
<<actionstentacle4lefthand>><br>
<</if>>
<<if $tentacleno gte 5>>
<<actionstentacle5lefthand>><br>
<</if>>
<<if $tentacleno gte 6>>
<<actionstentacle6lefthand>><br>
<</if>>
<<if $tentacleno gte 7>>
<<actionstentacle7lefthand>><br>
<</if>>
<<if $tentacleno gte 8>>
<<actionstentacle8lefthand>><br>
<</if>>
<<if $tentacleno gte 9>>
<<actionstentacle9lefthand>><br>
<</if>>
<<if $tentacleno gte 10>>
<<actionstentacle10lefthand>><br>
<</if>>
<<if $tentacleno gte 11>>
<<actionstentacle11lefthand>><br>
<</if>>
<<if $tentacleno gte 12>>
<<actionstentacle12lefthand>><br>
<</if>>
<<if $tentacleno gte 13>>
<<actionstentacle13lefthand>><br>
<</if>>
<<if $tentacleno gte 14>>
<<actionstentacle14lefthand>><br>
<</if>>
<<if $tentacleno gte 15>>
<<actionstentacle15lefthand>><br>
<</if>>
<<if $tentacleno gte 16>>
<<actionstentacle16lefthand>><br>
<</if>>
<</nobr>><</widget>>
<<widget "upperslither">><<nobr>>
<<if $upperclothes isnot "naked">>
then <<slithers>> beneath your $upperclothes
<<else>>
then <<slithers>> across your bare skin
<</if>>
<</nobr>><</widget>>
<<widget "lowerslither">><<nobr>>
<<if $lowerclothes isnot "naked">>
then <<slithers>> beneath your $lowerclothes
<<else>>
then <<slithers>> across your bare skin
<</if>>
<</nobr>><</widget>>
<<widget "underslither">><<nobr>>
<<if $lowerclothes isnot "naked">>
<<if $undertype isnot "naked" and $undertype isnot "chastity">>
then <<slithers>> beneath your $lowerclothes and $underclothes
<<elseif $undertype is "chastity">>
then <<slithers>> beneath your $lowerclothes against your chastity belt
<<else>>
<</if>>
<<else>>
<<if $undertype isnot "naked" and $undertype isnot "chastity">>
then <<slithers>> beneath your $underclothes
<<elseif $undertype is "chastity">>
then <<slithers>> against your chastity belt
<<else>>
then <<slithers>> across your bare skin
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "statetentacles">><<nobr>>
<<set $activetentacleno to $tentacleno>>
<<if $tentacleno gte 1>>
<<if $tentacle1shaft is "finished">>
<<set $activetentacleno -= 1>>
<</if>>
<</if>>
<<if $tentacleno gte 2>>
<<if $tentacle2shaft is "finished">>
<<set $activetentacleno -= 1>>
<</if>>
<</if>>
<<if $tentacleno gte 3>>
<<if $tentacle3shaft is "finished">>
<<set $activetentacleno -= 1>>
<</if>>
<</if>>
<<if $tentacleno gte 4>>
<<if $tentacle4shaft is "finished">>
<<set $activetentacleno -= 1>>
<</if>>
<</if>>
<<if $tentacleno gte 5>>
<<if $tentacle5shaft is "finished">>
<<set $activetentacleno -= 1>>
<</if>>
<</if>>
<<if $tentacleno gte 6>>
<<if $tentacle6shaft is "finished">>
<<set $activetentacleno -= 1>>
<</if>>
<</if>>
<<if $tentacleno gte 7>>
<<if $tentacle7shaft is "finished">>
<<set $activetentacleno -= 1>>
<</if>>
<</if>>
<<if $tentacleno gte 8>>
<<if $tentacle8shaft is "finished">>
<<set $activetentacleno -= 1>>
<</if>>
<</if>>
<<if $tentacleno gte 9>>
<<if $tentacle9shaft is "finished">>
<<set $activetentacleno -= 1>>
<</if>>
<</if>>
<<if $tentacleno gte 10>>
<<if $tentacle10shaft is "finished">>
<<set $activetentacleno -= 1>>
<</if>>
<</if>>
<<if $tentacleno gte 11>>
<<if $tentacle11shaft is "finished">>
<<set $activetentacleno -= 1>>
<</if>>
<</if>>
<<if $tentacleno gte 12>>
<<if $tentacle12shaft is "finished">>
<<set $activetentacleno -= 1>>
<</if>>
<</if>>
<<if $tentacleno gte 13>>
<<if $tentacle13shaft is "finished">>
<<set $activetentacleno -= 1>>
<</if>>
<</if>>
<<if $tentacleno gte 14>>
<<if $tentacle14shaft is "finished">>
<<set $activetentacleno -= 1>>
<</if>>
<</if>>
<<if $tentacleno gte 15>>
<<if $tentacle15shaft is "finished">>
<<set $activetentacleno -= 1>>
<</if>>
<</if>>
<<if $tentacleno gte 16>>
<<if $tentacle16shaft is "finished">>
<<set $activetentacleno -= 1>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "leftarmtentacledisable">><<nobr>>
<<if $leftarm is "tentacle1">>
<<set $tentacle1head to 0>>
<</if>>
<<if $leftarm is "tentacle2">>
<<set $tentacle2head to 0>>
<</if>>
<<if $leftarm is "tentacle3">>
<<set $tentacle3head to 0>>
<</if>>
<<if $leftarm is "tentacle4">>
<<set $tentacle4head to 0>>
<</if>>
<<if $leftarm is "tentacle5">>
<<set $tentacle5head to 0>>
<</if>>
<<if $leftarm is "tentacle6">>
<<set $tentacle6head to 0>>
<</if>>
<<if $leftarm is "tentacle7">>
<<set $tentacle7head to 0>>
<</if>>
<<if $leftarm is "tentacle8">>
<<set $tentacle8head to 0>>
<</if>>
<<if $leftarm is "tentacle9">>
<<set $tentacle9head to 0>>
<</if>>
<<if $leftarm is "tentacle10">>
<<set $tentacle10head to 0>>
<</if>>
<<if $leftarm is "tentacle11">>
<<set $tentacle11head to 0>>
<</if>>
<<if $leftarm is "tentacle12">>
<<set $tentacle12head to 0>>
<</if>>
<<if $leftarm is "tentacle13">>
<<set $tentacle13head to 0>>
<</if>>
<<if $leftarm is "tentacle14">>
<<set $tentacle14head to 0>>
<</if>>
<<if $leftarm is "tentacle15">>
<<set $tentacle15head to 0>>
<</if>>
<<if $leftarm is "tentacle16">>
<<set $tentacle16head to 0>>
<</if>>
<</nobr>><</widget>>
<<widget "rightarmtentacledisable">><<nobr>>
<<if $rightarm is "tentacle1">>
<<set $tentacle1head to 0>>
<</if>>
<<if $rightarm is "tentacle2">>
<<set $tentacle2head to 0>>
<</if>>
<<if $rightarm is "tentacle3">>
<<set $tentacle3head to 0>>
<</if>>
<<if $rightarm is "tentacle4">>
<<set $tentacle4head to 0>>
<</if>>
<<if $rightarm is "tentacle5">>
<<set $tentacle5head to 0>>
<</if>>
<<if $rightarm is "tentacle6">>
<<set $tentacle6head to 0>>
<</if>>
<<if $rightarm is "tentacle7">>
<<set $tentacle7head to 0>>
<</if>>
<<if $rightarm is "tentacle8">>
<<set $tentacle8head to 0>>
<</if>>
<<if $rightarm is "tentacle9">>
<<set $tentacle9head to 0>>
<</if>>
<<if $rightarm is "tentacle10">>
<<set $tentacle10head to 0>>
<</if>>
<<if $rightarm is "tentacle11">>
<<set $tentacle11head to 0>>
<</if>>
<<if $rightarm is "tentacle12">>
<<set $tentacle12head to 0>>
<</if>>
<<if $rightarm is "tentacle13">>
<<set $tentacle13head to 0>>
<</if>>
<<if $rightarm is "tentacle14">>
<<set $tentacle14head to 0>>
<</if>>
<<if $rightarm is "tentacle15">>
<<set $tentacle15head to 0>>
<</if>>
<<if $rightarm is "tentacle16">>
<<set $tentacle16head to 0>>
<</if>>
<</nobr>><</widget>>
<<widget "feettentacledisable">><<nobr>>
<<if $feet is "tentacle1">>
<<set $tentacle1head to 0>>
<</if>>
<<if $feet is "tentacle2">>
<<set $tentacle2head to 0>>
<</if>>
<<if $feet is "tentacle3">>
<<set $tentacle3head to 0>>
<</if>>
<<if $feet is "tentacle4">>
<<set $tentacle4head to 0>>
<</if>>
<<if $feet is "tentacle5">>
<<set $tentacle5head to 0>>
<</if>>
<<if $feet is "tentacle6">>
<<set $tentacle6head to 0>>
<</if>>
<<if $feet is "tentacle7">>
<<set $tentacle7head to 0>>
<</if>>
<<if $feet is "tentacle8">>
<<set $tentacle8head to 0>>
<</if>>
<<if $feet is "tentacle9">>
<<set $tentacle9head to 0>>
<</if>>
<<if $feet is "tentacle10">>
<<set $tentacle10head to 0>>
<</if>>
<<if $feet is "tentacle11">>
<<set $tentacle11head to 0>>
<</if>>
<<if $feet is "tentacle12">>
<<set $tentacle12head to 0>>
<</if>>
<<if $feet is "tentacle13">>
<<set $tentacle13head to 0>>
<</if>>
<<if $feet is "tentacle14">>
<<set $tentacle14head to 0>>
<</if>>
<<if $feet is "tentacle15">>
<<set $tentacle15head to 0>>
<</if>>
<<if $feet is "tentacle16">>
<<set $tentacle16head to 0>>
<</if>>
<</nobr>><</widget>>
:: Widgets Combat Tentacle [widget]
<<widget "tentacle1">><<nobr>>
<<if $tentacle1health lte 0 and $tentacle1shaft isnot "finished">>
Worn out, the $tentacle1 tentacle retracts from you.
<<tentacle1disable>>
<<set $tentacle1shaft to "finished">>
<<set $tentacle1head to "finished">>
<</if>>
<<if $tentacle1shaft is "tummy">>
The $tentacle1 tentacle <<slithers>> around your tummy,
<</if>>
<<if $tentacle1shaft is "thighs">>
The $tentacle1 tentacle <<slithers>> between your thighs,
<</if>>
<<if $tentacle1shaft is "breasts">>
The $tentacle1 tentacle squeezes your breasts together,
<</if>>
<<if $tentacle1shaft is "chest">>
The $tentacle1 tentacle <<slithers>> around your chest,
<</if>>
<<if $tentacle1shaft is "waist">>
The $tentacle1 tentacle <<slithers>> around your waist,
<</if>>
<<if $tentacle1shaft is "neck">>
The $tentacle1 tentacle <<slithers>> around your neck,
<</if>>
<<if $tentacle1shaft is "shoulders">>
The $tentacle1 tentacle <<slithers>> around your shoulders,
<</if>>
<<if $tentacle1shaft is "leftleg">>
The $tentacle1 tentacle <<slithers>> around your left leg,
<</if>>
<<if $tentacle1shaft is "rightleg">>
The $tentacle1 tentacle <<slithers>> around your right leg,
<</if>>
<<if $tentacle1shaft is "leftarm">>
The $tentacle1 tentacle <<slithers>> around your left arm,
<</if>>
<<if $tentacle1shaft is "rightarm">>
The $tentacle1 tentacle <<slithers>> around your right arm,
<</if>>
<<if $tentacle1head is "leftarm">>
The $tentacle1 tentacle writhes in your left hand.<<neutral 5>>
<</if>>
<<if $tentacle1head is "rightarm">>
The $tentacle1 tentacle writhes in your right hand.<<neutral 5>>
<</if>>
<<if $tentacle1head is "feet">>
The $tentacle1 tentacle writhes between your feet.<<neutral 5>>
<</if>>
<<if $tentacle1head is "leftnipplesuck">>
and up to your <<breastscomma>> where it suckles your left nipple.<<neutral 3>>
<</if>>
<<if $tentacle1head is "rightnipplesuck">>
and up to your <<breastscomma>> where it suckles your right nipple.<<neutral 3>>
<</if>>
<<if $tentacle1head is "leftnipple">>
and continues teasing your left nipple. <span class="purple">The tip of the tentacle opens up, latches on, then begins sucking.</span><<neutral 3>><<set $tentacle1head to "leftnipplesuck">><<set $leftnipple to "tentaclesuck">>
<</if>>
<<if $tentacle1head is "rightnipple">>
and continues teasing your right nipple. <span class="purple">The tip of the tentacle opens up, latches on, then begins sucking.</span><<neutral 3>><<set $tentacle1head to "rightnipplesuck">><<set $rightnipple to "tentaclesuck">>
<</if>>
<<if $tentacle1head is "chest">>
<<if $chestuse is "squeezed">>
then up between your <<breastscomma>> rubbing itself between them.<<neutral 2>>
<<else>>
moves away from your <<breasts>><<set $tentacle1head to 0>><<set $breastuse to 0>>
<</if>>
<</if>>
<<if $tentacle1head is "mouthdeep">>
and up into your mouth where it spurts a sweet fluid down your throat at the apex of each thrust.<<set $purity -= 1>><<internalejac>><<sex 5>><<set $drugged += 3>><<set $mouthgoo += 1>><<set $tentacle1health -= 1>>
<</if>>
<<if $tentacle1head is "mouth">>
and continues thrusting into your mouth.<span class="pink"> The tip opens and begins oozing a sweet liquid.</span><<set $purity -= 1>><<internalejac>><<set $mouthstate to "tentacledeep">><<set $tentacle1head to "mouthdeep">><<sex 5>><<oralejacstat>><<ejacstat>>
<</if>>
<<if $tentacle1head is "mouthimminent">>
<<if $oralvirginity is 1>>
<span class="pink"> and thrusts between your lips,</span><span class="red"> penetrating your mouth for the first time.</span><<set $oralvirginity to 0>><<violence 5>>
<<else>>
<span class="pink"> and thrusts between your lips.</span>
<</if>>
<<set $mouthstate to "tentacle">><<set $tentacle1head to "mouth">><<sex 5>><<raped>><<oralstat>>
<</if>>
<<if $tentacle1head is "mouthentrance">>
<span class="purple"> and presses against your lips.</span><<set $mouthstate to "tentacleimminent">><<set $tentacle1head to "mouthimminent">><<neutral 4>>
<</if>>
<<if $tentacle1head is "vaginadeep">>
and <<slithers>> into your <<pussy>> where it pumps a viscous fluid at the apex of each thrust.<<set $purity -= 1>><<internalejac>><<sex 5>><<set $drugged += 3>><<set $vaginagoo += 1>><<set $tentacle1health -= 1>>
<</if>>
<<if $tentacle1head is "vagina">>
and continues thrusting into your <<pussystop>><span class="pink"> The tip opens and begins oozing a viscous liquid.</span><<set $purity -= 1>><<internalejac>><<set $vaginastate to "tentacledeep">><<set $tentacle1head to "vaginadeep">><<sex 5>><<vaginalejacstat>><<ejacstat>>
<</if>>
<<if $tentacle1head is "vaginaimminent">>
<<if $vaginalvirginity is 1>>
<span class="pink"> and thrusts into your <<pussycomma>></span><span class="red"> tearing your hymen and forever robbing you of your purity.</span><<set $vaginalvirginity to 0>><<violence 100>>
<<else>>
<span class="pink"> and thrusts into your <<pussystop>></span>
<</if>>
<<set $vaginastate to "tentacle">><<set $tentacle1head to "vagina">><<sex 5>><<raped>><<vaginaraped>><<vaginalstat>><<violence 1>>
<</if>>
<<if $tentacle1head is "vaginaentrance">>
<<if $undertype isnot "chastity">>
<span class="purple"> and presses against your <<pussycomma>> about to penetrate.</span><<set $vaginastate to "tentacleimminent">><<set $tentacle1head to "vaginaimminent">><<neutral 4>>
<<else>>
and tries to find a way inside. Failing, it lashes at the metal.<<set $underintegrity -= 10>><<violence 1>>
<</if>>
<</if>>
<<if $tentacle1head is "penisdeep">>
and continues thrusting against your <<peniscomma>> caressing and kneading your length.<<sex 5>>
<</if>>
<<if $tentacle1head is "penis">>
and continues thrusting against your <<penisstop>><span class="pink"> It sucks and kneads your length, trying to milk you of your cum.</span><<set $penisstate to "tentacledeep">><<set $tentacle1head to "penisdeep">><<sex 5>>
<</if>>
<<if $tentacle1head is "penisimminent">>
<<if $penilevirginity is 1>>
<span class="pink"> and thrusts against your <<peniscomma>> swallowing you to the base and </span><span class="red"> tearing the membrane between your glans and foreskin, forever robbing you of your purity.</span><<set $penilevirginity to 0>><<violence 100>>
<<else>>
<span class="pink"> and thrusts against your <<peniscomma>> swallowing you to the base.</span>
<</if>>
<<set $penisstate to "tentacle">><<set $tentacle1head to "penis">><<sex 5>><<raped>><<penisraped>><<penilestat>><<violence 1>>
<</if>>
<<if $tentacle1head is "penisentrance">>
<<if $undertype isnot "chastity">>
<span class="purple"> and <<slithers>> over to your <<penisstop>> The tip opens and presses against your glans, about to envelop you.</span><<set $penisstate to "tentacleimminent">><<set $tentacle1head to "penisimminent">><<neutral 4>>
<<else>>
and tries to find a way inside. Failing, it lashes at the metal.<<set $underintegrity -= 10>><<violence 1>>
<</if>>
<</if>>
<<if $tentacle1head is "anusdeep">>
and <<slithers>> into your <<bottom>> where it pumps a viscous fluid at the apex of each thrust.<<set $purity -= 1>><<internalejac>><<sex 5>><<set $drugged += 3>><<set $anusgoo += 1>><<set $tentacle1health -= 1>>
<</if>>
<<if $tentacle1head is "anus">>
and continues thrusting into your <<bottomstop>><span class="pink"> The tip opens and begins oozing a viscous liquid.</span><<set $purity -= 1>><<internalejac>><<set $anusstate to "tentacledeep">><<set $tentacle1head to "anusdeep">><<sex 5>><<analejacstat>><<ejacstat>>
<</if>>
<<if $tentacle1head is "anusimminent">>
<<if $analvirginity is 1>>
<span class="pink"> and thrusts into your <<bottomcomma>></span><span class="red"> violating you in a way you hadn't conceived of.</span><<set $analvirginity to 0>><<violence 100>>
<<else>>
<span class="pink"> and thrusts into your <<bottomstop>></span>
<</if>>
<<set $anusstate to "tentacle">><<set $tentacle1head to "anus">><<sex 5>><<raped>><<analstat>><<violence 1>>
<</if>>
<<if $tentacle1head is "anusentrance">>
<<if $analshield is 0>>
<span class="purple"> and presses against your <<bottomcomma>> about to penetrate.</span><<set $anusstate to "tentacleimminent">><<set $tentacle1head to "anusimminent">><<neutral 4>>
<<else>>
and tries to find a way inside. Failing, it lashes at the device.<<set $underintegrity -= 10>><<violence 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $tentacle1head is "vaginarub">>
<<if $rng gte 21>>
and between your thighs where it <<slithers>> against your <<pussycomma>> pressing against your clit.<<sex 3>>
<<else>>
and between your thighs <span class="blue">where it <<slithers>> toward your <<pussystop>></span><<neutral 3>><<set $vaginause to "tentacle">><<set $vaginastate to "tentacleentrance">><<set $tentacle1head to "vaginaentrance">><<set $thighuse to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $tentacle1head is "penisrub">>
<<if $rng gte 21>>
and between your thighs where it <<slithers>> against your <<peniscomma>> coiling around it.<<sex 3>>
<<else>>
and between your thighs <span class="blue">where the tip opens and it <<slithers>> toward your <<penisstop>></span><<neutral 3>><<set $penisuse to "tentacle">><<set $penisstate to "tentacleentrance">><<set $tentacle1head to "penisentrance">><<set $thighuse to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $tentacle1head is "bottomrub">>
<<if $rng gte 21>>
and between your <<bottom>> cheeks where it <<slithers>> against your back.<<sex 3>>
<<else>>
and between your <<bottom>> cheeks, <span class="blue"> toward your anus.</span><<neutral 3>><<set $anususe to "tentacle">><<set $anusstate to "tentacleentrance">><<set $tentacle1head to "anusentrance">><<set $bottomuse to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $tentacle1head is 0 and $tentacle1shaft isnot 0>>
<<if $rng lte 10>>
<<if $chestuse is "squeezed" and $breastuse is 0>>
<<upperslither>><span class="blue">and up between your squeezed <<breastsstop>></span><<set $tentacle1head to "chest">><<neutral 2>><<set $breastuse to "tentacle">><<cheststat>>
<<else>>
<<tentacle1default>>
<</if>>
<<elseif $rng lte 20>>
<<if $leftnipple is 0>>
<<upperslither>> <span class="blue">and teases your left nipple.</span><<neutral 2>><<set $tentacle1head to "leftnipple">><<set $leftnipple to "tentacle">>
<<else>>
<<tentacle1default>>
<</if>>
<<elseif $rng lte 30>>
<<if $rightnipple is 0>>
<<upperslither>> <span class="blue">and teases your right nipple.</span><<neutral 2>><<set $tentacle1head to "rightnipple">><<set $rightnipple to "tentacle">>
<<else>>
<<tentacle1default>>
<</if>>
<<elseif $rng lte 40>>
<<if $mouthuse is 0>>
<<upperslither>> <span class="blue">and up toward your mouth.</span><<neutral 2>><<set $mouthuse to "tentacle">><<set $mouthstate to "tentacleentrance">><<set $tentacle1head to "mouthentrance">>
<<else>>
<<tentacle1default>>
<</if>>
<<elseif $rng lte 50>>
<<if $anususe is 0 and $analdisable is "f">>
<<underslither>> <span class="blue">and <<slithers>> toward your <<bottomstop>></span><<neutral 2>><<set $anususe to "tentacle">><<set $anusstate to "tentacleentrance">><<set $tentacle1head to "anusentrance">>
<<else>>
<<tentacle1default>>
<</if>>
<<elseif $rng lte 60>>
<<if $vaginaexist is 1 and $vaginause is 0>>
<<underslither>> <span class="blue">and <<slithers>> toward your <<pussystop>></span><<neutral 2>><<set $vaginause to "tentacle">><<set $vaginastate to "tentacleentrance">><<set $tentacle1head to "vaginaentrance">>
<<else>>
<<tentacle1default>>
<</if>>
<<elseif $rng lte 70>>
<<if $penisexist is 1 and $penisuse is 0>>
<<underslither>> <span class="blue">and <<slithers>> toward your <<penisstop>></span><<neutral 2>><<set $penisuse to "tentacle">><<set $penisstate to "tentacleentrance">><<set $tentacle1head to "penisentrance">>
<<else>>
<<tentacle1default>>
<</if>>
<<elseif $rng lte 80>>
<<if $thighuse is 0>>
<<if $penisexist is 1 and $penisuse is 0>>
<<underslither>> <span class="blue">and <<slithers>> between your thighs and against your tummy and <<penisstop>></span><<set $penisuse to "tentaclerub">><<set $thighuse to "tentaclerub">><<set $tentacle1head to "penisrub">><<sex 3>><<thighstat>>
<<elseif $vaginaexist is 1 and $vaginause is 0>>
<<underslither>> <span class="blue">and <<slithers>> between your thighs and against your tummy and <<pussystop>></span><<set $vaginause to "tentaclerub">><<set $thighuse to "tentaclerub">><<set $tentacle1head to "vaginarub">><<sex 3>><<thighstat>>
<<else>>
<<tentacle1default>>
<</if>>
<<else>>
<<tentacle1default>>
<</if>>
<<elseif $rng lte 90>>
<<if $bottomuse is 0 and $anususe is 0 and $analdisable is "f">>
<<underslither>> <span class="blue">and <<slithers>> between your <<bottom>> cheeks and against your back.</span><<set $bottomuse to "tentaclerub">><<set $anususe to "tentaclerub">><<set $tentacle1head to "bottomrub">><<sex 1>><<bottomstat>>
<<else>>
<<tentacle1default>>
<</if>>
<<else>>
<<tentacle1default>>
<</if>>
<<elseif $tentacle1head is 0 and $tentacle1shaft is 0>>
<<if $rng lte 10>>
<<if $position isnot "wall">>
The $tentacle1 tentacle winds around your tummy.<<neutral 1>><<set $tentacle1shaft to "tummy">>
<<else>>
The $tentacle1 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<elseif $rng lte 20>>
The $tentacle1 tentacle <<slithers>> between your thighs.<<neutral 1>><<set $tentacle1shaft to "thighs">>
<<elseif $rng lte 30>>
<<if $position isnot "wall">>
<<if $breastsize gte 2 and $chestuse is 0>>
The $tentacle1 tentacle <<slithers>> around your <<breastscomma>> <span class="blue">squeezing them together.</span><<neutral 1>><<set $tentacle1shaft to "breasts">><<set $chestuse to "squeezed">>
<<else>>
The $tentacle1 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<else>>
The $tentacle1 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<elseif $rng lte 40>>
<<if $position isnot "wall">>
The $tentacle1 tentacle winds its way around your chest, beneath your <<breastsstop>><<neutral 1>><<set $tentacle1shaft to "chest">>
<<else>>
The $tentacle1 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<elseif $rng lte 50>>
The $tentacle1 tentacle winds its way around your waist.<<neutral 1>><<set $tentacle1shaft to "waist">>
<<elseif $rng lte 60>>
<<if $position isnot "wall">>
<<if $head is 0>>
The $tentacle1 tentacle winds its way around your neck, <span class="blue">restraining your head.</span><<neutral 1>><<set $tentacle1shaft to "neck">><<set $head to "grappled">>
<<else>>
The $tentacle1 tentacle winds its way around your shoulders.<<neutral 1>><<set $tentacle1shaft to "shoulders">>
<</if>>
<<else>>
The $tentacle1 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<elseif $rng lte 70>>
The $tentacle1 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<<elseif $rng lte 80>>
<<if $leftleg is 0>>
The $tentacle1 tentacle winds its way around your left leg, <span class="blue">restraining it.</span><<neutral 1>><<feettentacledisable>><<set $tentacle1shaft to "leftleg">><<set $leftleg to "grappled">>
<<else>>
The $tentacle1 tentacle tickles your feet.<<neutral 1>>
<</if>>
<<elseif $rng lte 85>>
<<if $rightleg is 0>>
The $tentacle1 tentacle winds its way around your right leg, <span class="blue">restraining it.</span><<neutral 1>><<feettentacledisable>><<set $tentacle1shaft to "rightleg">><<set $rightleg to "grappled">>
<<else>>
The $tentacle1 tentacle tickles your feet.<<neutral 1>>
<</if>>
<<elseif $rng lte 90>>
<<if $leftarm is 0>>
The $tentacle1 tentacle winds its way around your left arm, <span class="blue">restraining it.</span><<neutral 1>><<leftarmtentacledisable>><<set $tentacle1shaft to "leftarm">><<set $leftarm to "grappled">><<set $leftarmstate to 0>>
<<else>>
The $tentacle1 tentacle tickles your armpit.<<neutral 1>>
<</if>>
<<elseif $rng lte 95>>
<<if $rightarm is 0>>
The $tentacle1 tentacle winds its way around your right arm, <span class="blue">restraining it.</span><<rightarmtentacledisable>><<neutral 1>><<set $tentacle1shaft to "rightarm">><<set $rightarm to "grappled">><<set $rightarmstate to 0>>
<<else>>
The $tentacle1 tentacle tickles your armpit.<<neutral 1>>
<</if>>
<<elseif $rng lte 100>>
The $tentacle1 tentacle <<slithers>> against your <<bottomstop>><<neutral 1>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "tentacle1default">><<nobr>>
<<set $rng to random(1, 100)>>
<<if $rng gte 90>>
then squirts a warm fluid over your neck.<<neutral 1>><<set $neckgoo += 1>><<set $tentacle1health -= 1>><<neckejacstat>><<ejacstat>>
<<elseif $rng gte 80>>
then squirts a warm fluid over your right arm.<<neutral 1>><<set $rightarmgoo += 1>><<set $tentacle1health -= 1>><<handejacstat>><<ejacstat>>
<<elseif $rng gte 70>>
then squirts a warm fluid over your left arm.<<neutral 1>><<set $leftarmgoo += 1>><<set $tentacle1health -= 1>><<handejacstat>><<ejacstat>>
<<elseif $rng gte 60>>
then squirts a warm fluid over your thighs.<<neutral 1>><<set $thighgoo += 1>><<set $tentacle1health -= 1>><<thighejacstat>><<ejacstat>>
<<elseif $rng gte 50>>
then squirts a warm fluid over your <<bottomstop>><<neutral 1>><<set $bottomgoo += 1>><<set $tentacle1health -= 1>><<bottomejacstat>><<ejacstat>>
<<elseif $rng gte 40>>
then squirts a warm fluid over your tummy.<<neutral 1>><<set $tummygoo += 1>><<set $tentacle1health -= 1>><<tummyejacstat>><<ejacstat>>
<<elseif $rng gte 30>>
then squirts a warm fluid over your chest.<<neutral 1>><<set $chestgoo += 1>><<set $tentacle1health -= 1>><<chestejacstat>><<ejacstat>>
<<elseif $rng gte 20>>
then squirts a warm fluid over your face.<<neutral 1>><<set $facegoo += 1>><<set $tentacle1health -= 1>><<faceejacstat>><<ejacstat>>
<<elseif $rng gte 10>>
then squirts a warm fluid over your hair.<<neutral 1>><<set $hairgoo += 1>><<set $tentacle1health -= 1>><<hairejacstat>><<ejacstat>>
<<else>>
then squirts a warm fluid over your feet.<<neutral 1>><<set $feetgoo += 1>><<set $tentacle1health -= 1>><<feetejacstat>><<ejacstat>>
<</if>>
<</nobr>><</widget>>
<<widget "tentacle1disable">><<nobr>>
<<if $tentacle1head is "feet">>
<<set $leftleg to 0>>
<<set $rightleg to 0>>
<<set $feetstate to 0>>
<</if>>
<<if $tentacle1head is "leftarm">>
<<set $leftarm to 0>>
<<set $leftarmstate to 0>>
<</if>>
<<if $tentacle1head is "rightarm">>
<<set $rightarm to 0>>
<<set $rightarmstate to 0>>
<</if>>
<<if $tentacle1head is "leftnipplesuck">>
<<set $leftnipple to 0>>
<</if>>
<<if $tentacle1head is "rightnipplesuck">>
<<set $rightnipple to 0>>
<</if>>
<<if $tentacle1head is "leftnipple">>
<<set $leftnipple to 0>>
<</if>>
<<if $tentacle1head is "rightnipple">>
<<set $rightnipple to 0>>
<</if>>
<<if $tentacle1head is "chest">>
<<set $chestuse to 0>>
<</if>>
<<if $tentacle1head is "mouthentrance">>
<<set $mouthuse to 0>>
<<set $mouthstate to 0>>
<</if>>
<<if $tentacle1head is "mouthimminent">>
<<set $mouthuse to 0>>
<<set $mouthstate to 0>>
<</if>>
<<if $tentacle1head is "mouth">>
<<set $mouthuse to 0>>
<<set $mouthstate to 0>>
<</if>>
<<if $tentacle1head is "mouthdeep">>
<<set $mouthuse to 0>>
<<set $mouthstate to 0>>
<</if>>
<<if $tentacle1head is "anusentrance">>
<<set $anususe to 0>>
<<set $anusstate to 0>>
<</if>>
<<if $tentacle1head is "anusimminent">>
<<set $anususe to 0>>
<<set $anusstate to 0>>
<</if>>
<<if $tentacle1head is "anus">>
<<set $anususe to 0>>
<<set $anusstate to 0>>
<</if>>
<<if $tentacle1head is "anusdeep">>
<<set $anususe to 0>>
<<set $anusstate to 0>>
<</if>>
<<if $tentacle1head is "vaginaentrance">>
<<set $vaginause to 0>>
<<set $vaginastate to 0>>
<</if>>
<<if $tentacle1head is "vaginaimminent">>
<<set $vaginause to 0>>
<<set $vaginastate to 0>>
<</if>>
<<if $tentacle1head is "vagina">>
<<set $vaginause to 0>>
<<set $vaginastate to 0>>
<</if>>
<<if $tentacle1head is "vaginadeep">>
<<set $vaginause to 0>>
<<set $vaginastate to 0>>
<</if>>
<<if $tentacle1head is "penisentrance">>
<<set $penisuse to 0>>
<<set $penisstate to 0>>
<</if>>
<<if $tentacle1head is "penisimminent">>
<<set $penisuse to 0>>
<<set $penisstate to 0>>
<</if>>
<<if $tentacle1head is "penis">>
<<set $penisuse to 0>>
<<set $penisstate to 0>>
<</if>>
<<if $tentacle1head is "penisdeep">>
<<set $penisuse to 0>>
<<set $penisstate to 0>>
<</if>>
<<if $tentacle1head is "vaginarub">>
<<set $vaginause to 0>>
<<set $thighuse to 0>>
<</if>>
<<if $tentacle1head is "penisrub">>
<<set $penisuse to 0>>
<<set $thighuse to 0>>
<</if>>
<<if $tentacle1head is "bottomrub">>
<<set $anususe to 0>>
<<set $bottomuse to 0>>
<</if>>
<<if $tentacle1shaft is "breasts">>
<<set $chestuse to 0>>
<</if>>
<<if $tentacle1shaft is "neck" and $head isnot "bound">>
<<set $head to 0>>
<</if>>
<<if $tentacle1shaft is "leftleg" and $leftleg isnot "bound">>
<<set $leftleg to 0>>
<</if>>
<<if $tentacle1shaft is "rightleg" and $rightleg isnot "bound">>
<<set $rightleg to 0>>
<</if>>
<<if $tentacle1shaft is "leftarm" and $leftarm isnot "bound">>
<<set $leftarm to 0>>
<</if>>
<<if $tentacle1shaft is "rightarm" and $rightarm isnot "bound">>
<<set $rightarm to 0>>
<</if>>
<<if $tentacle1head is "chest">>
<<set $breastuse to 0>>
<</if>>
<<set $tentacle1shaft to 0>>
<<set $tentacle1head to 0>>
<</nobr>><</widget>>
<<widget "actionstentacle1lefthand">><<nobr>>
<<if $leftarm is 0 and $tentacle1shaft isnot "finished">>
<<if $leftactiondefault is "lefthittentacle1">>
| <label><span class="def">Strike the $tentacle1 tentacle</span> <<radiobutton "$leftaction" "lefthittentacle1" checked>></label>
<<else>>
| <label><span class="def">Strike the $tentacle1 tentacle</span> <<radiobutton "$leftaction" "lefthittentacle1">></label>
<</if>>
<<if $leftactiondefault is "leftgrabtentacle1">>
| <label><span class="sub">Grab the $tentacle1 tentacle</span> <<radiobutton "$leftaction" "leftgrabtentacle1" checked>></label>
<<else>>
| <label><span class="sub">Grab the $tentacle1 tentacle</span> <<radiobutton "$leftaction" "leftgrabtentacle1">></label>
<</if>>
<<elseif $leftarm is "tentacle1">>You hold the $tentacle1 tentacle in your left hand.<br>
<<if $leftactiondefault is "leftrubtentacle1">>
| <label><span class="sub">Milk it</span> <<radiobutton "$leftaction" "leftrubtentacle1" checked>></label>
<<else>>
| <label><span class="sub">Milk it</span> <<radiobutton "$leftaction" "leftrubtentacle1">></label>
<</if>>
<<if $leftactiondefault is "leftstoptentacle1">>
| <label><span class="neutral">Let go</span> <<radiobutton "$leftaction" "leftstoptentacle1" checked>></label>
<<else>>
| <label><span class="neutral">Let go</span> <<radiobutton "$leftaction" "leftstoptentacle1">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle1righthand">><<nobr>>
<<if $rightarm is 0 and $tentacle1shaft isnot "finished">>
<<if $rightactiondefault is "righthittentacle1">>
| <label><span class="def">Strike the $tentacle1 tentacle</span> <<radiobutton "$rightaction" "righthittentacle1" checked>></label>
<<else>>
| <label><span class="def">Strike the $tentacle1 tentacle</span> <<radiobutton "$rightaction" "righthittentacle1">></label>
<</if>>
<<if $rightactiondefault is "rightgrabtentacle1">>
| <label><span class="sub">Grab the $tentacle1 tentacle</span> <<radiobutton "$rightaction" "rightgrabtentacle1" checked>></label>
<<else>>
| <label><span class="sub">Grab the $tentacle1 tentacle</span> <<radiobutton "$rightaction" "rightgrabtentacle1">></label>
<</if>>
<<elseif $rightarm is "tentacle1">>You hold the $tentacle1 tentacle in your right hand.<br>
<<if $rightactiondefault is "rightrubtentacle1">>
| <label><span class="sub">Milk it</span> <<radiobutton "$rightaction" "rightrubtentacle1" checked>></label>
<<else>>
| <label><span class="sub">Milk it</span> <<radiobutton "$rightaction" "rightrubtentacle1">></label>
<</if>>
<<if $rightactiondefault is "rightstoptentacle1">>
| <label><span class="neutral">Let go</span> <<radiobutton "$rightaction" "rightstoptentacle1" checked>></label>
<<else>>
| <label><span class="neutral">Let go</span> <<radiobutton "$rightaction" "rightstoptentacle1">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle1legs">><<nobr>>
<<if $leftleg is 0 and $rightleg is 0 and $tentacle1shaft isnot "finished">>
<<if $feetactiondefault is "feethittentacle1">>
| <label><span class="def">Kick the $tentacle1 tentacle</span> <<radiobutton "$feetaction" "feethittentacle1" checked>></label>
<<else>>
| <label><span class="def">Kick the $tentacle1 tentacle</span> <<radiobutton "$feetaction" "feethittentacle1">></label>
<</if>>
<<if $feetactiondefault is "feetgrabtentacle1">>
| <label><span class="sub">Grab the $tentacle1 tentacle</span> <<radiobutton "$feetaction" "feetgrabtentacle1" checked>></label>
<<else>>
| <label><span class="sub">Grab the $tentacle1 tentacle</span> <<radiobutton "$feetaction" "feetgrabtentacle1">></label>
<</if>>
<<elseif $leftleg is 0 and $tentacle1shaft isnot "finished">>
<<if $feetactiondefault is "feethittentacle1">>
| <label><span class="def">Kick the $tentacle1 tentacle</span> <<radiobutton "$feetaction" "feethittentacle1" checked>></label>
<<else>>
| <label><span class="def">Kick the $tentacle1 tentacle</span> <<radiobutton "$feetaction" "feethittentacle1">></label>
<</if>>
<<elseif $rightleg is 0 and $tentacle1shaft isnot "finished">>
<<if $feetactiondefault is "feethittentacle1">>
| <label><span class="def">Kick the $tentacle1 tentacle</span> <<radiobutton "$feetaction" "feethittentacle1" checked>></label>
<<else>>
| <label><span class="def">Kick the $tentacle1 tentacle</span> <<radiobutton "$feetaction" "feethittentacle1">></label>
<</if>>
<<elseif $leftleg is "tentacle1">>You hold the $tentacle1 tentacle between your feet.<br>
<<if $feetactiondefault is "feetrubtentacle1">>
| <label><span class="sub">Milk it</span> <<radiobutton "$feetaction" "feetrubtentacle1" checked>></label>
<<else>>
| <label><span class="sub">Milk it</span> <<radiobutton "$feetaction" "feetrubtentacle1">></label>
<</if>>
<<if $feetactiondefault is "feetstoptentacle1">>
| <label><span class="neutral">Let go</span> <<radiobutton "$feetaction" "feetstoptentacle1" checked>></label>
<<else>>
| <label><span class="neutral">Let go</span> <<radiobutton "$feetaction" "feetstoptentacle1">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle1mouth">><<nobr>>
<<if $tentacle1head is "mouthentrance">>
<<if $mouthactiondefault is "mouthlicktentacle1">>
| <label><span class="sub">Lick it</span> <<radiobutton "$mouthaction" "mouthlicktentacle1" checked>></label>
<<else>>
| <label><span class="sub">Lick it</span> <<radiobutton "$mouthaction" "mouthlicktentacle1">></label>
<</if>>
<<if $head is "grappled">>
<<else>>
<<if $mouthactiondefault is "mouthpullawaytentacle1">>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "mouthpullawaytentacle1" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "mouthpullawaytentacle1">></label>
<</if>>
<</if>>
<<elseif $tentacle1head is "mouthimminent">>
<<if $mouthactiondefault is "mouthkisstentacle1">>
| <label><span class="sub">Kiss it</span> <<radiobutton "$mouthaction" "mouthkisstentacle1" checked>></label>
<<else>>
| <label><span class="sub">Kiss it</span> <<radiobutton "$mouthaction" "mouthkisstentacle1">></label>
<</if>>
<<if $head is "grappled">>
<<else>>
<<if $mouthactiondefault is "mouthpullawaytentacle1">>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "mouthpullawaytentacle1" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "mouthpullawaytentacle1">></label>
<</if>>
<</if>>
<<elseif $tentacle1head is "mouth">>
<<if $mouthactiondefault is "mouthcooperatetentacle1">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$mouthaction" "mouthcooperatetentacle1" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$mouthaction" "mouthcooperatetentacle1">></label>
<</if>>
<<if $mouthactiondefault is "mouthbitetentacle1">>
| <label><span class="def">Bite</span> <<radiobutton "$mouthaction" "mouthbitetentacle1" checked>></label>
<<else>>
| <label><span class="def">Bite</span> <<radiobutton "$mouthaction" "mouthbitetentacle1">></label>
<</if>>
<<elseif $tentacle1head is "mouthdeep">>
<<if $mouthactiondefault is "mouthcooperatetentacle1">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$mouthaction" "mouthcooperatetentacle1" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$mouthaction" "mouthcooperatetentacle1">></label>
<</if>>
<<if $mouthactiondefault is "mouthbitetentacle1">>
| <label><span class="def">Bite</span> <<radiobutton "$mouthaction" "mouthbitetentacle1" checked>></label>
<<else>>
| <label><span class="def">Bite</span> <<radiobutton "$mouthaction" "mouthbitetentacle1">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle1vagina">><<nobr>>
<<if $tentacle1head is "vaginaentrance">>
<<if $vaginaactiondefault is "vaginarubtentacle1">>
| <label><span class="sub">Rub</span> <<radiobutton "$vaginaaction" "vaginarubtentacle1" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$vaginaaction" "vaginarubtentacle1">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $vaginaactiondefault is "vaginapullawaytentacle1">>
| <label><span class="brat">Pull away</span> <<radiobutton "$vaginaaction" "vaginapullawaytentacle1" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$vaginaaction" "vaginapullawaytentacle1">></label>
<</if>>
<</if>>
<<elseif $tentacle1head is "vaginaimminent">>
<<if $vaginaactiondefault is "vaginarubtentacle1">>
| <label><span class="sub">Rub</span> <<radiobutton "$vaginaaction" "vaginarubtentacle1" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$vaginaaction" "vaginarubtentacle1">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $vaginaactiondefault is "vaginapullawaytentacle1">>
| <label><span class="brat">Pull away</span> <<radiobutton "$vaginaaction" "vaginapullawaytentacle1" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$vaginaaction" "vaginapullawaytentacle1">></label>
<</if>>
<</if>>
<<elseif $tentacle1head is "vagina">>
<<if $vaginaactiondefault is "vaginacooperatetentacle1">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$vaginaaction" "vaginacooperatetentacle1" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$vaginaaction" "vaginacooperatetentacle1">></label>
<</if>>
<<elseif $tentacle1head is "vaginadeep">>
<<if $vaginaactiondefault is "vaginacooperatetentacle1">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$vaginaaction" "vaginacooperatetentacle1" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$vaginaaction" "vaginacooperatetentacle1">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle1penis">><<nobr>>
<<if $tentacle1head is "penisentrance">>
<<if $penisactiondefault is "penisrubtentacle1">>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "penisrubtentacle1" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "penisrubtentacle1">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $penisactiondefault is "penispullawaytentacle1">>
| <label><span class="brat">Pull away</span> <<radiobutton "$penisaction" "penispullawaytentacle1" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$penisaction" "penispullawaytentacle1">></label>
<</if>>
<</if>>
<<elseif $tentacle1head is "penisimminent">>
<<if $penisactiondefault is "penisrubtentacle1">>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "penisrubtentacle1" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "penisrubtentacle1">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $penisactiondefault is "penispullawaytentacle1">>
| <label><span class="brat">Pull away</span> <<radiobutton "$penisaction" "penispullawaytentacle1" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$penisaction" "penispullawaytentacle1">></label>
<</if>>
<</if>>
<<elseif $tentacle1head is "penis">>
<<if $penisactiondefault is "peniscooperatetentacle1">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$penisaction" "peniscooperatetentacle1" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$penisaction" "peniscooperatetentacle1">></label>
<</if>>
<<elseif $tentacle1head is "penisdeep">>
<<if $penisactiondefault is "peniscooperatetentacle1">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$penisaction" "peniscooperatetentacle1" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$penisaction" "peniscooperatetentacle1">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle1anus">><<nobr>>
<<if $tentacle1head is "anusentrance">>
<<if $anusactiondefault is "anusrubtentacle1">>
| <label><span class="sub">Rub</span> <<radiobutton "$anusaction" "anusrubtentacle1" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$anusaction" "anusrubtentacle1">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $anusactiondefault is "anuspullawaytentacle1">>
| <label><span class="brat">Pull away</span> <<radiobutton "$anusaction" "anuspullawaytentacle1" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$anusaction" "anuspullawaytentacle1">></label>
<</if>>
<</if>>
<<elseif $tentacle1head is "anusimminent">>
<<if $anusactiondefault is "anusrubtentacle1">>
| <label><span class="sub">Rub</span> <<radiobutton "$anusaction" "anusrubtentacle1" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$anusaction" "anusrubtentacle1">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $anusactiondefault is "anuspullawaytentacle1">>
| <label><span class="brat">Pull away</span> <<radiobutton "$anusaction" "anuspullawaytentacle1" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$anusaction" "anuspullawaytentacle1">></label>
<</if>>
<</if>>
<<elseif $tentacle1head is "anus">>
<<if $anusactiondefault is "anuscooperatetentacle1">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$anusaction" "anuscooperatetentacle1" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$anusaction" "anuscooperatetentacle1">></label>
<</if>>
<<elseif $tentacle1head is "anusdeep">>
<<if $anusactiondefault is "anuscooperatetentacle1">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$anusaction" "anuscooperatetentacle1" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$anusaction" "anuscooperatetentacle1">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle1thighs">><<nobr>>
<<if $tentacle1head is "penisrub">>
<<if $thighactiondefault is "penisrubtentacle1">>
| <label><span class="sub">Rub</span> <<radiobutton "$thighaction" "penisrubtentacle1" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$thighaction" "penisrubtentacle1">></label>
<</if>>
<<elseif $tentacle1head is "vaginarub">>
<<if $thighactiondefault is "vaginarubtentacle1">>
| <label><span class="sub">Rub</span> <<radiobutton "$thighaction" "vaginarubtentacle1" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$thighaction" "vaginarubtentacle1">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle1bottom">><<nobr>>
<<if $tentacle1head is "bottomrub">>
<<if $bottomactiondefault is "bottomrubtentacle1">>
| <label><span class="sub">Rub</span> <<radiobutton "$bottomaction" "bottomrubtentacle1" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$bottomaction" "bottomrubtentacle1">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle1chest">><<nobr>>
<<if $tentacle1head is "chest">>
<<if $chestactiondefault is "chestrubtentacle1">>
| <label><span class="sub">Rub</span> <<radiobutton "$chestaction" "chestrubtentacle1" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$chestaction" "chestrubtentacle1">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "effectstentacle1">><<nobr>>
<<if $leftaction is "lefthittentacle1">><<set $leftaction to 0>><<set $leftactiondefault to "lefthittentacle1">>You strike the $tentacle1 tentacle with your left hand and it reels away from you.<<defiance 2>><<set $speechhit to 1>><<tentacle1disable>><<set $attackstat += 1>><<set $tentacle1health -= 1>>
<<if $rng lte ($physique / 200)>>
<<set $tentacle1health -= 1>>
<</if>>
<</if>>
<<if $rightaction is "righthittentacle1">><<set $rightaction to 0>><<set $rightactiondefault to "righthittentacle1">>You strike the $tentacle1 tentacle with your right hand and it reels away from you.<<defiance 2>><<set $speechhit to 1>><<tentacle1disable>><<set $attackstat += 1>><<set $tentacle1health -= 1>>
<<if $rng lte ($physique / 200)>>
<<set $tentacle1health -= 1>>
<</if>>
<</if>>
<<if $leftaction is "leftgrabtentacle1">><<set $leftaction to 0>><<set $leftactiondefault to "leftrubtentacle1">><<submission 1>><<handstat>><span class="lblue">You <<handtext>> grab the $tentacle1 tentacle with your left hand.</span><<tentacle1disable>><<set $leftarm to "tentacle1">><<set $tentacle1head to "leftarm">><<handstat>><<set $leftarmstate to "tentacle">>
<</if>>
<<if $rightaction is "rightgrabtentacle1">><<set $rightaction to 0>><<set $rightactiondefault to "rightrubtentacle1">><<submission 1>><<handstat>><span class="lblue">You <<handtext>> grab the $tentacle1 tentacle with your right hand.</span><<tentacle1disable>><<set $rightarm to "tentacle1">><<set $tentacle1head to "rightarm">><<handstat>><<set $rightarmstate to "tentacle">>
<</if>>
<<if $leftaction is "leftrubtentacle1">><<set $leftaction to 0>><<set $leftactiondefault to "leftrubtentacle1">><<handskilluse>><<submission 1>>You <<handtext>> squeeze the $tentacle1 tentacle in your left hand and rub up and down its length.<<set $rng to random(1, 100)>>
<<if $handskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $rightarmgoo += 1>><<set $tentacle1health -= 3>><<handejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $rightaction is "rightrubtentacle1">><<set $rightaction to 0>><<set $rightactiondefault to "rightrubtentacle1">><<handskilluse>><<submission 1>>You <<handtext>> squeeze the $tentacle1 tentacle in your right hand and rub up and down its length.<<set $rng to random(1, 100)>>
<<if $handskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $rightarmgoo += 1>><<set $tentacle1health -= 3>><<handejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $leftaction is "leftstoptentacle1">><<set $leftaction to 0>><<set $leftactiondefault to "leftstoptentacle1">>You release the $tentacle1 tentacle from your left hand.<<tentacle1disable>>
<</if>>
<<if $rightaction is "rightstoptentacle1">><<set $rightaction to 0>><<set $rightactiondefault to "rightstoptentacle1">>You release the $tentacle1 tentacle from your right hand.<<tentacle1disable>>
<</if>>
<<if $feetaction is "feethittentacle1">><<set $feetaction to 0>><<set $feetactiondefault to "feethittentacle1">>You kick the $tentacle1 tentacle and it reels away from you.<<defiance 2>><<set $speechhit to 1>><<tentacle1disable>><<set $attackstat += 1>><<set $tentacle1health -= 1>>
<<if $rng lte ($physique / 200)>>
<<set $tentacle1health -= 1>>
<</if>>
<</if>>
<<if $feetaction is "feetgrabtentacle1">><<set $feetaction to 0>><<set $feetactiondefault to "feetrubtentacle1">><<submission 1>><<feetstat>><span class="lblue">You <<feettext>> grab the $tentacle1 tentacle between your feet.</span><<tentacle1disable>><<set $leftleg to "tentacle1">><<set $rightleg to "tentacle1">><<set $tentacle1head to "feet">><<feetstat>><<set $feetstate to "tentacle">>
<</if>>
<<if $feetaction is "feetrubtentacle1">><<set $feetaction to 0>><<set $feetactiondefault to "feetrubtentacle1">><<feetskilluse>><<submission 1>>You <<feettext>> squeeze the $tentacle1 tentacle between your feet and rub up and down its length.<<set $rng to random(1, 100)>>
<<if $feetskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $feetgoo += 1>><<set $tentacle1health -= 3>><<feetejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $feetaction is "feetstoptentacle1">><<set $feetaction to 0>><<set $feetactiondefault to "feetstoptentacle1">>You let go of the $tentacle1 tentacle between your feet.<<tentacle1disable>>
<</if>>
<<if $mouthaction is "mouthlicktentacle1">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthlicktentacle1">>
<<submission 2>><<oralskilluse>>You <<oraltext>> lick the tip of the $tentacle1 tentacle.<<set $rng to random(1, 100)>>
<<if $oralskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your face.</span><<set $facegoo += 1>><<set $tentacle1health -= 3>><<faceejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $mouthaction is "mouthkisstentacle1">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthkisstentacle1">>
<<submission 3>><<oralskilluse>>You <<oraltext>> kiss the tip of the $tentacle1 tentacle.<<set $rng to random(1, 100)>>
<<if $oralskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your face.</span><<set $facegoo += 1>><<set $tentacle1health -= 3>><<faceejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $mouthaction is "mouthcooperatetentacle1">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthcooperatetentacle1">>
<<sex 5>><<oralskilluse>>You <<oraltext>> suck the $tentacle1 tentacle invading your mouth.<<set $rng to random(1, 100)>>
<<if $oralskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip and into your mouth.</span><<set $tentacle1health -= 3>><<set $drugged += 3>><<set $mouthgoo += 1>><<oralejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $mouthaction is "mouthpullawaytentacle1">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthpullawaytentacle1">><<brat 1>><span class="teal">You pull away from the $tentacle1 tentacle threatening your mouth.</span><<tentacle1disable>>
<</if>>
<<if $mouthaction is "mouthbitetentacle1">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthbitetentacle1">><<defiance 5>>You bite down on the $tentacle1 tentacle invading your mouth. <span class="teal">It recoils immediately.</span><<tentacle1disable>><<set $attackstat += 1>><<set $tentacle1health -= 1>>
<<if $rng lte ($physique / 200)>>
<<set $tentacle1health -= 1>>
<</if>>
<</if>>
<<if $vaginaaction is "vaginarubtentacle1">><<set $vaginaaction to 0>><<set $vaginaactiondefault to "vaginarubtentacle1">>
<<submission 2>><<vaginalskilluse>>You <<vaginaltext>> rub the tip of the $tentacle1 tentacle with your <<pussystop>><<set $rng to random(1, 100)>>
<<if $vaginalskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $vaginaoutsidegoo += 1>><<set $tentacle1health -= 3>><<vaginalentranceejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $vaginaaction is "vaginacooperatetentacle1">><<set $vaginaaction to 0>><<set $vaginaactiondefault to "vaginacooperatetentacle1">>
<<sex 5>><<vaginalskilluse>>You <<vaginaltext>> push back against the $tentacle1 tentacle invading your <<pussystop>><<set $rng to random(1, 100)>>
<<if $vaginalskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, flooding your womb with its warmth.</span><<set $tentacle1health -= 3>><<set $drugged += 3>><<set $vaginagoo += 1>><<vaginalejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $vaginaaction is "vaginapullawaytentacle1">><<set $vaginaaction to 0>><<set $vaginaactiondefault to "vaginapullawaytentacle1">><<brat 1>><span class="teal">You pull away from the $tentacle1 tentacle threatening your <<pussystop>></span><<tentacle1disable>>
<</if>>
<<if $penisaction is "penisrubtentacle1">><<set $penisaction to 0>><<set $penisactiondefault to "penisrubtentacle1">>
<<submission 2>><<penileskilluse>>You <<peniletext>> rub the tip of the $tentacle1 tentacle with your <<penisstop>><<set $rng to random(1, 100)>>
<<if $penileskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $penisgoo += 1>><<set $tentacle1health -= 3>><<penileejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $penisaction is "peniscooperatetentacle1">><<set $penisaction to 0>><<set $penisactiondefault to "peniscooperatetentacle1">>
<<sex 5>><<penileskilluse>>You <<peniletext>> push back against the $tentacle1 tentacle engulfing your <<penisstop>><<set $rng to random(1, 100)>>
<<if $penileskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your groin.</span><<set $tentacle1health -= 3>><<set $penisgoo += 1>><<penileejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $penisaction is "penispullawaytentacle1">><<set $penisaction to 0>><<set $penisactiondefault to "penispullawaytentacle1">><<brat 1>><span class="teal">You pull away from the $tentacle1 tentacle threatening your <<penisstop>></span><<tentacle1disable>>
<</if>>
<<if $anusaction is "anusrubtentacle1">><<set $anusaction to 0>><<set $anusactiondefault to "anusrubtentacle1">>
<<submission 2>><<analskilluse>>You <<analtext>> rub the tip of the $tentacle1 tentacle with your <<bottomstop>><<set $rng to random(1, 100)>>
<<if $analskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your <<bottomstop>></span><<set $bottomgoo += 1>><<set $tentacle1health -= 3>><<bottomejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $anusaction is "anuscooperatetentacle1">><<set $anusaction to 0>><<set $anusactiondefault to "anuscooperatetentacle1">>
<<sex 5>><<analskilluse>>You <<analtext>> push back against the $tentacle1 tentacle invading your <<bottomstop>><<set $rng to random(1, 100)>>
<<if $analskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, flooding your bowels with its warmth.</span><<set $tentacle1health -= 3>><<set $drugged += 3>><<set $anusgoo += 1>><<analejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $anusaction is "anuspullawaytentacle1">><<set $anusaction to 0>><<set $anusactiondefault to "anuspullawaytentacle1">><<brat 1>><span class="teal">You pull away from the $tentacle1 tentacle threatening your <<bottomstop>></span><<tentacle1disable>>
<</if>>
<<if $thighaction is "penisrubtentacle1">><<set $thighaction to 0>><<set $thighactiondefault to "penisrubtentacle1">>
<<submission 3>><<thighskilluse>>You <<thightext>> rub the $tentacle1 tentacle between your thighs.<<set $rng to random(1, 100)>>
<<if $thighskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your tummy.</span><<set $tentacle1health -= 3>><<set $tummygoo += 1>><<tummyejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $thighaction is "vaginarubtentacle1">><<set $thighaction to 0>><<set $thighactiondefault to "vaginarubtentacle1">>
<<submission 3>><<thighskilluse>>You <<thightext>> rub the $tentacle1 tentacle between your thighs.<<set $rng to random(1, 100)>>
<<if $thighskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your tummy.</span><<set $tentacle1health -= 3>><<set $tummygoo += 1>><<tummyejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $bottomaction is "bottomrubtentacle1">><<set $bottomaction to 0>><<set $bottomactiondefault to "bottomrubtentacle1">>
<<submission 3>><<bottomskilluse>>You <<bottomtext>> rub the $tentacle1 tentacle between your cheeks.<<set $rng to random(1, 100)>>
<<if $bottomskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your <<bottomstop>></span><<set $tentacle1health -= 3>><<set $bottomgoo += 1>><<bottomejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $chestaction is "chestrubtentacle1">><<set $chestaction to 0>><<set $chestactiondefault to "chestrubtentacle1">>
<<submission 3>><<chestskilluse>>You <<chesttext>> rub the $tentacle1 tentacle between your <<breastsstop>><<set $rng to random(1, 100)>>
<<if $chestskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your chest.</span><<set $tentacle1health -= 3>><<set $chestgoo += 1>><<chestejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<</nobr>><</widget>>
:: Widgets Combat Tentacle2 [widget]
<<widget "tentacle2">><<nobr>>
<<if $tentacle2health lte 0 and $tentacle2shaft isnot "finished">>
Worn out, the $tentacle2 tentacle retracts from you.
<<tentacle2disable>>
<<set $tentacle2shaft to "finished">>
<<set $tentacle2head to "finished">>
<</if>>
<<if $tentacle2shaft is "tummy">>
The $tentacle2 tentacle <<slithers>> around your tummy,
<</if>>
<<if $tentacle2shaft is "thighs">>
The $tentacle2 tentacle <<slithers>> between your thighs,
<</if>>
<<if $tentacle2shaft is "breasts">>
The $tentacle2 tentacle squeezes your breasts together,
<</if>>
<<if $tentacle2shaft is "chest">>
The $tentacle2 tentacle <<slithers>> around your chest,
<</if>>
<<if $tentacle2shaft is "waist">>
The $tentacle2 tentacle <<slithers>> around your waist,
<</if>>
<<if $tentacle2shaft is "neck">>
The $tentacle2 tentacle <<slithers>> around your neck,
<</if>>
<<if $tentacle2shaft is "shoulders">>
The $tentacle2 tentacle <<slithers>> around your shoulders,
<</if>>
<<if $tentacle2shaft is "leftleg">>
The $tentacle2 tentacle <<slithers>> around your left leg,
<</if>>
<<if $tentacle2shaft is "rightleg">>
The $tentacle2 tentacle <<slithers>> around your right leg,
<</if>>
<<if $tentacle2shaft is "leftarm">>
The $tentacle2 tentacle <<slithers>> around your left arm,
<</if>>
<<if $tentacle2shaft is "rightarm">>
The $tentacle2 tentacle <<slithers>> around your right arm,
<</if>>
<<if $tentacle2head is "leftarm">>
The $tentacle2 tentacle writhes in your left hand.<<neutral 5>>
<</if>>
<<if $tentacle2head is "rightarm">>
The $tentacle2 tentacle writhes in your right hand.<<neutral 5>>
<</if>>
<<if $tentacle2head is "feet">>
The $tentacle2 tentacle writhes between your feet.<<neutral 5>>
<</if>>
<<if $tentacle2head is "leftnipplesuck">>
and up to your <<breastscomma>> where it suckles your left nipple.<<neutral 3>>
<</if>>
<<if $tentacle2head is "rightnipplesuck">>
and up to your <<breastscomma>> where it suckles your right nipple.<<neutral 3>>
<</if>>
<<if $tentacle2head is "leftnipple">>
and continues teasing your left nipple. <span class="purple">The tip of the tentacle opens up, latches on, then begins sucking.</span><<neutral 3>><<set $tentacle2head to "leftnipplesuck">><<set $leftnipple to "tentaclesuck">>
<</if>>
<<if $tentacle2head is "rightnipple">>
and continues teasing your right nipple. <span class="purple">The tip of the tentacle opens up, latches on, then begins sucking.</span><<neutral 3>><<set $tentacle2head to "rightnipplesuck">><<set $rightnipple to "tentaclesuck">>
<</if>>
<<if $tentacle2head is "chest">>
<<if $chestuse is "squeezed">>
then up between your <<breastscomma>> rubbing itself between them.<<neutral 2>>
<<else>>
moves away from your <<breasts>><<set $tentacle2head to 0>><<set $breastuse to 0>>
<</if>>
<</if>>
<<if $tentacle2head is "mouthdeep">>
and up into your mouth where it spurts a sweet fluid down your throat at the apex of each thrust.<<set $purity -= 1>><<internalejac>><<sex 5>><<set $drugged += 3>><<set $mouthgoo += 1>><<set $tentacle2health -= 1>>
<</if>>
<<if $tentacle2head is "mouth">>
and continues thrusting into your mouth.<span class="pink"> The tip opens and begins oozing a sweet liquid.</span><<set $purity -= 1>><<internalejac>><<set $mouthstate to "tentacledeep">><<set $tentacle2head to "mouthdeep">><<sex 5>><<oralejacstat>><<ejacstat>>
<</if>>
<<if $tentacle2head is "mouthimminent">>
<<if $oralvirginity is 1>>
<span class="pink"> and thrusts between your lips,</span><span class="red"> penetrating your mouth for the first time.</span><<set $oralvirginity to 0>><<violence 5>>
<<else>>
<span class="pink"> and thrusts between your lips.</span>
<</if>>
<<set $mouthstate to "tentacle">><<set $tentacle2head to "mouth">><<sex 5>><<raped>><<oralstat>>
<</if>>
<<if $tentacle2head is "mouthentrance">>
<span class="purple"> and presses against your lips.</span><<set $mouthstate to "tentacleimminent">><<set $tentacle2head to "mouthimminent">><<neutral 4>>
<</if>>
<<if $tentacle2head is "vaginadeep">>
and <<slithers>> into your <<pussy>> where it pumps a viscous fluid at the apex of each thrust.<<set $purity -= 1>><<internalejac>><<sex 5>><<set $drugged += 3>><<set $vaginagoo += 1>><<set $tentacle2health -= 1>>
<</if>>
<<if $tentacle2head is "vagina">>
and continues thrusting into your <<pussystop>><span class="pink"> The tip opens and begins oozing a viscous liquid.</span><<set $purity -= 1>><<internalejac>><<set $vaginastate to "tentacledeep">><<set $tentacle2head to "vaginadeep">><<sex 5>><<vaginalejacstat>><<ejacstat>>
<</if>>
<<if $tentacle2head is "vaginaimminent">>
<<if $vaginalvirginity is 1>>
<span class="pink"> and thrusts into your <<pussycomma>></span><span class="red"> tearing your hymen and forever robbing you of your purity.</span><<set $vaginalvirginity to 0>><<violence 100>>
<<else>>
<span class="pink"> and thrusts into your <<pussystop>></span>
<</if>>
<<set $vaginastate to "tentacle">><<set $tentacle2head to "vagina">><<sex 5>><<raped>><<vaginaraped>><<vaginalstat>><<violence 1>>
<</if>>
<<if $tentacle2head is "vaginaentrance">>
<<if $undertype isnot "chastity">>
<span class="purple"> and presses against your <<pussycomma>> about to penetrate.</span><<set $vaginastate to "tentacleimminent">><<set $tentacle2head to "vaginaimminent">><<neutral 4>>
<<else>>
and tries to find a way inside. Failing, it lashes at the metal.<<set $underintegrity -= 10>><<violence 1>>
<</if>>
<</if>>
<<if $tentacle2head is "penisdeep">>
and continues thrusting against your <<peniscomma>> caressing and kneading your length.<<sex 5>>
<</if>>
<<if $tentacle2head is "penis">>
and continues thrusting against your <<penisstop>><span class="pink"> It sucks and kneads your length, trying to milk you of your cum.</span><<set $penisstate to "tentacledeep">><<set $tentacle2head to "penisdeep">><<sex 5>>
<</if>>
<<if $tentacle2head is "penisimminent">>
<<if $penilevirginity is 1>>
<span class="pink"> and thrusts against your <<peniscomma>> swallowing you to the base and </span><span class="red"> tearing the membrane between your glans and foreskin, forever robbing you of your purity.</span><<set $penilevirginity to 0>><<violence 100>>
<<else>>
<span class="pink"> and thrusts against your <<peniscomma>> swallowing you to the base.</span>
<</if>>
<<set $penisstate to "tentacle">><<set $tentacle2head to "penis">><<sex 5>><<raped>><<penisraped>><<penilestat>><<violence 1>>
<</if>>
<<if $tentacle2head is "penisentrance">>
<<if $undertype isnot "chastity">>
<span class="purple"> and <<slithers>> over to your <<penisstop>> The tip opens and presses against your glans, about to envelop you.</span><<set $penisstate to "tentacleimminent">><<set $tentacle2head to "penisimminent">><<neutral 4>>
<<else>>
and tries to find a way inside. Failing, it lashes at the metal.<<set $underintegrity -= 10>><<violence 1>>
<</if>>
<</if>>
<<if $tentacle2head is "anusdeep">>
and <<slithers>> into your <<bottom>> where it pumps a viscous fluid at the apex of each thrust.<<set $purity -= 1>><<internalejac>><<sex 5>><<set $drugged += 3>><<set $anusgoo += 1>><<set $tentacle2health -= 1>>
<</if>>
<<if $tentacle2head is "anus">>
and continues thrusting into your <<bottomstop>><span class="pink"> The tip opens and begins oozing a viscous liquid.</span><<set $purity -= 1>><<internalejac>><<set $anusstate to "tentacledeep">><<set $tentacle2head to "anusdeep">><<sex 5>><<analejacstat>><<ejacstat>>
<</if>>
<<if $tentacle2head is "anusimminent">>
<<if $analvirginity is 1>>
<span class="pink"> and thrusts into your <<bottomcomma>></span><span class="red"> violating you in a way you hadn't conceived of.</span><<set $analvirginity to 0>><<violence 100>>
<<else>>
<span class="pink"> and thrusts into your <<bottomstop>></span>
<</if>>
<<set $anusstate to "tentacle">><<set $tentacle2head to "anus">><<sex 5>><<raped>><<analstat>><<violence 1>>
<</if>>
<<if $tentacle2head is "anusentrance">>
<<if $analshield is 0>>
<span class="purple"> and presses against your <<bottomcomma>> about to penetrate.</span><<set $anusstate to "tentacleimminent">><<set $tentacle2head to "anusimminent">><<neutral 4>>
<<else>>
and tries to find a way inside. Failing, it lashes at the device.<<set $underintegrity -= 10>><<violence 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $tentacle2head is "vaginarub">>
<<if $rng gte 21>>
and between your thighs where it <<slithers>> against your <<pussycomma>> pressing against your clit.<<sex 3>>
<<else>>
and between your thighs <span class="blue">where it <<slithers>> toward your <<pussystop>></span><<neutral 3>><<set $vaginause to "tentacle">><<set $vaginastate to "tentacleentrance">><<set $tentacle2head to "vaginaentrance">><<set $thighuse to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $tentacle2head is "penisrub">>
<<if $rng gte 21>>
and between your thighs where it <<slithers>> against your <<peniscomma>> coiling around it.<<sex 3>>
<<else>>
and between your thighs <span class="blue">where the tip opens and it <<slithers>> toward your <<penisstop>></span><<neutral 3>><<set $penisuse to "tentacle">><<set $penisstate to "tentacleentrance">><<set $tentacle2head to "penisentrance">><<set $thighuse to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $tentacle2head is "bottomrub">>
<<if $rng gte 21>>
and between your <<bottom>> cheeks where it <<slithers>> against your back.<<sex 3>>
<<else>>
and between your <<bottom>> cheeks, <span class="blue"> toward your anus.</span><<neutral 3>><<set $anususe to "tentacle">><<set $anusstate to "tentacleentrance">><<set $tentacle2head to "anusentrance">><<set $bottomuse to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $tentacle2head is 0 and $tentacle2shaft isnot 0>>
<<if $rng lte 10>>
<<if $chestuse is "squeezed" and $breastuse is 0>>
<<upperslither>><span class="blue">and up between your squeezed <<breastsstop>></span><<set $tentacle2head to "chest">><<neutral 2>><<set $breastuse to "tentacle">><<cheststat>>
<<else>>
<<tentacle2default>>
<</if>>
<<elseif $rng lte 20>>
<<if $leftnipple is 0>>
<<upperslither>> <span class="blue">and teases your left nipple.</span><<neutral 2>><<set $tentacle2head to "leftnipple">><<set $leftnipple to "tentacle">>
<<else>>
<<tentacle2default>>
<</if>>
<<elseif $rng lte 30>>
<<if $rightnipple is 0>>
<<upperslither>> <span class="blue">and teases your right nipple.</span><<neutral 2>><<set $tentacle2head to "rightnipple">><<set $rightnipple to "tentacle">>
<<else>>
<<tentacle2default>>
<</if>>
<<elseif $rng lte 40>>
<<if $mouthuse is 0>>
<<upperslither>> <span class="blue">and up toward your mouth.</span><<neutral 2>><<set $mouthuse to "tentacle">><<set $mouthstate to "tentacleentrance">><<set $tentacle2head to "mouthentrance">>
<<else>>
<<tentacle2default>>
<</if>>
<<elseif $rng lte 50>>
<<if $anususe is 0 and $analdisable is "f">>
<<underslither>> <span class="blue">and <<slithers>> toward your <<bottomstop>></span><<neutral 2>><<set $anususe to "tentacle">><<set $anusstate to "tentacleentrance">><<set $tentacle2head to "anusentrance">>
<<else>>
<<tentacle2default>>
<</if>>
<<elseif $rng lte 60>>
<<if $vaginaexist is 1 and $vaginause is 0>>
<<underslither>> <span class="blue">and <<slithers>> toward your <<pussystop>></span><<neutral 2>><<set $vaginause to "tentacle">><<set $vaginastate to "tentacleentrance">><<set $tentacle2head to "vaginaentrance">>
<<else>>
<<tentacle2default>>
<</if>>
<<elseif $rng lte 70>>
<<if $penisexist is 1 and $penisuse is 0>>
<<underslither>> <span class="blue">and <<slithers>> toward your <<penisstop>></span><<neutral 2>><<set $penisuse to "tentacle">><<set $penisstate to "tentacleentrance">><<set $tentacle2head to "penisentrance">>
<<else>>
<<tentacle2default>>
<</if>>
<<elseif $rng lte 80>>
<<if $thighuse is 0>>
<<if $penisexist is 1 and $penisuse is 0>>
<<underslither>> <span class="blue">and <<slithers>> between your thighs and against your tummy and <<penisstop>></span><<set $penisuse to "tentaclerub">><<set $thighuse to "tentaclerub">><<set $tentacle2head to "penisrub">><<sex 3>><<thighstat>>
<<elseif $vaginaexist is 1 and $vaginause is 0>>
<<underslither>> <span class="blue">and <<slithers>> between your thighs and against your tummy and <<pussystop>></span><<set $vaginause to "tentaclerub">><<set $thighuse to "tentaclerub">><<set $tentacle2head to "vaginarub">><<sex 3>><<thighstat>>
<<else>>
<<tentacle2default>>
<</if>>
<<else>>
<<tentacle2default>>
<</if>>
<<elseif $rng lte 90>>
<<if $bottomuse is 0 and $anususe is 0 and $analdisable is "f">>
<<underslither>> <span class="blue">and <<slithers>> between your <<bottom>> cheeks and against your back.</span><<set $bottomuse to "tentaclerub">><<set $anususe to "tentaclerub">><<set $tentacle2head to "bottomrub">><<sex 1>><<bottomstat>>
<<else>>
<<tentacle2default>>
<</if>>
<<else>>
<<tentacle2default>>
<</if>>
<<elseif $tentacle2head is 0 and $tentacle2shaft is 0>>
<<if $rng lte 10>>
<<if $position isnot "wall">>
The $tentacle2 tentacle winds around your tummy.<<neutral 1>><<set $tentacle2shaft to "tummy">>
<<else>>
The $tentacle2 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<elseif $rng lte 20>>
The $tentacle2 tentacle <<slithers>> between your thighs.<<neutral 1>><<set $tentacle2shaft to "thighs">>
<<elseif $rng lte 30>>
<<if $position isnot "wall">>
<<if $breastsize gte 2 and $chestuse is 0>>
The $tentacle2 tentacle <<slithers>> around your <<breastscomma>> <span class="blue">squeezing them together.</span><<neutral 1>><<set $tentacle2shaft to "breasts">><<set $chestuse to "squeezed">>
<<else>>
The $tentacle2 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<else>>
The $tentacle2 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<elseif $rng lte 40>>
<<if $position isnot "wall">>
The $tentacle2 tentacle winds its way around your chest, beneath your <<breastsstop>><<neutral 1>><<set $tentacle2shaft to "chest">>
<<else>>
The $tentacle2 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<elseif $rng lte 50>>
The $tentacle2 tentacle winds its way around your waist.<<neutral 1>><<set $tentacle2shaft to "waist">>
<<elseif $rng lte 60>>
<<if $position isnot "wall">>
<<if $head is 0>>
The $tentacle2 tentacle winds its way around your neck, <span class="blue">restraining your head.</span><<neutral 1>><<set $tentacle2shaft to "neck">><<set $head to "grappled">>
<<else>>
The $tentacle2 tentacle winds its way around your shoulders.<<neutral 1>><<set $tentacle2shaft to "shoulders">>
<</if>>
<<else>>
The $tentacle2 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<elseif $rng lte 70>>
The $tentacle2 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<<elseif $rng lte 80>>
<<if $leftleg is 0>>
The $tentacle2 tentacle winds its way around your left leg, <span class="blue">restraining it.</span><<neutral 1>><<feettentacledisable>><<set $tentacle2shaft to "leftleg">><<set $leftleg to "grappled">>
<<else>>
The $tentacle2 tentacle tickles your feet.<<neutral 1>>
<</if>>
<<elseif $rng lte 85>>
<<if $rightleg is 0>>
The $tentacle2 tentacle winds its way around your right leg, <span class="blue">restraining it.</span><<neutral 1>><<feettentacledisable>><<set $tentacle2shaft to "rightleg">><<set $rightleg to "grappled">>
<<else>>
The $tentacle2 tentacle tickles your feet.<<neutral 1>>
<</if>>
<<elseif $rng lte 90>>
<<if $leftarm is 0>>
The $tentacle2 tentacle winds its way around your left arm, <span class="blue">restraining it.</span><<neutral 1>><<leftarmtentacledisable>><<set $tentacle2shaft to "leftarm">><<set $leftarm to "grappled">><<set $leftarmstate to 0>>
<<else>>
The $tentacle2 tentacle tickles your armpit.<<neutral 1>>
<</if>>
<<elseif $rng lte 95>>
<<if $rightarm is 0>>
The $tentacle2 tentacle winds its way around your right arm, <span class="blue">restraining it.</span><<rightarmtentacledisable>><<neutral 1>><<set $tentacle2shaft to "rightarm">><<set $rightarm to "grappled">><<set $rightarmstate to 0>>
<<else>>
The $tentacle2 tentacle tickles your armpit.<<neutral 1>>
<</if>>
<<elseif $rng lte 100>>
The $tentacle2 tentacle <<slithers>> against your <<bottomstop>><<neutral 1>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "tentacle2default">><<nobr>>
<<set $rng to random(1, 100)>>
<<if $rng gte 90>>
then squirts a warm fluid over your neck.<<neutral 1>><<set $neckgoo += 1>><<set $tentacle2health -= 1>><<neckejacstat>><<ejacstat>>
<<elseif $rng gte 80>>
then squirts a warm fluid over your right arm.<<neutral 1>><<set $rightarmgoo += 1>><<set $tentacle2health -= 1>><<handejacstat>><<ejacstat>>
<<elseif $rng gte 70>>
then squirts a warm fluid over your left arm.<<neutral 1>><<set $leftarmgoo += 1>><<set $tentacle2health -= 1>><<handejacstat>><<ejacstat>>
<<elseif $rng gte 60>>
then squirts a warm fluid over your thighs.<<neutral 1>><<set $thighgoo += 1>><<set $tentacle2health -= 1>><<thighejacstat>><<ejacstat>>
<<elseif $rng gte 50>>
then squirts a warm fluid over your <<bottomstop>><<neutral 1>><<set $bottomgoo += 1>><<set $tentacle2health -= 1>><<bottomejacstat>><<ejacstat>>
<<elseif $rng gte 40>>
then squirts a warm fluid over your tummy.<<neutral 1>><<set $tummygoo += 1>><<set $tentacle2health -= 1>><<tummyejacstat>><<ejacstat>>
<<elseif $rng gte 30>>
then squirts a warm fluid over your chest.<<neutral 1>><<set $chestgoo += 1>><<set $tentacle2health -= 1>><<chestejacstat>><<ejacstat>>
<<elseif $rng gte 20>>
then squirts a warm fluid over your face.<<neutral 1>><<set $facegoo += 1>><<set $tentacle2health -= 1>><<faceejacstat>><<ejacstat>>
<<elseif $rng gte 10>>
then squirts a warm fluid over your hair.<<neutral 1>><<set $hairgoo += 1>><<set $tentacle2health -= 1>><<hairejacstat>><<ejacstat>>
<<else>>
then squirts a warm fluid over your feet.<<neutral 1>><<set $feetgoo += 1>><<set $tentacle2health -= 1>><<feetejacstat>><<ejacstat>>
<</if>>
<</nobr>><</widget>>
<<widget "tentacle2disable">><<nobr>>
<<if $tentacle2head is "feet">>
<<set $leftleg to 0>>
<<set $rightleg to 0>>
<<set $feetstate to 0>>
<</if>>
<<if $tentacle2head is "leftarm">>
<<set $leftarm to 0>>
<<set $leftarmstate to 0>>
<</if>>
<<if $tentacle2head is "rightarm">>
<<set $rightarm to 0>>
<<set $rightarmstate to 0>>
<</if>>
<<if $tentacle2head is "leftnipplesuck">>
<<set $leftnipple to 0>>
<</if>>
<<if $tentacle2head is "rightnipplesuck">>
<<set $rightnipple to 0>>
<</if>>
<<if $tentacle2head is "leftnipple">>
<<set $leftnipple to 0>>
<</if>>
<<if $tentacle2head is "rightnipple">>
<<set $rightnipple to 0>>
<</if>>
<<if $tentacle2head is "chest">>
<<set $chestuse to 0>>
<</if>>
<<if $tentacle2head is "mouthentrance">>
<<set $mouthuse to 0>>
<<set $mouthstate to 0>>
<</if>>
<<if $tentacle2head is "mouthimminent">>
<<set $mouthuse to 0>>
<<set $mouthstate to 0>>
<</if>>
<<if $tentacle2head is "mouth">>
<<set $mouthuse to 0>>
<<set $mouthstate to 0>>
<</if>>
<<if $tentacle2head is "mouthdeep">>
<<set $mouthuse to 0>>
<<set $mouthstate to 0>>
<</if>>
<<if $tentacle2head is "anusentrance">>
<<set $anususe to 0>>
<<set $anusstate to 0>>
<</if>>
<<if $tentacle2head is "anusimminent">>
<<set $anususe to 0>>
<<set $anusstate to 0>>
<</if>>
<<if $tentacle2head is "anus">>
<<set $anususe to 0>>
<<set $anusstate to 0>>
<</if>>
<<if $tentacle2head is "anusdeep">>
<<set $anususe to 0>>
<<set $anusstate to 0>>
<</if>>
<<if $tentacle2head is "vaginaentrance">>
<<set $vaginause to 0>>
<<set $vaginastate to 0>>
<</if>>
<<if $tentacle2head is "vaginaimminent">>
<<set $vaginause to 0>>
<<set $vaginastate to 0>>
<</if>>
<<if $tentacle2head is "vagina">>
<<set $vaginause to 0>>
<<set $vaginastate to 0>>
<</if>>
<<if $tentacle2head is "vaginadeep">>
<<set $vaginause to 0>>
<<set $vaginastate to 0>>
<</if>>
<<if $tentacle2head is "penisentrance">>
<<set $penisuse to 0>>
<<set $penisstate to 0>>
<</if>>
<<if $tentacle2head is "penisimminent">>
<<set $penisuse to 0>>
<<set $penisstate to 0>>
<</if>>
<<if $tentacle2head is "penis">>
<<set $penisuse to 0>>
<<set $penisstate to 0>>
<</if>>
<<if $tentacle2head is "penisdeep">>
<<set $penisuse to 0>>
<<set $penisstate to 0>>
<</if>>
<<if $tentacle2head is "vaginarub">>
<<set $vaginause to 0>>
<<set $thighuse to 0>>
<</if>>
<<if $tentacle2head is "penisrub">>
<<set $penisuse to 0>>
<<set $thighuse to 0>>
<</if>>
<<if $tentacle2head is "bottomrub">>
<<set $anususe to 0>>
<<set $bottomuse to 0>>
<</if>>
<<if $tentacle2shaft is "breasts">>
<<set $chestuse to 0>>
<</if>>
<<if $tentacle2shaft is "neck" and $head isnot "bound">>
<<set $head to 0>>
<</if>>
<<if $tentacle2shaft is "leftleg" and $leftleg isnot "bound">>
<<set $leftleg to 0>>
<</if>>
<<if $tentacle2shaft is "rightleg" and $rightleg isnot "bound">>
<<set $rightleg to 0>>
<</if>>
<<if $tentacle2shaft is "leftarm" and $leftarm isnot "bound">>
<<set $leftarm to 0>>
<</if>>
<<if $tentacle2shaft is "rightarm" and $rightarm isnot "bound">>
<<set $rightarm to 0>>
<</if>>
<<if $tentacle2head is "chest">>
<<set $breastuse to 0>>
<</if>>
<<set $tentacle2shaft to 0>>
<<set $tentacle2head to 0>>
<</nobr>><</widget>>
<<widget "actionstentacle2lefthand">><<nobr>>
<<if $leftarm is 0 and $tentacle2shaft isnot "finished">>
<<if $leftactiondefault is "lefthittentacle2">>
| <label><span class="def">Strike the $tentacle2 tentacle</span> <<radiobutton "$leftaction" "lefthittentacle2" checked>></label>
<<else>>
| <label><span class="def">Strike the $tentacle2 tentacle</span> <<radiobutton "$leftaction" "lefthittentacle2">></label>
<</if>>
<<if $leftactiondefault is "leftgrabtentacle2">>
| <label><span class="sub">Grab the $tentacle2 tentacle</span> <<radiobutton "$leftaction" "leftgrabtentacle2" checked>></label>
<<else>>
| <label><span class="sub">Grab the $tentacle2 tentacle</span> <<radiobutton "$leftaction" "leftgrabtentacle2">></label>
<</if>>
<<elseif $leftarm is "tentacle2">>You hold the $tentacle2 tentacle in your left hand.<br>
<<if $leftactiondefault is "leftrubtentacle2">>
| <label><span class="sub">Milk it</span> <<radiobutton "$leftaction" "leftrubtentacle2" checked>></label>
<<else>>
| <label><span class="sub">Milk it</span> <<radiobutton "$leftaction" "leftrubtentacle2">></label>
<</if>>
<<if $leftactiondefault is "leftstoptentacle2">>
| <label><span class="neutral">Let go</span> <<radiobutton "$leftaction" "leftstoptentacle2" checked>></label>
<<else>>
| <label><span class="neutral">Let go</span> <<radiobutton "$leftaction" "leftstoptentacle2">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle2righthand">><<nobr>>
<<if $rightarm is 0 and $tentacle2shaft isnot "finished">>
<<if $rightactiondefault is "righthittentacle2">>
| <label><span class="def">Strike the $tentacle2 tentacle</span> <<radiobutton "$rightaction" "righthittentacle2" checked>></label>
<<else>>
| <label><span class="def">Strike the $tentacle2 tentacle</span> <<radiobutton "$rightaction" "righthittentacle2">></label>
<</if>>
<<if $rightactiondefault is "rightgrabtentacle2">>
| <label><span class="sub">Grab the $tentacle2 tentacle</span> <<radiobutton "$rightaction" "rightgrabtentacle2" checked>></label>
<<else>>
| <label><span class="sub">Grab the $tentacle2 tentacle</span> <<radiobutton "$rightaction" "rightgrabtentacle2">></label>
<</if>>
<<elseif $rightarm is "tentacle2">>You hold the $tentacle2 tentacle in your right hand.<br>
<<if $rightactiondefault is "rightrubtentacle2">>
| <label><span class="sub">Milk it</span> <<radiobutton "$rightaction" "rightrubtentacle2" checked>></label>
<<else>>
| <label><span class="sub">Milk it</span> <<radiobutton "$rightaction" "rightrubtentacle2">></label>
<</if>>
<<if $rightactiondefault is "rightstoptentacle2">>
| <label><span class="neutral">Let go</span> <<radiobutton "$rightaction" "rightstoptentacle2" checked>></label>
<<else>>
| <label><span class="neutral">Let go</span> <<radiobutton "$rightaction" "rightstoptentacle2">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle2legs">><<nobr>>
<<if $leftleg is 0 and $rightleg is 0 and $tentacle2shaft isnot "finished">>
<<if $feetactiondefault is "feethittentacle2">>
| <label><span class="def">Kick the $tentacle2 tentacle</span> <<radiobutton "$feetaction" "feethittentacle2" checked>></label>
<<else>>
| <label><span class="def">Kick the $tentacle2 tentacle</span> <<radiobutton "$feetaction" "feethittentacle2">></label>
<</if>>
<<if $feetactiondefault is "feetgrabtentacle2">>
| <label><span class="sub">Grab the $tentacle2 tentacle</span> <<radiobutton "$feetaction" "feetgrabtentacle2" checked>></label>
<<else>>
| <label><span class="sub">Grab the $tentacle2 tentacle</span> <<radiobutton "$feetaction" "feetgrabtentacle2">></label>
<</if>>
<<elseif $leftleg is 0 and $tentacle2shaft isnot "finished">>
<<if $feetactiondefault is "feethittentacle2">>
| <label><span class="def">Kick the $tentacle2 tentacle</span> <<radiobutton "$feetaction" "feethittentacle2" checked>></label>
<<else>>
| <label><span class="def">Kick the $tentacle2 tentacle</span> <<radiobutton "$feetaction" "feethittentacle2">></label>
<</if>>
<<elseif $rightleg is 0 and $tentacle2shaft isnot "finished">>
<<if $feetactiondefault is "feethittentacle2">>
| <label><span class="def">Kick the $tentacle2 tentacle</span> <<radiobutton "$feetaction" "feethittentacle2" checked>></label>
<<else>>
| <label><span class="def">Kick the $tentacle2 tentacle</span> <<radiobutton "$feetaction" "feethittentacle2">></label>
<</if>>
<<elseif $leftleg is "tentacle2">>You hold the $tentacle2 tentacle between your feet.<br>
<<if $feetactiondefault is "feetrubtentacle2">>
| <label><span class="sub">Milk it</span> <<radiobutton "$feetaction" "feetrubtentacle2" checked>></label>
<<else>>
| <label><span class="sub">Milk it</span> <<radiobutton "$feetaction" "feetrubtentacle2">></label>
<</if>>
<<if $feetactiondefault is "feetstoptentacle2">>
| <label><span class="neutral">Let go</span> <<radiobutton "$feetaction" "feetstoptentacle2" checked>></label>
<<else>>
| <label><span class="neutral">Let go</span> <<radiobutton "$feetaction" "feetstoptentacle2">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle2mouth">><<nobr>>
<<if $tentacle2head is "mouthentrance">>
<<if $mouthactiondefault is "mouthlicktentacle2">>
| <label><span class="sub">Lick it</span> <<radiobutton "$mouthaction" "mouthlicktentacle2" checked>></label>
<<else>>
| <label><span class="sub">Lick it</span> <<radiobutton "$mouthaction" "mouthlicktentacle2">></label>
<</if>>
<<if $head is "grappled">>
<<else>>
<<if $mouthactiondefault is "mouthpullawaytentacle2">>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "mouthpullawaytentacle2" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "mouthpullawaytentacle2">></label>
<</if>>
<</if>>
<<elseif $tentacle2head is "mouthimminent">>
<<if $mouthactiondefault is "mouthkisstentacle2">>
| <label><span class="sub">Kiss it</span> <<radiobutton "$mouthaction" "mouthkisstentacle2" checked>></label>
<<else>>
| <label><span class="sub">Kiss it</span> <<radiobutton "$mouthaction" "mouthkisstentacle2">></label>
<</if>>
<<if $head is "grappled">>
<<else>>
<<if $mouthactiondefault is "mouthpullawaytentacle2">>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "mouthpullawaytentacle2" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "mouthpullawaytentacle2">></label>
<</if>>
<</if>>
<<elseif $tentacle2head is "mouth">>
<<if $mouthactiondefault is "mouthcooperatetentacle2">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$mouthaction" "mouthcooperatetentacle2" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$mouthaction" "mouthcooperatetentacle2">></label>
<</if>>
<<if $mouthactiondefault is "mouthbitetentacle2">>
| <label><span class="def">Bite</span> <<radiobutton "$mouthaction" "mouthbitetentacle2" checked>></label>
<<else>>
| <label><span class="def">Bite</span> <<radiobutton "$mouthaction" "mouthbitetentacle2">></label>
<</if>>
<<elseif $tentacle2head is "mouthdeep">>
<<if $mouthactiondefault is "mouthcooperatetentacle2">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$mouthaction" "mouthcooperatetentacle2" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$mouthaction" "mouthcooperatetentacle2">></label>
<</if>>
<<if $mouthactiondefault is "mouthbitetentacle2">>
| <label><span class="def">Bite</span> <<radiobutton "$mouthaction" "mouthbitetentacle2" checked>></label>
<<else>>
| <label><span class="def">Bite</span> <<radiobutton "$mouthaction" "mouthbitetentacle2">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle2vagina">><<nobr>>
<<if $tentacle2head is "vaginaentrance">>
<<if $vaginaactiondefault is "vaginarubtentacle2">>
| <label><span class="sub">Rub</span> <<radiobutton "$vaginaaction" "vaginarubtentacle2" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$vaginaaction" "vaginarubtentacle2">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $vaginaactiondefault is "vaginapullawaytentacle2">>
| <label><span class="brat">Pull away</span> <<radiobutton "$vaginaaction" "vaginapullawaytentacle2" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$vaginaaction" "vaginapullawaytentacle2">></label>
<</if>>
<</if>>
<<elseif $tentacle2head is "vaginaimminent">>
<<if $vaginaactiondefault is "vaginarubtentacle2">>
| <label><span class="sub">Rub</span> <<radiobutton "$vaginaaction" "vaginarubtentacle2" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$vaginaaction" "vaginarubtentacle2">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $vaginaactiondefault is "vaginapullawaytentacle2">>
| <label><span class="brat">Pull away</span> <<radiobutton "$vaginaaction" "vaginapullawaytentacle2" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$vaginaaction" "vaginapullawaytentacle2">></label>
<</if>>
<</if>>
<<elseif $tentacle2head is "vagina">>
<<if $vaginaactiondefault is "vaginacooperatetentacle2">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$vaginaaction" "vaginacooperatetentacle2" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$vaginaaction" "vaginacooperatetentacle2">></label>
<</if>>
<<elseif $tentacle2head is "vaginadeep">>
<<if $vaginaactiondefault is "vaginacooperatetentacle2">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$vaginaaction" "vaginacooperatetentacle2" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$vaginaaction" "vaginacooperatetentacle2">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle2penis">><<nobr>>
<<if $tentacle2head is "penisentrance">>
<<if $penisactiondefault is "penisrubtentacle2">>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "penisrubtentacle2" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "penisrubtentacle2">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $penisactiondefault is "penispullawaytentacle2">>
| <label><span class="brat">Pull away</span> <<radiobutton "$penisaction" "penispullawaytentacle2" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$penisaction" "penispullawaytentacle2">></label>
<</if>>
<</if>>
<<elseif $tentacle2head is "penisimminent">>
<<if $penisactiondefault is "penisrubtentacle2">>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "penisrubtentacle2" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "penisrubtentacle2">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $penisactiondefault is "penispullawaytentacle2">>
| <label><span class="brat">Pull away</span> <<radiobutton "$penisaction" "penispullawaytentacle2" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$penisaction" "penispullawaytentacle2">></label>
<</if>>
<</if>>
<<elseif $tentacle2head is "penis">>
<<if $penisactiondefault is "peniscooperatetentacle2">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$penisaction" "peniscooperatetentacle2" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$penisaction" "peniscooperatetentacle2">></label>
<</if>>
<<elseif $tentacle2head is "penisdeep">>
<<if $penisactiondefault is "peniscooperatetentacle2">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$penisaction" "peniscooperatetentacle2" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$penisaction" "peniscooperatetentacle2">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle2anus">><<nobr>>
<<if $tentacle2head is "anusentrance">>
<<if $anusactiondefault is "anusrubtentacle2">>
| <label><span class="sub">Rub</span> <<radiobutton "$anusaction" "anusrubtentacle2" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$anusaction" "anusrubtentacle2">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $anusactiondefault is "anuspullawaytentacle2">>
| <label><span class="brat">Pull away</span> <<radiobutton "$anusaction" "anuspullawaytentacle2" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$anusaction" "anuspullawaytentacle2">></label>
<</if>>
<</if>>
<<elseif $tentacle2head is "anusimminent">>
<<if $anusactiondefault is "anusrubtentacle2">>
| <label><span class="sub">Rub</span> <<radiobutton "$anusaction" "anusrubtentacle2" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$anusaction" "anusrubtentacle2">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $anusactiondefault is "anuspullawaytentacle2">>
| <label><span class="brat">Pull away</span> <<radiobutton "$anusaction" "anuspullawaytentacle2" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$anusaction" "anuspullawaytentacle2">></label>
<</if>>
<</if>>
<<elseif $tentacle2head is "anus">>
<<if $anusactiondefault is "anuscooperatetentacle2">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$anusaction" "anuscooperatetentacle2" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$anusaction" "anuscooperatetentacle2">></label>
<</if>>
<<elseif $tentacle2head is "anusdeep">>
<<if $anusactiondefault is "anuscooperatetentacle2">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$anusaction" "anuscooperatetentacle2" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$anusaction" "anuscooperatetentacle2">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle2thighs">><<nobr>>
<<if $tentacle2head is "penisrub">>
<<if $thighactiondefault is "penisrubtentacle2">>
| <label><span class="sub">Rub</span> <<radiobutton "$thighaction" "penisrubtentacle2" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$thighaction" "penisrubtentacle2">></label>
<</if>>
<<elseif $tentacle2head is "vaginarub">>
<<if $thighactiondefault is "vaginarubtentacle2">>
| <label><span class="sub">Rub</span> <<radiobutton "$thighaction" "vaginarubtentacle2" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$thighaction" "vaginarubtentacle2">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle2bottom">><<nobr>>
<<if $tentacle2head is "bottomrub">>
<<if $bottomactiondefault is "bottomrubtentacle2">>
| <label><span class="sub">Rub</span> <<radiobutton "$bottomaction" "bottomrubtentacle2" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$bottomaction" "bottomrubtentacle2">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle2chest">><<nobr>>
<<if $tentacle2head is "chest">>
<<if $chestactiondefault is "chestrubtentacle2">>
| <label><span class="sub">Rub</span> <<radiobutton "$chestaction" "chestrubtentacle2" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$chestaction" "chestrubtentacle2">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "effectstentacle2">><<nobr>>
<<if $leftaction is "lefthittentacle2">><<set $leftaction to 0>><<set $leftactiondefault to "lefthittentacle2">>You strike the $tentacle2 tentacle with your left hand and it reels away from you.<<defiance 2>><<set $speechhit to 1>><<tentacle2disable>><<set $attackstat += 1>><<set $tentacle2health -= 1>>
<<if $rng lte ($physique / 200)>>
<<set $tentacle2health -= 1>>
<</if>>
<</if>>
<<if $rightaction is "righthittentacle2">><<set $rightaction to 0>><<set $rightactiondefault to "righthittentacle2">>You strike the $tentacle2 tentacle with your right hand and it reels away from you.<<defiance 2>><<set $speechhit to 1>><<tentacle2disable>><<set $attackstat += 1>><<set $tentacle2health -= 1>>
<<if $rng lte ($physique / 200)>>
<<set $tentacle2health -= 1>>
<</if>>
<</if>>
<<if $leftaction is "leftgrabtentacle2">><<set $leftaction to 0>><<set $leftactiondefault to "leftrubtentacle2">><<submission 1>><<handstat>><span class="lblue">You <<handtext>> grab the $tentacle2 tentacle with your left hand.</span><<tentacle2disable>><<set $leftarm to "tentacle2">><<set $tentacle2head to "leftarm">><<handstat>><<set $leftarmstate to "tentacle">>
<</if>>
<<if $rightaction is "rightgrabtentacle2">><<set $rightaction to 0>><<set $rightactiondefault to "rightrubtentacle2">><<submission 1>><<handstat>><span class="lblue">You <<handtext>> grab the $tentacle2 tentacle with your right hand.</span><<tentacle2disable>><<set $rightarm to "tentacle2">><<set $tentacle2head to "rightarm">><<handstat>><<set $rightarmstate to "tentacle">>
<</if>>
<<if $leftaction is "leftrubtentacle2">><<set $leftaction to 0>><<set $leftactiondefault to "leftrubtentacle2">><<handskilluse>><<submission 1>>You <<handtext>> squeeze the $tentacle2 tentacle in your left hand and rub up and down its length.<<set $rng to random(1, 100)>>
<<if $handskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $rightarmgoo += 1>><<set $tentacle2health -= 3>><<handejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $rightaction is "rightrubtentacle2">><<set $rightaction to 0>><<set $rightactiondefault to "rightrubtentacle2">><<handskilluse>><<submission 1>>You <<handtext>> squeeze the $tentacle2 tentacle in your right hand and rub up and down its length.<<set $rng to random(1, 100)>>
<<if $handskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $rightarmgoo += 1>><<set $tentacle2health -= 3>><<handejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $leftaction is "leftstoptentacle2">><<set $leftaction to 0>><<set $leftactiondefault to "leftstoptentacle2">>You release the $tentacle2 tentacle from your left hand.<<tentacle2disable>>
<</if>>
<<if $rightaction is "rightstoptentacle2">><<set $rightaction to 0>><<set $rightactiondefault to "rightstoptentacle2">>You release the $tentacle2 tentacle from your right hand.<<tentacle2disable>>
<</if>>
<<if $feetaction is "feethittentacle2">><<set $feetaction to 0>><<set $feetactiondefault to "feethittentacle2">>You kick the $tentacle2 tentacle and it reels away from you.<<defiance 2>><<set $speechhit to 1>><<tentacle2disable>><<set $attackstat += 1>><<set $tentacle2health -= 1>>
<<if $rng lte ($physique / 200)>>
<<set $tentacle2health -= 1>>
<</if>>
<</if>>
<<if $feetaction is "feetgrabtentacle2">><<set $feetaction to 0>><<set $feetactiondefault to "feetrubtentacle2">><<submission 1>><<feetstat>><span class="lblue">You <<feettext>> grab the $tentacle2 tentacle between your feet.</span><<tentacle2disable>><<set $leftleg to "tentacle2">><<set $rightleg to "tentacle2">><<set $tentacle2head to "feet">><<feetstat>><<set $feetstate to "tentacle">>
<</if>>
<<if $feetaction is "feetrubtentacle2">><<set $feetaction to 0>><<set $feetactiondefault to "feetrubtentacle2">><<feetskilluse>><<submission 1>>You <<feettext>> squeeze the $tentacle2 tentacle between your feet and rub up and down its length.<<set $rng to random(1, 100)>>
<<if $feetskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $feetgoo += 1>><<set $tentacle2health -= 3>><<feetejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $feetaction is "feetstoptentacle2">><<set $feetaction to 0>><<set $feetactiondefault to "feetstoptentacle2">>You let go of the $tentacle2 tentacle between your feet.<<tentacle2disable>>
<</if>>
<<if $mouthaction is "mouthlicktentacle2">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthlicktentacle2">>
<<submission 2>><<oralskilluse>>You <<oraltext>> lick the tip of the $tentacle2 tentacle.<<set $rng to random(1, 100)>>
<<if $oralskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your face.</span><<set $facegoo += 1>><<set $tentacle2health -= 3>><<faceejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $mouthaction is "mouthkisstentacle2">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthkisstentacle2">>
<<submission 3>><<oralskilluse>>You <<oraltext>> kiss the tip of the $tentacle2 tentacle.<<set $rng to random(1, 100)>>
<<if $oralskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your face.</span><<set $facegoo += 1>><<set $tentacle2health -= 3>><<faceejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $mouthaction is "mouthcooperatetentacle2">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthcooperatetentacle2">>
<<sex 5>><<oralskilluse>>You <<oraltext>> suck the $tentacle2 tentacle invading your mouth.<<set $rng to random(1, 100)>>
<<if $oralskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip and into your mouth.</span><<set $tentacle2health -= 3>><<set $drugged += 3>><<set $mouthgoo += 1>><<oralejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $mouthaction is "mouthpullawaytentacle2">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthpullawaytentacle2">><<brat 1>><span class="teal">You pull away from the $tentacle2 tentacle threatening your mouth.</span><<tentacle2disable>>
<</if>>
<<if $mouthaction is "mouthbitetentacle2">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthbitetentacle2">><<defiance 5>>You bite down on the $tentacle2 tentacle invading your mouth. <span class="teal">It recoils immediately.</span><<tentacle2disable>><<set $attackstat += 1>><<set $tentacle2health -= 1>>
<<if $rng lte ($physique / 200)>>
<<set $tentacle2health -= 1>>
<</if>>
<</if>>
<<if $vaginaaction is "vaginarubtentacle2">><<set $vaginaaction to 0>><<set $vaginaactiondefault to "vaginarubtentacle2">>
<<submission 2>><<vaginalskilluse>>You <<vaginaltext>> rub the tip of the $tentacle2 tentacle with your <<pussystop>><<set $rng to random(1, 100)>>
<<if $vaginalskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $vaginaoutsidegoo += 1>><<set $tentacle2health -= 3>><<vaginalentranceejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $vaginaaction is "vaginacooperatetentacle2">><<set $vaginaaction to 0>><<set $vaginaactiondefault to "vaginacooperatetentacle2">>
<<sex 5>><<vaginalskilluse>>You <<vaginaltext>> push back against the $tentacle2 tentacle invading your <<pussystop>><<set $rng to random(1, 100)>>
<<if $vaginalskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, flooding your womb with its warmth.</span><<set $tentacle2health -= 3>><<set $drugged += 3>><<set $vaginagoo += 1>><<vaginalejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $vaginaaction is "vaginapullawaytentacle2">><<set $vaginaaction to 0>><<set $vaginaactiondefault to "vaginapullawaytentacle2">><<brat 1>><span class="teal">You pull away from the $tentacle2 tentacle threatening your <<pussystop>></span><<tentacle2disable>>
<</if>>
<<if $penisaction is "penisrubtentacle2">><<set $penisaction to 0>><<set $penisactiondefault to "penisrubtentacle2">>
<<submission 2>><<penileskilluse>>You <<peniletext>> rub the tip of the $tentacle2 tentacle with your <<penisstop>><<set $rng to random(1, 100)>>
<<if $penileskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $penisgoo += 1>><<set $tentacle2health -= 3>><<penileejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $penisaction is "peniscooperatetentacle2">><<set $penisaction to 0>><<set $penisactiondefault to "peniscooperatetentacle2">>
<<sex 5>><<penileskilluse>>You <<peniletext>> push back against the $tentacle2 tentacle engulfing your <<penisstop>><<set $rng to random(1, 100)>>
<<if $penileskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your groin.</span><<set $tentacle2health -= 3>><<set $penisgoo += 1>><<penileejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $penisaction is "penispullawaytentacle2">><<set $penisaction to 0>><<set $penisactiondefault to "penispullawaytentacle2">><<brat 1>><span class="teal">You pull away from the $tentacle2 tentacle threatening your <<penisstop>></span><<tentacle2disable>>
<</if>>
<<if $anusaction is "anusrubtentacle2">><<set $anusaction to 0>><<set $anusactiondefault to "anusrubtentacle2">>
<<submission 2>><<analskilluse>>You <<analtext>> rub the tip of the $tentacle2 tentacle with your <<bottomstop>><<set $rng to random(1, 100)>>
<<if $analskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your <<bottomstop>></span><<set $bottomgoo += 1>><<set $tentacle2health -= 3>><<bottomejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $anusaction is "anuscooperatetentacle2">><<set $anusaction to 0>><<set $anusactiondefault to "anuscooperatetentacle2">>
<<sex 5>><<analskilluse>>You <<analtext>> push back against the $tentacle2 tentacle invading your <<bottomstop>><<set $rng to random(1, 100)>>
<<if $analskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, flooding your bowels with its warmth.</span><<set $tentacle2health -= 3>><<set $drugged += 3>><<set $anusgoo += 1>><<analejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $anusaction is "anuspullawaytentacle2">><<set $anusaction to 0>><<set $anusactiondefault to "anuspullawaytentacle2">><<brat 1>><span class="teal">You pull away from the $tentacle2 tentacle threatening your <<bottomstop>></span><<tentacle2disable>>
<</if>>
<<if $thighaction is "penisrubtentacle2">><<set $thighaction to 0>><<set $thighactiondefault to "penisrubtentacle2">>
<<submission 3>><<thighskilluse>>You <<thightext>> rub the $tentacle2 tentacle between your thighs.<<set $rng to random(1, 100)>>
<<if $thighskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your tummy.</span><<set $tentacle2health -= 3>><<set $tummygoo += 1>><<tummyejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $thighaction is "vaginarubtentacle2">><<set $thighaction to 0>><<set $thighactiondefault to "vaginarubtentacle2">>
<<submission 3>><<thighskilluse>>You <<thightext>> rub the $tentacle2 tentacle between your thighs.<<set $rng to random(1, 100)>>
<<if $thighskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your tummy.</span><<set $tentacle2health -= 3>><<set $tummygoo += 1>><<tummyejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $bottomaction is "bottomrubtentacle2">><<set $bottomaction to 0>><<set $bottomactiondefault to "bottomrubtentacle2">>
<<submission 3>><<bottomskilluse>>You <<bottomtext>> rub the $tentacle2 tentacle between your cheeks.<<set $rng to random(1, 100)>>
<<if $bottomskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your <<bottomstop>></span><<set $tentacle2health -= 3>><<set $bottomgoo += 1>><<bottomejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $chestaction is "chestrubtentacle2">><<set $chestaction to 0>><<set $chestactiondefault to "chestrubtentacle2">>
<<submission 3>><<chestskilluse>>You <<chesttext>> rub the $tentacle2 tentacle between your <<breastsstop>><<set $rng to random(1, 100)>>
<<if $chestskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your chest.</span><<set $tentacle2health -= 3>><<set $chestgoo += 1>><<chestejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<</nobr>><</widget>>
:: Widgets Combat Tentacle3 [widget]
<<widget "tentacle3">><<nobr>>
<<if $tentacle3health lte 0 and $tentacle3shaft isnot "finished">>
Worn out, the $tentacle3 tentacle retracts from you.
<<tentacle3disable>>
<<set $tentacle3shaft to "finished">>
<<set $tentacle3head to "finished">>
<</if>>
<<if $tentacle3shaft is "tummy">>
The $tentacle3 tentacle <<slithers>> around your tummy,
<</if>>
<<if $tentacle3shaft is "thighs">>
The $tentacle3 tentacle <<slithers>> between your thighs,
<</if>>
<<if $tentacle3shaft is "breasts">>
The $tentacle3 tentacle squeezes your breasts together,
<</if>>
<<if $tentacle3shaft is "chest">>
The $tentacle3 tentacle <<slithers>> around your chest,
<</if>>
<<if $tentacle3shaft is "waist">>
The $tentacle3 tentacle <<slithers>> around your waist,
<</if>>
<<if $tentacle3shaft is "neck">>
The $tentacle3 tentacle <<slithers>> around your neck,
<</if>>
<<if $tentacle3shaft is "shoulders">>
The $tentacle3 tentacle <<slithers>> around your shoulders,
<</if>>
<<if $tentacle3shaft is "leftleg">>
The $tentacle3 tentacle <<slithers>> around your left leg,
<</if>>
<<if $tentacle3shaft is "rightleg">>
The $tentacle3 tentacle <<slithers>> around your right leg,
<</if>>
<<if $tentacle3shaft is "leftarm">>
The $tentacle3 tentacle <<slithers>> around your left arm,
<</if>>
<<if $tentacle3shaft is "rightarm">>
The $tentacle3 tentacle <<slithers>> around your right arm,
<</if>>
<<if $tentacle3head is "leftarm">>
The $tentacle3 tentacle writhes in your left hand.<<neutral 5>>
<</if>>
<<if $tentacle3head is "rightarm">>
The $tentacle3 tentacle writhes in your right hand.<<neutral 5>>
<</if>>
<<if $tentacle3head is "feet">>
The $tentacle3 tentacle writhes between your feet.<<neutral 5>>
<</if>>
<<if $tentacle3head is "leftnipplesuck">>
and up to your <<breastscomma>> where it suckles your left nipple.<<neutral 3>>
<</if>>
<<if $tentacle3head is "rightnipplesuck">>
and up to your <<breastscomma>> where it suckles your right nipple.<<neutral 3>>
<</if>>
<<if $tentacle3head is "leftnipple">>
and continues teasing your left nipple. <span class="purple">The tip of the tentacle opens up, latches on, then begins sucking.</span><<neutral 3>><<set $tentacle3head to "leftnipplesuck">><<set $leftnipple to "tentaclesuck">>
<</if>>
<<if $tentacle3head is "rightnipple">>
and continues teasing your right nipple. <span class="purple">The tip of the tentacle opens up, latches on, then begins sucking.</span><<neutral 3>><<set $tentacle3head to "rightnipplesuck">><<set $rightnipple to "tentaclesuck">>
<</if>>
<<if $tentacle3head is "chest">>
<<if $chestuse is "squeezed">>
then up between your <<breastscomma>> rubbing itself between them.<<neutral 2>>
<<else>>
moves away from your <<breasts>><<set $tentacle3head to 0>><<set $breastuse to 0>>
<</if>>
<</if>>
<<if $tentacle3head is "mouthdeep">>
and up into your mouth where it spurts a sweet fluid down your throat at the apex of each thrust.<<set $purity -= 1>><<internalejac>><<sex 5>><<set $drugged += 3>><<set $mouthgoo += 1>><<set $tentacle3health -= 1>>
<</if>>
<<if $tentacle3head is "mouth">>
and continues thrusting into your mouth.<span class="pink"> The tip opens and begins oozing a sweet liquid.</span><<set $purity -= 1>><<internalejac>><<set $mouthstate to "tentacledeep">><<set $tentacle3head to "mouthdeep">><<sex 5>><<oralejacstat>><<ejacstat>>
<</if>>
<<if $tentacle3head is "mouthimminent">>
<<if $oralvirginity is 1>>
<span class="pink"> and thrusts between your lips,</span><span class="red"> penetrating your mouth for the first time.</span><<set $oralvirginity to 0>><<violence 5>>
<<else>>
<span class="pink"> and thrusts between your lips.</span>
<</if>>
<<set $mouthstate to "tentacle">><<set $tentacle3head to "mouth">><<sex 5>><<raped>><<oralstat>>
<</if>>
<<if $tentacle3head is "mouthentrance">>
<span class="purple"> and presses against your lips.</span><<set $mouthstate to "tentacleimminent">><<set $tentacle3head to "mouthimminent">><<neutral 4>>
<</if>>
<<if $tentacle3head is "vaginadeep">>
and <<slithers>> into your <<pussy>> where it pumps a viscous fluid at the apex of each thrust.<<set $purity -= 1>><<internalejac>><<sex 5>><<set $drugged += 3>><<set $vaginagoo += 1>><<set $tentacle3health -= 1>>
<</if>>
<<if $tentacle3head is "vagina">>
and continues thrusting into your <<pussystop>><span class="pink"> The tip opens and begins oozing a viscous liquid.</span><<set $purity -= 1>><<internalejac>><<set $vaginastate to "tentacledeep">><<set $tentacle3head to "vaginadeep">><<sex 5>><<vaginalejacstat>><<ejacstat>>
<</if>>
<<if $tentacle3head is "vaginaimminent">>
<<if $vaginalvirginity is 1>>
<span class="pink"> and thrusts into your <<pussycomma>></span><span class="red"> tearing your hymen and forever robbing you of your purity.</span><<set $vaginalvirginity to 0>><<violence 100>>
<<else>>
<span class="pink"> and thrusts into your <<pussystop>></span>
<</if>>
<<set $vaginastate to "tentacle">><<set $tentacle3head to "vagina">><<sex 5>><<raped>><<vaginaraped>><<vaginalstat>><<violence 1>>
<</if>>
<<if $tentacle3head is "vaginaentrance">>
<<if $undertype isnot "chastity">>
<span class="purple"> and presses against your <<pussycomma>> about to penetrate.</span><<set $vaginastate to "tentacleimminent">><<set $tentacle3head to "vaginaimminent">><<neutral 4>>
<<else>>
and tries to find a way inside. Failing, it lashes at the metal.<<set $underintegrity -= 10>><<violence 1>>
<</if>>
<</if>>
<<if $tentacle3head is "penisdeep">>
and continues thrusting against your <<peniscomma>> caressing and kneading your length.<<sex 5>>
<</if>>
<<if $tentacle3head is "penis">>
and continues thrusting against your <<penisstop>><span class="pink"> It sucks and kneads your length, trying to milk you of your cum.</span><<set $penisstate to "tentacledeep">><<set $tentacle3head to "penisdeep">><<sex 5>>
<</if>>
<<if $tentacle3head is "penisimminent">>
<<if $penilevirginity is 1>>
<span class="pink"> and thrusts against your <<peniscomma>> swallowing you to the base and </span><span class="red"> tearing the membrane between your glans and foreskin, forever robbing you of your purity.</span><<set $penilevirginity to 0>><<violence 100>>
<<else>>
<span class="pink"> and thrusts against your <<peniscomma>> swallowing you to the base.</span>
<</if>>
<<set $penisstate to "tentacle">><<set $tentacle3head to "penis">><<sex 5>><<raped>><<penisraped>><<penilestat>><<violence 1>>
<</if>>
<<if $tentacle3head is "penisentrance">>
<<if $undertype isnot "chastity">>
<span class="purple"> and <<slithers>> over to your <<penisstop>> The tip opens and presses against your glans, about to envelop you.</span><<set $penisstate to "tentacleimminent">><<set $tentacle3head to "penisimminent">><<neutral 4>>
<<else>>
and tries to find a way inside. Failing, it lashes at the metal.<<set $underintegrity -= 10>><<violence 1>>
<</if>>
<</if>>
<<if $tentacle3head is "anusdeep">>
and <<slithers>> into your <<bottom>> where it pumps a viscous fluid at the apex of each thrust.<<set $purity -= 1>><<internalejac>><<sex 5>><<set $drugged += 3>><<set $anusgoo += 1>><<set $tentacle3health -= 1>>
<</if>>
<<if $tentacle3head is "anus">>
and continues thrusting into your <<bottomstop>><span class="pink"> The tip opens and begins oozing a viscous liquid.</span><<set $purity -= 1>><<internalejac>><<set $anusstate to "tentacledeep">><<set $tentacle3head to "anusdeep">><<sex 5>><<analejacstat>><<ejacstat>>
<</if>>
<<if $tentacle3head is "anusimminent">>
<<if $analvirginity is 1>>
<span class="pink"> and thrusts into your <<bottomcomma>></span><span class="red"> violating you in a way you hadn't conceived of.</span><<set $analvirginity to 0>><<violence 100>>
<<else>>
<span class="pink"> and thrusts into your <<bottomstop>></span>
<</if>>
<<set $anusstate to "tentacle">><<set $tentacle3head to "anus">><<sex 5>><<raped>><<analstat>><<violence 1>>
<</if>>
<<if $tentacle3head is "anusentrance">>
<<if $analshield is 0>>
<span class="purple"> and presses against your <<bottomcomma>> about to penetrate.</span><<set $anusstate to "tentacleimminent">><<set $tentacle3head to "anusimminent">><<neutral 4>>
<<else>>
and tries to find a way inside. Failing, it lashes at the device.<<set $underintegrity -= 10>><<violence 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $tentacle3head is "vaginarub">>
<<if $rng gte 21>>
and between your thighs where it <<slithers>> against your <<pussycomma>> pressing against your clit.<<sex 3>>
<<else>>
and between your thighs <span class="blue">where it <<slithers>> toward your <<pussystop>></span><<neutral 3>><<set $vaginause to "tentacle">><<set $vaginastate to "tentacleentrance">><<set $tentacle3head to "vaginaentrance">><<set $thighuse to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $tentacle3head is "penisrub">>
<<if $rng gte 21>>
and between your thighs where it <<slithers>> against your <<peniscomma>> coiling around it.<<sex 3>>
<<else>>
and between your thighs <span class="blue">where the tip opens and it <<slithers>> toward your <<penisstop>></span><<neutral 3>><<set $penisuse to "tentacle">><<set $penisstate to "tentacleentrance">><<set $tentacle3head to "penisentrance">><<set $thighuse to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $tentacle3head is "bottomrub">>
<<if $rng gte 21>>
and between your <<bottom>> cheeks where it <<slithers>> against your back.<<sex 3>>
<<else>>
and between your <<bottom>> cheeks, <span class="blue"> toward your anus.</span><<neutral 3>><<set $anususe to "tentacle">><<set $anusstate to "tentacleentrance">><<set $tentacle3head to "anusentrance">><<set $bottomuse to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $tentacle3head is 0 and $tentacle3shaft isnot 0>>
<<if $rng lte 10>>
<<if $chestuse is "squeezed" and $breastuse is 0>>
<<upperslither>><span class="blue">and up between your squeezed <<breastsstop>></span><<set $tentacle3head to "chest">><<neutral 2>><<set $breastuse to "tentacle">><<cheststat>>
<<else>>
<<tentacle3default>>
<</if>>
<<elseif $rng lte 20>>
<<if $leftnipple is 0>>
<<upperslither>> <span class="blue">and teases your left nipple.</span><<neutral 2>><<set $tentacle3head to "leftnipple">><<set $leftnipple to "tentacle">>
<<else>>
<<tentacle3default>>
<</if>>
<<elseif $rng lte 30>>
<<if $rightnipple is 0>>
<<upperslither>> <span class="blue">and teases your right nipple.</span><<neutral 2>><<set $tentacle3head to "rightnipple">><<set $rightnipple to "tentacle">>
<<else>>
<<tentacle3default>>
<</if>>
<<elseif $rng lte 40>>
<<if $mouthuse is 0>>
<<upperslither>> <span class="blue">and up toward your mouth.</span><<neutral 2>><<set $mouthuse to "tentacle">><<set $mouthstate to "tentacleentrance">><<set $tentacle3head to "mouthentrance">>
<<else>>
<<tentacle3default>>
<</if>>
<<elseif $rng lte 50>>
<<if $anususe is 0 and $analdisable is "f">>
<<underslither>> <span class="blue">and <<slithers>> toward your <<bottomstop>></span><<neutral 2>><<set $anususe to "tentacle">><<set $anusstate to "tentacleentrance">><<set $tentacle3head to "anusentrance">>
<<else>>
<<tentacle3default>>
<</if>>
<<elseif $rng lte 60>>
<<if $vaginaexist is 1 and $vaginause is 0>>
<<underslither>> <span class="blue">and <<slithers>> toward your <<pussystop>></span><<neutral 2>><<set $vaginause to "tentacle">><<set $vaginastate to "tentacleentrance">><<set $tentacle3head to "vaginaentrance">>
<<else>>
<<tentacle3default>>
<</if>>
<<elseif $rng lte 70>>
<<if $penisexist is 1 and $penisuse is 0>>
<<underslither>> <span class="blue">and <<slithers>> toward your <<penisstop>></span><<neutral 2>><<set $penisuse to "tentacle">><<set $penisstate to "tentacleentrance">><<set $tentacle3head to "penisentrance">>
<<else>>
<<tentacle3default>>
<</if>>
<<elseif $rng lte 80>>
<<if $thighuse is 0>>
<<if $penisexist is 1 and $penisuse is 0>>
<<underslither>> <span class="blue">and <<slithers>> between your thighs and against your tummy and <<penisstop>></span><<set $penisuse to "tentaclerub">><<set $thighuse to "tentaclerub">><<set $tentacle3head to "penisrub">><<sex 3>><<thighstat>>
<<elseif $vaginaexist is 1 and $vaginause is 0>>
<<underslither>> <span class="blue">and <<slithers>> between your thighs and against your tummy and <<pussystop>></span><<set $vaginause to "tentaclerub">><<set $thighuse to "tentaclerub">><<set $tentacle3head to "vaginarub">><<sex 3>><<thighstat>>
<<else>>
<<tentacle3default>>
<</if>>
<<else>>
<<tentacle3default>>
<</if>>
<<elseif $rng lte 90>>
<<if $bottomuse is 0 and $anususe is 0 and $analdisable is "f">>
<<underslither>> <span class="blue">and <<slithers>> between your <<bottom>> cheeks and against your back.</span><<set $bottomuse to "tentaclerub">><<set $anususe to "tentaclerub">><<set $tentacle3head to "bottomrub">><<sex 1>><<bottomstat>>
<<else>>
<<tentacle3default>>
<</if>>
<<else>>
<<tentacle3default>>
<</if>>
<<elseif $tentacle3head is 0 and $tentacle3shaft is 0>>
<<if $rng lte 10>>
<<if $position isnot "wall">>
The $tentacle3 tentacle winds around your tummy.<<neutral 1>><<set $tentacle3shaft to "tummy">>
<<else>>
The $tentacle3 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<elseif $rng lte 20>>
The $tentacle3 tentacle <<slithers>> between your thighs.<<neutral 1>><<set $tentacle3shaft to "thighs">>
<<elseif $rng lte 30>>
<<if $position isnot "wall">>
<<if $breastsize gte 2 and $chestuse is 0>>
The $tentacle3 tentacle <<slithers>> around your <<breastscomma>> <span class="blue">squeezing them together.</span><<neutral 1>><<set $tentacle3shaft to "breasts">><<set $chestuse to "squeezed">>
<<else>>
The $tentacle3 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<else>>
The $tentacle3 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<elseif $rng lte 40>>
<<if $position isnot "wall">>
The $tentacle3 tentacle winds its way around your chest, beneath your <<breastsstop>><<neutral 1>><<set $tentacle3shaft to "chest">>
<<else>>
The $tentacle3 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<elseif $rng lte 50>>
The $tentacle3 tentacle winds its way around your waist.<<neutral 1>><<set $tentacle3shaft to "waist">>
<<elseif $rng lte 60>>
<<if $position isnot "wall">>
<<if $head is 0>>
The $tentacle3 tentacle winds its way around your neck, <span class="blue">restraining your head.</span><<neutral 1>><<set $tentacle3shaft to "neck">><<set $head to "grappled">>
<<else>>
The $tentacle3 tentacle winds its way around your shoulders.<<neutral 1>><<set $tentacle3shaft to "shoulders">>
<</if>>
<<else>>
The $tentacle3 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<elseif $rng lte 70>>
The $tentacle3 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<<elseif $rng lte 80>>
<<if $leftleg is 0>>
The $tentacle3 tentacle winds its way around your left leg, <span class="blue">restraining it.</span><<neutral 1>><<feettentacledisable>><<set $tentacle3shaft to "leftleg">><<set $leftleg to "grappled">>
<<else>>
The $tentacle3 tentacle tickles your feet.<<neutral 1>>
<</if>>
<<elseif $rng lte 85>>
<<if $rightleg is 0>>
The $tentacle3 tentacle winds its way around your right leg, <span class="blue">restraining it.</span><<neutral 1>><<feettentacledisable>><<set $tentacle3shaft to "rightleg">><<set $rightleg to "grappled">>
<<else>>
The $tentacle3 tentacle tickles your feet.<<neutral 1>>
<</if>>
<<elseif $rng lte 90>>
<<if $leftarm is 0>>
The $tentacle3 tentacle winds its way around your left arm, <span class="blue">restraining it.</span><<neutral 1>><<leftarmtentacledisable>><<set $tentacle3shaft to "leftarm">><<set $leftarm to "grappled">><<set $leftarmstate to 0>>
<<else>>
The $tentacle3 tentacle tickles your armpit.<<neutral 1>>
<</if>>
<<elseif $rng lte 95>>
<<if $rightarm is 0>>
The $tentacle3 tentacle winds its way around your right arm, <span class="blue">restraining it.</span><<rightarmtentacledisable>><<neutral 1>><<set $tentacle3shaft to "rightarm">><<set $rightarm to "grappled">><<set $rightarmstate to 0>>
<<else>>
The $tentacle3 tentacle tickles your armpit.<<neutral 1>>
<</if>>
<<elseif $rng lte 100>>
The $tentacle3 tentacle <<slithers>> against your <<bottomstop>><<neutral 1>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "tentacle3default">><<nobr>>
<<set $rng to random(1, 100)>>
<<if $rng gte 90>>
then squirts a warm fluid over your neck.<<neutral 1>><<set $neckgoo += 1>><<set $tentacle3health -= 1>><<neckejacstat>><<ejacstat>>
<<elseif $rng gte 80>>
then squirts a warm fluid over your right arm.<<neutral 1>><<set $rightarmgoo += 1>><<set $tentacle3health -= 1>><<handejacstat>><<ejacstat>>
<<elseif $rng gte 70>>
then squirts a warm fluid over your left arm.<<neutral 1>><<set $leftarmgoo += 1>><<set $tentacle3health -= 1>><<handejacstat>><<ejacstat>>
<<elseif $rng gte 60>>
then squirts a warm fluid over your thighs.<<neutral 1>><<set $thighgoo += 1>><<set $tentacle3health -= 1>><<thighejacstat>><<ejacstat>>
<<elseif $rng gte 50>>
then squirts a warm fluid over your <<bottomstop>><<neutral 1>><<set $bottomgoo += 1>><<set $tentacle3health -= 1>><<bottomejacstat>><<ejacstat>>
<<elseif $rng gte 40>>
then squirts a warm fluid over your tummy.<<neutral 1>><<set $tummygoo += 1>><<set $tentacle3health -= 1>><<tummyejacstat>><<ejacstat>>
<<elseif $rng gte 30>>
then squirts a warm fluid over your chest.<<neutral 1>><<set $chestgoo += 1>><<set $tentacle3health -= 1>><<chestejacstat>><<ejacstat>>
<<elseif $rng gte 20>>
then squirts a warm fluid over your face.<<neutral 1>><<set $facegoo += 1>><<set $tentacle3health -= 1>><<faceejacstat>><<ejacstat>>
<<elseif $rng gte 10>>
then squirts a warm fluid over your hair.<<neutral 1>><<set $hairgoo += 1>><<set $tentacle3health -= 1>><<hairejacstat>><<ejacstat>>
<<else>>
then squirts a warm fluid over your feet.<<neutral 1>><<set $feetgoo += 1>><<set $tentacle3health -= 1>><<feetejacstat>><<ejacstat>>
<</if>>
<</nobr>><</widget>>
<<widget "tentacle3disable">><<nobr>>
<<if $tentacle3head is "feet">>
<<set $leftleg to 0>>
<<set $rightleg to 0>>
<<set $feetstate to 0>>
<</if>>
<<if $tentacle3head is "leftarm">>
<<set $leftarm to 0>>
<<set $leftarmstate to 0>>
<</if>>
<<if $tentacle3head is "rightarm">>
<<set $rightarm to 0>>
<<set $rightarmstate to 0>>
<</if>>
<<if $tentacle3head is "leftnipplesuck">>
<<set $leftnipple to 0>>
<</if>>
<<if $tentacle3head is "rightnipplesuck">>
<<set $rightnipple to 0>>
<</if>>
<<if $tentacle3head is "leftnipple">>
<<set $leftnipple to 0>>
<</if>>
<<if $tentacle3head is "rightnipple">>
<<set $rightnipple to 0>>
<</if>>
<<if $tentacle3head is "chest">>
<<set $chestuse to 0>>
<</if>>
<<if $tentacle3head is "mouthentrance">>
<<set $mouthuse to 0>>
<<set $mouthstate to 0>>
<</if>>
<<if $tentacle3head is "mouthimminent">>
<<set $mouthuse to 0>>
<<set $mouthstate to 0>>
<</if>>
<<if $tentacle3head is "mouth">>
<<set $mouthuse to 0>>
<<set $mouthstate to 0>>
<</if>>
<<if $tentacle3head is "mouthdeep">>
<<set $mouthuse to 0>>
<<set $mouthstate to 0>>
<</if>>
<<if $tentacle3head is "anusentrance">>
<<set $anususe to 0>>
<<set $anusstate to 0>>
<</if>>
<<if $tentacle3head is "anusimminent">>
<<set $anususe to 0>>
<<set $anusstate to 0>>
<</if>>
<<if $tentacle3head is "anus">>
<<set $anususe to 0>>
<<set $anusstate to 0>>
<</if>>
<<if $tentacle3head is "anusdeep">>
<<set $anususe to 0>>
<<set $anusstate to 0>>
<</if>>
<<if $tentacle3head is "vaginaentrance">>
<<set $vaginause to 0>>
<<set $vaginastate to 0>>
<</if>>
<<if $tentacle3head is "vaginaimminent">>
<<set $vaginause to 0>>
<<set $vaginastate to 0>>
<</if>>
<<if $tentacle3head is "vagina">>
<<set $vaginause to 0>>
<<set $vaginastate to 0>>
<</if>>
<<if $tentacle3head is "vaginadeep">>
<<set $vaginause to 0>>
<<set $vaginastate to 0>>
<</if>>
<<if $tentacle3head is "penisentrance">>
<<set $penisuse to 0>>
<<set $penisstate to 0>>
<</if>>
<<if $tentacle3head is "penisimminent">>
<<set $penisuse to 0>>
<<set $penisstate to 0>>
<</if>>
<<if $tentacle3head is "penis">>
<<set $penisuse to 0>>
<<set $penisstate to 0>>
<</if>>
<<if $tentacle3head is "penisdeep">>
<<set $penisuse to 0>>
<<set $penisstate to 0>>
<</if>>
<<if $tentacle3head is "vaginarub">>
<<set $vaginause to 0>>
<<set $thighuse to 0>>
<</if>>
<<if $tentacle3head is "penisrub">>
<<set $penisuse to 0>>
<<set $thighuse to 0>>
<</if>>
<<if $tentacle3head is "bottomrub">>
<<set $anususe to 0>>
<<set $bottomuse to 0>>
<</if>>
<<if $tentacle3shaft is "breasts">>
<<set $chestuse to 0>>
<</if>>
<<if $tentacle3shaft is "neck" and $head isnot "bound">>
<<set $head to 0>>
<</if>>
<<if $tentacle3shaft is "leftleg" and $leftleg isnot "bound">>
<<set $leftleg to 0>>
<</if>>
<<if $tentacle3shaft is "rightleg" and $rightleg isnot "bound">>
<<set $rightleg to 0>>
<</if>>
<<if $tentacle3shaft is "leftarm" and $leftarm isnot "bound">>
<<set $leftarm to 0>>
<</if>>
<<if $tentacle3shaft is "rightarm" and $rightarm isnot "bound">>
<<set $rightarm to 0>>
<</if>>
<<if $tentacle3head is "chest">>
<<set $breastuse to 0>>
<</if>>
<<set $tentacle3shaft to 0>>
<<set $tentacle3head to 0>>
<</nobr>><</widget>>
<<widget "actionstentacle3lefthand">><<nobr>>
<<if $leftarm is 0 and $tentacle3shaft isnot "finished">>
<<if $leftactiondefault is "lefthittentacle3">>
| <label><span class="def">Strike the $tentacle3 tentacle</span> <<radiobutton "$leftaction" "lefthittentacle3" checked>></label>
<<else>>
| <label><span class="def">Strike the $tentacle3 tentacle</span> <<radiobutton "$leftaction" "lefthittentacle3">></label>
<</if>>
<<if $leftactiondefault is "leftgrabtentacle3">>
| <label><span class="sub">Grab the $tentacle3 tentacle</span> <<radiobutton "$leftaction" "leftgrabtentacle3" checked>></label>
<<else>>
| <label><span class="sub">Grab the $tentacle3 tentacle</span> <<radiobutton "$leftaction" "leftgrabtentacle3">></label>
<</if>>
<<elseif $leftarm is "tentacle3">>You hold the $tentacle3 tentacle in your left hand.<br>
<<if $leftactiondefault is "leftrubtentacle3">>
| <label><span class="sub">Milk it</span> <<radiobutton "$leftaction" "leftrubtentacle3" checked>></label>
<<else>>
| <label><span class="sub">Milk it</span> <<radiobutton "$leftaction" "leftrubtentacle3">></label>
<</if>>
<<if $leftactiondefault is "leftstoptentacle3">>
| <label><span class="neutral">Let go</span> <<radiobutton "$leftaction" "leftstoptentacle3" checked>></label>
<<else>>
| <label><span class="neutral">Let go</span> <<radiobutton "$leftaction" "leftstoptentacle3">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle3righthand">><<nobr>>
<<if $rightarm is 0 and $tentacle3shaft isnot "finished">>
<<if $rightactiondefault is "righthittentacle3">>
| <label><span class="def">Strike the $tentacle3 tentacle</span> <<radiobutton "$rightaction" "righthittentacle3" checked>></label>
<<else>>
| <label><span class="def">Strike the $tentacle3 tentacle</span> <<radiobutton "$rightaction" "righthittentacle3">></label>
<</if>>
<<if $rightactiondefault is "rightgrabtentacle3">>
| <label><span class="sub">Grab the $tentacle3 tentacle</span> <<radiobutton "$rightaction" "rightgrabtentacle3" checked>></label>
<<else>>
| <label><span class="sub">Grab the $tentacle3 tentacle</span> <<radiobutton "$rightaction" "rightgrabtentacle3">></label>
<</if>>
<<elseif $rightarm is "tentacle3">>You hold the $tentacle3 tentacle in your right hand.<br>
<<if $rightactiondefault is "rightrubtentacle3">>
| <label><span class="sub">Milk it</span> <<radiobutton "$rightaction" "rightrubtentacle3" checked>></label>
<<else>>
| <label><span class="sub">Milk it</span> <<radiobutton "$rightaction" "rightrubtentacle3">></label>
<</if>>
<<if $rightactiondefault is "rightstoptentacle3">>
| <label><span class="neutral">Let go</span> <<radiobutton "$rightaction" "rightstoptentacle3" checked>></label>
<<else>>
| <label><span class="neutral">Let go</span> <<radiobutton "$rightaction" "rightstoptentacle3">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle3legs">><<nobr>>
<<if $leftleg is 0 and $rightleg is 0 and $tentacle3shaft isnot "finished">>
<<if $feetactiondefault is "feethittentacle3">>
| <label><span class="def">Kick the $tentacle3 tentacle</span> <<radiobutton "$feetaction" "feethittentacle3" checked>></label>
<<else>>
| <label><span class="def">Kick the $tentacle3 tentacle</span> <<radiobutton "$feetaction" "feethittentacle3">></label>
<</if>>
<<if $feetactiondefault is "feetgrabtentacle3">>
| <label><span class="sub">Grab the $tentacle3 tentacle</span> <<radiobutton "$feetaction" "feetgrabtentacle3" checked>></label>
<<else>>
| <label><span class="sub">Grab the $tentacle3 tentacle</span> <<radiobutton "$feetaction" "feetgrabtentacle3">></label>
<</if>>
<<elseif $leftleg is 0 and $tentacle3shaft isnot "finished">>
<<if $feetactiondefault is "feethittentacle3">>
| <label><span class="def">Kick the $tentacle3 tentacle</span> <<radiobutton "$feetaction" "feethittentacle3" checked>></label>
<<else>>
| <label><span class="def">Kick the $tentacle3 tentacle</span> <<radiobutton "$feetaction" "feethittentacle3">></label>
<</if>>
<<elseif $rightleg is 0 and $tentacle3shaft isnot "finished">>
<<if $feetactiondefault is "feethittentacle3">>
| <label><span class="def">Kick the $tentacle3 tentacle</span> <<radiobutton "$feetaction" "feethittentacle3" checked>></label>
<<else>>
| <label><span class="def">Kick the $tentacle3 tentacle</span> <<radiobutton "$feetaction" "feethittentacle3">></label>
<</if>>
<<elseif $leftleg is "tentacle3">>You hold the $tentacle3 tentacle between your feet.<br>
<<if $feetactiondefault is "feetrubtentacle3">>
| <label><span class="sub">Milk it</span> <<radiobutton "$feetaction" "feetrubtentacle3" checked>></label>
<<else>>
| <label><span class="sub">Milk it</span> <<radiobutton "$feetaction" "feetrubtentacle3">></label>
<</if>>
<<if $feetactiondefault is "feetstoptentacle3">>
| <label><span class="neutral">Let go</span> <<radiobutton "$feetaction" "feetstoptentacle3" checked>></label>
<<else>>
| <label><span class="neutral">Let go</span> <<radiobutton "$feetaction" "feetstoptentacle3">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle3mouth">><<nobr>>
<<if $tentacle3head is "mouthentrance">>
<<if $mouthactiondefault is "mouthlicktentacle3">>
| <label><span class="sub">Lick it</span> <<radiobutton "$mouthaction" "mouthlicktentacle3" checked>></label>
<<else>>
| <label><span class="sub">Lick it</span> <<radiobutton "$mouthaction" "mouthlicktentacle3">></label>
<</if>>
<<if $head is "grappled">>
<<else>>
<<if $mouthactiondefault is "mouthpullawaytentacle3">>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "mouthpullawaytentacle3" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "mouthpullawaytentacle3">></label>
<</if>>
<</if>>
<<elseif $tentacle3head is "mouthimminent">>
<<if $mouthactiondefault is "mouthkisstentacle3">>
| <label><span class="sub">Kiss it</span> <<radiobutton "$mouthaction" "mouthkisstentacle3" checked>></label>
<<else>>
| <label><span class="sub">Kiss it</span> <<radiobutton "$mouthaction" "mouthkisstentacle3">></label>
<</if>>
<<if $head is "grappled">>
<<else>>
<<if $mouthactiondefault is "mouthpullawaytentacle3">>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "mouthpullawaytentacle3" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "mouthpullawaytentacle3">></label>
<</if>>
<</if>>
<<elseif $tentacle3head is "mouth">>
<<if $mouthactiondefault is "mouthcooperatetentacle3">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$mouthaction" "mouthcooperatetentacle3" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$mouthaction" "mouthcooperatetentacle3">></label>
<</if>>
<<if $mouthactiondefault is "mouthbitetentacle3">>
| <label><span class="def">Bite</span> <<radiobutton "$mouthaction" "mouthbitetentacle3" checked>></label>
<<else>>
| <label><span class="def">Bite</span> <<radiobutton "$mouthaction" "mouthbitetentacle3">></label>
<</if>>
<<elseif $tentacle3head is "mouthdeep">>
<<if $mouthactiondefault is "mouthcooperatetentacle3">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$mouthaction" "mouthcooperatetentacle3" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$mouthaction" "mouthcooperatetentacle3">></label>
<</if>>
<<if $mouthactiondefault is "mouthbitetentacle3">>
| <label><span class="def">Bite</span> <<radiobutton "$mouthaction" "mouthbitetentacle3" checked>></label>
<<else>>
| <label><span class="def">Bite</span> <<radiobutton "$mouthaction" "mouthbitetentacle3">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle3vagina">><<nobr>>
<<if $tentacle3head is "vaginaentrance">>
<<if $vaginaactiondefault is "vaginarubtentacle3">>
| <label><span class="sub">Rub</span> <<radiobutton "$vaginaaction" "vaginarubtentacle3" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$vaginaaction" "vaginarubtentacle3">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $vaginaactiondefault is "vaginapullawaytentacle3">>
| <label><span class="brat">Pull away</span> <<radiobutton "$vaginaaction" "vaginapullawaytentacle3" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$vaginaaction" "vaginapullawaytentacle3">></label>
<</if>>
<</if>>
<<elseif $tentacle3head is "vaginaimminent">>
<<if $vaginaactiondefault is "vaginarubtentacle3">>
| <label><span class="sub">Rub</span> <<radiobutton "$vaginaaction" "vaginarubtentacle3" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$vaginaaction" "vaginarubtentacle3">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $vaginaactiondefault is "vaginapullawaytentacle3">>
| <label><span class="brat">Pull away</span> <<radiobutton "$vaginaaction" "vaginapullawaytentacle3" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$vaginaaction" "vaginapullawaytentacle3">></label>
<</if>>
<</if>>
<<elseif $tentacle3head is "vagina">>
<<if $vaginaactiondefault is "vaginacooperatetentacle3">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$vaginaaction" "vaginacooperatetentacle3" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$vaginaaction" "vaginacooperatetentacle3">></label>
<</if>>
<<elseif $tentacle3head is "vaginadeep">>
<<if $vaginaactiondefault is "vaginacooperatetentacle3">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$vaginaaction" "vaginacooperatetentacle3" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$vaginaaction" "vaginacooperatetentacle3">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle3penis">><<nobr>>
<<if $tentacle3head is "penisentrance">>
<<if $penisactiondefault is "penisrubtentacle3">>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "penisrubtentacle3" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "penisrubtentacle3">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $penisactiondefault is "penispullawaytentacle3">>
| <label><span class="brat">Pull away</span> <<radiobutton "$penisaction" "penispullawaytentacle3" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$penisaction" "penispullawaytentacle3">></label>
<</if>>
<</if>>
<<elseif $tentacle3head is "penisimminent">>
<<if $penisactiondefault is "penisrubtentacle3">>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "penisrubtentacle3" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "penisrubtentacle3">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $penisactiondefault is "penispullawaytentacle3">>
| <label><span class="brat">Pull away</span> <<radiobutton "$penisaction" "penispullawaytentacle3" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$penisaction" "penispullawaytentacle3">></label>
<</if>>
<</if>>
<<elseif $tentacle3head is "penis">>
<<if $penisactiondefault is "peniscooperatetentacle3">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$penisaction" "peniscooperatetentacle3" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$penisaction" "peniscooperatetentacle3">></label>
<</if>>
<<elseif $tentacle3head is "penisdeep">>
<<if $penisactiondefault is "peniscooperatetentacle3">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$penisaction" "peniscooperatetentacle3" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$penisaction" "peniscooperatetentacle3">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle3anus">><<nobr>>
<<if $tentacle3head is "anusentrance">>
<<if $anusactiondefault is "anusrubtentacle3">>
| <label><span class="sub">Rub</span> <<radiobutton "$anusaction" "anusrubtentacle3" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$anusaction" "anusrubtentacle3">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $anusactiondefault is "anuspullawaytentacle3">>
| <label><span class="brat">Pull away</span> <<radiobutton "$anusaction" "anuspullawaytentacle3" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$anusaction" "anuspullawaytentacle3">></label>
<</if>>
<</if>>
<<elseif $tentacle3head is "anusimminent">>
<<if $anusactiondefault is "anusrubtentacle3">>
| <label><span class="sub">Rub</span> <<radiobutton "$anusaction" "anusrubtentacle3" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$anusaction" "anusrubtentacle3">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $anusactiondefault is "anuspullawaytentacle3">>
| <label><span class="brat">Pull away</span> <<radiobutton "$anusaction" "anuspullawaytentacle3" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$anusaction" "anuspullawaytentacle3">></label>
<</if>>
<</if>>
<<elseif $tentacle3head is "anus">>
<<if $anusactiondefault is "anuscooperatetentacle3">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$anusaction" "anuscooperatetentacle3" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$anusaction" "anuscooperatetentacle3">></label>
<</if>>
<<elseif $tentacle3head is "anusdeep">>
<<if $anusactiondefault is "anuscooperatetentacle3">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$anusaction" "anuscooperatetentacle3" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$anusaction" "anuscooperatetentacle3">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle3thighs">><<nobr>>
<<if $tentacle3head is "penisrub">>
<<if $thighactiondefault is "penisrubtentacle3">>
| <label><span class="sub">Rub</span> <<radiobutton "$thighaction" "penisrubtentacle3" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$thighaction" "penisrubtentacle3">></label>
<</if>>
<<elseif $tentacle3head is "vaginarub">>
<<if $thighactiondefault is "vaginarubtentacle3">>
| <label><span class="sub">Rub</span> <<radiobutton "$thighaction" "vaginarubtentacle3" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$thighaction" "vaginarubtentacle3">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle3bottom">><<nobr>>
<<if $tentacle3head is "bottomrub">>
<<if $bottomactiondefault is "bottomrubtentacle3">>
| <label><span class="sub">Rub</span> <<radiobutton "$bottomaction" "bottomrubtentacle3" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$bottomaction" "bottomrubtentacle3">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle3chest">><<nobr>>
<<if $tentacle3head is "chest">>
<<if $chestactiondefault is "chestrubtentacle3">>
| <label><span class="sub">Rub</span> <<radiobutton "$chestaction" "chestrubtentacle3" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$chestaction" "chestrubtentacle3">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "effectstentacle3">><<nobr>>
<<if $leftaction is "lefthittentacle3">><<set $leftaction to 0>><<set $leftactiondefault to "lefthittentacle3">>You strike the $tentacle3 tentacle with your left hand and it reels away from you.<<defiance 2>><<set $speechhit to 1>><<tentacle3disable>><<set $attackstat += 1>><<set $tentacle3health -= 1>>
<<if $rng lte ($physique / 200)>>
<<set $tentacle3health -= 1>>
<</if>>
<</if>>
<<if $rightaction is "righthittentacle3">><<set $rightaction to 0>><<set $rightactiondefault to "righthittentacle3">>You strike the $tentacle3 tentacle with your right hand and it reels away from you.<<defiance 2>><<set $speechhit to 1>><<tentacle3disable>><<set $attackstat += 1>><<set $tentacle3health -= 1>>
<<if $rng lte ($physique / 200)>>
<<set $tentacle3health -= 1>>
<</if>>
<</if>>
<<if $leftaction is "leftgrabtentacle3">><<set $leftaction to 0>><<set $leftactiondefault to "leftrubtentacle3">><<submission 1>><<handstat>><span class="lblue">You <<handtext>> grab the $tentacle3 tentacle with your left hand.</span><<tentacle3disable>><<set $leftarm to "tentacle3">><<set $tentacle3head to "leftarm">><<handstat>><<set $leftarmstate to "tentacle">>
<</if>>
<<if $rightaction is "rightgrabtentacle3">><<set $rightaction to 0>><<set $rightactiondefault to "rightrubtentacle3">><<submission 1>><<handstat>><span class="lblue">You <<handtext>> grab the $tentacle3 tentacle with your right hand.</span><<tentacle3disable>><<set $rightarm to "tentacle3">><<set $tentacle3head to "rightarm">><<handstat>><<set $rightarmstate to "tentacle">>
<</if>>
<<if $leftaction is "leftrubtentacle3">><<set $leftaction to 0>><<set $leftactiondefault to "leftrubtentacle3">><<handskilluse>><<submission 1>>You <<handtext>> squeeze the $tentacle3 tentacle in your left hand and rub up and down its length.<<set $rng to random(1, 100)>>
<<if $handskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $rightarmgoo += 1>><<set $tentacle3health -= 3>><<handejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $rightaction is "rightrubtentacle3">><<set $rightaction to 0>><<set $rightactiondefault to "rightrubtentacle3">><<handskilluse>><<submission 1>>You <<handtext>> squeeze the $tentacle3 tentacle in your right hand and rub up and down its length.<<set $rng to random(1, 100)>>
<<if $handskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $rightarmgoo += 1>><<set $tentacle3health -= 3>><<handejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $leftaction is "leftstoptentacle3">><<set $leftaction to 0>><<set $leftactiondefault to "leftstoptentacle3">>You release the $tentacle3 tentacle from your left hand.<<tentacle3disable>>
<</if>>
<<if $rightaction is "rightstoptentacle3">><<set $rightaction to 0>><<set $rightactiondefault to "rightstoptentacle3">>You release the $tentacle3 tentacle from your right hand.<<tentacle3disable>>
<</if>>
<<if $feetaction is "feethittentacle3">><<set $feetaction to 0>><<set $feetactiondefault to "feethittentacle3">>You kick the $tentacle3 tentacle and it reels away from you.<<defiance 2>><<set $speechhit to 1>><<tentacle3disable>><<set $attackstat += 1>><<set $tentacle3health -= 1>>
<<if $rng lte ($physique / 200)>>
<<set $tentacle3health -= 1>>
<</if>>
<</if>>
<<if $feetaction is "feetgrabtentacle3">><<set $feetaction to 0>><<set $feetactiondefault to "feetrubtentacle3">><<submission 1>><<feetstat>><span class="lblue">You <<feettext>> grab the $tentacle3 tentacle between your feet.</span><<tentacle3disable>><<set $leftleg to "tentacle3">><<set $rightleg to "tentacle3">><<set $tentacle3head to "feet">><<feetstat>><<set $feetstate to "tentacle">>
<</if>>
<<if $feetaction is "feetrubtentacle3">><<set $feetaction to 0>><<set $feetactiondefault to "feetrubtentacle3">><<feetskilluse>><<submission 1>>You <<feettext>> squeeze the $tentacle3 tentacle between your feet and rub up and down its length.<<set $rng to random(1, 100)>>
<<if $feetskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $feetgoo += 1>><<set $tentacle3health -= 3>><<feetejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $feetaction is "feetstoptentacle3">><<set $feetaction to 0>><<set $feetactiondefault to "feetstoptentacle3">>You let go of the $tentacle3 tentacle between your feet.<<tentacle3disable>>
<</if>>
<<if $mouthaction is "mouthlicktentacle3">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthlicktentacle3">>
<<submission 2>><<oralskilluse>>You <<oraltext>> lick the tip of the $tentacle3 tentacle.<<set $rng to random(1, 100)>>
<<if $oralskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your face.</span><<set $facegoo += 1>><<set $tentacle3health -= 3>><<faceejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $mouthaction is "mouthkisstentacle3">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthkisstentacle3">>
<<submission 3>><<oralskilluse>>You <<oraltext>> kiss the tip of the $tentacle3 tentacle.<<set $rng to random(1, 100)>>
<<if $oralskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your face.</span><<set $facegoo += 1>><<set $tentacle3health -= 3>><<faceejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $mouthaction is "mouthcooperatetentacle3">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthcooperatetentacle3">>
<<sex 5>><<oralskilluse>>You <<oraltext>> suck the $tentacle3 tentacle invading your mouth.<<set $rng to random(1, 100)>>
<<if $oralskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip and into your mouth.</span><<set $tentacle3health -= 3>><<set $drugged += 3>><<set $mouthgoo += 1>><<oralejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $mouthaction is "mouthpullawaytentacle3">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthpullawaytentacle3">><<brat 1>><span class="teal">You pull away from the $tentacle3 tentacle threatening your mouth.</span><<tentacle3disable>>
<</if>>
<<if $mouthaction is "mouthbitetentacle3">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthbitetentacle3">><<defiance 5>>You bite down on the $tentacle3 tentacle invading your mouth. <span class="teal">It recoils immediately.</span><<tentacle3disable>><<set $attackstat += 1>><<set $tentacle3health -= 1>>
<<if $rng lte ($physique / 200)>>
<<set $tentacle3health -= 1>>
<</if>>
<</if>>
<<if $vaginaaction is "vaginarubtentacle3">><<set $vaginaaction to 0>><<set $vaginaactiondefault to "vaginarubtentacle3">>
<<submission 2>><<vaginalskilluse>>You <<vaginaltext>> rub the tip of the $tentacle3 tentacle with your <<pussystop>><<set $rng to random(1, 100)>>
<<if $vaginalskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $vaginaoutsidegoo += 1>><<set $tentacle3health -= 3>><<vaginalentranceejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $vaginaaction is "vaginacooperatetentacle3">><<set $vaginaaction to 0>><<set $vaginaactiondefault to "vaginacooperatetentacle3">>
<<sex 5>><<vaginalskilluse>>You <<vaginaltext>> push back against the $tentacle3 tentacle invading your <<pussystop>><<set $rng to random(1, 100)>>
<<if $vaginalskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, flooding your womb with its warmth.</span><<set $tentacle3health -= 3>><<set $drugged += 3>><<set $vaginagoo += 1>><<vaginalejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $vaginaaction is "vaginapullawaytentacle3">><<set $vaginaaction to 0>><<set $vaginaactiondefault to "vaginapullawaytentacle3">><<brat 1>><span class="teal">You pull away from the $tentacle3 tentacle threatening your <<pussystop>></span><<tentacle3disable>>
<</if>>
<<if $penisaction is "penisrubtentacle3">><<set $penisaction to 0>><<set $penisactiondefault to "penisrubtentacle3">>
<<submission 2>><<penileskilluse>>You <<peniletext>> rub the tip of the $tentacle3 tentacle with your <<penisstop>><<set $rng to random(1, 100)>>
<<if $penileskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $penisgoo += 1>><<set $tentacle3health -= 3>><<penileejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $penisaction is "peniscooperatetentacle3">><<set $penisaction to 0>><<set $penisactiondefault to "peniscooperatetentacle3">>
<<sex 5>><<penileskilluse>>You <<peniletext>> push back against the $tentacle3 tentacle engulfing your <<penisstop>><<set $rng to random(1, 100)>>
<<if $penileskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your groin.</span><<set $tentacle3health -= 3>><<set $penisgoo += 1>><<penileejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $penisaction is "penispullawaytentacle3">><<set $penisaction to 0>><<set $penisactiondefault to "penispullawaytentacle3">><<brat 1>><span class="teal">You pull away from the $tentacle3 tentacle threatening your <<penisstop>></span><<tentacle3disable>>
<</if>>
<<if $anusaction is "anusrubtentacle3">><<set $anusaction to 0>><<set $anusactiondefault to "anusrubtentacle3">>
<<submission 2>><<analskilluse>>You <<analtext>> rub the tip of the $tentacle3 tentacle with your <<bottomstop>><<set $rng to random(1, 100)>>
<<if $analskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your <<bottomstop>></span><<set $bottomgoo += 1>><<set $tentacle3health -= 3>><<bottomejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $anusaction is "anuscooperatetentacle3">><<set $anusaction to 0>><<set $anusactiondefault to "anuscooperatetentacle3">>
<<sex 5>><<analskilluse>>You <<analtext>> push back against the $tentacle3 tentacle invading your <<bottomstop>><<set $rng to random(1, 100)>>
<<if $analskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, flooding your bowels with its warmth.</span><<set $tentacle3health -= 3>><<set $drugged += 3>><<set $anusgoo += 1>><<analejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $anusaction is "anuspullawaytentacle3">><<set $anusaction to 0>><<set $anusactiondefault to "anuspullawaytentacle3">><<brat 1>><span class="teal">You pull away from the $tentacle3 tentacle threatening your <<bottomstop>></span><<tentacle3disable>>
<</if>>
<<if $thighaction is "penisrubtentacle3">><<set $thighaction to 0>><<set $thighactiondefault to "penisrubtentacle3">>
<<submission 3>><<thighskilluse>>You <<thightext>> rub the $tentacle3 tentacle between your thighs.<<set $rng to random(1, 100)>>
<<if $thighskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your tummy.</span><<set $tentacle3health -= 3>><<set $tummygoo += 1>><<tummyejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $thighaction is "vaginarubtentacle3">><<set $thighaction to 0>><<set $thighactiondefault to "vaginarubtentacle3">>
<<submission 3>><<thighskilluse>>You <<thightext>> rub the $tentacle3 tentacle between your thighs.<<set $rng to random(1, 100)>>
<<if $thighskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your tummy.</span><<set $tentacle3health -= 3>><<set $tummygoo += 1>><<tummyejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $bottomaction is "bottomrubtentacle3">><<set $bottomaction to 0>><<set $bottomactiondefault to "bottomrubtentacle3">>
<<submission 3>><<bottomskilluse>>You <<bottomtext>> rub the $tentacle3 tentacle between your cheeks.<<set $rng to random(1, 100)>>
<<if $bottomskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your <<bottomstop>></span><<set $tentacle3health -= 3>><<set $bottomgoo += 1>><<bottomejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $chestaction is "chestrubtentacle3">><<set $chestaction to 0>><<set $chestactiondefault to "chestrubtentacle3">>
<<submission 3>><<chestskilluse>>You <<chesttext>> rub the $tentacle3 tentacle between your <<breastsstop>><<set $rng to random(1, 100)>>
<<if $chestskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your chest.</span><<set $tentacle3health -= 3>><<set $chestgoo += 1>><<chestejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<</nobr>><</widget>>
:: Widgets Combat Tentacle4 [widget]
<<widget "tentacle4">><<nobr>>
<<if $tentacle4health lte 0 and $tentacle4shaft isnot "finished">>
Worn out, the $tentacle4 tentacle retracts from you.
<<tentacle4disable>>
<<set $tentacle4shaft to "finished">>
<<set $tentacle4head to "finished">>
<</if>>
<<if $tentacle4shaft is "tummy">>
The $tentacle4 tentacle <<slithers>> around your tummy,
<</if>>
<<if $tentacle4shaft is "thighs">>
The $tentacle4 tentacle <<slithers>> between your thighs,
<</if>>
<<if $tentacle4shaft is "breasts">>
The $tentacle4 tentacle squeezes your breasts together,
<</if>>
<<if $tentacle4shaft is "chest">>
The $tentacle4 tentacle <<slithers>> around your chest,
<</if>>
<<if $tentacle4shaft is "waist">>
The $tentacle4 tentacle <<slithers>> around your waist,
<</if>>
<<if $tentacle4shaft is "neck">>
The $tentacle4 tentacle <<slithers>> around your neck,
<</if>>
<<if $tentacle4shaft is "shoulders">>
The $tentacle4 tentacle <<slithers>> around your shoulders,
<</if>>
<<if $tentacle4shaft is "leftleg">>
The $tentacle4 tentacle <<slithers>> around your left leg,
<</if>>
<<if $tentacle4shaft is "rightleg">>
The $tentacle4 tentacle <<slithers>> around your right leg,
<</if>>
<<if $tentacle4shaft is "leftarm">>
The $tentacle4 tentacle <<slithers>> around your left arm,
<</if>>
<<if $tentacle4shaft is "rightarm">>
The $tentacle4 tentacle <<slithers>> around your right arm,
<</if>>
<<if $tentacle4head is "leftarm">>
The $tentacle4 tentacle writhes in your left hand.<<neutral 5>>
<</if>>
<<if $tentacle4head is "rightarm">>
The $tentacle4 tentacle writhes in your right hand.<<neutral 5>>
<</if>>
<<if $tentacle4head is "feet">>
The $tentacle4 tentacle writhes between your feet.<<neutral 5>>
<</if>>
<<if $tentacle4head is "leftnipplesuck">>
and up to your <<breastscomma>> where it suckles your left nipple.<<neutral 3>>
<</if>>
<<if $tentacle4head is "rightnipplesuck">>
and up to your <<breastscomma>> where it suckles your right nipple.<<neutral 3>>
<</if>>
<<if $tentacle4head is "leftnipple">>
and continues teasing your left nipple. <span class="purple">The tip of the tentacle opens up, latches on, then begins sucking.</span><<neutral 3>><<set $tentacle4head to "leftnipplesuck">><<set $leftnipple to "tentaclesuck">>
<</if>>
<<if $tentacle4head is "rightnipple">>
and continues teasing your right nipple. <span class="purple">The tip of the tentacle opens up, latches on, then begins sucking.</span><<neutral 3>><<set $tentacle4head to "rightnipplesuck">><<set $rightnipple to "tentaclesuck">>
<</if>>
<<if $tentacle4head is "chest">>
<<if $chestuse is "squeezed">>
then up between your <<breastscomma>> rubbing itself between them.<<neutral 2>>
<<else>>
moves away from your <<breasts>><<set $tentacle4head to 0>><<set $breastuse to 0>>
<</if>>
<</if>>
<<if $tentacle4head is "mouthdeep">>
and up into your mouth where it spurts a sweet fluid down your throat at the apex of each thrust.<<set $purity -= 1>><<internalejac>><<sex 5>><<set $drugged += 3>><<set $mouthgoo += 1>><<set $tentacle4health -= 1>>
<</if>>
<<if $tentacle4head is "mouth">>
and continues thrusting into your mouth.<span class="pink"> The tip opens and begins oozing a sweet liquid.</span><<set $purity -= 1>><<internalejac>><<set $mouthstate to "tentacledeep">><<set $tentacle4head to "mouthdeep">><<sex 5>><<oralejacstat>><<ejacstat>>
<</if>>
<<if $tentacle4head is "mouthimminent">>
<<if $oralvirginity is 1>>
<span class="pink"> and thrusts between your lips,</span><span class="red"> penetrating your mouth for the first time.</span><<set $oralvirginity to 0>><<violence 5>>
<<else>>
<span class="pink"> and thrusts between your lips.</span>
<</if>>
<<set $mouthstate to "tentacle">><<set $tentacle4head to "mouth">><<sex 5>><<raped>><<oralstat>>
<</if>>
<<if $tentacle4head is "mouthentrance">>
<span class="purple"> and presses against your lips.</span><<set $mouthstate to "tentacleimminent">><<set $tentacle4head to "mouthimminent">><<neutral 4>>
<</if>>
<<if $tentacle4head is "vaginadeep">>
and <<slithers>> into your <<pussy>> where it pumps a viscous fluid at the apex of each thrust.<<set $purity -= 1>><<internalejac>><<sex 5>><<set $drugged += 3>><<set $vaginagoo += 1>><<set $tentacle4health -= 1>>
<</if>>
<<if $tentacle4head is "vagina">>
and continues thrusting into your <<pussystop>><span class="pink"> The tip opens and begins oozing a viscous liquid.</span><<set $purity -= 1>><<internalejac>><<set $vaginastate to "tentacledeep">><<set $tentacle4head to "vaginadeep">><<sex 5>><<vaginalejacstat>><<ejacstat>>
<</if>>
<<if $tentacle4head is "vaginaimminent">>
<<if $vaginalvirginity is 1>>
<span class="pink"> and thrusts into your <<pussycomma>></span><span class="red"> tearing your hymen and forever robbing you of your purity.</span><<set $vaginalvirginity to 0>><<violence 100>>
<<else>>
<span class="pink"> and thrusts into your <<pussystop>></span>
<</if>>
<<set $vaginastate to "tentacle">><<set $tentacle4head to "vagina">><<sex 5>><<raped>><<vaginaraped>><<vaginalstat>><<violence 1>>
<</if>>
<<if $tentacle4head is "vaginaentrance">>
<<if $undertype isnot "chastity">>
<span class="purple"> and presses against your <<pussycomma>> about to penetrate.</span><<set $vaginastate to "tentacleimminent">><<set $tentacle4head to "vaginaimminent">><<neutral 4>>
<<else>>
and tries to find a way inside. Failing, it lashes at the metal.<<set $underintegrity -= 10>><<violence 1>>
<</if>>
<</if>>
<<if $tentacle4head is "penisdeep">>
and continues thrusting against your <<peniscomma>> caressing and kneading your length.<<sex 5>>
<</if>>
<<if $tentacle4head is "penis">>
and continues thrusting against your <<penisstop>><span class="pink"> It sucks and kneads your length, trying to milk you of your cum.</span><<set $penisstate to "tentacledeep">><<set $tentacle4head to "penisdeep">><<sex 5>>
<</if>>
<<if $tentacle4head is "penisimminent">>
<<if $penilevirginity is 1>>
<span class="pink"> and thrusts against your <<peniscomma>> swallowing you to the base and </span><span class="red"> tearing the membrane between your glans and foreskin, forever robbing you of your purity.</span><<set $penilevirginity to 0>><<violence 100>>
<<else>>
<span class="pink"> and thrusts against your <<peniscomma>> swallowing you to the base.</span>
<</if>>
<<set $penisstate to "tentacle">><<set $tentacle4head to "penis">><<sex 5>><<raped>><<penisraped>><<penilestat>><<violence 1>>
<</if>>
<<if $tentacle4head is "penisentrance">>
<<if $undertype isnot "chastity">>
<span class="purple"> and <<slithers>> over to your <<penisstop>> The tip opens and presses against your glans, about to envelop you.</span><<set $penisstate to "tentacleimminent">><<set $tentacle4head to "penisimminent">><<neutral 4>>
<<else>>
and tries to find a way inside. Failing, it lashes at the metal.<<set $underintegrity -= 10>><<violence 1>>
<</if>>
<</if>>
<<if $tentacle4head is "anusdeep">>
and <<slithers>> into your <<bottom>> where it pumps a viscous fluid at the apex of each thrust.<<set $purity -= 1>><<internalejac>><<sex 5>><<set $drugged += 3>><<set $anusgoo += 1>><<set $tentacle4health -= 1>>
<</if>>
<<if $tentacle4head is "anus">>
and continues thrusting into your <<bottomstop>><span class="pink"> The tip opens and begins oozing a viscous liquid.</span><<set $purity -= 1>><<internalejac>><<set $anusstate to "tentacledeep">><<set $tentacle4head to "anusdeep">><<sex 5>><<analejacstat>><<ejacstat>>
<</if>>
<<if $tentacle4head is "anusimminent">>
<<if $analvirginity is 1>>
<span class="pink"> and thrusts into your <<bottomcomma>></span><span class="red"> violating you in a way you hadn't conceived of.</span><<set $analvirginity to 0>><<violence 100>>
<<else>>
<span class="pink"> and thrusts into your <<bottomstop>></span>
<</if>>
<<set $anusstate to "tentacle">><<set $tentacle4head to "anus">><<sex 5>><<raped>><<analstat>><<violence 1>>
<</if>>
<<if $tentacle4head is "anusentrance">>
<<if $analshield is 0>>
<span class="purple"> and presses against your <<bottomcomma>> about to penetrate.</span><<set $anusstate to "tentacleimminent">><<set $tentacle4head to "anusimminent">><<neutral 4>>
<<else>>
and tries to find a way inside. Failing, it lashes at the device.<<set $underintegrity -= 10>><<violence 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $tentacle4head is "vaginarub">>
<<if $rng gte 21>>
and between your thighs where it <<slithers>> against your <<pussycomma>> pressing against your clit.<<sex 3>>
<<else>>
and between your thighs <span class="blue">where it <<slithers>> toward your <<pussystop>></span><<neutral 3>><<set $vaginause to "tentacle">><<set $vaginastate to "tentacleentrance">><<set $tentacle4head to "vaginaentrance">><<set $thighuse to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $tentacle4head is "penisrub">>
<<if $rng gte 21>>
and between your thighs where it <<slithers>> against your <<peniscomma>> coiling around it.<<sex 3>>
<<else>>
and between your thighs <span class="blue">where the tip opens and it <<slithers>> toward your <<penisstop>></span><<neutral 3>><<set $penisuse to "tentacle">><<set $penisstate to "tentacleentrance">><<set $tentacle4head to "penisentrance">><<set $thighuse to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $tentacle4head is "bottomrub">>
<<if $rng gte 21>>
and between your <<bottom>> cheeks where it <<slithers>> against your back.<<sex 3>>
<<else>>
and between your <<bottom>> cheeks, <span class="blue"> toward your anus.</span><<neutral 3>><<set $anususe to "tentacle">><<set $anusstate to "tentacleentrance">><<set $tentacle4head to "anusentrance">><<set $bottomuse to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $tentacle4head is 0 and $tentacle4shaft isnot 0>>
<<if $rng lte 10>>
<<if $chestuse is "squeezed" and $breastuse is 0>>
<<upperslither>><span class="blue">and up between your squeezed <<breastsstop>></span><<set $tentacle4head to "chest">><<neutral 2>><<set $breastuse to "tentacle">><<cheststat>>
<<else>>
<<tentacle4default>>
<</if>>
<<elseif $rng lte 20>>
<<if $leftnipple is 0>>
<<upperslither>> <span class="blue">and teases your left nipple.</span><<neutral 2>><<set $tentacle4head to "leftnipple">><<set $leftnipple to "tentacle">>
<<else>>
<<tentacle4default>>
<</if>>
<<elseif $rng lte 30>>
<<if $rightnipple is 0>>
<<upperslither>> <span class="blue">and teases your right nipple.</span><<neutral 2>><<set $tentacle4head to "rightnipple">><<set $rightnipple to "tentacle">>
<<else>>
<<tentacle4default>>
<</if>>
<<elseif $rng lte 40>>
<<if $mouthuse is 0>>
<<upperslither>> <span class="blue">and up toward your mouth.</span><<neutral 2>><<set $mouthuse to "tentacle">><<set $mouthstate to "tentacleentrance">><<set $tentacle4head to "mouthentrance">>
<<else>>
<<tentacle4default>>
<</if>>
<<elseif $rng lte 50>>
<<if $anususe is 0 and $analdisable is "f">>
<<underslither>> <span class="blue">and <<slithers>> toward your <<bottomstop>></span><<neutral 2>><<set $anususe to "tentacle">><<set $anusstate to "tentacleentrance">><<set $tentacle4head to "anusentrance">>
<<else>>
<<tentacle4default>>
<</if>>
<<elseif $rng lte 60>>
<<if $vaginaexist is 1 and $vaginause is 0>>
<<underslither>> <span class="blue">and <<slithers>> toward your <<pussystop>></span><<neutral 2>><<set $vaginause to "tentacle">><<set $vaginastate to "tentacleentrance">><<set $tentacle4head to "vaginaentrance">>
<<else>>
<<tentacle4default>>
<</if>>
<<elseif $rng lte 70>>
<<if $penisexist is 1 and $penisuse is 0>>
<<underslither>> <span class="blue">and <<slithers>> toward your <<penisstop>></span><<neutral 2>><<set $penisuse to "tentacle">><<set $penisstate to "tentacleentrance">><<set $tentacle4head to "penisentrance">>
<<else>>
<<tentacle4default>>
<</if>>
<<elseif $rng lte 80>>
<<if $thighuse is 0>>
<<if $penisexist is 1 and $penisuse is 0>>
<<underslither>> <span class="blue">and <<slithers>> between your thighs and against your tummy and <<penisstop>></span><<set $penisuse to "tentaclerub">><<set $thighuse to "tentaclerub">><<set $tentacle4head to "penisrub">><<sex 3>><<thighstat>>
<<elseif $vaginaexist is 1 and $vaginause is 0>>
<<underslither>> <span class="blue">and <<slithers>> between your thighs and against your tummy and <<pussystop>></span><<set $vaginause to "tentaclerub">><<set $thighuse to "tentaclerub">><<set $tentacle4head to "vaginarub">><<sex 3>><<thighstat>>
<<else>>
<<tentacle4default>>
<</if>>
<<else>>
<<tentacle4default>>
<</if>>
<<elseif $rng lte 90>>
<<if $bottomuse is 0 and $anususe is 0 and $analdisable is "f">>
<<underslither>> <span class="blue">and <<slithers>> between your <<bottom>> cheeks and against your back.</span><<set $bottomuse to "tentaclerub">><<set $anususe to "tentaclerub">><<set $tentacle4head to "bottomrub">><<sex 1>><<bottomstat>>
<<else>>
<<tentacle4default>>
<</if>>
<<else>>
<<tentacle4default>>
<</if>>
<<elseif $tentacle4head is 0 and $tentacle4shaft is 0>>
<<if $rng lte 10>>
<<if $position isnot "wall">>
The $tentacle4 tentacle winds around your tummy.<<neutral 1>><<set $tentacle4shaft to "tummy">>
<<else>>
The $tentacle4 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<elseif $rng lte 20>>
The $tentacle4 tentacle <<slithers>> between your thighs.<<neutral 1>><<set $tentacle4shaft to "thighs">>
<<elseif $rng lte 30>>
<<if $position isnot "wall">>
<<if $breastsize gte 2 and $chestuse is 0>>
The $tentacle4 tentacle <<slithers>> around your <<breastscomma>> <span class="blue">squeezing them together.</span><<neutral 1>><<set $tentacle4shaft to "breasts">><<set $chestuse to "squeezed">>
<<else>>
The $tentacle4 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<else>>
The $tentacle4 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<elseif $rng lte 40>>
<<if $position isnot "wall">>
The $tentacle4 tentacle winds its way around your chest, beneath your <<breastsstop>><<neutral 1>><<set $tentacle4shaft to "chest">>
<<else>>
The $tentacle4 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<elseif $rng lte 50>>
The $tentacle4 tentacle winds its way around your waist.<<neutral 1>><<set $tentacle4shaft to "waist">>
<<elseif $rng lte 60>>
<<if $position isnot "wall">>
<<if $head is 0>>
The $tentacle4 tentacle winds its way around your neck, <span class="blue">restraining your head.</span><<neutral 1>><<set $tentacle4shaft to "neck">><<set $head to "grappled">>
<<else>>
The $tentacle4 tentacle winds its way around your shoulders.<<neutral 1>><<set $tentacle4shaft to "shoulders">>
<</if>>
<<else>>
The $tentacle4 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<elseif $rng lte 70>>
The $tentacle4 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<<elseif $rng lte 80>>
<<if $leftleg is 0>>
The $tentacle4 tentacle winds its way around your left leg, <span class="blue">restraining it.</span><<neutral 1>><<feettentacledisable>><<set $tentacle4shaft to "leftleg">><<set $leftleg to "grappled">>
<<else>>
The $tentacle4 tentacle tickles your feet.<<neutral 1>>
<</if>>
<<elseif $rng lte 85>>
<<if $rightleg is 0>>
The $tentacle4 tentacle winds its way around your right leg, <span class="blue">restraining it.</span><<neutral 1>><<feettentacledisable>><<set $tentacle4shaft to "rightleg">><<set $rightleg to "grappled">>
<<else>>
The $tentacle4 tentacle tickles your feet.<<neutral 1>>
<</if>>
<<elseif $rng lte 90>>
<<if $leftarm is 0>>
The $tentacle4 tentacle winds its way around your left arm, <span class="blue">restraining it.</span><<neutral 1>><<leftarmtentacledisable>><<set $tentacle4shaft to "leftarm">><<set $leftarm to "grappled">><<set $leftarmstate to 0>>
<<else>>
The $tentacle4 tentacle tickles your armpit.<<neutral 1>>
<</if>>
<<elseif $rng lte 95>>
<<if $rightarm is 0>>
The $tentacle4 tentacle winds its way around your right arm, <span class="blue">restraining it.</span><<rightarmtentacledisable>><<neutral 1>><<set $tentacle4shaft to "rightarm">><<set $rightarm to "grappled">><<set $rightarmstate to 0>>
<<else>>
The $tentacle4 tentacle tickles your armpit.<<neutral 1>>
<</if>>
<<elseif $rng lte 100>>
The $tentacle4 tentacle <<slithers>> against your <<bottomstop>><<neutral 1>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "tentacle4default">><<nobr>>
<<set $rng to random(1, 100)>>
<<if $rng gte 90>>
then squirts a warm fluid over your neck.<<neutral 1>><<set $neckgoo += 1>><<set $tentacle4health -= 1>><<neckejacstat>><<ejacstat>>
<<elseif $rng gte 80>>
then squirts a warm fluid over your right arm.<<neutral 1>><<set $rightarmgoo += 1>><<set $tentacle4health -= 1>><<handejacstat>><<ejacstat>>
<<elseif $rng gte 70>>
then squirts a warm fluid over your left arm.<<neutral 1>><<set $leftarmgoo += 1>><<set $tentacle4health -= 1>><<handejacstat>><<ejacstat>>
<<elseif $rng gte 60>>
then squirts a warm fluid over your thighs.<<neutral 1>><<set $thighgoo += 1>><<set $tentacle4health -= 1>><<thighejacstat>><<ejacstat>>
<<elseif $rng gte 50>>
then squirts a warm fluid over your <<bottomstop>><<neutral 1>><<set $bottomgoo += 1>><<set $tentacle4health -= 1>><<bottomejacstat>><<ejacstat>>
<<elseif $rng gte 40>>
then squirts a warm fluid over your tummy.<<neutral 1>><<set $tummygoo += 1>><<set $tentacle4health -= 1>><<tummyejacstat>><<ejacstat>>
<<elseif $rng gte 30>>
then squirts a warm fluid over your chest.<<neutral 1>><<set $chestgoo += 1>><<set $tentacle4health -= 1>><<chestejacstat>><<ejacstat>>
<<elseif $rng gte 20>>
then squirts a warm fluid over your face.<<neutral 1>><<set $facegoo += 1>><<set $tentacle4health -= 1>><<faceejacstat>><<ejacstat>>
<<elseif $rng gte 10>>
then squirts a warm fluid over your hair.<<neutral 1>><<set $hairgoo += 1>><<set $tentacle4health -= 1>><<hairejacstat>><<ejacstat>>
<<else>>
then squirts a warm fluid over your feet.<<neutral 1>><<set $feetgoo += 1>><<set $tentacle4health -= 1>><<feetejacstat>><<ejacstat>>
<</if>>
<</nobr>><</widget>>
<<widget "tentacle4disable">><<nobr>>
<<if $tentacle4head is "feet">>
<<set $leftleg to 0>>
<<set $rightleg to 0>>
<<set $feetstate to 0>>
<</if>>
<<if $tentacle4head is "leftarm">>
<<set $leftarm to 0>>
<<set $leftarmstate to 0>>
<</if>>
<<if $tentacle4head is "rightarm">>
<<set $rightarm to 0>>
<<set $rightarmstate to 0>>
<</if>>
<<if $tentacle4head is "leftnipplesuck">>
<<set $leftnipple to 0>>
<</if>>
<<if $tentacle4head is "rightnipplesuck">>
<<set $rightnipple to 0>>
<</if>>
<<if $tentacle4head is "leftnipple">>
<<set $leftnipple to 0>>
<</if>>
<<if $tentacle4head is "rightnipple">>
<<set $rightnipple to 0>>
<</if>>
<<if $tentacle4head is "chest">>
<<set $chestuse to 0>>
<</if>>
<<if $tentacle4head is "mouthentrance">>
<<set $mouthuse to 0>>
<<set $mouthstate to 0>>
<</if>>
<<if $tentacle4head is "mouthimminent">>
<<set $mouthuse to 0>>
<<set $mouthstate to 0>>
<</if>>
<<if $tentacle4head is "mouth">>
<<set $mouthuse to 0>>
<<set $mouthstate to 0>>
<</if>>
<<if $tentacle4head is "mouthdeep">>
<<set $mouthuse to 0>>
<<set $mouthstate to 0>>
<</if>>
<<if $tentacle4head is "anusentrance">>
<<set $anususe to 0>>
<<set $anusstate to 0>>
<</if>>
<<if $tentacle4head is "anusimminent">>
<<set $anususe to 0>>
<<set $anusstate to 0>>
<</if>>
<<if $tentacle4head is "anus">>
<<set $anususe to 0>>
<<set $anusstate to 0>>
<</if>>
<<if $tentacle4head is "anusdeep">>
<<set $anususe to 0>>
<<set $anusstate to 0>>
<</if>>
<<if $tentacle4head is "vaginaentrance">>
<<set $vaginause to 0>>
<<set $vaginastate to 0>>
<</if>>
<<if $tentacle4head is "vaginaimminent">>
<<set $vaginause to 0>>
<<set $vaginastate to 0>>
<</if>>
<<if $tentacle4head is "vagina">>
<<set $vaginause to 0>>
<<set $vaginastate to 0>>
<</if>>
<<if $tentacle4head is "vaginadeep">>
<<set $vaginause to 0>>
<<set $vaginastate to 0>>
<</if>>
<<if $tentacle4head is "penisentrance">>
<<set $penisuse to 0>>
<<set $penisstate to 0>>
<</if>>
<<if $tentacle4head is "penisimminent">>
<<set $penisuse to 0>>
<<set $penisstate to 0>>
<</if>>
<<if $tentacle4head is "penis">>
<<set $penisuse to 0>>
<<set $penisstate to 0>>
<</if>>
<<if $tentacle4head is "penisdeep">>
<<set $penisuse to 0>>
<<set $penisstate to 0>>
<</if>>
<<if $tentacle4head is "vaginarub">>
<<set $vaginause to 0>>
<<set $thighuse to 0>>
<</if>>
<<if $tentacle4head is "penisrub">>
<<set $penisuse to 0>>
<<set $thighuse to 0>>
<</if>>
<<if $tentacle4head is "bottomrub">>
<<set $anususe to 0>>
<<set $bottomuse to 0>>
<</if>>
<<if $tentacle4shaft is "breasts">>
<<set $chestuse to 0>>
<</if>>
<<if $tentacle4shaft is "neck" and $head isnot "bound">>
<<set $head to 0>>
<</if>>
<<if $tentacle4shaft is "leftleg" and $leftleg isnot "bound">>
<<set $leftleg to 0>>
<</if>>
<<if $tentacle4shaft is "rightleg" and $rightleg isnot "bound">>
<<set $rightleg to 0>>
<</if>>
<<if $tentacle4shaft is "leftarm" and $leftarm isnot "bound">>
<<set $leftarm to 0>>
<</if>>
<<if $tentacle4shaft is "rightarm" and $rightarm isnot "bound">>
<<set $rightarm to 0>>
<</if>>
<<if $tentacle4head is "chest">>
<<set $breastuse to 0>>
<</if>>
<<set $tentacle4shaft to 0>>
<<set $tentacle4head to 0>>
<</nobr>><</widget>>
<<widget "actionstentacle4lefthand">><<nobr>>
<<if $leftarm is 0 and $tentacle4shaft isnot "finished">>
<<if $leftactiondefault is "lefthittentacle4">>
| <label><span class="def">Strike the $tentacle4 tentacle</span> <<radiobutton "$leftaction" "lefthittentacle4" checked>></label>
<<else>>
| <label><span class="def">Strike the $tentacle4 tentacle</span> <<radiobutton "$leftaction" "lefthittentacle4">></label>
<</if>>
<<if $leftactiondefault is "leftgrabtentacle4">>
| <label><span class="sub">Grab the $tentacle4 tentacle</span> <<radiobutton "$leftaction" "leftgrabtentacle4" checked>></label>
<<else>>
| <label><span class="sub">Grab the $tentacle4 tentacle</span> <<radiobutton "$leftaction" "leftgrabtentacle4">></label>
<</if>>
<<elseif $leftarm is "tentacle4">>You hold the $tentacle4 tentacle in your left hand.<br>
<<if $leftactiondefault is "leftrubtentacle4">>
| <label><span class="sub">Milk it</span> <<radiobutton "$leftaction" "leftrubtentacle4" checked>></label>
<<else>>
| <label><span class="sub">Milk it</span> <<radiobutton "$leftaction" "leftrubtentacle4">></label>
<</if>>
<<if $leftactiondefault is "leftstoptentacle4">>
| <label><span class="neutral">Let go</span> <<radiobutton "$leftaction" "leftstoptentacle4" checked>></label>
<<else>>
| <label><span class="neutral">Let go</span> <<radiobutton "$leftaction" "leftstoptentacle4">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle4righthand">><<nobr>>
<<if $rightarm is 0 and $tentacle4shaft isnot "finished">>
<<if $rightactiondefault is "righthittentacle4">>
| <label><span class="def">Strike the $tentacle4 tentacle</span> <<radiobutton "$rightaction" "righthittentacle4" checked>></label>
<<else>>
| <label><span class="def">Strike the $tentacle4 tentacle</span> <<radiobutton "$rightaction" "righthittentacle4">></label>
<</if>>
<<if $rightactiondefault is "rightgrabtentacle4">>
| <label><span class="sub">Grab the $tentacle4 tentacle</span> <<radiobutton "$rightaction" "rightgrabtentacle4" checked>></label>
<<else>>
| <label><span class="sub">Grab the $tentacle4 tentacle</span> <<radiobutton "$rightaction" "rightgrabtentacle4">></label>
<</if>>
<<elseif $rightarm is "tentacle4">>You hold the $tentacle4 tentacle in your right hand.<br>
<<if $rightactiondefault is "rightrubtentacle4">>
| <label><span class="sub">Milk it</span> <<radiobutton "$rightaction" "rightrubtentacle4" checked>></label>
<<else>>
| <label><span class="sub">Milk it</span> <<radiobutton "$rightaction" "rightrubtentacle4">></label>
<</if>>
<<if $rightactiondefault is "rightstoptentacle4">>
| <label><span class="neutral">Let go</span> <<radiobutton "$rightaction" "rightstoptentacle4" checked>></label>
<<else>>
| <label><span class="neutral">Let go</span> <<radiobutton "$rightaction" "rightstoptentacle4">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle4legs">><<nobr>>
<<if $leftleg is 0 and $rightleg is 0 and $tentacle4shaft isnot "finished">>
<<if $feetactiondefault is "feethittentacle4">>
| <label><span class="def">Kick the $tentacle4 tentacle</span> <<radiobutton "$feetaction" "feethittentacle4" checked>></label>
<<else>>
| <label><span class="def">Kick the $tentacle4 tentacle</span> <<radiobutton "$feetaction" "feethittentacle4">></label>
<</if>>
<<if $feetactiondefault is "feetgrabtentacle4">>
| <label><span class="sub">Grab the $tentacle4 tentacle</span> <<radiobutton "$feetaction" "feetgrabtentacle4" checked>></label>
<<else>>
| <label><span class="sub">Grab the $tentacle4 tentacle</span> <<radiobutton "$feetaction" "feetgrabtentacle4">></label>
<</if>>
<<elseif $leftleg is 0 and $tentacle4shaft isnot "finished">>
<<if $feetactiondefault is "feethittentacle4">>
| <label><span class="def">Kick the $tentacle4 tentacle</span> <<radiobutton "$feetaction" "feethittentacle4" checked>></label>
<<else>>
| <label><span class="def">Kick the $tentacle4 tentacle</span> <<radiobutton "$feetaction" "feethittentacle4">></label>
<</if>>
<<elseif $rightleg is 0 and $tentacle4shaft isnot "finished">>
<<if $feetactiondefault is "feethittentacle4">>
| <label><span class="def">Kick the $tentacle4 tentacle</span> <<radiobutton "$feetaction" "feethittentacle4" checked>></label>
<<else>>
| <label><span class="def">Kick the $tentacle4 tentacle</span> <<radiobutton "$feetaction" "feethittentacle4">></label>
<</if>>
<<elseif $leftleg is "tentacle4">>You hold the $tentacle4 tentacle between your feet.<br>
<<if $feetactiondefault is "feetrubtentacle4">>
| <label><span class="sub">Milk it</span> <<radiobutton "$feetaction" "feetrubtentacle4" checked>></label>
<<else>>
| <label><span class="sub">Milk it</span> <<radiobutton "$feetaction" "feetrubtentacle4">></label>
<</if>>
<<if $feetactiondefault is "feetstoptentacle4">>
| <label><span class="neutral">Let go</span> <<radiobutton "$feetaction" "feetstoptentacle4" checked>></label>
<<else>>
| <label><span class="neutral">Let go</span> <<radiobutton "$feetaction" "feetstoptentacle4">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle4mouth">><<nobr>>
<<if $tentacle4head is "mouthentrance">>
<<if $mouthactiondefault is "mouthlicktentacle4">>
| <label><span class="sub">Lick it</span> <<radiobutton "$mouthaction" "mouthlicktentacle4" checked>></label>
<<else>>
| <label><span class="sub">Lick it</span> <<radiobutton "$mouthaction" "mouthlicktentacle4">></label>
<</if>>
<<if $head is "grappled">>
<<else>>
<<if $mouthactiondefault is "mouthpullawaytentacle4">>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "mouthpullawaytentacle4" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "mouthpullawaytentacle4">></label>
<</if>>
<</if>>
<<elseif $tentacle4head is "mouthimminent">>
<<if $mouthactiondefault is "mouthkisstentacle4">>
| <label><span class="sub">Kiss it</span> <<radiobutton "$mouthaction" "mouthkisstentacle4" checked>></label>
<<else>>
| <label><span class="sub">Kiss it</span> <<radiobutton "$mouthaction" "mouthkisstentacle4">></label>
<</if>>
<<if $head is "grappled">>
<<else>>
<<if $mouthactiondefault is "mouthpullawaytentacle4">>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "mouthpullawaytentacle4" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "mouthpullawaytentacle4">></label>
<</if>>
<</if>>
<<elseif $tentacle4head is "mouth">>
<<if $mouthactiondefault is "mouthcooperatetentacle4">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$mouthaction" "mouthcooperatetentacle4" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$mouthaction" "mouthcooperatetentacle4">></label>
<</if>>
<<if $mouthactiondefault is "mouthbitetentacle4">>
| <label><span class="def">Bite</span> <<radiobutton "$mouthaction" "mouthbitetentacle4" checked>></label>
<<else>>
| <label><span class="def">Bite</span> <<radiobutton "$mouthaction" "mouthbitetentacle4">></label>
<</if>>
<<elseif $tentacle4head is "mouthdeep">>
<<if $mouthactiondefault is "mouthcooperatetentacle4">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$mouthaction" "mouthcooperatetentacle4" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$mouthaction" "mouthcooperatetentacle4">></label>
<</if>>
<<if $mouthactiondefault is "mouthbitetentacle4">>
| <label><span class="def">Bite</span> <<radiobutton "$mouthaction" "mouthbitetentacle4" checked>></label>
<<else>>
| <label><span class="def">Bite</span> <<radiobutton "$mouthaction" "mouthbitetentacle4">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle4vagina">><<nobr>>
<<if $tentacle4head is "vaginaentrance">>
<<if $vaginaactiondefault is "vaginarubtentacle4">>
| <label><span class="sub">Rub</span> <<radiobutton "$vaginaaction" "vaginarubtentacle4" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$vaginaaction" "vaginarubtentacle4">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $vaginaactiondefault is "vaginapullawaytentacle4">>
| <label><span class="brat">Pull away</span> <<radiobutton "$vaginaaction" "vaginapullawaytentacle4" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$vaginaaction" "vaginapullawaytentacle4">></label>
<</if>>
<</if>>
<<elseif $tentacle4head is "vaginaimminent">>
<<if $vaginaactiondefault is "vaginarubtentacle4">>
| <label><span class="sub">Rub</span> <<radiobutton "$vaginaaction" "vaginarubtentacle4" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$vaginaaction" "vaginarubtentacle4">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $vaginaactiondefault is "vaginapullawaytentacle4">>
| <label><span class="brat">Pull away</span> <<radiobutton "$vaginaaction" "vaginapullawaytentacle4" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$vaginaaction" "vaginapullawaytentacle4">></label>
<</if>>
<</if>>
<<elseif $tentacle4head is "vagina">>
<<if $vaginaactiondefault is "vaginacooperatetentacle4">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$vaginaaction" "vaginacooperatetentacle4" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$vaginaaction" "vaginacooperatetentacle4">></label>
<</if>>
<<elseif $tentacle4head is "vaginadeep">>
<<if $vaginaactiondefault is "vaginacooperatetentacle4">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$vaginaaction" "vaginacooperatetentacle4" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$vaginaaction" "vaginacooperatetentacle4">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle4penis">><<nobr>>
<<if $tentacle4head is "penisentrance">>
<<if $penisactiondefault is "penisrubtentacle4">>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "penisrubtentacle4" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "penisrubtentacle4">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $penisactiondefault is "penispullawaytentacle4">>
| <label><span class="brat">Pull away</span> <<radiobutton "$penisaction" "penispullawaytentacle4" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$penisaction" "penispullawaytentacle4">></label>
<</if>>
<</if>>
<<elseif $tentacle4head is "penisimminent">>
<<if $penisactiondefault is "penisrubtentacle4">>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "penisrubtentacle4" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "penisrubtentacle4">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $penisactiondefault is "penispullawaytentacle4">>
| <label><span class="brat">Pull away</span> <<radiobutton "$penisaction" "penispullawaytentacle4" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$penisaction" "penispullawaytentacle4">></label>
<</if>>
<</if>>
<<elseif $tentacle4head is "penis">>
<<if $penisactiondefault is "peniscooperatetentacle4">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$penisaction" "peniscooperatetentacle4" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$penisaction" "peniscooperatetentacle4">></label>
<</if>>
<<elseif $tentacle4head is "penisdeep">>
<<if $penisactiondefault is "peniscooperatetentacle4">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$penisaction" "peniscooperatetentacle4" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$penisaction" "peniscooperatetentacle4">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle4anus">><<nobr>>
<<if $tentacle4head is "anusentrance">>
<<if $anusactiondefault is "anusrubtentacle4">>
| <label><span class="sub">Rub</span> <<radiobutton "$anusaction" "anusrubtentacle4" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$anusaction" "anusrubtentacle4">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $anusactiondefault is "anuspullawaytentacle4">>
| <label><span class="brat">Pull away</span> <<radiobutton "$anusaction" "anuspullawaytentacle4" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$anusaction" "anuspullawaytentacle4">></label>
<</if>>
<</if>>
<<elseif $tentacle4head is "anusimminent">>
<<if $anusactiondefault is "anusrubtentacle4">>
| <label><span class="sub">Rub</span> <<radiobutton "$anusaction" "anusrubtentacle4" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$anusaction" "anusrubtentacle4">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $anusactiondefault is "anuspullawaytentacle4">>
| <label><span class="brat">Pull away</span> <<radiobutton "$anusaction" "anuspullawaytentacle4" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$anusaction" "anuspullawaytentacle4">></label>
<</if>>
<</if>>
<<elseif $tentacle4head is "anus">>
<<if $anusactiondefault is "anuscooperatetentacle4">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$anusaction" "anuscooperatetentacle4" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$anusaction" "anuscooperatetentacle4">></label>
<</if>>
<<elseif $tentacle4head is "anusdeep">>
<<if $anusactiondefault is "anuscooperatetentacle4">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$anusaction" "anuscooperatetentacle4" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$anusaction" "anuscooperatetentacle4">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle4thighs">><<nobr>>
<<if $tentacle4head is "penisrub">>
<<if $thighactiondefault is "penisrubtentacle4">>
| <label><span class="sub">Rub</span> <<radiobutton "$thighaction" "penisrubtentacle4" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$thighaction" "penisrubtentacle4">></label>
<</if>>
<<elseif $tentacle4head is "vaginarub">>
<<if $thighactiondefault is "vaginarubtentacle4">>
| <label><span class="sub">Rub</span> <<radiobutton "$thighaction" "vaginarubtentacle4" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$thighaction" "vaginarubtentacle4">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle4bottom">><<nobr>>
<<if $tentacle4head is "bottomrub">>
<<if $bottomactiondefault is "bottomrubtentacle4">>
| <label><span class="sub">Rub</span> <<radiobutton "$bottomaction" "bottomrubtentacle4" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$bottomaction" "bottomrubtentacle4">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle4chest">><<nobr>>
<<if $tentacle4head is "chest">>
<<if $chestactiondefault is "chestrubtentacle4">>
| <label><span class="sub">Rub</span> <<radiobutton "$chestaction" "chestrubtentacle4" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$chestaction" "chestrubtentacle4">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "effectstentacle4">><<nobr>>
<<if $leftaction is "lefthittentacle4">><<set $leftaction to 0>><<set $leftactiondefault to "lefthittentacle4">>You strike the $tentacle4 tentacle with your left hand and it reels away from you.<<defiance 2>><<set $speechhit to 1>><<tentacle4disable>><<set $attackstat += 1>><<set $tentacle4health -= 1>>
<<if $rng lte ($physique / 200)>>
<<set $tentacle4health -= 1>>
<</if>>
<</if>>
<<if $rightaction is "righthittentacle4">><<set $rightaction to 0>><<set $rightactiondefault to "righthittentacle4">>You strike the $tentacle4 tentacle with your right hand and it reels away from you.<<defiance 2>><<set $speechhit to 1>><<tentacle4disable>><<set $attackstat += 1>><<set $tentacle4health -= 1>>
<<if $rng lte ($physique / 200)>>
<<set $tentacle4health -= 1>>
<</if>>
<</if>>
<<if $leftaction is "leftgrabtentacle4">><<set $leftaction to 0>><<set $leftactiondefault to "leftrubtentacle4">><<submission 1>><<handstat>><span class="lblue">You <<handtext>> grab the $tentacle4 tentacle with your left hand.</span><<tentacle4disable>><<set $leftarm to "tentacle4">><<set $tentacle4head to "leftarm">><<handstat>><<set $leftarmstate to "tentacle">>
<</if>>
<<if $rightaction is "rightgrabtentacle4">><<set $rightaction to 0>><<set $rightactiondefault to "rightrubtentacle4">><<submission 1>><<handstat>><span class="lblue">You <<handtext>> grab the $tentacle4 tentacle with your right hand.</span><<tentacle4disable>><<set $rightarm to "tentacle4">><<set $tentacle4head to "rightarm">><<handstat>><<set $rightarmstate to "tentacle">>
<</if>>
<<if $leftaction is "leftrubtentacle4">><<set $leftaction to 0>><<set $leftactiondefault to "leftrubtentacle4">><<handskilluse>><<submission 1>>You <<handtext>> squeeze the $tentacle4 tentacle in your left hand and rub up and down its length.<<set $rng to random(1, 100)>>
<<if $handskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $rightarmgoo += 1>><<set $tentacle4health -= 3>><<handejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $rightaction is "rightrubtentacle4">><<set $rightaction to 0>><<set $rightactiondefault to "rightrubtentacle4">><<handskilluse>><<submission 1>>You <<handtext>> squeeze the $tentacle4 tentacle in your right hand and rub up and down its length.<<set $rng to random(1, 100)>>
<<if $handskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $rightarmgoo += 1>><<set $tentacle4health -= 3>><<handejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $leftaction is "leftstoptentacle4">><<set $leftaction to 0>><<set $leftactiondefault to "leftstoptentacle4">>You release the $tentacle4 tentacle from your left hand.<<tentacle4disable>>
<</if>>
<<if $rightaction is "rightstoptentacle4">><<set $rightaction to 0>><<set $rightactiondefault to "rightstoptentacle4">>You release the $tentacle4 tentacle from your right hand.<<tentacle4disable>>
<</if>>
<<if $feetaction is "feethittentacle4">><<set $feetaction to 0>><<set $feetactiondefault to "feethittentacle4">>You kick the $tentacle4 tentacle and it reels away from you.<<defiance 2>><<set $speechhit to 1>><<tentacle4disable>><<set $attackstat += 1>><<set $tentacle4health -= 1>>
<<if $rng lte ($physique / 200)>>
<<set $tentacle4health -= 1>>
<</if>>
<</if>>
<<if $feetaction is "feetgrabtentacle4">><<set $feetaction to 0>><<set $feetactiondefault to "feetrubtentacle4">><<submission 1>><<feetstat>><span class="lblue">You <<feettext>> grab the $tentacle4 tentacle between your feet.</span><<tentacle4disable>><<set $leftleg to "tentacle4">><<set $rightleg to "tentacle4">><<set $tentacle4head to "feet">><<feetstat>><<set $feetstate to "tentacle">>
<</if>>
<<if $feetaction is "feetrubtentacle4">><<set $feetaction to 0>><<set $feetactiondefault to "feetrubtentacle4">><<feetskilluse>><<submission 1>>You <<feettext>> squeeze the $tentacle4 tentacle between your feet and rub up and down its length.<<set $rng to random(1, 100)>>
<<if $feetskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $feetgoo += 1>><<set $tentacle4health -= 3>><<feetejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $feetaction is "feetstoptentacle4">><<set $feetaction to 0>><<set $feetactiondefault to "feetstoptentacle4">>You let go of the $tentacle4 tentacle between your feet.<<tentacle4disable>>
<</if>>
<<if $mouthaction is "mouthlicktentacle4">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthlicktentacle4">>
<<submission 2>><<oralskilluse>>You <<oraltext>> lick the tip of the $tentacle4 tentacle.<<set $rng to random(1, 100)>>
<<if $oralskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your face.</span><<set $facegoo += 1>><<set $tentacle4health -= 3>><<faceejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $mouthaction is "mouthkisstentacle4">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthkisstentacle4">>
<<submission 3>><<oralskilluse>>You <<oraltext>> kiss the tip of the $tentacle4 tentacle.<<set $rng to random(1, 100)>>
<<if $oralskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your face.</span><<set $facegoo += 1>><<set $tentacle4health -= 3>><<faceejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $mouthaction is "mouthcooperatetentacle4">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthcooperatetentacle4">>
<<sex 5>><<oralskilluse>>You <<oraltext>> suck the $tentacle4 tentacle invading your mouth.<<set $rng to random(1, 100)>>
<<if $oralskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip and into your mouth.</span><<set $tentacle4health -= 3>><<set $drugged += 3>><<set $mouthgoo += 1>><<oralejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $mouthaction is "mouthpullawaytentacle4">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthpullawaytentacle4">><<brat 1>><span class="teal">You pull away from the $tentacle4 tentacle threatening your mouth.</span><<tentacle4disable>>
<</if>>
<<if $mouthaction is "mouthbitetentacle4">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthbitetentacle4">><<defiance 5>>You bite down on the $tentacle4 tentacle invading your mouth. <span class="teal">It recoils immediately.</span><<tentacle4disable>><<set $attackstat += 1>><<set $tentacle4health -= 1>>
<<if $rng lte ($physique / 200)>>
<<set $tentacle4health -= 1>>
<</if>>
<</if>>
<<if $vaginaaction is "vaginarubtentacle4">><<set $vaginaaction to 0>><<set $vaginaactiondefault to "vaginarubtentacle4">>
<<submission 2>><<vaginalskilluse>>You <<vaginaltext>> rub the tip of the $tentacle4 tentacle with your <<pussystop>><<set $rng to random(1, 100)>>
<<if $vaginalskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $vaginaoutsidegoo += 1>><<set $tentacle4health -= 3>><<vaginalentranceejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $vaginaaction is "vaginacooperatetentacle4">><<set $vaginaaction to 0>><<set $vaginaactiondefault to "vaginacooperatetentacle4">>
<<sex 5>><<vaginalskilluse>>You <<vaginaltext>> push back against the $tentacle4 tentacle invading your <<pussystop>><<set $rng to random(1, 100)>>
<<if $vaginalskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, flooding your womb with its warmth.</span><<set $tentacle4health -= 3>><<set $drugged += 3>><<set $vaginagoo += 1>><<vaginalejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $vaginaaction is "vaginapullawaytentacle4">><<set $vaginaaction to 0>><<set $vaginaactiondefault to "vaginapullawaytentacle4">><<brat 1>><span class="teal">You pull away from the $tentacle4 tentacle threatening your <<pussystop>></span><<tentacle4disable>>
<</if>>
<<if $penisaction is "penisrubtentacle4">><<set $penisaction to 0>><<set $penisactiondefault to "penisrubtentacle4">>
<<submission 2>><<penileskilluse>>You <<peniletext>> rub the tip of the $tentacle4 tentacle with your <<penisstop>><<set $rng to random(1, 100)>>
<<if $penileskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $penisgoo += 1>><<set $tentacle4health -= 3>><<penileejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $penisaction is "peniscooperatetentacle4">><<set $penisaction to 0>><<set $penisactiondefault to "peniscooperatetentacle4">>
<<sex 5>><<penileskilluse>>You <<peniletext>> push back against the $tentacle4 tentacle engulfing your <<penisstop>><<set $rng to random(1, 100)>>
<<if $penileskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your groin.</span><<set $tentacle4health -= 3>><<set $penisgoo += 1>><<penileejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $penisaction is "penispullawaytentacle4">><<set $penisaction to 0>><<set $penisactiondefault to "penispullawaytentacle4">><<brat 1>><span class="teal">You pull away from the $tentacle4 tentacle threatening your <<penisstop>></span><<tentacle4disable>>
<</if>>
<<if $anusaction is "anusrubtentacle4">><<set $anusaction to 0>><<set $anusactiondefault to "anusrubtentacle4">>
<<submission 2>><<analskilluse>>You <<analtext>> rub the tip of the $tentacle4 tentacle with your <<bottomstop>><<set $rng to random(1, 100)>>
<<if $analskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your <<bottomstop>></span><<set $bottomgoo += 1>><<set $tentacle4health -= 3>><<bottomejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $anusaction is "anuscooperatetentacle4">><<set $anusaction to 0>><<set $anusactiondefault to "anuscooperatetentacle4">>
<<sex 5>><<analskilluse>>You <<analtext>> push back against the $tentacle4 tentacle invading your <<bottomstop>><<set $rng to random(1, 100)>>
<<if $analskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, flooding your bowels with its warmth.</span><<set $tentacle4health -= 3>><<set $drugged += 3>><<set $anusgoo += 1>><<analejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $anusaction is "anuspullawaytentacle4">><<set $anusaction to 0>><<set $anusactiondefault to "anuspullawaytentacle4">><<brat 1>><span class="teal">You pull away from the $tentacle4 tentacle threatening your <<bottomstop>></span><<tentacle4disable>>
<</if>>
<<if $thighaction is "penisrubtentacle4">><<set $thighaction to 0>><<set $thighactiondefault to "penisrubtentacle4">>
<<submission 3>><<thighskilluse>>You <<thightext>> rub the $tentacle4 tentacle between your thighs.<<set $rng to random(1, 100)>>
<<if $thighskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your tummy.</span><<set $tentacle4health -= 3>><<set $tummygoo += 1>><<tummyejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $thighaction is "vaginarubtentacle4">><<set $thighaction to 0>><<set $thighactiondefault to "vaginarubtentacle4">>
<<submission 3>><<thighskilluse>>You <<thightext>> rub the $tentacle4 tentacle between your thighs.<<set $rng to random(1, 100)>>
<<if $thighskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your tummy.</span><<set $tentacle4health -= 3>><<set $tummygoo += 1>><<tummyejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $bottomaction is "bottomrubtentacle4">><<set $bottomaction to 0>><<set $bottomactiondefault to "bottomrubtentacle4">>
<<submission 3>><<bottomskilluse>>You <<bottomtext>> rub the $tentacle4 tentacle between your cheeks.<<set $rng to random(1, 100)>>
<<if $bottomskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your <<bottomstop>></span><<set $tentacle4health -= 3>><<set $bottomgoo += 1>><<bottomejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $chestaction is "chestrubtentacle4">><<set $chestaction to 0>><<set $chestactiondefault to "chestrubtentacle4">>
<<submission 3>><<chestskilluse>>You <<chesttext>> rub the $tentacle4 tentacle between your <<breastsstop>><<set $rng to random(1, 100)>>
<<if $chestskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your chest.</span><<set $tentacle4health -= 3>><<set $chestgoo += 1>><<chestejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<</nobr>><</widget>>
:: Widgets Combat Tentacle5 [widget]
<<widget "tentacle5">><<nobr>>
<<if $tentacle5health lte 0 and $tentacle5shaft isnot "finished">>
Worn out, the $tentacle5 tentacle retracts from you.
<<tentacle5disable>>
<<set $tentacle5shaft to "finished">>
<<set $tentacle5head to "finished">>
<</if>>
<<if $tentacle5shaft is "tummy">>
The $tentacle5 tentacle <<slithers>> around your tummy,
<</if>>
<<if $tentacle5shaft is "thighs">>
The $tentacle5 tentacle <<slithers>> between your thighs,
<</if>>
<<if $tentacle5shaft is "breasts">>
The $tentacle5 tentacle squeezes your breasts together,
<</if>>
<<if $tentacle5shaft is "chest">>
The $tentacle5 tentacle <<slithers>> around your chest,
<</if>>
<<if $tentacle5shaft is "waist">>
The $tentacle5 tentacle <<slithers>> around your waist,
<</if>>
<<if $tentacle5shaft is "neck">>
The $tentacle5 tentacle <<slithers>> around your neck,
<</if>>
<<if $tentacle5shaft is "shoulders">>
The $tentacle5 tentacle <<slithers>> around your shoulders,
<</if>>
<<if $tentacle5shaft is "leftleg">>
The $tentacle5 tentacle <<slithers>> around your left leg,
<</if>>
<<if $tentacle5shaft is "rightleg">>
The $tentacle5 tentacle <<slithers>> around your right leg,
<</if>>
<<if $tentacle5shaft is "leftarm">>
The $tentacle5 tentacle <<slithers>> around your left arm,
<</if>>
<<if $tentacle5shaft is "rightarm">>
The $tentacle5 tentacle <<slithers>> around your right arm,
<</if>>
<<if $tentacle5head is "leftarm">>
The $tentacle5 tentacle writhes in your left hand.<<neutral 5>>
<</if>>
<<if $tentacle5head is "rightarm">>
The $tentacle5 tentacle writhes in your right hand.<<neutral 5>>
<</if>>
<<if $tentacle5head is "feet">>
The $tentacle5 tentacle writhes between your feet.<<neutral 5>>
<</if>>
<<if $tentacle5head is "leftnipplesuck">>
and up to your <<breastscomma>> where it suckles your left nipple.<<neutral 3>>
<</if>>
<<if $tentacle5head is "rightnipplesuck">>
and up to your <<breastscomma>> where it suckles your right nipple.<<neutral 3>>
<</if>>
<<if $tentacle5head is "leftnipple">>
and continues teasing your left nipple. <span class="purple">The tip of the tentacle opens up, latches on, then begins sucking.</span><<neutral 3>><<set $tentacle5head to "leftnipplesuck">><<set $leftnipple to "tentaclesuck">>
<</if>>
<<if $tentacle5head is "rightnipple">>
and continues teasing your right nipple. <span class="purple">The tip of the tentacle opens up, latches on, then begins sucking.</span><<neutral 3>><<set $tentacle5head to "rightnipplesuck">><<set $rightnipple to "tentaclesuck">>
<</if>>
<<if $tentacle5head is "chest">>
<<if $chestuse is "squeezed">>
then up between your <<breastscomma>> rubbing itself between them.<<neutral 2>>
<<else>>
moves away from your <<breasts>><<set $tentacle5head to 0>><<set $breastuse to 0>>
<</if>>
<</if>>
<<if $tentacle5head is "mouthdeep">>
and up into your mouth where it spurts a sweet fluid down your throat at the apex of each thrust.<<set $purity -= 1>><<internalejac>><<sex 5>><<set $drugged += 3>><<set $mouthgoo += 1>><<set $tentacle5health -= 1>>
<</if>>
<<if $tentacle5head is "mouth">>
and continues thrusting into your mouth.<span class="pink"> The tip opens and begins oozing a sweet liquid.</span><<set $purity -= 1>><<internalejac>><<set $mouthstate to "tentacledeep">><<set $tentacle5head to "mouthdeep">><<sex 5>><<oralejacstat>><<ejacstat>>
<</if>>
<<if $tentacle5head is "mouthimminent">>
<<if $oralvirginity is 1>>
<span class="pink"> and thrusts between your lips,</span><span class="red"> penetrating your mouth for the first time.</span><<set $oralvirginity to 0>><<violence 5>>
<<else>>
<span class="pink"> and thrusts between your lips.</span>
<</if>>
<<set $mouthstate to "tentacle">><<set $tentacle5head to "mouth">><<sex 5>><<raped>><<oralstat>>
<</if>>
<<if $tentacle5head is "mouthentrance">>
<span class="purple"> and presses against your lips.</span><<set $mouthstate to "tentacleimminent">><<set $tentacle5head to "mouthimminent">><<neutral 4>>
<</if>>
<<if $tentacle5head is "vaginadeep">>
and <<slithers>> into your <<pussy>> where it pumps a viscous fluid at the apex of each thrust.<<set $purity -= 1>><<internalejac>><<sex 5>><<set $drugged += 3>><<set $vaginagoo += 1>><<set $tentacle5health -= 1>>
<</if>>
<<if $tentacle5head is "vagina">>
and continues thrusting into your <<pussystop>><span class="pink"> The tip opens and begins oozing a viscous liquid.</span><<set $purity -= 1>><<internalejac>><<set $vaginastate to "tentacledeep">><<set $tentacle5head to "vaginadeep">><<sex 5>><<vaginalejacstat>><<ejacstat>>
<</if>>
<<if $tentacle5head is "vaginaimminent">>
<<if $vaginalvirginity is 1>>
<span class="pink"> and thrusts into your <<pussycomma>></span><span class="red"> tearing your hymen and forever robbing you of your purity.</span><<set $vaginalvirginity to 0>><<violence 100>>
<<else>>
<span class="pink"> and thrusts into your <<pussystop>></span>
<</if>>
<<set $vaginastate to "tentacle">><<set $tentacle5head to "vagina">><<sex 5>><<raped>><<vaginaraped>><<vaginalstat>><<violence 1>>
<</if>>
<<if $tentacle5head is "vaginaentrance">>
<<if $undertype isnot "chastity">>
<span class="purple"> and presses against your <<pussycomma>> about to penetrate.</span><<set $vaginastate to "tentacleimminent">><<set $tentacle5head to "vaginaimminent">><<neutral 4>>
<<else>>
and tries to find a way inside. Failing, it lashes at the metal.<<set $underintegrity -= 10>><<violence 1>>
<</if>>
<</if>>
<<if $tentacle5head is "penisdeep">>
and continues thrusting against your <<peniscomma>> caressing and kneading your length.<<sex 5>>
<</if>>
<<if $tentacle5head is "penis">>
and continues thrusting against your <<penisstop>><span class="pink"> It sucks and kneads your length, trying to milk you of your cum.</span><<set $penisstate to "tentacledeep">><<set $tentacle5head to "penisdeep">><<sex 5>>
<</if>>
<<if $tentacle5head is "penisimminent">>
<<if $penilevirginity is 1>>
<span class="pink"> and thrusts against your <<peniscomma>> swallowing you to the base and </span><span class="red"> tearing the membrane between your glans and foreskin, forever robbing you of your purity.</span><<set $penilevirginity to 0>><<violence 100>>
<<else>>
<span class="pink"> and thrusts against your <<peniscomma>> swallowing you to the base.</span>
<</if>>
<<set $penisstate to "tentacle">><<set $tentacle5head to "penis">><<sex 5>><<raped>><<penisraped>><<penilestat>><<violence 1>>
<</if>>
<<if $tentacle5head is "penisentrance">>
<<if $undertype isnot "chastity">>
<span class="purple"> and <<slithers>> over to your <<penisstop>> The tip opens and presses against your glans, about to envelop you.</span><<set $penisstate to "tentacleimminent">><<set $tentacle5head to "penisimminent">><<neutral 4>>
<<else>>
and tries to find a way inside. Failing, it lashes at the metal.<<set $underintegrity -= 10>><<violence 1>>
<</if>>
<</if>>
<<if $tentacle5head is "anusdeep">>
and <<slithers>> into your <<bottom>> where it pumps a viscous fluid at the apex of each thrust.<<set $purity -= 1>><<internalejac>><<sex 5>><<set $drugged += 3>><<set $anusgoo += 1>><<set $tentacle5health -= 1>>
<</if>>
<<if $tentacle5head is "anus">>
and continues thrusting into your <<bottomstop>><span class="pink"> The tip opens and begins oozing a viscous liquid.</span><<set $purity -= 1>><<internalejac>><<set $anusstate to "tentacledeep">><<set $tentacle5head to "anusdeep">><<sex 5>><<analejacstat>><<ejacstat>>
<</if>>
<<if $tentacle5head is "anusimminent">>
<<if $analvirginity is 1>>
<span class="pink"> and thrusts into your <<bottomcomma>></span><span class="red"> violating you in a way you hadn't conceived of.</span><<set $analvirginity to 0>><<violence 100>>
<<else>>
<span class="pink"> and thrusts into your <<bottomstop>></span>
<</if>>
<<set $anusstate to "tentacle">><<set $tentacle5head to "anus">><<sex 5>><<raped>><<analstat>><<violence 1>>
<</if>>
<<if $tentacle5head is "anusentrance">>
<<if $analshield is 0>>
<span class="purple"> and presses against your <<bottomcomma>> about to penetrate.</span><<set $anusstate to "tentacleimminent">><<set $tentacle5head to "anusimminent">><<neutral 4>>
<<else>>
and tries to find a way inside. Failing, it lashes at the device.<<set $underintegrity -= 10>><<violence 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $tentacle5head is "vaginarub">>
<<if $rng gte 21>>
and between your thighs where it <<slithers>> against your <<pussycomma>> pressing against your clit.<<sex 3>>
<<else>>
and between your thighs <span class="blue">where it <<slithers>> toward your <<pussystop>></span><<neutral 3>><<set $vaginause to "tentacle">><<set $vaginastate to "tentacleentrance">><<set $tentacle5head to "vaginaentrance">><<set $thighuse to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $tentacle5head is "penisrub">>
<<if $rng gte 21>>
and between your thighs where it <<slithers>> against your <<peniscomma>> coiling around it.<<sex 3>>
<<else>>
and between your thighs <span class="blue">where the tip opens and it <<slithers>> toward your <<penisstop>></span><<neutral 3>><<set $penisuse to "tentacle">><<set $penisstate to "tentacleentrance">><<set $tentacle5head to "penisentrance">><<set $thighuse to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $tentacle5head is "bottomrub">>
<<if $rng gte 21>>
and between your <<bottom>> cheeks where it <<slithers>> against your back.<<sex 3>>
<<else>>
and between your <<bottom>> cheeks, <span class="blue"> toward your anus.</span><<neutral 3>><<set $anususe to "tentacle">><<set $anusstate to "tentacleentrance">><<set $tentacle5head to "anusentrance">><<set $bottomuse to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $tentacle5head is 0 and $tentacle5shaft isnot 0>>
<<if $rng lte 10>>
<<if $chestuse is "squeezed" and $breastuse is 0>>
<<upperslither>><span class="blue">and up between your squeezed <<breastsstop>></span><<set $tentacle5head to "chest">><<neutral 2>><<set $breastuse to "tentacle">><<cheststat>>
<<else>>
<<tentacle5default>>
<</if>>
<<elseif $rng lte 20>>
<<if $leftnipple is 0>>
<<upperslither>> <span class="blue">and teases your left nipple.</span><<neutral 2>><<set $tentacle5head to "leftnipple">><<set $leftnipple to "tentacle">>
<<else>>
<<tentacle5default>>
<</if>>
<<elseif $rng lte 30>>
<<if $rightnipple is 0>>
<<upperslither>> <span class="blue">and teases your right nipple.</span><<neutral 2>><<set $tentacle5head to "rightnipple">><<set $rightnipple to "tentacle">>
<<else>>
<<tentacle5default>>
<</if>>
<<elseif $rng lte 40>>
<<if $mouthuse is 0>>
<<upperslither>> <span class="blue">and up toward your mouth.</span><<neutral 2>><<set $mouthuse to "tentacle">><<set $mouthstate to "tentacleentrance">><<set $tentacle5head to "mouthentrance">>
<<else>>
<<tentacle5default>>
<</if>>
<<elseif $rng lte 50>>
<<if $anususe is 0 and $analdisable is "f">>
<<underslither>> <span class="blue">and <<slithers>> toward your <<bottomstop>></span><<neutral 2>><<set $anususe to "tentacle">><<set $anusstate to "tentacleentrance">><<set $tentacle5head to "anusentrance">>
<<else>>
<<tentacle5default>>
<</if>>
<<elseif $rng lte 60>>
<<if $vaginaexist is 1 and $vaginause is 0>>
<<underslither>> <span class="blue">and <<slithers>> toward your <<pussystop>></span><<neutral 2>><<set $vaginause to "tentacle">><<set $vaginastate to "tentacleentrance">><<set $tentacle5head to "vaginaentrance">>
<<else>>
<<tentacle5default>>
<</if>>
<<elseif $rng lte 70>>
<<if $penisexist is 1 and $penisuse is 0>>
<<underslither>> <span class="blue">and <<slithers>> toward your <<penisstop>></span><<neutral 2>><<set $penisuse to "tentacle">><<set $penisstate to "tentacleentrance">><<set $tentacle5head to "penisentrance">>
<<else>>
<<tentacle5default>>
<</if>>
<<elseif $rng lte 80>>
<<if $thighuse is 0>>
<<if $penisexist is 1 and $penisuse is 0>>
<<underslither>> <span class="blue">and <<slithers>> between your thighs and against your tummy and <<penisstop>></span><<set $penisuse to "tentaclerub">><<set $thighuse to "tentaclerub">><<set $tentacle5head to "penisrub">><<sex 3>><<thighstat>>
<<elseif $vaginaexist is 1 and $vaginause is 0>>
<<underslither>> <span class="blue">and <<slithers>> between your thighs and against your tummy and <<pussystop>></span><<set $vaginause to "tentaclerub">><<set $thighuse to "tentaclerub">><<set $tentacle5head to "vaginarub">><<sex 3>><<thighstat>>
<<else>>
<<tentacle5default>>
<</if>>
<<else>>
<<tentacle5default>>
<</if>>
<<elseif $rng lte 90>>
<<if $bottomuse is 0 and $anususe is 0 and $analdisable is "f">>
<<underslither>> <span class="blue">and <<slithers>> between your <<bottom>> cheeks and against your back.</span><<set $bottomuse to "tentaclerub">><<set $anususe to "tentaclerub">><<set $tentacle5head to "bottomrub">><<sex 1>><<bottomstat>>
<<else>>
<<tentacle5default>>
<</if>>
<<else>>
<<tentacle5default>>
<</if>>
<<elseif $tentacle5head is 0 and $tentacle5shaft is 0>>
<<if $rng lte 10>>
<<if $position isnot "wall">>
The $tentacle5 tentacle winds around your tummy.<<neutral 1>><<set $tentacle5shaft to "tummy">>
<<else>>
The $tentacle5 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<elseif $rng lte 20>>
The $tentacle5 tentacle <<slithers>> between your thighs.<<neutral 1>><<set $tentacle5shaft to "thighs">>
<<elseif $rng lte 30>>
<<if $position isnot "wall">>
<<if $breastsize gte 2 and $chestuse is 0>>
The $tentacle5 tentacle <<slithers>> around your <<breastscomma>> <span class="blue">squeezing them together.</span><<neutral 1>><<set $tentacle5shaft to "breasts">><<set $chestuse to "squeezed">>
<<else>>
The $tentacle5 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<else>>
The $tentacle5 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<elseif $rng lte 40>>
<<if $position isnot "wall">>
The $tentacle5 tentacle winds its way around your chest, beneath your <<breastsstop>><<neutral 1>><<set $tentacle5shaft to "chest">>
<<else>>
The $tentacle5 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<elseif $rng lte 50>>
The $tentacle5 tentacle winds its way around your waist.<<neutral 1>><<set $tentacle5shaft to "waist">>
<<elseif $rng lte 60>>
<<if $position isnot "wall">>
<<if $head is 0>>
The $tentacle5 tentacle winds its way around your neck, <span class="blue">restraining your head.</span><<neutral 1>><<set $tentacle5shaft to "neck">><<set $head to "grappled">>
<<else>>
The $tentacle5 tentacle winds its way around your shoulders.<<neutral 1>><<set $tentacle5shaft to "shoulders">>
<</if>>
<<else>>
The $tentacle5 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<elseif $rng lte 70>>
The $tentacle5 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<<elseif $rng lte 80>>
<<if $leftleg is 0>>
The $tentacle5 tentacle winds its way around your left leg, <span class="blue">restraining it.</span><<neutral 1>><<feettentacledisable>><<set $tentacle5shaft to "leftleg">><<set $leftleg to "grappled">>
<<else>>
The $tentacle5 tentacle tickles your feet.<<neutral 1>>
<</if>>
<<elseif $rng lte 85>>
<<if $rightleg is 0>>
The $tentacle5 tentacle winds its way around your right leg, <span class="blue">restraining it.</span><<neutral 1>><<feettentacledisable>><<set $tentacle5shaft to "rightleg">><<set $rightleg to "grappled">>
<<else>>
The $tentacle5 tentacle tickles your feet.<<neutral 1>>
<</if>>
<<elseif $rng lte 90>>
<<if $leftarm is 0>>
The $tentacle5 tentacle winds its way around your left arm, <span class="blue">restraining it.</span><<neutral 1>><<leftarmtentacledisable>><<set $tentacle5shaft to "leftarm">><<set $leftarm to "grappled">><<set $leftarmstate to 0>>
<<else>>
The $tentacle5 tentacle tickles your armpit.<<neutral 1>>
<</if>>
<<elseif $rng lte 95>>
<<if $rightarm is 0>>
The $tentacle5 tentacle winds its way around your right arm, <span class="blue">restraining it.</span><<rightarmtentacledisable>><<neutral 1>><<set $tentacle5shaft to "rightarm">><<set $rightarm to "grappled">><<set $rightarmstate to 0>>
<<else>>
The $tentacle5 tentacle tickles your armpit.<<neutral 1>>
<</if>>
<<elseif $rng lte 100>>
The $tentacle5 tentacle <<slithers>> against your <<bottomstop>><<neutral 1>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "tentacle5default">><<nobr>>
<<set $rng to random(1, 100)>>
<<if $rng gte 90>>
then squirts a warm fluid over your neck.<<neutral 1>><<set $neckgoo += 1>><<set $tentacle5health -= 1>><<neckejacstat>><<ejacstat>>
<<elseif $rng gte 80>>
then squirts a warm fluid over your right arm.<<neutral 1>><<set $rightarmgoo += 1>><<set $tentacle5health -= 1>><<handejacstat>><<ejacstat>>
<<elseif $rng gte 70>>
then squirts a warm fluid over your left arm.<<neutral 1>><<set $leftarmgoo += 1>><<set $tentacle5health -= 1>><<handejacstat>><<ejacstat>>
<<elseif $rng gte 60>>
then squirts a warm fluid over your thighs.<<neutral 1>><<set $thighgoo += 1>><<set $tentacle5health -= 1>><<thighejacstat>><<ejacstat>>
<<elseif $rng gte 50>>
then squirts a warm fluid over your <<bottomstop>><<neutral 1>><<set $bottomgoo += 1>><<set $tentacle5health -= 1>><<bottomejacstat>><<ejacstat>>
<<elseif $rng gte 40>>
then squirts a warm fluid over your tummy.<<neutral 1>><<set $tummygoo += 1>><<set $tentacle5health -= 1>><<tummyejacstat>><<ejacstat>>
<<elseif $rng gte 30>>
then squirts a warm fluid over your chest.<<neutral 1>><<set $chestgoo += 1>><<set $tentacle5health -= 1>><<chestejacstat>><<ejacstat>>
<<elseif $rng gte 20>>
then squirts a warm fluid over your face.<<neutral 1>><<set $facegoo += 1>><<set $tentacle5health -= 1>><<faceejacstat>><<ejacstat>>
<<elseif $rng gte 10>>
then squirts a warm fluid over your hair.<<neutral 1>><<set $hairgoo += 1>><<set $tentacle5health -= 1>><<hairejacstat>><<ejacstat>>
<<else>>
then squirts a warm fluid over your feet.<<neutral 1>><<set $feetgoo += 1>><<set $tentacle5health -= 1>><<feetejacstat>><<ejacstat>>
<</if>>
<</nobr>><</widget>>
<<widget "tentacle5disable">><<nobr>>
<<if $tentacle5head is "feet">>
<<set $leftleg to 0>>
<<set $rightleg to 0>>
<<set $feetstate to 0>>
<</if>>
<<if $tentacle5head is "leftarm">>
<<set $leftarm to 0>>
<<set $leftarmstate to 0>>
<</if>>
<<if $tentacle5head is "rightarm">>
<<set $rightarm to 0>>
<<set $rightarmstate to 0>>
<</if>>
<<if $tentacle5head is "leftnipplesuck">>
<<set $leftnipple to 0>>
<</if>>
<<if $tentacle5head is "rightnipplesuck">>
<<set $rightnipple to 0>>
<</if>>
<<if $tentacle5head is "leftnipple">>
<<set $leftnipple to 0>>
<</if>>
<<if $tentacle5head is "rightnipple">>
<<set $rightnipple to 0>>
<</if>>
<<if $tentacle5head is "chest">>
<<set $chestuse to 0>>
<</if>>
<<if $tentacle5head is "mouthentrance">>
<<set $mouthuse to 0>>
<<set $mouthstate to 0>>
<</if>>
<<if $tentacle5head is "mouthimminent">>
<<set $mouthuse to 0>>
<<set $mouthstate to 0>>
<</if>>
<<if $tentacle5head is "mouth">>
<<set $mouthuse to 0>>
<<set $mouthstate to 0>>
<</if>>
<<if $tentacle5head is "mouthdeep">>
<<set $mouthuse to 0>>
<<set $mouthstate to 0>>
<</if>>
<<if $tentacle5head is "anusentrance">>
<<set $anususe to 0>>
<<set $anusstate to 0>>
<</if>>
<<if $tentacle5head is "anusimminent">>
<<set $anususe to 0>>
<<set $anusstate to 0>>
<</if>>
<<if $tentacle5head is "anus">>
<<set $anususe to 0>>
<<set $anusstate to 0>>
<</if>>
<<if $tentacle5head is "anusdeep">>
<<set $anususe to 0>>
<<set $anusstate to 0>>
<</if>>
<<if $tentacle5head is "vaginaentrance">>
<<set $vaginause to 0>>
<<set $vaginastate to 0>>
<</if>>
<<if $tentacle5head is "vaginaimminent">>
<<set $vaginause to 0>>
<<set $vaginastate to 0>>
<</if>>
<<if $tentacle5head is "vagina">>
<<set $vaginause to 0>>
<<set $vaginastate to 0>>
<</if>>
<<if $tentacle5head is "vaginadeep">>
<<set $vaginause to 0>>
<<set $vaginastate to 0>>
<</if>>
<<if $tentacle5head is "penisentrance">>
<<set $penisuse to 0>>
<<set $penisstate to 0>>
<</if>>
<<if $tentacle5head is "penisimminent">>
<<set $penisuse to 0>>
<<set $penisstate to 0>>
<</if>>
<<if $tentacle5head is "penis">>
<<set $penisuse to 0>>
<<set $penisstate to 0>>
<</if>>
<<if $tentacle5head is "penisdeep">>
<<set $penisuse to 0>>
<<set $penisstate to 0>>
<</if>>
<<if $tentacle5head is "vaginarub">>
<<set $vaginause to 0>>
<<set $thighuse to 0>>
<</if>>
<<if $tentacle5head is "penisrub">>
<<set $penisuse to 0>>
<<set $thighuse to 0>>
<</if>>
<<if $tentacle5head is "bottomrub">>
<<set $anususe to 0>>
<<set $bottomuse to 0>>
<</if>>
<<if $tentacle5shaft is "breasts">>
<<set $chestuse to 0>>
<</if>>
<<if $tentacle5shaft is "neck" and $head isnot "bound">>
<<set $head to 0>>
<</if>>
<<if $tentacle5shaft is "leftleg" and $leftleg isnot "bound">>
<<set $leftleg to 0>>
<</if>>
<<if $tentacle5shaft is "rightleg" and $rightleg isnot "bound">>
<<set $rightleg to 0>>
<</if>>
<<if $tentacle5shaft is "leftarm" and $leftarm isnot "bound">>
<<set $leftarm to 0>>
<</if>>
<<if $tentacle5shaft is "rightarm" and $rightarm isnot "bound">>
<<set $rightarm to 0>>
<</if>>
<<if $tentacle5head is "chest">>
<<set $breastuse to 0>>
<</if>>
<<set $tentacle5shaft to 0>>
<<set $tentacle5head to 0>>
<</nobr>><</widget>>
<<widget "actionstentacle5lefthand">><<nobr>>
<<if $leftarm is 0 and $tentacle5shaft isnot "finished">>
<<if $leftactiondefault is "lefthittentacle5">>
| <label><span class="def">Strike the $tentacle5 tentacle</span> <<radiobutton "$leftaction" "lefthittentacle5" checked>></label>
<<else>>
| <label><span class="def">Strike the $tentacle5 tentacle</span> <<radiobutton "$leftaction" "lefthittentacle5">></label>
<</if>>
<<if $leftactiondefault is "leftgrabtentacle5">>
| <label><span class="sub">Grab the $tentacle5 tentacle</span> <<radiobutton "$leftaction" "leftgrabtentacle5" checked>></label>
<<else>>
| <label><span class="sub">Grab the $tentacle5 tentacle</span> <<radiobutton "$leftaction" "leftgrabtentacle5">></label>
<</if>>
<<elseif $leftarm is "tentacle5">>You hold the $tentacle5 tentacle in your left hand.<br>
<<if $leftactiondefault is "leftrubtentacle5">>
| <label><span class="sub">Milk it</span> <<radiobutton "$leftaction" "leftrubtentacle5" checked>></label>
<<else>>
| <label><span class="sub">Milk it</span> <<radiobutton "$leftaction" "leftrubtentacle5">></label>
<</if>>
<<if $leftactiondefault is "leftstoptentacle5">>
| <label><span class="neutral">Let go</span> <<radiobutton "$leftaction" "leftstoptentacle5" checked>></label>
<<else>>
| <label><span class="neutral">Let go</span> <<radiobutton "$leftaction" "leftstoptentacle5">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle5righthand">><<nobr>>
<<if $rightarm is 0 and $tentacle5shaft isnot "finished">>
<<if $rightactiondefault is "righthittentacle5">>
| <label><span class="def">Strike the $tentacle5 tentacle</span> <<radiobutton "$rightaction" "righthittentacle5" checked>></label>
<<else>>
| <label><span class="def">Strike the $tentacle5 tentacle</span> <<radiobutton "$rightaction" "righthittentacle5">></label>
<</if>>
<<if $rightactiondefault is "rightgrabtentacle5">>
| <label><span class="sub">Grab the $tentacle5 tentacle</span> <<radiobutton "$rightaction" "rightgrabtentacle5" checked>></label>
<<else>>
| <label><span class="sub">Grab the $tentacle5 tentacle</span> <<radiobutton "$rightaction" "rightgrabtentacle5">></label>
<</if>>
<<elseif $rightarm is "tentacle5">>You hold the $tentacle5 tentacle in your right hand.<br>
<<if $rightactiondefault is "rightrubtentacle5">>
| <label><span class="sub">Milk it</span> <<radiobutton "$rightaction" "rightrubtentacle5" checked>></label>
<<else>>
| <label><span class="sub">Milk it</span> <<radiobutton "$rightaction" "rightrubtentacle5">></label>
<</if>>
<<if $rightactiondefault is "rightstoptentacle5">>
| <label><span class="neutral">Let go</span> <<radiobutton "$rightaction" "rightstoptentacle5" checked>></label>
<<else>>
| <label><span class="neutral">Let go</span> <<radiobutton "$rightaction" "rightstoptentacle5">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle5legs">><<nobr>>
<<if $leftleg is 0 and $rightleg is 0 and $tentacle5shaft isnot "finished">>
<<if $feetactiondefault is "feethittentacle5">>
| <label><span class="def">Kick the $tentacle5 tentacle</span> <<radiobutton "$feetaction" "feethittentacle5" checked>></label>
<<else>>
| <label><span class="def">Kick the $tentacle5 tentacle</span> <<radiobutton "$feetaction" "feethittentacle5">></label>
<</if>>
<<if $feetactiondefault is "feetgrabtentacle5">>
| <label><span class="sub">Grab the $tentacle5 tentacle</span> <<radiobutton "$feetaction" "feetgrabtentacle5" checked>></label>
<<else>>
| <label><span class="sub">Grab the $tentacle5 tentacle</span> <<radiobutton "$feetaction" "feetgrabtentacle5">></label>
<</if>>
<<elseif $leftleg is 0 and $tentacle5shaft isnot "finished">>
<<if $feetactiondefault is "feethittentacle5">>
| <label><span class="def">Kick the $tentacle5 tentacle</span> <<radiobutton "$feetaction" "feethittentacle5" checked>></label>
<<else>>
| <label><span class="def">Kick the $tentacle5 tentacle</span> <<radiobutton "$feetaction" "feethittentacle5">></label>
<</if>>
<<elseif $rightleg is 0 and $tentacle5shaft isnot "finished">>
<<if $feetactiondefault is "feethittentacle5">>
| <label><span class="def">Kick the $tentacle5 tentacle</span> <<radiobutton "$feetaction" "feethittentacle5" checked>></label>
<<else>>
| <label><span class="def">Kick the $tentacle5 tentacle</span> <<radiobutton "$feetaction" "feethittentacle5">></label>
<</if>>
<<elseif $leftleg is "tentacle5">>You hold the $tentacle5 tentacle between your feet.<br>
<<if $feetactiondefault is "feetrubtentacle5">>
| <label><span class="sub">Milk it</span> <<radiobutton "$feetaction" "feetrubtentacle5" checked>></label>
<<else>>
| <label><span class="sub">Milk it</span> <<radiobutton "$feetaction" "feetrubtentacle5">></label>
<</if>>
<<if $feetactiondefault is "feetstoptentacle5">>
| <label><span class="neutral">Let go</span> <<radiobutton "$feetaction" "feetstoptentacle5" checked>></label>
<<else>>
| <label><span class="neutral">Let go</span> <<radiobutton "$feetaction" "feetstoptentacle5">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle5mouth">><<nobr>>
<<if $tentacle5head is "mouthentrance">>
<<if $mouthactiondefault is "mouthlicktentacle5">>
| <label><span class="sub">Lick it</span> <<radiobutton "$mouthaction" "mouthlicktentacle5" checked>></label>
<<else>>
| <label><span class="sub">Lick it</span> <<radiobutton "$mouthaction" "mouthlicktentacle5">></label>
<</if>>
<<if $head is "grappled">>
<<else>>
<<if $mouthactiondefault is "mouthpullawaytentacle5">>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "mouthpullawaytentacle5" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "mouthpullawaytentacle5">></label>
<</if>>
<</if>>
<<elseif $tentacle5head is "mouthimminent">>
<<if $mouthactiondefault is "mouthkisstentacle5">>
| <label><span class="sub">Kiss it</span> <<radiobutton "$mouthaction" "mouthkisstentacle5" checked>></label>
<<else>>
| <label><span class="sub">Kiss it</span> <<radiobutton "$mouthaction" "mouthkisstentacle5">></label>
<</if>>
<<if $head is "grappled">>
<<else>>
<<if $mouthactiondefault is "mouthpullawaytentacle5">>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "mouthpullawaytentacle5" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "mouthpullawaytentacle5">></label>
<</if>>
<</if>>
<<elseif $tentacle5head is "mouth">>
<<if $mouthactiondefault is "mouthcooperatetentacle5">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$mouthaction" "mouthcooperatetentacle5" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$mouthaction" "mouthcooperatetentacle5">></label>
<</if>>
<<if $mouthactiondefault is "mouthbitetentacle5">>
| <label><span class="def">Bite</span> <<radiobutton "$mouthaction" "mouthbitetentacle5" checked>></label>
<<else>>
| <label><span class="def">Bite</span> <<radiobutton "$mouthaction" "mouthbitetentacle5">></label>
<</if>>
<<elseif $tentacle5head is "mouthdeep">>
<<if $mouthactiondefault is "mouthcooperatetentacle5">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$mouthaction" "mouthcooperatetentacle5" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$mouthaction" "mouthcooperatetentacle5">></label>
<</if>>
<<if $mouthactiondefault is "mouthbitetentacle5">>
| <label><span class="def">Bite</span> <<radiobutton "$mouthaction" "mouthbitetentacle5" checked>></label>
<<else>>
| <label><span class="def">Bite</span> <<radiobutton "$mouthaction" "mouthbitetentacle5">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle5vagina">><<nobr>>
<<if $tentacle5head is "vaginaentrance">>
<<if $vaginaactiondefault is "vaginarubtentacle5">>
| <label><span class="sub">Rub</span> <<radiobutton "$vaginaaction" "vaginarubtentacle5" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$vaginaaction" "vaginarubtentacle5">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $vaginaactiondefault is "vaginapullawaytentacle5">>
| <label><span class="brat">Pull away</span> <<radiobutton "$vaginaaction" "vaginapullawaytentacle5" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$vaginaaction" "vaginapullawaytentacle5">></label>
<</if>>
<</if>>
<<elseif $tentacle5head is "vaginaimminent">>
<<if $vaginaactiondefault is "vaginarubtentacle5">>
| <label><span class="sub">Rub</span> <<radiobutton "$vaginaaction" "vaginarubtentacle5" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$vaginaaction" "vaginarubtentacle5">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $vaginaactiondefault is "vaginapullawaytentacle5">>
| <label><span class="brat">Pull away</span> <<radiobutton "$vaginaaction" "vaginapullawaytentacle5" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$vaginaaction" "vaginapullawaytentacle5">></label>
<</if>>
<</if>>
<<elseif $tentacle5head is "vagina">>
<<if $vaginaactiondefault is "vaginacooperatetentacle5">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$vaginaaction" "vaginacooperatetentacle5" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$vaginaaction" "vaginacooperatetentacle5">></label>
<</if>>
<<elseif $tentacle5head is "vaginadeep">>
<<if $vaginaactiondefault is "vaginacooperatetentacle5">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$vaginaaction" "vaginacooperatetentacle5" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$vaginaaction" "vaginacooperatetentacle5">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle5penis">><<nobr>>
<<if $tentacle5head is "penisentrance">>
<<if $penisactiondefault is "penisrubtentacle5">>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "penisrubtentacle5" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "penisrubtentacle5">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $penisactiondefault is "penispullawaytentacle5">>
| <label><span class="brat">Pull away</span> <<radiobutton "$penisaction" "penispullawaytentacle5" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$penisaction" "penispullawaytentacle5">></label>
<</if>>
<</if>>
<<elseif $tentacle5head is "penisimminent">>
<<if $penisactiondefault is "penisrubtentacle5">>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "penisrubtentacle5" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "penisrubtentacle5">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $penisactiondefault is "penispullawaytentacle5">>
| <label><span class="brat">Pull away</span> <<radiobutton "$penisaction" "penispullawaytentacle5" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$penisaction" "penispullawaytentacle5">></label>
<</if>>
<</if>>
<<elseif $tentacle5head is "penis">>
<<if $penisactiondefault is "peniscooperatetentacle5">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$penisaction" "peniscooperatetentacle5" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$penisaction" "peniscooperatetentacle5">></label>
<</if>>
<<elseif $tentacle5head is "penisdeep">>
<<if $penisactiondefault is "peniscooperatetentacle5">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$penisaction" "peniscooperatetentacle5" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$penisaction" "peniscooperatetentacle5">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle5anus">><<nobr>>
<<if $tentacle5head is "anusentrance">>
<<if $anusactiondefault is "anusrubtentacle5">>
| <label><span class="sub">Rub</span> <<radiobutton "$anusaction" "anusrubtentacle5" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$anusaction" "anusrubtentacle5">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $anusactiondefault is "anuspullawaytentacle5">>
| <label><span class="brat">Pull away</span> <<radiobutton "$anusaction" "anuspullawaytentacle5" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$anusaction" "anuspullawaytentacle5">></label>
<</if>>
<</if>>
<<elseif $tentacle5head is "anusimminent">>
<<if $anusactiondefault is "anusrubtentacle5">>
| <label><span class="sub">Rub</span> <<radiobutton "$anusaction" "anusrubtentacle5" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$anusaction" "anusrubtentacle5">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $anusactiondefault is "anuspullawaytentacle5">>
| <label><span class="brat">Pull away</span> <<radiobutton "$anusaction" "anuspullawaytentacle5" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$anusaction" "anuspullawaytentacle5">></label>
<</if>>
<</if>>
<<elseif $tentacle5head is "anus">>
<<if $anusactiondefault is "anuscooperatetentacle5">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$anusaction" "anuscooperatetentacle5" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$anusaction" "anuscooperatetentacle5">></label>
<</if>>
<<elseif $tentacle5head is "anusdeep">>
<<if $anusactiondefault is "anuscooperatetentacle5">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$anusaction" "anuscooperatetentacle5" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$anusaction" "anuscooperatetentacle5">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle5thighs">><<nobr>>
<<if $tentacle5head is "penisrub">>
<<if $thighactiondefault is "penisrubtentacle5">>
| <label><span class="sub">Rub</span> <<radiobutton "$thighaction" "penisrubtentacle5" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$thighaction" "penisrubtentacle5">></label>
<</if>>
<<elseif $tentacle5head is "vaginarub">>
<<if $thighactiondefault is "vaginarubtentacle5">>
| <label><span class="sub">Rub</span> <<radiobutton "$thighaction" "vaginarubtentacle5" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$thighaction" "vaginarubtentacle5">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle5bottom">><<nobr>>
<<if $tentacle5head is "bottomrub">>
<<if $bottomactiondefault is "bottomrubtentacle5">>
| <label><span class="sub">Rub</span> <<radiobutton "$bottomaction" "bottomrubtentacle5" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$bottomaction" "bottomrubtentacle5">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle5chest">><<nobr>>
<<if $tentacle5head is "chest">>
<<if $chestactiondefault is "chestrubtentacle5">>
| <label><span class="sub">Rub</span> <<radiobutton "$chestaction" "chestrubtentacle5" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$chestaction" "chestrubtentacle5">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "effectstentacle5">><<nobr>>
<<if $leftaction is "lefthittentacle5">><<set $leftaction to 0>><<set $leftactiondefault to "lefthittentacle5">>You strike the $tentacle5 tentacle with your left hand and it reels away from you.<<defiance 2>><<set $speechhit to 1>><<tentacle5disable>><<set $attackstat += 1>><<set $tentacle5health -= 1>>
<<if $rng lte ($physique / 200)>>
<<set $tentacle5health -= 1>>
<</if>>
<</if>>
<<if $rightaction is "righthittentacle5">><<set $rightaction to 0>><<set $rightactiondefault to "righthittentacle5">>You strike the $tentacle5 tentacle with your right hand and it reels away from you.<<defiance 2>><<set $speechhit to 1>><<tentacle5disable>><<set $attackstat += 1>><<set $tentacle5health -= 1>>
<<if $rng lte ($physique / 200)>>
<<set $tentacle5health -= 1>>
<</if>>
<</if>>
<<if $leftaction is "leftgrabtentacle5">><<set $leftaction to 0>><<set $leftactiondefault to "leftrubtentacle5">><<submission 1>><<handstat>><span class="lblue">You <<handtext>> grab the $tentacle5 tentacle with your left hand.</span><<tentacle5disable>><<set $leftarm to "tentacle5">><<set $tentacle5head to "leftarm">><<handstat>><<set $leftarmstate to "tentacle">>
<</if>>
<<if $rightaction is "rightgrabtentacle5">><<set $rightaction to 0>><<set $rightactiondefault to "rightrubtentacle5">><<submission 1>><<handstat>><span class="lblue">You <<handtext>> grab the $tentacle5 tentacle with your right hand.</span><<tentacle5disable>><<set $rightarm to "tentacle5">><<set $tentacle5head to "rightarm">><<handstat>><<set $rightarmstate to "tentacle">>
<</if>>
<<if $leftaction is "leftrubtentacle5">><<set $leftaction to 0>><<set $leftactiondefault to "leftrubtentacle5">><<handskilluse>><<submission 1>>You <<handtext>> squeeze the $tentacle5 tentacle in your left hand and rub up and down its length.<<set $rng to random(1, 100)>>
<<if $handskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $rightarmgoo += 1>><<set $tentacle5health -= 3>><<handejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $rightaction is "rightrubtentacle5">><<set $rightaction to 0>><<set $rightactiondefault to "rightrubtentacle5">><<handskilluse>><<submission 1>>You <<handtext>> squeeze the $tentacle5 tentacle in your right hand and rub up and down its length.<<set $rng to random(1, 100)>>
<<if $handskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $rightarmgoo += 1>><<set $tentacle5health -= 3>><<handejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $leftaction is "leftstoptentacle5">><<set $leftaction to 0>><<set $leftactiondefault to "leftstoptentacle5">>You release the $tentacle5 tentacle from your left hand.<<tentacle5disable>>
<</if>>
<<if $rightaction is "rightstoptentacle5">><<set $rightaction to 0>><<set $rightactiondefault to "rightstoptentacle5">>You release the $tentacle5 tentacle from your right hand.<<tentacle5disable>>
<</if>>
<<if $feetaction is "feethittentacle5">><<set $feetaction to 0>><<set $feetactiondefault to "feethittentacle5">>You kick the $tentacle5 tentacle and it reels away from you.<<defiance 2>><<set $speechhit to 1>><<tentacle5disable>><<set $attackstat += 1>><<set $tentacle5health -= 1>>
<<if $rng lte ($physique / 200)>>
<<set $tentacle5health -= 1>>
<</if>>
<</if>>
<<if $feetaction is "feetgrabtentacle5">><<set $feetaction to 0>><<set $feetactiondefault to "feetrubtentacle5">><<submission 1>><<feetstat>><span class="lblue">You <<feettext>> grab the $tentacle5 tentacle between your feet.</span><<tentacle5disable>><<set $leftleg to "tentacle5">><<set $rightleg to "tentacle5">><<set $tentacle5head to "feet">><<feetstat>><<set $feetstate to "tentacle">>
<</if>>
<<if $feetaction is "feetrubtentacle5">><<set $feetaction to 0>><<set $feetactiondefault to "feetrubtentacle5">><<feetskilluse>><<submission 1>>You <<feettext>> squeeze the $tentacle5 tentacle between your feet and rub up and down its length.<<set $rng to random(1, 100)>>
<<if $feetskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $feetgoo += 1>><<set $tentacle5health -= 3>><<feetejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $feetaction is "feetstoptentacle5">><<set $feetaction to 0>><<set $feetactiondefault to "feetstoptentacle5">>You let go of the $tentacle5 tentacle between your feet.<<tentacle5disable>>
<</if>>
<<if $mouthaction is "mouthlicktentacle5">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthlicktentacle5">>
<<submission 2>><<oralskilluse>>You <<oraltext>> lick the tip of the $tentacle5 tentacle.<<set $rng to random(1, 100)>>
<<if $oralskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your face.</span><<set $facegoo += 1>><<set $tentacle5health -= 3>><<faceejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $mouthaction is "mouthkisstentacle5">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthkisstentacle5">>
<<submission 3>><<oralskilluse>>You <<oraltext>> kiss the tip of the $tentacle5 tentacle.<<set $rng to random(1, 100)>>
<<if $oralskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your face.</span><<set $facegoo += 1>><<set $tentacle5health -= 3>><<faceejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $mouthaction is "mouthcooperatetentacle5">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthcooperatetentacle5">>
<<sex 5>><<oralskilluse>>You <<oraltext>> suck the $tentacle5 tentacle invading your mouth.<<set $rng to random(1, 100)>>
<<if $oralskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip and into your mouth.</span><<set $tentacle5health -= 3>><<set $drugged += 3>><<set $mouthgoo += 1>><<oralejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $mouthaction is "mouthpullawaytentacle5">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthpullawaytentacle5">><<brat 1>><span class="teal">You pull away from the $tentacle5 tentacle threatening your mouth.</span><<tentacle5disable>>
<</if>>
<<if $mouthaction is "mouthbitetentacle5">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthbitetentacle5">><<defiance 5>>You bite down on the $tentacle5 tentacle invading your mouth. <span class="teal">It recoils immediately.</span><<tentacle5disable>><<set $attackstat += 1>><<set $tentacle5health -= 1>>
<<if $rng lte ($physique / 200)>>
<<set $tentacle5health -= 1>>
<</if>>
<</if>>
<<if $vaginaaction is "vaginarubtentacle5">><<set $vaginaaction to 0>><<set $vaginaactiondefault to "vaginarubtentacle5">>
<<submission 2>><<vaginalskilluse>>You <<vaginaltext>> rub the tip of the $tentacle5 tentacle with your <<pussystop>><<set $rng to random(1, 100)>>
<<if $vaginalskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $vaginaoutsidegoo += 1>><<set $tentacle5health -= 3>><<vaginalentranceejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $vaginaaction is "vaginacooperatetentacle5">><<set $vaginaaction to 0>><<set $vaginaactiondefault to "vaginacooperatetentacle5">>
<<sex 5>><<vaginalskilluse>>You <<vaginaltext>> push back against the $tentacle5 tentacle invading your <<pussystop>><<set $rng to random(1, 100)>>
<<if $vaginalskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, flooding your womb with its warmth.</span><<set $tentacle5health -= 3>><<set $drugged += 3>><<set $vaginagoo += 1>><<vaginalejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $vaginaaction is "vaginapullawaytentacle5">><<set $vaginaaction to 0>><<set $vaginaactiondefault to "vaginapullawaytentacle5">><<brat 1>><span class="teal">You pull away from the $tentacle5 tentacle threatening your <<pussystop>></span><<tentacle5disable>>
<</if>>
<<if $penisaction is "penisrubtentacle5">><<set $penisaction to 0>><<set $penisactiondefault to "penisrubtentacle5">>
<<submission 2>><<penileskilluse>>You <<peniletext>> rub the tip of the $tentacle5 tentacle with your <<penisstop>><<set $rng to random(1, 100)>>
<<if $penileskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $penisgoo += 1>><<set $tentacle5health -= 3>><<penileejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $penisaction is "peniscooperatetentacle5">><<set $penisaction to 0>><<set $penisactiondefault to "peniscooperatetentacle5">>
<<sex 5>><<penileskilluse>>You <<peniletext>> push back against the $tentacle5 tentacle engulfing your <<penisstop>><<set $rng to random(1, 100)>>
<<if $penileskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your groin.</span><<set $tentacle5health -= 3>><<set $penisgoo += 1>><<penileejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $penisaction is "penispullawaytentacle5">><<set $penisaction to 0>><<set $penisactiondefault to "penispullawaytentacle5">><<brat 1>><span class="teal">You pull away from the $tentacle5 tentacle threatening your <<penisstop>></span><<tentacle5disable>>
<</if>>
<<if $anusaction is "anusrubtentacle5">><<set $anusaction to 0>><<set $anusactiondefault to "anusrubtentacle5">>
<<submission 2>><<analskilluse>>You <<analtext>> rub the tip of the $tentacle5 tentacle with your <<bottomstop>><<set $rng to random(1, 100)>>
<<if $analskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your <<bottomstop>></span><<set $bottomgoo += 1>><<set $tentacle5health -= 3>><<bottomejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $anusaction is "anuscooperatetentacle5">><<set $anusaction to 0>><<set $anusactiondefault to "anuscooperatetentacle5">>
<<sex 5>><<analskilluse>>You <<analtext>> push back against the $tentacle5 tentacle invading your <<bottomstop>><<set $rng to random(1, 100)>>
<<if $analskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, flooding your bowels with its warmth.</span><<set $tentacle5health -= 3>><<set $drugged += 3>><<set $anusgoo += 1>><<analejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $anusaction is "anuspullawaytentacle5">><<set $anusaction to 0>><<set $anusactiondefault to "anuspullawaytentacle5">><<brat 1>><span class="teal">You pull away from the $tentacle5 tentacle threatening your <<bottomstop>></span><<tentacle5disable>>
<</if>>
<<if $thighaction is "penisrubtentacle5">><<set $thighaction to 0>><<set $thighactiondefault to "penisrubtentacle5">>
<<submission 3>><<thighskilluse>>You <<thightext>> rub the $tentacle5 tentacle between your thighs.<<set $rng to random(1, 100)>>
<<if $thighskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your tummy.</span><<set $tentacle5health -= 3>><<set $tummygoo += 1>><<tummyejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $thighaction is "vaginarubtentacle5">><<set $thighaction to 0>><<set $thighactiondefault to "vaginarubtentacle5">>
<<submission 3>><<thighskilluse>>You <<thightext>> rub the $tentacle5 tentacle between your thighs.<<set $rng to random(1, 100)>>
<<if $thighskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your tummy.</span><<set $tentacle5health -= 3>><<set $tummygoo += 1>><<tummyejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $bottomaction is "bottomrubtentacle5">><<set $bottomaction to 0>><<set $bottomactiondefault to "bottomrubtentacle5">>
<<submission 3>><<bottomskilluse>>You <<bottomtext>> rub the $tentacle5 tentacle between your cheeks.<<set $rng to random(1, 100)>>
<<if $bottomskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your <<bottomstop>></span><<set $tentacle5health -= 3>><<set $bottomgoo += 1>><<bottomejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $chestaction is "chestrubtentacle5">><<set $chestaction to 0>><<set $chestactiondefault to "chestrubtentacle5">>
<<submission 3>><<chestskilluse>>You <<chesttext>> rub the $tentacle5 tentacle between your <<breastsstop>><<set $rng to random(1, 100)>>
<<if $chestskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your chest.</span><<set $tentacle5health -= 3>><<set $chestgoo += 1>><<chestejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<</nobr>><</widget>>
:: Widgets Combat Tentacle6 [widget]
<<widget "tentacle6">><<nobr>>
<<if $tentacle6health lte 0 and $tentacle6shaft isnot "finished">>
Worn out, the $tentacle6 tentacle retracts from you.
<<tentacle6disable>>
<<set $tentacle6shaft to "finished">>
<<set $tentacle6head to "finished">>
<</if>>
<<if $tentacle6shaft is "tummy">>
The $tentacle6 tentacle <<slithers>> around your tummy,
<</if>>
<<if $tentacle6shaft is "thighs">>
The $tentacle6 tentacle <<slithers>> between your thighs,
<</if>>
<<if $tentacle6shaft is "breasts">>
The $tentacle6 tentacle squeezes your breasts together,
<</if>>
<<if $tentacle6shaft is "chest">>
The $tentacle6 tentacle <<slithers>> around your chest,
<</if>>
<<if $tentacle6shaft is "waist">>
The $tentacle6 tentacle <<slithers>> around your waist,
<</if>>
<<if $tentacle6shaft is "neck">>
The $tentacle6 tentacle <<slithers>> around your neck,
<</if>>
<<if $tentacle6shaft is "shoulders">>
The $tentacle6 tentacle <<slithers>> around your shoulders,
<</if>>
<<if $tentacle6shaft is "leftleg">>
The $tentacle6 tentacle <<slithers>> around your left leg,
<</if>>
<<if $tentacle6shaft is "rightleg">>
The $tentacle6 tentacle <<slithers>> around your right leg,
<</if>>
<<if $tentacle6shaft is "leftarm">>
The $tentacle6 tentacle <<slithers>> around your left arm,
<</if>>
<<if $tentacle6shaft is "rightarm">>
The $tentacle6 tentacle <<slithers>> around your right arm,
<</if>>
<<if $tentacle6head is "leftarm">>
The $tentacle6 tentacle writhes in your left hand.<<neutral 5>>
<</if>>
<<if $tentacle6head is "rightarm">>
The $tentacle6 tentacle writhes in your right hand.<<neutral 5>>
<</if>>
<<if $tentacle6head is "feet">>
The $tentacle6 tentacle writhes between your feet.<<neutral 5>>
<</if>>
<<if $tentacle6head is "leftnipplesuck">>
and up to your <<breastscomma>> where it suckles your left nipple.<<neutral 3>>
<</if>>
<<if $tentacle6head is "rightnipplesuck">>
and up to your <<breastscomma>> where it suckles your right nipple.<<neutral 3>>
<</if>>
<<if $tentacle6head is "leftnipple">>
and continues teasing your left nipple. <span class="purple">The tip of the tentacle opens up, latches on, then begins sucking.</span><<neutral 3>><<set $tentacle6head to "leftnipplesuck">><<set $leftnipple to "tentaclesuck">>
<</if>>
<<if $tentacle6head is "rightnipple">>
and continues teasing your right nipple. <span class="purple">The tip of the tentacle opens up, latches on, then begins sucking.</span><<neutral 3>><<set $tentacle6head to "rightnipplesuck">><<set $rightnipple to "tentaclesuck">>
<</if>>
<<if $tentacle6head is "chest">>
<<if $chestuse is "squeezed">>
then up between your <<breastscomma>> rubbing itself between them.<<neutral 2>>
<<else>>
moves away from your <<breasts>><<set $tentacle6head to 0>><<set $breastuse to 0>>
<</if>>
<</if>>
<<if $tentacle6head is "mouthdeep">>
and up into your mouth where it spurts a sweet fluid down your throat at the apex of each thrust.<<set $purity -= 1>><<internalejac>><<sex 5>><<set $drugged += 3>><<set $mouthgoo += 1>><<set $tentacle6health -= 1>>
<</if>>
<<if $tentacle6head is "mouth">>
and continues thrusting into your mouth.<span class="pink"> The tip opens and begins oozing a sweet liquid.</span><<set $purity -= 1>><<internalejac>><<set $mouthstate to "tentacledeep">><<set $tentacle6head to "mouthdeep">><<sex 5>><<oralejacstat>><<ejacstat>>
<</if>>
<<if $tentacle6head is "mouthimminent">>
<<if $oralvirginity is 1>>
<span class="pink"> and thrusts between your lips,</span><span class="red"> penetrating your mouth for the first time.</span><<set $oralvirginity to 0>><<violence 5>>
<<else>>
<span class="pink"> and thrusts between your lips.</span>
<</if>>
<<set $mouthstate to "tentacle">><<set $tentacle6head to "mouth">><<sex 5>><<raped>><<oralstat>>
<</if>>
<<if $tentacle6head is "mouthentrance">>
<span class="purple"> and presses against your lips.</span><<set $mouthstate to "tentacleimminent">><<set $tentacle6head to "mouthimminent">><<neutral 4>>
<</if>>
<<if $tentacle6head is "vaginadeep">>
and <<slithers>> into your <<pussy>> where it pumps a viscous fluid at the apex of each thrust.<<set $purity -= 1>><<internalejac>><<sex 5>><<set $drugged += 3>><<set $vaginagoo += 1>><<set $tentacle6health -= 1>>
<</if>>
<<if $tentacle6head is "vagina">>
and continues thrusting into your <<pussystop>><span class="pink"> The tip opens and begins oozing a viscous liquid.</span><<set $purity -= 1>><<internalejac>><<set $vaginastate to "tentacledeep">><<set $tentacle6head to "vaginadeep">><<sex 5>><<vaginalejacstat>><<ejacstat>>
<</if>>
<<if $tentacle6head is "vaginaimminent">>
<<if $vaginalvirginity is 1>>
<span class="pink"> and thrusts into your <<pussycomma>></span><span class="red"> tearing your hymen and forever robbing you of your purity.</span><<set $vaginalvirginity to 0>><<violence 100>>
<<else>>
<span class="pink"> and thrusts into your <<pussystop>></span>
<</if>>
<<set $vaginastate to "tentacle">><<set $tentacle6head to "vagina">><<sex 5>><<raped>><<vaginaraped>><<vaginalstat>><<violence 1>>
<</if>>
<<if $tentacle6head is "vaginaentrance">>
<<if $undertype isnot "chastity">>
<span class="purple"> and presses against your <<pussycomma>> about to penetrate.</span><<set $vaginastate to "tentacleimminent">><<set $tentacle6head to "vaginaimminent">><<neutral 4>>
<<else>>
and tries to find a way inside. Failing, it lashes at the metal.<<set $underintegrity -= 10>><<violence 1>>
<</if>>
<</if>>
<<if $tentacle6head is "penisdeep">>
and continues thrusting against your <<peniscomma>> caressing and kneading your length.<<sex 5>>
<</if>>
<<if $tentacle6head is "penis">>
and continues thrusting against your <<penisstop>><span class="pink"> It sucks and kneads your length, trying to milk you of your cum.</span><<set $penisstate to "tentacledeep">><<set $tentacle6head to "penisdeep">><<sex 5>>
<</if>>
<<if $tentacle6head is "penisimminent">>
<<if $penilevirginity is 1>>
<span class="pink"> and thrusts against your <<peniscomma>> swallowing you to the base and </span><span class="red"> tearing the membrane between your glans and foreskin, forever robbing you of your purity.</span><<set $penilevirginity to 0>><<violence 100>>
<<else>>
<span class="pink"> and thrusts against your <<peniscomma>> swallowing you to the base.</span>
<</if>>
<<set $penisstate to "tentacle">><<set $tentacle6head to "penis">><<sex 5>><<raped>><<penisraped>><<penilestat>><<violence 1>>
<</if>>
<<if $tentacle6head is "penisentrance">>
<<if $undertype isnot "chastity">>
<span class="purple"> and <<slithers>> over to your <<penisstop>> The tip opens and presses against your glans, about to envelop you.</span><<set $penisstate to "tentacleimminent">><<set $tentacle6head to "penisimminent">><<neutral 4>>
<<else>>
and tries to find a way inside. Failing, it lashes at the metal.<<set $underintegrity -= 10>><<violence 1>>
<</if>>
<</if>>
<<if $tentacle6head is "anusdeep">>
and <<slithers>> into your <<bottom>> where it pumps a viscous fluid at the apex of each thrust.<<set $purity -= 1>><<internalejac>><<sex 5>><<set $drugged += 3>><<set $anusgoo += 1>><<set $tentacle6health -= 1>>
<</if>>
<<if $tentacle6head is "anus">>
and continues thrusting into your <<bottomstop>><span class="pink"> The tip opens and begins oozing a viscous liquid.</span><<set $purity -= 1>><<internalejac>><<set $anusstate to "tentacledeep">><<set $tentacle6head to "anusdeep">><<sex 5>><<analejacstat>><<ejacstat>>
<</if>>
<<if $tentacle6head is "anusimminent">>
<<if $analvirginity is 1>>
<span class="pink"> and thrusts into your <<bottomcomma>></span><span class="red"> violating you in a way you hadn't conceived of.</span><<set $analvirginity to 0>><<violence 100>>
<<else>>
<span class="pink"> and thrusts into your <<bottomstop>></span>
<</if>>
<<set $anusstate to "tentacle">><<set $tentacle6head to "anus">><<sex 5>><<raped>><<analstat>><<violence 1>>
<</if>>
<<if $tentacle6head is "anusentrance">>
<<if $analshield is 0>>
<span class="purple"> and presses against your <<bottomcomma>> about to penetrate.</span><<set $anusstate to "tentacleimminent">><<set $tentacle6head to "anusimminent">><<neutral 4>>
<<else>>
and tries to find a way inside. Failing, it lashes at the device.<<set $underintegrity -= 10>><<violence 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $tentacle6head is "vaginarub">>
<<if $rng gte 21>>
and between your thighs where it <<slithers>> against your <<pussycomma>> pressing against your clit.<<sex 3>>
<<else>>
and between your thighs <span class="blue">where it <<slithers>> toward your <<pussystop>></span><<neutral 3>><<set $vaginause to "tentacle">><<set $vaginastate to "tentacleentrance">><<set $tentacle6head to "vaginaentrance">><<set $thighuse to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $tentacle6head is "penisrub">>
<<if $rng gte 21>>
and between your thighs where it <<slithers>> against your <<peniscomma>> coiling around it.<<sex 3>>
<<else>>
and between your thighs <span class="blue">where the tip opens and it <<slithers>> toward your <<penisstop>></span><<neutral 3>><<set $penisuse to "tentacle">><<set $penisstate to "tentacleentrance">><<set $tentacle6head to "penisentrance">><<set $thighuse to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $tentacle6head is "bottomrub">>
<<if $rng gte 21>>
and between your <<bottom>> cheeks where it <<slithers>> against your back.<<sex 3>>
<<else>>
and between your <<bottom>> cheeks, <span class="blue"> toward your anus.</span><<neutral 3>><<set $anususe to "tentacle">><<set $anusstate to "tentacleentrance">><<set $tentacle6head to "anusentrance">><<set $bottomuse to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $tentacle6head is 0 and $tentacle6shaft isnot 0>>
<<if $rng lte 10>>
<<if $chestuse is "squeezed" and $breastuse is 0>>
<<upperslither>><span class="blue">and up between your squeezed <<breastsstop>></span><<set $tentacle6head to "chest">><<neutral 2>><<set $breastuse to "tentacle">><<cheststat>>
<<else>>
<<tentacle6default>>
<</if>>
<<elseif $rng lte 20>>
<<if $leftnipple is 0>>
<<upperslither>> <span class="blue">and teases your left nipple.</span><<neutral 2>><<set $tentacle6head to "leftnipple">><<set $leftnipple to "tentacle">>
<<else>>
<<tentacle6default>>
<</if>>
<<elseif $rng lte 30>>
<<if $rightnipple is 0>>
<<upperslither>> <span class="blue">and teases your right nipple.</span><<neutral 2>><<set $tentacle6head to "rightnipple">><<set $rightnipple to "tentacle">>
<<else>>
<<tentacle6default>>
<</if>>
<<elseif $rng lte 40>>
<<if $mouthuse is 0>>
<<upperslither>> <span class="blue">and up toward your mouth.</span><<neutral 2>><<set $mouthuse to "tentacle">><<set $mouthstate to "tentacleentrance">><<set $tentacle6head to "mouthentrance">>
<<else>>
<<tentacle6default>>
<</if>>
<<elseif $rng lte 50>>
<<if $anususe is 0 and $analdisable is "f">>
<<underslither>> <span class="blue">and <<slithers>> toward your <<bottomstop>></span><<neutral 2>><<set $anususe to "tentacle">><<set $anusstate to "tentacleentrance">><<set $tentacle6head to "anusentrance">>
<<else>>
<<tentacle6default>>
<</if>>
<<elseif $rng lte 60>>
<<if $vaginaexist is 1 and $vaginause is 0>>
<<underslither>> <span class="blue">and <<slithers>> toward your <<pussystop>></span><<neutral 2>><<set $vaginause to "tentacle">><<set $vaginastate to "tentacleentrance">><<set $tentacle6head to "vaginaentrance">>
<<else>>
<<tentacle6default>>
<</if>>
<<elseif $rng lte 70>>
<<if $penisexist is 1 and $penisuse is 0>>
<<underslither>> <span class="blue">and <<slithers>> toward your <<penisstop>></span><<neutral 2>><<set $penisuse to "tentacle">><<set $penisstate to "tentacleentrance">><<set $tentacle6head to "penisentrance">>
<<else>>
<<tentacle6default>>
<</if>>
<<elseif $rng lte 80>>
<<if $thighuse is 0>>
<<if $penisexist is 1 and $penisuse is 0>>
<<underslither>> <span class="blue">and <<slithers>> between your thighs and against your tummy and <<penisstop>></span><<set $penisuse to "tentaclerub">><<set $thighuse to "tentaclerub">><<set $tentacle6head to "penisrub">><<sex 3>><<thighstat>>
<<elseif $vaginaexist is 1 and $vaginause is 0>>
<<underslither>> <span class="blue">and <<slithers>> between your thighs and against your tummy and <<pussystop>></span><<set $vaginause to "tentaclerub">><<set $thighuse to "tentaclerub">><<set $tentacle6head to "vaginarub">><<sex 3>><<thighstat>>
<<else>>
<<tentacle6default>>
<</if>>
<<else>>
<<tentacle6default>>
<</if>>
<<elseif $rng lte 90>>
<<if $bottomuse is 0 and $anususe is 0 and $analdisable is "f">>
<<underslither>> <span class="blue">and <<slithers>> between your <<bottom>> cheeks and against your back.</span><<set $bottomuse to "tentaclerub">><<set $anususe to "tentaclerub">><<set $tentacle6head to "bottomrub">><<sex 1>><<bottomstat>>
<<else>>
<<tentacle6default>>
<</if>>
<<else>>
<<tentacle6default>>
<</if>>
<<elseif $tentacle6head is 0 and $tentacle6shaft is 0>>
<<if $rng lte 10>>
<<if $position isnot "wall">>
The $tentacle6 tentacle winds around your tummy.<<neutral 1>><<set $tentacle6shaft to "tummy">>
<<else>>
The $tentacle6 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<elseif $rng lte 20>>
The $tentacle6 tentacle <<slithers>> between your thighs.<<neutral 1>><<set $tentacle6shaft to "thighs">>
<<elseif $rng lte 30>>
<<if $position isnot "wall">>
<<if $breastsize gte 2 and $chestuse is 0>>
The $tentacle6 tentacle <<slithers>> around your <<breastscomma>> <span class="blue">squeezing them together.</span><<neutral 1>><<set $tentacle6shaft to "breasts">><<set $chestuse to "squeezed">>
<<else>>
The $tentacle6 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<else>>
The $tentacle6 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<elseif $rng lte 40>>
<<if $position isnot "wall">>
The $tentacle6 tentacle winds its way around your chest, beneath your <<breastsstop>><<neutral 1>><<set $tentacle6shaft to "chest">>
<<else>>
The $tentacle6 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<elseif $rng lte 50>>
The $tentacle6 tentacle winds its way around your waist.<<neutral 1>><<set $tentacle6shaft to "waist">>
<<elseif $rng lte 60>>
<<if $position isnot "wall">>
<<if $head is 0>>
The $tentacle6 tentacle winds its way around your neck, <span class="blue">restraining your head.</span><<neutral 1>><<set $tentacle6shaft to "neck">><<set $head to "grappled">>
<<else>>
The $tentacle6 tentacle winds its way around your shoulders.<<neutral 1>><<set $tentacle6shaft to "shoulders">>
<</if>>
<<else>>
The $tentacle6 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<elseif $rng lte 70>>
The $tentacle6 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<<elseif $rng lte 80>>
<<if $leftleg is 0>>
The $tentacle6 tentacle winds its way around your left leg, <span class="blue">restraining it.</span><<neutral 1>><<feettentacledisable>><<set $tentacle6shaft to "leftleg">><<set $leftleg to "grappled">>
<<else>>
The $tentacle6 tentacle tickles your feet.<<neutral 1>>
<</if>>
<<elseif $rng lte 85>>
<<if $rightleg is 0>>
The $tentacle6 tentacle winds its way around your right leg, <span class="blue">restraining it.</span><<neutral 1>><<feettentacledisable>><<set $tentacle6shaft to "rightleg">><<set $rightleg to "grappled">>
<<else>>
The $tentacle6 tentacle tickles your feet.<<neutral 1>>
<</if>>
<<elseif $rng lte 90>>
<<if $leftarm is 0>>
The $tentacle6 tentacle winds its way around your left arm, <span class="blue">restraining it.</span><<neutral 1>><<leftarmtentacledisable>><<set $tentacle6shaft to "leftarm">><<set $leftarm to "grappled">><<set $leftarmstate to 0>>
<<else>>
The $tentacle6 tentacle tickles your armpit.<<neutral 1>>
<</if>>
<<elseif $rng lte 95>>
<<if $rightarm is 0>>
The $tentacle6 tentacle winds its way around your right arm, <span class="blue">restraining it.</span><<rightarmtentacledisable>><<neutral 1>><<set $tentacle6shaft to "rightarm">><<set $rightarm to "grappled">><<set $rightarmstate to 0>>
<<else>>
The $tentacle6 tentacle tickles your armpit.<<neutral 1>>
<</if>>
<<elseif $rng lte 100>>
The $tentacle6 tentacle <<slithers>> against your <<bottomstop>><<neutral 1>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "tentacle6default">><<nobr>>
<<set $rng to random(1, 100)>>
<<if $rng gte 90>>
then squirts a warm fluid over your neck.<<neutral 1>><<set $neckgoo += 1>><<set $tentacle6health -= 1>><<neckejacstat>><<ejacstat>>
<<elseif $rng gte 80>>
then squirts a warm fluid over your right arm.<<neutral 1>><<set $rightarmgoo += 1>><<set $tentacle6health -= 1>><<handejacstat>><<ejacstat>>
<<elseif $rng gte 70>>
then squirts a warm fluid over your left arm.<<neutral 1>><<set $leftarmgoo += 1>><<set $tentacle6health -= 1>><<handejacstat>><<ejacstat>>
<<elseif $rng gte 60>>
then squirts a warm fluid over your thighs.<<neutral 1>><<set $thighgoo += 1>><<set $tentacle6health -= 1>><<thighejacstat>><<ejacstat>>
<<elseif $rng gte 50>>
then squirts a warm fluid over your <<bottomstop>><<neutral 1>><<set $bottomgoo += 1>><<set $tentacle6health -= 1>><<bottomejacstat>><<ejacstat>>
<<elseif $rng gte 40>>
then squirts a warm fluid over your tummy.<<neutral 1>><<set $tummygoo += 1>><<set $tentacle6health -= 1>><<tummyejacstat>><<ejacstat>>
<<elseif $rng gte 30>>
then squirts a warm fluid over your chest.<<neutral 1>><<set $chestgoo += 1>><<set $tentacle6health -= 1>><<chestejacstat>><<ejacstat>>
<<elseif $rng gte 20>>
then squirts a warm fluid over your face.<<neutral 1>><<set $facegoo += 1>><<set $tentacle6health -= 1>><<faceejacstat>><<ejacstat>>
<<elseif $rng gte 10>>
then squirts a warm fluid over your hair.<<neutral 1>><<set $hairgoo += 1>><<set $tentacle6health -= 1>><<hairejacstat>><<ejacstat>>
<<else>>
then squirts a warm fluid over your feet.<<neutral 1>><<set $feetgoo += 1>><<set $tentacle6health -= 1>><<feetejacstat>><<ejacstat>>
<</if>>
<</nobr>><</widget>>
<<widget "tentacle6disable">><<nobr>>
<<if $tentacle6head is "feet">>
<<set $leftleg to 0>>
<<set $rightleg to 0>>
<<set $feetstate to 0>>
<</if>>
<<if $tentacle6head is "leftarm">>
<<set $leftarm to 0>>
<<set $leftarmstate to 0>>
<</if>>
<<if $tentacle6head is "rightarm">>
<<set $rightarm to 0>>
<<set $rightarmstate to 0>>
<</if>>
<<if $tentacle6head is "leftnipplesuck">>
<<set $leftnipple to 0>>
<</if>>
<<if $tentacle6head is "rightnipplesuck">>
<<set $rightnipple to 0>>
<</if>>
<<if $tentacle6head is "leftnipple">>
<<set $leftnipple to 0>>
<</if>>
<<if $tentacle6head is "rightnipple">>
<<set $rightnipple to 0>>
<</if>>
<<if $tentacle6head is "chest">>
<<set $chestuse to 0>>
<</if>>
<<if $tentacle6head is "mouthentrance">>
<<set $mouthuse to 0>>
<<set $mouthstate to 0>>
<</if>>
<<if $tentacle6head is "mouthimminent">>
<<set $mouthuse to 0>>
<<set $mouthstate to 0>>
<</if>>
<<if $tentacle6head is "mouth">>
<<set $mouthuse to 0>>
<<set $mouthstate to 0>>
<</if>>
<<if $tentacle6head is "mouthdeep">>
<<set $mouthuse to 0>>
<<set $mouthstate to 0>>
<</if>>
<<if $tentacle6head is "anusentrance">>
<<set $anususe to 0>>
<<set $anusstate to 0>>
<</if>>
<<if $tentacle6head is "anusimminent">>
<<set $anususe to 0>>
<<set $anusstate to 0>>
<</if>>
<<if $tentacle6head is "anus">>
<<set $anususe to 0>>
<<set $anusstate to 0>>
<</if>>
<<if $tentacle6head is "anusdeep">>
<<set $anususe to 0>>
<<set $anusstate to 0>>
<</if>>
<<if $tentacle6head is "vaginaentrance">>
<<set $vaginause to 0>>
<<set $vaginastate to 0>>
<</if>>
<<if $tentacle6head is "vaginaimminent">>
<<set $vaginause to 0>>
<<set $vaginastate to 0>>
<</if>>
<<if $tentacle6head is "vagina">>
<<set $vaginause to 0>>
<<set $vaginastate to 0>>
<</if>>
<<if $tentacle6head is "vaginadeep">>
<<set $vaginause to 0>>
<<set $vaginastate to 0>>
<</if>>
<<if $tentacle6head is "penisentrance">>
<<set $penisuse to 0>>
<<set $penisstate to 0>>
<</if>>
<<if $tentacle6head is "penisimminent">>
<<set $penisuse to 0>>
<<set $penisstate to 0>>
<</if>>
<<if $tentacle6head is "penis">>
<<set $penisuse to 0>>
<<set $penisstate to 0>>
<</if>>
<<if $tentacle6head is "penisdeep">>
<<set $penisuse to 0>>
<<set $penisstate to 0>>
<</if>>
<<if $tentacle6head is "vaginarub">>
<<set $vaginause to 0>>
<<set $thighuse to 0>>
<</if>>
<<if $tentacle6head is "penisrub">>
<<set $penisuse to 0>>
<<set $thighuse to 0>>
<</if>>
<<if $tentacle6head is "bottomrub">>
<<set $anususe to 0>>
<<set $bottomuse to 0>>
<</if>>
<<if $tentacle6shaft is "breasts">>
<<set $chestuse to 0>>
<</if>>
<<if $tentacle6shaft is "neck" and $head isnot "bound">>
<<set $head to 0>>
<</if>>
<<if $tentacle6shaft is "leftleg" and $leftleg isnot "bound">>
<<set $leftleg to 0>>
<</if>>
<<if $tentacle6shaft is "rightleg" and $rightleg isnot "bound">>
<<set $rightleg to 0>>
<</if>>
<<if $tentacle6shaft is "leftarm" and $leftarm isnot "bound">>
<<set $leftarm to 0>>
<</if>>
<<if $tentacle6shaft is "rightarm" and $rightarm isnot "bound">>
<<set $rightarm to 0>>
<</if>>
<<if $tentacle6head is "chest">>
<<set $breastuse to 0>>
<</if>>
<<set $tentacle6shaft to 0>>
<<set $tentacle6head to 0>>
<</nobr>><</widget>>
<<widget "actionstentacle6lefthand">><<nobr>>
<<if $leftarm is 0 and $tentacle6shaft isnot "finished">>
<<if $leftactiondefault is "lefthittentacle6">>
| <label><span class="def">Strike the $tentacle6 tentacle</span> <<radiobutton "$leftaction" "lefthittentacle6" checked>></label>
<<else>>
| <label><span class="def">Strike the $tentacle6 tentacle</span> <<radiobutton "$leftaction" "lefthittentacle6">></label>
<</if>>
<<if $leftactiondefault is "leftgrabtentacle6">>
| <label><span class="sub">Grab the $tentacle6 tentacle</span> <<radiobutton "$leftaction" "leftgrabtentacle6" checked>></label>
<<else>>
| <label><span class="sub">Grab the $tentacle6 tentacle</span> <<radiobutton "$leftaction" "leftgrabtentacle6">></label>
<</if>>
<<elseif $leftarm is "tentacle6">>You hold the $tentacle6 tentacle in your left hand.<br>
<<if $leftactiondefault is "leftrubtentacle6">>
| <label><span class="sub">Milk it</span> <<radiobutton "$leftaction" "leftrubtentacle6" checked>></label>
<<else>>
| <label><span class="sub">Milk it</span> <<radiobutton "$leftaction" "leftrubtentacle6">></label>
<</if>>
<<if $leftactiondefault is "leftstoptentacle6">>
| <label><span class="neutral">Let go</span> <<radiobutton "$leftaction" "leftstoptentacle6" checked>></label>
<<else>>
| <label><span class="neutral">Let go</span> <<radiobutton "$leftaction" "leftstoptentacle6">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle6righthand">><<nobr>>
<<if $rightarm is 0 and $tentacle6shaft isnot "finished">>
<<if $rightactiondefault is "righthittentacle6">>
| <label><span class="def">Strike the $tentacle6 tentacle</span> <<radiobutton "$rightaction" "righthittentacle6" checked>></label>
<<else>>
| <label><span class="def">Strike the $tentacle6 tentacle</span> <<radiobutton "$rightaction" "righthittentacle6">></label>
<</if>>
<<if $rightactiondefault is "rightgrabtentacle6">>
| <label><span class="sub">Grab the $tentacle6 tentacle</span> <<radiobutton "$rightaction" "rightgrabtentacle6" checked>></label>
<<else>>
| <label><span class="sub">Grab the $tentacle6 tentacle</span> <<radiobutton "$rightaction" "rightgrabtentacle6">></label>
<</if>>
<<elseif $rightarm is "tentacle6">>You hold the $tentacle6 tentacle in your right hand.<br>
<<if $rightactiondefault is "rightrubtentacle6">>
| <label><span class="sub">Milk it</span> <<radiobutton "$rightaction" "rightrubtentacle6" checked>></label>
<<else>>
| <label><span class="sub">Milk it</span> <<radiobutton "$rightaction" "rightrubtentacle6">></label>
<</if>>
<<if $rightactiondefault is "rightstoptentacle6">>
| <label><span class="neutral">Let go</span> <<radiobutton "$rightaction" "rightstoptentacle6" checked>></label>
<<else>>
| <label><span class="neutral">Let go</span> <<radiobutton "$rightaction" "rightstoptentacle6">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle6legs">><<nobr>>
<<if $leftleg is 0 and $rightleg is 0 and $tentacle6shaft isnot "finished">>
<<if $feetactiondefault is "feethittentacle6">>
| <label><span class="def">Kick the $tentacle6 tentacle</span> <<radiobutton "$feetaction" "feethittentacle6" checked>></label>
<<else>>
| <label><span class="def">Kick the $tentacle6 tentacle</span> <<radiobutton "$feetaction" "feethittentacle6">></label>
<</if>>
<<if $feetactiondefault is "feetgrabtentacle6">>
| <label><span class="sub">Grab the $tentacle6 tentacle</span> <<radiobutton "$feetaction" "feetgrabtentacle6" checked>></label>
<<else>>
| <label><span class="sub">Grab the $tentacle6 tentacle</span> <<radiobutton "$feetaction" "feetgrabtentacle6">></label>
<</if>>
<<elseif $leftleg is 0 and $tentacle6shaft isnot "finished">>
<<if $feetactiondefault is "feethittentacle6">>
| <label><span class="def">Kick the $tentacle6 tentacle</span> <<radiobutton "$feetaction" "feethittentacle6" checked>></label>
<<else>>
| <label><span class="def">Kick the $tentacle6 tentacle</span> <<radiobutton "$feetaction" "feethittentacle6">></label>
<</if>>
<<elseif $rightleg is 0 and $tentacle6shaft isnot "finished">>
<<if $feetactiondefault is "feethittentacle6">>
| <label><span class="def">Kick the $tentacle6 tentacle</span> <<radiobutton "$feetaction" "feethittentacle6" checked>></label>
<<else>>
| <label><span class="def">Kick the $tentacle6 tentacle</span> <<radiobutton "$feetaction" "feethittentacle6">></label>
<</if>>
<<elseif $leftleg is "tentacle6">>You hold the $tentacle6 tentacle between your feet.<br>
<<if $feetactiondefault is "feetrubtentacle6">>
| <label><span class="sub">Milk it</span> <<radiobutton "$feetaction" "feetrubtentacle6" checked>></label>
<<else>>
| <label><span class="sub">Milk it</span> <<radiobutton "$feetaction" "feetrubtentacle6">></label>
<</if>>
<<if $feetactiondefault is "feetstoptentacle6">>
| <label><span class="neutral">Let go</span> <<radiobutton "$feetaction" "feetstoptentacle6" checked>></label>
<<else>>
| <label><span class="neutral">Let go</span> <<radiobutton "$feetaction" "feetstoptentacle6">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle6mouth">><<nobr>>
<<if $tentacle6head is "mouthentrance">>
<<if $mouthactiondefault is "mouthlicktentacle6">>
| <label><span class="sub">Lick it</span> <<radiobutton "$mouthaction" "mouthlicktentacle6" checked>></label>
<<else>>
| <label><span class="sub">Lick it</span> <<radiobutton "$mouthaction" "mouthlicktentacle6">></label>
<</if>>
<<if $head is "grappled">>
<<else>>
<<if $mouthactiondefault is "mouthpullawaytentacle6">>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "mouthpullawaytentacle6" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "mouthpullawaytentacle6">></label>
<</if>>
<</if>>
<<elseif $tentacle6head is "mouthimminent">>
<<if $mouthactiondefault is "mouthkisstentacle6">>
| <label><span class="sub">Kiss it</span> <<radiobutton "$mouthaction" "mouthkisstentacle6" checked>></label>
<<else>>
| <label><span class="sub">Kiss it</span> <<radiobutton "$mouthaction" "mouthkisstentacle6">></label>
<</if>>
<<if $head is "grappled">>
<<else>>
<<if $mouthactiondefault is "mouthpullawaytentacle6">>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "mouthpullawaytentacle6" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "mouthpullawaytentacle6">></label>
<</if>>
<</if>>
<<elseif $tentacle6head is "mouth">>
<<if $mouthactiondefault is "mouthcooperatetentacle6">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$mouthaction" "mouthcooperatetentacle6" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$mouthaction" "mouthcooperatetentacle6">></label>
<</if>>
<<if $mouthactiondefault is "mouthbitetentacle6">>
| <label><span class="def">Bite</span> <<radiobutton "$mouthaction" "mouthbitetentacle6" checked>></label>
<<else>>
| <label><span class="def">Bite</span> <<radiobutton "$mouthaction" "mouthbitetentacle6">></label>
<</if>>
<<elseif $tentacle6head is "mouthdeep">>
<<if $mouthactiondefault is "mouthcooperatetentacle6">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$mouthaction" "mouthcooperatetentacle6" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$mouthaction" "mouthcooperatetentacle6">></label>
<</if>>
<<if $mouthactiondefault is "mouthbitetentacle6">>
| <label><span class="def">Bite</span> <<radiobutton "$mouthaction" "mouthbitetentacle6" checked>></label>
<<else>>
| <label><span class="def">Bite</span> <<radiobutton "$mouthaction" "mouthbitetentacle6">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle6vagina">><<nobr>>
<<if $tentacle6head is "vaginaentrance">>
<<if $vaginaactiondefault is "vaginarubtentacle6">>
| <label><span class="sub">Rub</span> <<radiobutton "$vaginaaction" "vaginarubtentacle6" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$vaginaaction" "vaginarubtentacle6">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $vaginaactiondefault is "vaginapullawaytentacle6">>
| <label><span class="brat">Pull away</span> <<radiobutton "$vaginaaction" "vaginapullawaytentacle6" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$vaginaaction" "vaginapullawaytentacle6">></label>
<</if>>
<</if>>
<<elseif $tentacle6head is "vaginaimminent">>
<<if $vaginaactiondefault is "vaginarubtentacle6">>
| <label><span class="sub">Rub</span> <<radiobutton "$vaginaaction" "vaginarubtentacle6" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$vaginaaction" "vaginarubtentacle6">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $vaginaactiondefault is "vaginapullawaytentacle6">>
| <label><span class="brat">Pull away</span> <<radiobutton "$vaginaaction" "vaginapullawaytentacle6" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$vaginaaction" "vaginapullawaytentacle6">></label>
<</if>>
<</if>>
<<elseif $tentacle6head is "vagina">>
<<if $vaginaactiondefault is "vaginacooperatetentacle6">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$vaginaaction" "vaginacooperatetentacle6" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$vaginaaction" "vaginacooperatetentacle6">></label>
<</if>>
<<elseif $tentacle6head is "vaginadeep">>
<<if $vaginaactiondefault is "vaginacooperatetentacle6">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$vaginaaction" "vaginacooperatetentacle6" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$vaginaaction" "vaginacooperatetentacle6">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle6penis">><<nobr>>
<<if $tentacle6head is "penisentrance">>
<<if $penisactiondefault is "penisrubtentacle6">>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "penisrubtentacle6" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "penisrubtentacle6">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $penisactiondefault is "penispullawaytentacle6">>
| <label><span class="brat">Pull away</span> <<radiobutton "$penisaction" "penispullawaytentacle6" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$penisaction" "penispullawaytentacle6">></label>
<</if>>
<</if>>
<<elseif $tentacle6head is "penisimminent">>
<<if $penisactiondefault is "penisrubtentacle6">>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "penisrubtentacle6" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "penisrubtentacle6">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $penisactiondefault is "penispullawaytentacle6">>
| <label><span class="brat">Pull away</span> <<radiobutton "$penisaction" "penispullawaytentacle6" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$penisaction" "penispullawaytentacle6">></label>
<</if>>
<</if>>
<<elseif $tentacle6head is "penis">>
<<if $penisactiondefault is "peniscooperatetentacle6">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$penisaction" "peniscooperatetentacle6" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$penisaction" "peniscooperatetentacle6">></label>
<</if>>
<<elseif $tentacle6head is "penisdeep">>
<<if $penisactiondefault is "peniscooperatetentacle6">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$penisaction" "peniscooperatetentacle6" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$penisaction" "peniscooperatetentacle6">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle6anus">><<nobr>>
<<if $tentacle6head is "anusentrance">>
<<if $anusactiondefault is "anusrubtentacle6">>
| <label><span class="sub">Rub</span> <<radiobutton "$anusaction" "anusrubtentacle6" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$anusaction" "anusrubtentacle6">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $anusactiondefault is "anuspullawaytentacle6">>
| <label><span class="brat">Pull away</span> <<radiobutton "$anusaction" "anuspullawaytentacle6" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$anusaction" "anuspullawaytentacle6">></label>
<</if>>
<</if>>
<<elseif $tentacle6head is "anusimminent">>
<<if $anusactiondefault is "anusrubtentacle6">>
| <label><span class="sub">Rub</span> <<radiobutton "$anusaction" "anusrubtentacle6" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$anusaction" "anusrubtentacle6">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $anusactiondefault is "anuspullawaytentacle6">>
| <label><span class="brat">Pull away</span> <<radiobutton "$anusaction" "anuspullawaytentacle6" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$anusaction" "anuspullawaytentacle6">></label>
<</if>>
<</if>>
<<elseif $tentacle6head is "anus">>
<<if $anusactiondefault is "anuscooperatetentacle6">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$anusaction" "anuscooperatetentacle6" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$anusaction" "anuscooperatetentacle6">></label>
<</if>>
<<elseif $tentacle6head is "anusdeep">>
<<if $anusactiondefault is "anuscooperatetentacle6">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$anusaction" "anuscooperatetentacle6" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$anusaction" "anuscooperatetentacle6">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle6thighs">><<nobr>>
<<if $tentacle6head is "penisrub">>
<<if $thighactiondefault is "penisrubtentacle6">>
| <label><span class="sub">Rub</span> <<radiobutton "$thighaction" "penisrubtentacle6" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$thighaction" "penisrubtentacle6">></label>
<</if>>
<<elseif $tentacle6head is "vaginarub">>
<<if $thighactiondefault is "vaginarubtentacle6">>
| <label><span class="sub">Rub</span> <<radiobutton "$thighaction" "vaginarubtentacle6" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$thighaction" "vaginarubtentacle6">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle6bottom">><<nobr>>
<<if $tentacle6head is "bottomrub">>
<<if $bottomactiondefault is "bottomrubtentacle6">>
| <label><span class="sub">Rub</span> <<radiobutton "$bottomaction" "bottomrubtentacle6" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$bottomaction" "bottomrubtentacle6">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle6chest">><<nobr>>
<<if $tentacle6head is "chest">>
<<if $chestactiondefault is "chestrubtentacle6">>
| <label><span class="sub">Rub</span> <<radiobutton "$chestaction" "chestrubtentacle6" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$chestaction" "chestrubtentacle6">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "effectstentacle6">><<nobr>>
<<if $leftaction is "lefthittentacle6">><<set $leftaction to 0>><<set $leftactiondefault to "lefthittentacle6">>You strike the $tentacle6 tentacle with your left hand and it reels away from you.<<defiance 2>><<set $speechhit to 1>><<tentacle6disable>><<set $attackstat += 1>><<set $tentacle6health -= 1>>
<<if $rng lte ($physique / 200)>>
<<set $tentacle6health -= 1>>
<</if>>
<</if>>
<<if $rightaction is "righthittentacle6">><<set $rightaction to 0>><<set $rightactiondefault to "righthittentacle6">>You strike the $tentacle6 tentacle with your right hand and it reels away from you.<<defiance 2>><<set $speechhit to 1>><<tentacle6disable>><<set $attackstat += 1>><<set $tentacle6health -= 1>>
<<if $rng lte ($physique / 200)>>
<<set $tentacle6health -= 1>>
<</if>>
<</if>>
<<if $leftaction is "leftgrabtentacle6">><<set $leftaction to 0>><<set $leftactiondefault to "leftrubtentacle6">><<submission 1>><<handstat>><span class="lblue">You <<handtext>> grab the $tentacle6 tentacle with your left hand.</span><<tentacle6disable>><<set $leftarm to "tentacle6">><<set $tentacle6head to "leftarm">><<handstat>><<set $leftarmstate to "tentacle">>
<</if>>
<<if $rightaction is "rightgrabtentacle6">><<set $rightaction to 0>><<set $rightactiondefault to "rightrubtentacle6">><<submission 1>><<handstat>><span class="lblue">You <<handtext>> grab the $tentacle6 tentacle with your right hand.</span><<tentacle6disable>><<set $rightarm to "tentacle6">><<set $tentacle6head to "rightarm">><<handstat>><<set $rightarmstate to "tentacle">>
<</if>>
<<if $leftaction is "leftrubtentacle6">><<set $leftaction to 0>><<set $leftactiondefault to "leftrubtentacle6">><<handskilluse>><<submission 1>>You <<handtext>> squeeze the $tentacle6 tentacle in your left hand and rub up and down its length.<<set $rng to random(1, 100)>>
<<if $handskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $rightarmgoo += 1>><<set $tentacle6health -= 3>><<handejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $rightaction is "rightrubtentacle6">><<set $rightaction to 0>><<set $rightactiondefault to "rightrubtentacle6">><<handskilluse>><<submission 1>>You <<handtext>> squeeze the $tentacle6 tentacle in your right hand and rub up and down its length.<<set $rng to random(1, 100)>>
<<if $handskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $rightarmgoo += 1>><<set $tentacle6health -= 3>><<handejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $leftaction is "leftstoptentacle6">><<set $leftaction to 0>><<set $leftactiondefault to "leftstoptentacle6">>You release the $tentacle6 tentacle from your left hand.<<tentacle6disable>>
<</if>>
<<if $rightaction is "rightstoptentacle6">><<set $rightaction to 0>><<set $rightactiondefault to "rightstoptentacle6">>You release the $tentacle6 tentacle from your right hand.<<tentacle6disable>>
<</if>>
<<if $feetaction is "feethittentacle6">><<set $feetaction to 0>><<set $feetactiondefault to "feethittentacle6">>You kick the $tentacle6 tentacle and it reels away from you.<<defiance 2>><<set $speechhit to 1>><<tentacle6disable>><<set $attackstat += 1>><<set $tentacle6health -= 1>>
<<if $rng lte ($physique / 200)>>
<<set $tentacle6health -= 1>>
<</if>>
<</if>>
<<if $feetaction is "feetgrabtentacle6">><<set $feetaction to 0>><<set $feetactiondefault to "feetrubtentacle6">><<submission 1>><<feetstat>><span class="lblue">You <<feettext>> grab the $tentacle6 tentacle between your feet.</span><<tentacle6disable>><<set $leftleg to "tentacle6">><<set $rightleg to "tentacle6">><<set $tentacle6head to "feet">><<feetstat>><<set $feetstate to "tentacle">>
<</if>>
<<if $feetaction is "feetrubtentacle6">><<set $feetaction to 0>><<set $feetactiondefault to "feetrubtentacle6">><<feetskilluse>><<submission 1>>You <<feettext>> squeeze the $tentacle6 tentacle between your feet and rub up and down its length.<<set $rng to random(1, 100)>>
<<if $feetskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $feetgoo += 1>><<set $tentacle6health -= 3>><<feetejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $feetaction is "feetstoptentacle6">><<set $feetaction to 0>><<set $feetactiondefault to "feetstoptentacle6">>You let go of the $tentacle6 tentacle between your feet.<<tentacle6disable>>
<</if>>
<<if $mouthaction is "mouthlicktentacle6">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthlicktentacle6">>
<<submission 2>><<oralskilluse>>You <<oraltext>> lick the tip of the $tentacle6 tentacle.<<set $rng to random(1, 100)>>
<<if $oralskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your face.</span><<set $facegoo += 1>><<set $tentacle6health -= 3>><<faceejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $mouthaction is "mouthkisstentacle6">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthkisstentacle6">>
<<submission 3>><<oralskilluse>>You <<oraltext>> kiss the tip of the $tentacle6 tentacle.<<set $rng to random(1, 100)>>
<<if $oralskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your face.</span><<set $facegoo += 1>><<set $tentacle6health -= 3>><<faceejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $mouthaction is "mouthcooperatetentacle6">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthcooperatetentacle6">>
<<sex 5>><<oralskilluse>>You <<oraltext>> suck the $tentacle6 tentacle invading your mouth.<<set $rng to random(1, 100)>>
<<if $oralskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip and into your mouth.</span><<set $tentacle6health -= 3>><<set $drugged += 3>><<set $mouthgoo += 1>><<oralejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $mouthaction is "mouthpullawaytentacle6">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthpullawaytentacle6">><<brat 1>><span class="teal">You pull away from the $tentacle6 tentacle threatening your mouth.</span><<tentacle6disable>>
<</if>>
<<if $mouthaction is "mouthbitetentacle6">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthbitetentacle6">><<defiance 5>>You bite down on the $tentacle6 tentacle invading your mouth. <span class="teal">It recoils immediately.</span><<tentacle6disable>><<set $attackstat += 1>><<set $tentacle6health -= 1>>
<<if $rng lte ($physique / 200)>>
<<set $tentacle6health -= 1>>
<</if>>
<</if>>
<<if $vaginaaction is "vaginarubtentacle6">><<set $vaginaaction to 0>><<set $vaginaactiondefault to "vaginarubtentacle6">>
<<submission 2>><<vaginalskilluse>>You <<vaginaltext>> rub the tip of the $tentacle6 tentacle with your <<pussystop>><<set $rng to random(1, 100)>>
<<if $vaginalskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $vaginaoutsidegoo += 1>><<set $tentacle6health -= 3>><<vaginalentranceejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $vaginaaction is "vaginacooperatetentacle6">><<set $vaginaaction to 0>><<set $vaginaactiondefault to "vaginacooperatetentacle6">>
<<sex 5>><<vaginalskilluse>>You <<vaginaltext>> push back against the $tentacle6 tentacle invading your <<pussystop>><<set $rng to random(1, 100)>>
<<if $vaginalskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, flooding your womb with its warmth.</span><<set $tentacle6health -= 3>><<set $drugged += 3>><<set $vaginagoo += 1>><<vaginalejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $vaginaaction is "vaginapullawaytentacle6">><<set $vaginaaction to 0>><<set $vaginaactiondefault to "vaginapullawaytentacle6">><<brat 1>><span class="teal">You pull away from the $tentacle6 tentacle threatening your <<pussystop>></span><<tentacle6disable>>
<</if>>
<<if $penisaction is "penisrubtentacle6">><<set $penisaction to 0>><<set $penisactiondefault to "penisrubtentacle6">>
<<submission 2>><<penileskilluse>>You <<peniletext>> rub the tip of the $tentacle6 tentacle with your <<penisstop>><<set $rng to random(1, 100)>>
<<if $penileskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $penisgoo += 1>><<set $tentacle6health -= 3>><<penileejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $penisaction is "peniscooperatetentacle6">><<set $penisaction to 0>><<set $penisactiondefault to "peniscooperatetentacle6">>
<<sex 5>><<penileskilluse>>You <<peniletext>> push back against the $tentacle6 tentacle engulfing your <<penisstop>><<set $rng to random(1, 100)>>
<<if $penileskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your groin.</span><<set $tentacle6health -= 3>><<set $penisgoo += 1>><<penileejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $penisaction is "penispullawaytentacle6">><<set $penisaction to 0>><<set $penisactiondefault to "penispullawaytentacle6">><<brat 1>><span class="teal">You pull away from the $tentacle6 tentacle threatening your <<penisstop>></span><<tentacle6disable>>
<</if>>
<<if $anusaction is "anusrubtentacle6">><<set $anusaction to 0>><<set $anusactiondefault to "anusrubtentacle6">>
<<submission 2>><<analskilluse>>You <<analtext>> rub the tip of the $tentacle6 tentacle with your <<bottomstop>><<set $rng to random(1, 100)>>
<<if $analskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your <<bottomstop>></span><<set $bottomgoo += 1>><<set $tentacle6health -= 3>><<bottomejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $anusaction is "anuscooperatetentacle6">><<set $anusaction to 0>><<set $anusactiondefault to "anuscooperatetentacle6">>
<<sex 5>><<analskilluse>>You <<analtext>> push back against the $tentacle6 tentacle invading your <<bottomstop>><<set $rng to random(1, 100)>>
<<if $analskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, flooding your bowels with its warmth.</span><<set $tentacle6health -= 3>><<set $drugged += 3>><<set $anusgoo += 1>><<analejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $anusaction is "anuspullawaytentacle6">><<set $anusaction to 0>><<set $anusactiondefault to "anuspullawaytentacle6">><<brat 1>><span class="teal">You pull away from the $tentacle6 tentacle threatening your <<bottomstop>></span><<tentacle6disable>>
<</if>>
<<if $thighaction is "penisrubtentacle6">><<set $thighaction to 0>><<set $thighactiondefault to "penisrubtentacle6">>
<<submission 3>><<thighskilluse>>You <<thightext>> rub the $tentacle6 tentacle between your thighs.<<set $rng to random(1, 100)>>
<<if $thighskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your tummy.</span><<set $tentacle6health -= 3>><<set $tummygoo += 1>><<tummyejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $thighaction is "vaginarubtentacle6">><<set $thighaction to 0>><<set $thighactiondefault to "vaginarubtentacle6">>
<<submission 3>><<thighskilluse>>You <<thightext>> rub the $tentacle6 tentacle between your thighs.<<set $rng to random(1, 100)>>
<<if $thighskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your tummy.</span><<set $tentacle6health -= 3>><<set $tummygoo += 1>><<tummyejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $bottomaction is "bottomrubtentacle6">><<set $bottomaction to 0>><<set $bottomactiondefault to "bottomrubtentacle6">>
<<submission 3>><<bottomskilluse>>You <<bottomtext>> rub the $tentacle6 tentacle between your cheeks.<<set $rng to random(1, 100)>>
<<if $bottomskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your <<bottomstop>></span><<set $tentacle6health -= 3>><<set $bottomgoo += 1>><<bottomejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $chestaction is "chestrubtentacle6">><<set $chestaction to 0>><<set $chestactiondefault to "chestrubtentacle6">>
<<submission 3>><<chestskilluse>>You <<chesttext>> rub the $tentacle6 tentacle between your <<breastsstop>><<set $rng to random(1, 100)>>
<<if $chestskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your chest.</span><<set $tentacle6health -= 3>><<set $chestgoo += 1>><<chestejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<</nobr>><</widget>>
:: Widgets Combat Tentacle7 [widget]
<<widget "tentacle7">><<nobr>>
<<if $tentacle7health lte 0 and $tentacle7shaft isnot "finished">>
Worn out, the $tentacle7 tentacle retracts from you.
<<tentacle7disable>>
<<set $tentacle7shaft to "finished">>
<<set $tentacle7head to "finished">>
<</if>>
<<if $tentacle7shaft is "tummy">>
The $tentacle7 tentacle <<slithers>> around your tummy,
<</if>>
<<if $tentacle7shaft is "thighs">>
The $tentacle7 tentacle <<slithers>> between your thighs,
<</if>>
<<if $tentacle7shaft is "breasts">>
The $tentacle7 tentacle squeezes your breasts together,
<</if>>
<<if $tentacle7shaft is "chest">>
The $tentacle7 tentacle <<slithers>> around your chest,
<</if>>
<<if $tentacle7shaft is "waist">>
The $tentacle7 tentacle <<slithers>> around your waist,
<</if>>
<<if $tentacle7shaft is "neck">>
The $tentacle7 tentacle <<slithers>> around your neck,
<</if>>
<<if $tentacle7shaft is "shoulders">>
The $tentacle7 tentacle <<slithers>> around your shoulders,
<</if>>
<<if $tentacle7shaft is "leftleg">>
The $tentacle7 tentacle <<slithers>> around your left leg,
<</if>>
<<if $tentacle7shaft is "rightleg">>
The $tentacle7 tentacle <<slithers>> around your right leg,
<</if>>
<<if $tentacle7shaft is "leftarm">>
The $tentacle7 tentacle <<slithers>> around your left arm,
<</if>>
<<if $tentacle7shaft is "rightarm">>
The $tentacle7 tentacle <<slithers>> around your right arm,
<</if>>
<<if $tentacle7head is "leftarm">>
The $tentacle7 tentacle writhes in your left hand.<<neutral 5>>
<</if>>
<<if $tentacle7head is "rightarm">>
The $tentacle7 tentacle writhes in your right hand.<<neutral 5>>
<</if>>
<<if $tentacle7head is "feet">>
The $tentacle7 tentacle writhes between your feet.<<neutral 5>>
<</if>>
<<if $tentacle7head is "leftnipplesuck">>
and up to your <<breastscomma>> where it suckles your left nipple.<<neutral 3>>
<</if>>
<<if $tentacle7head is "rightnipplesuck">>
and up to your <<breastscomma>> where it suckles your right nipple.<<neutral 3>>
<</if>>
<<if $tentacle7head is "leftnipple">>
and continues teasing your left nipple. <span class="purple">The tip of the tentacle opens up, latches on, then begins sucking.</span><<neutral 3>><<set $tentacle7head to "leftnipplesuck">><<set $leftnipple to "tentaclesuck">>
<</if>>
<<if $tentacle7head is "rightnipple">>
and continues teasing your right nipple. <span class="purple">The tip of the tentacle opens up, latches on, then begins sucking.</span><<neutral 3>><<set $tentacle7head to "rightnipplesuck">><<set $rightnipple to "tentaclesuck">>
<</if>>
<<if $tentacle7head is "chest">>
<<if $chestuse is "squeezed">>
then up between your <<breastscomma>> rubbing itself between them.<<neutral 2>>
<<else>>
moves away from your <<breasts>><<set $tentacle7head to 0>><<set $breastuse to 0>>
<</if>>
<</if>>
<<if $tentacle7head is "mouthdeep">>
and up into your mouth where it spurts a sweet fluid down your throat at the apex of each thrust.<<set $purity -= 1>><<internalejac>><<sex 5>><<set $drugged += 3>><<set $mouthgoo += 1>><<set $tentacle7health -= 1>>
<</if>>
<<if $tentacle7head is "mouth">>
and continues thrusting into your mouth.<span class="pink"> The tip opens and begins oozing a sweet liquid.</span><<set $purity -= 1>><<internalejac>><<set $mouthstate to "tentacledeep">><<set $tentacle7head to "mouthdeep">><<sex 5>><<oralejacstat>><<ejacstat>>
<</if>>
<<if $tentacle7head is "mouthimminent">>
<<if $oralvirginity is 1>>
<span class="pink"> and thrusts between your lips,</span><span class="red"> penetrating your mouth for the first time.</span><<set $oralvirginity to 0>><<violence 5>>
<<else>>
<span class="pink"> and thrusts between your lips.</span>
<</if>>
<<set $mouthstate to "tentacle">><<set $tentacle7head to "mouth">><<sex 5>><<raped>><<oralstat>>
<</if>>
<<if $tentacle7head is "mouthentrance">>
<span class="purple"> and presses against your lips.</span><<set $mouthstate to "tentacleimminent">><<set $tentacle7head to "mouthimminent">><<neutral 4>>
<</if>>
<<if $tentacle7head is "vaginadeep">>
and <<slithers>> into your <<pussy>> where it pumps a viscous fluid at the apex of each thrust.<<set $purity -= 1>><<internalejac>><<sex 5>><<set $drugged += 3>><<set $vaginagoo += 1>><<set $tentacle7health -= 1>>
<</if>>
<<if $tentacle7head is "vagina">>
and continues thrusting into your <<pussystop>><span class="pink"> The tip opens and begins oozing a viscous liquid.</span><<set $purity -= 1>><<internalejac>><<set $vaginastate to "tentacledeep">><<set $tentacle7head to "vaginadeep">><<sex 5>><<vaginalejacstat>><<ejacstat>>
<</if>>
<<if $tentacle7head is "vaginaimminent">>
<<if $vaginalvirginity is 1>>
<span class="pink"> and thrusts into your <<pussycomma>></span><span class="red"> tearing your hymen and forever robbing you of your purity.</span><<set $vaginalvirginity to 0>><<violence 100>>
<<else>>
<span class="pink"> and thrusts into your <<pussystop>></span>
<</if>>
<<set $vaginastate to "tentacle">><<set $tentacle7head to "vagina">><<sex 5>><<raped>><<vaginaraped>><<vaginalstat>><<violence 1>>
<</if>>
<<if $tentacle7head is "vaginaentrance">>
<<if $undertype isnot "chastity">>
<span class="purple"> and presses against your <<pussycomma>> about to penetrate.</span><<set $vaginastate to "tentacleimminent">><<set $tentacle7head to "vaginaimminent">><<neutral 4>>
<<else>>
and tries to find a way inside. Failing, it lashes at the metal.<<set $underintegrity -= 10>><<violence 1>>
<</if>>
<</if>>
<<if $tentacle7head is "penisdeep">>
and continues thrusting against your <<peniscomma>> caressing and kneading your length.<<sex 5>>
<</if>>
<<if $tentacle7head is "penis">>
and continues thrusting against your <<penisstop>><span class="pink"> It sucks and kneads your length, trying to milk you of your cum.</span><<set $penisstate to "tentacledeep">><<set $tentacle7head to "penisdeep">><<sex 5>>
<</if>>
<<if $tentacle7head is "penisimminent">>
<<if $penilevirginity is 1>>
<span class="pink"> and thrusts against your <<peniscomma>> swallowing you to the base and </span><span class="red"> tearing the membrane between your glans and foreskin, forever robbing you of your purity.</span><<set $penilevirginity to 0>><<violence 100>>
<<else>>
<span class="pink"> and thrusts against your <<peniscomma>> swallowing you to the base.</span>
<</if>>
<<set $penisstate to "tentacle">><<set $tentacle7head to "penis">><<sex 5>><<raped>><<penisraped>><<penilestat>><<violence 1>>
<</if>>
<<if $tentacle7head is "penisentrance">>
<<if $undertype isnot "chastity">>
<span class="purple"> and <<slithers>> over to your <<penisstop>> The tip opens and presses against your glans, about to envelop you.</span><<set $penisstate to "tentacleimminent">><<set $tentacle7head to "penisimminent">><<neutral 4>>
<<else>>
and tries to find a way inside. Failing, it lashes at the metal.<<set $underintegrity -= 10>><<violence 1>>
<</if>>
<</if>>
<<if $tentacle7head is "anusdeep">>
and <<slithers>> into your <<bottom>> where it pumps a viscous fluid at the apex of each thrust.<<set $purity -= 1>><<internalejac>><<sex 5>><<set $drugged += 3>><<set $anusgoo += 1>><<set $tentacle7health -= 1>>
<</if>>
<<if $tentacle7head is "anus">>
and continues thrusting into your <<bottomstop>><span class="pink"> The tip opens and begins oozing a viscous liquid.</span><<set $purity -= 1>><<internalejac>><<set $anusstate to "tentacledeep">><<set $tentacle7head to "anusdeep">><<sex 5>><<analejacstat>><<ejacstat>>
<</if>>
<<if $tentacle7head is "anusimminent">>
<<if $analvirginity is 1>>
<span class="pink"> and thrusts into your <<bottomcomma>></span><span class="red"> violating you in a way you hadn't conceived of.</span><<set $analvirginity to 0>><<violence 100>>
<<else>>
<span class="pink"> and thrusts into your <<bottomstop>></span>
<</if>>
<<set $anusstate to "tentacle">><<set $tentacle7head to "anus">><<sex 5>><<raped>><<analstat>><<violence 1>>
<</if>>
<<if $tentacle7head is "anusentrance">>
<<if $analshield is 0>>
<span class="purple"> and presses against your <<bottomcomma>> about to penetrate.</span><<set $anusstate to "tentacleimminent">><<set $tentacle7head to "anusimminent">><<neutral 4>>
<<else>>
and tries to find a way inside. Failing, it lashes at the device.<<set $underintegrity -= 10>><<violence 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $tentacle7head is "vaginarub">>
<<if $rng gte 21>>
and between your thighs where it <<slithers>> against your <<pussycomma>> pressing against your clit.<<sex 3>>
<<else>>
and between your thighs <span class="blue">where it <<slithers>> toward your <<pussystop>></span><<neutral 3>><<set $vaginause to "tentacle">><<set $vaginastate to "tentacleentrance">><<set $tentacle7head to "vaginaentrance">><<set $thighuse to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $tentacle7head is "penisrub">>
<<if $rng gte 21>>
and between your thighs where it <<slithers>> against your <<peniscomma>> coiling around it.<<sex 3>>
<<else>>
and between your thighs <span class="blue">where the tip opens and it <<slithers>> toward your <<penisstop>></span><<neutral 3>><<set $penisuse to "tentacle">><<set $penisstate to "tentacleentrance">><<set $tentacle7head to "penisentrance">><<set $thighuse to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $tentacle7head is "bottomrub">>
<<if $rng gte 21>>
and between your <<bottom>> cheeks where it <<slithers>> against your back.<<sex 3>>
<<else>>
and between your <<bottom>> cheeks, <span class="blue"> toward your anus.</span><<neutral 3>><<set $anususe to "tentacle">><<set $anusstate to "tentacleentrance">><<set $tentacle7head to "anusentrance">><<set $bottomuse to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $tentacle7head is 0 and $tentacle7shaft isnot 0>>
<<if $rng lte 10>>
<<if $chestuse is "squeezed" and $breastuse is 0>>
<<upperslither>><span class="blue">and up between your squeezed <<breastsstop>></span><<set $tentacle7head to "chest">><<neutral 2>><<set $breastuse to "tentacle">><<cheststat>>
<<else>>
<<tentacle7default>>
<</if>>
<<elseif $rng lte 20>>
<<if $leftnipple is 0>>
<<upperslither>> <span class="blue">and teases your left nipple.</span><<neutral 2>><<set $tentacle7head to "leftnipple">><<set $leftnipple to "tentacle">>
<<else>>
<<tentacle7default>>
<</if>>
<<elseif $rng lte 30>>
<<if $rightnipple is 0>>
<<upperslither>> <span class="blue">and teases your right nipple.</span><<neutral 2>><<set $tentacle7head to "rightnipple">><<set $rightnipple to "tentacle">>
<<else>>
<<tentacle7default>>
<</if>>
<<elseif $rng lte 40>>
<<if $mouthuse is 0>>
<<upperslither>> <span class="blue">and up toward your mouth.</span><<neutral 2>><<set $mouthuse to "tentacle">><<set $mouthstate to "tentacleentrance">><<set $tentacle7head to "mouthentrance">>
<<else>>
<<tentacle7default>>
<</if>>
<<elseif $rng lte 50>>
<<if $anususe is 0 and $analdisable is "f">>
<<underslither>> <span class="blue">and <<slithers>> toward your <<bottomstop>></span><<neutral 2>><<set $anususe to "tentacle">><<set $anusstate to "tentacleentrance">><<set $tentacle7head to "anusentrance">>
<<else>>
<<tentacle7default>>
<</if>>
<<elseif $rng lte 60>>
<<if $vaginaexist is 1 and $vaginause is 0>>
<<underslither>> <span class="blue">and <<slithers>> toward your <<pussystop>></span><<neutral 2>><<set $vaginause to "tentacle">><<set $vaginastate to "tentacleentrance">><<set $tentacle7head to "vaginaentrance">>
<<else>>
<<tentacle7default>>
<</if>>
<<elseif $rng lte 70>>
<<if $penisexist is 1 and $penisuse is 0>>
<<underslither>> <span class="blue">and <<slithers>> toward your <<penisstop>></span><<neutral 2>><<set $penisuse to "tentacle">><<set $penisstate to "tentacleentrance">><<set $tentacle7head to "penisentrance">>
<<else>>
<<tentacle7default>>
<</if>>
<<elseif $rng lte 80>>
<<if $thighuse is 0>>
<<if $penisexist is 1 and $penisuse is 0>>
<<underslither>> <span class="blue">and <<slithers>> between your thighs and against your tummy and <<penisstop>></span><<set $penisuse to "tentaclerub">><<set $thighuse to "tentaclerub">><<set $tentacle7head to "penisrub">><<sex 3>><<thighstat>>
<<elseif $vaginaexist is 1 and $vaginause is 0>>
<<underslither>> <span class="blue">and <<slithers>> between your thighs and against your tummy and <<pussystop>></span><<set $vaginause to "tentaclerub">><<set $thighuse to "tentaclerub">><<set $tentacle7head to "vaginarub">><<sex 3>><<thighstat>>
<<else>>
<<tentacle7default>>
<</if>>
<<else>>
<<tentacle7default>>
<</if>>
<<elseif $rng lte 90>>
<<if $bottomuse is 0 and $anususe is 0 and $analdisable is "f">>
<<underslither>> <span class="blue">and <<slithers>> between your <<bottom>> cheeks and against your back.</span><<set $bottomuse to "tentaclerub">><<set $anususe to "tentaclerub">><<set $tentacle7head to "bottomrub">><<sex 1>><<bottomstat>>
<<else>>
<<tentacle7default>>
<</if>>
<<else>>
<<tentacle7default>>
<</if>>
<<elseif $tentacle7head is 0 and $tentacle7shaft is 0>>
<<if $rng lte 10>>
<<if $position isnot "wall">>
The $tentacle7 tentacle winds around your tummy.<<neutral 1>><<set $tentacle7shaft to "tummy">>
<<else>>
The $tentacle7 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<elseif $rng lte 20>>
The $tentacle7 tentacle <<slithers>> between your thighs.<<neutral 1>><<set $tentacle7shaft to "thighs">>
<<elseif $rng lte 30>>
<<if $position isnot "wall">>
<<if $breastsize gte 2 and $chestuse is 0>>
The $tentacle7 tentacle <<slithers>> around your <<breastscomma>> <span class="blue">squeezing them together.</span><<neutral 1>><<set $tentacle7shaft to "breasts">><<set $chestuse to "squeezed">>
<<else>>
The $tentacle7 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<else>>
The $tentacle7 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<elseif $rng lte 40>>
<<if $position isnot "wall">>
The $tentacle7 tentacle winds its way around your chest, beneath your <<breastsstop>><<neutral 1>><<set $tentacle7shaft to "chest">>
<<else>>
The $tentacle7 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<elseif $rng lte 50>>
The $tentacle7 tentacle winds its way around your waist.<<neutral 1>><<set $tentacle7shaft to "waist">>
<<elseif $rng lte 60>>
<<if $position isnot "wall">>
<<if $head is 0>>
The $tentacle7 tentacle winds its way around your neck, <span class="blue">restraining your head.</span><<neutral 1>><<set $tentacle7shaft to "neck">><<set $head to "grappled">>
<<else>>
The $tentacle7 tentacle winds its way around your shoulders.<<neutral 1>><<set $tentacle7shaft to "shoulders">>
<</if>>
<<else>>
The $tentacle7 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<elseif $rng lte 70>>
The $tentacle7 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<<elseif $rng lte 80>>
<<if $leftleg is 0>>
The $tentacle7 tentacle winds its way around your left leg, <span class="blue">restraining it.</span><<neutral 1>><<feettentacledisable>><<set $tentacle7shaft to "leftleg">><<set $leftleg to "grappled">>
<<else>>
The $tentacle7 tentacle tickles your feet.<<neutral 1>>
<</if>>
<<elseif $rng lte 85>>
<<if $rightleg is 0>>
The $tentacle7 tentacle winds its way around your right leg, <span class="blue">restraining it.</span><<neutral 1>><<feettentacledisable>><<set $tentacle7shaft to "rightleg">><<set $rightleg to "grappled">>
<<else>>
The $tentacle7 tentacle tickles your feet.<<neutral 1>>
<</if>>
<<elseif $rng lte 90>>
<<if $leftarm is 0>>
The $tentacle7 tentacle winds its way around your left arm, <span class="blue">restraining it.</span><<neutral 1>><<leftarmtentacledisable>><<set $tentacle7shaft to "leftarm">><<set $leftarm to "grappled">><<set $leftarmstate to 0>>
<<else>>
The $tentacle7 tentacle tickles your armpit.<<neutral 1>>
<</if>>
<<elseif $rng lte 95>>
<<if $rightarm is 0>>
The $tentacle7 tentacle winds its way around your right arm, <span class="blue">restraining it.</span><<rightarmtentacledisable>><<neutral 1>><<set $tentacle7shaft to "rightarm">><<set $rightarm to "grappled">><<set $rightarmstate to 0>>
<<else>>
The $tentacle7 tentacle tickles your armpit.<<neutral 1>>
<</if>>
<<elseif $rng lte 100>>
The $tentacle7 tentacle <<slithers>> against your <<bottomstop>><<neutral 1>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "tentacle7default">><<nobr>>
<<set $rng to random(1, 100)>>
<<if $rng gte 90>>
then squirts a warm fluid over your neck.<<neutral 1>><<set $neckgoo += 1>><<set $tentacle7health -= 1>><<neckejacstat>><<ejacstat>>
<<elseif $rng gte 80>>
then squirts a warm fluid over your right arm.<<neutral 1>><<set $rightarmgoo += 1>><<set $tentacle7health -= 1>><<handejacstat>><<ejacstat>>
<<elseif $rng gte 70>>
then squirts a warm fluid over your left arm.<<neutral 1>><<set $leftarmgoo += 1>><<set $tentacle7health -= 1>><<handejacstat>><<ejacstat>>
<<elseif $rng gte 60>>
then squirts a warm fluid over your thighs.<<neutral 1>><<set $thighgoo += 1>><<set $tentacle7health -= 1>><<thighejacstat>><<ejacstat>>
<<elseif $rng gte 50>>
then squirts a warm fluid over your <<bottomstop>><<neutral 1>><<set $bottomgoo += 1>><<set $tentacle7health -= 1>><<bottomejacstat>><<ejacstat>>
<<elseif $rng gte 40>>
then squirts a warm fluid over your tummy.<<neutral 1>><<set $tummygoo += 1>><<set $tentacle7health -= 1>><<tummyejacstat>><<ejacstat>>
<<elseif $rng gte 30>>
then squirts a warm fluid over your chest.<<neutral 1>><<set $chestgoo += 1>><<set $tentacle7health -= 1>><<chestejacstat>><<ejacstat>>
<<elseif $rng gte 20>>
then squirts a warm fluid over your face.<<neutral 1>><<set $facegoo += 1>><<set $tentacle7health -= 1>><<faceejacstat>><<ejacstat>>
<<elseif $rng gte 10>>
then squirts a warm fluid over your hair.<<neutral 1>><<set $hairgoo += 1>><<set $tentacle7health -= 1>><<hairejacstat>><<ejacstat>>
<<else>>
then squirts a warm fluid over your feet.<<neutral 1>><<set $feetgoo += 1>><<set $tentacle7health -= 1>><<feetejacstat>><<ejacstat>>
<</if>>
<</nobr>><</widget>>
<<widget "tentacle7disable">><<nobr>>
<<if $tentacle7head is "feet">>
<<set $leftleg to 0>>
<<set $rightleg to 0>>
<<set $feetstate to 0>>
<</if>>
<<if $tentacle7head is "leftarm">>
<<set $leftarm to 0>>
<<set $leftarmstate to 0>>
<</if>>
<<if $tentacle7head is "rightarm">>
<<set $rightarm to 0>>
<<set $rightarmstate to 0>>
<</if>>
<<if $tentacle7head is "leftnipplesuck">>
<<set $leftnipple to 0>>
<</if>>
<<if $tentacle7head is "rightnipplesuck">>
<<set $rightnipple to 0>>
<</if>>
<<if $tentacle7head is "leftnipple">>
<<set $leftnipple to 0>>
<</if>>
<<if $tentacle7head is "rightnipple">>
<<set $rightnipple to 0>>
<</if>>
<<if $tentacle7head is "chest">>
<<set $chestuse to 0>>
<</if>>
<<if $tentacle7head is "mouthentrance">>
<<set $mouthuse to 0>>
<<set $mouthstate to 0>>
<</if>>
<<if $tentacle7head is "mouthimminent">>
<<set $mouthuse to 0>>
<<set $mouthstate to 0>>
<</if>>
<<if $tentacle7head is "mouth">>
<<set $mouthuse to 0>>
<<set $mouthstate to 0>>
<</if>>
<<if $tentacle7head is "mouthdeep">>
<<set $mouthuse to 0>>
<<set $mouthstate to 0>>
<</if>>
<<if $tentacle7head is "anusentrance">>
<<set $anususe to 0>>
<<set $anusstate to 0>>
<</if>>
<<if $tentacle7head is "anusimminent">>
<<set $anususe to 0>>
<<set $anusstate to 0>>
<</if>>
<<if $tentacle7head is "anus">>
<<set $anususe to 0>>
<<set $anusstate to 0>>
<</if>>
<<if $tentacle7head is "anusdeep">>
<<set $anususe to 0>>
<<set $anusstate to 0>>
<</if>>
<<if $tentacle7head is "vaginaentrance">>
<<set $vaginause to 0>>
<<set $vaginastate to 0>>
<</if>>
<<if $tentacle7head is "vaginaimminent">>
<<set $vaginause to 0>>
<<set $vaginastate to 0>>
<</if>>
<<if $tentacle7head is "vagina">>
<<set $vaginause to 0>>
<<set $vaginastate to 0>>
<</if>>
<<if $tentacle7head is "vaginadeep">>
<<set $vaginause to 0>>
<<set $vaginastate to 0>>
<</if>>
<<if $tentacle7head is "penisentrance">>
<<set $penisuse to 0>>
<<set $penisstate to 0>>
<</if>>
<<if $tentacle7head is "penisimminent">>
<<set $penisuse to 0>>
<<set $penisstate to 0>>
<</if>>
<<if $tentacle7head is "penis">>
<<set $penisuse to 0>>
<<set $penisstate to 0>>
<</if>>
<<if $tentacle7head is "penisdeep">>
<<set $penisuse to 0>>
<<set $penisstate to 0>>
<</if>>
<<if $tentacle7head is "vaginarub">>
<<set $vaginause to 0>>
<<set $thighuse to 0>>
<</if>>
<<if $tentacle7head is "penisrub">>
<<set $penisuse to 0>>
<<set $thighuse to 0>>
<</if>>
<<if $tentacle7head is "bottomrub">>
<<set $anususe to 0>>
<<set $bottomuse to 0>>
<</if>>
<<if $tentacle7shaft is "breasts">>
<<set $chestuse to 0>>
<</if>>
<<if $tentacle7shaft is "neck" and $head isnot "bound">>
<<set $head to 0>>
<</if>>
<<if $tentacle7shaft is "leftleg" and $leftleg isnot "bound">>
<<set $leftleg to 0>>
<</if>>
<<if $tentacle7shaft is "rightleg" and $rightleg isnot "bound">>
<<set $rightleg to 0>>
<</if>>
<<if $tentacle7shaft is "leftarm" and $leftarm isnot "bound">>
<<set $leftarm to 0>>
<</if>>
<<if $tentacle7shaft is "rightarm" and $rightarm isnot "bound">>
<<set $rightarm to 0>>
<</if>>
<<if $tentacle7head is "chest">>
<<set $breastuse to 0>>
<</if>>
<<set $tentacle7shaft to 0>>
<<set $tentacle7head to 0>>
<</nobr>><</widget>>
<<widget "actionstentacle7lefthand">><<nobr>>
<<if $leftarm is 0 and $tentacle7shaft isnot "finished">>
<<if $leftactiondefault is "lefthittentacle7">>
| <label><span class="def">Strike the $tentacle7 tentacle</span> <<radiobutton "$leftaction" "lefthittentacle7" checked>></label>
<<else>>
| <label><span class="def">Strike the $tentacle7 tentacle</span> <<radiobutton "$leftaction" "lefthittentacle7">></label>
<</if>>
<<if $leftactiondefault is "leftgrabtentacle7">>
| <label><span class="sub">Grab the $tentacle7 tentacle</span> <<radiobutton "$leftaction" "leftgrabtentacle7" checked>></label>
<<else>>
| <label><span class="sub">Grab the $tentacle7 tentacle</span> <<radiobutton "$leftaction" "leftgrabtentacle7">></label>
<</if>>
<<elseif $leftarm is "tentacle7">>You hold the $tentacle7 tentacle in your left hand.<br>
<<if $leftactiondefault is "leftrubtentacle7">>
| <label><span class="sub">Milk it</span> <<radiobutton "$leftaction" "leftrubtentacle7" checked>></label>
<<else>>
| <label><span class="sub">Milk it</span> <<radiobutton "$leftaction" "leftrubtentacle7">></label>
<</if>>
<<if $leftactiondefault is "leftstoptentacle7">>
| <label><span class="neutral">Let go</span> <<radiobutton "$leftaction" "leftstoptentacle7" checked>></label>
<<else>>
| <label><span class="neutral">Let go</span> <<radiobutton "$leftaction" "leftstoptentacle7">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle7righthand">><<nobr>>
<<if $rightarm is 0 and $tentacle7shaft isnot "finished">>
<<if $rightactiondefault is "righthittentacle7">>
| <label><span class="def">Strike the $tentacle7 tentacle</span> <<radiobutton "$rightaction" "righthittentacle7" checked>></label>
<<else>>
| <label><span class="def">Strike the $tentacle7 tentacle</span> <<radiobutton "$rightaction" "righthittentacle7">></label>
<</if>>
<<if $rightactiondefault is "rightgrabtentacle7">>
| <label><span class="sub">Grab the $tentacle7 tentacle</span> <<radiobutton "$rightaction" "rightgrabtentacle7" checked>></label>
<<else>>
| <label><span class="sub">Grab the $tentacle7 tentacle</span> <<radiobutton "$rightaction" "rightgrabtentacle7">></label>
<</if>>
<<elseif $rightarm is "tentacle7">>You hold the $tentacle7 tentacle in your right hand.<br>
<<if $rightactiondefault is "rightrubtentacle7">>
| <label><span class="sub">Milk it</span> <<radiobutton "$rightaction" "rightrubtentacle7" checked>></label>
<<else>>
| <label><span class="sub">Milk it</span> <<radiobutton "$rightaction" "rightrubtentacle7">></label>
<</if>>
<<if $rightactiondefault is "rightstoptentacle7">>
| <label><span class="neutral">Let go</span> <<radiobutton "$rightaction" "rightstoptentacle7" checked>></label>
<<else>>
| <label><span class="neutral">Let go</span> <<radiobutton "$rightaction" "rightstoptentacle7">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle7legs">><<nobr>>
<<if $leftleg is 0 and $rightleg is 0 and $tentacle7shaft isnot "finished">>
<<if $feetactiondefault is "feethittentacle7">>
| <label><span class="def">Kick the $tentacle7 tentacle</span> <<radiobutton "$feetaction" "feethittentacle7" checked>></label>
<<else>>
| <label><span class="def">Kick the $tentacle7 tentacle</span> <<radiobutton "$feetaction" "feethittentacle7">></label>
<</if>>
<<if $feetactiondefault is "feetgrabtentacle7">>
| <label><span class="sub">Grab the $tentacle7 tentacle</span> <<radiobutton "$feetaction" "feetgrabtentacle7" checked>></label>
<<else>>
| <label><span class="sub">Grab the $tentacle7 tentacle</span> <<radiobutton "$feetaction" "feetgrabtentacle7">></label>
<</if>>
<<elseif $leftleg is 0 and $tentacle7shaft isnot "finished">>
<<if $feetactiondefault is "feethittentacle7">>
| <label><span class="def">Kick the $tentacle7 tentacle</span> <<radiobutton "$feetaction" "feethittentacle7" checked>></label>
<<else>>
| <label><span class="def">Kick the $tentacle7 tentacle</span> <<radiobutton "$feetaction" "feethittentacle7">></label>
<</if>>
<<elseif $rightleg is 0 and $tentacle7shaft isnot "finished">>
<<if $feetactiondefault is "feethittentacle7">>
| <label><span class="def">Kick the $tentacle7 tentacle</span> <<radiobutton "$feetaction" "feethittentacle7" checked>></label>
<<else>>
| <label><span class="def">Kick the $tentacle7 tentacle</span> <<radiobutton "$feetaction" "feethittentacle7">></label>
<</if>>
<<elseif $leftleg is "tentacle7">>You hold the $tentacle7 tentacle between your feet.<br>
<<if $feetactiondefault is "feetrubtentacle7">>
| <label><span class="sub">Milk it</span> <<radiobutton "$feetaction" "feetrubtentacle7" checked>></label>
<<else>>
| <label><span class="sub">Milk it</span> <<radiobutton "$feetaction" "feetrubtentacle7">></label>
<</if>>
<<if $feetactiondefault is "feetstoptentacle7">>
| <label><span class="neutral">Let go</span> <<radiobutton "$feetaction" "feetstoptentacle7" checked>></label>
<<else>>
| <label><span class="neutral">Let go</span> <<radiobutton "$feetaction" "feetstoptentacle7">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle7mouth">><<nobr>>
<<if $tentacle7head is "mouthentrance">>
<<if $mouthactiondefault is "mouthlicktentacle7">>
| <label><span class="sub">Lick it</span> <<radiobutton "$mouthaction" "mouthlicktentacle7" checked>></label>
<<else>>
| <label><span class="sub">Lick it</span> <<radiobutton "$mouthaction" "mouthlicktentacle7">></label>
<</if>>
<<if $head is "grappled">>
<<else>>
<<if $mouthactiondefault is "mouthpullawaytentacle7">>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "mouthpullawaytentacle7" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "mouthpullawaytentacle7">></label>
<</if>>
<</if>>
<<elseif $tentacle7head is "mouthimminent">>
<<if $mouthactiondefault is "mouthkisstentacle7">>
| <label><span class="sub">Kiss it</span> <<radiobutton "$mouthaction" "mouthkisstentacle7" checked>></label>
<<else>>
| <label><span class="sub">Kiss it</span> <<radiobutton "$mouthaction" "mouthkisstentacle7">></label>
<</if>>
<<if $head is "grappled">>
<<else>>
<<if $mouthactiondefault is "mouthpullawaytentacle7">>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "mouthpullawaytentacle7" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "mouthpullawaytentacle7">></label>
<</if>>
<</if>>
<<elseif $tentacle7head is "mouth">>
<<if $mouthactiondefault is "mouthcooperatetentacle7">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$mouthaction" "mouthcooperatetentacle7" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$mouthaction" "mouthcooperatetentacle7">></label>
<</if>>
<<if $mouthactiondefault is "mouthbitetentacle7">>
| <label><span class="def">Bite</span> <<radiobutton "$mouthaction" "mouthbitetentacle7" checked>></label>
<<else>>
| <label><span class="def">Bite</span> <<radiobutton "$mouthaction" "mouthbitetentacle7">></label>
<</if>>
<<elseif $tentacle7head is "mouthdeep">>
<<if $mouthactiondefault is "mouthcooperatetentacle7">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$mouthaction" "mouthcooperatetentacle7" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$mouthaction" "mouthcooperatetentacle7">></label>
<</if>>
<<if $mouthactiondefault is "mouthbitetentacle7">>
| <label><span class="def">Bite</span> <<radiobutton "$mouthaction" "mouthbitetentacle7" checked>></label>
<<else>>
| <label><span class="def">Bite</span> <<radiobutton "$mouthaction" "mouthbitetentacle7">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle7vagina">><<nobr>>
<<if $tentacle7head is "vaginaentrance">>
<<if $vaginaactiondefault is "vaginarubtentacle7">>
| <label><span class="sub">Rub</span> <<radiobutton "$vaginaaction" "vaginarubtentacle7" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$vaginaaction" "vaginarubtentacle7">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $vaginaactiondefault is "vaginapullawaytentacle7">>
| <label><span class="brat">Pull away</span> <<radiobutton "$vaginaaction" "vaginapullawaytentacle7" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$vaginaaction" "vaginapullawaytentacle7">></label>
<</if>>
<</if>>
<<elseif $tentacle7head is "vaginaimminent">>
<<if $vaginaactiondefault is "vaginarubtentacle7">>
| <label><span class="sub">Rub</span> <<radiobutton "$vaginaaction" "vaginarubtentacle7" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$vaginaaction" "vaginarubtentacle7">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $vaginaactiondefault is "vaginapullawaytentacle7">>
| <label><span class="brat">Pull away</span> <<radiobutton "$vaginaaction" "vaginapullawaytentacle7" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$vaginaaction" "vaginapullawaytentacle7">></label>
<</if>>
<</if>>
<<elseif $tentacle7head is "vagina">>
<<if $vaginaactiondefault is "vaginacooperatetentacle7">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$vaginaaction" "vaginacooperatetentacle7" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$vaginaaction" "vaginacooperatetentacle7">></label>
<</if>>
<<elseif $tentacle7head is "vaginadeep">>
<<if $vaginaactiondefault is "vaginacooperatetentacle7">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$vaginaaction" "vaginacooperatetentacle7" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$vaginaaction" "vaginacooperatetentacle7">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle7penis">><<nobr>>
<<if $tentacle7head is "penisentrance">>
<<if $penisactiondefault is "penisrubtentacle7">>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "penisrubtentacle7" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "penisrubtentacle7">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $penisactiondefault is "penispullawaytentacle7">>
| <label><span class="brat">Pull away</span> <<radiobutton "$penisaction" "penispullawaytentacle7" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$penisaction" "penispullawaytentacle7">></label>
<</if>>
<</if>>
<<elseif $tentacle7head is "penisimminent">>
<<if $penisactiondefault is "penisrubtentacle7">>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "penisrubtentacle7" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "penisrubtentacle7">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $penisactiondefault is "penispullawaytentacle7">>
| <label><span class="brat">Pull away</span> <<radiobutton "$penisaction" "penispullawaytentacle7" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$penisaction" "penispullawaytentacle7">></label>
<</if>>
<</if>>
<<elseif $tentacle7head is "penis">>
<<if $penisactiondefault is "peniscooperatetentacle7">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$penisaction" "peniscooperatetentacle7" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$penisaction" "peniscooperatetentacle7">></label>
<</if>>
<<elseif $tentacle7head is "penisdeep">>
<<if $penisactiondefault is "peniscooperatetentacle7">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$penisaction" "peniscooperatetentacle7" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$penisaction" "peniscooperatetentacle7">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle7anus">><<nobr>>
<<if $tentacle7head is "anusentrance">>
<<if $anusactiondefault is "anusrubtentacle7">>
| <label><span class="sub">Rub</span> <<radiobutton "$anusaction" "anusrubtentacle7" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$anusaction" "anusrubtentacle7">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $anusactiondefault is "anuspullawaytentacle7">>
| <label><span class="brat">Pull away</span> <<radiobutton "$anusaction" "anuspullawaytentacle7" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$anusaction" "anuspullawaytentacle7">></label>
<</if>>
<</if>>
<<elseif $tentacle7head is "anusimminent">>
<<if $anusactiondefault is "anusrubtentacle7">>
| <label><span class="sub">Rub</span> <<radiobutton "$anusaction" "anusrubtentacle7" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$anusaction" "anusrubtentacle7">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $anusactiondefault is "anuspullawaytentacle7">>
| <label><span class="brat">Pull away</span> <<radiobutton "$anusaction" "anuspullawaytentacle7" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$anusaction" "anuspullawaytentacle7">></label>
<</if>>
<</if>>
<<elseif $tentacle7head is "anus">>
<<if $anusactiondefault is "anuscooperatetentacle7">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$anusaction" "anuscooperatetentacle7" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$anusaction" "anuscooperatetentacle7">></label>
<</if>>
<<elseif $tentacle7head is "anusdeep">>
<<if $anusactiondefault is "anuscooperatetentacle7">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$anusaction" "anuscooperatetentacle7" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$anusaction" "anuscooperatetentacle7">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle7thighs">><<nobr>>
<<if $tentacle7head is "penisrub">>
<<if $thighactiondefault is "penisrubtentacle7">>
| <label><span class="sub">Rub</span> <<radiobutton "$thighaction" "penisrubtentacle7" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$thighaction" "penisrubtentacle7">></label>
<</if>>
<<elseif $tentacle7head is "vaginarub">>
<<if $thighactiondefault is "vaginarubtentacle7">>
| <label><span class="sub">Rub</span> <<radiobutton "$thighaction" "vaginarubtentacle7" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$thighaction" "vaginarubtentacle7">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle7bottom">><<nobr>>
<<if $tentacle7head is "bottomrub">>
<<if $bottomactiondefault is "bottomrubtentacle7">>
| <label><span class="sub">Rub</span> <<radiobutton "$bottomaction" "bottomrubtentacle7" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$bottomaction" "bottomrubtentacle7">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle7chest">><<nobr>>
<<if $tentacle7head is "chest">>
<<if $chestactiondefault is "chestrubtentacle7">>
| <label><span class="sub">Rub</span> <<radiobutton "$chestaction" "chestrubtentacle7" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$chestaction" "chestrubtentacle7">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "effectstentacle7">><<nobr>>
<<if $leftaction is "lefthittentacle7">><<set $leftaction to 0>><<set $leftactiondefault to "lefthittentacle7">>You strike the $tentacle7 tentacle with your left hand and it reels away from you.<<defiance 2>><<set $speechhit to 1>><<tentacle7disable>><<set $attackstat += 1>><<set $tentacle7health -= 1>>
<<if $rng lte ($physique / 200)>>
<<set $tentacle7health -= 1>>
<</if>>
<</if>>
<<if $rightaction is "righthittentacle7">><<set $rightaction to 0>><<set $rightactiondefault to "righthittentacle7">>You strike the $tentacle7 tentacle with your right hand and it reels away from you.<<defiance 2>><<set $speechhit to 1>><<tentacle7disable>><<set $attackstat += 1>><<set $tentacle7health -= 1>>
<<if $rng lte ($physique / 200)>>
<<set $tentacle7health -= 1>>
<</if>>
<</if>>
<<if $leftaction is "leftgrabtentacle7">><<set $leftaction to 0>><<set $leftactiondefault to "leftrubtentacle7">><<submission 1>><<handstat>><span class="lblue">You <<handtext>> grab the $tentacle7 tentacle with your left hand.</span><<tentacle7disable>><<set $leftarm to "tentacle7">><<set $tentacle7head to "leftarm">><<handstat>><<set $leftarmstate to "tentacle">>
<</if>>
<<if $rightaction is "rightgrabtentacle7">><<set $rightaction to 0>><<set $rightactiondefault to "rightrubtentacle7">><<submission 1>><<handstat>><span class="lblue">You <<handtext>> grab the $tentacle7 tentacle with your right hand.</span><<tentacle7disable>><<set $rightarm to "tentacle7">><<set $tentacle7head to "rightarm">><<handstat>><<set $rightarmstate to "tentacle">>
<</if>>
<<if $leftaction is "leftrubtentacle7">><<set $leftaction to 0>><<set $leftactiondefault to "leftrubtentacle7">><<handskilluse>><<submission 1>>You <<handtext>> squeeze the $tentacle7 tentacle in your left hand and rub up and down its length.<<set $rng to random(1, 100)>>
<<if $handskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $rightarmgoo += 1>><<set $tentacle7health -= 3>><<handejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $rightaction is "rightrubtentacle7">><<set $rightaction to 0>><<set $rightactiondefault to "rightrubtentacle7">><<handskilluse>><<submission 1>>You <<handtext>> squeeze the $tentacle7 tentacle in your right hand and rub up and down its length.<<set $rng to random(1, 100)>>
<<if $handskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $rightarmgoo += 1>><<set $tentacle7health -= 3>><<handejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $leftaction is "leftstoptentacle7">><<set $leftaction to 0>><<set $leftactiondefault to "leftstoptentacle7">>You release the $tentacle7 tentacle from your left hand.<<tentacle7disable>>
<</if>>
<<if $rightaction is "rightstoptentacle7">><<set $rightaction to 0>><<set $rightactiondefault to "rightstoptentacle7">>You release the $tentacle7 tentacle from your right hand.<<tentacle7disable>>
<</if>>
<<if $feetaction is "feethittentacle7">><<set $feetaction to 0>><<set $feetactiondefault to "feethittentacle7">>You kick the $tentacle7 tentacle and it reels away from you.<<defiance 2>><<set $speechhit to 1>><<tentacle7disable>><<set $attackstat += 1>><<set $tentacle7health -= 1>>
<<if $rng lte ($physique / 200)>>
<<set $tentacle7health -= 1>>
<</if>>
<</if>>
<<if $feetaction is "feetgrabtentacle7">><<set $feetaction to 0>><<set $feetactiondefault to "feetrubtentacle7">><<submission 1>><<feetstat>><span class="lblue">You <<feettext>> grab the $tentacle7 tentacle between your feet.</span><<tentacle7disable>><<set $leftleg to "tentacle7">><<set $rightleg to "tentacle7">><<set $tentacle7head to "feet">><<feetstat>><<set $feetstate to "tentacle">>
<</if>>
<<if $feetaction is "feetrubtentacle7">><<set $feetaction to 0>><<set $feetactiondefault to "feetrubtentacle7">><<feetskilluse>><<submission 1>>You <<feettext>> squeeze the $tentacle7 tentacle between your feet and rub up and down its length.<<set $rng to random(1, 100)>>
<<if $feetskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $feetgoo += 1>><<set $tentacle7health -= 3>><<feetejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $feetaction is "feetstoptentacle7">><<set $feetaction to 0>><<set $feetactiondefault to "feetstoptentacle7">>You let go of the $tentacle7 tentacle between your feet.<<tentacle7disable>>
<</if>>
<<if $mouthaction is "mouthlicktentacle7">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthlicktentacle7">>
<<submission 2>><<oralskilluse>>You <<oraltext>> lick the tip of the $tentacle7 tentacle.<<set $rng to random(1, 100)>>
<<if $oralskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your face.</span><<set $facegoo += 1>><<set $tentacle7health -= 3>><<faceejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $mouthaction is "mouthkisstentacle7">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthkisstentacle7">>
<<submission 3>><<oralskilluse>>You <<oraltext>> kiss the tip of the $tentacle7 tentacle.<<set $rng to random(1, 100)>>
<<if $oralskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your face.</span><<set $facegoo += 1>><<set $tentacle7health -= 3>><<faceejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $mouthaction is "mouthcooperatetentacle7">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthcooperatetentacle7">>
<<sex 5>><<oralskilluse>>You <<oraltext>> suck the $tentacle7 tentacle invading your mouth.<<set $rng to random(1, 100)>>
<<if $oralskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip and into your mouth.</span><<set $tentacle7health -= 3>><<set $drugged += 3>><<set $mouthgoo += 1>><<oralejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $mouthaction is "mouthpullawaytentacle7">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthpullawaytentacle7">><<brat 1>><span class="teal">You pull away from the $tentacle7 tentacle threatening your mouth.</span><<tentacle7disable>>
<</if>>
<<if $mouthaction is "mouthbitetentacle7">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthbitetentacle7">><<defiance 5>>You bite down on the $tentacle7 tentacle invading your mouth. <span class="teal">It recoils immediately.</span><<tentacle7disable>><<set $attackstat += 1>><<set $tentacle7health -= 1>>
<<if $rng lte ($physique / 200)>>
<<set $tentacle7health -= 1>>
<</if>>
<</if>>
<<if $vaginaaction is "vaginarubtentacle7">><<set $vaginaaction to 0>><<set $vaginaactiondefault to "vaginarubtentacle7">>
<<submission 2>><<vaginalskilluse>>You <<vaginaltext>> rub the tip of the $tentacle7 tentacle with your <<pussystop>><<set $rng to random(1, 100)>>
<<if $vaginalskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $vaginaoutsidegoo += 1>><<set $tentacle7health -= 3>><<vaginalentranceejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $vaginaaction is "vaginacooperatetentacle7">><<set $vaginaaction to 0>><<set $vaginaactiondefault to "vaginacooperatetentacle7">>
<<sex 5>><<vaginalskilluse>>You <<vaginaltext>> push back against the $tentacle7 tentacle invading your <<pussystop>><<set $rng to random(1, 100)>>
<<if $vaginalskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, flooding your womb with its warmth.</span><<set $tentacle7health -= 3>><<set $drugged += 3>><<set $vaginagoo += 1>><<vaginalejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $vaginaaction is "vaginapullawaytentacle7">><<set $vaginaaction to 0>><<set $vaginaactiondefault to "vaginapullawaytentacle7">><<brat 1>><span class="teal">You pull away from the $tentacle7 tentacle threatening your <<pussystop>></span><<tentacle7disable>>
<</if>>
<<if $penisaction is "penisrubtentacle7">><<set $penisaction to 0>><<set $penisactiondefault to "penisrubtentacle7">>
<<submission 2>><<penileskilluse>>You <<peniletext>> rub the tip of the $tentacle7 tentacle with your <<penisstop>><<set $rng to random(1, 100)>>
<<if $penileskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $penisgoo += 1>><<set $tentacle7health -= 3>><<penileejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $penisaction is "peniscooperatetentacle7">><<set $penisaction to 0>><<set $penisactiondefault to "peniscooperatetentacle7">>
<<sex 5>><<penileskilluse>>You <<peniletext>> push back against the $tentacle7 tentacle engulfing your <<penisstop>><<set $rng to random(1, 100)>>
<<if $penileskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your groin.</span><<set $tentacle7health -= 3>><<set $penisgoo += 1>><<penileejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $penisaction is "penispullawaytentacle7">><<set $penisaction to 0>><<set $penisactiondefault to "penispullawaytentacle7">><<brat 1>><span class="teal">You pull away from the $tentacle7 tentacle threatening your <<penisstop>></span><<tentacle7disable>>
<</if>>
<<if $anusaction is "anusrubtentacle7">><<set $anusaction to 0>><<set $anusactiondefault to "anusrubtentacle7">>
<<submission 2>><<analskilluse>>You <<analtext>> rub the tip of the $tentacle7 tentacle with your <<bottomstop>><<set $rng to random(1, 100)>>
<<if $analskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your <<bottomstop>></span><<set $bottomgoo += 1>><<set $tentacle7health -= 3>><<bottomejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $anusaction is "anuscooperatetentacle7">><<set $anusaction to 0>><<set $anusactiondefault to "anuscooperatetentacle7">>
<<sex 5>><<analskilluse>>You <<analtext>> push back against the $tentacle7 tentacle invading your <<bottomstop>><<set $rng to random(1, 100)>>
<<if $analskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, flooding your bowels with its warmth.</span><<set $tentacle7health -= 3>><<set $drugged += 3>><<set $anusgoo += 1>><<analejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $anusaction is "anuspullawaytentacle7">><<set $anusaction to 0>><<set $anusactiondefault to "anuspullawaytentacle7">><<brat 1>><span class="teal">You pull away from the $tentacle7 tentacle threatening your <<bottomstop>></span><<tentacle7disable>>
<</if>>
<<if $thighaction is "penisrubtentacle7">><<set $thighaction to 0>><<set $thighactiondefault to "penisrubtentacle7">>
<<submission 3>><<thighskilluse>>You <<thightext>> rub the $tentacle7 tentacle between your thighs.<<set $rng to random(1, 100)>>
<<if $thighskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your tummy.</span><<set $tentacle7health -= 3>><<set $tummygoo += 1>><<tummyejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $thighaction is "vaginarubtentacle7">><<set $thighaction to 0>><<set $thighactiondefault to "vaginarubtentacle7">>
<<submission 3>><<thighskilluse>>You <<thightext>> rub the $tentacle7 tentacle between your thighs.<<set $rng to random(1, 100)>>
<<if $thighskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your tummy.</span><<set $tentacle7health -= 3>><<set $tummygoo += 1>><<tummyejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $bottomaction is "bottomrubtentacle7">><<set $bottomaction to 0>><<set $bottomactiondefault to "bottomrubtentacle7">>
<<submission 3>><<bottomskilluse>>You <<bottomtext>> rub the $tentacle7 tentacle between your cheeks.<<set $rng to random(1, 100)>>
<<if $bottomskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your <<bottomstop>></span><<set $tentacle7health -= 3>><<set $bottomgoo += 1>><<bottomejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $chestaction is "chestrubtentacle7">><<set $chestaction to 0>><<set $chestactiondefault to "chestrubtentacle7">>
<<submission 3>><<chestskilluse>>You <<chesttext>> rub the $tentacle7 tentacle between your <<breastsstop>><<set $rng to random(1, 100)>>
<<if $chestskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your chest.</span><<set $tentacle7health -= 3>><<set $chestgoo += 1>><<chestejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<</nobr>><</widget>>
:: Widgets Combat Tentacle8 [widget]
<<widget "tentacle8">><<nobr>>
<<if $tentacle8health lte 0 and $tentacle8shaft isnot "finished">>
Worn out, the $tentacle8 tentacle retracts from you.
<<tentacle8disable>>
<<set $tentacle8shaft to "finished">>
<<set $tentacle8head to "finished">>
<</if>>
<<if $tentacle8shaft is "tummy">>
The $tentacle8 tentacle <<slithers>> around your tummy,
<</if>>
<<if $tentacle8shaft is "thighs">>
The $tentacle8 tentacle <<slithers>> between your thighs,
<</if>>
<<if $tentacle8shaft is "breasts">>
The $tentacle8 tentacle squeezes your breasts together,
<</if>>
<<if $tentacle8shaft is "chest">>
The $tentacle8 tentacle <<slithers>> around your chest,
<</if>>
<<if $tentacle8shaft is "waist">>
The $tentacle8 tentacle <<slithers>> around your waist,
<</if>>
<<if $tentacle8shaft is "neck">>
The $tentacle8 tentacle <<slithers>> around your neck,
<</if>>
<<if $tentacle8shaft is "shoulders">>
The $tentacle8 tentacle <<slithers>> around your shoulders,
<</if>>
<<if $tentacle8shaft is "leftleg">>
The $tentacle8 tentacle <<slithers>> around your left leg,
<</if>>
<<if $tentacle8shaft is "rightleg">>
The $tentacle8 tentacle <<slithers>> around your right leg,
<</if>>
<<if $tentacle8shaft is "leftarm">>
The $tentacle8 tentacle <<slithers>> around your left arm,
<</if>>
<<if $tentacle8shaft is "rightarm">>
The $tentacle8 tentacle <<slithers>> around your right arm,
<</if>>
<<if $tentacle8head is "leftarm">>
The $tentacle8 tentacle writhes in your left hand.<<neutral 5>>
<</if>>
<<if $tentacle8head is "rightarm">>
The $tentacle8 tentacle writhes in your right hand.<<neutral 5>>
<</if>>
<<if $tentacle8head is "feet">>
The $tentacle8 tentacle writhes between your feet.<<neutral 5>>
<</if>>
<<if $tentacle8head is "leftnipplesuck">>
and up to your <<breastscomma>> where it suckles your left nipple.<<neutral 3>>
<</if>>
<<if $tentacle8head is "rightnipplesuck">>
and up to your <<breastscomma>> where it suckles your right nipple.<<neutral 3>>
<</if>>
<<if $tentacle8head is "leftnipple">>
and continues teasing your left nipple. <span class="purple">The tip of the tentacle opens up, latches on, then begins sucking.</span><<neutral 3>><<set $tentacle8head to "leftnipplesuck">><<set $leftnipple to "tentaclesuck">>
<</if>>
<<if $tentacle8head is "rightnipple">>
and continues teasing your right nipple. <span class="purple">The tip of the tentacle opens up, latches on, then begins sucking.</span><<neutral 3>><<set $tentacle8head to "rightnipplesuck">><<set $rightnipple to "tentaclesuck">>
<</if>>
<<if $tentacle8head is "chest">>
<<if $chestuse is "squeezed">>
then up between your <<breastscomma>> rubbing itself between them.<<neutral 2>>
<<else>>
moves away from your <<breasts>><<set $tentacle8head to 0>><<set $breastuse to 0>>
<</if>>
<</if>>
<<if $tentacle8head is "mouthdeep">>
and up into your mouth where it spurts a sweet fluid down your throat at the apex of each thrust.<<set $purity -= 1>><<internalejac>><<sex 5>><<set $drugged += 3>><<set $mouthgoo += 1>><<set $tentacle8health -= 1>>
<</if>>
<<if $tentacle8head is "mouth">>
and continues thrusting into your mouth.<span class="pink"> The tip opens and begins oozing a sweet liquid.</span><<set $purity -= 1>><<internalejac>><<set $mouthstate to "tentacledeep">><<set $tentacle8head to "mouthdeep">><<sex 5>><<oralejacstat>><<ejacstat>>
<</if>>
<<if $tentacle8head is "mouthimminent">>
<<if $oralvirginity is 1>>
<span class="pink"> and thrusts between your lips,</span><span class="red"> penetrating your mouth for the first time.</span><<set $oralvirginity to 0>><<violence 5>>
<<else>>
<span class="pink"> and thrusts between your lips.</span>
<</if>>
<<set $mouthstate to "tentacle">><<set $tentacle8head to "mouth">><<sex 5>><<raped>><<oralstat>>
<</if>>
<<if $tentacle8head is "mouthentrance">>
<span class="purple"> and presses against your lips.</span><<set $mouthstate to "tentacleimminent">><<set $tentacle8head to "mouthimminent">><<neutral 4>>
<</if>>
<<if $tentacle8head is "vaginadeep">>
and <<slithers>> into your <<pussy>> where it pumps a viscous fluid at the apex of each thrust.<<set $purity -= 1>><<internalejac>><<sex 5>><<set $drugged += 3>><<set $vaginagoo += 1>><<set $tentacle8health -= 1>>
<</if>>
<<if $tentacle8head is "vagina">>
and continues thrusting into your <<pussystop>><span class="pink"> The tip opens and begins oozing a viscous liquid.</span><<set $purity -= 1>><<internalejac>><<set $vaginastate to "tentacledeep">><<set $tentacle8head to "vaginadeep">><<sex 5>><<vaginalejacstat>><<ejacstat>>
<</if>>
<<if $tentacle8head is "vaginaimminent">>
<<if $vaginalvirginity is 1>>
<span class="pink"> and thrusts into your <<pussycomma>></span><span class="red"> tearing your hymen and forever robbing you of your purity.</span><<set $vaginalvirginity to 0>><<violence 100>>
<<else>>
<span class="pink"> and thrusts into your <<pussystop>></span>
<</if>>
<<set $vaginastate to "tentacle">><<set $tentacle8head to "vagina">><<sex 5>><<raped>><<vaginaraped>><<vaginalstat>><<violence 1>>
<</if>>
<<if $tentacle8head is "vaginaentrance">>
<<if $undertype isnot "chastity">>
<span class="purple"> and presses against your <<pussycomma>> about to penetrate.</span><<set $vaginastate to "tentacleimminent">><<set $tentacle8head to "vaginaimminent">><<neutral 4>>
<<else>>
and tries to find a way inside. Failing, it lashes at the metal.<<set $underintegrity -= 10>><<violence 1>>
<</if>>
<</if>>
<<if $tentacle8head is "penisdeep">>
and continues thrusting against your <<peniscomma>> caressing and kneading your length.<<sex 5>>
<</if>>
<<if $tentacle8head is "penis">>
and continues thrusting against your <<penisstop>><span class="pink"> It sucks and kneads your length, trying to milk you of your cum.</span><<set $penisstate to "tentacledeep">><<set $tentacle8head to "penisdeep">><<sex 5>>
<</if>>
<<if $tentacle8head is "penisimminent">>
<<if $penilevirginity is 1>>
<span class="pink"> and thrusts against your <<peniscomma>> swallowing you to the base and </span><span class="red"> tearing the membrane between your glans and foreskin, forever robbing you of your purity.</span><<set $penilevirginity to 0>><<violence 100>>
<<else>>
<span class="pink"> and thrusts against your <<peniscomma>> swallowing you to the base.</span>
<</if>>
<<set $penisstate to "tentacle">><<set $tentacle8head to "penis">><<sex 5>><<raped>><<penisraped>><<penilestat>><<violence 1>>
<</if>>
<<if $tentacle8head is "penisentrance">>
<<if $undertype isnot "chastity">>
<span class="purple"> and <<slithers>> over to your <<penisstop>> The tip opens and presses against your glans, about to envelop you.</span><<set $penisstate to "tentacleimminent">><<set $tentacle8head to "penisimminent">><<neutral 4>>
<<else>>
and tries to find a way inside. Failing, it lashes at the metal.<<set $underintegrity -= 10>><<violence 1>>
<</if>>
<</if>>
<<if $tentacle8head is "anusdeep">>
and <<slithers>> into your <<bottom>> where it pumps a viscous fluid at the apex of each thrust.<<set $purity -= 1>><<internalejac>><<sex 5>><<set $drugged += 3>><<set $anusgoo += 1>><<set $tentacle8health -= 1>>
<</if>>
<<if $tentacle8head is "anus">>
and continues thrusting into your <<bottomstop>><span class="pink"> The tip opens and begins oozing a viscous liquid.</span><<set $purity -= 1>><<internalejac>><<set $anusstate to "tentacledeep">><<set $tentacle8head to "anusdeep">><<sex 5>><<analejacstat>><<ejacstat>>
<</if>>
<<if $tentacle8head is "anusimminent">>
<<if $analvirginity is 1>>
<span class="pink"> and thrusts into your <<bottomcomma>></span><span class="red"> violating you in a way you hadn't conceived of.</span><<set $analvirginity to 0>><<violence 100>>
<<else>>
<span class="pink"> and thrusts into your <<bottomstop>></span>
<</if>>
<<set $anusstate to "tentacle">><<set $tentacle8head to "anus">><<sex 5>><<raped>><<analstat>><<violence 1>>
<</if>>
<<if $tentacle8head is "anusentrance">>
<<if $analshield is 0>>
<span class="purple"> and presses against your <<bottomcomma>> about to penetrate.</span><<set $anusstate to "tentacleimminent">><<set $tentacle8head to "anusimminent">><<neutral 4>>
<<else>>
and tries to find a way inside. Failing, it lashes at the device.<<set $underintegrity -= 10>><<violence 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $tentacle8head is "vaginarub">>
<<if $rng gte 21>>
and between your thighs where it <<slithers>> against your <<pussycomma>> pressing against your clit.<<sex 3>>
<<else>>
and between your thighs <span class="blue">where it <<slithers>> toward your <<pussystop>></span><<neutral 3>><<set $vaginause to "tentacle">><<set $vaginastate to "tentacleentrance">><<set $tentacle8head to "vaginaentrance">><<set $thighuse to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $tentacle8head is "penisrub">>
<<if $rng gte 21>>
and between your thighs where it <<slithers>> against your <<peniscomma>> coiling around it.<<sex 3>>
<<else>>
and between your thighs <span class="blue">where the tip opens and it <<slithers>> toward your <<penisstop>></span><<neutral 3>><<set $penisuse to "tentacle">><<set $penisstate to "tentacleentrance">><<set $tentacle8head to "penisentrance">><<set $thighuse to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $tentacle8head is "bottomrub">>
<<if $rng gte 21>>
and between your <<bottom>> cheeks where it <<slithers>> against your back.<<sex 3>>
<<else>>
and between your <<bottom>> cheeks, <span class="blue"> toward your anus.</span><<neutral 3>><<set $anususe to "tentacle">><<set $anusstate to "tentacleentrance">><<set $tentacle8head to "anusentrance">><<set $bottomuse to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $tentacle8head is 0 and $tentacle8shaft isnot 0>>
<<if $rng lte 10>>
<<if $chestuse is "squeezed" and $breastuse is 0>>
<<upperslither>><span class="blue">and up between your squeezed <<breastsstop>></span><<set $tentacle8head to "chest">><<neutral 2>><<set $breastuse to "tentacle">><<cheststat>>
<<else>>
<<tentacle8default>>
<</if>>
<<elseif $rng lte 20>>
<<if $leftnipple is 0>>
<<upperslither>> <span class="blue">and teases your left nipple.</span><<neutral 2>><<set $tentacle8head to "leftnipple">><<set $leftnipple to "tentacle">>
<<else>>
<<tentacle8default>>
<</if>>
<<elseif $rng lte 30>>
<<if $rightnipple is 0>>
<<upperslither>> <span class="blue">and teases your right nipple.</span><<neutral 2>><<set $tentacle8head to "rightnipple">><<set $rightnipple to "tentacle">>
<<else>>
<<tentacle8default>>
<</if>>
<<elseif $rng lte 40>>
<<if $mouthuse is 0>>
<<upperslither>> <span class="blue">and up toward your mouth.</span><<neutral 2>><<set $mouthuse to "tentacle">><<set $mouthstate to "tentacleentrance">><<set $tentacle8head to "mouthentrance">>
<<else>>
<<tentacle8default>>
<</if>>
<<elseif $rng lte 50>>
<<if $anususe is 0 and $analdisable is "f">>
<<underslither>> <span class="blue">and <<slithers>> toward your <<bottomstop>></span><<neutral 2>><<set $anususe to "tentacle">><<set $anusstate to "tentacleentrance">><<set $tentacle8head to "anusentrance">>
<<else>>
<<tentacle8default>>
<</if>>
<<elseif $rng lte 60>>
<<if $vaginaexist is 1 and $vaginause is 0>>
<<underslither>> <span class="blue">and <<slithers>> toward your <<pussystop>></span><<neutral 2>><<set $vaginause to "tentacle">><<set $vaginastate to "tentacleentrance">><<set $tentacle8head to "vaginaentrance">>
<<else>>
<<tentacle8default>>
<</if>>
<<elseif $rng lte 70>>
<<if $penisexist is 1 and $penisuse is 0>>
<<underslither>> <span class="blue">and <<slithers>> toward your <<penisstop>></span><<neutral 2>><<set $penisuse to "tentacle">><<set $penisstate to "tentacleentrance">><<set $tentacle8head to "penisentrance">>
<<else>>
<<tentacle8default>>
<</if>>
<<elseif $rng lte 80>>
<<if $thighuse is 0>>
<<if $penisexist is 1 and $penisuse is 0>>
<<underslither>> <span class="blue">and <<slithers>> between your thighs and against your tummy and <<penisstop>></span><<set $penisuse to "tentaclerub">><<set $thighuse to "tentaclerub">><<set $tentacle8head to "penisrub">><<sex 3>><<thighstat>>
<<elseif $vaginaexist is 1 and $vaginause is 0>>
<<underslither>> <span class="blue">and <<slithers>> between your thighs and against your tummy and <<pussystop>></span><<set $vaginause to "tentaclerub">><<set $thighuse to "tentaclerub">><<set $tentacle8head to "vaginarub">><<sex 3>><<thighstat>>
<<else>>
<<tentacle8default>>
<</if>>
<<else>>
<<tentacle8default>>
<</if>>
<<elseif $rng lte 90>>
<<if $bottomuse is 0 and $anususe is 0 and $analdisable is "f">>
<<underslither>> <span class="blue">and <<slithers>> between your <<bottom>> cheeks and against your back.</span><<set $bottomuse to "tentaclerub">><<set $anususe to "tentaclerub">><<set $tentacle8head to "bottomrub">><<sex 1>><<bottomstat>>
<<else>>
<<tentacle8default>>
<</if>>
<<else>>
<<tentacle8default>>
<</if>>
<<elseif $tentacle8head is 0 and $tentacle8shaft is 0>>
<<if $rng lte 10>>
<<if $position isnot "wall">>
The $tentacle8 tentacle winds around your tummy.<<neutral 1>><<set $tentacle8shaft to "tummy">>
<<else>>
The $tentacle8 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<elseif $rng lte 20>>
The $tentacle8 tentacle <<slithers>> between your thighs.<<neutral 1>><<set $tentacle8shaft to "thighs">>
<<elseif $rng lte 30>>
<<if $position isnot "wall">>
<<if $breastsize gte 2 and $chestuse is 0>>
The $tentacle8 tentacle <<slithers>> around your <<breastscomma>> <span class="blue">squeezing them together.</span><<neutral 1>><<set $tentacle8shaft to "breasts">><<set $chestuse to "squeezed">>
<<else>>
The $tentacle8 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<else>>
The $tentacle8 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<elseif $rng lte 40>>
<<if $position isnot "wall">>
The $tentacle8 tentacle winds its way around your chest, beneath your <<breastsstop>><<neutral 1>><<set $tentacle8shaft to "chest">>
<<else>>
The $tentacle8 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<elseif $rng lte 50>>
The $tentacle8 tentacle winds its way around your waist.<<neutral 1>><<set $tentacle8shaft to "waist">>
<<elseif $rng lte 60>>
<<if $position isnot "wall">>
<<if $head is 0>>
The $tentacle8 tentacle winds its way around your neck, <span class="blue">restraining your head.</span><<neutral 1>><<set $tentacle8shaft to "neck">><<set $head to "grappled">>
<<else>>
The $tentacle8 tentacle winds its way around your shoulders.<<neutral 1>><<set $tentacle8shaft to "shoulders">>
<</if>>
<<else>>
The $tentacle8 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<elseif $rng lte 70>>
The $tentacle8 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<<elseif $rng lte 80>>
<<if $leftleg is 0>>
The $tentacle8 tentacle winds its way around your left leg, <span class="blue">restraining it.</span><<neutral 1>><<feettentacledisable>><<set $tentacle8shaft to "leftleg">><<set $leftleg to "grappled">>
<<else>>
The $tentacle8 tentacle tickles your feet.<<neutral 1>>
<</if>>
<<elseif $rng lte 85>>
<<if $rightleg is 0>>
The $tentacle8 tentacle winds its way around your right leg, <span class="blue">restraining it.</span><<neutral 1>><<feettentacledisable>><<set $tentacle8shaft to "rightleg">><<set $rightleg to "grappled">>
<<else>>
The $tentacle8 tentacle tickles your feet.<<neutral 1>>
<</if>>
<<elseif $rng lte 90>>
<<if $leftarm is 0>>
The $tentacle8 tentacle winds its way around your left arm, <span class="blue">restraining it.</span><<neutral 1>><<leftarmtentacledisable>><<set $tentacle8shaft to "leftarm">><<set $leftarm to "grappled">><<set $leftarmstate to 0>>
<<else>>
The $tentacle8 tentacle tickles your armpit.<<neutral 1>>
<</if>>
<<elseif $rng lte 95>>
<<if $rightarm is 0>>
The $tentacle8 tentacle winds its way around your right arm, <span class="blue">restraining it.</span><<rightarmtentacledisable>><<neutral 1>><<set $tentacle8shaft to "rightarm">><<set $rightarm to "grappled">><<set $rightarmstate to 0>>
<<else>>
The $tentacle8 tentacle tickles your armpit.<<neutral 1>>
<</if>>
<<elseif $rng lte 100>>
The $tentacle8 tentacle <<slithers>> against your <<bottomstop>><<neutral 1>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "tentacle8default">><<nobr>>
<<set $rng to random(1, 100)>>
<<if $rng gte 90>>
then squirts a warm fluid over your neck.<<neutral 1>><<set $neckgoo += 1>><<set $tentacle8health -= 1>><<neckejacstat>><<ejacstat>>
<<elseif $rng gte 80>>
then squirts a warm fluid over your right arm.<<neutral 1>><<set $rightarmgoo += 1>><<set $tentacle8health -= 1>><<handejacstat>><<ejacstat>>
<<elseif $rng gte 70>>
then squirts a warm fluid over your left arm.<<neutral 1>><<set $leftarmgoo += 1>><<set $tentacle8health -= 1>><<handejacstat>><<ejacstat>>
<<elseif $rng gte 60>>
then squirts a warm fluid over your thighs.<<neutral 1>><<set $thighgoo += 1>><<set $tentacle8health -= 1>><<thighejacstat>><<ejacstat>>
<<elseif $rng gte 50>>
then squirts a warm fluid over your <<bottomstop>><<neutral 1>><<set $bottomgoo += 1>><<set $tentacle8health -= 1>><<bottomejacstat>><<ejacstat>>
<<elseif $rng gte 40>>
then squirts a warm fluid over your tummy.<<neutral 1>><<set $tummygoo += 1>><<set $tentacle8health -= 1>><<tummyejacstat>><<ejacstat>>
<<elseif $rng gte 30>>
then squirts a warm fluid over your chest.<<neutral 1>><<set $chestgoo += 1>><<set $tentacle8health -= 1>><<chestejacstat>><<ejacstat>>
<<elseif $rng gte 20>>
then squirts a warm fluid over your face.<<neutral 1>><<set $facegoo += 1>><<set $tentacle8health -= 1>><<faceejacstat>><<ejacstat>>
<<elseif $rng gte 10>>
then squirts a warm fluid over your hair.<<neutral 1>><<set $hairgoo += 1>><<set $tentacle8health -= 1>><<hairejacstat>><<ejacstat>>
<<else>>
then squirts a warm fluid over your feet.<<neutral 1>><<set $feetgoo += 1>><<set $tentacle8health -= 1>><<feetejacstat>><<ejacstat>>
<</if>>
<</nobr>><</widget>>
<<widget "tentacle8disable">><<nobr>>
<<if $tentacle8head is "feet">>
<<set $leftleg to 0>>
<<set $rightleg to 0>>
<<set $feetstate to 0>>
<</if>>
<<if $tentacle8head is "leftarm">>
<<set $leftarm to 0>>
<<set $leftarmstate to 0>>
<</if>>
<<if $tentacle8head is "rightarm">>
<<set $rightarm to 0>>
<<set $rightarmstate to 0>>
<</if>>
<<if $tentacle8head is "leftnipplesuck">>
<<set $leftnipple to 0>>
<</if>>
<<if $tentacle8head is "rightnipplesuck">>
<<set $rightnipple to 0>>
<</if>>
<<if $tentacle8head is "leftnipple">>
<<set $leftnipple to 0>>
<</if>>
<<if $tentacle8head is "rightnipple">>
<<set $rightnipple to 0>>
<</if>>
<<if $tentacle8head is "chest">>
<<set $chestuse to 0>>
<</if>>
<<if $tentacle8head is "mouthentrance">>
<<set $mouthuse to 0>>
<<set $mouthstate to 0>>
<</if>>
<<if $tentacle8head is "mouthimminent">>
<<set $mouthuse to 0>>
<<set $mouthstate to 0>>
<</if>>
<<if $tentacle8head is "mouth">>
<<set $mouthuse to 0>>
<<set $mouthstate to 0>>
<</if>>
<<if $tentacle8head is "mouthdeep">>
<<set $mouthuse to 0>>
<<set $mouthstate to 0>>
<</if>>
<<if $tentacle8head is "anusentrance">>
<<set $anususe to 0>>
<<set $anusstate to 0>>
<</if>>
<<if $tentacle8head is "anusimminent">>
<<set $anususe to 0>>
<<set $anusstate to 0>>
<</if>>
<<if $tentacle8head is "anus">>
<<set $anususe to 0>>
<<set $anusstate to 0>>
<</if>>
<<if $tentacle8head is "anusdeep">>
<<set $anususe to 0>>
<<set $anusstate to 0>>
<</if>>
<<if $tentacle8head is "vaginaentrance">>
<<set $vaginause to 0>>
<<set $vaginastate to 0>>
<</if>>
<<if $tentacle8head is "vaginaimminent">>
<<set $vaginause to 0>>
<<set $vaginastate to 0>>
<</if>>
<<if $tentacle8head is "vagina">>
<<set $vaginause to 0>>
<<set $vaginastate to 0>>
<</if>>
<<if $tentacle8head is "vaginadeep">>
<<set $vaginause to 0>>
<<set $vaginastate to 0>>
<</if>>
<<if $tentacle8head is "penisentrance">>
<<set $penisuse to 0>>
<<set $penisstate to 0>>
<</if>>
<<if $tentacle8head is "penisimminent">>
<<set $penisuse to 0>>
<<set $penisstate to 0>>
<</if>>
<<if $tentacle8head is "penis">>
<<set $penisuse to 0>>
<<set $penisstate to 0>>
<</if>>
<<if $tentacle8head is "penisdeep">>
<<set $penisuse to 0>>
<<set $penisstate to 0>>
<</if>>
<<if $tentacle8head is "vaginarub">>
<<set $vaginause to 0>>
<<set $thighuse to 0>>
<</if>>
<<if $tentacle8head is "penisrub">>
<<set $penisuse to 0>>
<<set $thighuse to 0>>
<</if>>
<<if $tentacle8head is "bottomrub">>
<<set $anususe to 0>>
<<set $bottomuse to 0>>
<</if>>
<<if $tentacle8shaft is "breasts">>
<<set $chestuse to 0>>
<</if>>
<<if $tentacle8shaft is "neck" and $head isnot "bound">>
<<set $head to 0>>
<</if>>
<<if $tentacle8shaft is "leftleg" and $leftleg isnot "bound">>
<<set $leftleg to 0>>
<</if>>
<<if $tentacle8shaft is "rightleg" and $rightleg isnot "bound">>
<<set $rightleg to 0>>
<</if>>
<<if $tentacle8shaft is "leftarm" and $leftarm isnot "bound">>
<<set $leftarm to 0>>
<</if>>
<<if $tentacle8shaft is "rightarm" and $rightarm isnot "bound">>
<<set $rightarm to 0>>
<</if>>
<<if $tentacle8head is "chest">>
<<set $breastuse to 0>>
<</if>>
<<set $tentacle8shaft to 0>>
<<set $tentacle8head to 0>>
<</nobr>><</widget>>
<<widget "actionstentacle8lefthand">><<nobr>>
<<if $leftarm is 0 and $tentacle8shaft isnot "finished">>
<<if $leftactiondefault is "lefthittentacle8">>
| <label><span class="def">Strike the $tentacle8 tentacle</span> <<radiobutton "$leftaction" "lefthittentacle8" checked>></label>
<<else>>
| <label><span class="def">Strike the $tentacle8 tentacle</span> <<radiobutton "$leftaction" "lefthittentacle8">></label>
<</if>>
<<if $leftactiondefault is "leftgrabtentacle8">>
| <label><span class="sub">Grab the $tentacle8 tentacle</span> <<radiobutton "$leftaction" "leftgrabtentacle8" checked>></label>
<<else>>
| <label><span class="sub">Grab the $tentacle8 tentacle</span> <<radiobutton "$leftaction" "leftgrabtentacle8">></label>
<</if>>
<<elseif $leftarm is "tentacle8">>You hold the $tentacle8 tentacle in your left hand.<br>
<<if $leftactiondefault is "leftrubtentacle8">>
| <label><span class="sub">Milk it</span> <<radiobutton "$leftaction" "leftrubtentacle8" checked>></label>
<<else>>
| <label><span class="sub">Milk it</span> <<radiobutton "$leftaction" "leftrubtentacle8">></label>
<</if>>
<<if $leftactiondefault is "leftstoptentacle8">>
| <label><span class="neutral">Let go</span> <<radiobutton "$leftaction" "leftstoptentacle8" checked>></label>
<<else>>
| <label><span class="neutral">Let go</span> <<radiobutton "$leftaction" "leftstoptentacle8">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle8righthand">><<nobr>>
<<if $rightarm is 0 and $tentacle8shaft isnot "finished">>
<<if $rightactiondefault is "righthittentacle8">>
| <label><span class="def">Strike the $tentacle8 tentacle</span> <<radiobutton "$rightaction" "righthittentacle8" checked>></label>
<<else>>
| <label><span class="def">Strike the $tentacle8 tentacle</span> <<radiobutton "$rightaction" "righthittentacle8">></label>
<</if>>
<<if $rightactiondefault is "rightgrabtentacle8">>
| <label><span class="sub">Grab the $tentacle8 tentacle</span> <<radiobutton "$rightaction" "rightgrabtentacle8" checked>></label>
<<else>>
| <label><span class="sub">Grab the $tentacle8 tentacle</span> <<radiobutton "$rightaction" "rightgrabtentacle8">></label>
<</if>>
<<elseif $rightarm is "tentacle8">>You hold the $tentacle8 tentacle in your right hand.<br>
<<if $rightactiondefault is "rightrubtentacle8">>
| <label><span class="sub">Milk it</span> <<radiobutton "$rightaction" "rightrubtentacle8" checked>></label>
<<else>>
| <label><span class="sub">Milk it</span> <<radiobutton "$rightaction" "rightrubtentacle8">></label>
<</if>>
<<if $rightactiondefault is "rightstoptentacle8">>
| <label><span class="neutral">Let go</span> <<radiobutton "$rightaction" "rightstoptentacle8" checked>></label>
<<else>>
| <label><span class="neutral">Let go</span> <<radiobutton "$rightaction" "rightstoptentacle8">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle8legs">><<nobr>>
<<if $leftleg is 0 and $rightleg is 0 and $tentacle8shaft isnot "finished">>
<<if $feetactiondefault is "feethittentacle8">>
| <label><span class="def">Kick the $tentacle8 tentacle</span> <<radiobutton "$feetaction" "feethittentacle8" checked>></label>
<<else>>
| <label><span class="def">Kick the $tentacle8 tentacle</span> <<radiobutton "$feetaction" "feethittentacle8">></label>
<</if>>
<<if $feetactiondefault is "feetgrabtentacle8">>
| <label><span class="sub">Grab the $tentacle8 tentacle</span> <<radiobutton "$feetaction" "feetgrabtentacle8" checked>></label>
<<else>>
| <label><span class="sub">Grab the $tentacle8 tentacle</span> <<radiobutton "$feetaction" "feetgrabtentacle8">></label>
<</if>>
<<elseif $leftleg is 0 and $tentacle8shaft isnot "finished">>
<<if $feetactiondefault is "feethittentacle8">>
| <label><span class="def">Kick the $tentacle8 tentacle</span> <<radiobutton "$feetaction" "feethittentacle8" checked>></label>
<<else>>
| <label><span class="def">Kick the $tentacle8 tentacle</span> <<radiobutton "$feetaction" "feethittentacle8">></label>
<</if>>
<<elseif $rightleg is 0 and $tentacle8shaft isnot "finished">>
<<if $feetactiondefault is "feethittentacle8">>
| <label><span class="def">Kick the $tentacle8 tentacle</span> <<radiobutton "$feetaction" "feethittentacle8" checked>></label>
<<else>>
| <label><span class="def">Kick the $tentacle8 tentacle</span> <<radiobutton "$feetaction" "feethittentacle8">></label>
<</if>>
<<elseif $leftleg is "tentacle8">>You hold the $tentacle8 tentacle between your feet.<br>
<<if $feetactiondefault is "feetrubtentacle8">>
| <label><span class="sub">Milk it</span> <<radiobutton "$feetaction" "feetrubtentacle8" checked>></label>
<<else>>
| <label><span class="sub">Milk it</span> <<radiobutton "$feetaction" "feetrubtentacle8">></label>
<</if>>
<<if $feetactiondefault is "feetstoptentacle8">>
| <label><span class="neutral">Let go</span> <<radiobutton "$feetaction" "feetstoptentacle8" checked>></label>
<<else>>
| <label><span class="neutral">Let go</span> <<radiobutton "$feetaction" "feetstoptentacle8">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle8mouth">><<nobr>>
<<if $tentacle8head is "mouthentrance">>
<<if $mouthactiondefault is "mouthlicktentacle8">>
| <label><span class="sub">Lick it</span> <<radiobutton "$mouthaction" "mouthlicktentacle8" checked>></label>
<<else>>
| <label><span class="sub">Lick it</span> <<radiobutton "$mouthaction" "mouthlicktentacle8">></label>
<</if>>
<<if $head is "grappled">>
<<else>>
<<if $mouthactiondefault is "mouthpullawaytentacle8">>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "mouthpullawaytentacle8" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "mouthpullawaytentacle8">></label>
<</if>>
<</if>>
<<elseif $tentacle8head is "mouthimminent">>
<<if $mouthactiondefault is "mouthkisstentacle8">>
| <label><span class="sub">Kiss it</span> <<radiobutton "$mouthaction" "mouthkisstentacle8" checked>></label>
<<else>>
| <label><span class="sub">Kiss it</span> <<radiobutton "$mouthaction" "mouthkisstentacle8">></label>
<</if>>
<<if $head is "grappled">>
<<else>>
<<if $mouthactiondefault is "mouthpullawaytentacle8">>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "mouthpullawaytentacle8" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "mouthpullawaytentacle8">></label>
<</if>>
<</if>>
<<elseif $tentacle8head is "mouth">>
<<if $mouthactiondefault is "mouthcooperatetentacle8">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$mouthaction" "mouthcooperatetentacle8" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$mouthaction" "mouthcooperatetentacle8">></label>
<</if>>
<<if $mouthactiondefault is "mouthbitetentacle8">>
| <label><span class="def">Bite</span> <<radiobutton "$mouthaction" "mouthbitetentacle8" checked>></label>
<<else>>
| <label><span class="def">Bite</span> <<radiobutton "$mouthaction" "mouthbitetentacle8">></label>
<</if>>
<<elseif $tentacle8head is "mouthdeep">>
<<if $mouthactiondefault is "mouthcooperatetentacle8">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$mouthaction" "mouthcooperatetentacle8" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$mouthaction" "mouthcooperatetentacle8">></label>
<</if>>
<<if $mouthactiondefault is "mouthbitetentacle8">>
| <label><span class="def">Bite</span> <<radiobutton "$mouthaction" "mouthbitetentacle8" checked>></label>
<<else>>
| <label><span class="def">Bite</span> <<radiobutton "$mouthaction" "mouthbitetentacle8">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle8vagina">><<nobr>>
<<if $tentacle8head is "vaginaentrance">>
<<if $vaginaactiondefault is "vaginarubtentacle8">>
| <label><span class="sub">Rub</span> <<radiobutton "$vaginaaction" "vaginarubtentacle8" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$vaginaaction" "vaginarubtentacle8">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $vaginaactiondefault is "vaginapullawaytentacle8">>
| <label><span class="brat">Pull away</span> <<radiobutton "$vaginaaction" "vaginapullawaytentacle8" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$vaginaaction" "vaginapullawaytentacle8">></label>
<</if>>
<</if>>
<<elseif $tentacle8head is "vaginaimminent">>
<<if $vaginaactiondefault is "vaginarubtentacle8">>
| <label><span class="sub">Rub</span> <<radiobutton "$vaginaaction" "vaginarubtentacle8" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$vaginaaction" "vaginarubtentacle8">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $vaginaactiondefault is "vaginapullawaytentacle8">>
| <label><span class="brat">Pull away</span> <<radiobutton "$vaginaaction" "vaginapullawaytentacle8" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$vaginaaction" "vaginapullawaytentacle8">></label>
<</if>>
<</if>>
<<elseif $tentacle8head is "vagina">>
<<if $vaginaactiondefault is "vaginacooperatetentacle8">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$vaginaaction" "vaginacooperatetentacle8" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$vaginaaction" "vaginacooperatetentacle8">></label>
<</if>>
<<elseif $tentacle8head is "vaginadeep">>
<<if $vaginaactiondefault is "vaginacooperatetentacle8">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$vaginaaction" "vaginacooperatetentacle8" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$vaginaaction" "vaginacooperatetentacle8">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle8penis">><<nobr>>
<<if $tentacle8head is "penisentrance">>
<<if $penisactiondefault is "penisrubtentacle8">>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "penisrubtentacle8" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "penisrubtentacle8">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $penisactiondefault is "penispullawaytentacle8">>
| <label><span class="brat">Pull away</span> <<radiobutton "$penisaction" "penispullawaytentacle8" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$penisaction" "penispullawaytentacle8">></label>
<</if>>
<</if>>
<<elseif $tentacle8head is "penisimminent">>
<<if $penisactiondefault is "penisrubtentacle8">>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "penisrubtentacle8" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "penisrubtentacle8">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $penisactiondefault is "penispullawaytentacle8">>
| <label><span class="brat">Pull away</span> <<radiobutton "$penisaction" "penispullawaytentacle8" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$penisaction" "penispullawaytentacle8">></label>
<</if>>
<</if>>
<<elseif $tentacle8head is "penis">>
<<if $penisactiondefault is "peniscooperatetentacle8">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$penisaction" "peniscooperatetentacle8" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$penisaction" "peniscooperatetentacle8">></label>
<</if>>
<<elseif $tentacle8head is "penisdeep">>
<<if $penisactiondefault is "peniscooperatetentacle8">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$penisaction" "peniscooperatetentacle8" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$penisaction" "peniscooperatetentacle8">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle8anus">><<nobr>>
<<if $tentacle8head is "anusentrance">>
<<if $anusactiondefault is "anusrubtentacle8">>
| <label><span class="sub">Rub</span> <<radiobutton "$anusaction" "anusrubtentacle8" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$anusaction" "anusrubtentacle8">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $anusactiondefault is "anuspullawaytentacle8">>
| <label><span class="brat">Pull away</span> <<radiobutton "$anusaction" "anuspullawaytentacle8" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$anusaction" "anuspullawaytentacle8">></label>
<</if>>
<</if>>
<<elseif $tentacle8head is "anusimminent">>
<<if $anusactiondefault is "anusrubtentacle8">>
| <label><span class="sub">Rub</span> <<radiobutton "$anusaction" "anusrubtentacle8" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$anusaction" "anusrubtentacle8">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $anusactiondefault is "anuspullawaytentacle8">>
| <label><span class="brat">Pull away</span> <<radiobutton "$anusaction" "anuspullawaytentacle8" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$anusaction" "anuspullawaytentacle8">></label>
<</if>>
<</if>>
<<elseif $tentacle8head is "anus">>
<<if $anusactiondefault is "anuscooperatetentacle8">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$anusaction" "anuscooperatetentacle8" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$anusaction" "anuscooperatetentacle8">></label>
<</if>>
<<elseif $tentacle8head is "anusdeep">>
<<if $anusactiondefault is "anuscooperatetentacle8">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$anusaction" "anuscooperatetentacle8" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$anusaction" "anuscooperatetentacle8">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle8thighs">><<nobr>>
<<if $tentacle8head is "penisrub">>
<<if $thighactiondefault is "penisrubtentacle8">>
| <label><span class="sub">Rub</span> <<radiobutton "$thighaction" "penisrubtentacle8" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$thighaction" "penisrubtentacle8">></label>
<</if>>
<<elseif $tentacle8head is "vaginarub">>
<<if $thighactiondefault is "vaginarubtentacle8">>
| <label><span class="sub">Rub</span> <<radiobutton "$thighaction" "vaginarubtentacle8" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$thighaction" "vaginarubtentacle8">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle8bottom">><<nobr>>
<<if $tentacle8head is "bottomrub">>
<<if $bottomactiondefault is "bottomrubtentacle8">>
| <label><span class="sub">Rub</span> <<radiobutton "$bottomaction" "bottomrubtentacle8" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$bottomaction" "bottomrubtentacle8">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle8chest">><<nobr>>
<<if $tentacle8head is "chest">>
<<if $chestactiondefault is "chestrubtentacle8">>
| <label><span class="sub">Rub</span> <<radiobutton "$chestaction" "chestrubtentacle8" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$chestaction" "chestrubtentacle8">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "effectstentacle8">><<nobr>>
<<if $leftaction is "lefthittentacle8">><<set $leftaction to 0>><<set $leftactiondefault to "lefthittentacle8">>You strike the $tentacle8 tentacle with your left hand and it reels away from you.<<defiance 2>><<set $speechhit to 1>><<tentacle8disable>><<set $attackstat += 1>><<set $tentacle8health -= 1>>
<<if $rng lte ($physique / 200)>>
<<set $tentacle8health -= 1>>
<</if>>
<</if>>
<<if $rightaction is "righthittentacle8">><<set $rightaction to 0>><<set $rightactiondefault to "righthittentacle8">>You strike the $tentacle8 tentacle with your right hand and it reels away from you.<<defiance 2>><<set $speechhit to 1>><<tentacle8disable>><<set $attackstat += 1>><<set $tentacle8health -= 1>>
<<if $rng lte ($physique / 200)>>
<<set $tentacle8health -= 1>>
<</if>>
<</if>>
<<if $leftaction is "leftgrabtentacle8">><<set $leftaction to 0>><<set $leftactiondefault to "leftrubtentacle8">><<submission 1>><<handstat>><span class="lblue">You <<handtext>> grab the $tentacle8 tentacle with your left hand.</span><<tentacle8disable>><<set $leftarm to "tentacle8">><<set $tentacle8head to "leftarm">><<handstat>><<set $leftarmstate to "tentacle">>
<</if>>
<<if $rightaction is "rightgrabtentacle8">><<set $rightaction to 0>><<set $rightactiondefault to "rightrubtentacle8">><<submission 1>><<handstat>><span class="lblue">You <<handtext>> grab the $tentacle8 tentacle with your right hand.</span><<tentacle8disable>><<set $rightarm to "tentacle8">><<set $tentacle8head to "rightarm">><<handstat>><<set $rightarmstate to "tentacle">>
<</if>>
<<if $leftaction is "leftrubtentacle8">><<set $leftaction to 0>><<set $leftactiondefault to "leftrubtentacle8">><<handskilluse>><<submission 1>>You <<handtext>> squeeze the $tentacle8 tentacle in your left hand and rub up and down its length.<<set $rng to random(1, 100)>>
<<if $handskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $rightarmgoo += 1>><<set $tentacle8health -= 3>><<handejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $rightaction is "rightrubtentacle8">><<set $rightaction to 0>><<set $rightactiondefault to "rightrubtentacle8">><<handskilluse>><<submission 1>>You <<handtext>> squeeze the $tentacle8 tentacle in your right hand and rub up and down its length.<<set $rng to random(1, 100)>>
<<if $handskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $rightarmgoo += 1>><<set $tentacle8health -= 3>><<handejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $leftaction is "leftstoptentacle8">><<set $leftaction to 0>><<set $leftactiondefault to "leftstoptentacle8">>You release the $tentacle8 tentacle from your left hand.<<tentacle8disable>>
<</if>>
<<if $rightaction is "rightstoptentacle8">><<set $rightaction to 0>><<set $rightactiondefault to "rightstoptentacle8">>You release the $tentacle8 tentacle from your right hand.<<tentacle8disable>>
<</if>>
<<if $feetaction is "feethittentacle8">><<set $feetaction to 0>><<set $feetactiondefault to "feethittentacle8">>You kick the $tentacle8 tentacle and it reels away from you.<<defiance 2>><<set $speechhit to 1>><<tentacle8disable>><<set $attackstat += 1>><<set $tentacle8health -= 1>>
<<if $rng lte ($physique / 200)>>
<<set $tentacle8health -= 1>>
<</if>>
<</if>>
<<if $feetaction is "feetgrabtentacle8">><<set $feetaction to 0>><<set $feetactiondefault to "feetrubtentacle8">><<submission 1>><<feetstat>><span class="lblue">You <<feettext>> grab the $tentacle8 tentacle between your feet.</span><<tentacle8disable>><<set $leftleg to "tentacle8">><<set $rightleg to "tentacle8">><<set $tentacle8head to "feet">><<feetstat>><<set $feetstate to "tentacle">>
<</if>>
<<if $feetaction is "feetrubtentacle8">><<set $feetaction to 0>><<set $feetactiondefault to "feetrubtentacle8">><<feetskilluse>><<submission 1>>You <<feettext>> squeeze the $tentacle8 tentacle between your feet and rub up and down its length.<<set $rng to random(1, 100)>>
<<if $feetskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $feetgoo += 1>><<set $tentacle8health -= 3>><<feetejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $feetaction is "feetstoptentacle8">><<set $feetaction to 0>><<set $feetactiondefault to "feetstoptentacle8">>You let go of the $tentacle8 tentacle between your feet.<<tentacle8disable>>
<</if>>
<<if $mouthaction is "mouthlicktentacle8">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthlicktentacle8">>
<<submission 2>><<oralskilluse>>You <<oraltext>> lick the tip of the $tentacle8 tentacle.<<set $rng to random(1, 100)>>
<<if $oralskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your face.</span><<set $facegoo += 1>><<set $tentacle8health -= 3>><<faceejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $mouthaction is "mouthkisstentacle8">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthkisstentacle8">>
<<submission 3>><<oralskilluse>>You <<oraltext>> kiss the tip of the $tentacle8 tentacle.<<set $rng to random(1, 100)>>
<<if $oralskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your face.</span><<set $facegoo += 1>><<set $tentacle8health -= 3>><<faceejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $mouthaction is "mouthcooperatetentacle8">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthcooperatetentacle8">>
<<sex 5>><<oralskilluse>>You <<oraltext>> suck the $tentacle8 tentacle invading your mouth.<<set $rng to random(1, 100)>>
<<if $oralskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip and into your mouth.</span><<set $tentacle8health -= 3>><<set $drugged += 3>><<set $mouthgoo += 1>><<oralejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $mouthaction is "mouthpullawaytentacle8">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthpullawaytentacle8">><<brat 1>><span class="teal">You pull away from the $tentacle8 tentacle threatening your mouth.</span><<tentacle8disable>>
<</if>>
<<if $mouthaction is "mouthbitetentacle8">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthbitetentacle8">><<defiance 5>>You bite down on the $tentacle8 tentacle invading your mouth. <span class="teal">It recoils immediately.</span><<tentacle8disable>><<set $attackstat += 1>><<set $tentacle8health -= 1>>
<<if $rng lte ($physique / 200)>>
<<set $tentacle8health -= 1>>
<</if>>
<</if>>
<<if $vaginaaction is "vaginarubtentacle8">><<set $vaginaaction to 0>><<set $vaginaactiondefault to "vaginarubtentacle8">>
<<submission 2>><<vaginalskilluse>>You <<vaginaltext>> rub the tip of the $tentacle8 tentacle with your <<pussystop>><<set $rng to random(1, 100)>>
<<if $vaginalskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $vaginaoutsidegoo += 1>><<set $tentacle8health -= 3>><<vaginalentranceejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $vaginaaction is "vaginacooperatetentacle8">><<set $vaginaaction to 0>><<set $vaginaactiondefault to "vaginacooperatetentacle8">>
<<sex 5>><<vaginalskilluse>>You <<vaginaltext>> push back against the $tentacle8 tentacle invading your <<pussystop>><<set $rng to random(1, 100)>>
<<if $vaginalskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, flooding your womb with its warmth.</span><<set $tentacle8health -= 3>><<set $drugged += 3>><<set $vaginagoo += 1>><<vaginalejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $vaginaaction is "vaginapullawaytentacle8">><<set $vaginaaction to 0>><<set $vaginaactiondefault to "vaginapullawaytentacle8">><<brat 1>><span class="teal">You pull away from the $tentacle8 tentacle threatening your <<pussystop>></span><<tentacle8disable>>
<</if>>
<<if $penisaction is "penisrubtentacle8">><<set $penisaction to 0>><<set $penisactiondefault to "penisrubtentacle8">>
<<submission 2>><<penileskilluse>>You <<peniletext>> rub the tip of the $tentacle8 tentacle with your <<penisstop>><<set $rng to random(1, 100)>>
<<if $penileskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $penisgoo += 1>><<set $tentacle8health -= 3>><<penileejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $penisaction is "peniscooperatetentacle8">><<set $penisaction to 0>><<set $penisactiondefault to "peniscooperatetentacle8">>
<<sex 5>><<penileskilluse>>You <<peniletext>> push back against the $tentacle8 tentacle engulfing your <<penisstop>><<set $rng to random(1, 100)>>
<<if $penileskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your groin.</span><<set $tentacle8health -= 3>><<set $penisgoo += 1>><<penileejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $penisaction is "penispullawaytentacle8">><<set $penisaction to 0>><<set $penisactiondefault to "penispullawaytentacle8">><<brat 1>><span class="teal">You pull away from the $tentacle8 tentacle threatening your <<penisstop>></span><<tentacle8disable>>
<</if>>
<<if $anusaction is "anusrubtentacle8">><<set $anusaction to 0>><<set $anusactiondefault to "anusrubtentacle8">>
<<submission 2>><<analskilluse>>You <<analtext>> rub the tip of the $tentacle8 tentacle with your <<bottomstop>><<set $rng to random(1, 100)>>
<<if $analskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your <<bottomstop>></span><<set $bottomgoo += 1>><<set $tentacle8health -= 3>><<bottomejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $anusaction is "anuscooperatetentacle8">><<set $anusaction to 0>><<set $anusactiondefault to "anuscooperatetentacle8">>
<<sex 5>><<analskilluse>>You <<analtext>> push back against the $tentacle8 tentacle invading your <<bottomstop>><<set $rng to random(1, 100)>>
<<if $analskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, flooding your bowels with its warmth.</span><<set $tentacle8health -= 3>><<set $drugged += 3>><<set $anusgoo += 1>><<analejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $anusaction is "anuspullawaytentacle8">><<set $anusaction to 0>><<set $anusactiondefault to "anuspullawaytentacle8">><<brat 1>><span class="teal">You pull away from the $tentacle8 tentacle threatening your <<bottomstop>></span><<tentacle8disable>>
<</if>>
<<if $thighaction is "penisrubtentacle8">><<set $thighaction to 0>><<set $thighactiondefault to "penisrubtentacle8">>
<<submission 3>><<thighskilluse>>You <<thightext>> rub the $tentacle8 tentacle between your thighs.<<set $rng to random(1, 100)>>
<<if $thighskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your tummy.</span><<set $tentacle8health -= 3>><<set $tummygoo += 1>><<tummyejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $thighaction is "vaginarubtentacle8">><<set $thighaction to 0>><<set $thighactiondefault to "vaginarubtentacle8">>
<<submission 3>><<thighskilluse>>You <<thightext>> rub the $tentacle8 tentacle between your thighs.<<set $rng to random(1, 100)>>
<<if $thighskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your tummy.</span><<set $tentacle8health -= 3>><<set $tummygoo += 1>><<tummyejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $bottomaction is "bottomrubtentacle8">><<set $bottomaction to 0>><<set $bottomactiondefault to "bottomrubtentacle8">>
<<submission 3>><<bottomskilluse>>You <<bottomtext>> rub the $tentacle8 tentacle between your cheeks.<<set $rng to random(1, 100)>>
<<if $bottomskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your <<bottomstop>></span><<set $tentacle8health -= 3>><<set $bottomgoo += 1>><<bottomejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $chestaction is "chestrubtentacle8">><<set $chestaction to 0>><<set $chestactiondefault to "chestrubtentacle8">>
<<submission 3>><<chestskilluse>>You <<chesttext>> rub the $tentacle8 tentacle between your <<breastsstop>><<set $rng to random(1, 100)>>
<<if $chestskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your chest.</span><<set $tentacle8health -= 3>><<set $chestgoo += 1>><<chestejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<</nobr>><</widget>>
:: Widgets Combat Tentacle9 [widget]
<<widget "tentacle9">><<nobr>>
<<if $tentacle9health lte 0 and $tentacle9shaft isnot "finished">>
Worn out, the $tentacle9 tentacle retracts from you.
<<tentacle9disable>>
<<set $tentacle9shaft to "finished">>
<<set $tentacle9head to "finished">>
<</if>>
<<if $tentacle9shaft is "tummy">>
The $tentacle9 tentacle <<slithers>> around your tummy,
<</if>>
<<if $tentacle9shaft is "thighs">>
The $tentacle9 tentacle <<slithers>> between your thighs,
<</if>>
<<if $tentacle9shaft is "breasts">>
The $tentacle9 tentacle squeezes your breasts together,
<</if>>
<<if $tentacle9shaft is "chest">>
The $tentacle9 tentacle <<slithers>> around your chest,
<</if>>
<<if $tentacle9shaft is "waist">>
The $tentacle9 tentacle <<slithers>> around your waist,
<</if>>
<<if $tentacle9shaft is "neck">>
The $tentacle9 tentacle <<slithers>> around your neck,
<</if>>
<<if $tentacle9shaft is "shoulders">>
The $tentacle9 tentacle <<slithers>> around your shoulders,
<</if>>
<<if $tentacle9shaft is "leftleg">>
The $tentacle9 tentacle <<slithers>> around your left leg,
<</if>>
<<if $tentacle9shaft is "rightleg">>
The $tentacle9 tentacle <<slithers>> around your right leg,
<</if>>
<<if $tentacle9shaft is "leftarm">>
The $tentacle9 tentacle <<slithers>> around your left arm,
<</if>>
<<if $tentacle9shaft is "rightarm">>
The $tentacle9 tentacle <<slithers>> around your right arm,
<</if>>
<<if $tentacle9head is "leftarm">>
The $tentacle9 tentacle writhes in your left hand.<<neutral 5>>
<</if>>
<<if $tentacle9head is "rightarm">>
The $tentacle9 tentacle writhes in your right hand.<<neutral 5>>
<</if>>
<<if $tentacle9head is "feet">>
The $tentacle9 tentacle writhes between your feet.<<neutral 5>>
<</if>>
<<if $tentacle9head is "leftnipplesuck">>
and up to your <<breastscomma>> where it suckles your left nipple.<<neutral 3>>
<</if>>
<<if $tentacle9head is "rightnipplesuck">>
and up to your <<breastscomma>> where it suckles your right nipple.<<neutral 3>>
<</if>>
<<if $tentacle9head is "leftnipple">>
and continues teasing your left nipple. <span class="purple">The tip of the tentacle opens up, latches on, then begins sucking.</span><<neutral 3>><<set $tentacle9head to "leftnipplesuck">><<set $leftnipple to "tentaclesuck">>
<</if>>
<<if $tentacle9head is "rightnipple">>
and continues teasing your right nipple. <span class="purple">The tip of the tentacle opens up, latches on, then begins sucking.</span><<neutral 3>><<set $tentacle9head to "rightnipplesuck">><<set $rightnipple to "tentaclesuck">>
<</if>>
<<if $tentacle9head is "chest">>
<<if $chestuse is "squeezed">>
then up between your <<breastscomma>> rubbing itself between them.<<neutral 2>>
<<else>>
moves away from your <<breasts>><<set $tentacle9head to 0>><<set $breastuse to 0>>
<</if>>
<</if>>
<<if $tentacle9head is "mouthdeep">>
and up into your mouth where it spurts a sweet fluid down your throat at the apex of each thrust.<<set $purity -= 1>><<internalejac>><<sex 5>><<set $drugged += 3>><<set $mouthgoo += 1>><<set $tentacle9health -= 1>>
<</if>>
<<if $tentacle9head is "mouth">>
and continues thrusting into your mouth.<span class="pink"> The tip opens and begins oozing a sweet liquid.</span><<set $purity -= 1>><<internalejac>><<set $mouthstate to "tentacledeep">><<set $tentacle9head to "mouthdeep">><<sex 5>><<oralejacstat>><<ejacstat>>
<</if>>
<<if $tentacle9head is "mouthimminent">>
<<if $oralvirginity is 1>>
<span class="pink"> and thrusts between your lips,</span><span class="red"> penetrating your mouth for the first time.</span><<set $oralvirginity to 0>><<violence 5>>
<<else>>
<span class="pink"> and thrusts between your lips.</span>
<</if>>
<<set $mouthstate to "tentacle">><<set $tentacle9head to "mouth">><<sex 5>><<raped>><<oralstat>>
<</if>>
<<if $tentacle9head is "mouthentrance">>
<span class="purple"> and presses against your lips.</span><<set $mouthstate to "tentacleimminent">><<set $tentacle9head to "mouthimminent">><<neutral 4>>
<</if>>
<<if $tentacle9head is "vaginadeep">>
and <<slithers>> into your <<pussy>> where it pumps a viscous fluid at the apex of each thrust.<<set $purity -= 1>><<internalejac>><<sex 5>><<set $drugged += 3>><<set $vaginagoo += 1>><<set $tentacle9health -= 1>>
<</if>>
<<if $tentacle9head is "vagina">>
and continues thrusting into your <<pussystop>><span class="pink"> The tip opens and begins oozing a viscous liquid.</span><<set $purity -= 1>><<internalejac>><<set $vaginastate to "tentacledeep">><<set $tentacle9head to "vaginadeep">><<sex 5>><<vaginalejacstat>><<ejacstat>>
<</if>>
<<if $tentacle9head is "vaginaimminent">>
<<if $vaginalvirginity is 1>>
<span class="pink"> and thrusts into your <<pussycomma>></span><span class="red"> tearing your hymen and forever robbing you of your purity.</span><<set $vaginalvirginity to 0>><<violence 100>>
<<else>>
<span class="pink"> and thrusts into your <<pussystop>></span>
<</if>>
<<set $vaginastate to "tentacle">><<set $tentacle9head to "vagina">><<sex 5>><<raped>><<vaginaraped>><<vaginalstat>><<violence 1>>
<</if>>
<<if $tentacle9head is "vaginaentrance">>
<<if $undertype isnot "chastity">>
<span class="purple"> and presses against your <<pussycomma>> about to penetrate.</span><<set $vaginastate to "tentacleimminent">><<set $tentacle9head to "vaginaimminent">><<neutral 4>>
<<else>>
and tries to find a way inside. Failing, it lashes at the metal.<<set $underintegrity -= 10>><<violence 1>>
<</if>>
<</if>>
<<if $tentacle9head is "penisdeep">>
and continues thrusting against your <<peniscomma>> caressing and kneading your length.<<sex 5>>
<</if>>
<<if $tentacle9head is "penis">>
and continues thrusting against your <<penisstop>><span class="pink"> It sucks and kneads your length, trying to milk you of your cum.</span><<set $penisstate to "tentacledeep">><<set $tentacle9head to "penisdeep">><<sex 5>>
<</if>>
<<if $tentacle9head is "penisimminent">>
<<if $penilevirginity is 1>>
<span class="pink"> and thrusts against your <<peniscomma>> swallowing you to the base and </span><span class="red"> tearing the membrane between your glans and foreskin, forever robbing you of your purity.</span><<set $penilevirginity to 0>><<violence 100>>
<<else>>
<span class="pink"> and thrusts against your <<peniscomma>> swallowing you to the base.</span>
<</if>>
<<set $penisstate to "tentacle">><<set $tentacle9head to "penis">><<sex 5>><<raped>><<penisraped>><<penilestat>><<violence 1>>
<</if>>
<<if $tentacle9head is "penisentrance">>
<<if $undertype isnot "chastity">>
<span class="purple"> and <<slithers>> over to your <<penisstop>> The tip opens and presses against your glans, about to envelop you.</span><<set $penisstate to "tentacleimminent">><<set $tentacle9head to "penisimminent">><<neutral 4>>
<<else>>
and tries to find a way inside. Failing, it lashes at the metal.<<set $underintegrity -= 10>><<violence 1>>
<</if>>
<</if>>
<<if $tentacle9head is "anusdeep">>
and <<slithers>> into your <<bottom>> where it pumps a viscous fluid at the apex of each thrust.<<set $purity -= 1>><<internalejac>><<sex 5>><<set $drugged += 3>><<set $anusgoo += 1>><<set $tentacle9health -= 1>>
<</if>>
<<if $tentacle9head is "anus">>
and continues thrusting into your <<bottomstop>><span class="pink"> The tip opens and begins oozing a viscous liquid.</span><<set $purity -= 1>><<internalejac>><<set $anusstate to "tentacledeep">><<set $tentacle9head to "anusdeep">><<sex 5>><<analejacstat>><<ejacstat>>
<</if>>
<<if $tentacle9head is "anusimminent">>
<<if $analvirginity is 1>>
<span class="pink"> and thrusts into your <<bottomcomma>></span><span class="red"> violating you in a way you hadn't conceived of.</span><<set $analvirginity to 0>><<violence 100>>
<<else>>
<span class="pink"> and thrusts into your <<bottomstop>></span>
<</if>>
<<set $anusstate to "tentacle">><<set $tentacle9head to "anus">><<sex 5>><<raped>><<analstat>><<violence 1>>
<</if>>
<<if $tentacle9head is "anusentrance">>
<<if $analshield is 0>>
<span class="purple"> and presses against your <<bottomcomma>> about to penetrate.</span><<set $anusstate to "tentacleimminent">><<set $tentacle9head to "anusimminent">><<neutral 4>>
<<else>>
and tries to find a way inside. Failing, it lashes at the device.<<set $underintegrity -= 10>><<violence 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $tentacle9head is "vaginarub">>
<<if $rng gte 21>>
and between your thighs where it <<slithers>> against your <<pussycomma>> pressing against your clit.<<sex 3>>
<<else>>
and between your thighs <span class="blue">where it <<slithers>> toward your <<pussystop>></span><<neutral 3>><<set $vaginause to "tentacle">><<set $vaginastate to "tentacleentrance">><<set $tentacle9head to "vaginaentrance">><<set $thighuse to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $tentacle9head is "penisrub">>
<<if $rng gte 21>>
and between your thighs where it <<slithers>> against your <<peniscomma>> coiling around it.<<sex 3>>
<<else>>
and between your thighs <span class="blue">where the tip opens and it <<slithers>> toward your <<penisstop>></span><<neutral 3>><<set $penisuse to "tentacle">><<set $penisstate to "tentacleentrance">><<set $tentacle9head to "penisentrance">><<set $thighuse to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $tentacle9head is "bottomrub">>
<<if $rng gte 21>>
and between your <<bottom>> cheeks where it <<slithers>> against your back.<<sex 3>>
<<else>>
and between your <<bottom>> cheeks, <span class="blue"> toward your anus.</span><<neutral 3>><<set $anususe to "tentacle">><<set $anusstate to "tentacleentrance">><<set $tentacle9head to "anusentrance">><<set $bottomuse to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $tentacle9head is 0 and $tentacle9shaft isnot 0>>
<<if $rng lte 10>>
<<if $chestuse is "squeezed" and $breastuse is 0>>
<<upperslither>><span class="blue">and up between your squeezed <<breastsstop>></span><<set $tentacle9head to "chest">><<neutral 2>><<set $breastuse to "tentacle">><<cheststat>>
<<else>>
<<tentacle9default>>
<</if>>
<<elseif $rng lte 20>>
<<if $leftnipple is 0>>
<<upperslither>> <span class="blue">and teases your left nipple.</span><<neutral 2>><<set $tentacle9head to "leftnipple">><<set $leftnipple to "tentacle">>
<<else>>
<<tentacle9default>>
<</if>>
<<elseif $rng lte 30>>
<<if $rightnipple is 0>>
<<upperslither>> <span class="blue">and teases your right nipple.</span><<neutral 2>><<set $tentacle9head to "rightnipple">><<set $rightnipple to "tentacle">>
<<else>>
<<tentacle9default>>
<</if>>
<<elseif $rng lte 40>>
<<if $mouthuse is 0>>
<<upperslither>> <span class="blue">and up toward your mouth.</span><<neutral 2>><<set $mouthuse to "tentacle">><<set $mouthstate to "tentacleentrance">><<set $tentacle9head to "mouthentrance">>
<<else>>
<<tentacle9default>>
<</if>>
<<elseif $rng lte 50>>
<<if $anususe is 0 and $analdisable is "f">>
<<underslither>> <span class="blue">and <<slithers>> toward your <<bottomstop>></span><<neutral 2>><<set $anususe to "tentacle">><<set $anusstate to "tentacleentrance">><<set $tentacle9head to "anusentrance">>
<<else>>
<<tentacle9default>>
<</if>>
<<elseif $rng lte 60>>
<<if $vaginaexist is 1 and $vaginause is 0>>
<<underslither>> <span class="blue">and <<slithers>> toward your <<pussystop>></span><<neutral 2>><<set $vaginause to "tentacle">><<set $vaginastate to "tentacleentrance">><<set $tentacle9head to "vaginaentrance">>
<<else>>
<<tentacle9default>>
<</if>>
<<elseif $rng lte 70>>
<<if $penisexist is 1 and $penisuse is 0>>
<<underslither>> <span class="blue">and <<slithers>> toward your <<penisstop>></span><<neutral 2>><<set $penisuse to "tentacle">><<set $penisstate to "tentacleentrance">><<set $tentacle9head to "penisentrance">>
<<else>>
<<tentacle9default>>
<</if>>
<<elseif $rng lte 80>>
<<if $thighuse is 0>>
<<if $penisexist is 1 and $penisuse is 0>>
<<underslither>> <span class="blue">and <<slithers>> between your thighs and against your tummy and <<penisstop>></span><<set $penisuse to "tentaclerub">><<set $thighuse to "tentaclerub">><<set $tentacle9head to "penisrub">><<sex 3>><<thighstat>>
<<elseif $vaginaexist is 1 and $vaginause is 0>>
<<underslither>> <span class="blue">and <<slithers>> between your thighs and against your tummy and <<pussystop>></span><<set $vaginause to "tentaclerub">><<set $thighuse to "tentaclerub">><<set $tentacle9head to "vaginarub">><<sex 3>><<thighstat>>
<<else>>
<<tentacle9default>>
<</if>>
<<else>>
<<tentacle9default>>
<</if>>
<<elseif $rng lte 90>>
<<if $bottomuse is 0 and $anususe is 0 and $analdisable is "f">>
<<underslither>> <span class="blue">and <<slithers>> between your <<bottom>> cheeks and against your back.</span><<set $bottomuse to "tentaclerub">><<set $anususe to "tentaclerub">><<set $tentacle9head to "bottomrub">><<sex 1>><<bottomstat>>
<<else>>
<<tentacle9default>>
<</if>>
<<else>>
<<tentacle9default>>
<</if>>
<<elseif $tentacle9head is 0 and $tentacle9shaft is 0>>
<<if $rng lte 10>>
<<if $position isnot "wall">>
The $tentacle9 tentacle winds around your tummy.<<neutral 1>><<set $tentacle9shaft to "tummy">>
<<else>>
The $tentacle9 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<elseif $rng lte 20>>
The $tentacle9 tentacle <<slithers>> between your thighs.<<neutral 1>><<set $tentacle9shaft to "thighs">>
<<elseif $rng lte 30>>
<<if $position isnot "wall">>
<<if $breastsize gte 2 and $chestuse is 0>>
The $tentacle9 tentacle <<slithers>> around your <<breastscomma>> <span class="blue">squeezing them together.</span><<neutral 1>><<set $tentacle9shaft to "breasts">><<set $chestuse to "squeezed">>
<<else>>
The $tentacle9 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<else>>
The $tentacle9 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<elseif $rng lte 40>>
<<if $position isnot "wall">>
The $tentacle9 tentacle winds its way around your chest, beneath your <<breastsstop>><<neutral 1>><<set $tentacle9shaft to "chest">>
<<else>>
The $tentacle9 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<elseif $rng lte 50>>
The $tentacle9 tentacle winds its way around your waist.<<neutral 1>><<set $tentacle9shaft to "waist">>
<<elseif $rng lte 60>>
<<if $position isnot "wall">>
<<if $head is 0>>
The $tentacle9 tentacle winds its way around your neck, <span class="blue">restraining your head.</span><<neutral 1>><<set $tentacle9shaft to "neck">><<set $head to "grappled">>
<<else>>
The $tentacle9 tentacle winds its way around your shoulders.<<neutral 1>><<set $tentacle9shaft to "shoulders">>
<</if>>
<<else>>
The $tentacle9 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<elseif $rng lte 70>>
The $tentacle9 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<<elseif $rng lte 80>>
<<if $leftleg is 0>>
The $tentacle9 tentacle winds its way around your left leg, <span class="blue">restraining it.</span><<neutral 1>><<feettentacledisable>><<set $tentacle9shaft to "leftleg">><<set $leftleg to "grappled">>
<<else>>
The $tentacle9 tentacle tickles your feet.<<neutral 1>>
<</if>>
<<elseif $rng lte 85>>
<<if $rightleg is 0>>
The $tentacle9 tentacle winds its way around your right leg, <span class="blue">restraining it.</span><<neutral 1>><<feettentacledisable>><<set $tentacle9shaft to "rightleg">><<set $rightleg to "grappled">>
<<else>>
The $tentacle9 tentacle tickles your feet.<<neutral 1>>
<</if>>
<<elseif $rng lte 90>>
<<if $leftarm is 0>>
The $tentacle9 tentacle winds its way around your left arm, <span class="blue">restraining it.</span><<neutral 1>><<leftarmtentacledisable>><<set $tentacle9shaft to "leftarm">><<set $leftarm to "grappled">><<set $leftarmstate to 0>>
<<else>>
The $tentacle9 tentacle tickles your armpit.<<neutral 1>>
<</if>>
<<elseif $rng lte 95>>
<<if $rightarm is 0>>
The $tentacle9 tentacle winds its way around your right arm, <span class="blue">restraining it.</span><<rightarmtentacledisable>><<neutral 1>><<set $tentacle9shaft to "rightarm">><<set $rightarm to "grappled">><<set $rightarmstate to 0>>
<<else>>
The $tentacle9 tentacle tickles your armpit.<<neutral 1>>
<</if>>
<<elseif $rng lte 100>>
The $tentacle9 tentacle <<slithers>> against your <<bottomstop>><<neutral 1>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "tentacle9default">><<nobr>>
<<set $rng to random(1, 100)>>
<<if $rng gte 90>>
then squirts a warm fluid over your neck.<<neutral 1>><<set $neckgoo += 1>><<set $tentacle9health -= 1>><<neckejacstat>><<ejacstat>>
<<elseif $rng gte 80>>
then squirts a warm fluid over your right arm.<<neutral 1>><<set $rightarmgoo += 1>><<set $tentacle9health -= 1>><<handejacstat>><<ejacstat>>
<<elseif $rng gte 70>>
then squirts a warm fluid over your left arm.<<neutral 1>><<set $leftarmgoo += 1>><<set $tentacle9health -= 1>><<handejacstat>><<ejacstat>>
<<elseif $rng gte 60>>
then squirts a warm fluid over your thighs.<<neutral 1>><<set $thighgoo += 1>><<set $tentacle9health -= 1>><<thighejacstat>><<ejacstat>>
<<elseif $rng gte 50>>
then squirts a warm fluid over your <<bottomstop>><<neutral 1>><<set $bottomgoo += 1>><<set $tentacle9health -= 1>><<bottomejacstat>><<ejacstat>>
<<elseif $rng gte 40>>
then squirts a warm fluid over your tummy.<<neutral 1>><<set $tummygoo += 1>><<set $tentacle9health -= 1>><<tummyejacstat>><<ejacstat>>
<<elseif $rng gte 30>>
then squirts a warm fluid over your chest.<<neutral 1>><<set $chestgoo += 1>><<set $tentacle9health -= 1>><<chestejacstat>><<ejacstat>>
<<elseif $rng gte 20>>
then squirts a warm fluid over your face.<<neutral 1>><<set $facegoo += 1>><<set $tentacle9health -= 1>><<faceejacstat>><<ejacstat>>
<<elseif $rng gte 10>>
then squirts a warm fluid over your hair.<<neutral 1>><<set $hairgoo += 1>><<set $tentacle9health -= 1>><<hairejacstat>><<ejacstat>>
<<else>>
then squirts a warm fluid over your feet.<<neutral 1>><<set $feetgoo += 1>><<set $tentacle9health -= 1>><<feetejacstat>><<ejacstat>>
<</if>>
<</nobr>><</widget>>
<<widget "tentacle9disable">><<nobr>>
<<if $tentacle9head is "feet">>
<<set $leftleg to 0>>
<<set $rightleg to 0>>
<<set $feetstate to 0>>
<</if>>
<<if $tentacle9head is "leftarm">>
<<set $leftarm to 0>>
<<set $leftarmstate to 0>>
<</if>>
<<if $tentacle9head is "rightarm">>
<<set $rightarm to 0>>
<<set $rightarmstate to 0>>
<</if>>
<<if $tentacle9head is "leftnipplesuck">>
<<set $leftnipple to 0>>
<</if>>
<<if $tentacle9head is "rightnipplesuck">>
<<set $rightnipple to 0>>
<</if>>
<<if $tentacle9head is "leftnipple">>
<<set $leftnipple to 0>>
<</if>>
<<if $tentacle9head is "rightnipple">>
<<set $rightnipple to 0>>
<</if>>
<<if $tentacle9head is "chest">>
<<set $chestuse to 0>>
<</if>>
<<if $tentacle9head is "mouthentrance">>
<<set $mouthuse to 0>>
<<set $mouthstate to 0>>
<</if>>
<<if $tentacle9head is "mouthimminent">>
<<set $mouthuse to 0>>
<<set $mouthstate to 0>>
<</if>>
<<if $tentacle9head is "mouth">>
<<set $mouthuse to 0>>
<<set $mouthstate to 0>>
<</if>>
<<if $tentacle9head is "mouthdeep">>
<<set $mouthuse to 0>>
<<set $mouthstate to 0>>
<</if>>
<<if $tentacle9head is "anusentrance">>
<<set $anususe to 0>>
<<set $anusstate to 0>>
<</if>>
<<if $tentacle9head is "anusimminent">>
<<set $anususe to 0>>
<<set $anusstate to 0>>
<</if>>
<<if $tentacle9head is "anus">>
<<set $anususe to 0>>
<<set $anusstate to 0>>
<</if>>
<<if $tentacle9head is "anusdeep">>
<<set $anususe to 0>>
<<set $anusstate to 0>>
<</if>>
<<if $tentacle9head is "vaginaentrance">>
<<set $vaginause to 0>>
<<set $vaginastate to 0>>
<</if>>
<<if $tentacle9head is "vaginaimminent">>
<<set $vaginause to 0>>
<<set $vaginastate to 0>>
<</if>>
<<if $tentacle9head is "vagina">>
<<set $vaginause to 0>>
<<set $vaginastate to 0>>
<</if>>
<<if $tentacle9head is "vaginadeep">>
<<set $vaginause to 0>>
<<set $vaginastate to 0>>
<</if>>
<<if $tentacle9head is "penisentrance">>
<<set $penisuse to 0>>
<<set $penisstate to 0>>
<</if>>
<<if $tentacle9head is "penisimminent">>
<<set $penisuse to 0>>
<<set $penisstate to 0>>
<</if>>
<<if $tentacle9head is "penis">>
<<set $penisuse to 0>>
<<set $penisstate to 0>>
<</if>>
<<if $tentacle9head is "penisdeep">>
<<set $penisuse to 0>>
<<set $penisstate to 0>>
<</if>>
<<if $tentacle9head is "vaginarub">>
<<set $vaginause to 0>>
<<set $thighuse to 0>>
<</if>>
<<if $tentacle9head is "penisrub">>
<<set $penisuse to 0>>
<<set $thighuse to 0>>
<</if>>
<<if $tentacle9head is "bottomrub">>
<<set $anususe to 0>>
<<set $bottomuse to 0>>
<</if>>
<<if $tentacle9shaft is "breasts">>
<<set $chestuse to 0>>
<</if>>
<<if $tentacle9shaft is "neck" and $head isnot "bound">>
<<set $head to 0>>
<</if>>
<<if $tentacle9shaft is "leftleg" and $leftleg isnot "bound">>
<<set $leftleg to 0>>
<</if>>
<<if $tentacle9shaft is "rightleg" and $rightleg isnot "bound">>
<<set $rightleg to 0>>
<</if>>
<<if $tentacle9shaft is "leftarm" and $leftarm isnot "bound">>
<<set $leftarm to 0>>
<</if>>
<<if $tentacle9shaft is "rightarm" and $rightarm isnot "bound">>
<<set $rightarm to 0>>
<</if>>
<<if $tentacle9head is "chest">>
<<set $breastuse to 0>>
<</if>>
<<set $tentacle9shaft to 0>>
<<set $tentacle9head to 0>>
<</nobr>><</widget>>
<<widget "actionstentacle9lefthand">><<nobr>>
<<if $leftarm is 0 and $tentacle9shaft isnot "finished">>
<<if $leftactiondefault is "lefthittentacle9">>
| <label><span class="def">Strike the $tentacle9 tentacle</span> <<radiobutton "$leftaction" "lefthittentacle9" checked>></label>
<<else>>
| <label><span class="def">Strike the $tentacle9 tentacle</span> <<radiobutton "$leftaction" "lefthittentacle9">></label>
<</if>>
<<if $leftactiondefault is "leftgrabtentacle9">>
| <label><span class="sub">Grab the $tentacle9 tentacle</span> <<radiobutton "$leftaction" "leftgrabtentacle9" checked>></label>
<<else>>
| <label><span class="sub">Grab the $tentacle9 tentacle</span> <<radiobutton "$leftaction" "leftgrabtentacle9">></label>
<</if>>
<<elseif $leftarm is "tentacle9">>You hold the $tentacle9 tentacle in your left hand.<br>
<<if $leftactiondefault is "leftrubtentacle9">>
| <label><span class="sub">Milk it</span> <<radiobutton "$leftaction" "leftrubtentacle9" checked>></label>
<<else>>
| <label><span class="sub">Milk it</span> <<radiobutton "$leftaction" "leftrubtentacle9">></label>
<</if>>
<<if $leftactiondefault is "leftstoptentacle9">>
| <label><span class="neutral">Let go</span> <<radiobutton "$leftaction" "leftstoptentacle9" checked>></label>
<<else>>
| <label><span class="neutral">Let go</span> <<radiobutton "$leftaction" "leftstoptentacle9">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle9righthand">><<nobr>>
<<if $rightarm is 0 and $tentacle9shaft isnot "finished">>
<<if $rightactiondefault is "righthittentacle9">>
| <label><span class="def">Strike the $tentacle9 tentacle</span> <<radiobutton "$rightaction" "righthittentacle9" checked>></label>
<<else>>
| <label><span class="def">Strike the $tentacle9 tentacle</span> <<radiobutton "$rightaction" "righthittentacle9">></label>
<</if>>
<<if $rightactiondefault is "rightgrabtentacle9">>
| <label><span class="sub">Grab the $tentacle9 tentacle</span> <<radiobutton "$rightaction" "rightgrabtentacle9" checked>></label>
<<else>>
| <label><span class="sub">Grab the $tentacle9 tentacle</span> <<radiobutton "$rightaction" "rightgrabtentacle9">></label>
<</if>>
<<elseif $rightarm is "tentacle9">>You hold the $tentacle9 tentacle in your right hand.<br>
<<if $rightactiondefault is "rightrubtentacle9">>
| <label><span class="sub">Milk it</span> <<radiobutton "$rightaction" "rightrubtentacle9" checked>></label>
<<else>>
| <label><span class="sub">Milk it</span> <<radiobutton "$rightaction" "rightrubtentacle9">></label>
<</if>>
<<if $rightactiondefault is "rightstoptentacle9">>
| <label><span class="neutral">Let go</span> <<radiobutton "$rightaction" "rightstoptentacle9" checked>></label>
<<else>>
| <label><span class="neutral">Let go</span> <<radiobutton "$rightaction" "rightstoptentacle9">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle9legs">><<nobr>>
<<if $leftleg is 0 and $rightleg is 0 and $tentacle9shaft isnot "finished">>
<<if $feetactiondefault is "feethittentacle9">>
| <label><span class="def">Kick the $tentacle9 tentacle</span> <<radiobutton "$feetaction" "feethittentacle9" checked>></label>
<<else>>
| <label><span class="def">Kick the $tentacle9 tentacle</span> <<radiobutton "$feetaction" "feethittentacle9">></label>
<</if>>
<<if $feetactiondefault is "feetgrabtentacle9">>
| <label><span class="sub">Grab the $tentacle9 tentacle</span> <<radiobutton "$feetaction" "feetgrabtentacle9" checked>></label>
<<else>>
| <label><span class="sub">Grab the $tentacle9 tentacle</span> <<radiobutton "$feetaction" "feetgrabtentacle9">></label>
<</if>>
<<elseif $leftleg is 0 and $tentacle9shaft isnot "finished">>
<<if $feetactiondefault is "feethittentacle9">>
| <label><span class="def">Kick the $tentacle9 tentacle</span> <<radiobutton "$feetaction" "feethittentacle9" checked>></label>
<<else>>
| <label><span class="def">Kick the $tentacle9 tentacle</span> <<radiobutton "$feetaction" "feethittentacle9">></label>
<</if>>
<<elseif $rightleg is 0 and $tentacle9shaft isnot "finished">>
<<if $feetactiondefault is "feethittentacle9">>
| <label><span class="def">Kick the $tentacle9 tentacle</span> <<radiobutton "$feetaction" "feethittentacle9" checked>></label>
<<else>>
| <label><span class="def">Kick the $tentacle9 tentacle</span> <<radiobutton "$feetaction" "feethittentacle9">></label>
<</if>>
<<elseif $leftleg is "tentacle9">>You hold the $tentacle9 tentacle between your feet.<br>
<<if $feetactiondefault is "feetrubtentacle9">>
| <label><span class="sub">Milk it</span> <<radiobutton "$feetaction" "feetrubtentacle9" checked>></label>
<<else>>
| <label><span class="sub">Milk it</span> <<radiobutton "$feetaction" "feetrubtentacle9">></label>
<</if>>
<<if $feetactiondefault is "feetstoptentacle9">>
| <label><span class="neutral">Let go</span> <<radiobutton "$feetaction" "feetstoptentacle9" checked>></label>
<<else>>
| <label><span class="neutral">Let go</span> <<radiobutton "$feetaction" "feetstoptentacle9">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle9mouth">><<nobr>>
<<if $tentacle9head is "mouthentrance">>
<<if $mouthactiondefault is "mouthlicktentacle9">>
| <label><span class="sub">Lick it</span> <<radiobutton "$mouthaction" "mouthlicktentacle9" checked>></label>
<<else>>
| <label><span class="sub">Lick it</span> <<radiobutton "$mouthaction" "mouthlicktentacle9">></label>
<</if>>
<<if $head is "grappled">>
<<else>>
<<if $mouthactiondefault is "mouthpullawaytentacle9">>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "mouthpullawaytentacle9" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "mouthpullawaytentacle9">></label>
<</if>>
<</if>>
<<elseif $tentacle9head is "mouthimminent">>
<<if $mouthactiondefault is "mouthkisstentacle9">>
| <label><span class="sub">Kiss it</span> <<radiobutton "$mouthaction" "mouthkisstentacle9" checked>></label>
<<else>>
| <label><span class="sub">Kiss it</span> <<radiobutton "$mouthaction" "mouthkisstentacle9">></label>
<</if>>
<<if $head is "grappled">>
<<else>>
<<if $mouthactiondefault is "mouthpullawaytentacle9">>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "mouthpullawaytentacle9" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "mouthpullawaytentacle9">></label>
<</if>>
<</if>>
<<elseif $tentacle9head is "mouth">>
<<if $mouthactiondefault is "mouthcooperatetentacle9">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$mouthaction" "mouthcooperatetentacle9" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$mouthaction" "mouthcooperatetentacle9">></label>
<</if>>
<<if $mouthactiondefault is "mouthbitetentacle9">>
| <label><span class="def">Bite</span> <<radiobutton "$mouthaction" "mouthbitetentacle9" checked>></label>
<<else>>
| <label><span class="def">Bite</span> <<radiobutton "$mouthaction" "mouthbitetentacle9">></label>
<</if>>
<<elseif $tentacle9head is "mouthdeep">>
<<if $mouthactiondefault is "mouthcooperatetentacle9">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$mouthaction" "mouthcooperatetentacle9" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$mouthaction" "mouthcooperatetentacle9">></label>
<</if>>
<<if $mouthactiondefault is "mouthbitetentacle9">>
| <label><span class="def">Bite</span> <<radiobutton "$mouthaction" "mouthbitetentacle9" checked>></label>
<<else>>
| <label><span class="def">Bite</span> <<radiobutton "$mouthaction" "mouthbitetentacle9">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle9vagina">><<nobr>>
<<if $tentacle9head is "vaginaentrance">>
<<if $vaginaactiondefault is "vaginarubtentacle9">>
| <label><span class="sub">Rub</span> <<radiobutton "$vaginaaction" "vaginarubtentacle9" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$vaginaaction" "vaginarubtentacle9">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $vaginaactiondefault is "vaginapullawaytentacle9">>
| <label><span class="brat">Pull away</span> <<radiobutton "$vaginaaction" "vaginapullawaytentacle9" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$vaginaaction" "vaginapullawaytentacle9">></label>
<</if>>
<</if>>
<<elseif $tentacle9head is "vaginaimminent">>
<<if $vaginaactiondefault is "vaginarubtentacle9">>
| <label><span class="sub">Rub</span> <<radiobutton "$vaginaaction" "vaginarubtentacle9" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$vaginaaction" "vaginarubtentacle9">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $vaginaactiondefault is "vaginapullawaytentacle9">>
| <label><span class="brat">Pull away</span> <<radiobutton "$vaginaaction" "vaginapullawaytentacle9" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$vaginaaction" "vaginapullawaytentacle9">></label>
<</if>>
<</if>>
<<elseif $tentacle9head is "vagina">>
<<if $vaginaactiondefault is "vaginacooperatetentacle9">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$vaginaaction" "vaginacooperatetentacle9" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$vaginaaction" "vaginacooperatetentacle9">></label>
<</if>>
<<elseif $tentacle9head is "vaginadeep">>
<<if $vaginaactiondefault is "vaginacooperatetentacle9">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$vaginaaction" "vaginacooperatetentacle9" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$vaginaaction" "vaginacooperatetentacle9">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle9penis">><<nobr>>
<<if $tentacle9head is "penisentrance">>
<<if $penisactiondefault is "penisrubtentacle9">>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "penisrubtentacle9" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "penisrubtentacle9">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $penisactiondefault is "penispullawaytentacle9">>
| <label><span class="brat">Pull away</span> <<radiobutton "$penisaction" "penispullawaytentacle9" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$penisaction" "penispullawaytentacle9">></label>
<</if>>
<</if>>
<<elseif $tentacle9head is "penisimminent">>
<<if $penisactiondefault is "penisrubtentacle9">>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "penisrubtentacle9" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "penisrubtentacle9">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $penisactiondefault is "penispullawaytentacle9">>
| <label><span class="brat">Pull away</span> <<radiobutton "$penisaction" "penispullawaytentacle9" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$penisaction" "penispullawaytentacle9">></label>
<</if>>
<</if>>
<<elseif $tentacle9head is "penis">>
<<if $penisactiondefault is "peniscooperatetentacle9">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$penisaction" "peniscooperatetentacle9" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$penisaction" "peniscooperatetentacle9">></label>
<</if>>
<<elseif $tentacle9head is "penisdeep">>
<<if $penisactiondefault is "peniscooperatetentacle9">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$penisaction" "peniscooperatetentacle9" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$penisaction" "peniscooperatetentacle9">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle9anus">><<nobr>>
<<if $tentacle9head is "anusentrance">>
<<if $anusactiondefault is "anusrubtentacle9">>
| <label><span class="sub">Rub</span> <<radiobutton "$anusaction" "anusrubtentacle9" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$anusaction" "anusrubtentacle9">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $anusactiondefault is "anuspullawaytentacle9">>
| <label><span class="brat">Pull away</span> <<radiobutton "$anusaction" "anuspullawaytentacle9" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$anusaction" "anuspullawaytentacle9">></label>
<</if>>
<</if>>
<<elseif $tentacle9head is "anusimminent">>
<<if $anusactiondefault is "anusrubtentacle9">>
| <label><span class="sub">Rub</span> <<radiobutton "$anusaction" "anusrubtentacle9" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$anusaction" "anusrubtentacle9">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $anusactiondefault is "anuspullawaytentacle9">>
| <label><span class="brat">Pull away</span> <<radiobutton "$anusaction" "anuspullawaytentacle9" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$anusaction" "anuspullawaytentacle9">></label>
<</if>>
<</if>>
<<elseif $tentacle9head is "anus">>
<<if $anusactiondefault is "anuscooperatetentacle9">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$anusaction" "anuscooperatetentacle9" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$anusaction" "anuscooperatetentacle9">></label>
<</if>>
<<elseif $tentacle9head is "anusdeep">>
<<if $anusactiondefault is "anuscooperatetentacle9">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$anusaction" "anuscooperatetentacle9" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$anusaction" "anuscooperatetentacle9">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle9thighs">><<nobr>>
<<if $tentacle9head is "penisrub">>
<<if $thighactiondefault is "penisrubtentacle9">>
| <label><span class="sub">Rub</span> <<radiobutton "$thighaction" "penisrubtentacle9" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$thighaction" "penisrubtentacle9">></label>
<</if>>
<<elseif $tentacle9head is "vaginarub">>
<<if $thighactiondefault is "vaginarubtentacle9">>
| <label><span class="sub">Rub</span> <<radiobutton "$thighaction" "vaginarubtentacle9" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$thighaction" "vaginarubtentacle9">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle9bottom">><<nobr>>
<<if $tentacle9head is "bottomrub">>
<<if $bottomactiondefault is "bottomrubtentacle9">>
| <label><span class="sub">Rub</span> <<radiobutton "$bottomaction" "bottomrubtentacle9" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$bottomaction" "bottomrubtentacle9">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle9chest">><<nobr>>
<<if $tentacle9head is "chest">>
<<if $chestactiondefault is "chestrubtentacle9">>
| <label><span class="sub">Rub</span> <<radiobutton "$chestaction" "chestrubtentacle9" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$chestaction" "chestrubtentacle9">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "effectstentacle9">><<nobr>>
<<if $leftaction is "lefthittentacle9">><<set $leftaction to 0>><<set $leftactiondefault to "lefthittentacle9">>You strike the $tentacle9 tentacle with your left hand and it reels away from you.<<defiance 2>><<set $speechhit to 1>><<tentacle9disable>><<set $attackstat += 1>><<set $tentacle9health -= 1>>
<<if $rng lte ($physique / 200)>>
<<set $tentacle9health -= 1>>
<</if>>
<</if>>
<<if $rightaction is "righthittentacle9">><<set $rightaction to 0>><<set $rightactiondefault to "righthittentacle9">>You strike the $tentacle9 tentacle with your right hand and it reels away from you.<<defiance 2>><<set $speechhit to 1>><<tentacle9disable>><<set $attackstat += 1>><<set $tentacle9health -= 1>>
<<if $rng lte ($physique / 200)>>
<<set $tentacle9health -= 1>>
<</if>>
<</if>>
<<if $leftaction is "leftgrabtentacle9">><<set $leftaction to 0>><<set $leftactiondefault to "leftrubtentacle9">><<submission 1>><<handstat>><span class="lblue">You <<handtext>> grab the $tentacle9 tentacle with your left hand.</span><<tentacle9disable>><<set $leftarm to "tentacle9">><<set $tentacle9head to "leftarm">><<handstat>><<set $leftarmstate to "tentacle">>
<</if>>
<<if $rightaction is "rightgrabtentacle9">><<set $rightaction to 0>><<set $rightactiondefault to "rightrubtentacle9">><<submission 1>><<handstat>><span class="lblue">You <<handtext>> grab the $tentacle9 tentacle with your right hand.</span><<tentacle9disable>><<set $rightarm to "tentacle9">><<set $tentacle9head to "rightarm">><<handstat>><<set $rightarmstate to "tentacle">>
<</if>>
<<if $leftaction is "leftrubtentacle9">><<set $leftaction to 0>><<set $leftactiondefault to "leftrubtentacle9">><<handskilluse>><<submission 1>>You <<handtext>> squeeze the $tentacle9 tentacle in your left hand and rub up and down its length.<<set $rng to random(1, 100)>>
<<if $handskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $rightarmgoo += 1>><<set $tentacle9health -= 3>><<handejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $rightaction is "rightrubtentacle9">><<set $rightaction to 0>><<set $rightactiondefault to "rightrubtentacle9">><<handskilluse>><<submission 1>>You <<handtext>> squeeze the $tentacle9 tentacle in your right hand and rub up and down its length.<<set $rng to random(1, 100)>>
<<if $handskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $rightarmgoo += 1>><<set $tentacle9health -= 3>><<handejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $leftaction is "leftstoptentacle9">><<set $leftaction to 0>><<set $leftactiondefault to "leftstoptentacle9">>You release the $tentacle9 tentacle from your left hand.<<tentacle9disable>>
<</if>>
<<if $rightaction is "rightstoptentacle9">><<set $rightaction to 0>><<set $rightactiondefault to "rightstoptentacle9">>You release the $tentacle9 tentacle from your right hand.<<tentacle9disable>>
<</if>>
<<if $feetaction is "feethittentacle9">><<set $feetaction to 0>><<set $feetactiondefault to "feethittentacle9">>You kick the $tentacle9 tentacle and it reels away from you.<<defiance 2>><<set $speechhit to 1>><<tentacle9disable>><<set $attackstat += 1>><<set $tentacle9health -= 1>>
<<if $rng lte ($physique / 200)>>
<<set $tentacle9health -= 1>>
<</if>>
<</if>>
<<if $feetaction is "feetgrabtentacle9">><<set $feetaction to 0>><<set $feetactiondefault to "feetrubtentacle9">><<submission 1>><<feetstat>><span class="lblue">You <<feettext>> grab the $tentacle9 tentacle between your feet.</span><<tentacle9disable>><<set $leftleg to "tentacle9">><<set $rightleg to "tentacle9">><<set $tentacle9head to "feet">><<feetstat>><<set $feetstate to "tentacle">>
<</if>>
<<if $feetaction is "feetrubtentacle9">><<set $feetaction to 0>><<set $feetactiondefault to "feetrubtentacle9">><<feetskilluse>><<submission 1>>You <<feettext>> squeeze the $tentacle9 tentacle between your feet and rub up and down its length.<<set $rng to random(1, 100)>>
<<if $feetskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $feetgoo += 1>><<set $tentacle9health -= 3>><<feetejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $feetaction is "feetstoptentacle9">><<set $feetaction to 0>><<set $feetactiondefault to "feetstoptentacle9">>You let go of the $tentacle9 tentacle between your feet.<<tentacle9disable>>
<</if>>
<<if $mouthaction is "mouthlicktentacle9">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthlicktentacle9">>
<<submission 2>><<oralskilluse>>You <<oraltext>> lick the tip of the $tentacle9 tentacle.<<set $rng to random(1, 100)>>
<<if $oralskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your face.</span><<set $facegoo += 1>><<set $tentacle9health -= 3>><<faceejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $mouthaction is "mouthkisstentacle9">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthkisstentacle9">>
<<submission 3>><<oralskilluse>>You <<oraltext>> kiss the tip of the $tentacle9 tentacle.<<set $rng to random(1, 100)>>
<<if $oralskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your face.</span><<set $facegoo += 1>><<set $tentacle9health -= 3>><<faceejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $mouthaction is "mouthcooperatetentacle9">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthcooperatetentacle9">>
<<sex 5>><<oralskilluse>>You <<oraltext>> suck the $tentacle9 tentacle invading your mouth.<<set $rng to random(1, 100)>>
<<if $oralskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip and into your mouth.</span><<set $tentacle9health -= 3>><<set $drugged += 3>><<set $mouthgoo += 1>><<oralejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $mouthaction is "mouthpullawaytentacle9">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthpullawaytentacle9">><<brat 1>><span class="teal">You pull away from the $tentacle9 tentacle threatening your mouth.</span><<tentacle9disable>>
<</if>>
<<if $mouthaction is "mouthbitetentacle9">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthbitetentacle9">><<defiance 5>>You bite down on the $tentacle9 tentacle invading your mouth. <span class="teal">It recoils immediately.</span><<tentacle9disable>><<set $attackstat += 1>><<set $tentacle9health -= 1>>
<<if $rng lte ($physique / 200)>>
<<set $tentacle9health -= 1>>
<</if>>
<</if>>
<<if $vaginaaction is "vaginarubtentacle9">><<set $vaginaaction to 0>><<set $vaginaactiondefault to "vaginarubtentacle9">>
<<submission 2>><<vaginalskilluse>>You <<vaginaltext>> rub the tip of the $tentacle9 tentacle with your <<pussystop>><<set $rng to random(1, 100)>>
<<if $vaginalskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $vaginaoutsidegoo += 1>><<set $tentacle9health -= 3>><<vaginalentranceejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $vaginaaction is "vaginacooperatetentacle9">><<set $vaginaaction to 0>><<set $vaginaactiondefault to "vaginacooperatetentacle9">>
<<sex 5>><<vaginalskilluse>>You <<vaginaltext>> push back against the $tentacle9 tentacle invading your <<pussystop>><<set $rng to random(1, 100)>>
<<if $vaginalskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, flooding your womb with its warmth.</span><<set $tentacle9health -= 3>><<set $drugged += 3>><<set $vaginagoo += 1>><<vaginalejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $vaginaaction is "vaginapullawaytentacle9">><<set $vaginaaction to 0>><<set $vaginaactiondefault to "vaginapullawaytentacle9">><<brat 1>><span class="teal">You pull away from the $tentacle9 tentacle threatening your <<pussystop>></span><<tentacle9disable>>
<</if>>
<<if $penisaction is "penisrubtentacle9">><<set $penisaction to 0>><<set $penisactiondefault to "penisrubtentacle9">>
<<submission 2>><<penileskilluse>>You <<peniletext>> rub the tip of the $tentacle9 tentacle with your <<penisstop>><<set $rng to random(1, 100)>>
<<if $penileskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $penisgoo += 1>><<set $tentacle9health -= 3>><<penileejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $penisaction is "peniscooperatetentacle9">><<set $penisaction to 0>><<set $penisactiondefault to "peniscooperatetentacle9">>
<<sex 5>><<penileskilluse>>You <<peniletext>> push back against the $tentacle9 tentacle engulfing your <<penisstop>><<set $rng to random(1, 100)>>
<<if $penileskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your groin.</span><<set $tentacle9health -= 3>><<set $penisgoo += 1>><<penileejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $penisaction is "penispullawaytentacle9">><<set $penisaction to 0>><<set $penisactiondefault to "penispullawaytentacle9">><<brat 1>><span class="teal">You pull away from the $tentacle9 tentacle threatening your <<penisstop>></span><<tentacle9disable>>
<</if>>
<<if $anusaction is "anusrubtentacle9">><<set $anusaction to 0>><<set $anusactiondefault to "anusrubtentacle9">>
<<submission 2>><<analskilluse>>You <<analtext>> rub the tip of the $tentacle9 tentacle with your <<bottomstop>><<set $rng to random(1, 100)>>
<<if $analskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your <<bottomstop>></span><<set $bottomgoo += 1>><<set $tentacle9health -= 3>><<bottomejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $anusaction is "anuscooperatetentacle9">><<set $anusaction to 0>><<set $anusactiondefault to "anuscooperatetentacle9">>
<<sex 5>><<analskilluse>>You <<analtext>> push back against the $tentacle9 tentacle invading your <<bottomstop>><<set $rng to random(1, 100)>>
<<if $analskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, flooding your bowels with its warmth.</span><<set $tentacle9health -= 3>><<set $drugged += 3>><<set $anusgoo += 1>><<analejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $anusaction is "anuspullawaytentacle9">><<set $anusaction to 0>><<set $anusactiondefault to "anuspullawaytentacle9">><<brat 1>><span class="teal">You pull away from the $tentacle9 tentacle threatening your <<bottomstop>></span><<tentacle9disable>>
<</if>>
<<if $thighaction is "penisrubtentacle9">><<set $thighaction to 0>><<set $thighactiondefault to "penisrubtentacle9">>
<<submission 3>><<thighskilluse>>You <<thightext>> rub the $tentacle9 tentacle between your thighs.<<set $rng to random(1, 100)>>
<<if $thighskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your tummy.</span><<set $tentacle9health -= 3>><<set $tummygoo += 1>><<tummyejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $thighaction is "vaginarubtentacle9">><<set $thighaction to 0>><<set $thighactiondefault to "vaginarubtentacle9">>
<<submission 3>><<thighskilluse>>You <<thightext>> rub the $tentacle9 tentacle between your thighs.<<set $rng to random(1, 100)>>
<<if $thighskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your tummy.</span><<set $tentacle9health -= 3>><<set $tummygoo += 1>><<tummyejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $bottomaction is "bottomrubtentacle9">><<set $bottomaction to 0>><<set $bottomactiondefault to "bottomrubtentacle9">>
<<submission 3>><<bottomskilluse>>You <<bottomtext>> rub the $tentacle9 tentacle between your cheeks.<<set $rng to random(1, 100)>>
<<if $bottomskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your <<bottomstop>></span><<set $tentacle9health -= 3>><<set $bottomgoo += 1>><<bottomejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $chestaction is "chestrubtentacle9">><<set $chestaction to 0>><<set $chestactiondefault to "chestrubtentacle9">>
<<submission 3>><<chestskilluse>>You <<chesttext>> rub the $tentacle9 tentacle between your <<breastsstop>><<set $rng to random(1, 100)>>
<<if $chestskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your chest.</span><<set $tentacle9health -= 3>><<set $chestgoo += 1>><<chestejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<</nobr>><</widget>>
:: Widgets Combat Tentacle10 [widget]
<<widget "tentacle10">><<nobr>>
<<if $tentacle10health lte 0 and $tentacle10shaft isnot "finished">>
Worn out, the $tentacle10 tentacle retracts from you.
<<tentacle10disable>>
<<set $tentacle10shaft to "finished">>
<<set $tentacle10head to "finished">>
<</if>>
<<if $tentacle10shaft is "tummy">>
The $tentacle10 tentacle <<slithers>> around your tummy,
<</if>>
<<if $tentacle10shaft is "thighs">>
The $tentacle10 tentacle <<slithers>> between your thighs,
<</if>>
<<if $tentacle10shaft is "breasts">>
The $tentacle10 tentacle squeezes your breasts together,
<</if>>
<<if $tentacle10shaft is "chest">>
The $tentacle10 tentacle <<slithers>> around your chest,
<</if>>
<<if $tentacle10shaft is "waist">>
The $tentacle10 tentacle <<slithers>> around your waist,
<</if>>
<<if $tentacle10shaft is "neck">>
The $tentacle10 tentacle <<slithers>> around your neck,
<</if>>
<<if $tentacle10shaft is "shoulders">>
The $tentacle10 tentacle <<slithers>> around your shoulders,
<</if>>
<<if $tentacle10shaft is "leftleg">>
The $tentacle10 tentacle <<slithers>> around your left leg,
<</if>>
<<if $tentacle10shaft is "rightleg">>
The $tentacle10 tentacle <<slithers>> around your right leg,
<</if>>
<<if $tentacle10shaft is "leftarm">>
The $tentacle10 tentacle <<slithers>> around your left arm,
<</if>>
<<if $tentacle10shaft is "rightarm">>
The $tentacle10 tentacle <<slithers>> around your right arm,
<</if>>
<<if $tentacle10head is "leftarm">>
The $tentacle10 tentacle writhes in your left hand.<<neutral 5>>
<</if>>
<<if $tentacle10head is "rightarm">>
The $tentacle10 tentacle writhes in your right hand.<<neutral 5>>
<</if>>
<<if $tentacle10head is "feet">>
The $tentacle10 tentacle writhes between your feet.<<neutral 5>>
<</if>>
<<if $tentacle10head is "leftnipplesuck">>
and up to your <<breastscomma>> where it suckles your left nipple.<<neutral 3>>
<</if>>
<<if $tentacle10head is "rightnipplesuck">>
and up to your <<breastscomma>> where it suckles your right nipple.<<neutral 3>>
<</if>>
<<if $tentacle10head is "leftnipple">>
and continues teasing your left nipple. <span class="purple">The tip of the tentacle opens up, latches on, then begins sucking.</span><<neutral 3>><<set $tentacle10head to "leftnipplesuck">><<set $leftnipple to "tentaclesuck">>
<</if>>
<<if $tentacle10head is "rightnipple">>
and continues teasing your right nipple. <span class="purple">The tip of the tentacle opens up, latches on, then begins sucking.</span><<neutral 3>><<set $tentacle10head to "rightnipplesuck">><<set $rightnipple to "tentaclesuck">>
<</if>>
<<if $tentacle10head is "chest">>
<<if $chestuse is "squeezed">>
then up between your <<breastscomma>> rubbing itself between them.<<neutral 2>>
<<else>>
moves away from your <<breasts>><<set $tentacle10head to 0>><<set $breastuse to 0>>
<</if>>
<</if>>
<<if $tentacle10head is "mouthdeep">>
and up into your mouth where it spurts a sweet fluid down your throat at the apex of each thrust.<<set $purity -= 1>><<internalejac>><<sex 5>><<set $drugged += 3>><<set $mouthgoo += 1>><<set $tentacle10health -= 1>>
<</if>>
<<if $tentacle10head is "mouth">>
and continues thrusting into your mouth.<span class="pink"> The tip opens and begins oozing a sweet liquid.</span><<set $purity -= 1>><<internalejac>><<set $mouthstate to "tentacledeep">><<set $tentacle10head to "mouthdeep">><<sex 5>><<oralejacstat>><<ejacstat>>
<</if>>
<<if $tentacle10head is "mouthimminent">>
<<if $oralvirginity is 1>>
<span class="pink"> and thrusts between your lips,</span><span class="red"> penetrating your mouth for the first time.</span><<set $oralvirginity to 0>><<violence 5>>
<<else>>
<span class="pink"> and thrusts between your lips.</span>
<</if>>
<<set $mouthstate to "tentacle">><<set $tentacle10head to "mouth">><<sex 5>><<raped>><<oralstat>>
<</if>>
<<if $tentacle10head is "mouthentrance">>
<span class="purple"> and presses against your lips.</span><<set $mouthstate to "tentacleimminent">><<set $tentacle10head to "mouthimminent">><<neutral 4>>
<</if>>
<<if $tentacle10head is "vaginadeep">>
and <<slithers>> into your <<pussy>> where it pumps a viscous fluid at the apex of each thrust.<<set $purity -= 1>><<internalejac>><<sex 5>><<set $drugged += 3>><<set $vaginagoo += 1>><<set $tentacle10health -= 1>>
<</if>>
<<if $tentacle10head is "vagina">>
and continues thrusting into your <<pussystop>><span class="pink"> The tip opens and begins oozing a viscous liquid.</span><<set $purity -= 1>><<internalejac>><<set $vaginastate to "tentacledeep">><<set $tentacle10head to "vaginadeep">><<sex 5>><<vaginalejacstat>><<ejacstat>>
<</if>>
<<if $tentacle10head is "vaginaimminent">>
<<if $vaginalvirginity is 1>>
<span class="pink"> and thrusts into your <<pussycomma>></span><span class="red"> tearing your hymen and forever robbing you of your purity.</span><<set $vaginalvirginity to 0>><<violence 100>>
<<else>>
<span class="pink"> and thrusts into your <<pussystop>></span>
<</if>>
<<set $vaginastate to "tentacle">><<set $tentacle10head to "vagina">><<sex 5>><<raped>><<vaginaraped>><<vaginalstat>><<violence 1>>
<</if>>
<<if $tentacle10head is "vaginaentrance">>
<<if $undertype isnot "chastity">>
<span class="purple"> and presses against your <<pussycomma>> about to penetrate.</span><<set $vaginastate to "tentacleimminent">><<set $tentacle10head to "vaginaimminent">><<neutral 4>>
<<else>>
and tries to find a way inside. Failing, it lashes at the metal.<<set $underintegrity -= 10>><<violence 1>>
<</if>>
<</if>>
<<if $tentacle10head is "penisdeep">>
and continues thrusting against your <<peniscomma>> caressing and kneading your length.<<sex 5>>
<</if>>
<<if $tentacle10head is "penis">>
and continues thrusting against your <<penisstop>><span class="pink"> It sucks and kneads your length, trying to milk you of your cum.</span><<set $penisstate to "tentacledeep">><<set $tentacle10head to "penisdeep">><<sex 5>>
<</if>>
<<if $tentacle10head is "penisimminent">>
<<if $penilevirginity is 1>>
<span class="pink"> and thrusts against your <<peniscomma>> swallowing you to the base and </span><span class="red"> tearing the membrane between your glans and foreskin, forever robbing you of your purity.</span><<set $penilevirginity to 0>><<violence 100>>
<<else>>
<span class="pink"> and thrusts against your <<peniscomma>> swallowing you to the base.</span>
<</if>>
<<set $penisstate to "tentacle">><<set $tentacle10head to "penis">><<sex 5>><<raped>><<penisraped>><<penilestat>><<violence 1>>
<</if>>
<<if $tentacle10head is "penisentrance">>
<<if $undertype isnot "chastity">>
<span class="purple"> and <<slithers>> over to your <<penisstop>> The tip opens and presses against your glans, about to envelop you.</span><<set $penisstate to "tentacleimminent">><<set $tentacle10head to "penisimminent">><<neutral 4>>
<<else>>
and tries to find a way inside. Failing, it lashes at the metal.<<set $underintegrity -= 10>><<violence 1>>
<</if>>
<</if>>
<<if $tentacle10head is "anusdeep">>
and <<slithers>> into your <<bottom>> where it pumps a viscous fluid at the apex of each thrust.<<set $purity -= 1>><<internalejac>><<sex 5>><<set $drugged += 3>><<set $anusgoo += 1>><<set $tentacle10health -= 1>>
<</if>>
<<if $tentacle10head is "anus">>
and continues thrusting into your <<bottomstop>><span class="pink"> The tip opens and begins oozing a viscous liquid.</span><<set $purity -= 1>><<internalejac>><<set $anusstate to "tentacledeep">><<set $tentacle10head to "anusdeep">><<sex 5>><<analejacstat>><<ejacstat>>
<</if>>
<<if $tentacle10head is "anusimminent">>
<<if $analvirginity is 1>>
<span class="pink"> and thrusts into your <<bottomcomma>></span><span class="red"> violating you in a way you hadn't conceived of.</span><<set $analvirginity to 0>><<violence 100>>
<<else>>
<span class="pink"> and thrusts into your <<bottomstop>></span>
<</if>>
<<set $anusstate to "tentacle">><<set $tentacle10head to "anus">><<sex 5>><<raped>><<analstat>><<violence 1>>
<</if>>
<<if $tentacle10head is "anusentrance">>
<<if $analshield is 0>>
<span class="purple"> and presses against your <<bottomcomma>> about to penetrate.</span><<set $anusstate to "tentacleimminent">><<set $tentacle10head to "anusimminent">><<neutral 4>>
<<else>>
and tries to find a way inside. Failing, it lashes at the device.<<set $underintegrity -= 10>><<violence 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $tentacle10head is "vaginarub">>
<<if $rng gte 21>>
and between your thighs where it <<slithers>> against your <<pussycomma>> pressing against your clit.<<sex 3>>
<<else>>
and between your thighs <span class="blue">where it <<slithers>> toward your <<pussystop>></span><<neutral 3>><<set $vaginause to "tentacle">><<set $vaginastate to "tentacleentrance">><<set $tentacle10head to "vaginaentrance">><<set $thighuse to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $tentacle10head is "penisrub">>
<<if $rng gte 21>>
and between your thighs where it <<slithers>> against your <<peniscomma>> coiling around it.<<sex 3>>
<<else>>
and between your thighs <span class="blue">where the tip opens and it <<slithers>> toward your <<penisstop>></span><<neutral 3>><<set $penisuse to "tentacle">><<set $penisstate to "tentacleentrance">><<set $tentacle10head to "penisentrance">><<set $thighuse to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $tentacle10head is "bottomrub">>
<<if $rng gte 21>>
and between your <<bottom>> cheeks where it <<slithers>> against your back.<<sex 3>>
<<else>>
and between your <<bottom>> cheeks, <span class="blue"> toward your anus.</span><<neutral 3>><<set $anususe to "tentacle">><<set $anusstate to "tentacleentrance">><<set $tentacle10head to "anusentrance">><<set $bottomuse to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $tentacle10head is 0 and $tentacle10shaft isnot 0>>
<<if $rng lte 10>>
<<if $chestuse is "squeezed" and $breastuse is 0>>
<<upperslither>><span class="blue">and up between your squeezed <<breastsstop>></span><<set $tentacle10head to "chest">><<neutral 2>><<set $breastuse to "tentacle">><<cheststat>>
<<else>>
<<tentacle10default>>
<</if>>
<<elseif $rng lte 20>>
<<if $leftnipple is 0>>
<<upperslither>> <span class="blue">and teases your left nipple.</span><<neutral 2>><<set $tentacle10head to "leftnipple">><<set $leftnipple to "tentacle">>
<<else>>
<<tentacle10default>>
<</if>>
<<elseif $rng lte 30>>
<<if $rightnipple is 0>>
<<upperslither>> <span class="blue">and teases your right nipple.</span><<neutral 2>><<set $tentacle10head to "rightnipple">><<set $rightnipple to "tentacle">>
<<else>>
<<tentacle10default>>
<</if>>
<<elseif $rng lte 40>>
<<if $mouthuse is 0>>
<<upperslither>> <span class="blue">and up toward your mouth.</span><<neutral 2>><<set $mouthuse to "tentacle">><<set $mouthstate to "tentacleentrance">><<set $tentacle10head to "mouthentrance">>
<<else>>
<<tentacle10default>>
<</if>>
<<elseif $rng lte 50>>
<<if $anususe is 0 and $analdisable is "f">>
<<underslither>> <span class="blue">and <<slithers>> toward your <<bottomstop>></span><<neutral 2>><<set $anususe to "tentacle">><<set $anusstate to "tentacleentrance">><<set $tentacle10head to "anusentrance">>
<<else>>
<<tentacle10default>>
<</if>>
<<elseif $rng lte 60>>
<<if $vaginaexist is 1 and $vaginause is 0>>
<<underslither>> <span class="blue">and <<slithers>> toward your <<pussystop>></span><<neutral 2>><<set $vaginause to "tentacle">><<set $vaginastate to "tentacleentrance">><<set $tentacle10head to "vaginaentrance">>
<<else>>
<<tentacle10default>>
<</if>>
<<elseif $rng lte 70>>
<<if $penisexist is 1 and $penisuse is 0>>
<<underslither>> <span class="blue">and <<slithers>> toward your <<penisstop>></span><<neutral 2>><<set $penisuse to "tentacle">><<set $penisstate to "tentacleentrance">><<set $tentacle10head to "penisentrance">>
<<else>>
<<tentacle10default>>
<</if>>
<<elseif $rng lte 80>>
<<if $thighuse is 0>>
<<if $penisexist is 1 and $penisuse is 0>>
<<underslither>> <span class="blue">and <<slithers>> between your thighs and against your tummy and <<penisstop>></span><<set $penisuse to "tentaclerub">><<set $thighuse to "tentaclerub">><<set $tentacle10head to "penisrub">><<sex 3>><<thighstat>>
<<elseif $vaginaexist is 1 and $vaginause is 0>>
<<underslither>> <span class="blue">and <<slithers>> between your thighs and against your tummy and <<pussystop>></span><<set $vaginause to "tentaclerub">><<set $thighuse to "tentaclerub">><<set $tentacle10head to "vaginarub">><<sex 3>><<thighstat>>
<<else>>
<<tentacle10default>>
<</if>>
<<else>>
<<tentacle10default>>
<</if>>
<<elseif $rng lte 90>>
<<if $bottomuse is 0 and $anususe is 0 and $analdisable is "f">>
<<underslither>> <span class="blue">and <<slithers>> between your <<bottom>> cheeks and against your back.</span><<set $bottomuse to "tentaclerub">><<set $anususe to "tentaclerub">><<set $tentacle10head to "bottomrub">><<sex 1>><<bottomstat>>
<<else>>
<<tentacle10default>>
<</if>>
<<else>>
<<tentacle10default>>
<</if>>
<<elseif $tentacle10head is 0 and $tentacle10shaft is 0>>
<<if $rng lte 10>>
<<if $position isnot "wall">>
The $tentacle10 tentacle winds around your tummy.<<neutral 1>><<set $tentacle10shaft to "tummy">>
<<else>>
The $tentacle10 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<elseif $rng lte 20>>
The $tentacle10 tentacle <<slithers>> between your thighs.<<neutral 1>><<set $tentacle10shaft to "thighs">>
<<elseif $rng lte 30>>
<<if $position isnot "wall">>
<<if $breastsize gte 2 and $chestuse is 0>>
The $tentacle10 tentacle <<slithers>> around your <<breastscomma>> <span class="blue">squeezing them together.</span><<neutral 1>><<set $tentacle10shaft to "breasts">><<set $chestuse to "squeezed">>
<<else>>
The $tentacle10 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<else>>
The $tentacle10 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<elseif $rng lte 40>>
<<if $position isnot "wall">>
The $tentacle10 tentacle winds its way around your chest, beneath your <<breastsstop>><<neutral 1>><<set $tentacle10shaft to "chest">>
<<else>>
The $tentacle10 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<elseif $rng lte 50>>
The $tentacle10 tentacle winds its way around your waist.<<neutral 1>><<set $tentacle10shaft to "waist">>
<<elseif $rng lte 60>>
<<if $position isnot "wall">>
<<if $head is 0>>
The $tentacle10 tentacle winds its way around your neck, <span class="blue">restraining your head.</span><<neutral 1>><<set $tentacle10shaft to "neck">><<set $head to "grappled">>
<<else>>
The $tentacle10 tentacle winds its way around your shoulders.<<neutral 1>><<set $tentacle10shaft to "shoulders">>
<</if>>
<<else>>
The $tentacle10 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<elseif $rng lte 70>>
The $tentacle10 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<<elseif $rng lte 80>>
<<if $leftleg is 0>>
The $tentacle10 tentacle winds its way around your left leg, <span class="blue">restraining it.</span><<neutral 1>><<feettentacledisable>><<set $tentacle10shaft to "leftleg">><<set $leftleg to "grappled">>
<<else>>
The $tentacle10 tentacle tickles your feet.<<neutral 1>>
<</if>>
<<elseif $rng lte 85>>
<<if $rightleg is 0>>
The $tentacle10 tentacle winds its way around your right leg, <span class="blue">restraining it.</span><<neutral 1>><<feettentacledisable>><<set $tentacle10shaft to "rightleg">><<set $rightleg to "grappled">>
<<else>>
The $tentacle10 tentacle tickles your feet.<<neutral 1>>
<</if>>
<<elseif $rng lte 90>>
<<if $leftarm is 0>>
The $tentacle10 tentacle winds its way around your left arm, <span class="blue">restraining it.</span><<neutral 1>><<leftarmtentacledisable>><<set $tentacle10shaft to "leftarm">><<set $leftarm to "grappled">><<set $leftarmstate to 0>>
<<else>>
The $tentacle10 tentacle tickles your armpit.<<neutral 1>>
<</if>>
<<elseif $rng lte 95>>
<<if $rightarm is 0>>
The $tentacle10 tentacle winds its way around your right arm, <span class="blue">restraining it.</span><<rightarmtentacledisable>><<neutral 1>><<set $tentacle10shaft to "rightarm">><<set $rightarm to "grappled">><<set $rightarmstate to 0>>
<<else>>
The $tentacle10 tentacle tickles your armpit.<<neutral 1>>
<</if>>
<<elseif $rng lte 100>>
The $tentacle10 tentacle <<slithers>> against your <<bottomstop>><<neutral 1>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "tentacle10default">><<nobr>>
<<set $rng to random(1, 100)>>
<<if $rng gte 90>>
then squirts a warm fluid over your neck.<<neutral 1>><<set $neckgoo += 1>><<set $tentacle10health -= 1>><<neckejacstat>><<ejacstat>>
<<elseif $rng gte 80>>
then squirts a warm fluid over your right arm.<<neutral 1>><<set $rightarmgoo += 1>><<set $tentacle10health -= 1>><<handejacstat>><<ejacstat>>
<<elseif $rng gte 70>>
then squirts a warm fluid over your left arm.<<neutral 1>><<set $leftarmgoo += 1>><<set $tentacle10health -= 1>><<handejacstat>><<ejacstat>>
<<elseif $rng gte 60>>
then squirts a warm fluid over your thighs.<<neutral 1>><<set $thighgoo += 1>><<set $tentacle10health -= 1>><<thighejacstat>><<ejacstat>>
<<elseif $rng gte 50>>
then squirts a warm fluid over your <<bottomstop>><<neutral 1>><<set $bottomgoo += 1>><<set $tentacle10health -= 1>><<bottomejacstat>><<ejacstat>>
<<elseif $rng gte 40>>
then squirts a warm fluid over your tummy.<<neutral 1>><<set $tummygoo += 1>><<set $tentacle10health -= 1>><<tummyejacstat>><<ejacstat>>
<<elseif $rng gte 30>>
then squirts a warm fluid over your chest.<<neutral 1>><<set $chestgoo += 1>><<set $tentacle10health -= 1>><<chestejacstat>><<ejacstat>>
<<elseif $rng gte 20>>
then squirts a warm fluid over your face.<<neutral 1>><<set $facegoo += 1>><<set $tentacle10health -= 1>><<faceejacstat>><<ejacstat>>
<<elseif $rng gte 10>>
then squirts a warm fluid over your hair.<<neutral 1>><<set $hairgoo += 1>><<set $tentacle10health -= 1>><<hairejacstat>><<ejacstat>>
<<else>>
then squirts a warm fluid over your feet.<<neutral 1>><<set $feetgoo += 1>><<set $tentacle10health -= 1>><<feetejacstat>><<ejacstat>>
<</if>>
<</nobr>><</widget>>
<<widget "tentacle10disable">><<nobr>>
<<if $tentacle10head is "feet">>
<<set $leftleg to 0>>
<<set $rightleg to 0>>
<<set $feetstate to 0>>
<</if>>
<<if $tentacle10head is "leftarm">>
<<set $leftarm to 0>>
<<set $leftarmstate to 0>>
<</if>>
<<if $tentacle10head is "rightarm">>
<<set $rightarm to 0>>
<<set $rightarmstate to 0>>
<</if>>
<<if $tentacle10head is "leftnipplesuck">>
<<set $leftnipple to 0>>
<</if>>
<<if $tentacle10head is "rightnipplesuck">>
<<set $rightnipple to 0>>
<</if>>
<<if $tentacle10head is "leftnipple">>
<<set $leftnipple to 0>>
<</if>>
<<if $tentacle10head is "rightnipple">>
<<set $rightnipple to 0>>
<</if>>
<<if $tentacle10head is "chest">>
<<set $chestuse to 0>>
<</if>>
<<if $tentacle10head is "mouthentrance">>
<<set $mouthuse to 0>>
<<set $mouthstate to 0>>
<</if>>
<<if $tentacle10head is "mouthimminent">>
<<set $mouthuse to 0>>
<<set $mouthstate to 0>>
<</if>>
<<if $tentacle10head is "mouth">>
<<set $mouthuse to 0>>
<<set $mouthstate to 0>>
<</if>>
<<if $tentacle10head is "mouthdeep">>
<<set $mouthuse to 0>>
<<set $mouthstate to 0>>
<</if>>
<<if $tentacle10head is "anusentrance">>
<<set $anususe to 0>>
<<set $anusstate to 0>>
<</if>>
<<if $tentacle10head is "anusimminent">>
<<set $anususe to 0>>
<<set $anusstate to 0>>
<</if>>
<<if $tentacle10head is "anus">>
<<set $anususe to 0>>
<<set $anusstate to 0>>
<</if>>
<<if $tentacle10head is "anusdeep">>
<<set $anususe to 0>>
<<set $anusstate to 0>>
<</if>>
<<if $tentacle10head is "vaginaentrance">>
<<set $vaginause to 0>>
<<set $vaginastate to 0>>
<</if>>
<<if $tentacle10head is "vaginaimminent">>
<<set $vaginause to 0>>
<<set $vaginastate to 0>>
<</if>>
<<if $tentacle10head is "vagina">>
<<set $vaginause to 0>>
<<set $vaginastate to 0>>
<</if>>
<<if $tentacle10head is "vaginadeep">>
<<set $vaginause to 0>>
<<set $vaginastate to 0>>
<</if>>
<<if $tentacle10head is "penisentrance">>
<<set $penisuse to 0>>
<<set $penisstate to 0>>
<</if>>
<<if $tentacle10head is "penisimminent">>
<<set $penisuse to 0>>
<<set $penisstate to 0>>
<</if>>
<<if $tentacle10head is "penis">>
<<set $penisuse to 0>>
<<set $penisstate to 0>>
<</if>>
<<if $tentacle10head is "penisdeep">>
<<set $penisuse to 0>>
<<set $penisstate to 0>>
<</if>>
<<if $tentacle10head is "vaginarub">>
<<set $vaginause to 0>>
<<set $thighuse to 0>>
<</if>>
<<if $tentacle10head is "penisrub">>
<<set $penisuse to 0>>
<<set $thighuse to 0>>
<</if>>
<<if $tentacle10head is "bottomrub">>
<<set $anususe to 0>>
<<set $bottomuse to 0>>
<</if>>
<<if $tentacle10shaft is "breasts">>
<<set $chestuse to 0>>
<</if>>
<<if $tentacle10shaft is "neck" and $head isnot "bound">>
<<set $head to 0>>
<</if>>
<<if $tentacle10shaft is "leftleg" and $leftleg isnot "bound">>
<<set $leftleg to 0>>
<</if>>
<<if $tentacle10shaft is "rightleg" and $rightleg isnot "bound">>
<<set $rightleg to 0>>
<</if>>
<<if $tentacle10shaft is "leftarm" and $leftarm isnot "bound">>
<<set $leftarm to 0>>
<</if>>
<<if $tentacle10shaft is "rightarm" and $rightarm isnot "bound">>
<<set $rightarm to 0>>
<</if>>
<<if $tentacle10head is "chest">>
<<set $breastuse to 0>>
<</if>>
<<set $tentacle10shaft to 0>>
<<set $tentacle10head to 0>>
<</nobr>><</widget>>
<<widget "actionstentacle10lefthand">><<nobr>>
<<if $leftarm is 0 and $tentacle10shaft isnot "finished">>
<<if $leftactiondefault is "lefthittentacle10">>
| <label><span class="def">Strike the $tentacle10 tentacle</span> <<radiobutton "$leftaction" "lefthittentacle10" checked>></label>
<<else>>
| <label><span class="def">Strike the $tentacle10 tentacle</span> <<radiobutton "$leftaction" "lefthittentacle10">></label>
<</if>>
<<if $leftactiondefault is "leftgrabtentacle10">>
| <label><span class="sub">Grab the $tentacle10 tentacle</span> <<radiobutton "$leftaction" "leftgrabtentacle10" checked>></label>
<<else>>
| <label><span class="sub">Grab the $tentacle10 tentacle</span> <<radiobutton "$leftaction" "leftgrabtentacle10">></label>
<</if>>
<<elseif $leftarm is "tentacle10">>You hold the $tentacle10 tentacle in your left hand.<br>
<<if $leftactiondefault is "leftrubtentacle10">>
| <label><span class="sub">Milk it</span> <<radiobutton "$leftaction" "leftrubtentacle10" checked>></label>
<<else>>
| <label><span class="sub">Milk it</span> <<radiobutton "$leftaction" "leftrubtentacle10">></label>
<</if>>
<<if $leftactiondefault is "leftstoptentacle10">>
| <label><span class="neutral">Let go</span> <<radiobutton "$leftaction" "leftstoptentacle10" checked>></label>
<<else>>
| <label><span class="neutral">Let go</span> <<radiobutton "$leftaction" "leftstoptentacle10">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle10righthand">><<nobr>>
<<if $rightarm is 0 and $tentacle10shaft isnot "finished">>
<<if $rightactiondefault is "righthittentacle10">>
| <label><span class="def">Strike the $tentacle10 tentacle</span> <<radiobutton "$rightaction" "righthittentacle10" checked>></label>
<<else>>
| <label><span class="def">Strike the $tentacle10 tentacle</span> <<radiobutton "$rightaction" "righthittentacle10">></label>
<</if>>
<<if $rightactiondefault is "rightgrabtentacle10">>
| <label><span class="sub">Grab the $tentacle10 tentacle</span> <<radiobutton "$rightaction" "rightgrabtentacle10" checked>></label>
<<else>>
| <label><span class="sub">Grab the $tentacle10 tentacle</span> <<radiobutton "$rightaction" "rightgrabtentacle10">></label>
<</if>>
<<elseif $rightarm is "tentacle10">>You hold the $tentacle10 tentacle in your right hand.<br>
<<if $rightactiondefault is "rightrubtentacle10">>
| <label><span class="sub">Milk it</span> <<radiobutton "$rightaction" "rightrubtentacle10" checked>></label>
<<else>>
| <label><span class="sub">Milk it</span> <<radiobutton "$rightaction" "rightrubtentacle10">></label>
<</if>>
<<if $rightactiondefault is "rightstoptentacle10">>
| <label><span class="neutral">Let go</span> <<radiobutton "$rightaction" "rightstoptentacle10" checked>></label>
<<else>>
| <label><span class="neutral">Let go</span> <<radiobutton "$rightaction" "rightstoptentacle10">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle10legs">><<nobr>>
<<if $leftleg is 0 and $rightleg is 0 and $tentacle10shaft isnot "finished">>
<<if $feetactiondefault is "feethittentacle10">>
| <label><span class="def">Kick the $tentacle10 tentacle</span> <<radiobutton "$feetaction" "feethittentacle10" checked>></label>
<<else>>
| <label><span class="def">Kick the $tentacle10 tentacle</span> <<radiobutton "$feetaction" "feethittentacle10">></label>
<</if>>
<<if $feetactiondefault is "feetgrabtentacle10">>
| <label><span class="sub">Grab the $tentacle10 tentacle</span> <<radiobutton "$feetaction" "feetgrabtentacle10" checked>></label>
<<else>>
| <label><span class="sub">Grab the $tentacle10 tentacle</span> <<radiobutton "$feetaction" "feetgrabtentacle10">></label>
<</if>>
<<elseif $leftleg is 0 and $tentacle10shaft isnot "finished">>
<<if $feetactiondefault is "feethittentacle10">>
| <label><span class="def">Kick the $tentacle10 tentacle</span> <<radiobutton "$feetaction" "feethittentacle10" checked>></label>
<<else>>
| <label><span class="def">Kick the $tentacle10 tentacle</span> <<radiobutton "$feetaction" "feethittentacle10">></label>
<</if>>
<<elseif $rightleg is 0 and $tentacle10shaft isnot "finished">>
<<if $feetactiondefault is "feethittentacle10">>
| <label><span class="def">Kick the $tentacle10 tentacle</span> <<radiobutton "$feetaction" "feethittentacle10" checked>></label>
<<else>>
| <label><span class="def">Kick the $tentacle10 tentacle</span> <<radiobutton "$feetaction" "feethittentacle10">></label>
<</if>>
<<elseif $leftleg is "tentacle10">>You hold the $tentacle10 tentacle between your feet.<br>
<<if $feetactiondefault is "feetrubtentacle10">>
| <label><span class="sub">Milk it</span> <<radiobutton "$feetaction" "feetrubtentacle10" checked>></label>
<<else>>
| <label><span class="sub">Milk it</span> <<radiobutton "$feetaction" "feetrubtentacle10">></label>
<</if>>
<<if $feetactiondefault is "feetstoptentacle10">>
| <label><span class="neutral">Let go</span> <<radiobutton "$feetaction" "feetstoptentacle10" checked>></label>
<<else>>
| <label><span class="neutral">Let go</span> <<radiobutton "$feetaction" "feetstoptentacle10">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle10mouth">><<nobr>>
<<if $tentacle10head is "mouthentrance">>
<<if $mouthactiondefault is "mouthlicktentacle10">>
| <label><span class="sub">Lick it</span> <<radiobutton "$mouthaction" "mouthlicktentacle10" checked>></label>
<<else>>
| <label><span class="sub">Lick it</span> <<radiobutton "$mouthaction" "mouthlicktentacle10">></label>
<</if>>
<<if $head is "grappled">>
<<else>>
<<if $mouthactiondefault is "mouthpullawaytentacle10">>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "mouthpullawaytentacle10" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "mouthpullawaytentacle10">></label>
<</if>>
<</if>>
<<elseif $tentacle10head is "mouthimminent">>
<<if $mouthactiondefault is "mouthkisstentacle10">>
| <label><span class="sub">Kiss it</span> <<radiobutton "$mouthaction" "mouthkisstentacle10" checked>></label>
<<else>>
| <label><span class="sub">Kiss it</span> <<radiobutton "$mouthaction" "mouthkisstentacle10">></label>
<</if>>
<<if $head is "grappled">>
<<else>>
<<if $mouthactiondefault is "mouthpullawaytentacle10">>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "mouthpullawaytentacle10" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "mouthpullawaytentacle10">></label>
<</if>>
<</if>>
<<elseif $tentacle10head is "mouth">>
<<if $mouthactiondefault is "mouthcooperatetentacle10">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$mouthaction" "mouthcooperatetentacle10" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$mouthaction" "mouthcooperatetentacle10">></label>
<</if>>
<<if $mouthactiondefault is "mouthbitetentacle10">>
| <label><span class="def">Bite</span> <<radiobutton "$mouthaction" "mouthbitetentacle10" checked>></label>
<<else>>
| <label><span class="def">Bite</span> <<radiobutton "$mouthaction" "mouthbitetentacle10">></label>
<</if>>
<<elseif $tentacle10head is "mouthdeep">>
<<if $mouthactiondefault is "mouthcooperatetentacle10">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$mouthaction" "mouthcooperatetentacle10" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$mouthaction" "mouthcooperatetentacle10">></label>
<</if>>
<<if $mouthactiondefault is "mouthbitetentacle10">>
| <label><span class="def">Bite</span> <<radiobutton "$mouthaction" "mouthbitetentacle10" checked>></label>
<<else>>
| <label><span class="def">Bite</span> <<radiobutton "$mouthaction" "mouthbitetentacle10">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle10vagina">><<nobr>>
<<if $tentacle10head is "vaginaentrance">>
<<if $vaginaactiondefault is "vaginarubtentacle10">>
| <label><span class="sub">Rub</span> <<radiobutton "$vaginaaction" "vaginarubtentacle10" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$vaginaaction" "vaginarubtentacle10">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $vaginaactiondefault is "vaginapullawaytentacle10">>
| <label><span class="brat">Pull away</span> <<radiobutton "$vaginaaction" "vaginapullawaytentacle10" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$vaginaaction" "vaginapullawaytentacle10">></label>
<</if>>
<</if>>
<<elseif $tentacle10head is "vaginaimminent">>
<<if $vaginaactiondefault is "vaginarubtentacle10">>
| <label><span class="sub">Rub</span> <<radiobutton "$vaginaaction" "vaginarubtentacle10" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$vaginaaction" "vaginarubtentacle10">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $vaginaactiondefault is "vaginapullawaytentacle10">>
| <label><span class="brat">Pull away</span> <<radiobutton "$vaginaaction" "vaginapullawaytentacle10" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$vaginaaction" "vaginapullawaytentacle10">></label>
<</if>>
<</if>>
<<elseif $tentacle10head is "vagina">>
<<if $vaginaactiondefault is "vaginacooperatetentacle10">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$vaginaaction" "vaginacooperatetentacle10" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$vaginaaction" "vaginacooperatetentacle10">></label>
<</if>>
<<elseif $tentacle10head is "vaginadeep">>
<<if $vaginaactiondefault is "vaginacooperatetentacle10">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$vaginaaction" "vaginacooperatetentacle10" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$vaginaaction" "vaginacooperatetentacle10">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle10penis">><<nobr>>
<<if $tentacle10head is "penisentrance">>
<<if $penisactiondefault is "penisrubtentacle10">>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "penisrubtentacle10" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "penisrubtentacle10">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $penisactiondefault is "penispullawaytentacle10">>
| <label><span class="brat">Pull away</span> <<radiobutton "$penisaction" "penispullawaytentacle10" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$penisaction" "penispullawaytentacle10">></label>
<</if>>
<</if>>
<<elseif $tentacle10head is "penisimminent">>
<<if $penisactiondefault is "penisrubtentacle10">>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "penisrubtentacle10" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "penisrubtentacle10">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $penisactiondefault is "penispullawaytentacle10">>
| <label><span class="brat">Pull away</span> <<radiobutton "$penisaction" "penispullawaytentacle10" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$penisaction" "penispullawaytentacle10">></label>
<</if>>
<</if>>
<<elseif $tentacle10head is "penis">>
<<if $penisactiondefault is "peniscooperatetentacle10">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$penisaction" "peniscooperatetentacle10" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$penisaction" "peniscooperatetentacle10">></label>
<</if>>
<<elseif $tentacle10head is "penisdeep">>
<<if $penisactiondefault is "peniscooperatetentacle10">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$penisaction" "peniscooperatetentacle10" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$penisaction" "peniscooperatetentacle10">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle10anus">><<nobr>>
<<if $tentacle10head is "anusentrance">>
<<if $anusactiondefault is "anusrubtentacle10">>
| <label><span class="sub">Rub</span> <<radiobutton "$anusaction" "anusrubtentacle10" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$anusaction" "anusrubtentacle10">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $anusactiondefault is "anuspullawaytentacle10">>
| <label><span class="brat">Pull away</span> <<radiobutton "$anusaction" "anuspullawaytentacle10" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$anusaction" "anuspullawaytentacle10">></label>
<</if>>
<</if>>
<<elseif $tentacle10head is "anusimminent">>
<<if $anusactiondefault is "anusrubtentacle10">>
| <label><span class="sub">Rub</span> <<radiobutton "$anusaction" "anusrubtentacle10" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$anusaction" "anusrubtentacle10">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $anusactiondefault is "anuspullawaytentacle10">>
| <label><span class="brat">Pull away</span> <<radiobutton "$anusaction" "anuspullawaytentacle10" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$anusaction" "anuspullawaytentacle10">></label>
<</if>>
<</if>>
<<elseif $tentacle10head is "anus">>
<<if $anusactiondefault is "anuscooperatetentacle10">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$anusaction" "anuscooperatetentacle10" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$anusaction" "anuscooperatetentacle10">></label>
<</if>>
<<elseif $tentacle10head is "anusdeep">>
<<if $anusactiondefault is "anuscooperatetentacle10">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$anusaction" "anuscooperatetentacle10" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$anusaction" "anuscooperatetentacle10">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle10thighs">><<nobr>>
<<if $tentacle10head is "penisrub">>
<<if $thighactiondefault is "penisrubtentacle10">>
| <label><span class="sub">Rub</span> <<radiobutton "$thighaction" "penisrubtentacle10" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$thighaction" "penisrubtentacle10">></label>
<</if>>
<<elseif $tentacle10head is "vaginarub">>
<<if $thighactiondefault is "vaginarubtentacle10">>
| <label><span class="sub">Rub</span> <<radiobutton "$thighaction" "vaginarubtentacle10" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$thighaction" "vaginarubtentacle10">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle10bottom">><<nobr>>
<<if $tentacle10head is "bottomrub">>
<<if $bottomactiondefault is "bottomrubtentacle10">>
| <label><span class="sub">Rub</span> <<radiobutton "$bottomaction" "bottomrubtentacle10" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$bottomaction" "bottomrubtentacle10">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle10chest">><<nobr>>
<<if $tentacle10head is "chest">>
<<if $chestactiondefault is "chestrubtentacle10">>
| <label><span class="sub">Rub</span> <<radiobutton "$chestaction" "chestrubtentacle10" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$chestaction" "chestrubtentacle10">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "effectstentacle10">><<nobr>>
<<if $leftaction is "lefthittentacle10">><<set $leftaction to 0>><<set $leftactiondefault to "lefthittentacle10">>You strike the $tentacle10 tentacle with your left hand and it reels away from you.<<defiance 2>><<set $speechhit to 1>><<tentacle10disable>><<set $attackstat += 1>><<set $tentacle10health -= 1>>
<<if $rng lte ($physique / 200)>>
<<set $tentacle10health -= 1>>
<</if>>
<</if>>
<<if $rightaction is "righthittentacle10">><<set $rightaction to 0>><<set $rightactiondefault to "righthittentacle10">>You strike the $tentacle10 tentacle with your right hand and it reels away from you.<<defiance 2>><<set $speechhit to 1>><<tentacle10disable>><<set $attackstat += 1>><<set $tentacle10health -= 1>>
<<if $rng lte ($physique / 200)>>
<<set $tentacle10health -= 1>>
<</if>>
<</if>>
<<if $leftaction is "leftgrabtentacle10">><<set $leftaction to 0>><<set $leftactiondefault to "leftrubtentacle10">><<submission 1>><<handstat>><span class="lblue">You <<handtext>> grab the $tentacle10 tentacle with your left hand.</span><<tentacle10disable>><<set $leftarm to "tentacle10">><<set $tentacle10head to "leftarm">><<handstat>><<set $leftarmstate to "tentacle">>
<</if>>
<<if $rightaction is "rightgrabtentacle10">><<set $rightaction to 0>><<set $rightactiondefault to "rightrubtentacle10">><<submission 1>><<handstat>><span class="lblue">You <<handtext>> grab the $tentacle10 tentacle with your right hand.</span><<tentacle10disable>><<set $rightarm to "tentacle10">><<set $tentacle10head to "rightarm">><<handstat>><<set $rightarmstate to "tentacle">>
<</if>>
<<if $leftaction is "leftrubtentacle10">><<set $leftaction to 0>><<set $leftactiondefault to "leftrubtentacle10">><<handskilluse>><<submission 1>>You <<handtext>> squeeze the $tentacle10 tentacle in your left hand and rub up and down its length.<<set $rng to random(1, 100)>>
<<if $handskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $rightarmgoo += 1>><<set $tentacle10health -= 3>><<handejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $rightaction is "rightrubtentacle10">><<set $rightaction to 0>><<set $rightactiondefault to "rightrubtentacle10">><<handskilluse>><<submission 1>>You <<handtext>> squeeze the $tentacle10 tentacle in your right hand and rub up and down its length.<<set $rng to random(1, 100)>>
<<if $handskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $rightarmgoo += 1>><<set $tentacle10health -= 3>><<handejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $leftaction is "leftstoptentacle10">><<set $leftaction to 0>><<set $leftactiondefault to "leftstoptentacle10">>You release the $tentacle10 tentacle from your left hand.<<tentacle10disable>>
<</if>>
<<if $rightaction is "rightstoptentacle10">><<set $rightaction to 0>><<set $rightactiondefault to "rightstoptentacle10">>You release the $tentacle10 tentacle from your right hand.<<tentacle10disable>>
<</if>>
<<if $feetaction is "feethittentacle10">><<set $feetaction to 0>><<set $feetactiondefault to "feethittentacle10">>You kick the $tentacle10 tentacle and it reels away from you.<<defiance 2>><<set $speechhit to 1>><<tentacle10disable>><<set $attackstat += 1>><<set $tentacle10health -= 1>>
<<if $rng lte ($physique / 200)>>
<<set $tentacle10health -= 1>>
<</if>>
<</if>>
<<if $feetaction is "feetgrabtentacle10">><<set $feetaction to 0>><<set $feetactiondefault to "feetrubtentacle10">><<submission 1>><<feetstat>><span class="lblue">You <<feettext>> grab the $tentacle10 tentacle between your feet.</span><<tentacle10disable>><<set $leftleg to "tentacle10">><<set $rightleg to "tentacle10">><<set $tentacle10head to "feet">><<feetstat>><<set $feetstate to "tentacle">>
<</if>>
<<if $feetaction is "feetrubtentacle10">><<set $feetaction to 0>><<set $feetactiondefault to "feetrubtentacle10">><<feetskilluse>><<submission 1>>You <<feettext>> squeeze the $tentacle10 tentacle between your feet and rub up and down its length.<<set $rng to random(1, 100)>>
<<if $feetskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $feetgoo += 1>><<set $tentacle10health -= 3>><<feetejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $feetaction is "feetstoptentacle10">><<set $feetaction to 0>><<set $feetactiondefault to "feetstoptentacle10">>You let go of the $tentacle10 tentacle between your feet.<<tentacle10disable>>
<</if>>
<<if $mouthaction is "mouthlicktentacle10">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthlicktentacle10">>
<<submission 2>><<oralskilluse>>You <<oraltext>> lick the tip of the $tentacle10 tentacle.<<set $rng to random(1, 100)>>
<<if $oralskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your face.</span><<set $facegoo += 1>><<set $tentacle10health -= 3>><<faceejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $mouthaction is "mouthkisstentacle10">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthkisstentacle10">>
<<submission 3>><<oralskilluse>>You <<oraltext>> kiss the tip of the $tentacle10 tentacle.<<set $rng to random(1, 100)>>
<<if $oralskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your face.</span><<set $facegoo += 1>><<set $tentacle10health -= 3>><<faceejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $mouthaction is "mouthcooperatetentacle10">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthcooperatetentacle10">>
<<sex 5>><<oralskilluse>>You <<oraltext>> suck the $tentacle10 tentacle invading your mouth.<<set $rng to random(1, 100)>>
<<if $oralskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip and into your mouth.</span><<set $tentacle10health -= 3>><<set $drugged += 3>><<set $mouthgoo += 1>><<oralejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $mouthaction is "mouthpullawaytentacle10">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthpullawaytentacle10">><<brat 1>><span class="teal">You pull away from the $tentacle10 tentacle threatening your mouth.</span><<tentacle10disable>>
<</if>>
<<if $mouthaction is "mouthbitetentacle10">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthbitetentacle10">><<defiance 5>>You bite down on the $tentacle10 tentacle invading your mouth. <span class="teal">It recoils immediately.</span><<tentacle10disable>><<set $attackstat += 1>><<set $tentacle10health -= 1>>
<<if $rng lte ($physique / 200)>>
<<set $tentacle10health -= 1>>
<</if>>
<</if>>
<<if $vaginaaction is "vaginarubtentacle10">><<set $vaginaaction to 0>><<set $vaginaactiondefault to "vaginarubtentacle10">>
<<submission 2>><<vaginalskilluse>>You <<vaginaltext>> rub the tip of the $tentacle10 tentacle with your <<pussystop>><<set $rng to random(1, 100)>>
<<if $vaginalskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $vaginaoutsidegoo += 1>><<set $tentacle10health -= 3>><<vaginalentranceejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $vaginaaction is "vaginacooperatetentacle10">><<set $vaginaaction to 0>><<set $vaginaactiondefault to "vaginacooperatetentacle10">>
<<sex 5>><<vaginalskilluse>>You <<vaginaltext>> push back against the $tentacle10 tentacle invading your <<pussystop>><<set $rng to random(1, 100)>>
<<if $vaginalskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, flooding your womb with its warmth.</span><<set $tentacle10health -= 3>><<set $drugged += 3>><<set $vaginagoo += 1>><<vaginalejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $vaginaaction is "vaginapullawaytentacle10">><<set $vaginaaction to 0>><<set $vaginaactiondefault to "vaginapullawaytentacle10">><<brat 1>><span class="teal">You pull away from the $tentacle10 tentacle threatening your <<pussystop>></span><<tentacle10disable>>
<</if>>
<<if $penisaction is "penisrubtentacle10">><<set $penisaction to 0>><<set $penisactiondefault to "penisrubtentacle10">>
<<submission 2>><<penileskilluse>>You <<peniletext>> rub the tip of the $tentacle10 tentacle with your <<penisstop>><<set $rng to random(1, 100)>>
<<if $penileskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $penisgoo += 1>><<set $tentacle10health -= 3>><<penileejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $penisaction is "peniscooperatetentacle10">><<set $penisaction to 0>><<set $penisactiondefault to "peniscooperatetentacle10">>
<<sex 5>><<penileskilluse>>You <<peniletext>> push back against the $tentacle10 tentacle engulfing your <<penisstop>><<set $rng to random(1, 100)>>
<<if $penileskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your groin.</span><<set $tentacle10health -= 3>><<set $penisgoo += 1>><<penileejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $penisaction is "penispullawaytentacle10">><<set $penisaction to 0>><<set $penisactiondefault to "penispullawaytentacle10">><<brat 1>><span class="teal">You pull away from the $tentacle10 tentacle threatening your <<penisstop>></span><<tentacle10disable>>
<</if>>
<<if $anusaction is "anusrubtentacle10">><<set $anusaction to 0>><<set $anusactiondefault to "anusrubtentacle10">>
<<submission 2>><<analskilluse>>You <<analtext>> rub the tip of the $tentacle10 tentacle with your <<bottomstop>><<set $rng to random(1, 100)>>
<<if $analskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your <<bottomstop>></span><<set $bottomgoo += 1>><<set $tentacle10health -= 3>><<bottomejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $anusaction is "anuscooperatetentacle10">><<set $anusaction to 0>><<set $anusactiondefault to "anuscooperatetentacle10">>
<<sex 5>><<analskilluse>>You <<analtext>> push back against the $tentacle10 tentacle invading your <<bottomstop>><<set $rng to random(1, 100)>>
<<if $analskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, flooding your bowels with its warmth.</span><<set $tentacle10health -= 3>><<set $drugged += 3>><<set $anusgoo += 1>><<analejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $anusaction is "anuspullawaytentacle10">><<set $anusaction to 0>><<set $anusactiondefault to "anuspullawaytentacle10">><<brat 1>><span class="teal">You pull away from the $tentacle10 tentacle threatening your <<bottomstop>></span><<tentacle10disable>>
<</if>>
<<if $thighaction is "penisrubtentacle10">><<set $thighaction to 0>><<set $thighactiondefault to "penisrubtentacle10">>
<<submission 3>><<thighskilluse>>You <<thightext>> rub the $tentacle10 tentacle between your thighs.<<set $rng to random(1, 100)>>
<<if $thighskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your tummy.</span><<set $tentacle10health -= 3>><<set $tummygoo += 1>><<tummyejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $thighaction is "vaginarubtentacle10">><<set $thighaction to 0>><<set $thighactiondefault to "vaginarubtentacle10">>
<<submission 3>><<thighskilluse>>You <<thightext>> rub the $tentacle10 tentacle between your thighs.<<set $rng to random(1, 100)>>
<<if $thighskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your tummy.</span><<set $tentacle10health -= 3>><<set $tummygoo += 1>><<tummyejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $bottomaction is "bottomrubtentacle10">><<set $bottomaction to 0>><<set $bottomactiondefault to "bottomrubtentacle10">>
<<submission 3>><<bottomskilluse>>You <<bottomtext>> rub the $tentacle10 tentacle between your cheeks.<<set $rng to random(1, 100)>>
<<if $bottomskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your <<bottomstop>></span><<set $tentacle10health -= 3>><<set $bottomgoo += 1>><<bottomejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $chestaction is "chestrubtentacle10">><<set $chestaction to 0>><<set $chestactiondefault to "chestrubtentacle10">>
<<submission 3>><<chestskilluse>>You <<chesttext>> rub the $tentacle10 tentacle between your <<breastsstop>><<set $rng to random(1, 100)>>
<<if $chestskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your chest.</span><<set $tentacle10health -= 3>><<set $chestgoo += 1>><<chestejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<</nobr>><</widget>>
:: Widgets Combat Tentacle11 [widget]
<<widget "tentacle11">><<nobr>>
<<if $tentacle11health lte 0 and $tentacle11shaft isnot "finished">>
Worn out, the $tentacle11 tentacle retracts from you.
<<tentacle11disable>>
<<set $tentacle11shaft to "finished">>
<<set $tentacle11head to "finished">>
<</if>>
<<if $tentacle11shaft is "tummy">>
The $tentacle11 tentacle <<slithers>> around your tummy,
<</if>>
<<if $tentacle11shaft is "thighs">>
The $tentacle11 tentacle <<slithers>> between your thighs,
<</if>>
<<if $tentacle11shaft is "breasts">>
The $tentacle11 tentacle squeezes your breasts together,
<</if>>
<<if $tentacle11shaft is "chest">>
The $tentacle11 tentacle <<slithers>> around your chest,
<</if>>
<<if $tentacle11shaft is "waist">>
The $tentacle11 tentacle <<slithers>> around your waist,
<</if>>
<<if $tentacle11shaft is "neck">>
The $tentacle11 tentacle <<slithers>> around your neck,
<</if>>
<<if $tentacle11shaft is "shoulders">>
The $tentacle11 tentacle <<slithers>> around your shoulders,
<</if>>
<<if $tentacle11shaft is "leftleg">>
The $tentacle11 tentacle <<slithers>> around your left leg,
<</if>>
<<if $tentacle11shaft is "rightleg">>
The $tentacle11 tentacle <<slithers>> around your right leg,
<</if>>
<<if $tentacle11shaft is "leftarm">>
The $tentacle11 tentacle <<slithers>> around your left arm,
<</if>>
<<if $tentacle11shaft is "rightarm">>
The $tentacle11 tentacle <<slithers>> around your right arm,
<</if>>
<<if $tentacle11head is "leftarm">>
The $tentacle11 tentacle writhes in your left hand.<<neutral 5>>
<</if>>
<<if $tentacle11head is "rightarm">>
The $tentacle11 tentacle writhes in your right hand.<<neutral 5>>
<</if>>
<<if $tentacle11head is "feet">>
The $tentacle11 tentacle writhes between your feet.<<neutral 5>>
<</if>>
<<if $tentacle11head is "leftnipplesuck">>
and up to your <<breastscomma>> where it suckles your left nipple.<<neutral 3>>
<</if>>
<<if $tentacle11head is "rightnipplesuck">>
and up to your <<breastscomma>> where it suckles your right nipple.<<neutral 3>>
<</if>>
<<if $tentacle11head is "leftnipple">>
and continues teasing your left nipple. <span class="purple">The tip of the tentacle opens up, latches on, then begins sucking.</span><<neutral 3>><<set $tentacle11head to "leftnipplesuck">><<set $leftnipple to "tentaclesuck">>
<</if>>
<<if $tentacle11head is "rightnipple">>
and continues teasing your right nipple. <span class="purple">The tip of the tentacle opens up, latches on, then begins sucking.</span><<neutral 3>><<set $tentacle11head to "rightnipplesuck">><<set $rightnipple to "tentaclesuck">>
<</if>>
<<if $tentacle11head is "chest">>
<<if $chestuse is "squeezed">>
then up between your <<breastscomma>> rubbing itself between them.<<neutral 2>>
<<else>>
moves away from your <<breasts>><<set $tentacle11head to 0>><<set $breastuse to 0>>
<</if>>
<</if>>
<<if $tentacle11head is "mouthdeep">>
and up into your mouth where it spurts a sweet fluid down your throat at the apex of each thrust.<<set $purity -= 1>><<internalejac>><<sex 5>><<set $drugged += 3>><<set $mouthgoo += 1>><<set $tentacle11health -= 1>>
<</if>>
<<if $tentacle11head is "mouth">>
and continues thrusting into your mouth.<span class="pink"> The tip opens and begins oozing a sweet liquid.</span><<set $purity -= 1>><<internalejac>><<set $mouthstate to "tentacledeep">><<set $tentacle11head to "mouthdeep">><<sex 5>><<oralejacstat>><<ejacstat>>
<</if>>
<<if $tentacle11head is "mouthimminent">>
<<if $oralvirginity is 1>>
<span class="pink"> and thrusts between your lips,</span><span class="red"> penetrating your mouth for the first time.</span><<set $oralvirginity to 0>><<violence 5>>
<<else>>
<span class="pink"> and thrusts between your lips.</span>
<</if>>
<<set $mouthstate to "tentacle">><<set $tentacle11head to "mouth">><<sex 5>><<raped>><<oralstat>>
<</if>>
<<if $tentacle11head is "mouthentrance">>
<span class="purple"> and presses against your lips.</span><<set $mouthstate to "tentacleimminent">><<set $tentacle11head to "mouthimminent">><<neutral 4>>
<</if>>
<<if $tentacle11head is "vaginadeep">>
and <<slithers>> into your <<pussy>> where it pumps a viscous fluid at the apex of each thrust.<<set $purity -= 1>><<internalejac>><<sex 5>><<set $drugged += 3>><<set $vaginagoo += 1>><<set $tentacle11health -= 1>>
<</if>>
<<if $tentacle11head is "vagina">>
and continues thrusting into your <<pussystop>><span class="pink"> The tip opens and begins oozing a viscous liquid.</span><<set $purity -= 1>><<internalejac>><<set $vaginastate to "tentacledeep">><<set $tentacle11head to "vaginadeep">><<sex 5>><<vaginalejacstat>><<ejacstat>>
<</if>>
<<if $tentacle11head is "vaginaimminent">>
<<if $vaginalvirginity is 1>>
<span class="pink"> and thrusts into your <<pussycomma>></span><span class="red"> tearing your hymen and forever robbing you of your purity.</span><<set $vaginalvirginity to 0>><<violence 100>>
<<else>>
<span class="pink"> and thrusts into your <<pussystop>></span>
<</if>>
<<set $vaginastate to "tentacle">><<set $tentacle11head to "vagina">><<sex 5>><<raped>><<vaginaraped>><<vaginalstat>><<violence 1>>
<</if>>
<<if $tentacle11head is "vaginaentrance">>
<<if $undertype isnot "chastity">>
<span class="purple"> and presses against your <<pussycomma>> about to penetrate.</span><<set $vaginastate to "tentacleimminent">><<set $tentacle11head to "vaginaimminent">><<neutral 4>>
<<else>>
and tries to find a way inside. Failing, it lashes at the metal.<<set $underintegrity -= 10>><<violence 1>>
<</if>>
<</if>>
<<if $tentacle11head is "penisdeep">>
and continues thrusting against your <<peniscomma>> caressing and kneading your length.<<sex 5>>
<</if>>
<<if $tentacle11head is "penis">>
and continues thrusting against your <<penisstop>><span class="pink"> It sucks and kneads your length, trying to milk you of your cum.</span><<set $penisstate to "tentacledeep">><<set $tentacle11head to "penisdeep">><<sex 5>>
<</if>>
<<if $tentacle11head is "penisimminent">>
<<if $penilevirginity is 1>>
<span class="pink"> and thrusts against your <<peniscomma>> swallowing you to the base and </span><span class="red"> tearing the membrane between your glans and foreskin, forever robbing you of your purity.</span><<set $penilevirginity to 0>><<violence 100>>
<<else>>
<span class="pink"> and thrusts against your <<peniscomma>> swallowing you to the base.</span>
<</if>>
<<set $penisstate to "tentacle">><<set $tentacle11head to "penis">><<sex 5>><<raped>><<penisraped>><<penilestat>><<violence 1>>
<</if>>
<<if $tentacle11head is "penisentrance">>
<<if $undertype isnot "chastity">>
<span class="purple"> and <<slithers>> over to your <<penisstop>> The tip opens and presses against your glans, about to envelop you.</span><<set $penisstate to "tentacleimminent">><<set $tentacle11head to "penisimminent">><<neutral 4>>
<<else>>
and tries to find a way inside. Failing, it lashes at the metal.<<set $underintegrity -= 10>><<violence 1>>
<</if>>
<</if>>
<<if $tentacle11head is "anusdeep">>
and <<slithers>> into your <<bottom>> where it pumps a viscous fluid at the apex of each thrust.<<set $purity -= 1>><<internalejac>><<sex 5>><<set $drugged += 3>><<set $anusgoo += 1>><<set $tentacle11health -= 1>>
<</if>>
<<if $tentacle11head is "anus">>
and continues thrusting into your <<bottomstop>><span class="pink"> The tip opens and begins oozing a viscous liquid.</span><<set $purity -= 1>><<internalejac>><<set $anusstate to "tentacledeep">><<set $tentacle11head to "anusdeep">><<sex 5>><<analejacstat>><<ejacstat>>
<</if>>
<<if $tentacle11head is "anusimminent">>
<<if $analvirginity is 1>>
<span class="pink"> and thrusts into your <<bottomcomma>></span><span class="red"> violating you in a way you hadn't conceived of.</span><<set $analvirginity to 0>><<violence 100>>
<<else>>
<span class="pink"> and thrusts into your <<bottomstop>></span>
<</if>>
<<set $anusstate to "tentacle">><<set $tentacle11head to "anus">><<sex 5>><<raped>><<analstat>><<violence 1>>
<</if>>
<<if $tentacle11head is "anusentrance">>
<<if $analshield is 0>>
<span class="purple"> and presses against your <<bottomcomma>> about to penetrate.</span><<set $anusstate to "tentacleimminent">><<set $tentacle11head to "anusimminent">><<neutral 4>>
<<else>>
and tries to find a way inside. Failing, it lashes at the device.<<set $underintegrity -= 10>><<violence 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $tentacle11head is "vaginarub">>
<<if $rng gte 21>>
and between your thighs where it <<slithers>> against your <<pussycomma>> pressing against your clit.<<sex 3>>
<<else>>
and between your thighs <span class="blue">where it <<slithers>> toward your <<pussystop>></span><<neutral 3>><<set $vaginause to "tentacle">><<set $vaginastate to "tentacleentrance">><<set $tentacle11head to "vaginaentrance">><<set $thighuse to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $tentacle11head is "penisrub">>
<<if $rng gte 21>>
and between your thighs where it <<slithers>> against your <<peniscomma>> coiling around it.<<sex 3>>
<<else>>
and between your thighs <span class="blue">where the tip opens and it <<slithers>> toward your <<penisstop>></span><<neutral 3>><<set $penisuse to "tentacle">><<set $penisstate to "tentacleentrance">><<set $tentacle11head to "penisentrance">><<set $thighuse to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $tentacle11head is "bottomrub">>
<<if $rng gte 21>>
and between your <<bottom>> cheeks where it <<slithers>> against your back.<<sex 3>>
<<else>>
and between your <<bottom>> cheeks, <span class="blue"> toward your anus.</span><<neutral 3>><<set $anususe to "tentacle">><<set $anusstate to "tentacleentrance">><<set $tentacle11head to "anusentrance">><<set $bottomuse to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $tentacle11head is 0 and $tentacle11shaft isnot 0>>
<<if $rng lte 10>>
<<if $chestuse is "squeezed" and $breastuse is 0>>
<<upperslither>><span class="blue">and up between your squeezed <<breastsstop>></span><<set $tentacle11head to "chest">><<neutral 2>><<set $breastuse to "tentacle">><<cheststat>>
<<else>>
<<tentacle11default>>
<</if>>
<<elseif $rng lte 20>>
<<if $leftnipple is 0>>
<<upperslither>> <span class="blue">and teases your left nipple.</span><<neutral 2>><<set $tentacle11head to "leftnipple">><<set $leftnipple to "tentacle">>
<<else>>
<<tentacle11default>>
<</if>>
<<elseif $rng lte 30>>
<<if $rightnipple is 0>>
<<upperslither>> <span class="blue">and teases your right nipple.</span><<neutral 2>><<set $tentacle11head to "rightnipple">><<set $rightnipple to "tentacle">>
<<else>>
<<tentacle11default>>
<</if>>
<<elseif $rng lte 40>>
<<if $mouthuse is 0>>
<<upperslither>> <span class="blue">and up toward your mouth.</span><<neutral 2>><<set $mouthuse to "tentacle">><<set $mouthstate to "tentacleentrance">><<set $tentacle11head to "mouthentrance">>
<<else>>
<<tentacle11default>>
<</if>>
<<elseif $rng lte 50>>
<<if $anususe is 0 and $analdisable is "f">>
<<underslither>> <span class="blue">and <<slithers>> toward your <<bottomstop>></span><<neutral 2>><<set $anususe to "tentacle">><<set $anusstate to "tentacleentrance">><<set $tentacle11head to "anusentrance">>
<<else>>
<<tentacle11default>>
<</if>>
<<elseif $rng lte 60>>
<<if $vaginaexist is 1 and $vaginause is 0>>
<<underslither>> <span class="blue">and <<slithers>> toward your <<pussystop>></span><<neutral 2>><<set $vaginause to "tentacle">><<set $vaginastate to "tentacleentrance">><<set $tentacle11head to "vaginaentrance">>
<<else>>
<<tentacle11default>>
<</if>>
<<elseif $rng lte 70>>
<<if $penisexist is 1 and $penisuse is 0>>
<<underslither>> <span class="blue">and <<slithers>> toward your <<penisstop>></span><<neutral 2>><<set $penisuse to "tentacle">><<set $penisstate to "tentacleentrance">><<set $tentacle11head to "penisentrance">>
<<else>>
<<tentacle11default>>
<</if>>
<<elseif $rng lte 80>>
<<if $thighuse is 0>>
<<if $penisexist is 1 and $penisuse is 0>>
<<underslither>> <span class="blue">and <<slithers>> between your thighs and against your tummy and <<penisstop>></span><<set $penisuse to "tentaclerub">><<set $thighuse to "tentaclerub">><<set $tentacle11head to "penisrub">><<sex 3>><<thighstat>>
<<elseif $vaginaexist is 1 and $vaginause is 0>>
<<underslither>> <span class="blue">and <<slithers>> between your thighs and against your tummy and <<pussystop>></span><<set $vaginause to "tentaclerub">><<set $thighuse to "tentaclerub">><<set $tentacle11head to "vaginarub">><<sex 3>><<thighstat>>
<<else>>
<<tentacle11default>>
<</if>>
<<else>>
<<tentacle11default>>
<</if>>
<<elseif $rng lte 90>>
<<if $bottomuse is 0 and $anususe is 0 and $analdisable is "f">>
<<underslither>> <span class="blue">and <<slithers>> between your <<bottom>> cheeks and against your back.</span><<set $bottomuse to "tentaclerub">><<set $anususe to "tentaclerub">><<set $tentacle11head to "bottomrub">><<sex 1>><<bottomstat>>
<<else>>
<<tentacle11default>>
<</if>>
<<else>>
<<tentacle11default>>
<</if>>
<<elseif $tentacle11head is 0 and $tentacle11shaft is 0>>
<<if $rng lte 10>>
<<if $position isnot "wall">>
The $tentacle11 tentacle winds around your tummy.<<neutral 1>><<set $tentacle11shaft to "tummy">>
<<else>>
The $tentacle11 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<elseif $rng lte 20>>
The $tentacle11 tentacle <<slithers>> between your thighs.<<neutral 1>><<set $tentacle11shaft to "thighs">>
<<elseif $rng lte 30>>
<<if $position isnot "wall">>
<<if $breastsize gte 2 and $chestuse is 0>>
The $tentacle11 tentacle <<slithers>> around your <<breastscomma>> <span class="blue">squeezing them together.</span><<neutral 1>><<set $tentacle11shaft to "breasts">><<set $chestuse to "squeezed">>
<<else>>
The $tentacle11 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<else>>
The $tentacle11 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<elseif $rng lte 40>>
<<if $position isnot "wall">>
The $tentacle11 tentacle winds its way around your chest, beneath your <<breastsstop>><<neutral 1>><<set $tentacle11shaft to "chest">>
<<else>>
The $tentacle11 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<elseif $rng lte 50>>
The $tentacle11 tentacle winds its way around your waist.<<neutral 1>><<set $tentacle11shaft to "waist">>
<<elseif $rng lte 60>>
<<if $position isnot "wall">>
<<if $head is 0>>
The $tentacle11 tentacle winds its way around your neck, <span class="blue">restraining your head.</span><<neutral 1>><<set $tentacle11shaft to "neck">><<set $head to "grappled">>
<<else>>
The $tentacle11 tentacle winds its way around your shoulders.<<neutral 1>><<set $tentacle11shaft to "shoulders">>
<</if>>
<<else>>
The $tentacle11 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<elseif $rng lte 70>>
The $tentacle11 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<<elseif $rng lte 80>>
<<if $leftleg is 0>>
The $tentacle11 tentacle winds its way around your left leg, <span class="blue">restraining it.</span><<neutral 1>><<feettentacledisable>><<set $tentacle11shaft to "leftleg">><<set $leftleg to "grappled">>
<<else>>
The $tentacle11 tentacle tickles your feet.<<neutral 1>>
<</if>>
<<elseif $rng lte 85>>
<<if $rightleg is 0>>
The $tentacle11 tentacle winds its way around your right leg, <span class="blue">restraining it.</span><<neutral 1>><<feettentacledisable>><<set $tentacle11shaft to "rightleg">><<set $rightleg to "grappled">>
<<else>>
The $tentacle11 tentacle tickles your feet.<<neutral 1>>
<</if>>
<<elseif $rng lte 90>>
<<if $leftarm is 0>>
The $tentacle11 tentacle winds its way around your left arm, <span class="blue">restraining it.</span><<neutral 1>><<leftarmtentacledisable>><<set $tentacle11shaft to "leftarm">><<set $leftarm to "grappled">><<set $leftarmstate to 0>>
<<else>>
The $tentacle11 tentacle tickles your armpit.<<neutral 1>>
<</if>>
<<elseif $rng lte 95>>
<<if $rightarm is 0>>
The $tentacle11 tentacle winds its way around your right arm, <span class="blue">restraining it.</span><<rightarmtentacledisable>><<neutral 1>><<set $tentacle11shaft to "rightarm">><<set $rightarm to "grappled">><<set $rightarmstate to 0>>
<<else>>
The $tentacle11 tentacle tickles your armpit.<<neutral 1>>
<</if>>
<<elseif $rng lte 100>>
The $tentacle11 tentacle <<slithers>> against your <<bottomstop>><<neutral 1>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "tentacle11default">><<nobr>>
<<set $rng to random(1, 100)>>
<<if $rng gte 90>>
then squirts a warm fluid over your neck.<<neutral 1>><<set $neckgoo += 1>><<set $tentacle11health -= 1>><<neckejacstat>><<ejacstat>>
<<elseif $rng gte 80>>
then squirts a warm fluid over your right arm.<<neutral 1>><<set $rightarmgoo += 1>><<set $tentacle11health -= 1>><<handejacstat>><<ejacstat>>
<<elseif $rng gte 70>>
then squirts a warm fluid over your left arm.<<neutral 1>><<set $leftarmgoo += 1>><<set $tentacle11health -= 1>><<handejacstat>><<ejacstat>>
<<elseif $rng gte 60>>
then squirts a warm fluid over your thighs.<<neutral 1>><<set $thighgoo += 1>><<set $tentacle11health -= 1>><<thighejacstat>><<ejacstat>>
<<elseif $rng gte 50>>
then squirts a warm fluid over your <<bottomstop>><<neutral 1>><<set $bottomgoo += 1>><<set $tentacle11health -= 1>><<bottomejacstat>><<ejacstat>>
<<elseif $rng gte 40>>
then squirts a warm fluid over your tummy.<<neutral 1>><<set $tummygoo += 1>><<set $tentacle11health -= 1>><<tummyejacstat>><<ejacstat>>
<<elseif $rng gte 30>>
then squirts a warm fluid over your chest.<<neutral 1>><<set $chestgoo += 1>><<set $tentacle11health -= 1>><<chestejacstat>><<ejacstat>>
<<elseif $rng gte 20>>
then squirts a warm fluid over your face.<<neutral 1>><<set $facegoo += 1>><<set $tentacle11health -= 1>><<faceejacstat>><<ejacstat>>
<<elseif $rng gte 10>>
then squirts a warm fluid over your hair.<<neutral 1>><<set $hairgoo += 1>><<set $tentacle11health -= 1>><<hairejacstat>><<ejacstat>>
<<else>>
then squirts a warm fluid over your feet.<<neutral 1>><<set $feetgoo += 1>><<set $tentacle11health -= 1>><<feetejacstat>><<ejacstat>>
<</if>>
<</nobr>><</widget>>
<<widget "tentacle11disable">><<nobr>>
<<if $tentacle11head is "feet">>
<<set $leftleg to 0>>
<<set $rightleg to 0>>
<<set $feetstate to 0>>
<</if>>
<<if $tentacle11head is "leftarm">>
<<set $leftarm to 0>>
<<set $leftarmstate to 0>>
<</if>>
<<if $tentacle11head is "rightarm">>
<<set $rightarm to 0>>
<<set $rightarmstate to 0>>
<</if>>
<<if $tentacle11head is "leftnipplesuck">>
<<set $leftnipple to 0>>
<</if>>
<<if $tentacle11head is "rightnipplesuck">>
<<set $rightnipple to 0>>
<</if>>
<<if $tentacle11head is "leftnipple">>
<<set $leftnipple to 0>>
<</if>>
<<if $tentacle11head is "rightnipple">>
<<set $rightnipple to 0>>
<</if>>
<<if $tentacle11head is "chest">>
<<set $chestuse to 0>>
<</if>>
<<if $tentacle11head is "mouthentrance">>
<<set $mouthuse to 0>>
<<set $mouthstate to 0>>
<</if>>
<<if $tentacle11head is "mouthimminent">>
<<set $mouthuse to 0>>
<<set $mouthstate to 0>>
<</if>>
<<if $tentacle11head is "mouth">>
<<set $mouthuse to 0>>
<<set $mouthstate to 0>>
<</if>>
<<if $tentacle11head is "mouthdeep">>
<<set $mouthuse to 0>>
<<set $mouthstate to 0>>
<</if>>
<<if $tentacle11head is "anusentrance">>
<<set $anususe to 0>>
<<set $anusstate to 0>>
<</if>>
<<if $tentacle11head is "anusimminent">>
<<set $anususe to 0>>
<<set $anusstate to 0>>
<</if>>
<<if $tentacle11head is "anus">>
<<set $anususe to 0>>
<<set $anusstate to 0>>
<</if>>
<<if $tentacle11head is "anusdeep">>
<<set $anususe to 0>>
<<set $anusstate to 0>>
<</if>>
<<if $tentacle11head is "vaginaentrance">>
<<set $vaginause to 0>>
<<set $vaginastate to 0>>
<</if>>
<<if $tentacle11head is "vaginaimminent">>
<<set $vaginause to 0>>
<<set $vaginastate to 0>>
<</if>>
<<if $tentacle11head is "vagina">>
<<set $vaginause to 0>>
<<set $vaginastate to 0>>
<</if>>
<<if $tentacle11head is "vaginadeep">>
<<set $vaginause to 0>>
<<set $vaginastate to 0>>
<</if>>
<<if $tentacle11head is "penisentrance">>
<<set $penisuse to 0>>
<<set $penisstate to 0>>
<</if>>
<<if $tentacle11head is "penisimminent">>
<<set $penisuse to 0>>
<<set $penisstate to 0>>
<</if>>
<<if $tentacle11head is "penis">>
<<set $penisuse to 0>>
<<set $penisstate to 0>>
<</if>>
<<if $tentacle11head is "penisdeep">>
<<set $penisuse to 0>>
<<set $penisstate to 0>>
<</if>>
<<if $tentacle11head is "vaginarub">>
<<set $vaginause to 0>>
<<set $thighuse to 0>>
<</if>>
<<if $tentacle11head is "penisrub">>
<<set $penisuse to 0>>
<<set $thighuse to 0>>
<</if>>
<<if $tentacle11head is "bottomrub">>
<<set $anususe to 0>>
<<set $bottomuse to 0>>
<</if>>
<<if $tentacle11shaft is "breasts">>
<<set $chestuse to 0>>
<</if>>
<<if $tentacle11shaft is "neck" and $head isnot "bound">>
<<set $head to 0>>
<</if>>
<<if $tentacle11shaft is "leftleg" and $leftleg isnot "bound">>
<<set $leftleg to 0>>
<</if>>
<<if $tentacle11shaft is "rightleg" and $rightleg isnot "bound">>
<<set $rightleg to 0>>
<</if>>
<<if $tentacle11shaft is "leftarm" and $leftarm isnot "bound">>
<<set $leftarm to 0>>
<</if>>
<<if $tentacle11shaft is "rightarm" and $rightarm isnot "bound">>
<<set $rightarm to 0>>
<</if>>
<<if $tentacle11head is "chest">>
<<set $breastuse to 0>>
<</if>>
<<set $tentacle11shaft to 0>>
<<set $tentacle11head to 0>>
<</nobr>><</widget>>
<<widget "actionstentacle11lefthand">><<nobr>>
<<if $leftarm is 0 and $tentacle11shaft isnot "finished">>
<<if $leftactiondefault is "lefthittentacle11">>
| <label><span class="def">Strike the $tentacle11 tentacle</span> <<radiobutton "$leftaction" "lefthittentacle11" checked>></label>
<<else>>
| <label><span class="def">Strike the $tentacle11 tentacle</span> <<radiobutton "$leftaction" "lefthittentacle11">></label>
<</if>>
<<if $leftactiondefault is "leftgrabtentacle11">>
| <label><span class="sub">Grab the $tentacle11 tentacle</span> <<radiobutton "$leftaction" "leftgrabtentacle11" checked>></label>
<<else>>
| <label><span class="sub">Grab the $tentacle11 tentacle</span> <<radiobutton "$leftaction" "leftgrabtentacle11">></label>
<</if>>
<<elseif $leftarm is "tentacle11">>You hold the $tentacle11 tentacle in your left hand.<br>
<<if $leftactiondefault is "leftrubtentacle11">>
| <label><span class="sub">Milk it</span> <<radiobutton "$leftaction" "leftrubtentacle11" checked>></label>
<<else>>
| <label><span class="sub">Milk it</span> <<radiobutton "$leftaction" "leftrubtentacle11">></label>
<</if>>
<<if $leftactiondefault is "leftstoptentacle11">>
| <label><span class="neutral">Let go</span> <<radiobutton "$leftaction" "leftstoptentacle11" checked>></label>
<<else>>
| <label><span class="neutral">Let go</span> <<radiobutton "$leftaction" "leftstoptentacle11">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle11righthand">><<nobr>>
<<if $rightarm is 0 and $tentacle11shaft isnot "finished">>
<<if $rightactiondefault is "righthittentacle11">>
| <label><span class="def">Strike the $tentacle11 tentacle</span> <<radiobutton "$rightaction" "righthittentacle11" checked>></label>
<<else>>
| <label><span class="def">Strike the $tentacle11 tentacle</span> <<radiobutton "$rightaction" "righthittentacle11">></label>
<</if>>
<<if $rightactiondefault is "rightgrabtentacle11">>
| <label><span class="sub">Grab the $tentacle11 tentacle</span> <<radiobutton "$rightaction" "rightgrabtentacle11" checked>></label>
<<else>>
| <label><span class="sub">Grab the $tentacle11 tentacle</span> <<radiobutton "$rightaction" "rightgrabtentacle11">></label>
<</if>>
<<elseif $rightarm is "tentacle11">>You hold the $tentacle11 tentacle in your right hand.<br>
<<if $rightactiondefault is "rightrubtentacle11">>
| <label><span class="sub">Milk it</span> <<radiobutton "$rightaction" "rightrubtentacle11" checked>></label>
<<else>>
| <label><span class="sub">Milk it</span> <<radiobutton "$rightaction" "rightrubtentacle11">></label>
<</if>>
<<if $rightactiondefault is "rightstoptentacle11">>
| <label><span class="neutral">Let go</span> <<radiobutton "$rightaction" "rightstoptentacle11" checked>></label>
<<else>>
| <label><span class="neutral">Let go</span> <<radiobutton "$rightaction" "rightstoptentacle11">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle11legs">><<nobr>>
<<if $leftleg is 0 and $rightleg is 0 and $tentacle11shaft isnot "finished">>
<<if $feetactiondefault is "feethittentacle11">>
| <label><span class="def">Kick the $tentacle11 tentacle</span> <<radiobutton "$feetaction" "feethittentacle11" checked>></label>
<<else>>
| <label><span class="def">Kick the $tentacle11 tentacle</span> <<radiobutton "$feetaction" "feethittentacle11">></label>
<</if>>
<<if $feetactiondefault is "feetgrabtentacle11">>
| <label><span class="sub">Grab the $tentacle11 tentacle</span> <<radiobutton "$feetaction" "feetgrabtentacle11" checked>></label>
<<else>>
| <label><span class="sub">Grab the $tentacle11 tentacle</span> <<radiobutton "$feetaction" "feetgrabtentacle11">></label>
<</if>>
<<elseif $leftleg is 0 and $tentacle11shaft isnot "finished">>
<<if $feetactiondefault is "feethittentacle11">>
| <label><span class="def">Kick the $tentacle11 tentacle</span> <<radiobutton "$feetaction" "feethittentacle11" checked>></label>
<<else>>
| <label><span class="def">Kick the $tentacle11 tentacle</span> <<radiobutton "$feetaction" "feethittentacle11">></label>
<</if>>
<<elseif $rightleg is 0 and $tentacle11shaft isnot "finished">>
<<if $feetactiondefault is "feethittentacle11">>
| <label><span class="def">Kick the $tentacle11 tentacle</span> <<radiobutton "$feetaction" "feethittentacle11" checked>></label>
<<else>>
| <label><span class="def">Kick the $tentacle11 tentacle</span> <<radiobutton "$feetaction" "feethittentacle11">></label>
<</if>>
<<elseif $leftleg is "tentacle11">>You hold the $tentacle11 tentacle between your feet.<br>
<<if $feetactiondefault is "feetrubtentacle11">>
| <label><span class="sub">Milk it</span> <<radiobutton "$feetaction" "feetrubtentacle11" checked>></label>
<<else>>
| <label><span class="sub">Milk it</span> <<radiobutton "$feetaction" "feetrubtentacle11">></label>
<</if>>
<<if $feetactiondefault is "feetstoptentacle11">>
| <label><span class="neutral">Let go</span> <<radiobutton "$feetaction" "feetstoptentacle11" checked>></label>
<<else>>
| <label><span class="neutral">Let go</span> <<radiobutton "$feetaction" "feetstoptentacle11">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle11mouth">><<nobr>>
<<if $tentacle11head is "mouthentrance">>
<<if $mouthactiondefault is "mouthlicktentacle11">>
| <label><span class="sub">Lick it</span> <<radiobutton "$mouthaction" "mouthlicktentacle11" checked>></label>
<<else>>
| <label><span class="sub">Lick it</span> <<radiobutton "$mouthaction" "mouthlicktentacle11">></label>
<</if>>
<<if $head is "grappled">>
<<else>>
<<if $mouthactiondefault is "mouthpullawaytentacle11">>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "mouthpullawaytentacle11" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "mouthpullawaytentacle11">></label>
<</if>>
<</if>>
<<elseif $tentacle11head is "mouthimminent">>
<<if $mouthactiondefault is "mouthkisstentacle11">>
| <label><span class="sub">Kiss it</span> <<radiobutton "$mouthaction" "mouthkisstentacle11" checked>></label>
<<else>>
| <label><span class="sub">Kiss it</span> <<radiobutton "$mouthaction" "mouthkisstentacle11">></label>
<</if>>
<<if $head is "grappled">>
<<else>>
<<if $mouthactiondefault is "mouthpullawaytentacle11">>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "mouthpullawaytentacle11" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "mouthpullawaytentacle11">></label>
<</if>>
<</if>>
<<elseif $tentacle11head is "mouth">>
<<if $mouthactiondefault is "mouthcooperatetentacle11">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$mouthaction" "mouthcooperatetentacle11" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$mouthaction" "mouthcooperatetentacle11">></label>
<</if>>
<<if $mouthactiondefault is "mouthbitetentacle11">>
| <label><span class="def">Bite</span> <<radiobutton "$mouthaction" "mouthbitetentacle11" checked>></label>
<<else>>
| <label><span class="def">Bite</span> <<radiobutton "$mouthaction" "mouthbitetentacle11">></label>
<</if>>
<<elseif $tentacle11head is "mouthdeep">>
<<if $mouthactiondefault is "mouthcooperatetentacle11">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$mouthaction" "mouthcooperatetentacle11" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$mouthaction" "mouthcooperatetentacle11">></label>
<</if>>
<<if $mouthactiondefault is "mouthbitetentacle11">>
| <label><span class="def">Bite</span> <<radiobutton "$mouthaction" "mouthbitetentacle11" checked>></label>
<<else>>
| <label><span class="def">Bite</span> <<radiobutton "$mouthaction" "mouthbitetentacle11">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle11vagina">><<nobr>>
<<if $tentacle11head is "vaginaentrance">>
<<if $vaginaactiondefault is "vaginarubtentacle11">>
| <label><span class="sub">Rub</span> <<radiobutton "$vaginaaction" "vaginarubtentacle11" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$vaginaaction" "vaginarubtentacle11">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $vaginaactiondefault is "vaginapullawaytentacle11">>
| <label><span class="brat">Pull away</span> <<radiobutton "$vaginaaction" "vaginapullawaytentacle11" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$vaginaaction" "vaginapullawaytentacle11">></label>
<</if>>
<</if>>
<<elseif $tentacle11head is "vaginaimminent">>
<<if $vaginaactiondefault is "vaginarubtentacle11">>
| <label><span class="sub">Rub</span> <<radiobutton "$vaginaaction" "vaginarubtentacle11" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$vaginaaction" "vaginarubtentacle11">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $vaginaactiondefault is "vaginapullawaytentacle11">>
| <label><span class="brat">Pull away</span> <<radiobutton "$vaginaaction" "vaginapullawaytentacle11" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$vaginaaction" "vaginapullawaytentacle11">></label>
<</if>>
<</if>>
<<elseif $tentacle11head is "vagina">>
<<if $vaginaactiondefault is "vaginacooperatetentacle11">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$vaginaaction" "vaginacooperatetentacle11" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$vaginaaction" "vaginacooperatetentacle11">></label>
<</if>>
<<elseif $tentacle11head is "vaginadeep">>
<<if $vaginaactiondefault is "vaginacooperatetentacle11">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$vaginaaction" "vaginacooperatetentacle11" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$vaginaaction" "vaginacooperatetentacle11">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle11penis">><<nobr>>
<<if $tentacle11head is "penisentrance">>
<<if $penisactiondefault is "penisrubtentacle11">>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "penisrubtentacle11" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "penisrubtentacle11">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $penisactiondefault is "penispullawaytentacle11">>
| <label><span class="brat">Pull away</span> <<radiobutton "$penisaction" "penispullawaytentacle11" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$penisaction" "penispullawaytentacle11">></label>
<</if>>
<</if>>
<<elseif $tentacle11head is "penisimminent">>
<<if $penisactiondefault is "penisrubtentacle11">>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "penisrubtentacle11" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "penisrubtentacle11">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $penisactiondefault is "penispullawaytentacle11">>
| <label><span class="brat">Pull away</span> <<radiobutton "$penisaction" "penispullawaytentacle11" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$penisaction" "penispullawaytentacle11">></label>
<</if>>
<</if>>
<<elseif $tentacle11head is "penis">>
<<if $penisactiondefault is "peniscooperatetentacle11">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$penisaction" "peniscooperatetentacle11" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$penisaction" "peniscooperatetentacle11">></label>
<</if>>
<<elseif $tentacle11head is "penisdeep">>
<<if $penisactiondefault is "peniscooperatetentacle11">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$penisaction" "peniscooperatetentacle11" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$penisaction" "peniscooperatetentacle11">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle11anus">><<nobr>>
<<if $tentacle11head is "anusentrance">>
<<if $anusactiondefault is "anusrubtentacle11">>
| <label><span class="sub">Rub</span> <<radiobutton "$anusaction" "anusrubtentacle11" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$anusaction" "anusrubtentacle11">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $anusactiondefault is "anuspullawaytentacle11">>
| <label><span class="brat">Pull away</span> <<radiobutton "$anusaction" "anuspullawaytentacle11" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$anusaction" "anuspullawaytentacle11">></label>
<</if>>
<</if>>
<<elseif $tentacle11head is "anusimminent">>
<<if $anusactiondefault is "anusrubtentacle11">>
| <label><span class="sub">Rub</span> <<radiobutton "$anusaction" "anusrubtentacle11" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$anusaction" "anusrubtentacle11">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $anusactiondefault is "anuspullawaytentacle11">>
| <label><span class="brat">Pull away</span> <<radiobutton "$anusaction" "anuspullawaytentacle11" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$anusaction" "anuspullawaytentacle11">></label>
<</if>>
<</if>>
<<elseif $tentacle11head is "anus">>
<<if $anusactiondefault is "anuscooperatetentacle11">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$anusaction" "anuscooperatetentacle11" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$anusaction" "anuscooperatetentacle11">></label>
<</if>>
<<elseif $tentacle11head is "anusdeep">>
<<if $anusactiondefault is "anuscooperatetentacle11">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$anusaction" "anuscooperatetentacle11" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$anusaction" "anuscooperatetentacle11">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle11thighs">><<nobr>>
<<if $tentacle11head is "penisrub">>
<<if $thighactiondefault is "penisrubtentacle11">>
| <label><span class="sub">Rub</span> <<radiobutton "$thighaction" "penisrubtentacle11" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$thighaction" "penisrubtentacle11">></label>
<</if>>
<<elseif $tentacle11head is "vaginarub">>
<<if $thighactiondefault is "vaginarubtentacle11">>
| <label><span class="sub">Rub</span> <<radiobutton "$thighaction" "vaginarubtentacle11" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$thighaction" "vaginarubtentacle11">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle11bottom">><<nobr>>
<<if $tentacle11head is "bottomrub">>
<<if $bottomactiondefault is "bottomrubtentacle11">>
| <label><span class="sub">Rub</span> <<radiobutton "$bottomaction" "bottomrubtentacle11" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$bottomaction" "bottomrubtentacle11">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle11chest">><<nobr>>
<<if $tentacle11head is "chest">>
<<if $chestactiondefault is "chestrubtentacle11">>
| <label><span class="sub">Rub</span> <<radiobutton "$chestaction" "chestrubtentacle11" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$chestaction" "chestrubtentacle11">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "effectstentacle11">><<nobr>>
<<if $leftaction is "lefthittentacle11">><<set $leftaction to 0>><<set $leftactiondefault to "lefthittentacle11">>You strike the $tentacle11 tentacle with your left hand and it reels away from you.<<defiance 2>><<set $speechhit to 1>><<tentacle11disable>><<set $attackstat += 1>><<set $tentacle11health -= 1>>
<<if $rng lte ($physique / 200)>>
<<set $tentacle11health -= 1>>
<</if>>
<</if>>
<<if $rightaction is "righthittentacle11">><<set $rightaction to 0>><<set $rightactiondefault to "righthittentacle11">>You strike the $tentacle11 tentacle with your right hand and it reels away from you.<<defiance 2>><<set $speechhit to 1>><<tentacle11disable>><<set $attackstat += 1>><<set $tentacle11health -= 1>>
<<if $rng lte ($physique / 200)>>
<<set $tentacle11health -= 1>>
<</if>>
<</if>>
<<if $leftaction is "leftgrabtentacle11">><<set $leftaction to 0>><<set $leftactiondefault to "leftrubtentacle11">><<submission 1>><<handstat>><span class="lblue">You <<handtext>> grab the $tentacle11 tentacle with your left hand.</span><<tentacle11disable>><<set $leftarm to "tentacle11">><<set $tentacle11head to "leftarm">><<handstat>><<set $leftarmstate to "tentacle">>
<</if>>
<<if $rightaction is "rightgrabtentacle11">><<set $rightaction to 0>><<set $rightactiondefault to "rightrubtentacle11">><<submission 1>><<handstat>><span class="lblue">You <<handtext>> grab the $tentacle11 tentacle with your right hand.</span><<tentacle11disable>><<set $rightarm to "tentacle11">><<set $tentacle11head to "rightarm">><<handstat>><<set $rightarmstate to "tentacle">>
<</if>>
<<if $leftaction is "leftrubtentacle11">><<set $leftaction to 0>><<set $leftactiondefault to "leftrubtentacle11">><<handskilluse>><<submission 1>>You <<handtext>> squeeze the $tentacle11 tentacle in your left hand and rub up and down its length.<<set $rng to random(1, 100)>>
<<if $handskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $rightarmgoo += 1>><<set $tentacle11health -= 3>><<handejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $rightaction is "rightrubtentacle11">><<set $rightaction to 0>><<set $rightactiondefault to "rightrubtentacle11">><<handskilluse>><<submission 1>>You <<handtext>> squeeze the $tentacle11 tentacle in your right hand and rub up and down its length.<<set $rng to random(1, 100)>>
<<if $handskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $rightarmgoo += 1>><<set $tentacle11health -= 3>><<handejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $leftaction is "leftstoptentacle11">><<set $leftaction to 0>><<set $leftactiondefault to "leftstoptentacle11">>You release the $tentacle11 tentacle from your left hand.<<tentacle11disable>>
<</if>>
<<if $rightaction is "rightstoptentacle11">><<set $rightaction to 0>><<set $rightactiondefault to "rightstoptentacle11">>You release the $tentacle11 tentacle from your right hand.<<tentacle11disable>>
<</if>>
<<if $feetaction is "feethittentacle11">><<set $feetaction to 0>><<set $feetactiondefault to "feethittentacle11">>You kick the $tentacle11 tentacle and it reels away from you.<<defiance 2>><<set $speechhit to 1>><<tentacle11disable>><<set $attackstat += 1>><<set $tentacle11health -= 1>>
<<if $rng lte ($physique / 200)>>
<<set $tentacle11health -= 1>>
<</if>>
<</if>>
<<if $feetaction is "feetgrabtentacle11">><<set $feetaction to 0>><<set $feetactiondefault to "feetrubtentacle11">><<submission 1>><<feetstat>><span class="lblue">You <<feettext>> grab the $tentacle11 tentacle between your feet.</span><<tentacle11disable>><<set $leftleg to "tentacle11">><<set $rightleg to "tentacle11">><<set $tentacle11head to "feet">><<feetstat>><<set $feetstate to "tentacle">>
<</if>>
<<if $feetaction is "feetrubtentacle11">><<set $feetaction to 0>><<set $feetactiondefault to "feetrubtentacle11">><<feetskilluse>><<submission 1>>You <<feettext>> squeeze the $tentacle11 tentacle between your feet and rub up and down its length.<<set $rng to random(1, 100)>>
<<if $feetskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $feetgoo += 1>><<set $tentacle11health -= 3>><<feetejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $feetaction is "feetstoptentacle11">><<set $feetaction to 0>><<set $feetactiondefault to "feetstoptentacle11">>You let go of the $tentacle11 tentacle between your feet.<<tentacle11disable>>
<</if>>
<<if $mouthaction is "mouthlicktentacle11">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthlicktentacle11">>
<<submission 2>><<oralskilluse>>You <<oraltext>> lick the tip of the $tentacle11 tentacle.<<set $rng to random(1, 100)>>
<<if $oralskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your face.</span><<set $facegoo += 1>><<set $tentacle11health -= 3>><<faceejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $mouthaction is "mouthkisstentacle11">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthkisstentacle11">>
<<submission 3>><<oralskilluse>>You <<oraltext>> kiss the tip of the $tentacle11 tentacle.<<set $rng to random(1, 100)>>
<<if $oralskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your face.</span><<set $facegoo += 1>><<set $tentacle11health -= 3>><<faceejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $mouthaction is "mouthcooperatetentacle11">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthcooperatetentacle11">>
<<sex 5>><<oralskilluse>>You <<oraltext>> suck the $tentacle11 tentacle invading your mouth.<<set $rng to random(1, 100)>>
<<if $oralskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip and into your mouth.</span><<set $tentacle11health -= 3>><<set $drugged += 3>><<set $mouthgoo += 1>><<oralejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $mouthaction is "mouthpullawaytentacle11">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthpullawaytentacle11">><<brat 1>><span class="teal">You pull away from the $tentacle11 tentacle threatening your mouth.</span><<tentacle11disable>>
<</if>>
<<if $mouthaction is "mouthbitetentacle11">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthbitetentacle11">><<defiance 5>>You bite down on the $tentacle11 tentacle invading your mouth. <span class="teal">It recoils immediately.</span><<tentacle11disable>><<set $attackstat += 1>><<set $tentacle11health -= 1>>
<<if $rng lte ($physique / 200)>>
<<set $tentacle11health -= 1>>
<</if>>
<</if>>
<<if $vaginaaction is "vaginarubtentacle11">><<set $vaginaaction to 0>><<set $vaginaactiondefault to "vaginarubtentacle11">>
<<submission 2>><<vaginalskilluse>>You <<vaginaltext>> rub the tip of the $tentacle11 tentacle with your <<pussystop>><<set $rng to random(1, 100)>>
<<if $vaginalskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $vaginaoutsidegoo += 1>><<set $tentacle11health -= 3>><<vaginalentranceejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $vaginaaction is "vaginacooperatetentacle11">><<set $vaginaaction to 0>><<set $vaginaactiondefault to "vaginacooperatetentacle11">>
<<sex 5>><<vaginalskilluse>>You <<vaginaltext>> push back against the $tentacle11 tentacle invading your <<pussystop>><<set $rng to random(1, 100)>>
<<if $vaginalskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, flooding your womb with its warmth.</span><<set $tentacle11health -= 3>><<set $drugged += 3>><<set $vaginagoo += 1>><<vaginalejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $vaginaaction is "vaginapullawaytentacle11">><<set $vaginaaction to 0>><<set $vaginaactiondefault to "vaginapullawaytentacle11">><<brat 1>><span class="teal">You pull away from the $tentacle11 tentacle threatening your <<pussystop>></span><<tentacle11disable>>
<</if>>
<<if $penisaction is "penisrubtentacle11">><<set $penisaction to 0>><<set $penisactiondefault to "penisrubtentacle11">>
<<submission 2>><<penileskilluse>>You <<peniletext>> rub the tip of the $tentacle11 tentacle with your <<penisstop>><<set $rng to random(1, 100)>>
<<if $penileskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $penisgoo += 1>><<set $tentacle11health -= 3>><<penileejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $penisaction is "peniscooperatetentacle11">><<set $penisaction to 0>><<set $penisactiondefault to "peniscooperatetentacle11">>
<<sex 5>><<penileskilluse>>You <<peniletext>> push back against the $tentacle11 tentacle engulfing your <<penisstop>><<set $rng to random(1, 100)>>
<<if $penileskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your groin.</span><<set $tentacle11health -= 3>><<set $penisgoo += 1>><<penileejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $penisaction is "penispullawaytentacle11">><<set $penisaction to 0>><<set $penisactiondefault to "penispullawaytentacle11">><<brat 1>><span class="teal">You pull away from the $tentacle11 tentacle threatening your <<penisstop>></span><<tentacle11disable>>
<</if>>
<<if $anusaction is "anusrubtentacle11">><<set $anusaction to 0>><<set $anusactiondefault to "anusrubtentacle11">>
<<submission 2>><<analskilluse>>You <<analtext>> rub the tip of the $tentacle11 tentacle with your <<bottomstop>><<set $rng to random(1, 100)>>
<<if $analskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your <<bottomstop>></span><<set $bottomgoo += 1>><<set $tentacle11health -= 3>><<bottomejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $anusaction is "anuscooperatetentacle11">><<set $anusaction to 0>><<set $anusactiondefault to "anuscooperatetentacle11">>
<<sex 5>><<analskilluse>>You <<analtext>> push back against the $tentacle11 tentacle invading your <<bottomstop>><<set $rng to random(1, 100)>>
<<if $analskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, flooding your bowels with its warmth.</span><<set $tentacle11health -= 3>><<set $drugged += 3>><<set $anusgoo += 1>><<analejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $anusaction is "anuspullawaytentacle11">><<set $anusaction to 0>><<set $anusactiondefault to "anuspullawaytentacle11">><<brat 1>><span class="teal">You pull away from the $tentacle11 tentacle threatening your <<bottomstop>></span><<tentacle11disable>>
<</if>>
<<if $thighaction is "penisrubtentacle11">><<set $thighaction to 0>><<set $thighactiondefault to "penisrubtentacle11">>
<<submission 3>><<thighskilluse>>You <<thightext>> rub the $tentacle11 tentacle between your thighs.<<set $rng to random(1, 100)>>
<<if $thighskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your tummy.</span><<set $tentacle11health -= 3>><<set $tummygoo += 1>><<tummyejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $thighaction is "vaginarubtentacle11">><<set $thighaction to 0>><<set $thighactiondefault to "vaginarubtentacle11">>
<<submission 3>><<thighskilluse>>You <<thightext>> rub the $tentacle11 tentacle between your thighs.<<set $rng to random(1, 100)>>
<<if $thighskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your tummy.</span><<set $tentacle11health -= 3>><<set $tummygoo += 1>><<tummyejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $bottomaction is "bottomrubtentacle11">><<set $bottomaction to 0>><<set $bottomactiondefault to "bottomrubtentacle11">>
<<submission 3>><<bottomskilluse>>You <<bottomtext>> rub the $tentacle11 tentacle between your cheeks.<<set $rng to random(1, 100)>>
<<if $bottomskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your <<bottomstop>></span><<set $tentacle11health -= 3>><<set $bottomgoo += 1>><<bottomejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $chestaction is "chestrubtentacle11">><<set $chestaction to 0>><<set $chestactiondefault to "chestrubtentacle11">>
<<submission 3>><<chestskilluse>>You <<chesttext>> rub the $tentacle11 tentacle between your <<breastsstop>><<set $rng to random(1, 100)>>
<<if $chestskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your chest.</span><<set $tentacle11health -= 3>><<set $chestgoo += 1>><<chestejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<</nobr>><</widget>>
:: Widgets Combat Tentacle12 [widget]
<<widget "tentacle12">><<nobr>>
<<if $tentacle12health lte 0 and $tentacle12shaft isnot "finished">>
Worn out, the $tentacle12 tentacle retracts from you.
<<tentacle12disable>>
<<set $tentacle12shaft to "finished">>
<<set $tentacle12head to "finished">>
<</if>>
<<if $tentacle12shaft is "tummy">>
The $tentacle12 tentacle <<slithers>> around your tummy,
<</if>>
<<if $tentacle12shaft is "thighs">>
The $tentacle12 tentacle <<slithers>> between your thighs,
<</if>>
<<if $tentacle12shaft is "breasts">>
The $tentacle12 tentacle squeezes your breasts together,
<</if>>
<<if $tentacle12shaft is "chest">>
The $tentacle12 tentacle <<slithers>> around your chest,
<</if>>
<<if $tentacle12shaft is "waist">>
The $tentacle12 tentacle <<slithers>> around your waist,
<</if>>
<<if $tentacle12shaft is "neck">>
The $tentacle12 tentacle <<slithers>> around your neck,
<</if>>
<<if $tentacle12shaft is "shoulders">>
The $tentacle12 tentacle <<slithers>> around your shoulders,
<</if>>
<<if $tentacle12shaft is "leftleg">>
The $tentacle12 tentacle <<slithers>> around your left leg,
<</if>>
<<if $tentacle12shaft is "rightleg">>
The $tentacle12 tentacle <<slithers>> around your right leg,
<</if>>
<<if $tentacle12shaft is "leftarm">>
The $tentacle12 tentacle <<slithers>> around your left arm,
<</if>>
<<if $tentacle12shaft is "rightarm">>
The $tentacle12 tentacle <<slithers>> around your right arm,
<</if>>
<<if $tentacle12head is "leftarm">>
The $tentacle12 tentacle writhes in your left hand.<<neutral 5>>
<</if>>
<<if $tentacle12head is "rightarm">>
The $tentacle12 tentacle writhes in your right hand.<<neutral 5>>
<</if>>
<<if $tentacle12head is "feet">>
The $tentacle12 tentacle writhes between your feet.<<neutral 5>>
<</if>>
<<if $tentacle12head is "leftnipplesuck">>
and up to your <<breastscomma>> where it suckles your left nipple.<<neutral 3>>
<</if>>
<<if $tentacle12head is "rightnipplesuck">>
and up to your <<breastscomma>> where it suckles your right nipple.<<neutral 3>>
<</if>>
<<if $tentacle12head is "leftnipple">>
and continues teasing your left nipple. <span class="purple">The tip of the tentacle opens up, latches on, then begins sucking.</span><<neutral 3>><<set $tentacle12head to "leftnipplesuck">><<set $leftnipple to "tentaclesuck">>
<</if>>
<<if $tentacle12head is "rightnipple">>
and continues teasing your right nipple. <span class="purple">The tip of the tentacle opens up, latches on, then begins sucking.</span><<neutral 3>><<set $tentacle12head to "rightnipplesuck">><<set $rightnipple to "tentaclesuck">>
<</if>>
<<if $tentacle12head is "chest">>
<<if $chestuse is "squeezed">>
then up between your <<breastscomma>> rubbing itself between them.<<neutral 2>>
<<else>>
moves away from your <<breasts>><<set $tentacle12head to 0>><<set $breastuse to 0>>
<</if>>
<</if>>
<<if $tentacle12head is "mouthdeep">>
and up into your mouth where it spurts a sweet fluid down your throat at the apex of each thrust.<<set $purity -= 1>><<internalejac>><<sex 5>><<set $drugged += 3>><<set $mouthgoo += 1>><<set $tentacle12health -= 1>>
<</if>>
<<if $tentacle12head is "mouth">>
and continues thrusting into your mouth.<span class="pink"> The tip opens and begins oozing a sweet liquid.</span><<set $purity -= 1>><<internalejac>><<set $mouthstate to "tentacledeep">><<set $tentacle12head to "mouthdeep">><<sex 5>><<oralejacstat>><<ejacstat>>
<</if>>
<<if $tentacle12head is "mouthimminent">>
<<if $oralvirginity is 1>>
<span class="pink"> and thrusts between your lips,</span><span class="red"> penetrating your mouth for the first time.</span><<set $oralvirginity to 0>><<violence 5>>
<<else>>
<span class="pink"> and thrusts between your lips.</span>
<</if>>
<<set $mouthstate to "tentacle">><<set $tentacle12head to "mouth">><<sex 5>><<raped>><<oralstat>>
<</if>>
<<if $tentacle12head is "mouthentrance">>
<span class="purple"> and presses against your lips.</span><<set $mouthstate to "tentacleimminent">><<set $tentacle12head to "mouthimminent">><<neutral 4>>
<</if>>
<<if $tentacle12head is "vaginadeep">>
and <<slithers>> into your <<pussy>> where it pumps a viscous fluid at the apex of each thrust.<<set $purity -= 1>><<internalejac>><<sex 5>><<set $drugged += 3>><<set $vaginagoo += 1>><<set $tentacle12health -= 1>>
<</if>>
<<if $tentacle12head is "vagina">>
and continues thrusting into your <<pussystop>><span class="pink"> The tip opens and begins oozing a viscous liquid.</span><<set $purity -= 1>><<internalejac>><<set $vaginastate to "tentacledeep">><<set $tentacle12head to "vaginadeep">><<sex 5>><<vaginalejacstat>><<ejacstat>>
<</if>>
<<if $tentacle12head is "vaginaimminent">>
<<if $vaginalvirginity is 1>>
<span class="pink"> and thrusts into your <<pussycomma>></span><span class="red"> tearing your hymen and forever robbing you of your purity.</span><<set $vaginalvirginity to 0>><<violence 100>>
<<else>>
<span class="pink"> and thrusts into your <<pussystop>></span>
<</if>>
<<set $vaginastate to "tentacle">><<set $tentacle12head to "vagina">><<sex 5>><<raped>><<vaginaraped>><<vaginalstat>><<violence 1>>
<</if>>
<<if $tentacle12head is "vaginaentrance">>
<<if $undertype isnot "chastity">>
<span class="purple"> and presses against your <<pussycomma>> about to penetrate.</span><<set $vaginastate to "tentacleimminent">><<set $tentacle12head to "vaginaimminent">><<neutral 4>>
<<else>>
and tries to find a way inside. Failing, it lashes at the metal.<<set $underintegrity -= 10>><<violence 1>>
<</if>>
<</if>>
<<if $tentacle12head is "penisdeep">>
and continues thrusting against your <<peniscomma>> caressing and kneading your length.<<sex 5>>
<</if>>
<<if $tentacle12head is "penis">>
and continues thrusting against your <<penisstop>><span class="pink"> It sucks and kneads your length, trying to milk you of your cum.</span><<set $penisstate to "tentacledeep">><<set $tentacle12head to "penisdeep">><<sex 5>>
<</if>>
<<if $tentacle12head is "penisimminent">>
<<if $penilevirginity is 1>>
<span class="pink"> and thrusts against your <<peniscomma>> swallowing you to the base and </span><span class="red"> tearing the membrane between your glans and foreskin, forever robbing you of your purity.</span><<set $penilevirginity to 0>><<violence 100>>
<<else>>
<span class="pink"> and thrusts against your <<peniscomma>> swallowing you to the base.</span>
<</if>>
<<set $penisstate to "tentacle">><<set $tentacle12head to "penis">><<sex 5>><<raped>><<penisraped>><<penilestat>><<violence 1>>
<</if>>
<<if $tentacle12head is "penisentrance">>
<<if $undertype isnot "chastity">>
<span class="purple"> and <<slithers>> over to your <<penisstop>> The tip opens and presses against your glans, about to envelop you.</span><<set $penisstate to "tentacleimminent">><<set $tentacle12head to "penisimminent">><<neutral 4>>
<<else>>
and tries to find a way inside. Failing, it lashes at the metal.<<set $underintegrity -= 10>><<violence 1>>
<</if>>
<</if>>
<<if $tentacle12head is "anusdeep">>
and <<slithers>> into your <<bottom>> where it pumps a viscous fluid at the apex of each thrust.<<set $purity -= 1>><<internalejac>><<sex 5>><<set $drugged += 3>><<set $anusgoo += 1>><<set $tentacle12health -= 1>>
<</if>>
<<if $tentacle12head is "anus">>
and continues thrusting into your <<bottomstop>><span class="pink"> The tip opens and begins oozing a viscous liquid.</span><<set $purity -= 1>><<internalejac>><<set $anusstate to "tentacledeep">><<set $tentacle12head to "anusdeep">><<sex 5>><<analejacstat>><<ejacstat>>
<</if>>
<<if $tentacle12head is "anusimminent">>
<<if $analvirginity is 1>>
<span class="pink"> and thrusts into your <<bottomcomma>></span><span class="red"> violating you in a way you hadn't conceived of.</span><<set $analvirginity to 0>><<violence 100>>
<<else>>
<span class="pink"> and thrusts into your <<bottomstop>></span>
<</if>>
<<set $anusstate to "tentacle">><<set $tentacle12head to "anus">><<sex 5>><<raped>><<analstat>><<violence 1>>
<</if>>
<<if $tentacle12head is "anusentrance">>
<<if $analshield is 0>>
<span class="purple"> and presses against your <<bottomcomma>> about to penetrate.</span><<set $anusstate to "tentacleimminent">><<set $tentacle12head to "anusimminent">><<neutral 4>>
<<else>>
and tries to find a way inside. Failing, it lashes at the device.<<set $underintegrity -= 10>><<violence 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $tentacle12head is "vaginarub">>
<<if $rng gte 21>>
and between your thighs where it <<slithers>> against your <<pussycomma>> pressing against your clit.<<sex 3>>
<<else>>
and between your thighs <span class="blue">where it <<slithers>> toward your <<pussystop>></span><<neutral 3>><<set $vaginause to "tentacle">><<set $vaginastate to "tentacleentrance">><<set $tentacle12head to "vaginaentrance">><<set $thighuse to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $tentacle12head is "penisrub">>
<<if $rng gte 21>>
and between your thighs where it <<slithers>> against your <<peniscomma>> coiling around it.<<sex 3>>
<<else>>
and between your thighs <span class="blue">where the tip opens and it <<slithers>> toward your <<penisstop>></span><<neutral 3>><<set $penisuse to "tentacle">><<set $penisstate to "tentacleentrance">><<set $tentacle12head to "penisentrance">><<set $thighuse to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $tentacle12head is "bottomrub">>
<<if $rng gte 21>>
and between your <<bottom>> cheeks where it <<slithers>> against your back.<<sex 3>>
<<else>>
and between your <<bottom>> cheeks, <span class="blue"> toward your anus.</span><<neutral 3>><<set $anususe to "tentacle">><<set $anusstate to "tentacleentrance">><<set $tentacle12head to "anusentrance">><<set $bottomuse to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $tentacle12head is 0 and $tentacle12shaft isnot 0>>
<<if $rng lte 10>>
<<if $chestuse is "squeezed" and $breastuse is 0>>
<<upperslither>><span class="blue">and up between your squeezed <<breastsstop>></span><<set $tentacle12head to "chest">><<neutral 2>><<set $breastuse to "tentacle">><<cheststat>>
<<else>>
<<tentacle12default>>
<</if>>
<<elseif $rng lte 20>>
<<if $leftnipple is 0>>
<<upperslither>> <span class="blue">and teases your left nipple.</span><<neutral 2>><<set $tentacle12head to "leftnipple">><<set $leftnipple to "tentacle">>
<<else>>
<<tentacle12default>>
<</if>>
<<elseif $rng lte 30>>
<<if $rightnipple is 0>>
<<upperslither>> <span class="blue">and teases your right nipple.</span><<neutral 2>><<set $tentacle12head to "rightnipple">><<set $rightnipple to "tentacle">>
<<else>>
<<tentacle12default>>
<</if>>
<<elseif $rng lte 40>>
<<if $mouthuse is 0>>
<<upperslither>> <span class="blue">and up toward your mouth.</span><<neutral 2>><<set $mouthuse to "tentacle">><<set $mouthstate to "tentacleentrance">><<set $tentacle12head to "mouthentrance">>
<<else>>
<<tentacle12default>>
<</if>>
<<elseif $rng lte 50>>
<<if $anususe is 0 and $analdisable is "f">>
<<underslither>> <span class="blue">and <<slithers>> toward your <<bottomstop>></span><<neutral 2>><<set $anususe to "tentacle">><<set $anusstate to "tentacleentrance">><<set $tentacle12head to "anusentrance">>
<<else>>
<<tentacle12default>>
<</if>>
<<elseif $rng lte 60>>
<<if $vaginaexist is 1 and $vaginause is 0>>
<<underslither>> <span class="blue">and <<slithers>> toward your <<pussystop>></span><<neutral 2>><<set $vaginause to "tentacle">><<set $vaginastate to "tentacleentrance">><<set $tentacle12head to "vaginaentrance">>
<<else>>
<<tentacle12default>>
<</if>>
<<elseif $rng lte 70>>
<<if $penisexist is 1 and $penisuse is 0>>
<<underslither>> <span class="blue">and <<slithers>> toward your <<penisstop>></span><<neutral 2>><<set $penisuse to "tentacle">><<set $penisstate to "tentacleentrance">><<set $tentacle12head to "penisentrance">>
<<else>>
<<tentacle12default>>
<</if>>
<<elseif $rng lte 80>>
<<if $thighuse is 0>>
<<if $penisexist is 1 and $penisuse is 0>>
<<underslither>> <span class="blue">and <<slithers>> between your thighs and against your tummy and <<penisstop>></span><<set $penisuse to "tentaclerub">><<set $thighuse to "tentaclerub">><<set $tentacle12head to "penisrub">><<sex 3>><<thighstat>>
<<elseif $vaginaexist is 1 and $vaginause is 0>>
<<underslither>> <span class="blue">and <<slithers>> between your thighs and against your tummy and <<pussystop>></span><<set $vaginause to "tentaclerub">><<set $thighuse to "tentaclerub">><<set $tentacle12head to "vaginarub">><<sex 3>><<thighstat>>
<<else>>
<<tentacle12default>>
<</if>>
<<else>>
<<tentacle12default>>
<</if>>
<<elseif $rng lte 90>>
<<if $bottomuse is 0 and $anususe is 0 and $analdisable is "f">>
<<underslither>> <span class="blue">and <<slithers>> between your <<bottom>> cheeks and against your back.</span><<set $bottomuse to "tentaclerub">><<set $anususe to "tentaclerub">><<set $tentacle12head to "bottomrub">><<sex 1>><<bottomstat>>
<<else>>
<<tentacle12default>>
<</if>>
<<else>>
<<tentacle12default>>
<</if>>
<<elseif $tentacle12head is 0 and $tentacle12shaft is 0>>
<<if $rng lte 10>>
<<if $position isnot "wall">>
The $tentacle12 tentacle winds around your tummy.<<neutral 1>><<set $tentacle12shaft to "tummy">>
<<else>>
The $tentacle12 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<elseif $rng lte 20>>
The $tentacle12 tentacle <<slithers>> between your thighs.<<neutral 1>><<set $tentacle12shaft to "thighs">>
<<elseif $rng lte 30>>
<<if $position isnot "wall">>
<<if $breastsize gte 2 and $chestuse is 0>>
The $tentacle12 tentacle <<slithers>> around your <<breastscomma>> <span class="blue">squeezing them together.</span><<neutral 1>><<set $tentacle12shaft to "breasts">><<set $chestuse to "squeezed">>
<<else>>
The $tentacle12 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<else>>
The $tentacle12 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<elseif $rng lte 40>>
<<if $position isnot "wall">>
The $tentacle12 tentacle winds its way around your chest, beneath your <<breastsstop>><<neutral 1>><<set $tentacle12shaft to "chest">>
<<else>>
The $tentacle12 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<elseif $rng lte 50>>
The $tentacle12 tentacle winds its way around your waist.<<neutral 1>><<set $tentacle12shaft to "waist">>
<<elseif $rng lte 60>>
<<if $position isnot "wall">>
<<if $head is 0>>
The $tentacle12 tentacle winds its way around your neck, <span class="blue">restraining your head.</span><<neutral 1>><<set $tentacle12shaft to "neck">><<set $head to "grappled">>
<<else>>
The $tentacle12 tentacle winds its way around your shoulders.<<neutral 1>><<set $tentacle12shaft to "shoulders">>
<</if>>
<<else>>
The $tentacle12 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<elseif $rng lte 70>>
The $tentacle12 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<<elseif $rng lte 80>>
<<if $leftleg is 0>>
The $tentacle12 tentacle winds its way around your left leg, <span class="blue">restraining it.</span><<neutral 1>><<feettentacledisable>><<set $tentacle12shaft to "leftleg">><<set $leftleg to "grappled">>
<<else>>
The $tentacle12 tentacle tickles your feet.<<neutral 1>>
<</if>>
<<elseif $rng lte 85>>
<<if $rightleg is 0>>
The $tentacle12 tentacle winds its way around your right leg, <span class="blue">restraining it.</span><<neutral 1>><<feettentacledisable>><<set $tentacle12shaft to "rightleg">><<set $rightleg to "grappled">>
<<else>>
The $tentacle12 tentacle tickles your feet.<<neutral 1>>
<</if>>
<<elseif $rng lte 90>>
<<if $leftarm is 0>>
The $tentacle12 tentacle winds its way around your left arm, <span class="blue">restraining it.</span><<neutral 1>><<leftarmtentacledisable>><<set $tentacle12shaft to "leftarm">><<set $leftarm to "grappled">><<set $leftarmstate to 0>>
<<else>>
The $tentacle12 tentacle tickles your armpit.<<neutral 1>>
<</if>>
<<elseif $rng lte 95>>
<<if $rightarm is 0>>
The $tentacle12 tentacle winds its way around your right arm, <span class="blue">restraining it.</span><<rightarmtentacledisable>><<neutral 1>><<set $tentacle12shaft to "rightarm">><<set $rightarm to "grappled">><<set $rightarmstate to 0>>
<<else>>
The $tentacle12 tentacle tickles your armpit.<<neutral 1>>
<</if>>
<<elseif $rng lte 100>>
The $tentacle12 tentacle <<slithers>> against your <<bottomstop>><<neutral 1>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "tentacle12default">><<nobr>>
<<set $rng to random(1, 100)>>
<<if $rng gte 90>>
then squirts a warm fluid over your neck.<<neutral 1>><<set $neckgoo += 1>><<set $tentacle12health -= 1>><<neckejacstat>><<ejacstat>>
<<elseif $rng gte 80>>
then squirts a warm fluid over your right arm.<<neutral 1>><<set $rightarmgoo += 1>><<set $tentacle12health -= 1>><<handejacstat>><<ejacstat>>
<<elseif $rng gte 70>>
then squirts a warm fluid over your left arm.<<neutral 1>><<set $leftarmgoo += 1>><<set $tentacle12health -= 1>><<handejacstat>><<ejacstat>>
<<elseif $rng gte 60>>
then squirts a warm fluid over your thighs.<<neutral 1>><<set $thighgoo += 1>><<set $tentacle12health -= 1>><<thighejacstat>><<ejacstat>>
<<elseif $rng gte 50>>
then squirts a warm fluid over your <<bottomstop>><<neutral 1>><<set $bottomgoo += 1>><<set $tentacle12health -= 1>><<bottomejacstat>><<ejacstat>>
<<elseif $rng gte 40>>
then squirts a warm fluid over your tummy.<<neutral 1>><<set $tummygoo += 1>><<set $tentacle12health -= 1>><<tummyejacstat>><<ejacstat>>
<<elseif $rng gte 30>>
then squirts a warm fluid over your chest.<<neutral 1>><<set $chestgoo += 1>><<set $tentacle12health -= 1>><<chestejacstat>><<ejacstat>>
<<elseif $rng gte 20>>
then squirts a warm fluid over your face.<<neutral 1>><<set $facegoo += 1>><<set $tentacle12health -= 1>><<faceejacstat>><<ejacstat>>
<<elseif $rng gte 10>>
then squirts a warm fluid over your hair.<<neutral 1>><<set $hairgoo += 1>><<set $tentacle12health -= 1>><<hairejacstat>><<ejacstat>>
<<else>>
then squirts a warm fluid over your feet.<<neutral 1>><<set $feetgoo += 1>><<set $tentacle12health -= 1>><<feetejacstat>><<ejacstat>>
<</if>>
<</nobr>><</widget>>
<<widget "tentacle12disable">><<nobr>>
<<if $tentacle12head is "feet">>
<<set $leftleg to 0>>
<<set $rightleg to 0>>
<<set $feetstate to 0>>
<</if>>
<<if $tentacle12head is "leftarm">>
<<set $leftarm to 0>>
<<set $leftarmstate to 0>>
<</if>>
<<if $tentacle12head is "rightarm">>
<<set $rightarm to 0>>
<<set $rightarmstate to 0>>
<</if>>
<<if $tentacle12head is "leftnipplesuck">>
<<set $leftnipple to 0>>
<</if>>
<<if $tentacle12head is "rightnipplesuck">>
<<set $rightnipple to 0>>
<</if>>
<<if $tentacle12head is "leftnipple">>
<<set $leftnipple to 0>>
<</if>>
<<if $tentacle12head is "rightnipple">>
<<set $rightnipple to 0>>
<</if>>
<<if $tentacle12head is "chest">>
<<set $chestuse to 0>>
<</if>>
<<if $tentacle12head is "mouthentrance">>
<<set $mouthuse to 0>>
<<set $mouthstate to 0>>
<</if>>
<<if $tentacle12head is "mouthimminent">>
<<set $mouthuse to 0>>
<<set $mouthstate to 0>>
<</if>>
<<if $tentacle12head is "mouth">>
<<set $mouthuse to 0>>
<<set $mouthstate to 0>>
<</if>>
<<if $tentacle12head is "mouthdeep">>
<<set $mouthuse to 0>>
<<set $mouthstate to 0>>
<</if>>
<<if $tentacle12head is "anusentrance">>
<<set $anususe to 0>>
<<set $anusstate to 0>>
<</if>>
<<if $tentacle12head is "anusimminent">>
<<set $anususe to 0>>
<<set $anusstate to 0>>
<</if>>
<<if $tentacle12head is "anus">>
<<set $anususe to 0>>
<<set $anusstate to 0>>
<</if>>
<<if $tentacle12head is "anusdeep">>
<<set $anususe to 0>>
<<set $anusstate to 0>>
<</if>>
<<if $tentacle12head is "vaginaentrance">>
<<set $vaginause to 0>>
<<set $vaginastate to 0>>
<</if>>
<<if $tentacle12head is "vaginaimminent">>
<<set $vaginause to 0>>
<<set $vaginastate to 0>>
<</if>>
<<if $tentacle12head is "vagina">>
<<set $vaginause to 0>>
<<set $vaginastate to 0>>
<</if>>
<<if $tentacle12head is "vaginadeep">>
<<set $vaginause to 0>>
<<set $vaginastate to 0>>
<</if>>
<<if $tentacle12head is "penisentrance">>
<<set $penisuse to 0>>
<<set $penisstate to 0>>
<</if>>
<<if $tentacle12head is "penisimminent">>
<<set $penisuse to 0>>
<<set $penisstate to 0>>
<</if>>
<<if $tentacle12head is "penis">>
<<set $penisuse to 0>>
<<set $penisstate to 0>>
<</if>>
<<if $tentacle12head is "penisdeep">>
<<set $penisuse to 0>>
<<set $penisstate to 0>>
<</if>>
<<if $tentacle12head is "vaginarub">>
<<set $vaginause to 0>>
<<set $thighuse to 0>>
<</if>>
<<if $tentacle12head is "penisrub">>
<<set $penisuse to 0>>
<<set $thighuse to 0>>
<</if>>
<<if $tentacle12head is "bottomrub">>
<<set $anususe to 0>>
<<set $bottomuse to 0>>
<</if>>
<<if $tentacle12shaft is "breasts">>
<<set $chestuse to 0>>
<</if>>
<<if $tentacle12shaft is "neck" and $head isnot "bound">>
<<set $head to 0>>
<</if>>
<<if $tentacle12shaft is "leftleg" and $leftleg isnot "bound">>
<<set $leftleg to 0>>
<</if>>
<<if $tentacle12shaft is "rightleg" and $rightleg isnot "bound">>
<<set $rightleg to 0>>
<</if>>
<<if $tentacle12shaft is "leftarm" and $leftarm isnot "bound">>
<<set $leftarm to 0>>
<</if>>
<<if $tentacle12shaft is "rightarm" and $rightarm isnot "bound">>
<<set $rightarm to 0>>
<</if>>
<<if $tentacle12head is "chest">>
<<set $breastuse to 0>>
<</if>>
<<set $tentacle12shaft to 0>>
<<set $tentacle12head to 0>>
<</nobr>><</widget>>
<<widget "actionstentacle12lefthand">><<nobr>>
<<if $leftarm is 0 and $tentacle12shaft isnot "finished">>
<<if $leftactiondefault is "lefthittentacle12">>
| <label><span class="def">Strike the $tentacle12 tentacle</span> <<radiobutton "$leftaction" "lefthittentacle12" checked>></label>
<<else>>
| <label><span class="def">Strike the $tentacle12 tentacle</span> <<radiobutton "$leftaction" "lefthittentacle12">></label>
<</if>>
<<if $leftactiondefault is "leftgrabtentacle12">>
| <label><span class="sub">Grab the $tentacle12 tentacle</span> <<radiobutton "$leftaction" "leftgrabtentacle12" checked>></label>
<<else>>
| <label><span class="sub">Grab the $tentacle12 tentacle</span> <<radiobutton "$leftaction" "leftgrabtentacle12">></label>
<</if>>
<<elseif $leftarm is "tentacle12">>You hold the $tentacle12 tentacle in your left hand.<br>
<<if $leftactiondefault is "leftrubtentacle12">>
| <label><span class="sub">Milk it</span> <<radiobutton "$leftaction" "leftrubtentacle12" checked>></label>
<<else>>
| <label><span class="sub">Milk it</span> <<radiobutton "$leftaction" "leftrubtentacle12">></label>
<</if>>
<<if $leftactiondefault is "leftstoptentacle12">>
| <label><span class="neutral">Let go</span> <<radiobutton "$leftaction" "leftstoptentacle12" checked>></label>
<<else>>
| <label><span class="neutral">Let go</span> <<radiobutton "$leftaction" "leftstoptentacle12">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle12righthand">><<nobr>>
<<if $rightarm is 0 and $tentacle12shaft isnot "finished">>
<<if $rightactiondefault is "righthittentacle12">>
| <label><span class="def">Strike the $tentacle12 tentacle</span> <<radiobutton "$rightaction" "righthittentacle12" checked>></label>
<<else>>
| <label><span class="def">Strike the $tentacle12 tentacle</span> <<radiobutton "$rightaction" "righthittentacle12">></label>
<</if>>
<<if $rightactiondefault is "rightgrabtentacle12">>
| <label><span class="sub">Grab the $tentacle12 tentacle</span> <<radiobutton "$rightaction" "rightgrabtentacle12" checked>></label>
<<else>>
| <label><span class="sub">Grab the $tentacle12 tentacle</span> <<radiobutton "$rightaction" "rightgrabtentacle12">></label>
<</if>>
<<elseif $rightarm is "tentacle12">>You hold the $tentacle12 tentacle in your right hand.<br>
<<if $rightactiondefault is "rightrubtentacle12">>
| <label><span class="sub">Milk it</span> <<radiobutton "$rightaction" "rightrubtentacle12" checked>></label>
<<else>>
| <label><span class="sub">Milk it</span> <<radiobutton "$rightaction" "rightrubtentacle12">></label>
<</if>>
<<if $rightactiondefault is "rightstoptentacle12">>
| <label><span class="neutral">Let go</span> <<radiobutton "$rightaction" "rightstoptentacle12" checked>></label>
<<else>>
| <label><span class="neutral">Let go</span> <<radiobutton "$rightaction" "rightstoptentacle12">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle12legs">><<nobr>>
<<if $leftleg is 0 and $rightleg is 0 and $tentacle12shaft isnot "finished">>
<<if $feetactiondefault is "feethittentacle12">>
| <label><span class="def">Kick the $tentacle12 tentacle</span> <<radiobutton "$feetaction" "feethittentacle12" checked>></label>
<<else>>
| <label><span class="def">Kick the $tentacle12 tentacle</span> <<radiobutton "$feetaction" "feethittentacle12">></label>
<</if>>
<<if $feetactiondefault is "feetgrabtentacle12">>
| <label><span class="sub">Grab the $tentacle12 tentacle</span> <<radiobutton "$feetaction" "feetgrabtentacle12" checked>></label>
<<else>>
| <label><span class="sub">Grab the $tentacle12 tentacle</span> <<radiobutton "$feetaction" "feetgrabtentacle12">></label>
<</if>>
<<elseif $leftleg is 0 and $tentacle12shaft isnot "finished">>
<<if $feetactiondefault is "feethittentacle12">>
| <label><span class="def">Kick the $tentacle12 tentacle</span> <<radiobutton "$feetaction" "feethittentacle12" checked>></label>
<<else>>
| <label><span class="def">Kick the $tentacle12 tentacle</span> <<radiobutton "$feetaction" "feethittentacle12">></label>
<</if>>
<<elseif $rightleg is 0 and $tentacle12shaft isnot "finished">>
<<if $feetactiondefault is "feethittentacle12">>
| <label><span class="def">Kick the $tentacle12 tentacle</span> <<radiobutton "$feetaction" "feethittentacle12" checked>></label>
<<else>>
| <label><span class="def">Kick the $tentacle12 tentacle</span> <<radiobutton "$feetaction" "feethittentacle12">></label>
<</if>>
<<elseif $leftleg is "tentacle12">>You hold the $tentacle12 tentacle between your feet.<br>
<<if $feetactiondefault is "feetrubtentacle12">>
| <label><span class="sub">Milk it</span> <<radiobutton "$feetaction" "feetrubtentacle12" checked>></label>
<<else>>
| <label><span class="sub">Milk it</span> <<radiobutton "$feetaction" "feetrubtentacle12">></label>
<</if>>
<<if $feetactiondefault is "feetstoptentacle12">>
| <label><span class="neutral">Let go</span> <<radiobutton "$feetaction" "feetstoptentacle12" checked>></label>
<<else>>
| <label><span class="neutral">Let go</span> <<radiobutton "$feetaction" "feetstoptentacle12">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle12mouth">><<nobr>>
<<if $tentacle12head is "mouthentrance">>
<<if $mouthactiondefault is "mouthlicktentacle12">>
| <label><span class="sub">Lick it</span> <<radiobutton "$mouthaction" "mouthlicktentacle12" checked>></label>
<<else>>
| <label><span class="sub">Lick it</span> <<radiobutton "$mouthaction" "mouthlicktentacle12">></label>
<</if>>
<<if $head is "grappled">>
<<else>>
<<if $mouthactiondefault is "mouthpullawaytentacle12">>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "mouthpullawaytentacle12" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "mouthpullawaytentacle12">></label>
<</if>>
<</if>>
<<elseif $tentacle12head is "mouthimminent">>
<<if $mouthactiondefault is "mouthkisstentacle12">>
| <label><span class="sub">Kiss it</span> <<radiobutton "$mouthaction" "mouthkisstentacle12" checked>></label>
<<else>>
| <label><span class="sub">Kiss it</span> <<radiobutton "$mouthaction" "mouthkisstentacle12">></label>
<</if>>
<<if $head is "grappled">>
<<else>>
<<if $mouthactiondefault is "mouthpullawaytentacle12">>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "mouthpullawaytentacle12" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "mouthpullawaytentacle12">></label>
<</if>>
<</if>>
<<elseif $tentacle12head is "mouth">>
<<if $mouthactiondefault is "mouthcooperatetentacle12">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$mouthaction" "mouthcooperatetentacle12" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$mouthaction" "mouthcooperatetentacle12">></label>
<</if>>
<<if $mouthactiondefault is "mouthbitetentacle12">>
| <label><span class="def">Bite</span> <<radiobutton "$mouthaction" "mouthbitetentacle12" checked>></label>
<<else>>
| <label><span class="def">Bite</span> <<radiobutton "$mouthaction" "mouthbitetentacle12">></label>
<</if>>
<<elseif $tentacle12head is "mouthdeep">>
<<if $mouthactiondefault is "mouthcooperatetentacle12">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$mouthaction" "mouthcooperatetentacle12" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$mouthaction" "mouthcooperatetentacle12">></label>
<</if>>
<<if $mouthactiondefault is "mouthbitetentacle12">>
| <label><span class="def">Bite</span> <<radiobutton "$mouthaction" "mouthbitetentacle12" checked>></label>
<<else>>
| <label><span class="def">Bite</span> <<radiobutton "$mouthaction" "mouthbitetentacle12">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle12vagina">><<nobr>>
<<if $tentacle12head is "vaginaentrance">>
<<if $vaginaactiondefault is "vaginarubtentacle12">>
| <label><span class="sub">Rub</span> <<radiobutton "$vaginaaction" "vaginarubtentacle12" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$vaginaaction" "vaginarubtentacle12">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $vaginaactiondefault is "vaginapullawaytentacle12">>
| <label><span class="brat">Pull away</span> <<radiobutton "$vaginaaction" "vaginapullawaytentacle12" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$vaginaaction" "vaginapullawaytentacle12">></label>
<</if>>
<</if>>
<<elseif $tentacle12head is "vaginaimminent">>
<<if $vaginaactiondefault is "vaginarubtentacle12">>
| <label><span class="sub">Rub</span> <<radiobutton "$vaginaaction" "vaginarubtentacle12" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$vaginaaction" "vaginarubtentacle12">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $vaginaactiondefault is "vaginapullawaytentacle12">>
| <label><span class="brat">Pull away</span> <<radiobutton "$vaginaaction" "vaginapullawaytentacle12" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$vaginaaction" "vaginapullawaytentacle12">></label>
<</if>>
<</if>>
<<elseif $tentacle12head is "vagina">>
<<if $vaginaactiondefault is "vaginacooperatetentacle12">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$vaginaaction" "vaginacooperatetentacle12" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$vaginaaction" "vaginacooperatetentacle12">></label>
<</if>>
<<elseif $tentacle12head is "vaginadeep">>
<<if $vaginaactiondefault is "vaginacooperatetentacle12">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$vaginaaction" "vaginacooperatetentacle12" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$vaginaaction" "vaginacooperatetentacle12">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle12penis">><<nobr>>
<<if $tentacle12head is "penisentrance">>
<<if $penisactiondefault is "penisrubtentacle12">>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "penisrubtentacle12" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "penisrubtentacle12">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $penisactiondefault is "penispullawaytentacle12">>
| <label><span class="brat">Pull away</span> <<radiobutton "$penisaction" "penispullawaytentacle12" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$penisaction" "penispullawaytentacle12">></label>
<</if>>
<</if>>
<<elseif $tentacle12head is "penisimminent">>
<<if $penisactiondefault is "penisrubtentacle12">>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "penisrubtentacle12" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "penisrubtentacle12">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $penisactiondefault is "penispullawaytentacle12">>
| <label><span class="brat">Pull away</span> <<radiobutton "$penisaction" "penispullawaytentacle12" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$penisaction" "penispullawaytentacle12">></label>
<</if>>
<</if>>
<<elseif $tentacle12head is "penis">>
<<if $penisactiondefault is "peniscooperatetentacle12">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$penisaction" "peniscooperatetentacle12" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$penisaction" "peniscooperatetentacle12">></label>
<</if>>
<<elseif $tentacle12head is "penisdeep">>
<<if $penisactiondefault is "peniscooperatetentacle12">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$penisaction" "peniscooperatetentacle12" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$penisaction" "peniscooperatetentacle12">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle12anus">><<nobr>>
<<if $tentacle12head is "anusentrance">>
<<if $anusactiondefault is "anusrubtentacle12">>
| <label><span class="sub">Rub</span> <<radiobutton "$anusaction" "anusrubtentacle12" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$anusaction" "anusrubtentacle12">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $anusactiondefault is "anuspullawaytentacle12">>
| <label><span class="brat">Pull away</span> <<radiobutton "$anusaction" "anuspullawaytentacle12" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$anusaction" "anuspullawaytentacle12">></label>
<</if>>
<</if>>
<<elseif $tentacle12head is "anusimminent">>
<<if $anusactiondefault is "anusrubtentacle12">>
| <label><span class="sub">Rub</span> <<radiobutton "$anusaction" "anusrubtentacle12" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$anusaction" "anusrubtentacle12">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $anusactiondefault is "anuspullawaytentacle12">>
| <label><span class="brat">Pull away</span> <<radiobutton "$anusaction" "anuspullawaytentacle12" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$anusaction" "anuspullawaytentacle12">></label>
<</if>>
<</if>>
<<elseif $tentacle12head is "anus">>
<<if $anusactiondefault is "anuscooperatetentacle12">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$anusaction" "anuscooperatetentacle12" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$anusaction" "anuscooperatetentacle12">></label>
<</if>>
<<elseif $tentacle12head is "anusdeep">>
<<if $anusactiondefault is "anuscooperatetentacle12">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$anusaction" "anuscooperatetentacle12" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$anusaction" "anuscooperatetentacle12">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle12thighs">><<nobr>>
<<if $tentacle12head is "penisrub">>
<<if $thighactiondefault is "penisrubtentacle12">>
| <label><span class="sub">Rub</span> <<radiobutton "$thighaction" "penisrubtentacle12" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$thighaction" "penisrubtentacle12">></label>
<</if>>
<<elseif $tentacle12head is "vaginarub">>
<<if $thighactiondefault is "vaginarubtentacle12">>
| <label><span class="sub">Rub</span> <<radiobutton "$thighaction" "vaginarubtentacle12" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$thighaction" "vaginarubtentacle12">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle12bottom">><<nobr>>
<<if $tentacle12head is "bottomrub">>
<<if $bottomactiondefault is "bottomrubtentacle12">>
| <label><span class="sub">Rub</span> <<radiobutton "$bottomaction" "bottomrubtentacle12" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$bottomaction" "bottomrubtentacle12">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle12chest">><<nobr>>
<<if $tentacle12head is "chest">>
<<if $chestactiondefault is "chestrubtentacle12">>
| <label><span class="sub">Rub</span> <<radiobutton "$chestaction" "chestrubtentacle12" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$chestaction" "chestrubtentacle12">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "effectstentacle12">><<nobr>>
<<if $leftaction is "lefthittentacle12">><<set $leftaction to 0>><<set $leftactiondefault to "lefthittentacle12">>You strike the $tentacle12 tentacle with your left hand and it reels away from you.<<defiance 2>><<set $speechhit to 1>><<tentacle12disable>><<set $attackstat += 1>><<set $tentacle12health -= 1>>
<<if $rng lte ($physique / 200)>>
<<set $tentacle12health -= 1>>
<</if>>
<</if>>
<<if $rightaction is "righthittentacle12">><<set $rightaction to 0>><<set $rightactiondefault to "righthittentacle12">>You strike the $tentacle12 tentacle with your right hand and it reels away from you.<<defiance 2>><<set $speechhit to 1>><<tentacle12disable>><<set $attackstat += 1>><<set $tentacle12health -= 1>>
<<if $rng lte ($physique / 200)>>
<<set $tentacle12health -= 1>>
<</if>>
<</if>>
<<if $leftaction is "leftgrabtentacle12">><<set $leftaction to 0>><<set $leftactiondefault to "leftrubtentacle12">><<submission 1>><<handstat>><span class="lblue">You <<handtext>> grab the $tentacle12 tentacle with your left hand.</span><<tentacle12disable>><<set $leftarm to "tentacle12">><<set $tentacle12head to "leftarm">><<handstat>><<set $leftarmstate to "tentacle">>
<</if>>
<<if $rightaction is "rightgrabtentacle12">><<set $rightaction to 0>><<set $rightactiondefault to "rightrubtentacle12">><<submission 1>><<handstat>><span class="lblue">You <<handtext>> grab the $tentacle12 tentacle with your right hand.</span><<tentacle12disable>><<set $rightarm to "tentacle12">><<set $tentacle12head to "rightarm">><<handstat>><<set $rightarmstate to "tentacle">>
<</if>>
<<if $leftaction is "leftrubtentacle12">><<set $leftaction to 0>><<set $leftactiondefault to "leftrubtentacle12">><<handskilluse>><<submission 1>>You <<handtext>> squeeze the $tentacle12 tentacle in your left hand and rub up and down its length.<<set $rng to random(1, 100)>>
<<if $handskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $rightarmgoo += 1>><<set $tentacle12health -= 3>><<handejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $rightaction is "rightrubtentacle12">><<set $rightaction to 0>><<set $rightactiondefault to "rightrubtentacle12">><<handskilluse>><<submission 1>>You <<handtext>> squeeze the $tentacle12 tentacle in your right hand and rub up and down its length.<<set $rng to random(1, 100)>>
<<if $handskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $rightarmgoo += 1>><<set $tentacle12health -= 3>><<handejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $leftaction is "leftstoptentacle12">><<set $leftaction to 0>><<set $leftactiondefault to "leftstoptentacle12">>You release the $tentacle12 tentacle from your left hand.<<tentacle12disable>>
<</if>>
<<if $rightaction is "rightstoptentacle12">><<set $rightaction to 0>><<set $rightactiondefault to "rightstoptentacle12">>You release the $tentacle12 tentacle from your right hand.<<tentacle12disable>>
<</if>>
<<if $feetaction is "feethittentacle12">><<set $feetaction to 0>><<set $feetactiondefault to "feethittentacle12">>You kick the $tentacle12 tentacle and it reels away from you.<<defiance 2>><<set $speechhit to 1>><<tentacle12disable>><<set $attackstat += 1>><<set $tentacle12health -= 1>>
<<if $rng lte ($physique / 200)>>
<<set $tentacle12health -= 1>>
<</if>>
<</if>>
<<if $feetaction is "feetgrabtentacle12">><<set $feetaction to 0>><<set $feetactiondefault to "feetrubtentacle12">><<submission 1>><<feetstat>><span class="lblue">You <<feettext>> grab the $tentacle12 tentacle between your feet.</span><<tentacle12disable>><<set $leftleg to "tentacle12">><<set $rightleg to "tentacle12">><<set $tentacle12head to "feet">><<feetstat>><<set $feetstate to "tentacle">>
<</if>>
<<if $feetaction is "feetrubtentacle12">><<set $feetaction to 0>><<set $feetactiondefault to "feetrubtentacle12">><<feetskilluse>><<submission 1>>You <<feettext>> squeeze the $tentacle12 tentacle between your feet and rub up and down its length.<<set $rng to random(1, 100)>>
<<if $feetskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $feetgoo += 1>><<set $tentacle12health -= 3>><<feetejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $feetaction is "feetstoptentacle12">><<set $feetaction to 0>><<set $feetactiondefault to "feetstoptentacle12">>You let go of the $tentacle12 tentacle between your feet.<<tentacle12disable>>
<</if>>
<<if $mouthaction is "mouthlicktentacle12">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthlicktentacle12">>
<<submission 2>><<oralskilluse>>You <<oraltext>> lick the tip of the $tentacle12 tentacle.<<set $rng to random(1, 100)>>
<<if $oralskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your face.</span><<set $facegoo += 1>><<set $tentacle12health -= 3>><<faceejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $mouthaction is "mouthkisstentacle12">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthkisstentacle12">>
<<submission 3>><<oralskilluse>>You <<oraltext>> kiss the tip of the $tentacle12 tentacle.<<set $rng to random(1, 100)>>
<<if $oralskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your face.</span><<set $facegoo += 1>><<set $tentacle12health -= 3>><<faceejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $mouthaction is "mouthcooperatetentacle12">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthcooperatetentacle12">>
<<sex 5>><<oralskilluse>>You <<oraltext>> suck the $tentacle12 tentacle invading your mouth.<<set $rng to random(1, 100)>>
<<if $oralskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip and into your mouth.</span><<set $tentacle12health -= 3>><<set $drugged += 3>><<set $mouthgoo += 1>><<oralejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $mouthaction is "mouthpullawaytentacle12">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthpullawaytentacle12">><<brat 1>><span class="teal">You pull away from the $tentacle12 tentacle threatening your mouth.</span><<tentacle12disable>>
<</if>>
<<if $mouthaction is "mouthbitetentacle12">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthbitetentacle12">><<defiance 5>>You bite down on the $tentacle12 tentacle invading your mouth. <span class="teal">It recoils immediately.</span><<tentacle12disable>><<set $attackstat += 1>><<set $tentacle12health -= 1>>
<<if $rng lte ($physique / 200)>>
<<set $tentacle12health -= 1>>
<</if>>
<</if>>
<<if $vaginaaction is "vaginarubtentacle12">><<set $vaginaaction to 0>><<set $vaginaactiondefault to "vaginarubtentacle12">>
<<submission 2>><<vaginalskilluse>>You <<vaginaltext>> rub the tip of the $tentacle12 tentacle with your <<pussystop>><<set $rng to random(1, 100)>>
<<if $vaginalskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $vaginaoutsidegoo += 1>><<set $tentacle12health -= 3>><<vaginalentranceejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $vaginaaction is "vaginacooperatetentacle12">><<set $vaginaaction to 0>><<set $vaginaactiondefault to "vaginacooperatetentacle12">>
<<sex 5>><<vaginalskilluse>>You <<vaginaltext>> push back against the $tentacle12 tentacle invading your <<pussystop>><<set $rng to random(1, 100)>>
<<if $vaginalskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, flooding your womb with its warmth.</span><<set $tentacle12health -= 3>><<set $drugged += 3>><<set $vaginagoo += 1>><<vaginalejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $vaginaaction is "vaginapullawaytentacle12">><<set $vaginaaction to 0>><<set $vaginaactiondefault to "vaginapullawaytentacle12">><<brat 1>><span class="teal">You pull away from the $tentacle12 tentacle threatening your <<pussystop>></span><<tentacle12disable>>
<</if>>
<<if $penisaction is "penisrubtentacle12">><<set $penisaction to 0>><<set $penisactiondefault to "penisrubtentacle12">>
<<submission 2>><<penileskilluse>>You <<peniletext>> rub the tip of the $tentacle12 tentacle with your <<penisstop>><<set $rng to random(1, 100)>>
<<if $penileskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $penisgoo += 1>><<set $tentacle12health -= 3>><<penileejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $penisaction is "peniscooperatetentacle12">><<set $penisaction to 0>><<set $penisactiondefault to "peniscooperatetentacle12">>
<<sex 5>><<penileskilluse>>You <<peniletext>> push back against the $tentacle12 tentacle engulfing your <<penisstop>><<set $rng to random(1, 100)>>
<<if $penileskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your groin.</span><<set $tentacle12health -= 3>><<set $penisgoo += 1>><<penileejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $penisaction is "penispullawaytentacle12">><<set $penisaction to 0>><<set $penisactiondefault to "penispullawaytentacle12">><<brat 1>><span class="teal">You pull away from the $tentacle12 tentacle threatening your <<penisstop>></span><<tentacle12disable>>
<</if>>
<<if $anusaction is "anusrubtentacle12">><<set $anusaction to 0>><<set $anusactiondefault to "anusrubtentacle12">>
<<submission 2>><<analskilluse>>You <<analtext>> rub the tip of the $tentacle12 tentacle with your <<bottomstop>><<set $rng to random(1, 100)>>
<<if $analskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your <<bottomstop>></span><<set $bottomgoo += 1>><<set $tentacle12health -= 3>><<bottomejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $anusaction is "anuscooperatetentacle12">><<set $anusaction to 0>><<set $anusactiondefault to "anuscooperatetentacle12">>
<<sex 5>><<analskilluse>>You <<analtext>> push back against the $tentacle12 tentacle invading your <<bottomstop>><<set $rng to random(1, 100)>>
<<if $analskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, flooding your bowels with its warmth.</span><<set $tentacle12health -= 3>><<set $drugged += 3>><<set $anusgoo += 1>><<analejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $anusaction is "anuspullawaytentacle12">><<set $anusaction to 0>><<set $anusactiondefault to "anuspullawaytentacle12">><<brat 1>><span class="teal">You pull away from the $tentacle12 tentacle threatening your <<bottomstop>></span><<tentacle12disable>>
<</if>>
<<if $thighaction is "penisrubtentacle12">><<set $thighaction to 0>><<set $thighactiondefault to "penisrubtentacle12">>
<<submission 3>><<thighskilluse>>You <<thightext>> rub the $tentacle12 tentacle between your thighs.<<set $rng to random(1, 100)>>
<<if $thighskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your tummy.</span><<set $tentacle12health -= 3>><<set $tummygoo += 1>><<tummyejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $thighaction is "vaginarubtentacle12">><<set $thighaction to 0>><<set $thighactiondefault to "vaginarubtentacle12">>
<<submission 3>><<thighskilluse>>You <<thightext>> rub the $tentacle12 tentacle between your thighs.<<set $rng to random(1, 100)>>
<<if $thighskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your tummy.</span><<set $tentacle12health -= 3>><<set $tummygoo += 1>><<tummyejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $bottomaction is "bottomrubtentacle12">><<set $bottomaction to 0>><<set $bottomactiondefault to "bottomrubtentacle12">>
<<submission 3>><<bottomskilluse>>You <<bottomtext>> rub the $tentacle12 tentacle between your cheeks.<<set $rng to random(1, 100)>>
<<if $bottomskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your <<bottomstop>></span><<set $tentacle12health -= 3>><<set $bottomgoo += 1>><<bottomejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $chestaction is "chestrubtentacle12">><<set $chestaction to 0>><<set $chestactiondefault to "chestrubtentacle12">>
<<submission 3>><<chestskilluse>>You <<chesttext>> rub the $tentacle12 tentacle between your <<breastsstop>><<set $rng to random(1, 100)>>
<<if $chestskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your chest.</span><<set $tentacle12health -= 3>><<set $chestgoo += 1>><<chestejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<</nobr>><</widget>>
:: Widgets Combat Tentacle13 [widget]
<<widget "tentacle13">><<nobr>>
<<if $tentacle13health lte 0 and $tentacle13shaft isnot "finished">>
Worn out, the $tentacle13 tentacle retracts from you.
<<tentacle13disable>>
<<set $tentacle13shaft to "finished">>
<<set $tentacle13head to "finished">>
<</if>>
<<if $tentacle13shaft is "tummy">>
The $tentacle13 tentacle <<slithers>> around your tummy,
<</if>>
<<if $tentacle13shaft is "thighs">>
The $tentacle13 tentacle <<slithers>> between your thighs,
<</if>>
<<if $tentacle13shaft is "breasts">>
The $tentacle13 tentacle squeezes your breasts together,
<</if>>
<<if $tentacle13shaft is "chest">>
The $tentacle13 tentacle <<slithers>> around your chest,
<</if>>
<<if $tentacle13shaft is "waist">>
The $tentacle13 tentacle <<slithers>> around your waist,
<</if>>
<<if $tentacle13shaft is "neck">>
The $tentacle13 tentacle <<slithers>> around your neck,
<</if>>
<<if $tentacle13shaft is "shoulders">>
The $tentacle13 tentacle <<slithers>> around your shoulders,
<</if>>
<<if $tentacle13shaft is "leftleg">>
The $tentacle13 tentacle <<slithers>> around your left leg,
<</if>>
<<if $tentacle13shaft is "rightleg">>
The $tentacle13 tentacle <<slithers>> around your right leg,
<</if>>
<<if $tentacle13shaft is "leftarm">>
The $tentacle13 tentacle <<slithers>> around your left arm,
<</if>>
<<if $tentacle13shaft is "rightarm">>
The $tentacle13 tentacle <<slithers>> around your right arm,
<</if>>
<<if $tentacle13head is "leftarm">>
The $tentacle13 tentacle writhes in your left hand.<<neutral 5>>
<</if>>
<<if $tentacle13head is "rightarm">>
The $tentacle13 tentacle writhes in your right hand.<<neutral 5>>
<</if>>
<<if $tentacle13head is "feet">>
The $tentacle13 tentacle writhes between your feet.<<neutral 5>>
<</if>>
<<if $tentacle13head is "leftnipplesuck">>
and up to your <<breastscomma>> where it suckles your left nipple.<<neutral 3>>
<</if>>
<<if $tentacle13head is "rightnipplesuck">>
and up to your <<breastscomma>> where it suckles your right nipple.<<neutral 3>>
<</if>>
<<if $tentacle13head is "leftnipple">>
and continues teasing your left nipple. <span class="purple">The tip of the tentacle opens up, latches on, then begins sucking.</span><<neutral 3>><<set $tentacle13head to "leftnipplesuck">><<set $leftnipple to "tentaclesuck">>
<</if>>
<<if $tentacle13head is "rightnipple">>
and continues teasing your right nipple. <span class="purple">The tip of the tentacle opens up, latches on, then begins sucking.</span><<neutral 3>><<set $tentacle13head to "rightnipplesuck">><<set $rightnipple to "tentaclesuck">>
<</if>>
<<if $tentacle13head is "chest">>
<<if $chestuse is "squeezed">>
then up between your <<breastscomma>> rubbing itself between them.<<neutral 2>>
<<else>>
moves away from your <<breasts>><<set $tentacle13head to 0>><<set $breastuse to 0>>
<</if>>
<</if>>
<<if $tentacle13head is "mouthdeep">>
and up into your mouth where it spurts a sweet fluid down your throat at the apex of each thrust.<<set $purity -= 1>><<internalejac>><<sex 5>><<set $drugged += 3>><<set $mouthgoo += 1>><<set $tentacle13health -= 1>>
<</if>>
<<if $tentacle13head is "mouth">>
and continues thrusting into your mouth.<span class="pink"> The tip opens and begins oozing a sweet liquid.</span><<set $purity -= 1>><<internalejac>><<set $mouthstate to "tentacledeep">><<set $tentacle13head to "mouthdeep">><<sex 5>><<oralejacstat>><<ejacstat>>
<</if>>
<<if $tentacle13head is "mouthimminent">>
<<if $oralvirginity is 1>>
<span class="pink"> and thrusts between your lips,</span><span class="red"> penetrating your mouth for the first time.</span><<set $oralvirginity to 0>><<violence 5>>
<<else>>
<span class="pink"> and thrusts between your lips.</span>
<</if>>
<<set $mouthstate to "tentacle">><<set $tentacle13head to "mouth">><<sex 5>><<raped>><<oralstat>>
<</if>>
<<if $tentacle13head is "mouthentrance">>
<span class="purple"> and presses against your lips.</span><<set $mouthstate to "tentacleimminent">><<set $tentacle13head to "mouthimminent">><<neutral 4>>
<</if>>
<<if $tentacle13head is "vaginadeep">>
and <<slithers>> into your <<pussy>> where it pumps a viscous fluid at the apex of each thrust.<<set $purity -= 1>><<internalejac>><<sex 5>><<set $drugged += 3>><<set $vaginagoo += 1>><<set $tentacle13health -= 1>>
<</if>>
<<if $tentacle13head is "vagina">>
and continues thrusting into your <<pussystop>><span class="pink"> The tip opens and begins oozing a viscous liquid.</span><<set $purity -= 1>><<internalejac>><<set $vaginastate to "tentacledeep">><<set $tentacle13head to "vaginadeep">><<sex 5>><<vaginalejacstat>><<ejacstat>>
<</if>>
<<if $tentacle13head is "vaginaimminent">>
<<if $vaginalvirginity is 1>>
<span class="pink"> and thrusts into your <<pussycomma>></span><span class="red"> tearing your hymen and forever robbing you of your purity.</span><<set $vaginalvirginity to 0>><<violence 100>>
<<else>>
<span class="pink"> and thrusts into your <<pussystop>></span>
<</if>>
<<set $vaginastate to "tentacle">><<set $tentacle13head to "vagina">><<sex 5>><<raped>><<vaginaraped>><<vaginalstat>><<violence 1>>
<</if>>
<<if $tentacle13head is "vaginaentrance">>
<<if $undertype isnot "chastity">>
<span class="purple"> and presses against your <<pussycomma>> about to penetrate.</span><<set $vaginastate to "tentacleimminent">><<set $tentacle13head to "vaginaimminent">><<neutral 4>>
<<else>>
and tries to find a way inside. Failing, it lashes at the metal.<<set $underintegrity -= 10>><<violence 1>>
<</if>>
<</if>>
<<if $tentacle13head is "penisdeep">>
and continues thrusting against your <<peniscomma>> caressing and kneading your length.<<sex 5>>
<</if>>
<<if $tentacle13head is "penis">>
and continues thrusting against your <<penisstop>><span class="pink"> It sucks and kneads your length, trying to milk you of your cum.</span><<set $penisstate to "tentacledeep">><<set $tentacle13head to "penisdeep">><<sex 5>>
<</if>>
<<if $tentacle13head is "penisimminent">>
<<if $penilevirginity is 1>>
<span class="pink"> and thrusts against your <<peniscomma>> swallowing you to the base and </span><span class="red"> tearing the membrane between your glans and foreskin, forever robbing you of your purity.</span><<set $penilevirginity to 0>><<violence 100>>
<<else>>
<span class="pink"> and thrusts against your <<peniscomma>> swallowing you to the base.</span>
<</if>>
<<set $penisstate to "tentacle">><<set $tentacle13head to "penis">><<sex 5>><<raped>><<penisraped>><<penilestat>><<violence 1>>
<</if>>
<<if $tentacle13head is "penisentrance">>
<<if $undertype isnot "chastity">>
<span class="purple"> and <<slithers>> over to your <<penisstop>> The tip opens and presses against your glans, about to envelop you.</span><<set $penisstate to "tentacleimminent">><<set $tentacle13head to "penisimminent">><<neutral 4>>
<<else>>
and tries to find a way inside. Failing, it lashes at the metal.<<set $underintegrity -= 10>><<violence 1>>
<</if>>
<</if>>
<<if $tentacle13head is "anusdeep">>
and <<slithers>> into your <<bottom>> where it pumps a viscous fluid at the apex of each thrust.<<set $purity -= 1>><<internalejac>><<sex 5>><<set $drugged += 3>><<set $anusgoo += 1>><<set $tentacle13health -= 1>>
<</if>>
<<if $tentacle13head is "anus">>
and continues thrusting into your <<bottomstop>><span class="pink"> The tip opens and begins oozing a viscous liquid.</span><<set $purity -= 1>><<internalejac>><<set $anusstate to "tentacledeep">><<set $tentacle13head to "anusdeep">><<sex 5>><<analejacstat>><<ejacstat>>
<</if>>
<<if $tentacle13head is "anusimminent">>
<<if $analvirginity is 1>>
<span class="pink"> and thrusts into your <<bottomcomma>></span><span class="red"> violating you in a way you hadn't conceived of.</span><<set $analvirginity to 0>><<violence 100>>
<<else>>
<span class="pink"> and thrusts into your <<bottomstop>></span>
<</if>>
<<set $anusstate to "tentacle">><<set $tentacle13head to "anus">><<sex 5>><<raped>><<analstat>><<violence 1>>
<</if>>
<<if $tentacle13head is "anusentrance">>
<<if $analshield is 0>>
<span class="purple"> and presses against your <<bottomcomma>> about to penetrate.</span><<set $anusstate to "tentacleimminent">><<set $tentacle13head to "anusimminent">><<neutral 4>>
<<else>>
and tries to find a way inside. Failing, it lashes at the device.<<set $underintegrity -= 10>><<violence 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $tentacle13head is "vaginarub">>
<<if $rng gte 21>>
and between your thighs where it <<slithers>> against your <<pussycomma>> pressing against your clit.<<sex 3>>
<<else>>
and between your thighs <span class="blue">where it <<slithers>> toward your <<pussystop>></span><<neutral 3>><<set $vaginause to "tentacle">><<set $vaginastate to "tentacleentrance">><<set $tentacle13head to "vaginaentrance">><<set $thighuse to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $tentacle13head is "penisrub">>
<<if $rng gte 21>>
and between your thighs where it <<slithers>> against your <<peniscomma>> coiling around it.<<sex 3>>
<<else>>
and between your thighs <span class="blue">where the tip opens and it <<slithers>> toward your <<penisstop>></span><<neutral 3>><<set $penisuse to "tentacle">><<set $penisstate to "tentacleentrance">><<set $tentacle13head to "penisentrance">><<set $thighuse to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $tentacle13head is "bottomrub">>
<<if $rng gte 21>>
and between your <<bottom>> cheeks where it <<slithers>> against your back.<<sex 3>>
<<else>>
and between your <<bottom>> cheeks, <span class="blue"> toward your anus.</span><<neutral 3>><<set $anususe to "tentacle">><<set $anusstate to "tentacleentrance">><<set $tentacle13head to "anusentrance">><<set $bottomuse to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $tentacle13head is 0 and $tentacle13shaft isnot 0>>
<<if $rng lte 10>>
<<if $chestuse is "squeezed" and $breastuse is 0>>
<<upperslither>><span class="blue">and up between your squeezed <<breastsstop>></span><<set $tentacle13head to "chest">><<neutral 2>><<set $breastuse to "tentacle">><<cheststat>>
<<else>>
<<tentacle13default>>
<</if>>
<<elseif $rng lte 20>>
<<if $leftnipple is 0>>
<<upperslither>> <span class="blue">and teases your left nipple.</span><<neutral 2>><<set $tentacle13head to "leftnipple">><<set $leftnipple to "tentacle">>
<<else>>
<<tentacle13default>>
<</if>>
<<elseif $rng lte 30>>
<<if $rightnipple is 0>>
<<upperslither>> <span class="blue">and teases your right nipple.</span><<neutral 2>><<set $tentacle13head to "rightnipple">><<set $rightnipple to "tentacle">>
<<else>>
<<tentacle13default>>
<</if>>
<<elseif $rng lte 40>>
<<if $mouthuse is 0>>
<<upperslither>> <span class="blue">and up toward your mouth.</span><<neutral 2>><<set $mouthuse to "tentacle">><<set $mouthstate to "tentacleentrance">><<set $tentacle13head to "mouthentrance">>
<<else>>
<<tentacle13default>>
<</if>>
<<elseif $rng lte 50>>
<<if $anususe is 0 and $analdisable is "f">>
<<underslither>> <span class="blue">and <<slithers>> toward your <<bottomstop>></span><<neutral 2>><<set $anususe to "tentacle">><<set $anusstate to "tentacleentrance">><<set $tentacle13head to "anusentrance">>
<<else>>
<<tentacle13default>>
<</if>>
<<elseif $rng lte 60>>
<<if $vaginaexist is 1 and $vaginause is 0>>
<<underslither>> <span class="blue">and <<slithers>> toward your <<pussystop>></span><<neutral 2>><<set $vaginause to "tentacle">><<set $vaginastate to "tentacleentrance">><<set $tentacle13head to "vaginaentrance">>
<<else>>
<<tentacle13default>>
<</if>>
<<elseif $rng lte 70>>
<<if $penisexist is 1 and $penisuse is 0>>
<<underslither>> <span class="blue">and <<slithers>> toward your <<penisstop>></span><<neutral 2>><<set $penisuse to "tentacle">><<set $penisstate to "tentacleentrance">><<set $tentacle13head to "penisentrance">>
<<else>>
<<tentacle13default>>
<</if>>
<<elseif $rng lte 80>>
<<if $thighuse is 0>>
<<if $penisexist is 1 and $penisuse is 0>>
<<underslither>> <span class="blue">and <<slithers>> between your thighs and against your tummy and <<penisstop>></span><<set $penisuse to "tentaclerub">><<set $thighuse to "tentaclerub">><<set $tentacle13head to "penisrub">><<sex 3>><<thighstat>>
<<elseif $vaginaexist is 1 and $vaginause is 0>>
<<underslither>> <span class="blue">and <<slithers>> between your thighs and against your tummy and <<pussystop>></span><<set $vaginause to "tentaclerub">><<set $thighuse to "tentaclerub">><<set $tentacle13head to "vaginarub">><<sex 3>><<thighstat>>
<<else>>
<<tentacle13default>>
<</if>>
<<else>>
<<tentacle13default>>
<</if>>
<<elseif $rng lte 90>>
<<if $bottomuse is 0 and $anususe is 0 and $analdisable is "f">>
<<underslither>> <span class="blue">and <<slithers>> between your <<bottom>> cheeks and against your back.</span><<set $bottomuse to "tentaclerub">><<set $anususe to "tentaclerub">><<set $tentacle13head to "bottomrub">><<sex 1>><<bottomstat>>
<<else>>
<<tentacle13default>>
<</if>>
<<else>>
<<tentacle13default>>
<</if>>
<<elseif $tentacle13head is 0 and $tentacle13shaft is 0>>
<<if $rng lte 10>>
<<if $position isnot "wall">>
The $tentacle13 tentacle winds around your tummy.<<neutral 1>><<set $tentacle13shaft to "tummy">>
<<else>>
The $tentacle13 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<elseif $rng lte 20>>
The $tentacle13 tentacle <<slithers>> between your thighs.<<neutral 1>><<set $tentacle13shaft to "thighs">>
<<elseif $rng lte 30>>
<<if $position isnot "wall">>
<<if $breastsize gte 2 and $chestuse is 0>>
The $tentacle13 tentacle <<slithers>> around your <<breastscomma>> <span class="blue">squeezing them together.</span><<neutral 1>><<set $tentacle13shaft to "breasts">><<set $chestuse to "squeezed">>
<<else>>
The $tentacle13 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<else>>
The $tentacle13 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<elseif $rng lte 40>>
<<if $position isnot "wall">>
The $tentacle13 tentacle winds its way around your chest, beneath your <<breastsstop>><<neutral 1>><<set $tentacle13shaft to "chest">>
<<else>>
The $tentacle13 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<elseif $rng lte 50>>
The $tentacle13 tentacle winds its way around your waist.<<neutral 1>><<set $tentacle13shaft to "waist">>
<<elseif $rng lte 60>>
<<if $position isnot "wall">>
<<if $head is 0>>
The $tentacle13 tentacle winds its way around your neck, <span class="blue">restraining your head.</span><<neutral 1>><<set $tentacle13shaft to "neck">><<set $head to "grappled">>
<<else>>
The $tentacle13 tentacle winds its way around your shoulders.<<neutral 1>><<set $tentacle13shaft to "shoulders">>
<</if>>
<<else>>
The $tentacle13 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<elseif $rng lte 70>>
The $tentacle13 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<<elseif $rng lte 80>>
<<if $leftleg is 0>>
The $tentacle13 tentacle winds its way around your left leg, <span class="blue">restraining it.</span><<neutral 1>><<feettentacledisable>><<set $tentacle13shaft to "leftleg">><<set $leftleg to "grappled">>
<<else>>
The $tentacle13 tentacle tickles your feet.<<neutral 1>>
<</if>>
<<elseif $rng lte 85>>
<<if $rightleg is 0>>
The $tentacle13 tentacle winds its way around your right leg, <span class="blue">restraining it.</span><<neutral 1>><<feettentacledisable>><<set $tentacle13shaft to "rightleg">><<set $rightleg to "grappled">>
<<else>>
The $tentacle13 tentacle tickles your feet.<<neutral 1>>
<</if>>
<<elseif $rng lte 90>>
<<if $leftarm is 0>>
The $tentacle13 tentacle winds its way around your left arm, <span class="blue">restraining it.</span><<neutral 1>><<leftarmtentacledisable>><<set $tentacle13shaft to "leftarm">><<set $leftarm to "grappled">><<set $leftarmstate to 0>>
<<else>>
The $tentacle13 tentacle tickles your armpit.<<neutral 1>>
<</if>>
<<elseif $rng lte 95>>
<<if $rightarm is 0>>
The $tentacle13 tentacle winds its way around your right arm, <span class="blue">restraining it.</span><<rightarmtentacledisable>><<neutral 1>><<set $tentacle13shaft to "rightarm">><<set $rightarm to "grappled">><<set $rightarmstate to 0>>
<<else>>
The $tentacle13 tentacle tickles your armpit.<<neutral 1>>
<</if>>
<<elseif $rng lte 100>>
The $tentacle13 tentacle <<slithers>> against your <<bottomstop>><<neutral 1>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "tentacle13default">><<nobr>>
<<set $rng to random(1, 100)>>
<<if $rng gte 90>>
then squirts a warm fluid over your neck.<<neutral 1>><<set $neckgoo += 1>><<set $tentacle13health -= 1>><<neckejacstat>><<ejacstat>>
<<elseif $rng gte 80>>
then squirts a warm fluid over your right arm.<<neutral 1>><<set $rightarmgoo += 1>><<set $tentacle13health -= 1>><<handejacstat>><<ejacstat>>
<<elseif $rng gte 70>>
then squirts a warm fluid over your left arm.<<neutral 1>><<set $leftarmgoo += 1>><<set $tentacle13health -= 1>><<handejacstat>><<ejacstat>>
<<elseif $rng gte 60>>
then squirts a warm fluid over your thighs.<<neutral 1>><<set $thighgoo += 1>><<set $tentacle13health -= 1>><<thighejacstat>><<ejacstat>>
<<elseif $rng gte 50>>
then squirts a warm fluid over your <<bottomstop>><<neutral 1>><<set $bottomgoo += 1>><<set $tentacle13health -= 1>><<bottomejacstat>><<ejacstat>>
<<elseif $rng gte 40>>
then squirts a warm fluid over your tummy.<<neutral 1>><<set $tummygoo += 1>><<set $tentacle13health -= 1>><<tummyejacstat>><<ejacstat>>
<<elseif $rng gte 30>>
then squirts a warm fluid over your chest.<<neutral 1>><<set $chestgoo += 1>><<set $tentacle13health -= 1>><<chestejacstat>><<ejacstat>>
<<elseif $rng gte 20>>
then squirts a warm fluid over your face.<<neutral 1>><<set $facegoo += 1>><<set $tentacle13health -= 1>><<faceejacstat>><<ejacstat>>
<<elseif $rng gte 10>>
then squirts a warm fluid over your hair.<<neutral 1>><<set $hairgoo += 1>><<set $tentacle13health -= 1>><<hairejacstat>><<ejacstat>>
<<else>>
then squirts a warm fluid over your feet.<<neutral 1>><<set $feetgoo += 1>><<set $tentacle13health -= 1>><<feetejacstat>><<ejacstat>>
<</if>>
<</nobr>><</widget>>
<<widget "tentacle13disable">><<nobr>>
<<if $tentacle13head is "feet">>
<<set $leftleg to 0>>
<<set $rightleg to 0>>
<<set $feetstate to 0>>
<</if>>
<<if $tentacle13head is "leftarm">>
<<set $leftarm to 0>>
<<set $leftarmstate to 0>>
<</if>>
<<if $tentacle13head is "rightarm">>
<<set $rightarm to 0>>
<<set $rightarmstate to 0>>
<</if>>
<<if $tentacle13head is "leftnipplesuck">>
<<set $leftnipple to 0>>
<</if>>
<<if $tentacle13head is "rightnipplesuck">>
<<set $rightnipple to 0>>
<</if>>
<<if $tentacle13head is "leftnipple">>
<<set $leftnipple to 0>>
<</if>>
<<if $tentacle13head is "rightnipple">>
<<set $rightnipple to 0>>
<</if>>
<<if $tentacle13head is "chest">>
<<set $chestuse to 0>>
<</if>>
<<if $tentacle13head is "mouthentrance">>
<<set $mouthuse to 0>>
<<set $mouthstate to 0>>
<</if>>
<<if $tentacle13head is "mouthimminent">>
<<set $mouthuse to 0>>
<<set $mouthstate to 0>>
<</if>>
<<if $tentacle13head is "mouth">>
<<set $mouthuse to 0>>
<<set $mouthstate to 0>>
<</if>>
<<if $tentacle13head is "mouthdeep">>
<<set $mouthuse to 0>>
<<set $mouthstate to 0>>
<</if>>
<<if $tentacle13head is "anusentrance">>
<<set $anususe to 0>>
<<set $anusstate to 0>>
<</if>>
<<if $tentacle13head is "anusimminent">>
<<set $anususe to 0>>
<<set $anusstate to 0>>
<</if>>
<<if $tentacle13head is "anus">>
<<set $anususe to 0>>
<<set $anusstate to 0>>
<</if>>
<<if $tentacle13head is "anusdeep">>
<<set $anususe to 0>>
<<set $anusstate to 0>>
<</if>>
<<if $tentacle13head is "vaginaentrance">>
<<set $vaginause to 0>>
<<set $vaginastate to 0>>
<</if>>
<<if $tentacle13head is "vaginaimminent">>
<<set $vaginause to 0>>
<<set $vaginastate to 0>>
<</if>>
<<if $tentacle13head is "vagina">>
<<set $vaginause to 0>>
<<set $vaginastate to 0>>
<</if>>
<<if $tentacle13head is "vaginadeep">>
<<set $vaginause to 0>>
<<set $vaginastate to 0>>
<</if>>
<<if $tentacle13head is "penisentrance">>
<<set $penisuse to 0>>
<<set $penisstate to 0>>
<</if>>
<<if $tentacle13head is "penisimminent">>
<<set $penisuse to 0>>
<<set $penisstate to 0>>
<</if>>
<<if $tentacle13head is "penis">>
<<set $penisuse to 0>>
<<set $penisstate to 0>>
<</if>>
<<if $tentacle13head is "penisdeep">>
<<set $penisuse to 0>>
<<set $penisstate to 0>>
<</if>>
<<if $tentacle13head is "vaginarub">>
<<set $vaginause to 0>>
<<set $thighuse to 0>>
<</if>>
<<if $tentacle13head is "penisrub">>
<<set $penisuse to 0>>
<<set $thighuse to 0>>
<</if>>
<<if $tentacle13head is "bottomrub">>
<<set $anususe to 0>>
<<set $bottomuse to 0>>
<</if>>
<<if $tentacle13shaft is "breasts">>
<<set $chestuse to 0>>
<</if>>
<<if $tentacle13shaft is "neck" and $head isnot "bound">>
<<set $head to 0>>
<</if>>
<<if $tentacle13shaft is "leftleg" and $leftleg isnot "bound">>
<<set $leftleg to 0>>
<</if>>
<<if $tentacle13shaft is "rightleg" and $rightleg isnot "bound">>
<<set $rightleg to 0>>
<</if>>
<<if $tentacle13shaft is "leftarm" and $leftarm isnot "bound">>
<<set $leftarm to 0>>
<</if>>
<<if $tentacle13shaft is "rightarm" and $rightarm isnot "bound">>
<<set $rightarm to 0>>
<</if>>
<<if $tentacle13head is "chest">>
<<set $breastuse to 0>>
<</if>>
<<set $tentacle13shaft to 0>>
<<set $tentacle13head to 0>>
<</nobr>><</widget>>
<<widget "actionstentacle13lefthand">><<nobr>>
<<if $leftarm is 0 and $tentacle13shaft isnot "finished">>
<<if $leftactiondefault is "lefthittentacle13">>
| <label><span class="def">Strike the $tentacle13 tentacle</span> <<radiobutton "$leftaction" "lefthittentacle13" checked>></label>
<<else>>
| <label><span class="def">Strike the $tentacle13 tentacle</span> <<radiobutton "$leftaction" "lefthittentacle13">></label>
<</if>>
<<if $leftactiondefault is "leftgrabtentacle13">>
| <label><span class="sub">Grab the $tentacle13 tentacle</span> <<radiobutton "$leftaction" "leftgrabtentacle13" checked>></label>
<<else>>
| <label><span class="sub">Grab the $tentacle13 tentacle</span> <<radiobutton "$leftaction" "leftgrabtentacle13">></label>
<</if>>
<<elseif $leftarm is "tentacle13">>You hold the $tentacle13 tentacle in your left hand.<br>
<<if $leftactiondefault is "leftrubtentacle13">>
| <label><span class="sub">Milk it</span> <<radiobutton "$leftaction" "leftrubtentacle13" checked>></label>
<<else>>
| <label><span class="sub">Milk it</span> <<radiobutton "$leftaction" "leftrubtentacle13">></label>
<</if>>
<<if $leftactiondefault is "leftstoptentacle13">>
| <label><span class="neutral">Let go</span> <<radiobutton "$leftaction" "leftstoptentacle13" checked>></label>
<<else>>
| <label><span class="neutral">Let go</span> <<radiobutton "$leftaction" "leftstoptentacle13">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle13righthand">><<nobr>>
<<if $rightarm is 0 and $tentacle13shaft isnot "finished">>
<<if $rightactiondefault is "righthittentacle13">>
| <label><span class="def">Strike the $tentacle13 tentacle</span> <<radiobutton "$rightaction" "righthittentacle13" checked>></label>
<<else>>
| <label><span class="def">Strike the $tentacle13 tentacle</span> <<radiobutton "$rightaction" "righthittentacle13">></label>
<</if>>
<<if $rightactiondefault is "rightgrabtentacle13">>
| <label><span class="sub">Grab the $tentacle13 tentacle</span> <<radiobutton "$rightaction" "rightgrabtentacle13" checked>></label>
<<else>>
| <label><span class="sub">Grab the $tentacle13 tentacle</span> <<radiobutton "$rightaction" "rightgrabtentacle13">></label>
<</if>>
<<elseif $rightarm is "tentacle13">>You hold the $tentacle13 tentacle in your right hand.<br>
<<if $rightactiondefault is "rightrubtentacle13">>
| <label><span class="sub">Milk it</span> <<radiobutton "$rightaction" "rightrubtentacle13" checked>></label>
<<else>>
| <label><span class="sub">Milk it</span> <<radiobutton "$rightaction" "rightrubtentacle13">></label>
<</if>>
<<if $rightactiondefault is "rightstoptentacle13">>
| <label><span class="neutral">Let go</span> <<radiobutton "$rightaction" "rightstoptentacle13" checked>></label>
<<else>>
| <label><span class="neutral">Let go</span> <<radiobutton "$rightaction" "rightstoptentacle13">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle13legs">><<nobr>>
<<if $leftleg is 0 and $rightleg is 0 and $tentacle13shaft isnot "finished">>
<<if $feetactiondefault is "feethittentacle13">>
| <label><span class="def">Kick the $tentacle13 tentacle</span> <<radiobutton "$feetaction" "feethittentacle13" checked>></label>
<<else>>
| <label><span class="def">Kick the $tentacle13 tentacle</span> <<radiobutton "$feetaction" "feethittentacle13">></label>
<</if>>
<<if $feetactiondefault is "feetgrabtentacle13">>
| <label><span class="sub">Grab the $tentacle13 tentacle</span> <<radiobutton "$feetaction" "feetgrabtentacle13" checked>></label>
<<else>>
| <label><span class="sub">Grab the $tentacle13 tentacle</span> <<radiobutton "$feetaction" "feetgrabtentacle13">></label>
<</if>>
<<elseif $leftleg is 0 and $tentacle13shaft isnot "finished">>
<<if $feetactiondefault is "feethittentacle13">>
| <label><span class="def">Kick the $tentacle13 tentacle</span> <<radiobutton "$feetaction" "feethittentacle13" checked>></label>
<<else>>
| <label><span class="def">Kick the $tentacle13 tentacle</span> <<radiobutton "$feetaction" "feethittentacle13">></label>
<</if>>
<<elseif $rightleg is 0 and $tentacle13shaft isnot "finished">>
<<if $feetactiondefault is "feethittentacle13">>
| <label><span class="def">Kick the $tentacle13 tentacle</span> <<radiobutton "$feetaction" "feethittentacle13" checked>></label>
<<else>>
| <label><span class="def">Kick the $tentacle13 tentacle</span> <<radiobutton "$feetaction" "feethittentacle13">></label>
<</if>>
<<elseif $leftleg is "tentacle13">>You hold the $tentacle13 tentacle between your feet.<br>
<<if $feetactiondefault is "feetrubtentacle13">>
| <label><span class="sub">Milk it</span> <<radiobutton "$feetaction" "feetrubtentacle13" checked>></label>
<<else>>
| <label><span class="sub">Milk it</span> <<radiobutton "$feetaction" "feetrubtentacle13">></label>
<</if>>
<<if $feetactiondefault is "feetstoptentacle13">>
| <label><span class="neutral">Let go</span> <<radiobutton "$feetaction" "feetstoptentacle13" checked>></label>
<<else>>
| <label><span class="neutral">Let go</span> <<radiobutton "$feetaction" "feetstoptentacle13">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle13mouth">><<nobr>>
<<if $tentacle13head is "mouthentrance">>
<<if $mouthactiondefault is "mouthlicktentacle13">>
| <label><span class="sub">Lick it</span> <<radiobutton "$mouthaction" "mouthlicktentacle13" checked>></label>
<<else>>
| <label><span class="sub">Lick it</span> <<radiobutton "$mouthaction" "mouthlicktentacle13">></label>
<</if>>
<<if $head is "grappled">>
<<else>>
<<if $mouthactiondefault is "mouthpullawaytentacle13">>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "mouthpullawaytentacle13" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "mouthpullawaytentacle13">></label>
<</if>>
<</if>>
<<elseif $tentacle13head is "mouthimminent">>
<<if $mouthactiondefault is "mouthkisstentacle13">>
| <label><span class="sub">Kiss it</span> <<radiobutton "$mouthaction" "mouthkisstentacle13" checked>></label>
<<else>>
| <label><span class="sub">Kiss it</span> <<radiobutton "$mouthaction" "mouthkisstentacle13">></label>
<</if>>
<<if $head is "grappled">>
<<else>>
<<if $mouthactiondefault is "mouthpullawaytentacle13">>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "mouthpullawaytentacle13" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "mouthpullawaytentacle13">></label>
<</if>>
<</if>>
<<elseif $tentacle13head is "mouth">>
<<if $mouthactiondefault is "mouthcooperatetentacle13">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$mouthaction" "mouthcooperatetentacle13" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$mouthaction" "mouthcooperatetentacle13">></label>
<</if>>
<<if $mouthactiondefault is "mouthbitetentacle13">>
| <label><span class="def">Bite</span> <<radiobutton "$mouthaction" "mouthbitetentacle13" checked>></label>
<<else>>
| <label><span class="def">Bite</span> <<radiobutton "$mouthaction" "mouthbitetentacle13">></label>
<</if>>
<<elseif $tentacle13head is "mouthdeep">>
<<if $mouthactiondefault is "mouthcooperatetentacle13">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$mouthaction" "mouthcooperatetentacle13" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$mouthaction" "mouthcooperatetentacle13">></label>
<</if>>
<<if $mouthactiondefault is "mouthbitetentacle13">>
| <label><span class="def">Bite</span> <<radiobutton "$mouthaction" "mouthbitetentacle13" checked>></label>
<<else>>
| <label><span class="def">Bite</span> <<radiobutton "$mouthaction" "mouthbitetentacle13">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle13vagina">><<nobr>>
<<if $tentacle13head is "vaginaentrance">>
<<if $vaginaactiondefault is "vaginarubtentacle13">>
| <label><span class="sub">Rub</span> <<radiobutton "$vaginaaction" "vaginarubtentacle13" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$vaginaaction" "vaginarubtentacle13">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $vaginaactiondefault is "vaginapullawaytentacle13">>
| <label><span class="brat">Pull away</span> <<radiobutton "$vaginaaction" "vaginapullawaytentacle13" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$vaginaaction" "vaginapullawaytentacle13">></label>
<</if>>
<</if>>
<<elseif $tentacle13head is "vaginaimminent">>
<<if $vaginaactiondefault is "vaginarubtentacle13">>
| <label><span class="sub">Rub</span> <<radiobutton "$vaginaaction" "vaginarubtentacle13" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$vaginaaction" "vaginarubtentacle13">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $vaginaactiondefault is "vaginapullawaytentacle13">>
| <label><span class="brat">Pull away</span> <<radiobutton "$vaginaaction" "vaginapullawaytentacle13" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$vaginaaction" "vaginapullawaytentacle13">></label>
<</if>>
<</if>>
<<elseif $tentacle13head is "vagina">>
<<if $vaginaactiondefault is "vaginacooperatetentacle13">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$vaginaaction" "vaginacooperatetentacle13" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$vaginaaction" "vaginacooperatetentacle13">></label>
<</if>>
<<elseif $tentacle13head is "vaginadeep">>
<<if $vaginaactiondefault is "vaginacooperatetentacle13">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$vaginaaction" "vaginacooperatetentacle13" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$vaginaaction" "vaginacooperatetentacle13">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle13penis">><<nobr>>
<<if $tentacle13head is "penisentrance">>
<<if $penisactiondefault is "penisrubtentacle13">>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "penisrubtentacle13" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "penisrubtentacle13">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $penisactiondefault is "penispullawaytentacle13">>
| <label><span class="brat">Pull away</span> <<radiobutton "$penisaction" "penispullawaytentacle13" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$penisaction" "penispullawaytentacle13">></label>
<</if>>
<</if>>
<<elseif $tentacle13head is "penisimminent">>
<<if $penisactiondefault is "penisrubtentacle13">>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "penisrubtentacle13" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "penisrubtentacle13">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $penisactiondefault is "penispullawaytentacle13">>
| <label><span class="brat">Pull away</span> <<radiobutton "$penisaction" "penispullawaytentacle13" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$penisaction" "penispullawaytentacle13">></label>
<</if>>
<</if>>
<<elseif $tentacle13head is "penis">>
<<if $penisactiondefault is "peniscooperatetentacle13">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$penisaction" "peniscooperatetentacle13" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$penisaction" "peniscooperatetentacle13">></label>
<</if>>
<<elseif $tentacle13head is "penisdeep">>
<<if $penisactiondefault is "peniscooperatetentacle13">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$penisaction" "peniscooperatetentacle13" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$penisaction" "peniscooperatetentacle13">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle13anus">><<nobr>>
<<if $tentacle13head is "anusentrance">>
<<if $anusactiondefault is "anusrubtentacle13">>
| <label><span class="sub">Rub</span> <<radiobutton "$anusaction" "anusrubtentacle13" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$anusaction" "anusrubtentacle13">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $anusactiondefault is "anuspullawaytentacle13">>
| <label><span class="brat">Pull away</span> <<radiobutton "$anusaction" "anuspullawaytentacle13" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$anusaction" "anuspullawaytentacle13">></label>
<</if>>
<</if>>
<<elseif $tentacle13head is "anusimminent">>
<<if $anusactiondefault is "anusrubtentacle13">>
| <label><span class="sub">Rub</span> <<radiobutton "$anusaction" "anusrubtentacle13" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$anusaction" "anusrubtentacle13">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $anusactiondefault is "anuspullawaytentacle13">>
| <label><span class="brat">Pull away</span> <<radiobutton "$anusaction" "anuspullawaytentacle13" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$anusaction" "anuspullawaytentacle13">></label>
<</if>>
<</if>>
<<elseif $tentacle13head is "anus">>
<<if $anusactiondefault is "anuscooperatetentacle13">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$anusaction" "anuscooperatetentacle13" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$anusaction" "anuscooperatetentacle13">></label>
<</if>>
<<elseif $tentacle13head is "anusdeep">>
<<if $anusactiondefault is "anuscooperatetentacle13">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$anusaction" "anuscooperatetentacle13" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$anusaction" "anuscooperatetentacle13">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle13thighs">><<nobr>>
<<if $tentacle13head is "penisrub">>
<<if $thighactiondefault is "penisrubtentacle13">>
| <label><span class="sub">Rub</span> <<radiobutton "$thighaction" "penisrubtentacle13" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$thighaction" "penisrubtentacle13">></label>
<</if>>
<<elseif $tentacle13head is "vaginarub">>
<<if $thighactiondefault is "vaginarubtentacle13">>
| <label><span class="sub">Rub</span> <<radiobutton "$thighaction" "vaginarubtentacle13" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$thighaction" "vaginarubtentacle13">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle13bottom">><<nobr>>
<<if $tentacle13head is "bottomrub">>
<<if $bottomactiondefault is "bottomrubtentacle13">>
| <label><span class="sub">Rub</span> <<radiobutton "$bottomaction" "bottomrubtentacle13" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$bottomaction" "bottomrubtentacle13">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle13chest">><<nobr>>
<<if $tentacle13head is "chest">>
<<if $chestactiondefault is "chestrubtentacle13">>
| <label><span class="sub">Rub</span> <<radiobutton "$chestaction" "chestrubtentacle13" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$chestaction" "chestrubtentacle13">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "effectstentacle13">><<nobr>>
<<if $leftaction is "lefthittentacle13">><<set $leftaction to 0>><<set $leftactiondefault to "lefthittentacle13">>You strike the $tentacle13 tentacle with your left hand and it reels away from you.<<defiance 2>><<set $speechhit to 1>><<tentacle13disable>><<set $attackstat += 1>><<set $tentacle13health -= 1>>
<<if $rng lte ($physique / 200)>>
<<set $tentacle13health -= 1>>
<</if>>
<</if>>
<<if $rightaction is "righthittentacle13">><<set $rightaction to 0>><<set $rightactiondefault to "righthittentacle13">>You strike the $tentacle13 tentacle with your right hand and it reels away from you.<<defiance 2>><<set $speechhit to 1>><<tentacle13disable>><<set $attackstat += 1>><<set $tentacle13health -= 1>>
<<if $rng lte ($physique / 200)>>
<<set $tentacle13health -= 1>>
<</if>>
<</if>>
<<if $leftaction is "leftgrabtentacle13">><<set $leftaction to 0>><<set $leftactiondefault to "leftrubtentacle13">><<submission 1>><<handstat>><span class="lblue">You <<handtext>> grab the $tentacle13 tentacle with your left hand.</span><<tentacle13disable>><<set $leftarm to "tentacle13">><<set $tentacle13head to "leftarm">><<handstat>><<set $leftarmstate to "tentacle">>
<</if>>
<<if $rightaction is "rightgrabtentacle13">><<set $rightaction to 0>><<set $rightactiondefault to "rightrubtentacle13">><<submission 1>><<handstat>><span class="lblue">You <<handtext>> grab the $tentacle13 tentacle with your right hand.</span><<tentacle13disable>><<set $rightarm to "tentacle13">><<set $tentacle13head to "rightarm">><<handstat>><<set $rightarmstate to "tentacle">>
<</if>>
<<if $leftaction is "leftrubtentacle13">><<set $leftaction to 0>><<set $leftactiondefault to "leftrubtentacle13">><<handskilluse>><<submission 1>>You <<handtext>> squeeze the $tentacle13 tentacle in your left hand and rub up and down its length.<<set $rng to random(1, 100)>>
<<if $handskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $rightarmgoo += 1>><<set $tentacle13health -= 3>><<handejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $rightaction is "rightrubtentacle13">><<set $rightaction to 0>><<set $rightactiondefault to "rightrubtentacle13">><<handskilluse>><<submission 1>>You <<handtext>> squeeze the $tentacle13 tentacle in your right hand and rub up and down its length.<<set $rng to random(1, 100)>>
<<if $handskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $rightarmgoo += 1>><<set $tentacle13health -= 3>><<handejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $leftaction is "leftstoptentacle13">><<set $leftaction to 0>><<set $leftactiondefault to "leftstoptentacle13">>You release the $tentacle13 tentacle from your left hand.<<tentacle13disable>>
<</if>>
<<if $rightaction is "rightstoptentacle13">><<set $rightaction to 0>><<set $rightactiondefault to "rightstoptentacle13">>You release the $tentacle13 tentacle from your right hand.<<tentacle13disable>>
<</if>>
<<if $feetaction is "feethittentacle13">><<set $feetaction to 0>><<set $feetactiondefault to "feethittentacle13">>You kick the $tentacle13 tentacle and it reels away from you.<<defiance 2>><<set $speechhit to 1>><<tentacle13disable>><<set $attackstat += 1>><<set $tentacle13health -= 1>>
<<if $rng lte ($physique / 200)>>
<<set $tentacle13health -= 1>>
<</if>>
<</if>>
<<if $feetaction is "feetgrabtentacle13">><<set $feetaction to 0>><<set $feetactiondefault to "feetrubtentacle13">><<submission 1>><<feetstat>><span class="lblue">You <<feettext>> grab the $tentacle13 tentacle between your feet.</span><<tentacle13disable>><<set $leftleg to "tentacle13">><<set $rightleg to "tentacle13">><<set $tentacle13head to "feet">><<feetstat>><<set $feetstate to "tentacle">>
<</if>>
<<if $feetaction is "feetrubtentacle13">><<set $feetaction to 0>><<set $feetactiondefault to "feetrubtentacle13">><<feetskilluse>><<submission 1>>You <<feettext>> squeeze the $tentacle13 tentacle between your feet and rub up and down its length.<<set $rng to random(1, 100)>>
<<if $feetskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $feetgoo += 1>><<set $tentacle13health -= 3>><<feetejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $feetaction is "feetstoptentacle13">><<set $feetaction to 0>><<set $feetactiondefault to "feetstoptentacle13">>You let go of the $tentacle13 tentacle between your feet.<<tentacle13disable>>
<</if>>
<<if $mouthaction is "mouthlicktentacle13">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthlicktentacle13">>
<<submission 2>><<oralskilluse>>You <<oraltext>> lick the tip of the $tentacle13 tentacle.<<set $rng to random(1, 100)>>
<<if $oralskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your face.</span><<set $facegoo += 1>><<set $tentacle13health -= 3>><<faceejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $mouthaction is "mouthkisstentacle13">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthkisstentacle13">>
<<submission 3>><<oralskilluse>>You <<oraltext>> kiss the tip of the $tentacle13 tentacle.<<set $rng to random(1, 100)>>
<<if $oralskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your face.</span><<set $facegoo += 1>><<set $tentacle13health -= 3>><<faceejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $mouthaction is "mouthcooperatetentacle13">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthcooperatetentacle13">>
<<sex 5>><<oralskilluse>>You <<oraltext>> suck the $tentacle13 tentacle invading your mouth.<<set $rng to random(1, 100)>>
<<if $oralskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip and into your mouth.</span><<set $tentacle13health -= 3>><<set $drugged += 3>><<set $mouthgoo += 1>><<oralejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $mouthaction is "mouthpullawaytentacle13">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthpullawaytentacle13">><<brat 1>><span class="teal">You pull away from the $tentacle13 tentacle threatening your mouth.</span><<tentacle13disable>>
<</if>>
<<if $mouthaction is "mouthbitetentacle13">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthbitetentacle13">><<defiance 5>>You bite down on the $tentacle13 tentacle invading your mouth. <span class="teal">It recoils immediately.</span><<tentacle13disable>><<set $attackstat += 1>><<set $tentacle13health -= 1>>
<<if $rng lte ($physique / 200)>>
<<set $tentacle13health -= 1>>
<</if>>
<</if>>
<<if $vaginaaction is "vaginarubtentacle13">><<set $vaginaaction to 0>><<set $vaginaactiondefault to "vaginarubtentacle13">>
<<submission 2>><<vaginalskilluse>>You <<vaginaltext>> rub the tip of the $tentacle13 tentacle with your <<pussystop>><<set $rng to random(1, 100)>>
<<if $vaginalskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $vaginaoutsidegoo += 1>><<set $tentacle13health -= 3>><<vaginalentranceejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $vaginaaction is "vaginacooperatetentacle13">><<set $vaginaaction to 0>><<set $vaginaactiondefault to "vaginacooperatetentacle13">>
<<sex 5>><<vaginalskilluse>>You <<vaginaltext>> push back against the $tentacle13 tentacle invading your <<pussystop>><<set $rng to random(1, 100)>>
<<if $vaginalskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, flooding your womb with its warmth.</span><<set $tentacle13health -= 3>><<set $drugged += 3>><<set $vaginagoo += 1>><<vaginalejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $vaginaaction is "vaginapullawaytentacle13">><<set $vaginaaction to 0>><<set $vaginaactiondefault to "vaginapullawaytentacle13">><<brat 1>><span class="teal">You pull away from the $tentacle13 tentacle threatening your <<pussystop>></span><<tentacle13disable>>
<</if>>
<<if $penisaction is "penisrubtentacle13">><<set $penisaction to 0>><<set $penisactiondefault to "penisrubtentacle13">>
<<submission 2>><<penileskilluse>>You <<peniletext>> rub the tip of the $tentacle13 tentacle with your <<penisstop>><<set $rng to random(1, 100)>>
<<if $penileskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $penisgoo += 1>><<set $tentacle13health -= 3>><<penileejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $penisaction is "peniscooperatetentacle13">><<set $penisaction to 0>><<set $penisactiondefault to "peniscooperatetentacle13">>
<<sex 5>><<penileskilluse>>You <<peniletext>> push back against the $tentacle13 tentacle engulfing your <<penisstop>><<set $rng to random(1, 100)>>
<<if $penileskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your groin.</span><<set $tentacle13health -= 3>><<set $penisgoo += 1>><<penileejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $penisaction is "penispullawaytentacle13">><<set $penisaction to 0>><<set $penisactiondefault to "penispullawaytentacle13">><<brat 1>><span class="teal">You pull away from the $tentacle13 tentacle threatening your <<penisstop>></span><<tentacle13disable>>
<</if>>
<<if $anusaction is "anusrubtentacle13">><<set $anusaction to 0>><<set $anusactiondefault to "anusrubtentacle13">>
<<submission 2>><<analskilluse>>You <<analtext>> rub the tip of the $tentacle13 tentacle with your <<bottomstop>><<set $rng to random(1, 100)>>
<<if $analskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your <<bottomstop>></span><<set $bottomgoo += 1>><<set $tentacle13health -= 3>><<bottomejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $anusaction is "anuscooperatetentacle13">><<set $anusaction to 0>><<set $anusactiondefault to "anuscooperatetentacle13">>
<<sex 5>><<analskilluse>>You <<analtext>> push back against the $tentacle13 tentacle invading your <<bottomstop>><<set $rng to random(1, 100)>>
<<if $analskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, flooding your bowels with its warmth.</span><<set $tentacle13health -= 3>><<set $drugged += 3>><<set $anusgoo += 1>><<analejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $anusaction is "anuspullawaytentacle13">><<set $anusaction to 0>><<set $anusactiondefault to "anuspullawaytentacle13">><<brat 1>><span class="teal">You pull away from the $tentacle13 tentacle threatening your <<bottomstop>></span><<tentacle13disable>>
<</if>>
<<if $thighaction is "penisrubtentacle13">><<set $thighaction to 0>><<set $thighactiondefault to "penisrubtentacle13">>
<<submission 3>><<thighskilluse>>You <<thightext>> rub the $tentacle13 tentacle between your thighs.<<set $rng to random(1, 100)>>
<<if $thighskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your tummy.</span><<set $tentacle13health -= 3>><<set $tummygoo += 1>><<tummyejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $thighaction is "vaginarubtentacle13">><<set $thighaction to 0>><<set $thighactiondefault to "vaginarubtentacle13">>
<<submission 3>><<thighskilluse>>You <<thightext>> rub the $tentacle13 tentacle between your thighs.<<set $rng to random(1, 100)>>
<<if $thighskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your tummy.</span><<set $tentacle13health -= 3>><<set $tummygoo += 1>><<tummyejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $bottomaction is "bottomrubtentacle13">><<set $bottomaction to 0>><<set $bottomactiondefault to "bottomrubtentacle13">>
<<submission 3>><<bottomskilluse>>You <<bottomtext>> rub the $tentacle13 tentacle between your cheeks.<<set $rng to random(1, 100)>>
<<if $bottomskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your <<bottomstop>></span><<set $tentacle13health -= 3>><<set $bottomgoo += 1>><<bottomejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $chestaction is "chestrubtentacle13">><<set $chestaction to 0>><<set $chestactiondefault to "chestrubtentacle13">>
<<submission 3>><<chestskilluse>>You <<chesttext>> rub the $tentacle13 tentacle between your <<breastsstop>><<set $rng to random(1, 100)>>
<<if $chestskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your chest.</span><<set $tentacle13health -= 3>><<set $chestgoo += 1>><<chestejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<</nobr>><</widget>>
:: Widgets Combat Tentacle14 [widget]
<<widget "tentacle14">><<nobr>>
<<if $tentacle14health lte 0 and $tentacle14shaft isnot "finished">>
Worn out, the $tentacle14 tentacle retracts from you.
<<tentacle14disable>>
<<set $tentacle14shaft to "finished">>
<<set $tentacle14head to "finished">>
<</if>>
<<if $tentacle14shaft is "tummy">>
The $tentacle14 tentacle <<slithers>> around your tummy,
<</if>>
<<if $tentacle14shaft is "thighs">>
The $tentacle14 tentacle <<slithers>> between your thighs,
<</if>>
<<if $tentacle14shaft is "breasts">>
The $tentacle14 tentacle squeezes your breasts together,
<</if>>
<<if $tentacle14shaft is "chest">>
The $tentacle14 tentacle <<slithers>> around your chest,
<</if>>
<<if $tentacle14shaft is "waist">>
The $tentacle14 tentacle <<slithers>> around your waist,
<</if>>
<<if $tentacle14shaft is "neck">>
The $tentacle14 tentacle <<slithers>> around your neck,
<</if>>
<<if $tentacle14shaft is "shoulders">>
The $tentacle14 tentacle <<slithers>> around your shoulders,
<</if>>
<<if $tentacle14shaft is "leftleg">>
The $tentacle14 tentacle <<slithers>> around your left leg,
<</if>>
<<if $tentacle14shaft is "rightleg">>
The $tentacle14 tentacle <<slithers>> around your right leg,
<</if>>
<<if $tentacle14shaft is "leftarm">>
The $tentacle14 tentacle <<slithers>> around your left arm,
<</if>>
<<if $tentacle14shaft is "rightarm">>
The $tentacle14 tentacle <<slithers>> around your right arm,
<</if>>
<<if $tentacle14head is "leftarm">>
The $tentacle14 tentacle writhes in your left hand.<<neutral 5>>
<</if>>
<<if $tentacle14head is "rightarm">>
The $tentacle14 tentacle writhes in your right hand.<<neutral 5>>
<</if>>
<<if $tentacle14head is "feet">>
The $tentacle14 tentacle writhes between your feet.<<neutral 5>>
<</if>>
<<if $tentacle14head is "leftnipplesuck">>
and up to your <<breastscomma>> where it suckles your left nipple.<<neutral 3>>
<</if>>
<<if $tentacle14head is "rightnipplesuck">>
and up to your <<breastscomma>> where it suckles your right nipple.<<neutral 3>>
<</if>>
<<if $tentacle14head is "leftnipple">>
and continues teasing your left nipple. <span class="purple">The tip of the tentacle opens up, latches on, then begins sucking.</span><<neutral 3>><<set $tentacle14head to "leftnipplesuck">><<set $leftnipple to "tentaclesuck">>
<</if>>
<<if $tentacle14head is "rightnipple">>
and continues teasing your right nipple. <span class="purple">The tip of the tentacle opens up, latches on, then begins sucking.</span><<neutral 3>><<set $tentacle14head to "rightnipplesuck">><<set $rightnipple to "tentaclesuck">>
<</if>>
<<if $tentacle14head is "chest">>
<<if $chestuse is "squeezed">>
then up between your <<breastscomma>> rubbing itself between them.<<neutral 2>>
<<else>>
moves away from your <<breasts>><<set $tentacle14head to 0>><<set $breastuse to 0>>
<</if>>
<</if>>
<<if $tentacle14head is "mouthdeep">>
and up into your mouth where it spurts a sweet fluid down your throat at the apex of each thrust.<<set $purity -= 1>><<internalejac>><<sex 5>><<set $drugged += 3>><<set $mouthgoo += 1>><<set $tentacle14health -= 1>>
<</if>>
<<if $tentacle14head is "mouth">>
and continues thrusting into your mouth.<span class="pink"> The tip opens and begins oozing a sweet liquid.</span><<set $purity -= 1>><<internalejac>><<set $mouthstate to "tentacledeep">><<set $tentacle14head to "mouthdeep">><<sex 5>><<oralejacstat>><<ejacstat>>
<</if>>
<<if $tentacle14head is "mouthimminent">>
<<if $oralvirginity is 1>>
<span class="pink"> and thrusts between your lips,</span><span class="red"> penetrating your mouth for the first time.</span><<set $oralvirginity to 0>><<violence 5>>
<<else>>
<span class="pink"> and thrusts between your lips.</span>
<</if>>
<<set $mouthstate to "tentacle">><<set $tentacle14head to "mouth">><<sex 5>><<raped>><<oralstat>>
<</if>>
<<if $tentacle14head is "mouthentrance">>
<span class="purple"> and presses against your lips.</span><<set $mouthstate to "tentacleimminent">><<set $tentacle14head to "mouthimminent">><<neutral 4>>
<</if>>
<<if $tentacle14head is "vaginadeep">>
and <<slithers>> into your <<pussy>> where it pumps a viscous fluid at the apex of each thrust.<<set $purity -= 1>><<internalejac>><<sex 5>><<set $drugged += 3>><<set $vaginagoo += 1>><<set $tentacle14health -= 1>>
<</if>>
<<if $tentacle14head is "vagina">>
and continues thrusting into your <<pussystop>><span class="pink"> The tip opens and begins oozing a viscous liquid.</span><<set $purity -= 1>><<internalejac>><<set $vaginastate to "tentacledeep">><<set $tentacle14head to "vaginadeep">><<sex 5>><<vaginalejacstat>><<ejacstat>>
<</if>>
<<if $tentacle14head is "vaginaimminent">>
<<if $vaginalvirginity is 1>>
<span class="pink"> and thrusts into your <<pussycomma>></span><span class="red"> tearing your hymen and forever robbing you of your purity.</span><<set $vaginalvirginity to 0>><<violence 100>>
<<else>>
<span class="pink"> and thrusts into your <<pussystop>></span>
<</if>>
<<set $vaginastate to "tentacle">><<set $tentacle14head to "vagina">><<sex 5>><<raped>><<vaginaraped>><<vaginalstat>><<violence 1>>
<</if>>
<<if $tentacle14head is "vaginaentrance">>
<<if $undertype isnot "chastity">>
<span class="purple"> and presses against your <<pussycomma>> about to penetrate.</span><<set $vaginastate to "tentacleimminent">><<set $tentacle14head to "vaginaimminent">><<neutral 4>>
<<else>>
and tries to find a way inside. Failing, it lashes at the metal.<<set $underintegrity -= 10>><<violence 1>>
<</if>>
<</if>>
<<if $tentacle14head is "penisdeep">>
and continues thrusting against your <<peniscomma>> caressing and kneading your length.<<sex 5>>
<</if>>
<<if $tentacle14head is "penis">>
and continues thrusting against your <<penisstop>><span class="pink"> It sucks and kneads your length, trying to milk you of your cum.</span><<set $penisstate to "tentacledeep">><<set $tentacle14head to "penisdeep">><<sex 5>>
<</if>>
<<if $tentacle14head is "penisimminent">>
<<if $penilevirginity is 1>>
<span class="pink"> and thrusts against your <<peniscomma>> swallowing you to the base and </span><span class="red"> tearing the membrane between your glans and foreskin, forever robbing you of your purity.</span><<set $penilevirginity to 0>><<violence 100>>
<<else>>
<span class="pink"> and thrusts against your <<peniscomma>> swallowing you to the base.</span>
<</if>>
<<set $penisstate to "tentacle">><<set $tentacle14head to "penis">><<sex 5>><<raped>><<penisraped>><<penilestat>><<violence 1>>
<</if>>
<<if $tentacle14head is "penisentrance">>
<<if $undertype isnot "chastity">>
<span class="purple"> and <<slithers>> over to your <<penisstop>> The tip opens and presses against your glans, about to envelop you.</span><<set $penisstate to "tentacleimminent">><<set $tentacle14head to "penisimminent">><<neutral 4>>
<<else>>
and tries to find a way inside. Failing, it lashes at the metal.<<set $underintegrity -= 10>><<violence 1>>
<</if>>
<</if>>
<<if $tentacle14head is "anusdeep">>
and <<slithers>> into your <<bottom>> where it pumps a viscous fluid at the apex of each thrust.<<set $purity -= 1>><<internalejac>><<sex 5>><<set $drugged += 3>><<set $anusgoo += 1>><<set $tentacle14health -= 1>>
<</if>>
<<if $tentacle14head is "anus">>
and continues thrusting into your <<bottomstop>><span class="pink"> The tip opens and begins oozing a viscous liquid.</span><<set $purity -= 1>><<internalejac>><<set $anusstate to "tentacledeep">><<set $tentacle14head to "anusdeep">><<sex 5>><<analejacstat>><<ejacstat>>
<</if>>
<<if $tentacle14head is "anusimminent">>
<<if $analvirginity is 1>>
<span class="pink"> and thrusts into your <<bottomcomma>></span><span class="red"> violating you in a way you hadn't conceived of.</span><<set $analvirginity to 0>><<violence 100>>
<<else>>
<span class="pink"> and thrusts into your <<bottomstop>></span>
<</if>>
<<set $anusstate to "tentacle">><<set $tentacle14head to "anus">><<sex 5>><<raped>><<analstat>><<violence 1>>
<</if>>
<<if $tentacle14head is "anusentrance">>
<<if $analshield is 0>>
<span class="purple"> and presses against your <<bottomcomma>> about to penetrate.</span><<set $anusstate to "tentacleimminent">><<set $tentacle14head to "anusimminent">><<neutral 4>>
<<else>>
and tries to find a way inside. Failing, it lashes at the device.<<set $underintegrity -= 10>><<violence 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $tentacle14head is "vaginarub">>
<<if $rng gte 21>>
and between your thighs where it <<slithers>> against your <<pussycomma>> pressing against your clit.<<sex 3>>
<<else>>
and between your thighs <span class="blue">where it <<slithers>> toward your <<pussystop>></span><<neutral 3>><<set $vaginause to "tentacle">><<set $vaginastate to "tentacleentrance">><<set $tentacle14head to "vaginaentrance">><<set $thighuse to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $tentacle14head is "penisrub">>
<<if $rng gte 21>>
and between your thighs where it <<slithers>> against your <<peniscomma>> coiling around it.<<sex 3>>
<<else>>
and between your thighs <span class="blue">where the tip opens and it <<slithers>> toward your <<penisstop>></span><<neutral 3>><<set $penisuse to "tentacle">><<set $penisstate to "tentacleentrance">><<set $tentacle14head to "penisentrance">><<set $thighuse to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $tentacle14head is "bottomrub">>
<<if $rng gte 21>>
and between your <<bottom>> cheeks where it <<slithers>> against your back.<<sex 3>>
<<else>>
and between your <<bottom>> cheeks, <span class="blue"> toward your anus.</span><<neutral 3>><<set $anususe to "tentacle">><<set $anusstate to "tentacleentrance">><<set $tentacle14head to "anusentrance">><<set $bottomuse to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $tentacle14head is 0 and $tentacle14shaft isnot 0>>
<<if $rng lte 10>>
<<if $chestuse is "squeezed" and $breastuse is 0>>
<<upperslither>><span class="blue">and up between your squeezed <<breastsstop>></span><<set $tentacle14head to "chest">><<neutral 2>><<set $breastuse to "tentacle">><<cheststat>>
<<else>>
<<tentacle14default>>
<</if>>
<<elseif $rng lte 20>>
<<if $leftnipple is 0>>
<<upperslither>> <span class="blue">and teases your left nipple.</span><<neutral 2>><<set $tentacle14head to "leftnipple">><<set $leftnipple to "tentacle">>
<<else>>
<<tentacle14default>>
<</if>>
<<elseif $rng lte 30>>
<<if $rightnipple is 0>>
<<upperslither>> <span class="blue">and teases your right nipple.</span><<neutral 2>><<set $tentacle14head to "rightnipple">><<set $rightnipple to "tentacle">>
<<else>>
<<tentacle14default>>
<</if>>
<<elseif $rng lte 40>>
<<if $mouthuse is 0>>
<<upperslither>> <span class="blue">and up toward your mouth.</span><<neutral 2>><<set $mouthuse to "tentacle">><<set $mouthstate to "tentacleentrance">><<set $tentacle14head to "mouthentrance">>
<<else>>
<<tentacle14default>>
<</if>>
<<elseif $rng lte 50>>
<<if $anususe is 0 and $analdisable is "f">>
<<underslither>> <span class="blue">and <<slithers>> toward your <<bottomstop>></span><<neutral 2>><<set $anususe to "tentacle">><<set $anusstate to "tentacleentrance">><<set $tentacle14head to "anusentrance">>
<<else>>
<<tentacle14default>>
<</if>>
<<elseif $rng lte 60>>
<<if $vaginaexist is 1 and $vaginause is 0>>
<<underslither>> <span class="blue">and <<slithers>> toward your <<pussystop>></span><<neutral 2>><<set $vaginause to "tentacle">><<set $vaginastate to "tentacleentrance">><<set $tentacle14head to "vaginaentrance">>
<<else>>
<<tentacle14default>>
<</if>>
<<elseif $rng lte 70>>
<<if $penisexist is 1 and $penisuse is 0>>
<<underslither>> <span class="blue">and <<slithers>> toward your <<penisstop>></span><<neutral 2>><<set $penisuse to "tentacle">><<set $penisstate to "tentacleentrance">><<set $tentacle14head to "penisentrance">>
<<else>>
<<tentacle14default>>
<</if>>
<<elseif $rng lte 80>>
<<if $thighuse is 0>>
<<if $penisexist is 1 and $penisuse is 0>>
<<underslither>> <span class="blue">and <<slithers>> between your thighs and against your tummy and <<penisstop>></span><<set $penisuse to "tentaclerub">><<set $thighuse to "tentaclerub">><<set $tentacle14head to "penisrub">><<sex 3>><<thighstat>>
<<elseif $vaginaexist is 1 and $vaginause is 0>>
<<underslither>> <span class="blue">and <<slithers>> between your thighs and against your tummy and <<pussystop>></span><<set $vaginause to "tentaclerub">><<set $thighuse to "tentaclerub">><<set $tentacle14head to "vaginarub">><<sex 3>><<thighstat>>
<<else>>
<<tentacle14default>>
<</if>>
<<else>>
<<tentacle14default>>
<</if>>
<<elseif $rng lte 90>>
<<if $bottomuse is 0 and $anususe is 0 and $analdisable is "f">>
<<underslither>> <span class="blue">and <<slithers>> between your <<bottom>> cheeks and against your back.</span><<set $bottomuse to "tentaclerub">><<set $anususe to "tentaclerub">><<set $tentacle14head to "bottomrub">><<sex 1>><<bottomstat>>
<<else>>
<<tentacle14default>>
<</if>>
<<else>>
<<tentacle14default>>
<</if>>
<<elseif $tentacle14head is 0 and $tentacle14shaft is 0>>
<<if $rng lte 10>>
<<if $position isnot "wall">>
The $tentacle14 tentacle winds around your tummy.<<neutral 1>><<set $tentacle14shaft to "tummy">>
<<else>>
The $tentacle14 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<elseif $rng lte 20>>
The $tentacle14 tentacle <<slithers>> between your thighs.<<neutral 1>><<set $tentacle14shaft to "thighs">>
<<elseif $rng lte 30>>
<<if $position isnot "wall">>
<<if $breastsize gte 2 and $chestuse is 0>>
The $tentacle14 tentacle <<slithers>> around your <<breastscomma>> <span class="blue">squeezing them together.</span><<neutral 1>><<set $tentacle14shaft to "breasts">><<set $chestuse to "squeezed">>
<<else>>
The $tentacle14 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<else>>
The $tentacle14 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<elseif $rng lte 40>>
<<if $position isnot "wall">>
The $tentacle14 tentacle winds its way around your chest, beneath your <<breastsstop>><<neutral 1>><<set $tentacle14shaft to "chest">>
<<else>>
The $tentacle14 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<elseif $rng lte 50>>
The $tentacle14 tentacle winds its way around your waist.<<neutral 1>><<set $tentacle14shaft to "waist">>
<<elseif $rng lte 60>>
<<if $position isnot "wall">>
<<if $head is 0>>
The $tentacle14 tentacle winds its way around your neck, <span class="blue">restraining your head.</span><<neutral 1>><<set $tentacle14shaft to "neck">><<set $head to "grappled">>
<<else>>
The $tentacle14 tentacle winds its way around your shoulders.<<neutral 1>><<set $tentacle14shaft to "shoulders">>
<</if>>
<<else>>
The $tentacle14 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<elseif $rng lte 70>>
The $tentacle14 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<<elseif $rng lte 80>>
<<if $leftleg is 0>>
The $tentacle14 tentacle winds its way around your left leg, <span class="blue">restraining it.</span><<neutral 1>><<feettentacledisable>><<set $tentacle14shaft to "leftleg">><<set $leftleg to "grappled">>
<<else>>
The $tentacle14 tentacle tickles your feet.<<neutral 1>>
<</if>>
<<elseif $rng lte 85>>
<<if $rightleg is 0>>
The $tentacle14 tentacle winds its way around your right leg, <span class="blue">restraining it.</span><<neutral 1>><<feettentacledisable>><<set $tentacle14shaft to "rightleg">><<set $rightleg to "grappled">>
<<else>>
The $tentacle14 tentacle tickles your feet.<<neutral 1>>
<</if>>
<<elseif $rng lte 90>>
<<if $leftarm is 0>>
The $tentacle14 tentacle winds its way around your left arm, <span class="blue">restraining it.</span><<neutral 1>><<leftarmtentacledisable>><<set $tentacle14shaft to "leftarm">><<set $leftarm to "grappled">><<set $leftarmstate to 0>>
<<else>>
The $tentacle14 tentacle tickles your armpit.<<neutral 1>>
<</if>>
<<elseif $rng lte 95>>
<<if $rightarm is 0>>
The $tentacle14 tentacle winds its way around your right arm, <span class="blue">restraining it.</span><<rightarmtentacledisable>><<neutral 1>><<set $tentacle14shaft to "rightarm">><<set $rightarm to "grappled">><<set $rightarmstate to 0>>
<<else>>
The $tentacle14 tentacle tickles your armpit.<<neutral 1>>
<</if>>
<<elseif $rng lte 100>>
The $tentacle14 tentacle <<slithers>> against your <<bottomstop>><<neutral 1>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "tentacle14default">><<nobr>>
<<set $rng to random(1, 100)>>
<<if $rng gte 90>>
then squirts a warm fluid over your neck.<<neutral 1>><<set $neckgoo += 1>><<set $tentacle14health -= 1>><<neckejacstat>><<ejacstat>>
<<elseif $rng gte 80>>
then squirts a warm fluid over your right arm.<<neutral 1>><<set $rightarmgoo += 1>><<set $tentacle14health -= 1>><<handejacstat>><<ejacstat>>
<<elseif $rng gte 70>>
then squirts a warm fluid over your left arm.<<neutral 1>><<set $leftarmgoo += 1>><<set $tentacle14health -= 1>><<handejacstat>><<ejacstat>>
<<elseif $rng gte 60>>
then squirts a warm fluid over your thighs.<<neutral 1>><<set $thighgoo += 1>><<set $tentacle14health -= 1>><<thighejacstat>><<ejacstat>>
<<elseif $rng gte 50>>
then squirts a warm fluid over your <<bottomstop>><<neutral 1>><<set $bottomgoo += 1>><<set $tentacle14health -= 1>><<bottomejacstat>><<ejacstat>>
<<elseif $rng gte 40>>
then squirts a warm fluid over your tummy.<<neutral 1>><<set $tummygoo += 1>><<set $tentacle14health -= 1>><<tummyejacstat>><<ejacstat>>
<<elseif $rng gte 30>>
then squirts a warm fluid over your chest.<<neutral 1>><<set $chestgoo += 1>><<set $tentacle14health -= 1>><<chestejacstat>><<ejacstat>>
<<elseif $rng gte 20>>
then squirts a warm fluid over your face.<<neutral 1>><<set $facegoo += 1>><<set $tentacle14health -= 1>><<faceejacstat>><<ejacstat>>
<<elseif $rng gte 10>>
then squirts a warm fluid over your hair.<<neutral 1>><<set $hairgoo += 1>><<set $tentacle14health -= 1>><<hairejacstat>><<ejacstat>>
<<else>>
then squirts a warm fluid over your feet.<<neutral 1>><<set $feetgoo += 1>><<set $tentacle14health -= 1>><<feetejacstat>><<ejacstat>>
<</if>>
<</nobr>><</widget>>
<<widget "tentacle14disable">><<nobr>>
<<if $tentacle14head is "feet">>
<<set $leftleg to 0>>
<<set $rightleg to 0>>
<<set $feetstate to 0>>
<</if>>
<<if $tentacle14head is "leftarm">>
<<set $leftarm to 0>>
<<set $leftarmstate to 0>>
<</if>>
<<if $tentacle14head is "rightarm">>
<<set $rightarm to 0>>
<<set $rightarmstate to 0>>
<</if>>
<<if $tentacle14head is "leftnipplesuck">>
<<set $leftnipple to 0>>
<</if>>
<<if $tentacle14head is "rightnipplesuck">>
<<set $rightnipple to 0>>
<</if>>
<<if $tentacle14head is "leftnipple">>
<<set $leftnipple to 0>>
<</if>>
<<if $tentacle14head is "rightnipple">>
<<set $rightnipple to 0>>
<</if>>
<<if $tentacle14head is "chest">>
<<set $chestuse to 0>>
<</if>>
<<if $tentacle14head is "mouthentrance">>
<<set $mouthuse to 0>>
<<set $mouthstate to 0>>
<</if>>
<<if $tentacle14head is "mouthimminent">>
<<set $mouthuse to 0>>
<<set $mouthstate to 0>>
<</if>>
<<if $tentacle14head is "mouth">>
<<set $mouthuse to 0>>
<<set $mouthstate to 0>>
<</if>>
<<if $tentacle14head is "mouthdeep">>
<<set $mouthuse to 0>>
<<set $mouthstate to 0>>
<</if>>
<<if $tentacle14head is "anusentrance">>
<<set $anususe to 0>>
<<set $anusstate to 0>>
<</if>>
<<if $tentacle14head is "anusimminent">>
<<set $anususe to 0>>
<<set $anusstate to 0>>
<</if>>
<<if $tentacle14head is "anus">>
<<set $anususe to 0>>
<<set $anusstate to 0>>
<</if>>
<<if $tentacle14head is "anusdeep">>
<<set $anususe to 0>>
<<set $anusstate to 0>>
<</if>>
<<if $tentacle14head is "vaginaentrance">>
<<set $vaginause to 0>>
<<set $vaginastate to 0>>
<</if>>
<<if $tentacle14head is "vaginaimminent">>
<<set $vaginause to 0>>
<<set $vaginastate to 0>>
<</if>>
<<if $tentacle14head is "vagina">>
<<set $vaginause to 0>>
<<set $vaginastate to 0>>
<</if>>
<<if $tentacle14head is "vaginadeep">>
<<set $vaginause to 0>>
<<set $vaginastate to 0>>
<</if>>
<<if $tentacle14head is "penisentrance">>
<<set $penisuse to 0>>
<<set $penisstate to 0>>
<</if>>
<<if $tentacle14head is "penisimminent">>
<<set $penisuse to 0>>
<<set $penisstate to 0>>
<</if>>
<<if $tentacle14head is "penis">>
<<set $penisuse to 0>>
<<set $penisstate to 0>>
<</if>>
<<if $tentacle14head is "penisdeep">>
<<set $penisuse to 0>>
<<set $penisstate to 0>>
<</if>>
<<if $tentacle14head is "vaginarub">>
<<set $vaginause to 0>>
<<set $thighuse to 0>>
<</if>>
<<if $tentacle14head is "penisrub">>
<<set $penisuse to 0>>
<<set $thighuse to 0>>
<</if>>
<<if $tentacle14head is "bottomrub">>
<<set $anususe to 0>>
<<set $bottomuse to 0>>
<</if>>
<<if $tentacle14shaft is "breasts">>
<<set $chestuse to 0>>
<</if>>
<<if $tentacle14shaft is "neck" and $head isnot "bound">>
<<set $head to 0>>
<</if>>
<<if $tentacle14shaft is "leftleg" and $leftleg isnot "bound">>
<<set $leftleg to 0>>
<</if>>
<<if $tentacle14shaft is "rightleg" and $rightleg isnot "bound">>
<<set $rightleg to 0>>
<</if>>
<<if $tentacle14shaft is "leftarm" and $leftarm isnot "bound">>
<<set $leftarm to 0>>
<</if>>
<<if $tentacle14shaft is "rightarm" and $rightarm isnot "bound">>
<<set $rightarm to 0>>
<</if>>
<<if $tentacle14head is "chest">>
<<set $breastuse to 0>>
<</if>>
<<set $tentacle14shaft to 0>>
<<set $tentacle14head to 0>>
<</nobr>><</widget>>
<<widget "actionstentacle14lefthand">><<nobr>>
<<if $leftarm is 0 and $tentacle14shaft isnot "finished">>
<<if $leftactiondefault is "lefthittentacle14">>
| <label><span class="def">Strike the $tentacle14 tentacle</span> <<radiobutton "$leftaction" "lefthittentacle14" checked>></label>
<<else>>
| <label><span class="def">Strike the $tentacle14 tentacle</span> <<radiobutton "$leftaction" "lefthittentacle14">></label>
<</if>>
<<if $leftactiondefault is "leftgrabtentacle14">>
| <label><span class="sub">Grab the $tentacle14 tentacle</span> <<radiobutton "$leftaction" "leftgrabtentacle14" checked>></label>
<<else>>
| <label><span class="sub">Grab the $tentacle14 tentacle</span> <<radiobutton "$leftaction" "leftgrabtentacle14">></label>
<</if>>
<<elseif $leftarm is "tentacle14">>You hold the $tentacle14 tentacle in your left hand.<br>
<<if $leftactiondefault is "leftrubtentacle14">>
| <label><span class="sub">Milk it</span> <<radiobutton "$leftaction" "leftrubtentacle14" checked>></label>
<<else>>
| <label><span class="sub">Milk it</span> <<radiobutton "$leftaction" "leftrubtentacle14">></label>
<</if>>
<<if $leftactiondefault is "leftstoptentacle14">>
| <label><span class="neutral">Let go</span> <<radiobutton "$leftaction" "leftstoptentacle14" checked>></label>
<<else>>
| <label><span class="neutral">Let go</span> <<radiobutton "$leftaction" "leftstoptentacle14">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle14righthand">><<nobr>>
<<if $rightarm is 0 and $tentacle14shaft isnot "finished">>
<<if $rightactiondefault is "righthittentacle14">>
| <label><span class="def">Strike the $tentacle14 tentacle</span> <<radiobutton "$rightaction" "righthittentacle14" checked>></label>
<<else>>
| <label><span class="def">Strike the $tentacle14 tentacle</span> <<radiobutton "$rightaction" "righthittentacle14">></label>
<</if>>
<<if $rightactiondefault is "rightgrabtentacle14">>
| <label><span class="sub">Grab the $tentacle14 tentacle</span> <<radiobutton "$rightaction" "rightgrabtentacle14" checked>></label>
<<else>>
| <label><span class="sub">Grab the $tentacle14 tentacle</span> <<radiobutton "$rightaction" "rightgrabtentacle14">></label>
<</if>>
<<elseif $rightarm is "tentacle14">>You hold the $tentacle14 tentacle in your right hand.<br>
<<if $rightactiondefault is "rightrubtentacle14">>
| <label><span class="sub">Milk it</span> <<radiobutton "$rightaction" "rightrubtentacle14" checked>></label>
<<else>>
| <label><span class="sub">Milk it</span> <<radiobutton "$rightaction" "rightrubtentacle14">></label>
<</if>>
<<if $rightactiondefault is "rightstoptentacle14">>
| <label><span class="neutral">Let go</span> <<radiobutton "$rightaction" "rightstoptentacle14" checked>></label>
<<else>>
| <label><span class="neutral">Let go</span> <<radiobutton "$rightaction" "rightstoptentacle14">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle14legs">><<nobr>>
<<if $leftleg is 0 and $rightleg is 0 and $tentacle14shaft isnot "finished">>
<<if $feetactiondefault is "feethittentacle14">>
| <label><span class="def">Kick the $tentacle14 tentacle</span> <<radiobutton "$feetaction" "feethittentacle14" checked>></label>
<<else>>
| <label><span class="def">Kick the $tentacle14 tentacle</span> <<radiobutton "$feetaction" "feethittentacle14">></label>
<</if>>
<<if $feetactiondefault is "feetgrabtentacle14">>
| <label><span class="sub">Grab the $tentacle14 tentacle</span> <<radiobutton "$feetaction" "feetgrabtentacle14" checked>></label>
<<else>>
| <label><span class="sub">Grab the $tentacle14 tentacle</span> <<radiobutton "$feetaction" "feetgrabtentacle14">></label>
<</if>>
<<elseif $leftleg is 0 and $tentacle14shaft isnot "finished">>
<<if $feetactiondefault is "feethittentacle14">>
| <label><span class="def">Kick the $tentacle14 tentacle</span> <<radiobutton "$feetaction" "feethittentacle14" checked>></label>
<<else>>
| <label><span class="def">Kick the $tentacle14 tentacle</span> <<radiobutton "$feetaction" "feethittentacle14">></label>
<</if>>
<<elseif $rightleg is 0 and $tentacle14shaft isnot "finished">>
<<if $feetactiondefault is "feethittentacle14">>
| <label><span class="def">Kick the $tentacle14 tentacle</span> <<radiobutton "$feetaction" "feethittentacle14" checked>></label>
<<else>>
| <label><span class="def">Kick the $tentacle14 tentacle</span> <<radiobutton "$feetaction" "feethittentacle14">></label>
<</if>>
<<elseif $leftleg is "tentacle14">>You hold the $tentacle14 tentacle between your feet.<br>
<<if $feetactiondefault is "feetrubtentacle14">>
| <label><span class="sub">Milk it</span> <<radiobutton "$feetaction" "feetrubtentacle14" checked>></label>
<<else>>
| <label><span class="sub">Milk it</span> <<radiobutton "$feetaction" "feetrubtentacle14">></label>
<</if>>
<<if $feetactiondefault is "feetstoptentacle14">>
| <label><span class="neutral">Let go</span> <<radiobutton "$feetaction" "feetstoptentacle14" checked>></label>
<<else>>
| <label><span class="neutral">Let go</span> <<radiobutton "$feetaction" "feetstoptentacle14">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle14mouth">><<nobr>>
<<if $tentacle14head is "mouthentrance">>
<<if $mouthactiondefault is "mouthlicktentacle14">>
| <label><span class="sub">Lick it</span> <<radiobutton "$mouthaction" "mouthlicktentacle14" checked>></label>
<<else>>
| <label><span class="sub">Lick it</span> <<radiobutton "$mouthaction" "mouthlicktentacle14">></label>
<</if>>
<<if $head is "grappled">>
<<else>>
<<if $mouthactiondefault is "mouthpullawaytentacle14">>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "mouthpullawaytentacle14" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "mouthpullawaytentacle14">></label>
<</if>>
<</if>>
<<elseif $tentacle14head is "mouthimminent">>
<<if $mouthactiondefault is "mouthkisstentacle14">>
| <label><span class="sub">Kiss it</span> <<radiobutton "$mouthaction" "mouthkisstentacle14" checked>></label>
<<else>>
| <label><span class="sub">Kiss it</span> <<radiobutton "$mouthaction" "mouthkisstentacle14">></label>
<</if>>
<<if $head is "grappled">>
<<else>>
<<if $mouthactiondefault is "mouthpullawaytentacle14">>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "mouthpullawaytentacle14" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "mouthpullawaytentacle14">></label>
<</if>>
<</if>>
<<elseif $tentacle14head is "mouth">>
<<if $mouthactiondefault is "mouthcooperatetentacle14">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$mouthaction" "mouthcooperatetentacle14" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$mouthaction" "mouthcooperatetentacle14">></label>
<</if>>
<<if $mouthactiondefault is "mouthbitetentacle14">>
| <label><span class="def">Bite</span> <<radiobutton "$mouthaction" "mouthbitetentacle14" checked>></label>
<<else>>
| <label><span class="def">Bite</span> <<radiobutton "$mouthaction" "mouthbitetentacle14">></label>
<</if>>
<<elseif $tentacle14head is "mouthdeep">>
<<if $mouthactiondefault is "mouthcooperatetentacle14">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$mouthaction" "mouthcooperatetentacle14" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$mouthaction" "mouthcooperatetentacle14">></label>
<</if>>
<<if $mouthactiondefault is "mouthbitetentacle14">>
| <label><span class="def">Bite</span> <<radiobutton "$mouthaction" "mouthbitetentacle14" checked>></label>
<<else>>
| <label><span class="def">Bite</span> <<radiobutton "$mouthaction" "mouthbitetentacle14">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle14vagina">><<nobr>>
<<if $tentacle14head is "vaginaentrance">>
<<if $vaginaactiondefault is "vaginarubtentacle14">>
| <label><span class="sub">Rub</span> <<radiobutton "$vaginaaction" "vaginarubtentacle14" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$vaginaaction" "vaginarubtentacle14">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $vaginaactiondefault is "vaginapullawaytentacle14">>
| <label><span class="brat">Pull away</span> <<radiobutton "$vaginaaction" "vaginapullawaytentacle14" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$vaginaaction" "vaginapullawaytentacle14">></label>
<</if>>
<</if>>
<<elseif $tentacle14head is "vaginaimminent">>
<<if $vaginaactiondefault is "vaginarubtentacle14">>
| <label><span class="sub">Rub</span> <<radiobutton "$vaginaaction" "vaginarubtentacle14" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$vaginaaction" "vaginarubtentacle14">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $vaginaactiondefault is "vaginapullawaytentacle14">>
| <label><span class="brat">Pull away</span> <<radiobutton "$vaginaaction" "vaginapullawaytentacle14" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$vaginaaction" "vaginapullawaytentacle14">></label>
<</if>>
<</if>>
<<elseif $tentacle14head is "vagina">>
<<if $vaginaactiondefault is "vaginacooperatetentacle14">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$vaginaaction" "vaginacooperatetentacle14" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$vaginaaction" "vaginacooperatetentacle14">></label>
<</if>>
<<elseif $tentacle14head is "vaginadeep">>
<<if $vaginaactiondefault is "vaginacooperatetentacle14">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$vaginaaction" "vaginacooperatetentacle14" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$vaginaaction" "vaginacooperatetentacle14">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle14penis">><<nobr>>
<<if $tentacle14head is "penisentrance">>
<<if $penisactiondefault is "penisrubtentacle14">>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "penisrubtentacle14" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "penisrubtentacle14">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $penisactiondefault is "penispullawaytentacle14">>
| <label><span class="brat">Pull away</span> <<radiobutton "$penisaction" "penispullawaytentacle14" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$penisaction" "penispullawaytentacle14">></label>
<</if>>
<</if>>
<<elseif $tentacle14head is "penisimminent">>
<<if $penisactiondefault is "penisrubtentacle14">>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "penisrubtentacle14" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "penisrubtentacle14">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $penisactiondefault is "penispullawaytentacle14">>
| <label><span class="brat">Pull away</span> <<radiobutton "$penisaction" "penispullawaytentacle14" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$penisaction" "penispullawaytentacle14">></label>
<</if>>
<</if>>
<<elseif $tentacle14head is "penis">>
<<if $penisactiondefault is "peniscooperatetentacle14">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$penisaction" "peniscooperatetentacle14" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$penisaction" "peniscooperatetentacle14">></label>
<</if>>
<<elseif $tentacle14head is "penisdeep">>
<<if $penisactiondefault is "peniscooperatetentacle14">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$penisaction" "peniscooperatetentacle14" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$penisaction" "peniscooperatetentacle14">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle14anus">><<nobr>>
<<if $tentacle14head is "anusentrance">>
<<if $anusactiondefault is "anusrubtentacle14">>
| <label><span class="sub">Rub</span> <<radiobutton "$anusaction" "anusrubtentacle14" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$anusaction" "anusrubtentacle14">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $anusactiondefault is "anuspullawaytentacle14">>
| <label><span class="brat">Pull away</span> <<radiobutton "$anusaction" "anuspullawaytentacle14" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$anusaction" "anuspullawaytentacle14">></label>
<</if>>
<</if>>
<<elseif $tentacle14head is "anusimminent">>
<<if $anusactiondefault is "anusrubtentacle14">>
| <label><span class="sub">Rub</span> <<radiobutton "$anusaction" "anusrubtentacle14" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$anusaction" "anusrubtentacle14">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $anusactiondefault is "anuspullawaytentacle14">>
| <label><span class="brat">Pull away</span> <<radiobutton "$anusaction" "anuspullawaytentacle14" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$anusaction" "anuspullawaytentacle14">></label>
<</if>>
<</if>>
<<elseif $tentacle14head is "anus">>
<<if $anusactiondefault is "anuscooperatetentacle14">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$anusaction" "anuscooperatetentacle14" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$anusaction" "anuscooperatetentacle14">></label>
<</if>>
<<elseif $tentacle14head is "anusdeep">>
<<if $anusactiondefault is "anuscooperatetentacle14">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$anusaction" "anuscooperatetentacle14" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$anusaction" "anuscooperatetentacle14">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle14thighs">><<nobr>>
<<if $tentacle14head is "penisrub">>
<<if $thighactiondefault is "penisrubtentacle14">>
| <label><span class="sub">Rub</span> <<radiobutton "$thighaction" "penisrubtentacle14" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$thighaction" "penisrubtentacle14">></label>
<</if>>
<<elseif $tentacle14head is "vaginarub">>
<<if $thighactiondefault is "vaginarubtentacle14">>
| <label><span class="sub">Rub</span> <<radiobutton "$thighaction" "vaginarubtentacle14" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$thighaction" "vaginarubtentacle14">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle14bottom">><<nobr>>
<<if $tentacle14head is "bottomrub">>
<<if $bottomactiondefault is "bottomrubtentacle14">>
| <label><span class="sub">Rub</span> <<radiobutton "$bottomaction" "bottomrubtentacle14" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$bottomaction" "bottomrubtentacle14">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle14chest">><<nobr>>
<<if $tentacle14head is "chest">>
<<if $chestactiondefault is "chestrubtentacle14">>
| <label><span class="sub">Rub</span> <<radiobutton "$chestaction" "chestrubtentacle14" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$chestaction" "chestrubtentacle14">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "effectstentacle14">><<nobr>>
<<if $leftaction is "lefthittentacle14">><<set $leftaction to 0>><<set $leftactiondefault to "lefthittentacle14">>You strike the $tentacle14 tentacle with your left hand and it reels away from you.<<defiance 2>><<set $speechhit to 1>><<tentacle14disable>><<set $attackstat += 1>><<set $tentacle14health -= 1>>
<<if $rng lte ($physique / 200)>>
<<set $tentacle14health -= 1>>
<</if>>
<</if>>
<<if $rightaction is "righthittentacle14">><<set $rightaction to 0>><<set $rightactiondefault to "righthittentacle14">>You strike the $tentacle14 tentacle with your right hand and it reels away from you.<<defiance 2>><<set $speechhit to 1>><<tentacle14disable>><<set $attackstat += 1>><<set $tentacle14health -= 1>>
<<if $rng lte ($physique / 200)>>
<<set $tentacle14health -= 1>>
<</if>>
<</if>>
<<if $leftaction is "leftgrabtentacle14">><<set $leftaction to 0>><<set $leftactiondefault to "leftrubtentacle14">><<submission 1>><<handstat>><span class="lblue">You <<handtext>> grab the $tentacle14 tentacle with your left hand.</span><<tentacle14disable>><<set $leftarm to "tentacle14">><<set $tentacle14head to "leftarm">><<handstat>><<set $leftarmstate to "tentacle">>
<</if>>
<<if $rightaction is "rightgrabtentacle14">><<set $rightaction to 0>><<set $rightactiondefault to "rightrubtentacle14">><<submission 1>><<handstat>><span class="lblue">You <<handtext>> grab the $tentacle14 tentacle with your right hand.</span><<tentacle14disable>><<set $rightarm to "tentacle14">><<set $tentacle14head to "rightarm">><<handstat>><<set $rightarmstate to "tentacle">>
<</if>>
<<if $leftaction is "leftrubtentacle14">><<set $leftaction to 0>><<set $leftactiondefault to "leftrubtentacle14">><<handskilluse>><<submission 1>>You <<handtext>> squeeze the $tentacle14 tentacle in your left hand and rub up and down its length.<<set $rng to random(1, 100)>>
<<if $handskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $rightarmgoo += 1>><<set $tentacle14health -= 3>><<handejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $rightaction is "rightrubtentacle14">><<set $rightaction to 0>><<set $rightactiondefault to "rightrubtentacle14">><<handskilluse>><<submission 1>>You <<handtext>> squeeze the $tentacle14 tentacle in your right hand and rub up and down its length.<<set $rng to random(1, 100)>>
<<if $handskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $rightarmgoo += 1>><<set $tentacle14health -= 3>><<handejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $leftaction is "leftstoptentacle14">><<set $leftaction to 0>><<set $leftactiondefault to "leftstoptentacle14">>You release the $tentacle14 tentacle from your left hand.<<tentacle14disable>>
<</if>>
<<if $rightaction is "rightstoptentacle14">><<set $rightaction to 0>><<set $rightactiondefault to "rightstoptentacle14">>You release the $tentacle14 tentacle from your right hand.<<tentacle14disable>>
<</if>>
<<if $feetaction is "feethittentacle14">><<set $feetaction to 0>><<set $feetactiondefault to "feethittentacle14">>You kick the $tentacle14 tentacle and it reels away from you.<<defiance 2>><<set $speechhit to 1>><<tentacle14disable>><<set $attackstat += 1>><<set $tentacle14health -= 1>>
<<if $rng lte ($physique / 200)>>
<<set $tentacle14health -= 1>>
<</if>>
<</if>>
<<if $feetaction is "feetgrabtentacle14">><<set $feetaction to 0>><<set $feetactiondefault to "feetrubtentacle14">><<submission 1>><<feetstat>><span class="lblue">You <<feettext>> grab the $tentacle14 tentacle between your feet.</span><<tentacle14disable>><<set $leftleg to "tentacle14">><<set $rightleg to "tentacle14">><<set $tentacle14head to "feet">><<feetstat>><<set $feetstate to "tentacle">>
<</if>>
<<if $feetaction is "feetrubtentacle14">><<set $feetaction to 0>><<set $feetactiondefault to "feetrubtentacle14">><<feetskilluse>><<submission 1>>You <<feettext>> squeeze the $tentacle14 tentacle between your feet and rub up and down its length.<<set $rng to random(1, 100)>>
<<if $feetskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $feetgoo += 1>><<set $tentacle14health -= 3>><<feetejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $feetaction is "feetstoptentacle14">><<set $feetaction to 0>><<set $feetactiondefault to "feetstoptentacle14">>You let go of the $tentacle14 tentacle between your feet.<<tentacle14disable>>
<</if>>
<<if $mouthaction is "mouthlicktentacle14">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthlicktentacle14">>
<<submission 2>><<oralskilluse>>You <<oraltext>> lick the tip of the $tentacle14 tentacle.<<set $rng to random(1, 100)>>
<<if $oralskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your face.</span><<set $facegoo += 1>><<set $tentacle14health -= 3>><<faceejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $mouthaction is "mouthkisstentacle14">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthkisstentacle14">>
<<submission 3>><<oralskilluse>>You <<oraltext>> kiss the tip of the $tentacle14 tentacle.<<set $rng to random(1, 100)>>
<<if $oralskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your face.</span><<set $facegoo += 1>><<set $tentacle14health -= 3>><<faceejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $mouthaction is "mouthcooperatetentacle14">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthcooperatetentacle14">>
<<sex 5>><<oralskilluse>>You <<oraltext>> suck the $tentacle14 tentacle invading your mouth.<<set $rng to random(1, 100)>>
<<if $oralskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip and into your mouth.</span><<set $tentacle14health -= 3>><<set $drugged += 3>><<set $mouthgoo += 1>><<oralejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $mouthaction is "mouthpullawaytentacle14">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthpullawaytentacle14">><<brat 1>><span class="teal">You pull away from the $tentacle14 tentacle threatening your mouth.</span><<tentacle14disable>>
<</if>>
<<if $mouthaction is "mouthbitetentacle14">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthbitetentacle14">><<defiance 5>>You bite down on the $tentacle14 tentacle invading your mouth. <span class="teal">It recoils immediately.</span><<tentacle14disable>><<set $attackstat += 1>><<set $tentacle14health -= 1>>
<<if $rng lte ($physique / 200)>>
<<set $tentacle14health -= 1>>
<</if>>
<</if>>
<<if $vaginaaction is "vaginarubtentacle14">><<set $vaginaaction to 0>><<set $vaginaactiondefault to "vaginarubtentacle14">>
<<submission 2>><<vaginalskilluse>>You <<vaginaltext>> rub the tip of the $tentacle14 tentacle with your <<pussystop>><<set $rng to random(1, 100)>>
<<if $vaginalskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $vaginaoutsidegoo += 1>><<set $tentacle14health -= 3>><<vaginalentranceejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $vaginaaction is "vaginacooperatetentacle14">><<set $vaginaaction to 0>><<set $vaginaactiondefault to "vaginacooperatetentacle14">>
<<sex 5>><<vaginalskilluse>>You <<vaginaltext>> push back against the $tentacle14 tentacle invading your <<pussystop>><<set $rng to random(1, 100)>>
<<if $vaginalskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, flooding your womb with its warmth.</span><<set $tentacle14health -= 3>><<set $drugged += 3>><<set $vaginagoo += 1>><<vaginalejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $vaginaaction is "vaginapullawaytentacle14">><<set $vaginaaction to 0>><<set $vaginaactiondefault to "vaginapullawaytentacle14">><<brat 1>><span class="teal">You pull away from the $tentacle14 tentacle threatening your <<pussystop>></span><<tentacle14disable>>
<</if>>
<<if $penisaction is "penisrubtentacle14">><<set $penisaction to 0>><<set $penisactiondefault to "penisrubtentacle14">>
<<submission 2>><<penileskilluse>>You <<peniletext>> rub the tip of the $tentacle14 tentacle with your <<penisstop>><<set $rng to random(1, 100)>>
<<if $penileskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $penisgoo += 1>><<set $tentacle14health -= 3>><<penileejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $penisaction is "peniscooperatetentacle14">><<set $penisaction to 0>><<set $penisactiondefault to "peniscooperatetentacle14">>
<<sex 5>><<penileskilluse>>You <<peniletext>> push back against the $tentacle14 tentacle engulfing your <<penisstop>><<set $rng to random(1, 100)>>
<<if $penileskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your groin.</span><<set $tentacle14health -= 3>><<set $penisgoo += 1>><<penileejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $penisaction is "penispullawaytentacle14">><<set $penisaction to 0>><<set $penisactiondefault to "penispullawaytentacle14">><<brat 1>><span class="teal">You pull away from the $tentacle14 tentacle threatening your <<penisstop>></span><<tentacle14disable>>
<</if>>
<<if $anusaction is "anusrubtentacle14">><<set $anusaction to 0>><<set $anusactiondefault to "anusrubtentacle14">>
<<submission 2>><<analskilluse>>You <<analtext>> rub the tip of the $tentacle14 tentacle with your <<bottomstop>><<set $rng to random(1, 100)>>
<<if $analskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your <<bottomstop>></span><<set $bottomgoo += 1>><<set $tentacle14health -= 3>><<bottomejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $anusaction is "anuscooperatetentacle14">><<set $anusaction to 0>><<set $anusactiondefault to "anuscooperatetentacle14">>
<<sex 5>><<analskilluse>>You <<analtext>> push back against the $tentacle14 tentacle invading your <<bottomstop>><<set $rng to random(1, 100)>>
<<if $analskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, flooding your bowels with its warmth.</span><<set $tentacle14health -= 3>><<set $drugged += 3>><<set $anusgoo += 1>><<analejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $anusaction is "anuspullawaytentacle14">><<set $anusaction to 0>><<set $anusactiondefault to "anuspullawaytentacle14">><<brat 1>><span class="teal">You pull away from the $tentacle14 tentacle threatening your <<bottomstop>></span><<tentacle14disable>>
<</if>>
<<if $thighaction is "penisrubtentacle14">><<set $thighaction to 0>><<set $thighactiondefault to "penisrubtentacle14">>
<<submission 3>><<thighskilluse>>You <<thightext>> rub the $tentacle14 tentacle between your thighs.<<set $rng to random(1, 100)>>
<<if $thighskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your tummy.</span><<set $tentacle14health -= 3>><<set $tummygoo += 1>><<tummyejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $thighaction is "vaginarubtentacle14">><<set $thighaction to 0>><<set $thighactiondefault to "vaginarubtentacle14">>
<<submission 3>><<thighskilluse>>You <<thightext>> rub the $tentacle14 tentacle between your thighs.<<set $rng to random(1, 100)>>
<<if $thighskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your tummy.</span><<set $tentacle14health -= 3>><<set $tummygoo += 1>><<tummyejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $bottomaction is "bottomrubtentacle14">><<set $bottomaction to 0>><<set $bottomactiondefault to "bottomrubtentacle14">>
<<submission 3>><<bottomskilluse>>You <<bottomtext>> rub the $tentacle14 tentacle between your cheeks.<<set $rng to random(1, 100)>>
<<if $bottomskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your <<bottomstop>></span><<set $tentacle14health -= 3>><<set $bottomgoo += 1>><<bottomejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $chestaction is "chestrubtentacle14">><<set $chestaction to 0>><<set $chestactiondefault to "chestrubtentacle14">>
<<submission 3>><<chestskilluse>>You <<chesttext>> rub the $tentacle14 tentacle between your <<breastsstop>><<set $rng to random(1, 100)>>
<<if $chestskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your chest.</span><<set $tentacle14health -= 3>><<set $chestgoo += 1>><<chestejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<</nobr>><</widget>>
:: Widgets Combat Tentacle15 [widget]
<<widget "tentacle15">><<nobr>>
<<if $tentacle15health lte 0 and $tentacle15shaft isnot "finished">>
Worn out, the $tentacle15 tentacle retracts from you.
<<tentacle15disable>>
<<set $tentacle15shaft to "finished">>
<<set $tentacle15head to "finished">>
<</if>>
<<if $tentacle15shaft is "tummy">>
The $tentacle15 tentacle <<slithers>> around your tummy,
<</if>>
<<if $tentacle15shaft is "thighs">>
The $tentacle15 tentacle <<slithers>> between your thighs,
<</if>>
<<if $tentacle15shaft is "breasts">>
The $tentacle15 tentacle squeezes your breasts together,
<</if>>
<<if $tentacle15shaft is "chest">>
The $tentacle15 tentacle <<slithers>> around your chest,
<</if>>
<<if $tentacle15shaft is "waist">>
The $tentacle15 tentacle <<slithers>> around your waist,
<</if>>
<<if $tentacle15shaft is "neck">>
The $tentacle15 tentacle <<slithers>> around your neck,
<</if>>
<<if $tentacle15shaft is "shoulders">>
The $tentacle15 tentacle <<slithers>> around your shoulders,
<</if>>
<<if $tentacle15shaft is "leftleg">>
The $tentacle15 tentacle <<slithers>> around your left leg,
<</if>>
<<if $tentacle15shaft is "rightleg">>
The $tentacle15 tentacle <<slithers>> around your right leg,
<</if>>
<<if $tentacle15shaft is "leftarm">>
The $tentacle15 tentacle <<slithers>> around your left arm,
<</if>>
<<if $tentacle15shaft is "rightarm">>
The $tentacle15 tentacle <<slithers>> around your right arm,
<</if>>
<<if $tentacle15head is "leftarm">>
The $tentacle15 tentacle writhes in your left hand.<<neutral 5>>
<</if>>
<<if $tentacle15head is "rightarm">>
The $tentacle15 tentacle writhes in your right hand.<<neutral 5>>
<</if>>
<<if $tentacle15head is "feet">>
The $tentacle15 tentacle writhes between your feet.<<neutral 5>>
<</if>>
<<if $tentacle15head is "leftnipplesuck">>
and up to your <<breastscomma>> where it suckles your left nipple.<<neutral 3>>
<</if>>
<<if $tentacle15head is "rightnipplesuck">>
and up to your <<breastscomma>> where it suckles your right nipple.<<neutral 3>>
<</if>>
<<if $tentacle15head is "leftnipple">>
and continues teasing your left nipple. <span class="purple">The tip of the tentacle opens up, latches on, then begins sucking.</span><<neutral 3>><<set $tentacle15head to "leftnipplesuck">><<set $leftnipple to "tentaclesuck">>
<</if>>
<<if $tentacle15head is "rightnipple">>
and continues teasing your right nipple. <span class="purple">The tip of the tentacle opens up, latches on, then begins sucking.</span><<neutral 3>><<set $tentacle15head to "rightnipplesuck">><<set $rightnipple to "tentaclesuck">>
<</if>>
<<if $tentacle15head is "chest">>
<<if $chestuse is "squeezed">>
then up between your <<breastscomma>> rubbing itself between them.<<neutral 2>>
<<else>>
moves away from your <<breasts>><<set $tentacle15head to 0>><<set $breastuse to 0>>
<</if>>
<</if>>
<<if $tentacle15head is "mouthdeep">>
and up into your mouth where it spurts a sweet fluid down your throat at the apex of each thrust.<<set $purity -= 1>><<internalejac>><<sex 5>><<set $drugged += 3>><<set $mouthgoo += 1>><<set $tentacle15health -= 1>>
<</if>>
<<if $tentacle15head is "mouth">>
and continues thrusting into your mouth.<span class="pink"> The tip opens and begins oozing a sweet liquid.</span><<set $purity -= 1>><<internalejac>><<set $mouthstate to "tentacledeep">><<set $tentacle15head to "mouthdeep">><<sex 5>><<oralejacstat>><<ejacstat>>
<</if>>
<<if $tentacle15head is "mouthimminent">>
<<if $oralvirginity is 1>>
<span class="pink"> and thrusts between your lips,</span><span class="red"> penetrating your mouth for the first time.</span><<set $oralvirginity to 0>><<violence 5>>
<<else>>
<span class="pink"> and thrusts between your lips.</span>
<</if>>
<<set $mouthstate to "tentacle">><<set $tentacle15head to "mouth">><<sex 5>><<raped>><<oralstat>>
<</if>>
<<if $tentacle15head is "mouthentrance">>
<span class="purple"> and presses against your lips.</span><<set $mouthstate to "tentacleimminent">><<set $tentacle15head to "mouthimminent">><<neutral 4>>
<</if>>
<<if $tentacle15head is "vaginadeep">>
and <<slithers>> into your <<pussy>> where it pumps a viscous fluid at the apex of each thrust.<<set $purity -= 1>><<internalejac>><<sex 5>><<set $drugged += 3>><<set $vaginagoo += 1>><<set $tentacle15health -= 1>>
<</if>>
<<if $tentacle15head is "vagina">>
and continues thrusting into your <<pussystop>><span class="pink"> The tip opens and begins oozing a viscous liquid.</span><<set $purity -= 1>><<internalejac>><<set $vaginastate to "tentacledeep">><<set $tentacle15head to "vaginadeep">><<sex 5>><<vaginalejacstat>><<ejacstat>>
<</if>>
<<if $tentacle15head is "vaginaimminent">>
<<if $vaginalvirginity is 1>>
<span class="pink"> and thrusts into your <<pussycomma>></span><span class="red"> tearing your hymen and forever robbing you of your purity.</span><<set $vaginalvirginity to 0>><<violence 100>>
<<else>>
<span class="pink"> and thrusts into your <<pussystop>></span>
<</if>>
<<set $vaginastate to "tentacle">><<set $tentacle15head to "vagina">><<sex 5>><<raped>><<vaginaraped>><<vaginalstat>><<violence 1>>
<</if>>
<<if $tentacle15head is "vaginaentrance">>
<<if $undertype isnot "chastity">>
<span class="purple"> and presses against your <<pussycomma>> about to penetrate.</span><<set $vaginastate to "tentacleimminent">><<set $tentacle15head to "vaginaimminent">><<neutral 4>>
<<else>>
and tries to find a way inside. Failing, it lashes at the metal.<<set $underintegrity -= 10>><<violence 1>>
<</if>>
<</if>>
<<if $tentacle15head is "penisdeep">>
and continues thrusting against your <<peniscomma>> caressing and kneading your length.<<sex 5>>
<</if>>
<<if $tentacle15head is "penis">>
and continues thrusting against your <<penisstop>><span class="pink"> It sucks and kneads your length, trying to milk you of your cum.</span><<set $penisstate to "tentacledeep">><<set $tentacle15head to "penisdeep">><<sex 5>>
<</if>>
<<if $tentacle15head is "penisimminent">>
<<if $penilevirginity is 1>>
<span class="pink"> and thrusts against your <<peniscomma>> swallowing you to the base and </span><span class="red"> tearing the membrane between your glans and foreskin, forever robbing you of your purity.</span><<set $penilevirginity to 0>><<violence 100>>
<<else>>
<span class="pink"> and thrusts against your <<peniscomma>> swallowing you to the base.</span>
<</if>>
<<set $penisstate to "tentacle">><<set $tentacle15head to "penis">><<sex 5>><<raped>><<penisraped>><<penilestat>><<violence 1>>
<</if>>
<<if $tentacle15head is "penisentrance">>
<<if $undertype isnot "chastity">>
<span class="purple"> and <<slithers>> over to your <<penisstop>> The tip opens and presses against your glans, about to envelop you.</span><<set $penisstate to "tentacleimminent">><<set $tentacle15head to "penisimminent">><<neutral 4>>
<<else>>
and tries to find a way inside. Failing, it lashes at the metal.<<set $underintegrity -= 10>><<violence 1>>
<</if>>
<</if>>
<<if $tentacle15head is "anusdeep">>
and <<slithers>> into your <<bottom>> where it pumps a viscous fluid at the apex of each thrust.<<set $purity -= 1>><<internalejac>><<sex 5>><<set $drugged += 3>><<set $anusgoo += 1>><<set $tentacle15health -= 1>>
<</if>>
<<if $tentacle15head is "anus">>
and continues thrusting into your <<bottomstop>><span class="pink"> The tip opens and begins oozing a viscous liquid.</span><<set $purity -= 1>><<internalejac>><<set $anusstate to "tentacledeep">><<set $tentacle15head to "anusdeep">><<sex 5>><<analejacstat>><<ejacstat>>
<</if>>
<<if $tentacle15head is "anusimminent">>
<<if $analvirginity is 1>>
<span class="pink"> and thrusts into your <<bottomcomma>></span><span class="red"> violating you in a way you hadn't conceived of.</span><<set $analvirginity to 0>><<violence 100>>
<<else>>
<span class="pink"> and thrusts into your <<bottomstop>></span>
<</if>>
<<set $anusstate to "tentacle">><<set $tentacle15head to "anus">><<sex 5>><<raped>><<analstat>><<violence 1>>
<</if>>
<<if $tentacle15head is "anusentrance">>
<<if $analshield is 0>>
<span class="purple"> and presses against your <<bottomcomma>> about to penetrate.</span><<set $anusstate to "tentacleimminent">><<set $tentacle15head to "anusimminent">><<neutral 4>>
<<else>>
and tries to find a way inside. Failing, it lashes at the device.<<set $underintegrity -= 10>><<violence 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $tentacle15head is "vaginarub">>
<<if $rng gte 21>>
and between your thighs where it <<slithers>> against your <<pussycomma>> pressing against your clit.<<sex 3>>
<<else>>
and between your thighs <span class="blue">where it <<slithers>> toward your <<pussystop>></span><<neutral 3>><<set $vaginause to "tentacle">><<set $vaginastate to "tentacleentrance">><<set $tentacle15head to "vaginaentrance">><<set $thighuse to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $tentacle15head is "penisrub">>
<<if $rng gte 21>>
and between your thighs where it <<slithers>> against your <<peniscomma>> coiling around it.<<sex 3>>
<<else>>
and between your thighs <span class="blue">where the tip opens and it <<slithers>> toward your <<penisstop>></span><<neutral 3>><<set $penisuse to "tentacle">><<set $penisstate to "tentacleentrance">><<set $tentacle15head to "penisentrance">><<set $thighuse to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $tentacle15head is "bottomrub">>
<<if $rng gte 21>>
and between your <<bottom>> cheeks where it <<slithers>> against your back.<<sex 3>>
<<else>>
and between your <<bottom>> cheeks, <span class="blue"> toward your anus.</span><<neutral 3>><<set $anususe to "tentacle">><<set $anusstate to "tentacleentrance">><<set $tentacle15head to "anusentrance">><<set $bottomuse to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $tentacle15head is 0 and $tentacle15shaft isnot 0>>
<<if $rng lte 10>>
<<if $chestuse is "squeezed" and $breastuse is 0>>
<<upperslither>><span class="blue">and up between your squeezed <<breastsstop>></span><<set $tentacle15head to "chest">><<neutral 2>><<set $breastuse to "tentacle">><<cheststat>>
<<else>>
<<tentacle15default>>
<</if>>
<<elseif $rng lte 20>>
<<if $leftnipple is 0>>
<<upperslither>> <span class="blue">and teases your left nipple.</span><<neutral 2>><<set $tentacle15head to "leftnipple">><<set $leftnipple to "tentacle">>
<<else>>
<<tentacle15default>>
<</if>>
<<elseif $rng lte 30>>
<<if $rightnipple is 0>>
<<upperslither>> <span class="blue">and teases your right nipple.</span><<neutral 2>><<set $tentacle15head to "rightnipple">><<set $rightnipple to "tentacle">>
<<else>>
<<tentacle15default>>
<</if>>
<<elseif $rng lte 40>>
<<if $mouthuse is 0>>
<<upperslither>> <span class="blue">and up toward your mouth.</span><<neutral 2>><<set $mouthuse to "tentacle">><<set $mouthstate to "tentacleentrance">><<set $tentacle15head to "mouthentrance">>
<<else>>
<<tentacle15default>>
<</if>>
<<elseif $rng lte 50>>
<<if $anususe is 0 and $analdisable is "f">>
<<underslither>> <span class="blue">and <<slithers>> toward your <<bottomstop>></span><<neutral 2>><<set $anususe to "tentacle">><<set $anusstate to "tentacleentrance">><<set $tentacle15head to "anusentrance">>
<<else>>
<<tentacle15default>>
<</if>>
<<elseif $rng lte 60>>
<<if $vaginaexist is 1 and $vaginause is 0>>
<<underslither>> <span class="blue">and <<slithers>> toward your <<pussystop>></span><<neutral 2>><<set $vaginause to "tentacle">><<set $vaginastate to "tentacleentrance">><<set $tentacle15head to "vaginaentrance">>
<<else>>
<<tentacle15default>>
<</if>>
<<elseif $rng lte 70>>
<<if $penisexist is 1 and $penisuse is 0>>
<<underslither>> <span class="blue">and <<slithers>> toward your <<penisstop>></span><<neutral 2>><<set $penisuse to "tentacle">><<set $penisstate to "tentacleentrance">><<set $tentacle15head to "penisentrance">>
<<else>>
<<tentacle15default>>
<</if>>
<<elseif $rng lte 80>>
<<if $thighuse is 0>>
<<if $penisexist is 1 and $penisuse is 0>>
<<underslither>> <span class="blue">and <<slithers>> between your thighs and against your tummy and <<penisstop>></span><<set $penisuse to "tentaclerub">><<set $thighuse to "tentaclerub">><<set $tentacle15head to "penisrub">><<sex 3>><<thighstat>>
<<elseif $vaginaexist is 1 and $vaginause is 0>>
<<underslither>> <span class="blue">and <<slithers>> between your thighs and against your tummy and <<pussystop>></span><<set $vaginause to "tentaclerub">><<set $thighuse to "tentaclerub">><<set $tentacle15head to "vaginarub">><<sex 3>><<thighstat>>
<<else>>
<<tentacle15default>>
<</if>>
<<else>>
<<tentacle15default>>
<</if>>
<<elseif $rng lte 90>>
<<if $bottomuse is 0 and $anususe is 0 and $analdisable is "f">>
<<underslither>> <span class="blue">and <<slithers>> between your <<bottom>> cheeks and against your back.</span><<set $bottomuse to "tentaclerub">><<set $anususe to "tentaclerub">><<set $tentacle15head to "bottomrub">><<sex 1>><<bottomstat>>
<<else>>
<<tentacle15default>>
<</if>>
<<else>>
<<tentacle15default>>
<</if>>
<<elseif $tentacle15head is 0 and $tentacle15shaft is 0>>
<<if $rng lte 10>>
<<if $position isnot "wall">>
The $tentacle15 tentacle winds around your tummy.<<neutral 1>><<set $tentacle15shaft to "tummy">>
<<else>>
The $tentacle15 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<elseif $rng lte 20>>
The $tentacle15 tentacle <<slithers>> between your thighs.<<neutral 1>><<set $tentacle15shaft to "thighs">>
<<elseif $rng lte 30>>
<<if $position isnot "wall">>
<<if $breastsize gte 2 and $chestuse is 0>>
The $tentacle15 tentacle <<slithers>> around your <<breastscomma>> <span class="blue">squeezing them together.</span><<neutral 1>><<set $tentacle15shaft to "breasts">><<set $chestuse to "squeezed">>
<<else>>
The $tentacle15 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<else>>
The $tentacle15 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<elseif $rng lte 40>>
<<if $position isnot "wall">>
The $tentacle15 tentacle winds its way around your chest, beneath your <<breastsstop>><<neutral 1>><<set $tentacle15shaft to "chest">>
<<else>>
The $tentacle15 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<elseif $rng lte 50>>
The $tentacle15 tentacle winds its way around your waist.<<neutral 1>><<set $tentacle15shaft to "waist">>
<<elseif $rng lte 60>>
<<if $position isnot "wall">>
<<if $head is 0>>
The $tentacle15 tentacle winds its way around your neck, <span class="blue">restraining your head.</span><<neutral 1>><<set $tentacle15shaft to "neck">><<set $head to "grappled">>
<<else>>
The $tentacle15 tentacle winds its way around your shoulders.<<neutral 1>><<set $tentacle15shaft to "shoulders">>
<</if>>
<<else>>
The $tentacle15 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<elseif $rng lte 70>>
The $tentacle15 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<<elseif $rng lte 80>>
<<if $leftleg is 0>>
The $tentacle15 tentacle winds its way around your left leg, <span class="blue">restraining it.</span><<neutral 1>><<feettentacledisable>><<set $tentacle15shaft to "leftleg">><<set $leftleg to "grappled">>
<<else>>
The $tentacle15 tentacle tickles your feet.<<neutral 1>>
<</if>>
<<elseif $rng lte 85>>
<<if $rightleg is 0>>
The $tentacle15 tentacle winds its way around your right leg, <span class="blue">restraining it.</span><<neutral 1>><<feettentacledisable>><<set $tentacle15shaft to "rightleg">><<set $rightleg to "grappled">>
<<else>>
The $tentacle15 tentacle tickles your feet.<<neutral 1>>
<</if>>
<<elseif $rng lte 90>>
<<if $leftarm is 0>>
The $tentacle15 tentacle winds its way around your left arm, <span class="blue">restraining it.</span><<neutral 1>><<leftarmtentacledisable>><<set $tentacle15shaft to "leftarm">><<set $leftarm to "grappled">><<set $leftarmstate to 0>>
<<else>>
The $tentacle15 tentacle tickles your armpit.<<neutral 1>>
<</if>>
<<elseif $rng lte 95>>
<<if $rightarm is 0>>
The $tentacle15 tentacle winds its way around your right arm, <span class="blue">restraining it.</span><<rightarmtentacledisable>><<neutral 1>><<set $tentacle15shaft to "rightarm">><<set $rightarm to "grappled">><<set $rightarmstate to 0>>
<<else>>
The $tentacle15 tentacle tickles your armpit.<<neutral 1>>
<</if>>
<<elseif $rng lte 100>>
The $tentacle15 tentacle <<slithers>> against your <<bottomstop>><<neutral 1>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "tentacle15default">><<nobr>>
<<set $rng to random(1, 100)>>
<<if $rng gte 90>>
then squirts a warm fluid over your neck.<<neutral 1>><<set $neckgoo += 1>><<set $tentacle15health -= 1>><<neckejacstat>><<ejacstat>>
<<elseif $rng gte 80>>
then squirts a warm fluid over your right arm.<<neutral 1>><<set $rightarmgoo += 1>><<set $tentacle15health -= 1>><<handejacstat>><<ejacstat>>
<<elseif $rng gte 70>>
then squirts a warm fluid over your left arm.<<neutral 1>><<set $leftarmgoo += 1>><<set $tentacle15health -= 1>><<handejacstat>><<ejacstat>>
<<elseif $rng gte 60>>
then squirts a warm fluid over your thighs.<<neutral 1>><<set $thighgoo += 1>><<set $tentacle15health -= 1>><<thighejacstat>><<ejacstat>>
<<elseif $rng gte 50>>
then squirts a warm fluid over your <<bottomstop>><<neutral 1>><<set $bottomgoo += 1>><<set $tentacle15health -= 1>><<bottomejacstat>><<ejacstat>>
<<elseif $rng gte 40>>
then squirts a warm fluid over your tummy.<<neutral 1>><<set $tummygoo += 1>><<set $tentacle15health -= 1>><<tummyejacstat>><<ejacstat>>
<<elseif $rng gte 30>>
then squirts a warm fluid over your chest.<<neutral 1>><<set $chestgoo += 1>><<set $tentacle15health -= 1>><<chestejacstat>><<ejacstat>>
<<elseif $rng gte 20>>
then squirts a warm fluid over your face.<<neutral 1>><<set $facegoo += 1>><<set $tentacle15health -= 1>><<faceejacstat>><<ejacstat>>
<<elseif $rng gte 10>>
then squirts a warm fluid over your hair.<<neutral 1>><<set $hairgoo += 1>><<set $tentacle15health -= 1>><<hairejacstat>><<ejacstat>>
<<else>>
then squirts a warm fluid over your feet.<<neutral 1>><<set $feetgoo += 1>><<set $tentacle15health -= 1>><<feetejacstat>><<ejacstat>>
<</if>>
<</nobr>><</widget>>
<<widget "tentacle15disable">><<nobr>>
<<if $tentacle15head is "feet">>
<<set $leftleg to 0>>
<<set $rightleg to 0>>
<<set $feetstate to 0>>
<</if>>
<<if $tentacle15head is "leftarm">>
<<set $leftarm to 0>>
<<set $leftarmstate to 0>>
<</if>>
<<if $tentacle15head is "rightarm">>
<<set $rightarm to 0>>
<<set $rightarmstate to 0>>
<</if>>
<<if $tentacle15head is "leftnipplesuck">>
<<set $leftnipple to 0>>
<</if>>
<<if $tentacle15head is "rightnipplesuck">>
<<set $rightnipple to 0>>
<</if>>
<<if $tentacle15head is "leftnipple">>
<<set $leftnipple to 0>>
<</if>>
<<if $tentacle15head is "rightnipple">>
<<set $rightnipple to 0>>
<</if>>
<<if $tentacle15head is "chest">>
<<set $chestuse to 0>>
<</if>>
<<if $tentacle15head is "mouthentrance">>
<<set $mouthuse to 0>>
<<set $mouthstate to 0>>
<</if>>
<<if $tentacle15head is "mouthimminent">>
<<set $mouthuse to 0>>
<<set $mouthstate to 0>>
<</if>>
<<if $tentacle15head is "mouth">>
<<set $mouthuse to 0>>
<<set $mouthstate to 0>>
<</if>>
<<if $tentacle15head is "mouthdeep">>
<<set $mouthuse to 0>>
<<set $mouthstate to 0>>
<</if>>
<<if $tentacle15head is "anusentrance">>
<<set $anususe to 0>>
<<set $anusstate to 0>>
<</if>>
<<if $tentacle15head is "anusimminent">>
<<set $anususe to 0>>
<<set $anusstate to 0>>
<</if>>
<<if $tentacle15head is "anus">>
<<set $anususe to 0>>
<<set $anusstate to 0>>
<</if>>
<<if $tentacle15head is "anusdeep">>
<<set $anususe to 0>>
<<set $anusstate to 0>>
<</if>>
<<if $tentacle15head is "vaginaentrance">>
<<set $vaginause to 0>>
<<set $vaginastate to 0>>
<</if>>
<<if $tentacle15head is "vaginaimminent">>
<<set $vaginause to 0>>
<<set $vaginastate to 0>>
<</if>>
<<if $tentacle15head is "vagina">>
<<set $vaginause to 0>>
<<set $vaginastate to 0>>
<</if>>
<<if $tentacle15head is "vaginadeep">>
<<set $vaginause to 0>>
<<set $vaginastate to 0>>
<</if>>
<<if $tentacle15head is "penisentrance">>
<<set $penisuse to 0>>
<<set $penisstate to 0>>
<</if>>
<<if $tentacle15head is "penisimminent">>
<<set $penisuse to 0>>
<<set $penisstate to 0>>
<</if>>
<<if $tentacle15head is "penis">>
<<set $penisuse to 0>>
<<set $penisstate to 0>>
<</if>>
<<if $tentacle15head is "penisdeep">>
<<set $penisuse to 0>>
<<set $penisstate to 0>>
<</if>>
<<if $tentacle15head is "vaginarub">>
<<set $vaginause to 0>>
<<set $thighuse to 0>>
<</if>>
<<if $tentacle15head is "penisrub">>
<<set $penisuse to 0>>
<<set $thighuse to 0>>
<</if>>
<<if $tentacle15head is "bottomrub">>
<<set $anususe to 0>>
<<set $bottomuse to 0>>
<</if>>
<<if $tentacle15shaft is "breasts">>
<<set $chestuse to 0>>
<</if>>
<<if $tentacle15shaft is "neck" and $head isnot "bound">>
<<set $head to 0>>
<</if>>
<<if $tentacle15shaft is "leftleg" and $leftleg isnot "bound">>
<<set $leftleg to 0>>
<</if>>
<<if $tentacle15shaft is "rightleg" and $rightleg isnot "bound">>
<<set $rightleg to 0>>
<</if>>
<<if $tentacle15shaft is "leftarm" and $leftarm isnot "bound">>
<<set $leftarm to 0>>
<</if>>
<<if $tentacle15shaft is "rightarm" and $rightarm isnot "bound">>
<<set $rightarm to 0>>
<</if>>
<<if $tentacle15head is "chest">>
<<set $breastuse to 0>>
<</if>>
<<set $tentacle15shaft to 0>>
<<set $tentacle15head to 0>>
<</nobr>><</widget>>
<<widget "actionstentacle15lefthand">><<nobr>>
<<if $leftarm is 0 and $tentacle15shaft isnot "finished">>
<<if $leftactiondefault is "lefthittentacle15">>
| <label><span class="def">Strike the $tentacle15 tentacle</span> <<radiobutton "$leftaction" "lefthittentacle15" checked>></label>
<<else>>
| <label><span class="def">Strike the $tentacle15 tentacle</span> <<radiobutton "$leftaction" "lefthittentacle15">></label>
<</if>>
<<if $leftactiondefault is "leftgrabtentacle15">>
| <label><span class="sub">Grab the $tentacle15 tentacle</span> <<radiobutton "$leftaction" "leftgrabtentacle15" checked>></label>
<<else>>
| <label><span class="sub">Grab the $tentacle15 tentacle</span> <<radiobutton "$leftaction" "leftgrabtentacle15">></label>
<</if>>
<<elseif $leftarm is "tentacle15">>You hold the $tentacle15 tentacle in your left hand.<br>
<<if $leftactiondefault is "leftrubtentacle15">>
| <label><span class="sub">Milk it</span> <<radiobutton "$leftaction" "leftrubtentacle15" checked>></label>
<<else>>
| <label><span class="sub">Milk it</span> <<radiobutton "$leftaction" "leftrubtentacle15">></label>
<</if>>
<<if $leftactiondefault is "leftstoptentacle15">>
| <label><span class="neutral">Let go</span> <<radiobutton "$leftaction" "leftstoptentacle15" checked>></label>
<<else>>
| <label><span class="neutral">Let go</span> <<radiobutton "$leftaction" "leftstoptentacle15">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle15righthand">><<nobr>>
<<if $rightarm is 0 and $tentacle15shaft isnot "finished">>
<<if $rightactiondefault is "righthittentacle15">>
| <label><span class="def">Strike the $tentacle15 tentacle</span> <<radiobutton "$rightaction" "righthittentacle15" checked>></label>
<<else>>
| <label><span class="def">Strike the $tentacle15 tentacle</span> <<radiobutton "$rightaction" "righthittentacle15">></label>
<</if>>
<<if $rightactiondefault is "rightgrabtentacle15">>
| <label><span class="sub">Grab the $tentacle15 tentacle</span> <<radiobutton "$rightaction" "rightgrabtentacle15" checked>></label>
<<else>>
| <label><span class="sub">Grab the $tentacle15 tentacle</span> <<radiobutton "$rightaction" "rightgrabtentacle15">></label>
<</if>>
<<elseif $rightarm is "tentacle15">>You hold the $tentacle15 tentacle in your right hand.<br>
<<if $rightactiondefault is "rightrubtentacle15">>
| <label><span class="sub">Milk it</span> <<radiobutton "$rightaction" "rightrubtentacle15" checked>></label>
<<else>>
| <label><span class="sub">Milk it</span> <<radiobutton "$rightaction" "rightrubtentacle15">></label>
<</if>>
<<if $rightactiondefault is "rightstoptentacle15">>
| <label><span class="neutral">Let go</span> <<radiobutton "$rightaction" "rightstoptentacle15" checked>></label>
<<else>>
| <label><span class="neutral">Let go</span> <<radiobutton "$rightaction" "rightstoptentacle15">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle15legs">><<nobr>>
<<if $leftleg is 0 and $rightleg is 0 and $tentacle15shaft isnot "finished">>
<<if $feetactiondefault is "feethittentacle15">>
| <label><span class="def">Kick the $tentacle15 tentacle</span> <<radiobutton "$feetaction" "feethittentacle15" checked>></label>
<<else>>
| <label><span class="def">Kick the $tentacle15 tentacle</span> <<radiobutton "$feetaction" "feethittentacle15">></label>
<</if>>
<<if $feetactiondefault is "feetgrabtentacle15">>
| <label><span class="sub">Grab the $tentacle15 tentacle</span> <<radiobutton "$feetaction" "feetgrabtentacle15" checked>></label>
<<else>>
| <label><span class="sub">Grab the $tentacle15 tentacle</span> <<radiobutton "$feetaction" "feetgrabtentacle15">></label>
<</if>>
<<elseif $leftleg is 0 and $tentacle15shaft isnot "finished">>
<<if $feetactiondefault is "feethittentacle15">>
| <label><span class="def">Kick the $tentacle15 tentacle</span> <<radiobutton "$feetaction" "feethittentacle15" checked>></label>
<<else>>
| <label><span class="def">Kick the $tentacle15 tentacle</span> <<radiobutton "$feetaction" "feethittentacle15">></label>
<</if>>
<<elseif $rightleg is 0 and $tentacle15shaft isnot "finished">>
<<if $feetactiondefault is "feethittentacle15">>
| <label><span class="def">Kick the $tentacle15 tentacle</span> <<radiobutton "$feetaction" "feethittentacle15" checked>></label>
<<else>>
| <label><span class="def">Kick the $tentacle15 tentacle</span> <<radiobutton "$feetaction" "feethittentacle15">></label>
<</if>>
<<elseif $leftleg is "tentacle15">>You hold the $tentacle15 tentacle between your feet.<br>
<<if $feetactiondefault is "feetrubtentacle15">>
| <label><span class="sub">Milk it</span> <<radiobutton "$feetaction" "feetrubtentacle15" checked>></label>
<<else>>
| <label><span class="sub">Milk it</span> <<radiobutton "$feetaction" "feetrubtentacle15">></label>
<</if>>
<<if $feetactiondefault is "feetstoptentacle15">>
| <label><span class="neutral">Let go</span> <<radiobutton "$feetaction" "feetstoptentacle15" checked>></label>
<<else>>
| <label><span class="neutral">Let go</span> <<radiobutton "$feetaction" "feetstoptentacle15">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle15mouth">><<nobr>>
<<if $tentacle15head is "mouthentrance">>
<<if $mouthactiondefault is "mouthlicktentacle15">>
| <label><span class="sub">Lick it</span> <<radiobutton "$mouthaction" "mouthlicktentacle15" checked>></label>
<<else>>
| <label><span class="sub">Lick it</span> <<radiobutton "$mouthaction" "mouthlicktentacle15">></label>
<</if>>
<<if $head is "grappled">>
<<else>>
<<if $mouthactiondefault is "mouthpullawaytentacle15">>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "mouthpullawaytentacle15" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "mouthpullawaytentacle15">></label>
<</if>>
<</if>>
<<elseif $tentacle15head is "mouthimminent">>
<<if $mouthactiondefault is "mouthkisstentacle15">>
| <label><span class="sub">Kiss it</span> <<radiobutton "$mouthaction" "mouthkisstentacle15" checked>></label>
<<else>>
| <label><span class="sub">Kiss it</span> <<radiobutton "$mouthaction" "mouthkisstentacle15">></label>
<</if>>
<<if $head is "grappled">>
<<else>>
<<if $mouthactiondefault is "mouthpullawaytentacle15">>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "mouthpullawaytentacle15" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "mouthpullawaytentacle15">></label>
<</if>>
<</if>>
<<elseif $tentacle15head is "mouth">>
<<if $mouthactiondefault is "mouthcooperatetentacle15">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$mouthaction" "mouthcooperatetentacle15" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$mouthaction" "mouthcooperatetentacle15">></label>
<</if>>
<<if $mouthactiondefault is "mouthbitetentacle15">>
| <label><span class="def">Bite</span> <<radiobutton "$mouthaction" "mouthbitetentacle15" checked>></label>
<<else>>
| <label><span class="def">Bite</span> <<radiobutton "$mouthaction" "mouthbitetentacle15">></label>
<</if>>
<<elseif $tentacle15head is "mouthdeep">>
<<if $mouthactiondefault is "mouthcooperatetentacle15">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$mouthaction" "mouthcooperatetentacle15" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$mouthaction" "mouthcooperatetentacle15">></label>
<</if>>
<<if $mouthactiondefault is "mouthbitetentacle15">>
| <label><span class="def">Bite</span> <<radiobutton "$mouthaction" "mouthbitetentacle15" checked>></label>
<<else>>
| <label><span class="def">Bite</span> <<radiobutton "$mouthaction" "mouthbitetentacle15">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle15vagina">><<nobr>>
<<if $tentacle15head is "vaginaentrance">>
<<if $vaginaactiondefault is "vaginarubtentacle15">>
| <label><span class="sub">Rub</span> <<radiobutton "$vaginaaction" "vaginarubtentacle15" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$vaginaaction" "vaginarubtentacle15">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $vaginaactiondefault is "vaginapullawaytentacle15">>
| <label><span class="brat">Pull away</span> <<radiobutton "$vaginaaction" "vaginapullawaytentacle15" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$vaginaaction" "vaginapullawaytentacle15">></label>
<</if>>
<</if>>
<<elseif $tentacle15head is "vaginaimminent">>
<<if $vaginaactiondefault is "vaginarubtentacle15">>
| <label><span class="sub">Rub</span> <<radiobutton "$vaginaaction" "vaginarubtentacle15" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$vaginaaction" "vaginarubtentacle15">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $vaginaactiondefault is "vaginapullawaytentacle15">>
| <label><span class="brat">Pull away</span> <<radiobutton "$vaginaaction" "vaginapullawaytentacle15" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$vaginaaction" "vaginapullawaytentacle15">></label>
<</if>>
<</if>>
<<elseif $tentacle15head is "vagina">>
<<if $vaginaactiondefault is "vaginacooperatetentacle15">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$vaginaaction" "vaginacooperatetentacle15" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$vaginaaction" "vaginacooperatetentacle15">></label>
<</if>>
<<elseif $tentacle15head is "vaginadeep">>
<<if $vaginaactiondefault is "vaginacooperatetentacle15">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$vaginaaction" "vaginacooperatetentacle15" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$vaginaaction" "vaginacooperatetentacle15">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle15penis">><<nobr>>
<<if $tentacle15head is "penisentrance">>
<<if $penisactiondefault is "penisrubtentacle15">>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "penisrubtentacle15" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "penisrubtentacle15">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $penisactiondefault is "penispullawaytentacle15">>
| <label><span class="brat">Pull away</span> <<radiobutton "$penisaction" "penispullawaytentacle15" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$penisaction" "penispullawaytentacle15">></label>
<</if>>
<</if>>
<<elseif $tentacle15head is "penisimminent">>
<<if $penisactiondefault is "penisrubtentacle15">>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "penisrubtentacle15" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "penisrubtentacle15">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $penisactiondefault is "penispullawaytentacle15">>
| <label><span class="brat">Pull away</span> <<radiobutton "$penisaction" "penispullawaytentacle15" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$penisaction" "penispullawaytentacle15">></label>
<</if>>
<</if>>
<<elseif $tentacle15head is "penis">>
<<if $penisactiondefault is "peniscooperatetentacle15">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$penisaction" "peniscooperatetentacle15" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$penisaction" "peniscooperatetentacle15">></label>
<</if>>
<<elseif $tentacle15head is "penisdeep">>
<<if $penisactiondefault is "peniscooperatetentacle15">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$penisaction" "peniscooperatetentacle15" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$penisaction" "peniscooperatetentacle15">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle15anus">><<nobr>>
<<if $tentacle15head is "anusentrance">>
<<if $anusactiondefault is "anusrubtentacle15">>
| <label><span class="sub">Rub</span> <<radiobutton "$anusaction" "anusrubtentacle15" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$anusaction" "anusrubtentacle15">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $anusactiondefault is "anuspullawaytentacle15">>
| <label><span class="brat">Pull away</span> <<radiobutton "$anusaction" "anuspullawaytentacle15" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$anusaction" "anuspullawaytentacle15">></label>
<</if>>
<</if>>
<<elseif $tentacle15head is "anusimminent">>
<<if $anusactiondefault is "anusrubtentacle15">>
| <label><span class="sub">Rub</span> <<radiobutton "$anusaction" "anusrubtentacle15" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$anusaction" "anusrubtentacle15">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $anusactiondefault is "anuspullawaytentacle15">>
| <label><span class="brat">Pull away</span> <<radiobutton "$anusaction" "anuspullawaytentacle15" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$anusaction" "anuspullawaytentacle15">></label>
<</if>>
<</if>>
<<elseif $tentacle15head is "anus">>
<<if $anusactiondefault is "anuscooperatetentacle15">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$anusaction" "anuscooperatetentacle15" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$anusaction" "anuscooperatetentacle15">></label>
<</if>>
<<elseif $tentacle15head is "anusdeep">>
<<if $anusactiondefault is "anuscooperatetentacle15">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$anusaction" "anuscooperatetentacle15" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$anusaction" "anuscooperatetentacle15">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle15thighs">><<nobr>>
<<if $tentacle15head is "penisrub">>
<<if $thighactiondefault is "penisrubtentacle15">>
| <label><span class="sub">Rub</span> <<radiobutton "$thighaction" "penisrubtentacle15" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$thighaction" "penisrubtentacle15">></label>
<</if>>
<<elseif $tentacle15head is "vaginarub">>
<<if $thighactiondefault is "vaginarubtentacle15">>
| <label><span class="sub">Rub</span> <<radiobutton "$thighaction" "vaginarubtentacle15" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$thighaction" "vaginarubtentacle15">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle15bottom">><<nobr>>
<<if $tentacle15head is "bottomrub">>
<<if $bottomactiondefault is "bottomrubtentacle15">>
| <label><span class="sub">Rub</span> <<radiobutton "$bottomaction" "bottomrubtentacle15" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$bottomaction" "bottomrubtentacle15">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle15chest">><<nobr>>
<<if $tentacle15head is "chest">>
<<if $chestactiondefault is "chestrubtentacle15">>
| <label><span class="sub">Rub</span> <<radiobutton "$chestaction" "chestrubtentacle15" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$chestaction" "chestrubtentacle15">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "effectstentacle15">><<nobr>>
<<if $leftaction is "lefthittentacle15">><<set $leftaction to 0>><<set $leftactiondefault to "lefthittentacle15">>You strike the $tentacle15 tentacle with your left hand and it reels away from you.<<defiance 2>><<set $speechhit to 1>><<tentacle15disable>><<set $attackstat += 1>><<set $tentacle15health -= 1>>
<<if $rng lte ($physique / 200)>>
<<set $tentacle15health -= 1>>
<</if>>
<</if>>
<<if $rightaction is "righthittentacle15">><<set $rightaction to 0>><<set $rightactiondefault to "righthittentacle15">>You strike the $tentacle15 tentacle with your right hand and it reels away from you.<<defiance 2>><<set $speechhit to 1>><<tentacle15disable>><<set $attackstat += 1>><<set $tentacle15health -= 1>>
<<if $rng lte ($physique / 200)>>
<<set $tentacle15health -= 1>>
<</if>>
<</if>>
<<if $leftaction is "leftgrabtentacle15">><<set $leftaction to 0>><<set $leftactiondefault to "leftrubtentacle15">><<submission 1>><<handstat>><span class="lblue">You <<handtext>> grab the $tentacle15 tentacle with your left hand.</span><<tentacle15disable>><<set $leftarm to "tentacle15">><<set $tentacle15head to "leftarm">><<handstat>><<set $leftarmstate to "tentacle">>
<</if>>
<<if $rightaction is "rightgrabtentacle15">><<set $rightaction to 0>><<set $rightactiondefault to "rightrubtentacle15">><<submission 1>><<handstat>><span class="lblue">You <<handtext>> grab the $tentacle15 tentacle with your right hand.</span><<tentacle15disable>><<set $rightarm to "tentacle15">><<set $tentacle15head to "rightarm">><<handstat>><<set $rightarmstate to "tentacle">>
<</if>>
<<if $leftaction is "leftrubtentacle15">><<set $leftaction to 0>><<set $leftactiondefault to "leftrubtentacle15">><<handskilluse>><<submission 1>>You <<handtext>> squeeze the $tentacle15 tentacle in your left hand and rub up and down its length.<<set $rng to random(1, 100)>>
<<if $handskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $rightarmgoo += 1>><<set $tentacle15health -= 3>><<handejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $rightaction is "rightrubtentacle15">><<set $rightaction to 0>><<set $rightactiondefault to "rightrubtentacle15">><<handskilluse>><<submission 1>>You <<handtext>> squeeze the $tentacle15 tentacle in your right hand and rub up and down its length.<<set $rng to random(1, 100)>>
<<if $handskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $rightarmgoo += 1>><<set $tentacle15health -= 3>><<handejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $leftaction is "leftstoptentacle15">><<set $leftaction to 0>><<set $leftactiondefault to "leftstoptentacle15">>You release the $tentacle15 tentacle from your left hand.<<tentacle15disable>>
<</if>>
<<if $rightaction is "rightstoptentacle15">><<set $rightaction to 0>><<set $rightactiondefault to "rightstoptentacle15">>You release the $tentacle15 tentacle from your right hand.<<tentacle15disable>>
<</if>>
<<if $feetaction is "feethittentacle15">><<set $feetaction to 0>><<set $feetactiondefault to "feethittentacle15">>You kick the $tentacle15 tentacle and it reels away from you.<<defiance 2>><<set $speechhit to 1>><<tentacle15disable>><<set $attackstat += 1>><<set $tentacle15health -= 1>>
<<if $rng lte ($physique / 200)>>
<<set $tentacle15health -= 1>>
<</if>>
<</if>>
<<if $feetaction is "feetgrabtentacle15">><<set $feetaction to 0>><<set $feetactiondefault to "feetrubtentacle15">><<submission 1>><<feetstat>><span class="lblue">You <<feettext>> grab the $tentacle15 tentacle between your feet.</span><<tentacle15disable>><<set $leftleg to "tentacle15">><<set $rightleg to "tentacle15">><<set $tentacle15head to "feet">><<feetstat>><<set $feetstate to "tentacle">>
<</if>>
<<if $feetaction is "feetrubtentacle15">><<set $feetaction to 0>><<set $feetactiondefault to "feetrubtentacle15">><<feetskilluse>><<submission 1>>You <<feettext>> squeeze the $tentacle15 tentacle between your feet and rub up and down its length.<<set $rng to random(1, 100)>>
<<if $feetskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $feetgoo += 1>><<set $tentacle15health -= 3>><<feetejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $feetaction is "feetstoptentacle15">><<set $feetaction to 0>><<set $feetactiondefault to "feetstoptentacle15">>You let go of the $tentacle15 tentacle between your feet.<<tentacle15disable>>
<</if>>
<<if $mouthaction is "mouthlicktentacle15">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthlicktentacle15">>
<<submission 2>><<oralskilluse>>You <<oraltext>> lick the tip of the $tentacle15 tentacle.<<set $rng to random(1, 100)>>
<<if $oralskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your face.</span><<set $facegoo += 1>><<set $tentacle15health -= 3>><<faceejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $mouthaction is "mouthkisstentacle15">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthkisstentacle15">>
<<submission 3>><<oralskilluse>>You <<oraltext>> kiss the tip of the $tentacle15 tentacle.<<set $rng to random(1, 100)>>
<<if $oralskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your face.</span><<set $facegoo += 1>><<set $tentacle15health -= 3>><<faceejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $mouthaction is "mouthcooperatetentacle15">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthcooperatetentacle15">>
<<sex 5>><<oralskilluse>>You <<oraltext>> suck the $tentacle15 tentacle invading your mouth.<<set $rng to random(1, 100)>>
<<if $oralskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip and into your mouth.</span><<set $tentacle15health -= 3>><<set $drugged += 3>><<set $mouthgoo += 1>><<oralejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $mouthaction is "mouthpullawaytentacle15">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthpullawaytentacle15">><<brat 1>><span class="teal">You pull away from the $tentacle15 tentacle threatening your mouth.</span><<tentacle15disable>>
<</if>>
<<if $mouthaction is "mouthbitetentacle15">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthbitetentacle15">><<defiance 5>>You bite down on the $tentacle15 tentacle invading your mouth. <span class="teal">It recoils immediately.</span><<tentacle15disable>><<set $attackstat += 1>><<set $tentacle15health -= 1>>
<<if $rng lte ($physique / 200)>>
<<set $tentacle15health -= 1>>
<</if>>
<</if>>
<<if $vaginaaction is "vaginarubtentacle15">><<set $vaginaaction to 0>><<set $vaginaactiondefault to "vaginarubtentacle15">>
<<submission 2>><<vaginalskilluse>>You <<vaginaltext>> rub the tip of the $tentacle15 tentacle with your <<pussystop>><<set $rng to random(1, 100)>>
<<if $vaginalskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $vaginaoutsidegoo += 1>><<set $tentacle15health -= 3>><<vaginalentranceejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $vaginaaction is "vaginacooperatetentacle15">><<set $vaginaaction to 0>><<set $vaginaactiondefault to "vaginacooperatetentacle15">>
<<sex 5>><<vaginalskilluse>>You <<vaginaltext>> push back against the $tentacle15 tentacle invading your <<pussystop>><<set $rng to random(1, 100)>>
<<if $vaginalskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, flooding your womb with its warmth.</span><<set $tentacle15health -= 3>><<set $drugged += 3>><<set $vaginagoo += 1>><<vaginalejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $vaginaaction is "vaginapullawaytentacle15">><<set $vaginaaction to 0>><<set $vaginaactiondefault to "vaginapullawaytentacle15">><<brat 1>><span class="teal">You pull away from the $tentacle15 tentacle threatening your <<pussystop>></span><<tentacle15disable>>
<</if>>
<<if $penisaction is "penisrubtentacle15">><<set $penisaction to 0>><<set $penisactiondefault to "penisrubtentacle15">>
<<submission 2>><<penileskilluse>>You <<peniletext>> rub the tip of the $tentacle15 tentacle with your <<penisstop>><<set $rng to random(1, 100)>>
<<if $penileskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $penisgoo += 1>><<set $tentacle15health -= 3>><<penileejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $penisaction is "peniscooperatetentacle15">><<set $penisaction to 0>><<set $penisactiondefault to "peniscooperatetentacle15">>
<<sex 5>><<penileskilluse>>You <<peniletext>> push back against the $tentacle15 tentacle engulfing your <<penisstop>><<set $rng to random(1, 100)>>
<<if $penileskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your groin.</span><<set $tentacle15health -= 3>><<set $penisgoo += 1>><<penileejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $penisaction is "penispullawaytentacle15">><<set $penisaction to 0>><<set $penisactiondefault to "penispullawaytentacle15">><<brat 1>><span class="teal">You pull away from the $tentacle15 tentacle threatening your <<penisstop>></span><<tentacle15disable>>
<</if>>
<<if $anusaction is "anusrubtentacle15">><<set $anusaction to 0>><<set $anusactiondefault to "anusrubtentacle15">>
<<submission 2>><<analskilluse>>You <<analtext>> rub the tip of the $tentacle15 tentacle with your <<bottomstop>><<set $rng to random(1, 100)>>
<<if $analskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your <<bottomstop>></span><<set $bottomgoo += 1>><<set $tentacle15health -= 3>><<bottomejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $anusaction is "anuscooperatetentacle15">><<set $anusaction to 0>><<set $anusactiondefault to "anuscooperatetentacle15">>
<<sex 5>><<analskilluse>>You <<analtext>> push back against the $tentacle15 tentacle invading your <<bottomstop>><<set $rng to random(1, 100)>>
<<if $analskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, flooding your bowels with its warmth.</span><<set $tentacle15health -= 3>><<set $drugged += 3>><<set $anusgoo += 1>><<analejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $anusaction is "anuspullawaytentacle15">><<set $anusaction to 0>><<set $anusactiondefault to "anuspullawaytentacle15">><<brat 1>><span class="teal">You pull away from the $tentacle15 tentacle threatening your <<bottomstop>></span><<tentacle15disable>>
<</if>>
<<if $thighaction is "penisrubtentacle15">><<set $thighaction to 0>><<set $thighactiondefault to "penisrubtentacle15">>
<<submission 3>><<thighskilluse>>You <<thightext>> rub the $tentacle15 tentacle between your thighs.<<set $rng to random(1, 100)>>
<<if $thighskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your tummy.</span><<set $tentacle15health -= 3>><<set $tummygoo += 1>><<tummyejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $thighaction is "vaginarubtentacle15">><<set $thighaction to 0>><<set $thighactiondefault to "vaginarubtentacle15">>
<<submission 3>><<thighskilluse>>You <<thightext>> rub the $tentacle15 tentacle between your thighs.<<set $rng to random(1, 100)>>
<<if $thighskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your tummy.</span><<set $tentacle15health -= 3>><<set $tummygoo += 1>><<tummyejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $bottomaction is "bottomrubtentacle15">><<set $bottomaction to 0>><<set $bottomactiondefault to "bottomrubtentacle15">>
<<submission 3>><<bottomskilluse>>You <<bottomtext>> rub the $tentacle15 tentacle between your cheeks.<<set $rng to random(1, 100)>>
<<if $bottomskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your <<bottomstop>></span><<set $tentacle15health -= 3>><<set $bottomgoo += 1>><<bottomejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $chestaction is "chestrubtentacle15">><<set $chestaction to 0>><<set $chestactiondefault to "chestrubtentacle15">>
<<submission 3>><<chestskilluse>>You <<chesttext>> rub the $tentacle15 tentacle between your <<breastsstop>><<set $rng to random(1, 100)>>
<<if $chestskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your chest.</span><<set $tentacle15health -= 3>><<set $chestgoo += 1>><<chestejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<</nobr>><</widget>>
:: Widgets Combat Tentacle16 [widget]
<<widget "tentacle16">><<nobr>>
<<if $tentacle16health lte 0 and $tentacle16shaft isnot "finished">>
Worn out, the $tentacle16 tentacle retracts from you.
<<tentacle16disable>>
<<set $tentacle16shaft to "finished">>
<<set $tentacle16head to "finished">>
<</if>>
<<if $tentacle16shaft is "tummy">>
The $tentacle16 tentacle <<slithers>> around your tummy,
<</if>>
<<if $tentacle16shaft is "thighs">>
The $tentacle16 tentacle <<slithers>> between your thighs,
<</if>>
<<if $tentacle16shaft is "breasts">>
The $tentacle16 tentacle squeezes your breasts together,
<</if>>
<<if $tentacle16shaft is "chest">>
The $tentacle16 tentacle <<slithers>> around your chest,
<</if>>
<<if $tentacle16shaft is "waist">>
The $tentacle16 tentacle <<slithers>> around your waist,
<</if>>
<<if $tentacle16shaft is "neck">>
The $tentacle16 tentacle <<slithers>> around your neck,
<</if>>
<<if $tentacle16shaft is "shoulders">>
The $tentacle16 tentacle <<slithers>> around your shoulders,
<</if>>
<<if $tentacle16shaft is "leftleg">>
The $tentacle16 tentacle <<slithers>> around your left leg,
<</if>>
<<if $tentacle16shaft is "rightleg">>
The $tentacle16 tentacle <<slithers>> around your right leg,
<</if>>
<<if $tentacle16shaft is "leftarm">>
The $tentacle16 tentacle <<slithers>> around your left arm,
<</if>>
<<if $tentacle16shaft is "rightarm">>
The $tentacle16 tentacle <<slithers>> around your right arm,
<</if>>
<<if $tentacle16head is "leftarm">>
The $tentacle16 tentacle writhes in your left hand.<<neutral 5>>
<</if>>
<<if $tentacle16head is "rightarm">>
The $tentacle16 tentacle writhes in your right hand.<<neutral 5>>
<</if>>
<<if $tentacle16head is "feet">>
The $tentacle16 tentacle writhes between your feet.<<neutral 5>>
<</if>>
<<if $tentacle16head is "leftnipplesuck">>
and up to your <<breastscomma>> where it suckles your left nipple.<<neutral 3>>
<</if>>
<<if $tentacle16head is "rightnipplesuck">>
and up to your <<breastscomma>> where it suckles your right nipple.<<neutral 3>>
<</if>>
<<if $tentacle16head is "leftnipple">>
and continues teasing your left nipple. <span class="purple">The tip of the tentacle opens up, latches on, then begins sucking.</span><<neutral 3>><<set $tentacle16head to "leftnipplesuck">><<set $leftnipple to "tentaclesuck">>
<</if>>
<<if $tentacle16head is "rightnipple">>
and continues teasing your right nipple. <span class="purple">The tip of the tentacle opens up, latches on, then begins sucking.</span><<neutral 3>><<set $tentacle16head to "rightnipplesuck">><<set $rightnipple to "tentaclesuck">>
<</if>>
<<if $tentacle16head is "chest">>
<<if $chestuse is "squeezed">>
then up between your <<breastscomma>> rubbing itself between them.<<neutral 2>>
<<else>>
moves away from your <<breasts>><<set $tentacle16head to 0>><<set $breastuse to 0>>
<</if>>
<</if>>
<<if $tentacle16head is "mouthdeep">>
and up into your mouth where it spurts a sweet fluid down your throat at the apex of each thrust.<<set $purity -= 1>><<internalejac>><<sex 5>><<set $drugged += 3>><<set $mouthgoo += 1>><<set $tentacle16health -= 1>>
<</if>>
<<if $tentacle16head is "mouth">>
and continues thrusting into your mouth.<span class="pink"> The tip opens and begins oozing a sweet liquid.</span><<set $purity -= 1>><<internalejac>><<set $mouthstate to "tentacledeep">><<set $tentacle16head to "mouthdeep">><<sex 5>><<oralejacstat>><<ejacstat>>
<</if>>
<<if $tentacle16head is "mouthimminent">>
<<if $oralvirginity is 1>>
<span class="pink"> and thrusts between your lips,</span><span class="red"> penetrating your mouth for the first time.</span><<set $oralvirginity to 0>><<violence 5>>
<<else>>
<span class="pink"> and thrusts between your lips.</span>
<</if>>
<<set $mouthstate to "tentacle">><<set $tentacle16head to "mouth">><<sex 5>><<raped>><<oralstat>>
<</if>>
<<if $tentacle16head is "mouthentrance">>
<span class="purple"> and presses against your lips.</span><<set $mouthstate to "tentacleimminent">><<set $tentacle16head to "mouthimminent">><<neutral 4>>
<</if>>
<<if $tentacle16head is "vaginadeep">>
and <<slithers>> into your <<pussy>> where it pumps a viscous fluid at the apex of each thrust.<<set $purity -= 1>><<internalejac>><<sex 5>><<set $drugged += 3>><<set $vaginagoo += 1>><<set $tentacle16health -= 1>>
<</if>>
<<if $tentacle16head is "vagina">>
and continues thrusting into your <<pussystop>><span class="pink"> The tip opens and begins oozing a viscous liquid.</span><<set $purity -= 1>><<internalejac>><<set $vaginastate to "tentacledeep">><<set $tentacle16head to "vaginadeep">><<sex 5>><<vaginalejacstat>><<ejacstat>>
<</if>>
<<if $tentacle16head is "vaginaimminent">>
<<if $vaginalvirginity is 1>>
<span class="pink"> and thrusts into your <<pussycomma>></span><span class="red"> tearing your hymen and forever robbing you of your purity.</span><<set $vaginalvirginity to 0>><<violence 100>>
<<else>>
<span class="pink"> and thrusts into your <<pussystop>></span>
<</if>>
<<set $vaginastate to "tentacle">><<set $tentacle16head to "vagina">><<sex 5>><<raped>><<vaginaraped>><<vaginalstat>><<violence 1>>
<</if>>
<<if $tentacle16head is "vaginaentrance">>
<<if $undertype isnot "chastity">>
<span class="purple"> and presses against your <<pussycomma>> about to penetrate.</span><<set $vaginastate to "tentacleimminent">><<set $tentacle16head to "vaginaimminent">><<neutral 4>>
<<else>>
and tries to find a way inside. Failing, it lashes at the metal.<<set $underintegrity -= 10>><<violence 1>>
<</if>>
<</if>>
<<if $tentacle16head is "penisdeep">>
and continues thrusting against your <<peniscomma>> caressing and kneading your length.<<sex 5>>
<</if>>
<<if $tentacle16head is "penis">>
and continues thrusting against your <<penisstop>><span class="pink"> It sucks and kneads your length, trying to milk you of your cum.</span><<set $penisstate to "tentacledeep">><<set $tentacle16head to "penisdeep">><<sex 5>>
<</if>>
<<if $tentacle16head is "penisimminent">>
<<if $penilevirginity is 1>>
<span class="pink"> and thrusts against your <<peniscomma>> swallowing you to the base and </span><span class="red"> tearing the membrane between your glans and foreskin, forever robbing you of your purity.</span><<set $penilevirginity to 0>><<violence 100>>
<<else>>
<span class="pink"> and thrusts against your <<peniscomma>> swallowing you to the base.</span>
<</if>>
<<set $penisstate to "tentacle">><<set $tentacle16head to "penis">><<sex 5>><<raped>><<penisraped>><<penilestat>><<violence 1>>
<</if>>
<<if $tentacle16head is "penisentrance">>
<<if $undertype isnot "chastity">>
<span class="purple"> and <<slithers>> over to your <<penisstop>> The tip opens and presses against your glans, about to envelop you.</span><<set $penisstate to "tentacleimminent">><<set $tentacle16head to "penisimminent">><<neutral 4>>
<<else>>
and tries to find a way inside. Failing, it lashes at the metal.<<set $underintegrity -= 10>><<violence 1>>
<</if>>
<</if>>
<<if $tentacle16head is "anusdeep">>
and <<slithers>> into your <<bottom>> where it pumps a viscous fluid at the apex of each thrust.<<set $purity -= 1>><<internalejac>><<sex 5>><<set $drugged += 3>><<set $anusgoo += 1>><<set $tentacle16health -= 1>>
<</if>>
<<if $tentacle16head is "anus">>
and continues thrusting into your <<bottomstop>><span class="pink"> The tip opens and begins oozing a viscous liquid.</span><<set $purity -= 1>><<internalejac>><<set $anusstate to "tentacledeep">><<set $tentacle16head to "anusdeep">><<sex 5>><<analejacstat>><<ejacstat>>
<</if>>
<<if $tentacle16head is "anusimminent">>
<<if $analvirginity is 1>>
<span class="pink"> and thrusts into your <<bottomcomma>></span><span class="red"> violating you in a way you hadn't conceived of.</span><<set $analvirginity to 0>><<violence 100>>
<<else>>
<span class="pink"> and thrusts into your <<bottomstop>></span>
<</if>>
<<set $anusstate to "tentacle">><<set $tentacle16head to "anus">><<sex 5>><<raped>><<analstat>><<violence 1>>
<</if>>
<<if $tentacle16head is "anusentrance">>
<<if $analshield is 0>>
<span class="purple"> and presses against your <<bottomcomma>> about to penetrate.</span><<set $anusstate to "tentacleimminent">><<set $tentacle16head to "anusimminent">><<neutral 4>>
<<else>>
and tries to find a way inside. Failing, it lashes at the device.<<set $underintegrity -= 10>><<violence 1>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $tentacle16head is "vaginarub">>
<<if $rng gte 21>>
and between your thighs where it <<slithers>> against your <<pussycomma>> pressing against your clit.<<sex 3>>
<<else>>
and between your thighs <span class="blue">where it <<slithers>> toward your <<pussystop>></span><<neutral 3>><<set $vaginause to "tentacle">><<set $vaginastate to "tentacleentrance">><<set $tentacle16head to "vaginaentrance">><<set $thighuse to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $tentacle16head is "penisrub">>
<<if $rng gte 21>>
and between your thighs where it <<slithers>> against your <<peniscomma>> coiling around it.<<sex 3>>
<<else>>
and between your thighs <span class="blue">where the tip opens and it <<slithers>> toward your <<penisstop>></span><<neutral 3>><<set $penisuse to "tentacle">><<set $penisstate to "tentacleentrance">><<set $tentacle16head to "penisentrance">><<set $thighuse to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $tentacle16head is "bottomrub">>
<<if $rng gte 21>>
and between your <<bottom>> cheeks where it <<slithers>> against your back.<<sex 3>>
<<else>>
and between your <<bottom>> cheeks, <span class="blue"> toward your anus.</span><<neutral 3>><<set $anususe to "tentacle">><<set $anusstate to "tentacleentrance">><<set $tentacle16head to "anusentrance">><<set $bottomuse to 0>>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $tentacle16head is 0 and $tentacle16shaft isnot 0>>
<<if $rng lte 10>>
<<if $chestuse is "squeezed" and $breastuse is 0>>
<<upperslither>><span class="blue">and up between your squeezed <<breastsstop>></span><<set $tentacle16head to "chest">><<neutral 2>><<set $breastuse to "tentacle">><<cheststat>>
<<else>>
<<tentacle16default>>
<</if>>
<<elseif $rng lte 20>>
<<if $leftnipple is 0>>
<<upperslither>> <span class="blue">and teases your left nipple.</span><<neutral 2>><<set $tentacle16head to "leftnipple">><<set $leftnipple to "tentacle">>
<<else>>
<<tentacle16default>>
<</if>>
<<elseif $rng lte 30>>
<<if $rightnipple is 0>>
<<upperslither>> <span class="blue">and teases your right nipple.</span><<neutral 2>><<set $tentacle16head to "rightnipple">><<set $rightnipple to "tentacle">>
<<else>>
<<tentacle16default>>
<</if>>
<<elseif $rng lte 40>>
<<if $mouthuse is 0>>
<<upperslither>> <span class="blue">and up toward your mouth.</span><<neutral 2>><<set $mouthuse to "tentacle">><<set $mouthstate to "tentacleentrance">><<set $tentacle16head to "mouthentrance">>
<<else>>
<<tentacle16default>>
<</if>>
<<elseif $rng lte 50>>
<<if $anususe is 0 and $analdisable is "f">>
<<underslither>> <span class="blue">and <<slithers>> toward your <<bottomstop>></span><<neutral 2>><<set $anususe to "tentacle">><<set $anusstate to "tentacleentrance">><<set $tentacle16head to "anusentrance">>
<<else>>
<<tentacle16default>>
<</if>>
<<elseif $rng lte 60>>
<<if $vaginaexist is 1 and $vaginause is 0>>
<<underslither>> <span class="blue">and <<slithers>> toward your <<pussystop>></span><<neutral 2>><<set $vaginause to "tentacle">><<set $vaginastate to "tentacleentrance">><<set $tentacle16head to "vaginaentrance">>
<<else>>
<<tentacle16default>>
<</if>>
<<elseif $rng lte 70>>
<<if $penisexist is 1 and $penisuse is 0>>
<<underslither>> <span class="blue">and <<slithers>> toward your <<penisstop>></span><<neutral 2>><<set $penisuse to "tentacle">><<set $penisstate to "tentacleentrance">><<set $tentacle16head to "penisentrance">>
<<else>>
<<tentacle16default>>
<</if>>
<<elseif $rng lte 80>>
<<if $thighuse is 0>>
<<if $penisexist is 1 and $penisuse is 0>>
<<underslither>> <span class="blue">and <<slithers>> between your thighs and against your tummy and <<penisstop>></span><<set $penisuse to "tentaclerub">><<set $thighuse to "tentaclerub">><<set $tentacle16head to "penisrub">><<sex 3>><<thighstat>>
<<elseif $vaginaexist is 1 and $vaginause is 0>>
<<underslither>> <span class="blue">and <<slithers>> between your thighs and against your tummy and <<pussystop>></span><<set $vaginause to "tentaclerub">><<set $thighuse to "tentaclerub">><<set $tentacle16head to "vaginarub">><<sex 3>><<thighstat>>
<<else>>
<<tentacle16default>>
<</if>>
<<else>>
<<tentacle16default>>
<</if>>
<<elseif $rng lte 90>>
<<if $bottomuse is 0 and $anususe is 0 and $analdisable is "f">>
<<underslither>> <span class="blue">and <<slithers>> between your <<bottom>> cheeks and against your back.</span><<set $bottomuse to "tentaclerub">><<set $anususe to "tentaclerub">><<set $tentacle16head to "bottomrub">><<sex 1>><<bottomstat>>
<<else>>
<<tentacle16default>>
<</if>>
<<else>>
<<tentacle16default>>
<</if>>
<<elseif $tentacle16head is 0 and $tentacle16shaft is 0>>
<<if $rng lte 10>>
<<if $position isnot "wall">>
The $tentacle16 tentacle winds around your tummy.<<neutral 1>><<set $tentacle16shaft to "tummy">>
<<else>>
The $tentacle16 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<elseif $rng lte 20>>
The $tentacle16 tentacle <<slithers>> between your thighs.<<neutral 1>><<set $tentacle16shaft to "thighs">>
<<elseif $rng lte 30>>
<<if $position isnot "wall">>
<<if $breastsize gte 2 and $chestuse is 0>>
The $tentacle16 tentacle <<slithers>> around your <<breastscomma>> <span class="blue">squeezing them together.</span><<neutral 1>><<set $tentacle16shaft to "breasts">><<set $chestuse to "squeezed">>
<<else>>
The $tentacle16 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<else>>
The $tentacle16 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<elseif $rng lte 40>>
<<if $position isnot "wall">>
The $tentacle16 tentacle winds its way around your chest, beneath your <<breastsstop>><<neutral 1>><<set $tentacle16shaft to "chest">>
<<else>>
The $tentacle16 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<elseif $rng lte 50>>
The $tentacle16 tentacle winds its way around your waist.<<neutral 1>><<set $tentacle16shaft to "waist">>
<<elseif $rng lte 60>>
<<if $position isnot "wall">>
<<if $head is 0>>
The $tentacle16 tentacle winds its way around your neck, <span class="blue">restraining your head.</span><<neutral 1>><<set $tentacle16shaft to "neck">><<set $head to "grappled">>
<<else>>
The $tentacle16 tentacle winds its way around your shoulders.<<neutral 1>><<set $tentacle16shaft to "shoulders">>
<</if>>
<<else>>
The $tentacle16 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<</if>>
<<elseif $rng lte 70>>
The $tentacle16 tentacle gently slaps your <<bottomstop>><<violence 1>><<hitstat>>
<<elseif $rng lte 80>>
<<if $leftleg is 0>>
The $tentacle16 tentacle winds its way around your left leg, <span class="blue">restraining it.</span><<neutral 1>><<feettentacledisable>><<set $tentacle16shaft to "leftleg">><<set $leftleg to "grappled">>
<<else>>
The $tentacle16 tentacle tickles your feet.<<neutral 1>>
<</if>>
<<elseif $rng lte 85>>
<<if $rightleg is 0>>
The $tentacle16 tentacle winds its way around your right leg, <span class="blue">restraining it.</span><<neutral 1>><<feettentacledisable>><<set $tentacle16shaft to "rightleg">><<set $rightleg to "grappled">>
<<else>>
The $tentacle16 tentacle tickles your feet.<<neutral 1>>
<</if>>
<<elseif $rng lte 90>>
<<if $leftarm is 0>>
The $tentacle16 tentacle winds its way around your left arm, <span class="blue">restraining it.</span><<neutral 1>><<leftarmtentacledisable>><<set $tentacle16shaft to "leftarm">><<set $leftarm to "grappled">><<set $leftarmstate to 0>>
<<else>>
The $tentacle16 tentacle tickles your armpit.<<neutral 1>>
<</if>>
<<elseif $rng lte 95>>
<<if $rightarm is 0>>
The $tentacle16 tentacle winds its way around your right arm, <span class="blue">restraining it.</span><<rightarmtentacledisable>><<neutral 1>><<set $tentacle16shaft to "rightarm">><<set $rightarm to "grappled">><<set $rightarmstate to 0>>
<<else>>
The $tentacle16 tentacle tickles your armpit.<<neutral 1>>
<</if>>
<<elseif $rng lte 100>>
The $tentacle16 tentacle <<slithers>> against your <<bottomstop>><<neutral 1>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "tentacle16default">><<nobr>>
<<set $rng to random(1, 100)>>
<<if $rng gte 90>>
then squirts a warm fluid over your neck.<<neutral 1>><<set $neckgoo += 1>><<set $tentacle16health -= 1>><<neckejacstat>><<ejacstat>>
<<elseif $rng gte 80>>
then squirts a warm fluid over your right arm.<<neutral 1>><<set $rightarmgoo += 1>><<set $tentacle16health -= 1>><<handejacstat>><<ejacstat>>
<<elseif $rng gte 70>>
then squirts a warm fluid over your left arm.<<neutral 1>><<set $leftarmgoo += 1>><<set $tentacle16health -= 1>><<handejacstat>><<ejacstat>>
<<elseif $rng gte 60>>
then squirts a warm fluid over your thighs.<<neutral 1>><<set $thighgoo += 1>><<set $tentacle16health -= 1>><<thighejacstat>><<ejacstat>>
<<elseif $rng gte 50>>
then squirts a warm fluid over your <<bottomstop>><<neutral 1>><<set $bottomgoo += 1>><<set $tentacle16health -= 1>><<bottomejacstat>><<ejacstat>>
<<elseif $rng gte 40>>
then squirts a warm fluid over your tummy.<<neutral 1>><<set $tummygoo += 1>><<set $tentacle16health -= 1>><<tummyejacstat>><<ejacstat>>
<<elseif $rng gte 30>>
then squirts a warm fluid over your chest.<<neutral 1>><<set $chestgoo += 1>><<set $tentacle16health -= 1>><<chestejacstat>><<ejacstat>>
<<elseif $rng gte 20>>
then squirts a warm fluid over your face.<<neutral 1>><<set $facegoo += 1>><<set $tentacle16health -= 1>><<faceejacstat>><<ejacstat>>
<<elseif $rng gte 10>>
then squirts a warm fluid over your hair.<<neutral 1>><<set $hairgoo += 1>><<set $tentacle16health -= 1>><<hairejacstat>><<ejacstat>>
<<else>>
then squirts a warm fluid over your feet.<<neutral 1>><<set $feetgoo += 1>><<set $tentacle16health -= 1>><<feetejacstat>><<ejacstat>>
<</if>>
<</nobr>><</widget>>
<<widget "tentacle16disable">><<nobr>>
<<if $tentacle16head is "feet">>
<<set $leftleg to 0>>
<<set $rightleg to 0>>
<<set $feetstate to 0>>
<</if>>
<<if $tentacle16head is "leftarm">>
<<set $leftarm to 0>>
<<set $leftarmstate to 0>>
<</if>>
<<if $tentacle16head is "rightarm">>
<<set $rightarm to 0>>
<<set $rightarmstate to 0>>
<</if>>
<<if $tentacle16head is "leftnipplesuck">>
<<set $leftnipple to 0>>
<</if>>
<<if $tentacle16head is "rightnipplesuck">>
<<set $rightnipple to 0>>
<</if>>
<<if $tentacle16head is "leftnipple">>
<<set $leftnipple to 0>>
<</if>>
<<if $tentacle16head is "rightnipple">>
<<set $rightnipple to 0>>
<</if>>
<<if $tentacle16head is "chest">>
<<set $chestuse to 0>>
<</if>>
<<if $tentacle16head is "mouthentrance">>
<<set $mouthuse to 0>>
<<set $mouthstate to 0>>
<</if>>
<<if $tentacle16head is "mouthimminent">>
<<set $mouthuse to 0>>
<<set $mouthstate to 0>>
<</if>>
<<if $tentacle16head is "mouth">>
<<set $mouthuse to 0>>
<<set $mouthstate to 0>>
<</if>>
<<if $tentacle16head is "mouthdeep">>
<<set $mouthuse to 0>>
<<set $mouthstate to 0>>
<</if>>
<<if $tentacle16head is "anusentrance">>
<<set $anususe to 0>>
<<set $anusstate to 0>>
<</if>>
<<if $tentacle16head is "anusimminent">>
<<set $anususe to 0>>
<<set $anusstate to 0>>
<</if>>
<<if $tentacle16head is "anus">>
<<set $anususe to 0>>
<<set $anusstate to 0>>
<</if>>
<<if $tentacle16head is "anusdeep">>
<<set $anususe to 0>>
<<set $anusstate to 0>>
<</if>>
<<if $tentacle16head is "vaginaentrance">>
<<set $vaginause to 0>>
<<set $vaginastate to 0>>
<</if>>
<<if $tentacle16head is "vaginaimminent">>
<<set $vaginause to 0>>
<<set $vaginastate to 0>>
<</if>>
<<if $tentacle16head is "vagina">>
<<set $vaginause to 0>>
<<set $vaginastate to 0>>
<</if>>
<<if $tentacle16head is "vaginadeep">>
<<set $vaginause to 0>>
<<set $vaginastate to 0>>
<</if>>
<<if $tentacle16head is "penisentrance">>
<<set $penisuse to 0>>
<<set $penisstate to 0>>
<</if>>
<<if $tentacle16head is "penisimminent">>
<<set $penisuse to 0>>
<<set $penisstate to 0>>
<</if>>
<<if $tentacle16head is "penis">>
<<set $penisuse to 0>>
<<set $penisstate to 0>>
<</if>>
<<if $tentacle16head is "penisdeep">>
<<set $penisuse to 0>>
<<set $penisstate to 0>>
<</if>>
<<if $tentacle16head is "vaginarub">>
<<set $vaginause to 0>>
<<set $thighuse to 0>>
<</if>>
<<if $tentacle16head is "penisrub">>
<<set $penisuse to 0>>
<<set $thighuse to 0>>
<</if>>
<<if $tentacle16head is "bottomrub">>
<<set $anususe to 0>>
<<set $bottomuse to 0>>
<</if>>
<<if $tentacle16shaft is "breasts">>
<<set $chestuse to 0>>
<</if>>
<<if $tentacle16shaft is "neck" and $head isnot "bound">>
<<set $head to 0>>
<</if>>
<<if $tentacle16shaft is "leftleg" and $leftleg isnot "bound">>
<<set $leftleg to 0>>
<</if>>
<<if $tentacle16shaft is "rightleg" and $rightleg isnot "bound">>
<<set $rightleg to 0>>
<</if>>
<<if $tentacle16shaft is "leftarm" and $leftarm isnot "bound">>
<<set $leftarm to 0>>
<</if>>
<<if $tentacle16shaft is "rightarm" and $rightarm isnot "bound">>
<<set $rightarm to 0>>
<</if>>
<<if $tentacle16head is "chest">>
<<set $breastuse to 0>>
<</if>>
<<set $tentacle16shaft to 0>>
<<set $tentacle16head to 0>>
<</nobr>><</widget>>
<<widget "actionstentacle16lefthand">><<nobr>>
<<if $leftarm is 0 and $tentacle16shaft isnot "finished">>
<<if $leftactiondefault is "lefthittentacle16">>
| <label><span class="def">Strike the $tentacle16 tentacle</span> <<radiobutton "$leftaction" "lefthittentacle16" checked>></label>
<<else>>
| <label><span class="def">Strike the $tentacle16 tentacle</span> <<radiobutton "$leftaction" "lefthittentacle16">></label>
<</if>>
<<if $leftactiondefault is "leftgrabtentacle16">>
| <label><span class="sub">Grab the $tentacle16 tentacle</span> <<radiobutton "$leftaction" "leftgrabtentacle16" checked>></label>
<<else>>
| <label><span class="sub">Grab the $tentacle16 tentacle</span> <<radiobutton "$leftaction" "leftgrabtentacle16">></label>
<</if>>
<<elseif $leftarm is "tentacle16">>You hold the $tentacle16 tentacle in your left hand.<br>
<<if $leftactiondefault is "leftrubtentacle16">>
| <label><span class="sub">Milk it</span> <<radiobutton "$leftaction" "leftrubtentacle16" checked>></label>
<<else>>
| <label><span class="sub">Milk it</span> <<radiobutton "$leftaction" "leftrubtentacle16">></label>
<</if>>
<<if $leftactiondefault is "leftstoptentacle16">>
| <label><span class="neutral">Let go</span> <<radiobutton "$leftaction" "leftstoptentacle16" checked>></label>
<<else>>
| <label><span class="neutral">Let go</span> <<radiobutton "$leftaction" "leftstoptentacle16">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle16righthand">><<nobr>>
<<if $rightarm is 0 and $tentacle16shaft isnot "finished">>
<<if $rightactiondefault is "righthittentacle16">>
| <label><span class="def">Strike the $tentacle16 tentacle</span> <<radiobutton "$rightaction" "righthittentacle16" checked>></label>
<<else>>
| <label><span class="def">Strike the $tentacle16 tentacle</span> <<radiobutton "$rightaction" "righthittentacle16">></label>
<</if>>
<<if $rightactiondefault is "rightgrabtentacle16">>
| <label><span class="sub">Grab the $tentacle16 tentacle</span> <<radiobutton "$rightaction" "rightgrabtentacle16" checked>></label>
<<else>>
| <label><span class="sub">Grab the $tentacle16 tentacle</span> <<radiobutton "$rightaction" "rightgrabtentacle16">></label>
<</if>>
<<elseif $rightarm is "tentacle16">>You hold the $tentacle16 tentacle in your right hand.<br>
<<if $rightactiondefault is "rightrubtentacle16">>
| <label><span class="sub">Milk it</span> <<radiobutton "$rightaction" "rightrubtentacle16" checked>></label>
<<else>>
| <label><span class="sub">Milk it</span> <<radiobutton "$rightaction" "rightrubtentacle16">></label>
<</if>>
<<if $rightactiondefault is "rightstoptentacle16">>
| <label><span class="neutral">Let go</span> <<radiobutton "$rightaction" "rightstoptentacle16" checked>></label>
<<else>>
| <label><span class="neutral">Let go</span> <<radiobutton "$rightaction" "rightstoptentacle16">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle16legs">><<nobr>>
<<if $leftleg is 0 and $rightleg is 0 and $tentacle16shaft isnot "finished">>
<<if $feetactiondefault is "feethittentacle16">>
| <label><span class="def">Kick the $tentacle16 tentacle</span> <<radiobutton "$feetaction" "feethittentacle16" checked>></label>
<<else>>
| <label><span class="def">Kick the $tentacle16 tentacle</span> <<radiobutton "$feetaction" "feethittentacle16">></label>
<</if>>
<<if $feetactiondefault is "feetgrabtentacle16">>
| <label><span class="sub">Grab the $tentacle16 tentacle</span> <<radiobutton "$feetaction" "feetgrabtentacle16" checked>></label>
<<else>>
| <label><span class="sub">Grab the $tentacle16 tentacle</span> <<radiobutton "$feetaction" "feetgrabtentacle16">></label>
<</if>>
<<elseif $leftleg is 0 and $tentacle16shaft isnot "finished">>
<<if $feetactiondefault is "feethittentacle16">>
| <label><span class="def">Kick the $tentacle16 tentacle</span> <<radiobutton "$feetaction" "feethittentacle16" checked>></label>
<<else>>
| <label><span class="def">Kick the $tentacle16 tentacle</span> <<radiobutton "$feetaction" "feethittentacle16">></label>
<</if>>
<<elseif $rightleg is 0 and $tentacle16shaft isnot "finished">>
<<if $feetactiondefault is "feethittentacle16">>
| <label><span class="def">Kick the $tentacle16 tentacle</span> <<radiobutton "$feetaction" "feethittentacle16" checked>></label>
<<else>>
| <label><span class="def">Kick the $tentacle16 tentacle</span> <<radiobutton "$feetaction" "feethittentacle16">></label>
<</if>>
<<elseif $leftleg is "tentacle16">>You hold the $tentacle16 tentacle between your feet.<br>
<<if $feetactiondefault is "feetrubtentacle16">>
| <label><span class="sub">Milk it</span> <<radiobutton "$feetaction" "feetrubtentacle16" checked>></label>
<<else>>
| <label><span class="sub">Milk it</span> <<radiobutton "$feetaction" "feetrubtentacle16">></label>
<</if>>
<<if $feetactiondefault is "feetstoptentacle16">>
| <label><span class="neutral">Let go</span> <<radiobutton "$feetaction" "feetstoptentacle16" checked>></label>
<<else>>
| <label><span class="neutral">Let go</span> <<radiobutton "$feetaction" "feetstoptentacle16">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle16mouth">><<nobr>>
<<if $tentacle16head is "mouthentrance">>
<<if $mouthactiondefault is "mouthlicktentacle16">>
| <label><span class="sub">Lick it</span> <<radiobutton "$mouthaction" "mouthlicktentacle16" checked>></label>
<<else>>
| <label><span class="sub">Lick it</span> <<radiobutton "$mouthaction" "mouthlicktentacle16">></label>
<</if>>
<<if $head is "grappled">>
<<else>>
<<if $mouthactiondefault is "mouthpullawaytentacle16">>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "mouthpullawaytentacle16" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "mouthpullawaytentacle16">></label>
<</if>>
<</if>>
<<elseif $tentacle16head is "mouthimminent">>
<<if $mouthactiondefault is "mouthkisstentacle16">>
| <label><span class="sub">Kiss it</span> <<radiobutton "$mouthaction" "mouthkisstentacle16" checked>></label>
<<else>>
| <label><span class="sub">Kiss it</span> <<radiobutton "$mouthaction" "mouthkisstentacle16">></label>
<</if>>
<<if $head is "grappled">>
<<else>>
<<if $mouthactiondefault is "mouthpullawaytentacle16">>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "mouthpullawaytentacle16" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$mouthaction" "mouthpullawaytentacle16">></label>
<</if>>
<</if>>
<<elseif $tentacle16head is "mouth">>
<<if $mouthactiondefault is "mouthcooperatetentacle16">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$mouthaction" "mouthcooperatetentacle16" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$mouthaction" "mouthcooperatetentacle16">></label>
<</if>>
<<if $mouthactiondefault is "mouthbitetentacle16">>
| <label><span class="def">Bite</span> <<radiobutton "$mouthaction" "mouthbitetentacle16" checked>></label>
<<else>>
| <label><span class="def">Bite</span> <<radiobutton "$mouthaction" "mouthbitetentacle16">></label>
<</if>>
<<elseif $tentacle16head is "mouthdeep">>
<<if $mouthactiondefault is "mouthcooperatetentacle16">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$mouthaction" "mouthcooperatetentacle16" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$mouthaction" "mouthcooperatetentacle16">></label>
<</if>>
<<if $mouthactiondefault is "mouthbitetentacle16">>
| <label><span class="def">Bite</span> <<radiobutton "$mouthaction" "mouthbitetentacle16" checked>></label>
<<else>>
| <label><span class="def">Bite</span> <<radiobutton "$mouthaction" "mouthbitetentacle16">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle16vagina">><<nobr>>
<<if $tentacle16head is "vaginaentrance">>
<<if $vaginaactiondefault is "vaginarubtentacle16">>
| <label><span class="sub">Rub</span> <<radiobutton "$vaginaaction" "vaginarubtentacle16" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$vaginaaction" "vaginarubtentacle16">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $vaginaactiondefault is "vaginapullawaytentacle16">>
| <label><span class="brat">Pull away</span> <<radiobutton "$vaginaaction" "vaginapullawaytentacle16" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$vaginaaction" "vaginapullawaytentacle16">></label>
<</if>>
<</if>>
<<elseif $tentacle16head is "vaginaimminent">>
<<if $vaginaactiondefault is "vaginarubtentacle16">>
| <label><span class="sub">Rub</span> <<radiobutton "$vaginaaction" "vaginarubtentacle16" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$vaginaaction" "vaginarubtentacle16">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $vaginaactiondefault is "vaginapullawaytentacle16">>
| <label><span class="brat">Pull away</span> <<radiobutton "$vaginaaction" "vaginapullawaytentacle16" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$vaginaaction" "vaginapullawaytentacle16">></label>
<</if>>
<</if>>
<<elseif $tentacle16head is "vagina">>
<<if $vaginaactiondefault is "vaginacooperatetentacle16">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$vaginaaction" "vaginacooperatetentacle16" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$vaginaaction" "vaginacooperatetentacle16">></label>
<</if>>
<<elseif $tentacle16head is "vaginadeep">>
<<if $vaginaactiondefault is "vaginacooperatetentacle16">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$vaginaaction" "vaginacooperatetentacle16" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$vaginaaction" "vaginacooperatetentacle16">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle16penis">><<nobr>>
<<if $tentacle16head is "penisentrance">>
<<if $penisactiondefault is "penisrubtentacle16">>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "penisrubtentacle16" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "penisrubtentacle16">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $penisactiondefault is "penispullawaytentacle16">>
| <label><span class="brat">Pull away</span> <<radiobutton "$penisaction" "penispullawaytentacle16" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$penisaction" "penispullawaytentacle16">></label>
<</if>>
<</if>>
<<elseif $tentacle16head is "penisimminent">>
<<if $penisactiondefault is "penisrubtentacle16">>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "penisrubtentacle16" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$penisaction" "penisrubtentacle16">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $penisactiondefault is "penispullawaytentacle16">>
| <label><span class="brat">Pull away</span> <<radiobutton "$penisaction" "penispullawaytentacle16" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$penisaction" "penispullawaytentacle16">></label>
<</if>>
<</if>>
<<elseif $tentacle16head is "penis">>
<<if $penisactiondefault is "peniscooperatetentacle16">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$penisaction" "peniscooperatetentacle16" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$penisaction" "peniscooperatetentacle16">></label>
<</if>>
<<elseif $tentacle16head is "penisdeep">>
<<if $penisactiondefault is "peniscooperatetentacle16">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$penisaction" "peniscooperatetentacle16" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$penisaction" "peniscooperatetentacle16">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle16anus">><<nobr>>
<<if $tentacle16head is "anusentrance">>
<<if $anusactiondefault is "anusrubtentacle16">>
| <label><span class="sub">Rub</span> <<radiobutton "$anusaction" "anusrubtentacle16" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$anusaction" "anusrubtentacle16">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $anusactiondefault is "anuspullawaytentacle16">>
| <label><span class="brat">Pull away</span> <<radiobutton "$anusaction" "anuspullawaytentacle16" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$anusaction" "anuspullawaytentacle16">></label>
<</if>>
<</if>>
<<elseif $tentacle16head is "anusimminent">>
<<if $anusactiondefault is "anusrubtentacle16">>
| <label><span class="sub">Rub</span> <<radiobutton "$anusaction" "anusrubtentacle16" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$anusaction" "anusrubtentacle16">></label>
<</if>>
<<if $leftleg is "grappled" and $rightleg is "grappled">>
<<else>>
<<if $anusactiondefault is "anuspullawaytentacle16">>
| <label><span class="brat">Pull away</span> <<radiobutton "$anusaction" "anuspullawaytentacle16" checked>></label>
<<else>>
| <label><span class="brat">Pull away</span> <<radiobutton "$anusaction" "anuspullawaytentacle16">></label>
<</if>>
<</if>>
<<elseif $tentacle16head is "anus">>
<<if $anusactiondefault is "anuscooperatetentacle16">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$anusaction" "anuscooperatetentacle16" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$anusaction" "anuscooperatetentacle16">></label>
<</if>>
<<elseif $tentacle16head is "anusdeep">>
<<if $anusactiondefault is "anuscooperatetentacle16">>
| <label><span class="sub">Cooperate</span> <<radiobutton "$anusaction" "anuscooperatetentacle16" checked>></label>
<<else>>
| <label><span class="sub">Cooperate</span> <<radiobutton "$anusaction" "anuscooperatetentacle16">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle16thighs">><<nobr>>
<<if $tentacle16head is "penisrub">>
<<if $thighactiondefault is "penisrubtentacle16">>
| <label><span class="sub">Rub</span> <<radiobutton "$thighaction" "penisrubtentacle16" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$thighaction" "penisrubtentacle16">></label>
<</if>>
<<elseif $tentacle16head is "vaginarub">>
<<if $thighactiondefault is "vaginarubtentacle16">>
| <label><span class="sub">Rub</span> <<radiobutton "$thighaction" "vaginarubtentacle16" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$thighaction" "vaginarubtentacle16">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle16bottom">><<nobr>>
<<if $tentacle16head is "bottomrub">>
<<if $bottomactiondefault is "bottomrubtentacle16">>
| <label><span class="sub">Rub</span> <<radiobutton "$bottomaction" "bottomrubtentacle16" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$bottomaction" "bottomrubtentacle16">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionstentacle16chest">><<nobr>>
<<if $tentacle16head is "chest">>
<<if $chestactiondefault is "chestrubtentacle16">>
| <label><span class="sub">Rub</span> <<radiobutton "$chestaction" "chestrubtentacle16" checked>></label>
<<else>>
| <label><span class="sub">Rub</span> <<radiobutton "$chestaction" "chestrubtentacle16">></label>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "effectstentacle16">><<nobr>>
<<if $leftaction is "lefthittentacle16">><<set $leftaction to 0>><<set $leftactiondefault to "lefthittentacle16">>You strike the $tentacle16 tentacle with your left hand and it reels away from you.<<defiance 2>><<set $speechhit to 1>><<tentacle16disable>><<set $attackstat += 1>><<set $tentacle16health -= 1>>
<<if $rng lte ($physique / 200)>>
<<set $tentacle16health -= 1>>
<</if>>
<</if>>
<<if $rightaction is "righthittentacle16">><<set $rightaction to 0>><<set $rightactiondefault to "righthittentacle16">>You strike the $tentacle16 tentacle with your right hand and it reels away from you.<<defiance 2>><<set $speechhit to 1>><<tentacle16disable>><<set $attackstat += 1>><<set $tentacle16health -= 1>>
<<if $rng lte ($physique / 200)>>
<<set $tentacle16health -= 1>>
<</if>>
<</if>>
<<if $leftaction is "leftgrabtentacle16">><<set $leftaction to 0>><<set $leftactiondefault to "leftrubtentacle16">><<submission 1>><<handstat>><span class="lblue">You <<handtext>> grab the $tentacle16 tentacle with your left hand.</span><<tentacle16disable>><<set $leftarm to "tentacle16">><<set $tentacle16head to "leftarm">><<handstat>><<set $leftarmstate to "tentacle">>
<</if>>
<<if $rightaction is "rightgrabtentacle16">><<set $rightaction to 0>><<set $rightactiondefault to "rightrubtentacle16">><<submission 1>><<handstat>><span class="lblue">You <<handtext>> grab the $tentacle16 tentacle with your right hand.</span><<tentacle16disable>><<set $rightarm to "tentacle16">><<set $tentacle16head to "rightarm">><<handstat>><<set $rightarmstate to "tentacle">>
<</if>>
<<if $leftaction is "leftrubtentacle16">><<set $leftaction to 0>><<set $leftactiondefault to "leftrubtentacle16">><<handskilluse>><<submission 1>>You <<handtext>> squeeze the $tentacle16 tentacle in your left hand and rub up and down its length.<<set $rng to random(1, 100)>>
<<if $handskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $rightarmgoo += 1>><<set $tentacle16health -= 3>><<handejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $rightaction is "rightrubtentacle16">><<set $rightaction to 0>><<set $rightactiondefault to "rightrubtentacle16">><<handskilluse>><<submission 1>>You <<handtext>> squeeze the $tentacle16 tentacle in your right hand and rub up and down its length.<<set $rng to random(1, 100)>>
<<if $handskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $rightarmgoo += 1>><<set $tentacle16health -= 3>><<handejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $leftaction is "leftstoptentacle16">><<set $leftaction to 0>><<set $leftactiondefault to "leftstoptentacle16">>You release the $tentacle16 tentacle from your left hand.<<tentacle16disable>>
<</if>>
<<if $rightaction is "rightstoptentacle16">><<set $rightaction to 0>><<set $rightactiondefault to "rightstoptentacle16">>You release the $tentacle16 tentacle from your right hand.<<tentacle16disable>>
<</if>>
<<if $feetaction is "feethittentacle16">><<set $feetaction to 0>><<set $feetactiondefault to "feethittentacle16">>You kick the $tentacle16 tentacle and it reels away from you.<<defiance 2>><<set $speechhit to 1>><<tentacle16disable>><<set $attackstat += 1>><<set $tentacle16health -= 1>>
<<if $rng lte ($physique / 200)>>
<<set $tentacle16health -= 1>>
<</if>>
<</if>>
<<if $feetaction is "feetgrabtentacle16">><<set $feetaction to 0>><<set $feetactiondefault to "feetrubtentacle16">><<submission 1>><<feetstat>><span class="lblue">You <<feettext>> grab the $tentacle16 tentacle between your feet.</span><<tentacle16disable>><<set $leftleg to "tentacle16">><<set $rightleg to "tentacle16">><<set $tentacle16head to "feet">><<feetstat>><<set $feetstate to "tentacle">>
<</if>>
<<if $feetaction is "feetrubtentacle16">><<set $feetaction to 0>><<set $feetactiondefault to "feetrubtentacle16">><<feetskilluse>><<submission 1>>You <<feettext>> squeeze the $tentacle16 tentacle between your feet and rub up and down its length.<<set $rng to random(1, 100)>>
<<if $feetskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $feetgoo += 1>><<set $tentacle16health -= 3>><<feetejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $feetaction is "feetstoptentacle16">><<set $feetaction to 0>><<set $feetactiondefault to "feetstoptentacle16">>You let go of the $tentacle16 tentacle between your feet.<<tentacle16disable>>
<</if>>
<<if $mouthaction is "mouthlicktentacle16">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthlicktentacle16">>
<<submission 2>><<oralskilluse>>You <<oraltext>> lick the tip of the $tentacle16 tentacle.<<set $rng to random(1, 100)>>
<<if $oralskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your face.</span><<set $facegoo += 1>><<set $tentacle16health -= 3>><<faceejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $mouthaction is "mouthkisstentacle16">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthkisstentacle16">>
<<submission 3>><<oralskilluse>>You <<oraltext>> kiss the tip of the $tentacle16 tentacle.<<set $rng to random(1, 100)>>
<<if $oralskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your face.</span><<set $facegoo += 1>><<set $tentacle16health -= 3>><<faceejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $mouthaction is "mouthcooperatetentacle16">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthcooperatetentacle16">>
<<sex 5>><<oralskilluse>>You <<oraltext>> suck the $tentacle16 tentacle invading your mouth.<<set $rng to random(1, 100)>>
<<if $oralskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip and into your mouth.</span><<set $tentacle16health -= 3>><<set $drugged += 3>><<set $mouthgoo += 1>><<oralejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $mouthaction is "mouthpullawaytentacle16">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthpullawaytentacle16">><<brat 1>><span class="teal">You pull away from the $tentacle16 tentacle threatening your mouth.</span><<tentacle16disable>>
<</if>>
<<if $mouthaction is "mouthbitetentacle16">><<set $mouthaction to 0>><<set $mouthactiondefault to "mouthbitetentacle16">><<defiance 5>>You bite down on the $tentacle16 tentacle invading your mouth. <span class="teal">It recoils immediately.</span><<tentacle16disable>><<set $attackstat += 1>><<set $tentacle16health -= 1>>
<<if $rng lte ($physique / 200)>>
<<set $tentacle16health -= 1>>
<</if>>
<</if>>
<<if $vaginaaction is "vaginarubtentacle16">><<set $vaginaaction to 0>><<set $vaginaactiondefault to "vaginarubtentacle16">>
<<submission 2>><<vaginalskilluse>>You <<vaginaltext>> rub the tip of the $tentacle16 tentacle with your <<pussystop>><<set $rng to random(1, 100)>>
<<if $vaginalskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $vaginaoutsidegoo += 1>><<set $tentacle16health -= 3>><<vaginalentranceejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $vaginaaction is "vaginacooperatetentacle16">><<set $vaginaaction to 0>><<set $vaginaactiondefault to "vaginacooperatetentacle16">>
<<sex 5>><<vaginalskilluse>>You <<vaginaltext>> push back against the $tentacle16 tentacle invading your <<pussystop>><<set $rng to random(1, 100)>>
<<if $vaginalskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, flooding your womb with its warmth.</span><<set $tentacle16health -= 3>><<set $drugged += 3>><<set $vaginagoo += 1>><<vaginalejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $vaginaaction is "vaginapullawaytentacle16">><<set $vaginaaction to 0>><<set $vaginaactiondefault to "vaginapullawaytentacle16">><<brat 1>><span class="teal">You pull away from the $tentacle16 tentacle threatening your <<pussystop>></span><<tentacle16disable>>
<</if>>
<<if $penisaction is "penisrubtentacle16">><<set $penisaction to 0>><<set $penisactiondefault to "penisrubtentacle16">>
<<submission 2>><<penileskilluse>>You <<peniletext>> rub the tip of the $tentacle16 tentacle with your <<penisstop>><<set $rng to random(1, 100)>>
<<if $penileskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip.</span><<set $penisgoo += 1>><<set $tentacle16health -= 3>><<penileejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $penisaction is "peniscooperatetentacle16">><<set $penisaction to 0>><<set $penisactiondefault to "peniscooperatetentacle16">>
<<sex 5>><<penileskilluse>>You <<peniletext>> push back against the $tentacle16 tentacle engulfing your <<penisstop>><<set $rng to random(1, 100)>>
<<if $penileskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your groin.</span><<set $tentacle16health -= 3>><<set $penisgoo += 1>><<penileejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $penisaction is "penispullawaytentacle16">><<set $penisaction to 0>><<set $penisactiondefault to "penispullawaytentacle16">><<brat 1>><span class="teal">You pull away from the $tentacle16 tentacle threatening your <<penisstop>></span><<tentacle16disable>>
<</if>>
<<if $anusaction is "anusrubtentacle16">><<set $anusaction to 0>><<set $anusactiondefault to "anusrubtentacle16">>
<<submission 2>><<analskilluse>>You <<analtext>> rub the tip of the $tentacle16 tentacle with your <<bottomstop>><<set $rng to random(1, 100)>>
<<if $analskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your <<bottomstop>></span><<set $bottomgoo += 1>><<set $tentacle16health -= 3>><<bottomejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $anusaction is "anuscooperatetentacle16">><<set $anusaction to 0>><<set $anusactiondefault to "anuscooperatetentacle16">>
<<sex 5>><<analskilluse>>You <<analtext>> push back against the $tentacle16 tentacle invading your <<bottomstop>><<set $rng to random(1, 100)>>
<<if $analskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, flooding your bowels with its warmth.</span><<set $tentacle16health -= 3>><<set $drugged += 3>><<set $anusgoo += 1>><<analejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $anusaction is "anuspullawaytentacle16">><<set $anusaction to 0>><<set $anusactiondefault to "anuspullawaytentacle16">><<brat 1>><span class="teal">You pull away from the $tentacle16 tentacle threatening your <<bottomstop>></span><<tentacle16disable>>
<</if>>
<<if $thighaction is "penisrubtentacle16">><<set $thighaction to 0>><<set $thighactiondefault to "penisrubtentacle16">>
<<submission 3>><<thighskilluse>>You <<thightext>> rub the $tentacle16 tentacle between your thighs.<<set $rng to random(1, 100)>>
<<if $thighskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your tummy.</span><<set $tentacle16health -= 3>><<set $tummygoo += 1>><<tummyejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $thighaction is "vaginarubtentacle16">><<set $thighaction to 0>><<set $thighactiondefault to "vaginarubtentacle16">>
<<submission 3>><<thighskilluse>>You <<thightext>> rub the $tentacle16 tentacle between your thighs.<<set $rng to random(1, 100)>>
<<if $thighskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your tummy.</span><<set $tentacle16health -= 3>><<set $tummygoo += 1>><<tummyejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $bottomaction is "bottomrubtentacle16">><<set $bottomaction to 0>><<set $bottomactiondefault to "bottomrubtentacle16">>
<<submission 3>><<bottomskilluse>>You <<bottomtext>> rub the $tentacle16 tentacle between your cheeks.<<set $rng to random(1, 100)>>
<<if $bottomskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your <<bottomstop>></span><<set $tentacle16health -= 3>><<set $bottomgoo += 1>><<bottomejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<<if $chestaction is "chestrubtentacle16">><<set $chestaction to 0>><<set $chestactiondefault to "chestrubtentacle16">>
<<submission 3>><<chestskilluse>>You <<chesttext>> rub the $tentacle16 tentacle between your <<breastsstop>><<set $rng to random(1, 100)>>
<<if $chestskill gte (800 - ($rng * 10))>>
<span class="lblue">Slimy fluid erupts from the tip, covering your chest.</span><<set $tentacle16health -= 3>><<set $chestgoo += 1>><<chestejacstat>><<ejacstat>>
<<else>>
<</if>>
<</if>>
<</nobr>><</widget>>
:: Widgets Tentacle Img [widget]
<<widget "tentacleimgvfast">><<nobr>>
<<if $swarmfront gte 1>>
<<if $vaginaexist is 1>>
<img id="sexpenis" src="img/sex/doggy/slime/slimevaginalvfast.gif">
<</if>>
<<if $penisexist is 1>>
<img id="sextears" src="img/sex/doggy/slime/slimepenilevfast.gif">
<</if>>
<</if>>
<<if $swarmfrontinside gte 1>>
<<if $vaginaexist is 1>>
<img id="sexpenis" src="img/sex/doggy/slime/slimevaginalvfast.gif">
<</if>>
<<if $penisexist is 1>>
<img id="sextears" src="img/sex/doggy/slime/slimepenilevfast.gif">
<</if>>
<</if>>
<<if $swarmback gte 1>>
<img id="sexpenis" src="img/sex/doggy/slime/slimeanalvfast.gif">
<</if>>
<<if $vaginastate is "tentacleentrance">>
<img id="sextears" src="img/sex/doggy/tentacles/tentaclevaginalentrancevfast.gif">
<</if>>
<<if $vaginastate is "tentacleimminent">>
<img id="sextears" src="img/sex/doggy/tentacles/tentaclevaginalimminentvfast.gif">
<</if>>
<<if $vaginastate is "tentacle">>
<img id="sextears" src="img/sex/doggy/tentacles/tentaclevaginalvfast.gif">
<</if>>
<<if $vaginastate is "tentacledeep">>
<img id="sextears" src="img/sex/doggy/tentacles/tentaclevaginalvfast.gif">
<img id="sextears" src="img/sex/doggy/active/body/doggyactivevaginalcumvfast.gif">
<</if>>
<<if $vaginause is "tentaclerub">>
<img id="sextears" src="img/sex/doggy/tentacles/tentaclevaginalrubvfast.gif">
<</if>>
<<if $anusstate is "tentacleentrance">>
<img id="sextears" src="img/sex/doggy/tentacles/tentacleanalentrancevfast.gif">
<</if>>
<<if $anusstate is "tentacleimminent">>
<img id="sextears" src="img/sex/doggy/tentacles/tentacleanalimminentvfast.gif">
<</if>>
<<if $anusstate is "tentacle">>
<img id="sextears" src="img/sex/doggy/tentacles/tentacleanalvfast.gif">
<</if>>
<<if $anusstate is "tentacledeep">>
<img id="sextears" src="img/sex/doggy/tentacles/tentacleanalvfast.gif">
<img id="sextears" src="img/sex/doggy/active/body/doggyactiveanalcumvfast.gif">
<</if>>
<<if $anususe is "tentaclerub">>
<img id="sextears" src="img/sex/doggy/tentacles/tentacleanalrubvfast.gif">
<</if>>
<<if $penisstate is "tentacleentrance">>
<img id="sextears" src="img/sex/doggy/tentacles/tentaclepenileentrancevfast.gif">
<</if>>
<<if $penisstate is "tentacleimminent">>
<img id="sextears" src="img/sex/doggy/tentacles/tentaclepenileimminentvfast.gif">
<</if>>
<<if $penisstate is "tentacle">>
<img id="sextears" src="img/sex/doggy/tentacles/tentaclepenilevfast.gif">
<</if>>
<<if $penisstate is "tentacledeep">>
<img id="sextears" src="img/sex/doggy/tentacles/tentaclepenilevfast.gif">
<</if>>
<<if $penisuse is "tentaclerub">>
<img id="sextears" src="img/sex/doggy/tentacles/tentaclevaginalrubvfast.gif">
<</if>>
<<if $mouthstate is "tentacleentrance">>
<img id="sextears" src="img/sex/doggy/tentacles/tentacleoralentrancevfast.gif">
<</if>>
<<if $mouthstate is "tentacleimminent">>
<img id="sextears" src="img/sex/doggy/tentacles/tentacleoralimminentvfast.gif">
<</if>>
<<if $mouthstate is "tentacle">>
<img id="sextears" src="img/sex/doggy/tentacles/tentacleoralvfast.gif">
<</if>>
<<if $mouthstate is "tentacledeep">>
<img id="sextears" src="img/sex/doggy/tentacles/tentacleoralvfast.gif">
<img id="sextears" src="img/sex/doggy/active/body/doggyactiveoralcumvfast.gif">
<</if>>
<<if $leftarmstate is "tentacle">>
<img id="sextears" src="img/sex/doggy/tentacles/tentaclehandjobleftvfast.gif">
<</if>>
<<if $rightarmstate is "tentacle">>
<img id="sexbaseback" src="img/sex/doggy/tentacles/tentaclehandjobrightvfast.gif">
<</if>>
<<if $feetstate is "tentacle">>
<img id="sextears" src="img/sex/doggy/tentacles/tentaclefootjobvfast.gif">
<</if>>
<</nobr>><</widget>>
<<widget "tentacleimgfast">><<nobr>>
<<if $swarmfront gte 1>>
<<if $vaginaexist is 1>>
<img id="sexpenis" src="img/sex/doggy/slime/slimevaginalfast.gif">
<</if>>
<<if $penisexist is 1>>
<img id="sextears" src="img/sex/doggy/slime/slimepenilefast.gif">
<</if>>
<</if>>
<<if $swarmfrontinside gte 1>>
<<if $vaginaexist is 1>>
<img id="sexpenis" src="img/sex/doggy/slime/slimevaginalfast.gif">
<</if>>
<<if $penisexist is 1>>
<img id="sextears" src="img/sex/doggy/slime/slimepenilefast.gif">
<</if>>
<</if>>
<<if $swarmback gte 1>>
<img id="sexpenis" src="img/sex/doggy/slime/slimeanalfast.gif">
<</if>>
<<if $vaginastate is "tentacleentrance">>
<img id="sextears" src="img/sex/doggy/tentacles/tentaclevaginalentrancefast.gif">
<</if>>
<<if $vaginastate is "tentacleimminent">>
<img id="sextears" src="img/sex/doggy/tentacles/tentaclevaginalimminentfast.gif">
<</if>>
<<if $vaginastate is "tentacle">>
<img id="sextears" src="img/sex/doggy/tentacles/tentaclevaginalfast.gif">
<</if>>
<<if $vaginastate is "tentacledeep">>
<img id="sextears" src="img/sex/doggy/tentacles/tentaclevaginalfast.gif">
<img id="sextears" src="img/sex/doggy/active/body/doggyactivevaginalcumfast.gif">
<</if>>
<<if $vaginause is "tentaclerub">>
<img id="sextears" src="img/sex/doggy/tentacles/tentaclevaginalrubfast.gif">
<</if>>
<<if $anusstate is "tentacleentrance">>
<img id="sextears" src="img/sex/doggy/tentacles/tentacleanalentrancefast.gif">
<</if>>
<<if $anusstate is "tentacleimminent">>
<img id="sextears" src="img/sex/doggy/tentacles/tentacleanalimminentfast.gif">
<</if>>
<<if $anusstate is "tentacle">>
<img id="sextears" src="img/sex/doggy/tentacles/tentacleanalfast.gif">
<</if>>
<<if $anusstate is "tentacledeep">>
<img id="sextears" src="img/sex/doggy/tentacles/tentacleanalfast.gif">
<img id="sextears" src="img/sex/doggy/active/body/doggyactiveanalcumfast.gif">
<</if>>
<<if $anususe is "tentaclerub">>
<img id="sextears" src="img/sex/doggy/tentacles/tentacleanalrubfast.gif">
<</if>>
<<if $penisstate is "tentacleentrance">>
<img id="sextears" src="img/sex/doggy/tentacles/tentaclepenileentrancefast.gif">
<</if>>
<<if $penisstate is "tentacleimminent">>
<img id="sextears" src="img/sex/doggy/tentacles/tentaclepenileimminentfast.gif">
<</if>>
<<if $penisstate is "tentacle">>
<img id="sextears" src="img/sex/doggy/tentacles/tentaclepenilefast.gif">
<</if>>
<<if $penisstate is "tentacledeep">>
<img id="sextears" src="img/sex/doggy/tentacles/tentaclepenilefast.gif">
<</if>>
<<if $penisuse is "tentaclerub">>
<img id="sextears" src="img/sex/doggy/tentacles/tentaclevaginalrubfast.gif">
<</if>>
<<if $mouthstate is "tentacleentrance">>
<img id="sextears" src="img/sex/doggy/tentacles/tentacleoralentrancefast.gif">
<</if>>
<<if $mouthstate is "tentacleimminent">>
<img id="sextears" src="img/sex/doggy/tentacles/tentacleoralimminentfast.gif">
<</if>>
<<if $mouthstate is "tentacle">>
<img id="sextears" src="img/sex/doggy/tentacles/tentacleoralfast.gif">
<</if>>
<<if $mouthstate is "tentacledeep">>
<img id="sextears" src="img/sex/doggy/tentacles/tentacleoralfast.gif">
<img id="sextears" src="img/sex/doggy/active/body/doggyactiveoralcumfast.gif">
<</if>>
<<if $leftarmstate is "tentacle">>
<img id="sextears" src="img/sex/doggy/tentacles/tentaclehandjobleftfast.gif">
<</if>>
<<if $rightarmstate is "tentacle">>
<img id="sexbaseback" src="img/sex/doggy/tentacles/tentaclehandjobrightfast.gif">
<</if>>
<<if $feetstate is "tentacle">>
<img id="sextears" src="img/sex/doggy/tentacles/tentaclefootjobfast.gif">
<</if>>
<</nobr>><</widget>>
<<widget "tentacleimgmid">><<nobr>>
<<if $swarmfront gte 1>>
<<if $vaginaexist is 1>>
<img id="sexpenis" src="img/sex/doggy/slime/slimevaginalmid.gif">
<</if>>
<<if $penisexist is 1>>
<img id="sextears" src="img/sex/doggy/slime/slimepenilemid.gif">
<</if>>
<</if>>
<<if $swarmfrontinside gte 1>>
<<if $vaginaexist is 1>>
<img id="sexpenis" src="img/sex/doggy/slime/slimevaginalmid.gif">
<</if>>
<<if $penisexist is 1>>
<img id="sextears" src="img/sex/doggy/slime/slimepenilemid.gif">
<</if>>
<</if>>
<<if $swarmback gte 1>>
<img id="sexpenis" src="img/sex/doggy/slime/slimeanalmid.gif">
<</if>>
<<if $vaginastate is "tentacleentrance">>
<img id="sextears" src="img/sex/doggy/tentacles/tentaclevaginalentrancemid.gif">
<</if>>
<<if $vaginastate is "tentacleimminent">>
<img id="sextears" src="img/sex/doggy/tentacles/tentaclevaginalimminentmid.gif">
<</if>>
<<if $vaginastate is "tentacle">>
<img id="sextears" src="img/sex/doggy/tentacles/tentaclevaginalmid.gif">
<</if>>
<<if $vaginastate is "tentacledeep">>
<img id="sextears" src="img/sex/doggy/tentacles/tentaclevaginalmid.gif">
<img id="sextears" src="img/sex/doggy/active/body/doggyactivevaginalcummid.gif">
<</if>>
<<if $vaginause is "tentaclerub">>
<img id="sextears" src="img/sex/doggy/tentacles/tentaclevaginalrubmid.gif">
<</if>>
<<if $anusstate is "tentacleentrance">>
<img id="sextears" src="img/sex/doggy/tentacles/tentacleanalentrancemid.gif">
<</if>>
<<if $anusstate is "tentacleimminent">>
<img id="sextears" src="img/sex/doggy/tentacles/tentacleanalimminentmid.gif">
<</if>>
<<if $anusstate is "tentacle">>
<img id="sextears" src="img/sex/doggy/tentacles/tentacleanalmid.gif">
<</if>>
<<if $anusstate is "tentacledeep">>
<img id="sextears" src="img/sex/doggy/tentacles/tentacleanalmid.gif">
<img id="sextears" src="img/sex/doggy/active/body/doggyactiveanalcummid.gif">
<</if>>
<<if $anususe is "tentaclerub">>
<img id="sextears" src="img/sex/doggy/tentacles/tentacleanalrubmid.gif">
<</if>>
<<if $penisstate is "tentacleentrance">>
<img id="sextears" src="img/sex/doggy/tentacles/tentaclepenileentrancemid.gif">
<</if>>
<<if $penisstate is "tentacleimminent">>
<img id="sextears" src="img/sex/doggy/tentacles/tentaclepenileimminentmid.gif">
<</if>>
<<if $penisstate is "tentacle">>
<img id="sextears" src="img/sex/doggy/tentacles/tentaclepenilemid.gif">
<</if>>
<<if $penisstate is "tentacledeep">>
<img id="sextears" src="img/sex/doggy/tentacles/tentaclepenilemid.gif">
<</if>>
<<if $penisuse is "tentaclerub">>
<img id="sextears" src="img/sex/doggy/tentacles/tentaclevaginalrubmid.gif">
<</if>>
<<if $mouthstate is "tentacleentrance">>
<img id="sextears" src="img/sex/doggy/tentacles/tentacleoralentrancemid.gif">
<</if>>
<<if $mouthstate is "tentacleimminent">>
<img id="sextears" src="img/sex/doggy/tentacles/tentacleoralimminentmid.gif">
<</if>>
<<if $mouthstate is "tentacle">>
<img id="sextears" src="img/sex/doggy/tentacles/tentacleoralmid.gif">
<</if>>
<<if $mouthstate is "tentacledeep">>
<img id="sextears" src="img/sex/doggy/tentacles/tentacleoralmid.gif">
<img id="sextears" src="img/sex/doggy/active/body/doggyactiveoralcummid.gif">
<</if>>
<<if $leftarmstate is "tentacle">>
<img id="sextears" src="img/sex/doggy/tentacles/tentaclehandjobleftmid.gif">
<</if>>
<<if $rightarmstate is "tentacle">>
<img id="sexbaseback" src="img/sex/doggy/tentacles/tentaclehandjobrightmid.gif">
<</if>>
<<if $feetstate is "tentacle">>
<img id="sextears" src="img/sex/doggy/tentacles/tentaclefootjobmid.gif">
<</if>>
<</nobr>><</widget>>
<<widget "tentacleimgslow">><<nobr>>
<<if $swarmfront gte 1>>
<<if $vaginaexist is 1>>
<img id="sexpenis" src="img/sex/doggy/slime/slimevaginalslow.gif">
<</if>>
<<if $penisexist is 1>>
<img id="sextears" src="img/sex/doggy/slime/slimepenileslow.gif">
<</if>>
<</if>>
<<if $swarmfrontinside gte 1>>
<<if $vaginaexist is 1>>
<img id="sexpenis" src="img/sex/doggy/slime/slimevaginalslow.gif">
<</if>>
<<if $penisexist is 1>>
<img id="sextears" src="img/sex/doggy/slime/slimepenileslow.gif">
<</if>>
<</if>>
<<if $swarmback gte 1>>
<img id="sexpenis" src="img/sex/doggy/slime/slimeanalslow.gif">
<</if>>
<<if $vaginastate is "tentacleentrance">>
<img id="sextears" src="img/sex/doggy/tentacles/tentaclevaginalentranceslow.gif">
<</if>>
<<if $vaginastate is "tentacleimminent">>
<img id="sextears" src="img/sex/doggy/tentacles/tentaclevaginalimminentslow.gif">
<</if>>
<<if $vaginastate is "tentacle">>
<img id="sextears" src="img/sex/doggy/tentacles/tentaclevaginalslow.gif">
<</if>>
<<if $vaginastate is "tentacledeep">>
<img id="sextears" src="img/sex/doggy/tentacles/tentaclevaginalslow.gif">
<img id="sextears" src="img/sex/doggy/active/body/doggyactivevaginalcumslow.gif">
<</if>>
<<if $vaginause is "tentaclerub">>
<img id="sextears" src="img/sex/doggy/tentacles/tentaclevaginalrubslow.gif">
<</if>>
<<if $anusstate is "tentacleentrance">>
<img id="sextears" src="img/sex/doggy/tentacles/tentacleanalentranceslow.gif">
<</if>>
<<if $anusstate is "tentacleimminent">>
<img id="sextears" src="img/sex/doggy/tentacles/tentacleanalimminentslow.gif">
<</if>>
<<if $anusstate is "tentacle">>
<img id="sextears" src="img/sex/doggy/tentacles/tentacleanalslow.gif">
<</if>>
<<if $anusstate is "tentacledeep">>
<img id="sextears" src="img/sex/doggy/tentacles/tentacleanalslow.gif">
<img id="sextears" src="img/sex/doggy/active/body/doggyactiveanalcumslow.gif">
<</if>>
<<if $anususe is "tentaclerub">>
<img id="sextears" src="img/sex/doggy/tentacles/tentacleanalrubslow.gif">
<</if>>
<<if $penisstate is "tentacleentrance">>
<img id="sextears" src="img/sex/doggy/tentacles/tentaclepenileentranceslow.gif">
<</if>>
<<if $penisstate is "tentacleimminent">>
<img id="sextears" src="img/sex/doggy/tentacles/tentaclepenileimminentslow.gif">
<</if>>
<<if $penisstate is "tentacle">>
<img id="sextears" src="img/sex/doggy/tentacles/tentaclepenileslow.gif">
<</if>>
<<if $penisstate is "tentacledeep">>
<img id="sextears" src="img/sex/doggy/tentacles/tentaclepenileslow.gif">
<</if>>
<<if $penisuse is "tentaclerub">>
<img id="sextears" src="img/sex/doggy/tentacles/tentaclevaginalrubslow.gif">
<</if>>
<<if $mouthstate is "tentacleentrance">>
<img id="sextears" src="img/sex/doggy/tentacles/tentacleoralentranceslow.gif">
<</if>>
<<if $mouthstate is "tentacleimminent">>
<img id="sextears" src="img/sex/doggy/tentacles/tentacleoralimminentslow.gif">
<</if>>
<<if $mouthstate is "tentacle">>
<img id="sextears" src="img/sex/doggy/tentacles/tentacleoralslow.gif">
<</if>>
<<if $mouthstate is "tentacledeep">>
<img id="sextears" src="img/sex/doggy/tentacles/tentacleoralslow.gif">
<img id="sextears" src="img/sex/doggy/active/body/doggyactiveoralcumslow.gif">
<</if>>
<<if $leftarmstate is "tentacle">>
<img id="sextears" src="img/sex/doggy/tentacles/tentaclehandjobleftslow.gif">
<</if>>
<<if $rightarmstate is "tentacle">>
<img id="sexbaseback" src="img/sex/doggy/tentacles/tentaclehandjobrightslow.gif">
<</if>>
<<if $feetstate is "tentacle">>
<img id="sextears" src="img/sex/doggy/tentacles/tentaclefootjobslow.gif">
<</if>>
<</nobr>><</widget>>
:: Widgets Beast Img [widget]
<<widget "beastimgvfast">><<nobr>>
<<if $enemytype is "beast" and $beaststance is "top">>
<<if $beasttype is "lizard">>
<img id="beastback" src="img/sex/doggy/beast/activelizardvfast.gif">
<img id="beastfront" src="img/sex/doggy/beast/activelizardfrontlegvfast.gif">
<<elseif $beastname is "blackwolf">>
<img id="beastback" src="img/sex/doggy/beast/activeblackwolfvfast.gif">
<img id="beastfront" src="img/sex/doggy/beast/activeblackwolffrontlegvfast.gif">
<<elseif $beasttype is "wolf">>
<img id="beastback" src="img/sex/doggy/beast/activewolfvfast.gif">
<img id="beastfront" src="img/sex/doggy/beast/activewolffrontlegvfast.gif">
<<elseif $beasttype is "dolphin">>
<img id="beastback" src="img/sex/doggy/beast/dolphin/activedolphinvfast.gif">
<img id="beastfront" src="img/sex/doggy/beast/dolphin/activedolphinfrontlegvfast.gif">
<<elseif $beasttype is "pig">>
<img id="beastback" src="img/sex/doggy/beast/pig/activepigvfast.gif">
<img id="beastfront" src="img/sex/doggy/beast/pig/activepigfrontlegvfast.gif">
<<elseif $beasttype is "boar">>
<img id="beastback" src="img/sex/doggy/beast/boar/activeboarvfast.gif">
<img id="beastfront" src="img/sex/doggy/beast/boar/activeboarfrontlegvfast.gif">
<<else>>
<img id="beastback" src="img/sex/doggy/beast/activebeastvfast.gif">
<img id="beastfront" src="img/sex/doggy/beast/activebeastfrontlegvfast.gif">
<</if>>
<</if>>
<<if $beasttype is "dolphin" and $enemytype is "beast">>
<<if $penis is "anusentrance">>
<img id="beastback" src="img/sex/doggy/beast/dolphin/activedolphinanusentrancevfast.gif">
<</if>>
<<if $penis is "anusimminent">>
<img id="beastback" src="img/sex/doggy/beast/dolphin/activedolphinanusentrancevfast.gif">
<</if>>
<<if $penis is "anus">>
<img id="beastback" src="img/sex/doggy/beast/dolphin/activedolphinpenisvfast.gif">
<</if>>
<<if $penis is "cheeks">>
<img id="beastback" src="img/sex/doggy/beast/dolphin/activedolphinanusentrancevfast.gif">
<</if>>
<<if $penis is "thighs">>
<img id="beastfront" src="img/sex/doggy/beast/dolphin/activedolphinvaginaentrancevfast.gif">
<</if>>
<<if $penis is "vaginaentrance">>
<img id="beastfront" src="img/sex/doggy/beast/dolphin/activedolphinvaginaentrancevfast.gif">
<</if>>
<<if $penis is "vaginaimminent">>
<img id="beastfront" src="img/sex/doggy/beast/dolphin/activedolphinvaginaentrancevfast.gif">
<</if>>
<<if $penis is "vagina">>
<img id="beastback" src="img/sex/doggy/beast/dolphin/activedolphinpenisvfast.gif">
<</if>>
<<elseif $enemytype is "beast">>
<<if $penis is "anusentrance">>
<img id="beastback" src="img/sex/doggy/beast/activebeastanusentrancevfast.gif">
<</if>>
<<if $penis is "anusimminent">>
<img id="beastback" src="img/sex/doggy/beast/activebeastanusentrancevfast.gif">
<</if>>
<<if $penis is "anus">>
<img id="beastback" src="img/sex/doggy/beast/activebeastpenisvfast.gif">
<</if>>
<<if $penis is "cheeks">>
<img id="beastback" src="img/sex/doggy/beast/activebeastanusentrancevfast.gif">
<</if>>
<<if $penis is "thighs">>
<img id="beastfront" src="img/sex/doggy/beast/activebeastvaginaentrancevfast.gif">
<</if>>
<<if $penis is "vaginaentrance">>
<img id="beastfront" src="img/sex/doggy/beast/activebeastvaginaentrancevfast.gif">
<</if>>
<<if $penis is "vaginaimminent">>
<img id="beastfront" src="img/sex/doggy/beast/activebeastvaginaentrancevfast.gif">
<</if>>
<<if $penis is "vagina">>
<img id="beastback" src="img/sex/doggy/beast/activebeastpenisvfast.gif">
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "beastimgfast">><<nobr>>
<<if $enemytype is "beast" and $beaststance is "top">>
<<if $beasttype is "lizard">>
<img id="beastback" src="img/sex/doggy/beast/activelizardfast.gif">
<img id="beastfront" src="img/sex/doggy/beast/activelizardfrontlegfast.gif">
<<elseif $beastname is "blackwolf">>
<img id="beastback" src="img/sex/doggy/beast/activeblackwolffast.gif">
<img id="beastfront" src="img/sex/doggy/beast/activeblackwolffrontlegfast.gif">
<<elseif $beasttype is "wolf">>
<img id="beastback" src="img/sex/doggy/beast/activewolffast.gif">
<img id="beastfront" src="img/sex/doggy/beast/activewolffrontlegfast.gif">
<<elseif $beasttype is "dolphin">>
<img id="beastback" src="img/sex/doggy/beast/dolphin/activedolphinfast.gif">
<img id="beastfront" src="img/sex/doggy/beast/dolphin/activedolphinfrontlegfast.gif">
<<elseif $beasttype is "pig">>
<img id="beastback" src="img/sex/doggy/beast/pig/activepigfast.gif">
<img id="beastfront" src="img/sex/doggy/beast/pig/activepigfrontlegfast.gif">
<<elseif $beasttype is "boar">>
<img id="beastback" src="img/sex/doggy/beast/boar/activeboarfast.gif">
<img id="beastfront" src="img/sex/doggy/beast/boar/activeboarfrontlegfast.gif">
<<else>>
<img id="beastback" src="img/sex/doggy/beast/activebeastfast.gif">
<img id="beastfront" src="img/sex/doggy/beast/activebeastfrontlegfast.gif">
<</if>>
<</if>>
<<if $beasttype is "dolphin" and $enemytype is "beast">>
<<if $penis is "anusentrance">>
<img id="beastback" src="img/sex/doggy/beast/dolphin/activedolphinanusentrancefast.gif">
<</if>>
<<if $penis is "anusimminent">>
<img id="beastback" src="img/sex/doggy/beast/dolphin/activedolphinanusentrancefast.gif">
<</if>>
<<if $penis is "anus">>
<img id="beastback" src="img/sex/doggy/beast/dolphin/activedolphinpenisfast.gif">
<</if>>
<<if $penis is "cheeks">>
<img id="beastback" src="img/sex/doggy/beast/dolphin/activedolphinanusentrancefast.gif">
<</if>>
<<if $penis is "thighs">>
<img id="beastfront" src="img/sex/doggy/beast/dolphin/activedolphinvaginaentrancefast.gif">
<</if>>
<<if $penis is "vaginaentrance">>
<img id="beastfront" src="img/sex/doggy/beast/dolphin/activedolphinvaginaentrancefast.gif">
<</if>>
<<if $penis is "vaginaimminent">>
<img id="beastfront" src="img/sex/doggy/beast/dolphin/activedolphinvaginaentrancefast.gif">
<</if>>
<<if $penis is "vagina">>
<img id="beastback" src="img/sex/doggy/beast/dolphin/activedolphinpenisfast.gif">
<</if>>
<<elseif $enemytype is "beast">>
<<if $penis is "anusentrance">>
<img id="beastback" src="img/sex/doggy/beast/activebeastanusentrancefast.gif">
<</if>>
<<if $penis is "anusimminent">>
<img id="beastback" src="img/sex/doggy/beast/activebeastanusentrancefast.gif">
<</if>>
<<if $penis is "anus">>
<img id="beastback" src="img/sex/doggy/beast/activebeastpenisfast.gif">
<</if>>
<<if $penis is "cheeks">>
<img id="beastback" src="img/sex/doggy/beast/activebeastanusentrancefast.gif">
<</if>>
<<if $penis is "thighs">>
<img id="beastfront" src="img/sex/doggy/beast/activebeastvaginaentrancefast.gif">
<</if>>
<<if $penis is "vaginaentrance">>
<img id="beastfront" src="img/sex/doggy/beast/activebeastvaginaentrancefast.gif">
<</if>>
<<if $penis is "vaginaimminent">>
<img id="beastfront" src="img/sex/doggy/beast/activebeastvaginaentrancefast.gif">
<</if>>
<<if $penis is "vagina">>
<img id="beastback" src="img/sex/doggy/beast/activebeastpenisfast.gif">
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "beastimgmid">><<nobr>>
<<if $enemytype is "beast" and $beaststance is "top">>
<<if $beasttype is "lizard">>
<img id="beastback" src="img/sex/doggy/beast/activelizardmid.gif">
<img id="beastfront" src="img/sex/doggy/beast/activelizardfrontlegmid.gif">
<<elseif $beastname is "blackwolf">>
<img id="beastback" src="img/sex/doggy/beast/activeblackwolfmid.gif">
<img id="beastfront" src="img/sex/doggy/beast/activeblackwolffrontlegmid.gif">
<<elseif $beasttype is "wolf">>
<img id="beastback" src="img/sex/doggy/beast/activewolfmid.gif">
<img id="beastfront" src="img/sex/doggy/beast/activewolffrontlegmid.gif">
<<elseif $beasttype is "dolphin">>
<img id="beastback" src="img/sex/doggy/beast/dolphin/activedolphinmid.gif">
<img id="beastfront" src="img/sex/doggy/beast/dolphin/activedolphinfrontlegmid.gif">
<<elseif $beasttype is "pig">>
<img id="beastback" src="img/sex/doggy/beast/pig/activepigmid.gif">
<img id="beastfront" src="img/sex/doggy/beast/pig/activepigfrontlegmid.gif">
<<elseif $beasttype is "boar">>
<img id="beastback" src="img/sex/doggy/beast/boar/activeboarmid.gif">
<img id="beastfront" src="img/sex/doggy/beast/boar/activeboarfrontlegmid.gif">
<<else>>
<img id="beastback" src="img/sex/doggy/beast/activebeastmid.gif">
<img id="beastfront" src="img/sex/doggy/beast/activebeastfrontlegmid.gif">
<</if>>
<</if>>
<<if $beasttype is "dolphin" and $enemytype is "beast">>
<<if $penis is "anusentrance">>
<img id="beastback" src="img/sex/doggy/beast/dolphin/activedolphinanusentrancemid.gif">
<</if>>
<<if $penis is "anusimminent">>
<img id="beastback" src="img/sex/doggy/beast/dolphin/activedolphinanusentrancemid.gif">
<</if>>
<<if $penis is "anus">>
<img id="beastback" src="img/sex/doggy/beast/dolphin/activedolphinpenismid.gif">
<</if>>
<<if $penis is "cheeks">>
<img id="beastback" src="img/sex/doggy/beast/dolphin/activedolphinanusentrancemid.gif">
<</if>>
<<if $penis is "thighs">>
<img id="beastfront" src="img/sex/doggy/beast/dolphin/activedolphinvaginaentrancemid.gif">
<</if>>
<<if $penis is "vaginaentrance">>
<img id="beastfront" src="img/sex/doggy/beast/dolphin/activedolphinvaginaentrancemid.gif">
<</if>>
<<if $penis is "vaginaimminent">>
<img id="beastfront" src="img/sex/doggy/beast/dolphin/activedolphinvaginaentrancemid.gif">
<</if>>
<<if $penis is "vagina">>
<img id="beastback" src="img/sex/doggy/beast/dolphin/activedolphinpenismid.gif">
<</if>>
<<elseif $enemytype is "beast">>
<<if $penis is "anusentrance">>
<img id="beastback" src="img/sex/doggy/beast/activebeastanusentrancemid.gif">
<</if>>
<<if $penis is "anusimminent">>
<img id="beastback" src="img/sex/doggy/beast/activebeastanusentrancemid.gif">
<</if>>
<<if $penis is "anus">>
<img id="beastback" src="img/sex/doggy/beast/activebeastpenismid.gif">
<</if>>
<<if $penis is "cheeks">>
<img id="beastback" src="img/sex/doggy/beast/activebeastanusentrancemid.gif">
<</if>>
<<if $penis is "thighs">>
<img id="beastfront" src="img/sex/doggy/beast/activebeastvaginaentrancemid.gif">
<</if>>
<<if $penis is "vaginaentrance">>
<img id="beastfront" src="img/sex/doggy/beast/activebeastvaginaentrancemid.gif">
<</if>>
<<if $penis is "vaginaimminent">>
<img id="beastfront" src="img/sex/doggy/beast/activebeastvaginaentrancemid.gif">
<</if>>
<<if $penis is "vagina">>
<img id="beastback" src="img/sex/doggy/beast/activebeastpenismid.gif">
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "beastimgslow">><<nobr>>
<<if $enemytype is "beast" and $beaststance is "top">>
<<if $beasttype is "lizard">>
<img id="beastback" src="img/sex/doggy/beast/activelizardslow.gif">
<img id="beastfront" src="img/sex/doggy/beast/activelizardfrontlegslow.gif">
<<elseif $beastname is "blackwolf">>
<img id="beastback" src="img/sex/doggy/beast/activeblackwolfmid.gif">
<img id="beastfront" src="img/sex/doggy/beast/activeblackwolffrontlegmid.gif">
<<elseif $beasttype is "wolf">>
<img id="beastback" src="img/sex/doggy/beast/activewolfslow.gif">
<img id="beastfront" src="img/sex/doggy/beast/activewolffrontlegslow.gif">
<<elseif $beasttype is "dolphin">>
<img id="beastback" src="img/sex/doggy/beast/dolphin/activedolphinslow.gif">
<img id="beastfront" src="img/sex/doggy/beast/dolphin/activedolphinfrontlegslow.gif">
<<elseif $beasttype is "pig">>
<img id="beastback" src="img/sex/doggy/beast/pig/activepigslow.gif">
<img id="beastfront" src="img/sex/doggy/beast/pig/activepigfrontlegslow.gif">
<<elseif $beasttype is "boar">>
<img id="beastback" src="img/sex/doggy/beast/boar/activeboarslow.gif">
<img id="beastfront" src="img/sex/doggy/beast/boar/activeboarfrontlegslow.gif">
<<else>>
<img id="beastback" src="img/sex/doggy/beast/activebeastslow.gif">
<img id="beastfront" src="img/sex/doggy/beast/activebeastfrontlegslow.gif">
<</if>>
<</if>>
<<if $beasttype is "dolphin" and $enemytype is "beast">>
<<if $penis is "anusentrance">>
<img id="beastback" src="img/sex/doggy/beast/dolphin/activedolphinanusentranceslow.gif">
<</if>>
<<if $penis is "anusimminent">>
<img id="beastback" src="img/sex/doggy/beast/dolphin/activedolphinanusentranceslow.gif">
<</if>>
<<if $penis is "anus">>
<img id="beastback" src="img/sex/doggy/beast/dolphin/activedolphinpenisslow.gif">
<</if>>
<<if $penis is "cheeks">>
<img id="beastback" src="img/sex/doggy/beast/dolphin/activedolphinanusentranceslow.gif">
<</if>>
<<if $penis is "thighs">>
<img id="beastfront" src="img/sex/doggy/beast/dolphin/activedolphinvaginaentranceslow.gif">
<</if>>
<<if $penis is "vaginaentrance">>
<img id="beastfront" src="img/sex/doggy/beast/dolphin/activedolphinvaginaentranceslow.gif">
<</if>>
<<if $penis is "vaginaimminent">>
<img id="beastfront" src="img/sex/doggy/beast/dolphin/activedolphinvaginaentranceslow.gif">
<</if>>
<<if $penis is "vagina">>
<img id="beastback" src="img/sex/doggy/beast/dolphin/activedolphinpenisslow.gif">
<</if>>
<<elseif $enemytype is "beast">>
<<if $penis is "anusentrance">>
<img id="beastback" src="img/sex/doggy/beast/activebeastanusentranceslow.gif">
<</if>>
<<if $penis is "anusimminent">>
<img id="beastback" src="img/sex/doggy/beast/activebeastanusentranceslow.gif">
<</if>>
<<if $penis is "anus">>
<img id="beastback" src="img/sex/doggy/beast/activebeastpenisslow.gif">
<</if>>
<<if $penis is "cheeks">>
<img id="beastback" src="img/sex/doggy/beast/activebeastanusentranceslow.gif">
<</if>>
<<if $penis is "thighs">>
<img id="beastfront" src="img/sex/doggy/beast/activebeastvaginaentranceslow.gif">
<</if>>
<<if $penis is "vaginaentrance">>
<img id="beastfront" src="img/sex/doggy/beast/activebeastvaginaentranceslow.gif">
<</if>>
<<if $penis is "vaginaimminent">>
<img id="beastfront" src="img/sex/doggy/beast/activebeastvaginaentranceslow.gif">
<</if>>
<<if $penis is "vagina">>
<img id="beastback" src="img/sex/doggy/beast/activebeastpenisslow.gif">
<</if>>
<</if>>
<</nobr>><</widget>>
:: Widgets Combat Effects [widget]
<<widget "combateffects">><<nobr>>
<<if $dev is 1>>
<<if $consensual is 1>>
<<if $trauma gte $traumasaved>>
<<set $trauma to ($trauma - (($trauma - $traumasaved) * (($devlevel - 6) * 0.1)))>>
<</if>>
<</if>>
<<elseif $dev is 0>>
<<if $consensual is 1>>
<<if $trauma gte $traumasaved>>
<<set $trauma -= ($trauma - $traumasaved)>>
<</if>>
<</if>>
<</if>>
<<if $rapetrait gte 1>>
<<if $trauma gte $traumasaved>>
<<set $trauma to ($trauma - (($trauma - $traumasaved) * 0.3))>>
<</if>>
<</if>>
<<if $bestialitytrait gte 1 and $enemytype is "beast">>
<<if $trauma gte $traumasaved>>
<<set $trauma to ($trauma - (($trauma - $traumasaved) * 0.3))>>
<</if>>
<</if>>
<<if $tentacletrait gte 1 and $enemytype is "tentacles">>
<<if $trauma gte $traumasaved>>
<<set $trauma to ($trauma - (($trauma - $traumasaved) * 0.3))>>
<</if>>
<</if>>
<<if $trauma gte $traumasaved>>
<<set $traumagain += ($trauma - $traumasaved)>>
<</if>>
<<if $trauma lte 0>>
<<set $traumasaved to 0>>
<<else>>
<<set $traumasaved to $trauma>>
<</if>>
<<if $sciencetrait gte 1>>
<<if $pain gte $painsaved>>
<<set $pain to ($pain - (($pain - $painsaved) * ($sciencetrait / 10)))>>
<</if>>
<</if>>
<<set $painsaved to $pain>>
<<if $orgasmtrait gte 1>>
<<if $arousal gte $arousalsaved>>
<<set $arousal to ($arousal - (($arousal - $arousalsaved) * 0.4))>>
<</if>>
<</if>>
<<set $arousalsaved to $arousal>>
<<if $stress gte $stresssaved>>
<<set $stressgain += ($stress - $stresssaved)>>
<</if>>
<<if $stress lte 0>>
<<set $stresssaved to 0>>
<<else>>
<<set $stresssaved to $stress>>
<</if>>
<</nobr>><</widget>>
:: Widgets Actions Pain [widget]
<<widget "actionspain">><<nobr>>
<<if $leftarm is 0>>Your left arm is free, but hurts to move.<br>
<<if $leftactiondefault is "leftstruggleweak">>
| <label><span class="brat">Struggle</span> <<radiobutton "$leftaction" "leftstruggleweak" checked>></label>
<<else>>
| <label><span class="brat">Struggle</span> <<radiobutton "$leftaction" "leftstruggleweak">></label>
<</if>>
<<if $leftactiondefault is "leftprotect">>
| <label><span class="meek">Protect</span> <<radiobutton "$leftaction" "leftprotect" checked>></label>
<<else>>
| <label><span class="meek">Protect</span> <<radiobutton "$leftaction" "leftprotect">></label>
<</if>>
<<elseif $leftarm is "grappled">>
Your left arm is held in a painful grip.<br><br>
<<elseif $leftarm is "bound">>
Your left arm is held in a painful bind.<br><br>
<</if>>
<br><br>
<<if $rightarm is 0>>Your right arm is free, but hurts to move.<br>
<<if $rightactiondefault is "rightstruggleweak">>
| <label><span class="brat">Struggle</span> <<radiobutton "$rightaction" "rightstruggleweak" checked>></label>
<<else>>
| <label><span class="brat">Struggle</span> <<radiobutton "$rightaction" "rightstruggleweak">></label>
<</if>>
<<if $rightactiondefault is "rightprotect">>
| <label><span class="meek">Protect</span> <<radiobutton "$rightaction" "rightprotect" checked>></label>
<<else>>
| <label><span class="meek">Protect</span> <<radiobutton "$rightaction" "rightprotect">></label>
<</if>>
<<elseif $rightarm is "grappled">>
Your right arm is held in a painful grip.<br><br>
<<elseif $rightarm is "bound">>
Your right arm is held in a painful grip.<br><br>
<</if>>
<br><br>
<<if $mouthuse is 0>>
Your mouth is free, but involuntary sobs and cries prevent speaking.<br>
<<if $mouthactiondefault is "stifle">>
| <label>Stifle <<radiobutton "$mouthaction" "stifle" checked>></label>
<<else>>
| <label>Stifle <<radiobutton "$mouthaction" "stifle">></label>
<</if>>
<<if $mouthactiondefault is "letout">>
| <label><span class="meek">Let it out</span> <<radiobutton "$mouthaction" "letout" checked>></label>
<<else>>
| <label><span class="meek">Let it out</span> <<radiobutton "$mouthaction" "letout">></label>
<</if>>
<</if>>
<br><br>
<</nobr>><</widget>>
:: Widgets Effects Pain [widget]
<<widget "effectspain">><<nobr>>
<<if $leftaction is "leftstruggleweak" and $rightaction is "rightstruggleweak">><<set $leftaction to 0>><<set $rightaction to 0>><<set $leftactiondefault to "leftstruggleweak">><<set $rightactiondefault to "rightstruggleweak">>
You fight through the pain and try to push them away, but have too little strength.<<brat 2>>
<</if>>
<<if $leftaction is "leftstruggleweak">><<set $leftaction to 0>><<set $leftactiondefault to "leftstruggleweak">>
You fight through the pain and push them with your left arm, but have too little strength.<<brat 1>>
<</if>>
<<if $rightaction is "rightstruggleweak">><<set $rightaction to 0>><<set $rightactiondefault to "rightstruggleweak">>
You fight through the pain and push them with your right arm, but have too little strength.<<brat 1>>
<</if>>
<<if $leftaction is "leftprotect" and $rightaction is "rightprotect">><<set $leftaction to 0>><<set $rightaction to 0>><<set $leftactiondefault to "leftprotect">><<set $rightactiondefault to "rightprotect">>
You shield the tender parts of your body, protecting them from further harm. <span class="green"> - Pain</span><<meek 2>><<set $pain -= 2>>
<</if>>
<<if $leftaction is "leftprotect">><<set $leftaction to 0>><<set $leftactiondefault to "leftprotect">>
You clutch a tender spot on your body with your left hand, protecting it from harm. <span class="green"> - Pain</span><<meek 1>><<set $pain -= 1>>
<</if>>
<<if $rightaction is "rightprotect">><<set $rightaction to 0>><<set $rightactiondefault to "rightprotect">>
You clutch a tender spot on your body with your right hand, protecting it from harm. <span class="green"> - Pain</span><<meek 1>><<set $pain -= 1>>
<</if>>
<br>
<<if $mouthaction is "stifle">><<set $mouthaction to 0>><<set $mouthactiondefault to "stifle">>
You try to control your breath and stifle your sobs. You're mostly successful.<<set $pain -= 1>> <span class="green"> - Pain</span>
<</if>>
<<if $mouthaction is "letout">><<set $mouthaction to 0>><<set $mouthactiondefault to "letout">>
You don't hold back your tears. Your sobs are punctuated by cries and whimpers.<<meek 1>><<stress -2>><span class="green"> - Stress</span>
<</if>>
<</nobr>><</widget>>
:: Widgets Actions Orgasm [widget]
<<widget "actionsorgasm">><<nobr>>
<<if $leftarm is 0>>Your left arm is free, but you can't stop the spasms.<br>
<<if $leftactiondefault is "leftfold">>
| <label><span class="brat">Fold</span> <<radiobutton "$leftaction" "leftfold" checked>></label>
<<else>>
| <label><span class="brat">Fold</span> <<radiobutton "$leftaction" "leftfold">></label>
<</if>>
<<if $leftactiondefault is "leftgrip">>
| <label><span class="meek">Grip</span> <<radiobutton "$leftaction" "leftgrip" checked>></label>
<<else>>
| <label><span class="meek">Grip</span> <<radiobutton "$leftaction" "leftgrip">></label>
<</if>>
<<elseif $leftarm is "grappled">>
Your left arm jerks against their grip.<br><br>
<<elseif $leftarm is "bound">>
Your left arm jerks against its bonds.<br><br>
<</if>>
<br><br>
<<if $rightarm is 0>>Your right arm is free, but you can't stop the spasms.<br>
<<if $rightactiondefault is "rightfold">>
| <label><span class="brat">Fold</span> <<radiobutton "$rightaction" "rightfold" checked>></label>
<<else>>
| <label><span class="brat">Fold</span> <<radiobutton "$rightaction" "rightfold">></label>
<</if>>
<<if $rightactiondefault is "rightgrip">>
| <label><span class="meek">Grip</span> <<radiobutton "$rightaction" "rightgrip" checked>></label>
<<else>>
| <label><span class="meek">Grip</span> <<radiobutton "$rightaction" "rightgrip">></label>
<</if>>
<<elseif $rightarm is "grappled">>
Your right arm jerks against their grip.<br><br>
<<elseif $rightarm is "bound">>
Your right arm jerks against its bonds.<br><br>
<</if>>
<br><br>
<<if $mouthuse is 0>>
Your mouth is free, but involuntary moans and cries prevent speaking.<br>
<<if $mouthactiondefault is "stifleorgasm">>
| <label><span class="brat">Stifle</span> <<radiobutton "$mouthaction" "stifleorgasm" checked>></label>
<<else>>
| <label><span class="brat">Stifle</span> <<radiobutton "$mouthaction" "stifleorgasm">></label>
<</if>>
<<if $mouthactiondefault is "letoutorgasm">>
| <label><span class="meek">Let it out</span> <<radiobutton "$mouthaction" "letoutorgasm" checked>></label>
<<else>>
| <label><span class="meek">Let it out</span> <<radiobutton "$mouthaction" "letoutorgasm">></label>
<</if>>
<</if>>
<br><br>
<</nobr>><</widget>>
:: Widgets Effects Orgasm [widget]
<<widget "effectsorgasm">><<nobr>>
<<if $leftaction is "leftfold" and $rightaction is "rightfold">><<set $leftaction to 0>><<set $rightaction to 0>><<set $leftactiondefault to "leftfold">><<set $rightactiondefault to "rightfold">>
You try to conceal your orgasm by folding your arms in front of you, keeping them as still as possible.<<brat 2>>
<</if>>
<<if $leftaction is "leftfold">><<set $leftaction to 0>><<set $leftactiondefault to "leftfold">>
You fold your left arm in front of you to keep it as still as possible.<<brat 1>>
<</if>>
<<if $rightaction is "rightfold">><<set $rightaction to 0>><<set $rightactiondefault to "rightfold">>
You fold your right arm in front of you to keep it as still as possible.<<brat 1>>
<</if>>
<<if $leftaction is "leftgrip" and $rightaction is "rightgrip">><<set $leftaction to 0>><<set $rightaction to 0>><<set $leftactiondefault to "leftgrip">><<set $rightactiondefault to "rightgrip">>
You grip whatever you can for purchase as your body trembles. <span class="green"> - Arousal</span><<meek 2>><<set $arousal -= 300>>
<</if>>
<<if $leftaction is "leftgrip">><<set $leftaction to 0>><<set $leftactiondefault to "leftgrip">>
You grip whatever you can with your left hand as your body trembles. <span class="green"> - Arousal</span><<meek 1>><<set $arousal -= 300>>
<</if>>
<<if $rightaction is "rightgrip">><<set $rightaction to 0>><<set $rightactiondefault to "rightgrip">>
You grip whatever you can with your right hand as your body trembles. <span class="green"> - Arousal</span><<meek 1>><<set $arousal -= 300>>
<</if>>
<br>
<<if $mouthaction is "stifleorgasm">><<set $mouthaction to 0>><<set $mouthactiondefault to "stifleorgasm">>
You scowl, hoping your gasps are taken as exasperation.<<brat 1>>
<</if>>
<<if $mouthaction is "letoutorgasm">><<set $mouthaction to 0>><<set $mouthactiondefault to "letoutorgasm">>
You don't hold back, letting gasps and moans escape as they will.<<meek 1>><span class="green"> - Arousal</span><<set $arousal -= 300>>
<</if>>
<</nobr>><</widget>>
:: Widgets Actions Dissociation [widget]
<<widget "actionsdissociation">><<nobr>>
<<if $leftarm is 0>>Your left arm is free, but doesn't feel real.<br>
<<if $leftactiondefault is "leftpoke">>
| <label>Poke yourself <<radiobutton "$leftaction" "leftpoke" checked>></label>
<<else>>
| <label>Poke yourself <<radiobutton "$leftaction" "leftpoke">></label>
<</if>>
<<if $leftactiondefault is "leftcurl">>
| <label><span class="meek">Keep your arms out of the way</span> <<radiobutton "$leftaction" "leftcurl" checked>></label>
<<else>>
| <label><span class="meek">Keep your arms out of the way</span> <<radiobutton "$leftaction" "leftcurl">></label>
<</if>>
<<elseif $leftarm is "grappled">>
Your left arm lies limp in their grip.<br><br>
<<elseif $leftarm is "bound">>
Your left arm lies limp in its bonds.<br><br>
<</if>>
<br><br>
<<if $rightarm is 0>>Your right arm is free, but doesn't feel real.<br>
<<if $rightactiondefault is "rightpoke">>
| <label>Poke yourself <<radiobutton "$rightaction" "rightpoke" checked>></label>
<<else>>
| <label>Poke yourself <<radiobutton "$rightaction" "rightpoke">></label>
<</if>>
<<if $rightactiondefault is "rightcurl">>
| <label><span class="meek">Keep your arms out of the way</span> <<radiobutton "$rightaction" "rightcurl" checked>></label>
<<else>>
| <label><span class="meek">Keep your arms out of the way</span> <<radiobutton "$rightaction" "rightcurl">></label>
<</if>>
<<elseif $rightarm is "grappled">>
Your right arm lies limp in their grip.<br><br>
<<elseif $rightarm is "bound">>
Your right arm lies limp in its bonds.<br><br>
<</if>>
<br><br>
<<if $mouthuse is 0>>
Your mouth is free, but you don't know why.<br>
<<if $mouthactiondefault is "speak">>
| <label>Try to speak <<radiobutton "$mouthaction" "speak" checked>></label>
<<else>>
| <label>Try to speak <<radiobutton "$mouthaction" "speak">></label>
<</if>>
<<if $mouthactiondefault is "noises">>
| <label><span class="meek">Make soft noises</span> <<radiobutton "$mouthaction" "noises" checked>></label>
<<else>>
| <label><span class="meek">Make soft noises</span> <<radiobutton "$mouthaction" "noises">></label>
<</if>>
<</if>>
<br><br>
<</nobr>><</widget>>
:: Widgets Effects Dissociation [widget]
<<widget "effectsdissociation">><<nobr>>
<<if $leftaction is "leftpoke" and $rightaction is "rightpoke">><<set $leftaction to 0>><<set $rightaction to 0>><<set $leftactiondefault to "leftpoke">><<set $rightactiondefault to "rightpoke">>
You poke yourself. Is this real?<<set $traumafocus += 2>><span class="green"> + Focus</span>
<</if>>
<<if $leftaction is "leftpoke">><<set $leftaction to 0>><<set $leftactiondefault to "leftpoke">>
You poke yourself with your left hand.<<set $traumafocus += 1>><span class="green"> + Focus</span>
<</if>>
<<if $rightaction is "rightpoke">><<set $rightaction to 0>><<set $rightactiondefault to "rightpoke">>
You poke yourself with your right hand.<<set $traumafocus += 1>><span class="green"> + Focus</span>
<</if>>
<<if $leftaction is "leftcurl" and $rightaction is "rightcurl">><<set $leftaction to 0>><<set $rightaction to 0>><<set $leftactiondefault to "leftcurl">><<set $rightactiondefault to "rightcurl">>
You hold your arms to the side and curl your fingers.<<meek 2>>
<</if>>
<<if $leftaction is "leftcurl">><<set $leftaction to 0>><<set $leftactiondefault to "leftcurl">>
You hold your left arm to the side and curl your fingers.<<meek 1>>
<</if>>
<<if $rightaction is "rightcurl">><<set $rightaction to 0>><<set $rightactiondefault to "rightcurl">>
You hold your right arm to the side and curl your fingers.<<meek 1>>
<</if>>
<br>
<<if $mouthaction is "speak">><<set $mouthaction to 0>><<set $mouthactiondefault to "speak">>
You make some noises that resemble words.<span class="green"> + Focus</span>
<</if>>
<<if $mouthaction is "noises">><<set $mouthaction to 0>><<set $mouthactiondefault to "noises">>
You make some soft noises. They sound nice.<<meek 1>>
<</if>>
<</nobr>><</widget>>
:: Widgets Combat State [widget]
<<widget "combatstate">><<nobr>>
<<if $orgasmdown gte 1>><<set $enemyarousal += 10>>
<span class="pink">Your body pulses and spasms with orgasmic waves, preventing you from acting normally.<br></span><<disable>>
<<if $panicviolence lte 0 and $panicparalysis lte 0 and $trance lte 0>>
<<actionsorgasm>>
<</if>>
<</if>>
<<if $pain gte 100>><<set $enemyarousal += 10>>
<span class="red">You are in too much pain to act normally.<br></span><<disable>>
<<if $orgasmdown lte 0 and $panicviolence lte 0 and $panicparalysis lte 0 and $trance lte 0>>
<<actionspain>>
<</if>>
<</if>>
<<if $panicviolence gte 1>><<set $enemyarousal += 10>>
<span class="red">You are stricken with panic, and flail wildly at anything invading your personal space.<br></span><<defiance 10>><<set $panicviolence to $panicviolence - 1>><<disable>>
<</if>>
<<if $panicparalysis gte 1>><<set $enemyarousal += 10>>
<span class="red">You are stricken with panic, your muscles seize up, preventing action.<br></span><<set $panicparalysis -= 1>><<disable>>
<</if>>
<<if $dissociation gte 2>><<set $enemyarousal += 10>>
You feel disconnected from yourself, as if in a dream.<br><<disable>>
<<if $orgasmdown lte 0 and $panicviolence lte 0 and $panicparalysis lte 0 and $trance lte 0 and $pain lt 100>>
<<actionsdissociation>>
<</if>>
<</if>>
<<if $trance gte 1>><<set $enemyarousal += 10>>
You are entranced.<br>
<<disable>>
<</if>>
<</nobr>><</widget>>
<<widget "carryblock">><<nobr>>
<<if $orgasmdown gte 1>><<set $carryblock to "orgasm">>
<<elseif $pain gte 100>><<set $carryblock to "pain">>
<<elseif $dissociation gte 2>><<set $carryblock to "dissociation">>
<<elseif $panicviolence gte 1>><<set $carryblock to 1>>
<<elseif $panicparalysis gte 1>><<set $carryblock to 1>>
<<elseif $trance gte 1>><<set $carryblock to 1>>
<<else>><<set $carryblock to 0>>
<</if>>
<</nobr>><</widget>>
<<widget "actioncarry">><<nobr>>
<<if $carryblock is 0>>
<<set $leftactioncarry to $leftactiondefault>>
<<set $rightactioncarry to $rightactiondefault>>
<<set $feetactioncarry to $feetactiondefault>>
<<set $mouthactioncarry to $mouthactiondefault>>
<<set $vaginaactioncarry to $vaginaactiondefault>>
<<set $penisactioncarry to $penisactiondefault>>
<<set $anusactioncarry to $anusactiondefault>>
<<set $thighactioncarry to $thighactiondefault>>
<<set $cheekactioncarry to $cheekactiondefault>>
<<set $chestactioncarry to $chestactiondefault>>
<<elseif $carryblock is "pain">>
<<set $leftactioncarrypain to $leftactiondefault>>
<<set $rightactioncarrypain to $rightactiondefault>>
<<set $feetactioncarrypain to $feetactiondefault>>
<<set $mouthactioncarrypain to $mouthactiondefault>>
<<set $vaginaactioncarrypain to $vaginaactiondefault>>
<<set $penisactioncarrypain to $penisactiondefault>>
<<set $anusactioncarrypain to $anusactiondefault>>
<<set $thighactioncarrypain to $thighactiondefault>>
<<set $cheekactioncarrypain to $cheekactiondefault>>
<<set $chestactioncarrypain to $chestactiondefault>>
<<elseif $carryblock is "orgasm">>
<<set $leftactioncarryorgasm to $leftactiondefault>>
<<set $rightactioncarryorgasm to $rightactiondefault>>
<<set $feetactioncarryorgasm to $feetactiondefault>>
<<set $mouthactioncarryorgasm to $mouthactiondefault>>
<<set $vaginaactioncarryorgasm to $vaginaactiondefault>>
<<set $penisactioncarryorgasm to $penisactiondefault>>
<<set $anusactioncarryorgasm to $anusactiondefault>>
<<set $thighactioncarryorgasm to $thighactiondefault>>
<<set $cheekactioncarryorgasm to $cheekactiondefault>>
<<set $chestactioncarryorgasm to $chestactiondefault>>
<<elseif $carryblock is "dissociation">>
<<set $leftactioncarrydissociation to $leftactiondefault>>
<<set $rightactioncarrydissociation to $rightactiondefault>>
<<set $feetactioncarrydissociation to $feetactiondefault>>
<<set $mouthactioncarrydissociation to $mouthactiondefault>>
<<set $vaginaactioncarrydissociation to $vaginaactiondefault>>
<<set $penisactioncarrydissociation to $penisactiondefault>>
<<set $anusactioncarrydissociation to $anusactiondefault>>
<<set $thighactioncarrydissociation to $thighactiondefault>>
<<set $cheekactioncarrydissociation to $cheekactiondefault>>
<<set $chestactioncarrydissociation to $chestactiondefault>>
<</if>>
<<set $carryblock to 0>>
<</nobr>><</widget>>
<<widget "actioncarrydrop">><<nobr>>
<<if $orgasmdown gte 1>>
<<set $leftactiondefault to $leftactioncarryorgasm>>
<<set $rightactiondefault to $rightactioncarryorgasm>>
<<set $feetactiondefault to $feetactioncarryorgasm>>
<<set $mouthactiondefault to $mouthactioncarryorgasm>>
<<set $vaginaactiondefault to $vaginaactioncarryorgasm>>
<<set $penisactiondefault to $penisactioncarryorgasm>>
<<set $anusactiondefault to $anusactioncarryorgasm>>
<<set $thighactiondefault to $thighactioncarryorgasm>>
<<set $cheekactiondefault to $cheekactioncarryorgasm>>
<<set $chestactiondefault to $chestactioncarryorgasm>>
<<elseif $pain gte 100>>
<<set $leftactiondefault to $leftactioncarrypain>>
<<set $rightactiondefault to $rightactioncarrypain>>
<<set $feetactiondefault to $feetactioncarrypain>>
<<set $mouthactiondefault to $mouthactioncarrypain>>
<<set $vaginaactiondefault to $vaginaactioncarrypain>>
<<set $penisactiondefault to $penisactioncarrypain>>
<<set $anusactiondefault to $anusactioncarrypain>>
<<set $thighactiondefault to $thighactioncarrypain>>
<<set $cheekactiondefault to $cheekactioncarrypain>>
<<set $chestactiondefault to $chestactioncarrypain>>
<<elseif $dissociation gte 2>>
<<set $leftactiondefault to $leftactioncarrydissociation>>
<<set $rightactiondefault to $rightactioncarrydissociation>>
<<set $feetactiondefault to $feetactioncarrydissociation>>
<<set $mouthactiondefault to $mouthactioncarrydissociation>>
<<set $vaginaactiondefault to $vaginaactioncarrydissociation>>
<<set $penisactiondefault to $penisactioncarrydissociation>>
<<set $anusactiondefault to $anusactioncarrydissociation>>
<<set $thighactiondefault to $thighactioncarrydissociation>>
<<set $cheekactiondefault to $cheekactioncarrydissociation>>
<<set $chestactiondefault to $chestactioncarrydissociation>>
<<else>>
<<set $leftactiondefault to $leftactioncarry>>
<<set $rightactiondefault to $rightactioncarry>>
<<set $feetactiondefault to $feetactioncarry>>
<<set $mouthactiondefault to $mouthactioncarry>>
<<set $vaginaactiondefault to $vaginaactioncarry>>
<<set $penisactiondefault to $penisactioncarry>>
<<set $anusactiondefault to $anusactioncarry>>
<<set $thighactiondefault to $thighactioncarry>>
<<set $cheekactiondefault to $cheekactioncarry>>
<<set $chestactiondefault to $chestactioncarry>>
<</if>>
<</nobr>><</widget>>
:: Widgets Actions Vagina [widget]
<<widget "actionsvaginatopenis">><<nobr>>
<<if $undertype isnot "chastity">>
<<if $penis is 0>>
<<if $consensual is 1 and $promiscuity lte 74 and $enemytype is "man" or $consensual is 1 and $deviancy lte 74 and $enemytype isnot "man">>
<<else>>
<<if $vaginaactiondefault is "vaginatopenis">>
| <label><span class="sub">Straddle <<his>> penis</span> <<radiobutton "$vaginaaction" "vaginatopenis" checked>><<vaginaldifficulty>> <<combatpromiscuous5>></label>
<<else>>
| <label><span class="sub">Straddle <<his>> penis</span> <<radiobutton "$vaginaaction" "vaginatopenis">><<vaginaldifficulty>> <<combatpromiscuous5>></label>
<</if>>
<</if>>
<<elseif $penis2 is 0>>
<<if $consensual is 1 and $promiscuity lte 74 and $enemytype is "man" or $consensual is 1 and $deviancy lte 74 and $enemytype isnot "man">>
<<else>>
<<if $vaginaactiondefault is "vaginatopenis">>
| <label><span class="sub">Straddle <<his>> penis</span> <<radiobutton "$vaginaaction" "vaginatopenis" checked>><<vaginaldifficulty>> <<combatpromiscuous5>></label>
<<else>>
| <label><span class="sub">Straddle <<his>> penis</span> <<radiobutton "$vaginaaction" "vaginatopenis">><<vaginaldifficulty>> <<combatpromiscuous5>></label>
<</if>>
<</if>>
<<elseif $penis3 is 0>>
<<if $consensual is 1 and $promiscuity lte 74 and $enemytype is "man" or $consensual is 1 and $deviancy lte 74 and $enemytype isnot "man">>
<<else>>
<<if $vaginaactiondefault is "vaginatopenis">>
| <label><span class="sub">Straddle <<his>> penis</span> <<radiobutton "$vaginaaction" "vaginatopenis" checked>><<vaginaldifficulty>> <<combatpromiscuous5>></label>
<<else>>
| <label><span class="sub">Straddle <<his>> penis</span> <<radiobutton "$vaginaaction" "vaginatopenis">><<vaginaldifficulty>> <<combatpromiscuous5>></label>
<</if>>
<</if>>
<<elseif $penis4 is 0>>
<<if $consensual is 1 and $promiscuity lte 74 and $enemytype is "man" or $consensual is 1 and $deviancy lte 74 and $enemytype isnot "man">>
<<else>>
<<if $vaginaactiondefault is "vaginatopenis">>
| <label><span class="sub">Straddle <<his>> penis</span> <<radiobutton "$vaginaaction" "vaginatopenis" checked>><<vaginaldifficulty>> <<combatpromiscuous5>></label>
<<else>>
| <label><span class="sub">Straddle <<his>> penis</span> <<radiobutton "$vaginaaction" "vaginatopenis">><<vaginaldifficulty>> <<combatpromiscuous5>></label>
<</if>>
<</if>>
<<elseif $penis5 is 0>>
<<if $consensual is 1 and $promiscuity lte 74 and $enemytype is "man" or $consensual is 1 and $deviancy lte 74 and $enemytype isnot "man">>
<<else>>
<<if $vaginaactiondefault is "vaginatopenis">>
| <label><span class="sub">Straddle <<his>> penis</span> <<radiobutton "$vaginaaction" "vaginatopenis" checked>><<vaginaldifficulty>> <<combatpromiscuous5>></label>
<<else>>
| <label><span class="sub">Straddle <<his>> penis</span> <<radiobutton "$vaginaaction" "vaginatopenis">><<vaginaldifficulty>> <<combatpromiscuous5>></label>
<</if>>
<</if>>
<<elseif $penis6 is 0>>
<<if $consensual is 1 and $promiscuity lte 74 and $enemytype is "man" or $consensual is 1 and $deviancy lte 74 and $enemytype isnot "man">>
<<else>>
<<if $vaginaactiondefault is "vaginatopenis">>
| <label><span class="sub">Straddle <<his>> penis</span> <<radiobutton "$vaginaaction" "vaginatopenis" checked>><<vaginaldifficulty>> <<combatpromiscuous5>></label>
<<else>>
| <label><span class="sub">Straddle <<his>> penis</span> <<radiobutton "$vaginaaction" "vaginatopenis">><<vaginaldifficulty>> <<combatpromiscuous5>></label>
<</if>>
<</if>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionsvaginapenisfuck">><<nobr>>
<<if $undertype isnot "chastity" and $undervaginaexposed is 1 and $lowervaginaexposed is 1>>
<<if $penis is "vaginaentrance" or $penis is "vaginaimminent">>
<<if $consensual is 1 and $promiscuity lte 74 and $enemytype is "man" or $consensual is 1 and $deviancy lte 74 and $enemytype isnot "man">>
<<else>>
<<if $vaginaactiondefault is "vaginapenisfuck">>
| <label><span class="sub">Envelop <<his>> penis</span> <<radiobutton "$vaginaaction" "vaginapenisfuck" checked>> <<combatpromiscuous5>><<vaginalvirginitywarning>></label>
<<else>>
| <label><span class="sub">Envelop <<his>> penis</span> <<radiobutton "$vaginaaction" "vaginapenisfuck">> <<combatpromiscuous5>><<vaginalvirginitywarning>></label>
<</if>>
<</if>>
<<elseif $penis2 is "vaginaentrance" or $penis2 is "vaginaimminent">>
<<if $consensual is 1 and $promiscuity lte 74 and $enemytype is "man" or $consensual is 1 and $deviancy lte 74 and $enemytype isnot "man">>
<<else>>
<<if $vaginaactiondefault is "vaginapenisfuck">>
| <label><span class="sub">Envelop <<his>> penis</span> <<radiobutton "$vaginaaction" "vaginapenisfuck" checked>> <<combatpromiscuous5>><<vaginalvirginitywarning>></label>
<<else>>
| <label><span class="sub">Envelop <<his>> penis</span> <<radiobutton "$vaginaaction" "vaginapenisfuck">> <<combatpromiscuous5>><<vaginalvirginitywarning>></label>
<</if>>
<</if>>
<<elseif $penis3 is "vaginaentrance" or $penis3 is "vaginaimminent">>
<<if $consensual is 1 and $promiscuity lte 74 and $enemytype is "man" or $consensual is 1 and $deviancy lte 74 and $enemytype isnot "man">>
<<else>>
<<if $vaginaactiondefault is "vaginapenisfuck">>
| <label><span class="sub">Envelop <<his>> penis</span> <<radiobutton "$vaginaaction" "vaginapenisfuck" checked>> <<combatpromiscuous5>><<vaginalvirginitywarning>></label>
<<else>>
| <label><span class="sub">Envelop <<his>> penis</span> <<radiobutton "$vaginaaction" "vaginapenisfuck">> <<combatpromiscuous5>><<vaginalvirginitywarning>></label>
<</if>>
<</if>>
<<elseif $penis4 is "vaginaentrance" or $penis4 is "vaginaimminent">>
<<if $consensual is 1 and $promiscuity lte 74 and $enemytype is "man" or $consensual is 1 and $deviancy lte 74 and $enemytype isnot "man">>
<<else>>
<<if $vaginaactiondefault is "vaginapenisfuck">>
| <label><span class="sub">Envelop <<his>> penis</span> <<radiobutton "$vaginaaction" "vaginapenisfuck" checked>> <<combatpromiscuous5>><<vaginalvirginitywarning>></label>
<<else>>
| <label><span class="sub">Envelop <<his>> penis</span> <<radiobutton "$vaginaaction" "vaginapenisfuck">> <<combatpromiscuous5>><<vaginalvirginitywarning>></label>
<</if>>
<</if>>
<<elseif $penis5 is "vaginaentrance" or $penis5 is "vaginaimminent">>
<<if $consensual is 1 and $promiscuity lte 74 and $enemytype is "man" or $consensual is 1 and $deviancy lte 74 and $enemytype isnot "man">>
<<else>>
<<if $vaginaactiondefault is "vaginapenisfuck">>
| <label><span class="sub">Envelop <<his>> penis</span> <<radiobutton "$vaginaaction" "vaginapenisfuck" checked>> <<combatpromiscuous5>><<vaginalvirginitywarning>></label>
<<else>>
| <label><span class="sub">Envelop <<his>> penis</span> <<radiobutton "$vaginaaction" "vaginapenisfuck">> <<combatpromiscuous5>><<vaginalvirginitywarning>></label>
<</if>>
<</if>>
<<elseif $penis6 is "vaginaentrance" or $penis6 is "vaginaimminent">>
<<if $consensual is 1 and $promiscuity lte 74 and $enemytype is "man" or $consensual is 1 and $deviancy lte 74 and $enemytype isnot "man">>
<<else>>
<<if $vaginaactiondefault is "vaginapenisfuck">>
| <label><span class="sub">Envelop <<his>> penis</span> <<radiobutton "$vaginaaction" "vaginapenisfuck" checked>> <<combatpromiscuous5>><<vaginalvirginitywarning>></label>
<<else>>
| <label><span class="sub">Envelop <<his>> penis</span> <<radiobutton "$vaginaaction" "vaginapenisfuck">> <<combatpromiscuous5>><<vaginalvirginitywarning>></label>
<</if>>
<</if>>
<</if>>
<</if>>
<</nobr>><</widget>>
:: Widgets Effects Vagina [widget]
<<widget "effectsvaginatopenis">><<nobr>>
<<if $vaginaaction is "vaginatopenis">><<set $vaginaaction to 0>><<submission 10>><<vaginalskilluse>><<set $vaginaactiondefault to "vaginatopenis">><<combatpromiscuity5>>
<<if (1000 - ($rng * 10) - ($enemytrust * 10) - $vaginalskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<<if $penis is 0>>
<<submission 2>><<set $vaginause to "penis">><<set $penis to "vaginaentrance">><<set $vaginastate to "entrance">><span class="lblue">You straddle the <<person1>><<combatperson>> and kiss <<his1>> penis with your <<pussystop>></span>
<<elseif $penis2 is 0>>
<<submission 2>><<set $vaginause to "penis">><<set $penis2 to "vaginaentrance">><<set $vaginastate to "entrance">><span class="lblue">You straddle the <<person2>><<combatperson>> and kiss <<his2>> penis with your <<pussystop>></span>
<<elseif $penis3 is 0>>
<<submission 2>><<set $vaginause to "penis">><<set $penis3 to "vaginaentrance">><<set $vaginastate to "entrance">><span class="lblue">You straddle the <<person3>><<combatperson>> and kiss <<his3>> penis with your <<pussystop>></span>
<<elseif $penis4 is 0>>
<<submission 2>><<set $vaginause to "penis">><<set $penis4 to "vaginaentrance">><<set $vaginastate to "entrance">><span class="lblue">You straddle the <<person4>><<combatperson>> and kiss <<his4>> penis with your <<pussystop>></span>
<<elseif $penis5 is 0>>
<<submission 2>><<set $vaginause to "penis">><<set $penis5 to "vaginaentrance">><<set $vaginastate to "entrance">><span class="lblue">You straddle the <<person5>><<combatperson>> and kiss <<his5>> penis with your <<pussystop>></span>
<<elseif $penis6 is 0>>
<<submission 2>><<set $vaginause to "penis">><<set $penis6 to "vaginaentrance">><<set $vaginastate to "entrance">><span class="lblue">You straddle the <<person6>><<combatperson>> and kiss <<his6>> penis with your <<pussystop>></span>
<</if>>
<<else>>
<<if $penis is 0>>
<span class="blue">You try to straddle the <<person1>><<combatperson>> but <<he>> pushes you off.</span>
<<elseif $penis2 is 0>>
<span class="blue">You try to straddle the <<person2>><<combatperson>> but <<he>> pushes you off.</span>
<<elseif $penis3 is 0>>
<span class="blue">You try to straddle the <<person3>><<combatperson>> but <<he>> pushes you off.</span>
<<elseif $penis4 is 0>>
<span class="blue">You try to straddle the <<person4>><<combatperson>> but <<he>> pushes you off.</span>
<<elseif $penis5 is 0>>
<span class="blue">You try to straddle the <<person5>><<combatperson>> but <<he>> pushes you off.</span>
<<elseif $penis6 is 0>>
<span class="blue">You try to straddle the <<person6>><<combatperson>> but <<he>> pushes you off.</span>
<</if>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "effectsvaginapenisfuck">><<nobr>>
<<if $vaginaaction is "vaginapenisfuck">><<set $vaginaaction to 0>><<submission 20>><<vaginalskilluse>><<set $vaginaactiondefault to "vaginapenisfuck">><<combatpromiscuity5>>
<<if $vaginalvirginity is 0>>
<<if $penis is "vaginaentrance" or $penis is "vaginaimminent">><<set $penis to "vagina">>
<span class="pink">You <<vaginaltext>> push against the <<person1>><<combatpersons>> penis, taking it deep into your <<pussystop>></span>
<<elseif $penis2 is "vaginaentrance" or $penis2 is "vaginaimminent">><<set $penis2 to "vagina">>
<span class="pink">You <<vaginaltext>> push against the <<person2>><<combatpersons>> penis, taking it deep into your <<pussystop>></span>
<<elseif $penis3 is "vaginaentrance" or $penis3 is "vaginaimminent">><<set $penis3 to "vagina">>
<span class="pink">You <<vaginaltext>> push against the <<person3>><<combatpersons>> penis, taking it deep into your <<pussystop>></span>
<<elseif $penis4 is "vaginaentrance" or $penis4 is "vaginaimminent">><<set $penis4 to "vagina">>
<span class="pink">You <<vaginaltext>> push against the <<person4>><<combatpersons>> penis, taking it deep deep into your <<pussystop>></span>
<<elseif $penis5 is "vaginaentrance" or $penis5 is "vaginaimminent">><<set $penis5 to "vagina">>
<span class="pink">You <<vaginaltext>> push against the <<person5>><<combatpersons>> penis, taking it deep into your <<pussystop>></span>
<<elseif $penis6 is "vaginaentrance" or $penis6 is "vaginaimminent">><<set $penis6 to "vagina">>
<span class="pink">You <<vaginaltext>> push against the <<person6>><<combatpersons>> penis, taking it deep into your <<pussystop>></span>
<</if>>
<<sex 30>><<vaginalstat>><<raped>><<vaginaraped>><<set $vaginastate to "penetrated">><<set $speechvaginapenetrated to 1>>
<<elseif $vaginalvirginity is 1>>
<<if $penis is "vaginaentrance" or $penis is "vaginaimminent">><<set $penis to "vagina">>
<span class="pink">You <<vaginaltext>> push against the <<person1>><<combatpersons>> penis, taking it deep into your virgin pussy.</span> <span class="red"> You feel your hymen tear, forever robbing you of your purity.</span>
<<elseif $penis2 is "vaginaentrance" or $penis2 is "vaginaimminent">><<set $penis2 to "vagina">>
<span class="pink">You <<vaginaltext>> push against the <<person2>><<combatpersons>> penis, taking it deep into your virgin pussy.</span> <span class="red"> You feel your hymen tear, forever robbing you of your purity.</span>
<<elseif $penis3 is "vaginaentrance" or $penis3 is "vaginaimminent">><<set $penis3 to "vagina">>
<span class="pink">You <<vaginaltext>> push against the <<person3>><<combatpersons>> penis, taking it deep into your virgin pussy.</span> <span class="red"> You feel your hymen tear, forever robbing you of your purity.</span>
<<elseif $penis4 is "vaginaentrance" or $penis4 is "vaginaimminent">><<set $penis4 to "vagina">>
<span class="pink">You <<vaginaltext>> push against the <<person4>><<combatpersons>> penis, taking it deep into your virgin pussy.</span> <span class="red"> You feel your hymen tear, forever robbing you of your purity.</span>
<<elseif $penis5 is "vaginaentrance" or $penis5 is "vaginaimminent">><<set $penis5 to "vagina">>
<span class="pink">You <<vaginaltext>> push against the <<person5>><<combatpersons>> penis, taking it deep into your virgin pussy.</span> <span class="red"> You feel your hymen tear, forever robbing you of your purity.</span>
<<elseif $penis6 is "vaginaentrance" or $penis6 is "vaginaimminent">><<set $penis6 to "vagina">>
<span class="pink">You <<vaginaltext>> push against the <<person6>><<combatpersons>> penis, taking it deep into your virgin pussy.</span> <span class="red"> You feel your hymen tear, forever robbing you of your purity.</span>
<</if>>
<<sex 100>><<set $vaginalvirginity to 0>><<bruise vagina>><<vaginalstat>><<violence 30>><<raped>><<vaginaraped>><<set $vaginastate to "penetrated">><<set $speechvaginavirgin to 1>>
<</if>>
<</if>>
<</nobr>><</widget>>
:: Widgets Actions Penis [widget]
<<widget "actionspenistovagina">><<nobr>>
<<if $undertype isnot "chastity">>
<<if $vagina is 0>>
<<if $consensual is 1 and $promiscuity lte 74 and $enemytype is "man" or $consensual is 1 and $deviancy lte 74 and $enemytype isnot "man">>
<<else>>
<<if $penisactiondefault is "penistovagina">>
| <label><span class="sub">Press against <<his>> pussy</span> <<radiobutton "$penisaction" "penistovagina" checked>><<peniledifficulty>> <<combatpromiscuous5>></label>
<<else>>
| <label><span class="sub">Press against <<his>> pussy</span> <<radiobutton "$penisaction" "penistovagina">><<peniledifficulty>> <<combatpromiscuous5>></label>
<</if>>
<</if>>
<<elseif $vagina2 is 0>>
<<if $consensual is 1 and $promiscuity lte 74 and $enemytype is "man" or $consensual is 1 and $deviancy lte 74 and $enemytype isnot "man">>
<<else>>
<<if $penisactiondefault is "penistovagina">>
| <label><span class="sub">Press against <<his>> pussy</span> <<radiobutton "$penisaction" "penistovagina" checked>><<peniledifficulty>> <<combatpromiscuous5>></label>
<<else>>
| <label><span class="sub">Press against <<his>> pussy</span> <<radiobutton "$penisaction" "penistovagina">><<peniledifficulty>> <<combatpromiscuous5>></label>
<</if>>
<</if>>
<<elseif $vagina3 is 0>>
<<if $consensual is 1 and $promiscuity lte 74 and $enemytype is "man" or $consensual is 1 and $deviancy lte 74 and $enemytype isnot "man">>
<<else>>
<<if $penisactiondefault is "penistovagina">>
| <label><span class="sub">Press against <<his>> pussy</span> <<radiobutton "$penisaction" "penistovagina" checked>><<peniledifficulty>> <<combatpromiscuous5>></label>
<<else>>
| <label><span class="sub">Press against <<his>> pussy</span> <<radiobutton "$penisaction" "penistovagina">><<peniledifficulty>> <<combatpromiscuous5>></label>
<</if>>
<</if>>
<<elseif $vagina4 is 0>>
<<if $consensual is 1 and $promiscuity lte 74 and $enemytype is "man" or $consensual is 1 and $deviancy lte 74 and $enemytype isnot "man">>
<<else>>
<<if $penisactiondefault is "penistovagina">>
| <label><span class="sub">Press against <<his>> pussy</span> <<radiobutton "$penisaction" "penistovagina" checked>><<peniledifficulty>> <<combatpromiscuous5>></label>
<<else>>
| <label><span class="sub">Press against <<his>> pussy</span> <<radiobutton "$penisaction" "penistovagina">><<peniledifficulty>> <<combatpromiscuous5>></label>
<</if>>
<</if>>
<<elseif $vagina5 is 0>>
<<if $consensual is 1 and $promiscuity lte 74 and $enemytype is "man" or $consensual is 1 and $deviancy lte 74 and $enemytype isnot "man">>
<<else>>
<<if $penisactiondefault is "penistovagina">>
| <label><span class="sub">Press against <<his>> pussy</span> <<radiobutton "$penisaction" "penistovagina" checked>><<peniledifficulty>> <<combatpromiscuous5>></label>
<<else>>
| <label><span class="sub">Press against <<his>> pussy</span> <<radiobutton "$penisaction" "penistovagina">><<peniledifficulty>> <<combatpromiscuous5>></label>
<</if>>
<</if>>
<<elseif $vagina6 is 0>>
<<if $consensual is 1 and $promiscuity lte 74 and $enemytype is "man" or $consensual is 1 and $deviancy lte 74 and $enemytype isnot "man">>
<<else>>
<<if $penisactiondefault is "penistovagina">>
| <label><span class="sub">Press against <<his>> pussy</span> <<radiobutton "$penisaction" "penistovagina" checked>><<peniledifficulty>> <<combatpromiscuous5>></label>
<<else>>
| <label><span class="sub">Press against <<his>> pussy</span> <<radiobutton "$penisaction" "penistovagina">><<peniledifficulty>> <<combatpromiscuous5>></label>
<</if>>
<</if>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionspenistoanus">><<nobr>>
<<if $enemytype isnot "beast" and $undertype isnot "chastity">>
<<if $vagina is 0>>
<<if $consensual is 1 and $promiscuity lte 74 and $enemytype is "man" or $consensual is 1 and $deviancy lte 74 and $enemytype isnot "man">>
<<else>>
<<if $penisactiondefault is "penistoanus">>
| <label><span class="sub">Press against <<his>> ass</span> <<radiobutton "$penisaction" "penistoanus" checked>><<peniledifficulty>> <<combatpromiscuous5>></label>
<<else>>
| <label><span class="sub">Press against <<his>> ass</span> <<radiobutton "$penisaction" "penistoanus">><<peniledifficulty>> <<combatpromiscuous5>></label>
<</if>>
<</if>>
<<elseif $vagina2 is 0>>
<<if $consensual is 1 and $promiscuity lte 74 and $enemytype is "man" or $consensual is 1 and $deviancy lte 74 and $enemytype isnot "man">>
<<else>>
<<if $penisactiondefault is "penistoanus">>
| <label><span class="sub">Press against <<his>> ass</span> <<radiobutton "$penisaction" "penistoanus" checked>><<peniledifficulty>> <<combatpromiscuous5>></label>
<<else>>
| <label><span class="sub">Press against <<his>> ass</span> <<radiobutton "$penisaction" "penistoanus">><<peniledifficulty>> <<combatpromiscuous5>></label>
<</if>>
<</if>>
<<elseif $vagina3 is 0>>
<<if $consensual is 1 and $promiscuity lte 74 and $enemytype is "man" or $consensual is 1 and $deviancy lte 74 and $enemytype isnot "man">>
<<else>>
<<if $penisactiondefault is "penistoanus">>
| <label><span class="sub">Press against <<his>> ass</span> <<radiobutton "$penisaction" "penistoanus" checked>><<peniledifficulty>> <<combatpromiscuous5>></label>
<<else>>
| <label><span class="sub">Press against <<his>> ass</span> <<radiobutton "$penisaction" "penistoanus">><<peniledifficulty>> <<combatpromiscuous5>></label>
<</if>>
<</if>>
<<elseif $vagina4 is 0>>
<<if $consensual is 1 and $promiscuity lte 74 and $enemytype is "man" or $consensual is 1 and $deviancy lte 74 and $enemytype isnot "man">>
<<else>>
<<if $penisactiondefault is "penistoanus">>
| <label><span class="sub">Press against <<his>> ass</span> <<radiobutton "$penisaction" "penistoanus" checked>><<peniledifficulty>> <<combatpromiscuous5>></label>
<<else>>
| <label><span class="sub">Press against <<his>> ass</span> <<radiobutton "$penisaction" "penistoanus">><<peniledifficulty>> <<combatpromiscuous5>></label>
<</if>>
<</if>>
<<elseif $vagina5 is 0>>
<<if $consensual is 1 and $promiscuity lte 74 and $enemytype is "man" or $consensual is 1 and $deviancy lte 74 and $enemytype isnot "man">>
<<else>>
<<if $penisactiondefault is "penistoanus">>
| <label><span class="sub">Press against <<his>> ass</span> <<radiobutton "$penisaction" "penistoanus" checked>><<peniledifficulty>> <<combatpromiscuous5>></label>
<<else>>
| <label><span class="sub">Press against <<his>> ass</span> <<radiobutton "$penisaction" "penistoanus">><<peniledifficulty>> <<combatpromiscuous5>></label>
<</if>>
<</if>>
<<elseif $vagina6 is 0>>
<<if $consensual is 1 and $promiscuity lte 74 and $enemytype is "man" or $consensual is 1 and $deviancy lte 74 and $enemytype isnot "man">>
<<else>>
<<if $penisactiondefault is "penistoanus">>
| <label><span class="sub">Press against <<his>> ass</span> <<radiobutton "$penisaction" "penistoanus" checked>><<peniledifficulty>> <<combatpromiscuous5>></label>
<<else>>
| <label><span class="sub">Press against <<his>> ass</span> <<radiobutton "$penisaction" "penistoanus">><<peniledifficulty>> <<combatpromiscuous5>></label>
<</if>>
<</if>>
<<elseif $penis is 0>>
<<if $consensual is 1 and $promiscuity lte 74 and $enemytype is "man" or $consensual is 1 and $deviancy lte 74 and $enemytype isnot "man">>
<<else>>
<<if $penisactiondefault is "penistoanus">>
| <label><span class="sub">Press against <<his>> ass</span> <<radiobutton "$penisaction" "penistoanus" checked>><<peniledifficulty>> <<combatpromiscuous5>></label>
<<else>>
| <label><span class="sub">Press against <<his>> ass</span> <<radiobutton "$penisaction" "penistoanus">><<peniledifficulty>> <<combatpromiscuous5>></label>
<</if>>
<</if>>
<<elseif $penis2 is 0>>
<<if $consensual is 1 and $promiscuity lte 74 and $enemytype is "man" or $consensual is 1 and $deviancy lte 74 and $enemytype isnot "man">>
<<else>>
<<if $penisactiondefault is "penistoanus">>
| <label><span class="sub">Press against <<his>> ass</span> <<radiobutton "$penisaction" "penistoanus" checked>><<peniledifficulty>> <<combatpromiscuous5>></label>
<<else>>
| <label><span class="sub">Press against <<his>> ass</span> <<radiobutton "$penisaction" "penistoanus">><<peniledifficulty>> <<combatpromiscuous5>></label>
<</if>>
<</if>>
<<elseif $penis3 is 0>>
<<if $consensual is 1 and $promiscuity lte 74 and $enemytype is "man" or $consensual is 1 and $deviancy lte 74 and $enemytype isnot "man">>
<<else>>
<<if $penisactiondefault is "penistoanus">>
| <label><span class="sub">Press against <<his>> ass</span> <<radiobutton "$penisaction" "penistoanus" checked>><<peniledifficulty>> <<combatpromiscuous5>></label>
<<else>>
| <label><span class="sub">Press against <<his>> ass</span> <<radiobutton "$penisaction" "penistoanus">><<peniledifficulty>> <<combatpromiscuous5>></label>
<</if>>
<</if>>
<<elseif $penis4 is 0>>
<<if $consensual is 1 and $promiscuity lte 74 and $enemytype is "man" or $consensual is 1 and $deviancy lte 74 and $enemytype isnot "man">>
<<else>>
<<if $penisactiondefault is "penistoanus">>
| <label><span class="sub">Press against <<his>> ass</span> <<radiobutton "$penisaction" "penistoanus" checked>><<peniledifficulty>> <<combatpromiscuous5>></label>
<<else>>
| <label><span class="sub">Press against <<his>> ass</span> <<radiobutton "$penisaction" "penistoanus">><<peniledifficulty>> <<combatpromiscuous5>></label>
<</if>>
<</if>>
<<elseif $penis5 is 0>>
<<if $consensual is 1 and $promiscuity lte 74 and $enemytype is "man" or $consensual is 1 and $deviancy lte 74 and $enemytype isnot "man">>
<<else>>
<<if $penisactiondefault is "penistoanus">>
| <label><span class="sub">Press against <<his>> ass</span> <<radiobutton "$penisaction" "penistoanus" checked>><<peniledifficulty>> <<combatpromiscuous5>></label>
<<else>>
| <label><span class="sub">Press against <<his>> ass</span> <<radiobutton "$penisaction" "penistoanus">><<peniledifficulty>> <<combatpromiscuous5>></label>
<</if>>
<</if>>
<<elseif $penis6 is 0>>
<<if $consensual is 1 and $promiscuity lte 74 and $enemytype is "man" or $consensual is 1 and $deviancy lte 74 and $enemytype isnot "man">>
<<else>>
<<if $penisactiondefault is "penistoanus">>
| <label><span class="sub">Press against <<his>> ass</span> <<radiobutton "$penisaction" "penistoanus" checked>><<peniledifficulty>> <<combatpromiscuous5>></label>
<<else>>
| <label><span class="sub">Press against <<his>> ass</span> <<radiobutton "$penisaction" "penistoanus">><<peniledifficulty>> <<combatpromiscuous5>></label>
<</if>>
<</if>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionspenisvaginafuck">><<nobr>>
<<if $enemytype isnot "beast" and $undertype isnot "chastity" and $undervaginaexposed is 1 and $lowervaginaexposed is 1>>
<<if $vagina is "penisentrance" or $vagina is "penisimminent">>
<<if $consensual is 1 and $promiscuity lte 74 and $enemytype is "man" or $consensual is 1 and $deviancy lte 74 and $enemytype isnot "man">>
<<else>>
<<if $penisactiondefault is "penisvaginafuck">>
| <label><span class="sub">Penetrate <<his>> pussy</span> <<radiobutton "$penisaction" "penisvaginafuck" checked>> <<combatpromiscuous5>><<penilevirginitywarning>></label>
<<else>>
| <label><span class="sub">Penetrate <<his>> pussy</span> <<radiobutton "$penisaction" "penisvaginafuck">> <<combatpromiscuous5>><<penilevirginitywarning>></label>
<</if>>
<</if>>
<<elseif $vagina2 is "penisentrance" or $vagina2 is "penisimminent">>
<<if $consensual is 1 and $promiscuity lte 74 and $enemytype is "man" or $consensual is 1 and $deviancy lte 74 and $enemytype isnot "man">>
<<else>>
<<if $penisactiondefault is "penisvaginafuck">>
| <label><span class="sub">Penetrate <<his>> pussy</span> <<radiobutton "$penisaction" "penisvaginafuck" checked>> <<combatpromiscuous5>><<penilevirginitywarning>></label>
<<else>>
| <label><span class="sub">Penetrate <<his>> pussy</span> <<radiobutton "$penisaction" "penisvaginafuck">> <<combatpromiscuous5>><<penilevirginitywarning>></label>
<</if>>
<</if>>
<<elseif $vagina3 is "penisentrance" or $vagina3 is "penisimminent">>
<<if $consensual is 1 and $promiscuity lte 74 and $enemytype is "man" or $consensual is 1 and $deviancy lte 74 and $enemytype isnot "man">>
<<else>>
<<if $penisactiondefault is "penisvaginafuck">>
| <label><span class="sub">Penetrate <<his>> pussy</span> <<radiobutton "$penisaction" "penisvaginafuck" checked>> <<combatpromiscuous5>><<penilevirginitywarning>></label>
<<else>>
| <label><span class="sub">Penetrate <<his>> pussy</span> <<radiobutton "$penisaction" "penisvaginafuck">> <<combatpromiscuous5>><<penilevirginitywarning>></label>
<</if>>
<</if>>
<<elseif $vagina4 is "penisentrance" or $vagina4 is "penisimminent">>
<<if $consensual is 1 and $promiscuity lte 74 and $enemytype is "man" or $consensual is 1 and $deviancy lte 74 and $enemytype isnot "man">>
<<else>>
<<if $penisactiondefault is "penisvaginafuck">>
| <label><span class="sub">Penetrate <<his>> pussy</span> <<radiobutton "$penisaction" "penisvaginafuck" checked>> <<combatpromiscuous5>><<penilevirginitywarning>></label>
<<else>>
| <label><span class="sub">Penetrate <<his>> pussy</span> <<radiobutton "$penisaction" "penisvaginafuck">> <<combatpromiscuous5>><<penilevirginitywarning>></label>
<</if>>
<</if>>
<<elseif $vagina5 is "penisentrance" or $vagina5 is "penisimminent">>
<<if $consensual is 1 and $promiscuity lte 74 and $enemytype is "man" or $consensual is 1 and $deviancy lte 74 and $enemytype isnot "man">>
<<else>>
<<if $penisactiondefault is "penisvaginafuck">>
| <label><span class="sub">Penetrate <<his>> pussy</span> <<radiobutton "$penisaction" "penisvaginafuck" checked>> <<combatpromiscuous5>><<penilevirginitywarning>></label>
<<else>>
| <label><span class="sub">Penetrate <<his>> pussy</span> <<radiobutton "$penisaction" "penisvaginafuck">> <<combatpromiscuous5>><<penilevirginitywarning>></label>
<</if>>
<</if>>
<<elseif $vagina6 is "penisentrance" or $vagina6 is "penisimminent">>
<<if $consensual is 1 and $promiscuity lte 74 and $enemytype is "man" or $consensual is 1 and $deviancy lte 74 and $enemytype isnot "man">>
<<else>>
<<if $penisactiondefault is "penisvaginafuck">>
| <label><span class="sub">Penetrate <<his>> pussy</span> <<radiobutton "$penisaction" "penisvaginafuck" checked>> <<combatpromiscuous5>><<penilevirginitywarning>></label>
<<else>>
| <label><span class="sub">Penetrate <<his>> pussy</span> <<radiobutton "$penisaction" "penisvaginafuck">> <<combatpromiscuous5>><<penilevirginitywarning>></label>
<</if>>
<</if>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionspenisanusfuck">><<nobr>>
<<if $enemytype isnot "beast" and $undertype isnot "chastity" and $undervaginaexposed is 1 and $lowervaginaexposed is 1>>
<<if $vagina is "otheranusentrance" or $vagina is "otheranusimminent">>
<<if $consensual is 1 and $promiscuity lte 74 and $enemytype is "man" or $consensual is 1 and $deviancy lte 74 and $enemytype isnot "man">>
<<else>>
<<if $penisactiondefault is "penisanusfuck">>
| <label><span class="sub">Penetrate <<his>> ass</span> <<radiobutton "$penisaction" "penisanusfuck" checked>> <<combatpromiscuous5>><<penilevirginitywarning>></label>
<<else>>
| <label><span class="sub">Penetrate <<his>> ass</span> <<radiobutton "$penisaction" "penisanusfuck">> <<combatpromiscuous5>><<penilevirginitywarning>></label>
<</if>>
<</if>>
<<elseif $vagina2 is "otheranusentrance" or $vagina2 is "otheranusimminent">>
<<if $consensual is 1 and $promiscuity lte 74 and $enemytype is "man" or $consensual is 1 and $deviancy lte 74 and $enemytype isnot "man">>
<<else>>
<<if $penisactiondefault is "penisanusfuck">>
| <label><span class="sub">Penetrate <<his>> ass</span> <<radiobutton "$penisaction" "penisanusfuck" checked>> <<combatpromiscuous5>></label>
<<else>>
| <label><span class="sub">Penetrate <<his>> ass</span> <<radiobutton "$penisaction" "penisanusfuck">> <<combatpromiscuous5>><<penilevirginitywarning>></label>
<</if>>
<</if>>
<<elseif $vagina3 is "otheranusentrance" or $vagina3 is "otheranusimminent">>
<<if $consensual is 1 and $promiscuity lte 74 and $enemytype is "man" or $consensual is 1 and $deviancy lte 74 and $enemytype isnot "man">>
<<else>>
<<if $penisactiondefault is "penisanusfuck">>
| <label><span class="sub">Penetrate <<his>> ass</span> <<radiobutton "$penisaction" "penisanusfuck" checked>> <<combatpromiscuous5>><<penilevirginitywarning>></label>
<<else>>
| <label><span class="sub">Penetrate <<his>> ass</span> <<radiobutton "$penisaction" "penisanusfuck">> <<combatpromiscuous5>><<penilevirginitywarning>></label>
<</if>>
<</if>>
<<elseif $vagina4 is "otheranusentrance" or $vagina4 is "otheranusimminent">>
<<if $consensual is 1 and $promiscuity lte 74 and $enemytype is "man" or $consensual is 1 and $deviancy lte 74 and $enemytype isnot "man">>
<<else>>
<<if $penisactiondefault is "penisanusfuck">>
| <label><span class="sub">Penetrate <<his>> ass</span> <<radiobutton "$penisaction" "penisanusfuck" checked>> <<combatpromiscuous5>><<penilevirginitywarning>></label>
<<else>>
| <label><span class="sub">Penetrate <<his>> ass</span> <<radiobutton "$penisaction" "penisanusfuck">> <<combatpromiscuous5>><<penilevirginitywarning>></label>
<</if>>
<</if>>
<<elseif $vagina5 is "otheranusentrance" or $vagina5 is "otheranusimminent">>
<<if $consensual is 1 and $promiscuity lte 74 and $enemytype is "man" or $consensual is 1 and $deviancy lte 74 and $enemytype isnot "man">>
<<else>>
<<if $penisactiondefault is "penisanusfuck">>
| <label><span class="sub">Penetrate <<his>> ass</span> <<radiobutton "$penisaction" "penisanusfuck" checked>> <<combatpromiscuous5>><<penilevirginitywarning>></label>
<<else>>
| <label><span class="sub">Penetrate <<his>> ass</span> <<radiobutton "$penisaction" "penisanusfuck">> <<combatpromiscuous5>><<penilevirginitywarning>></label>
<</if>>
<</if>>
<<elseif $vagina6 is "otheranusentrance" or $vagina6 is "otheranusimminent">>
<<if $consensual is 1 and $promiscuity lte 74 and $enemytype is "man" or $consensual is 1 and $deviancy lte 74 and $enemytype isnot "man">>
<<else>>
<<if $penisactiondefault is "penisanusfuck">>
| <label><span class="sub">Penetrate <<his>> ass</span> <<radiobutton "$penisaction" "penisanusfuck" checked>> <<combatpromiscuous5>><<penilevirginitywarning>></label>
<<else>>
| <label><span class="sub">Penetrate <<his>> ass</span> <<radiobutton "$penisaction" "penisanusfuck">> <<combatpromiscuous5>><<penilevirginitywarning>></label>
<</if>>
<</if>>
<<elseif $penis is "otheranusentrance" or $penis is "otheranusimminent">>
<<if $consensual is 1 and $promiscuity lte 74 and $enemytype is "man" or $consensual is 1 and $deviancy lte 74 and $enemytype isnot "man">>
<<else>>
<<if $penisactiondefault is "penisanusfuck">>
| <label><span class="sub">Penetrate <<his>> ass</span> <<radiobutton "$penisaction" "penisanusfuck" checked>> <<combatpromiscuous5>><<penilevirginitywarning>></label>
<<else>>
| <label><span class="sub">Penetrate <<his>> ass</span> <<radiobutton "$penisaction" "penisanusfuck">> <<combatpromiscuous5>><<penilevirginitywarning>></label>
<</if>>
<</if>>
<<elseif $penis2 is "otheranusentrance" or $penis2 is "otheranusimminent">>
<<if $consensual is 1 and $promiscuity lte 74 and $enemytype is "man" or $consensual is 1 and $deviancy lte 74 and $enemytype isnot "man">>
<<else>>
<<if $penisactiondefault is "penisanusfuck">>
| <label><span class="sub">Penetrate <<his>> ass</span> <<radiobutton "$penisaction" "penisanusfuck" checked>> <<combatpromiscuous5>><<penilevirginitywarning>></label>
<<else>>
| <label><span class="sub">Penetrate <<his>> ass</span> <<radiobutton "$penisaction" "penisanusfuck">> <<combatpromiscuous5>><<penilevirginitywarning>></label>
<</if>>
<</if>>
<<elseif $penis3 is "otheranusentrance" or $penis3 is "otheranusimminent">>
<<if $consensual is 1 and $promiscuity lte 74 and $enemytype is "man" or $consensual is 1 and $deviancy lte 74 and $enemytype isnot "man">>
<<else>>
<<if $penisactiondefault is "penisanusfuck">>
| <label><span class="sub">Penetrate <<his>> ass</span> <<radiobutton "$penisaction" "penisanusfuck" checked>> <<combatpromiscuous5>><<penilevirginitywarning>></label>
<<else>>
| <label><span class="sub">Penetrate <<his>> ass</span> <<radiobutton "$penisaction" "penisanusfuck">> <<combatpromiscuous5>><<penilevirginitywarning>></label>
<</if>>
<</if>>
<<elseif $penis4 is "otheranusentrance" or $penis4 is "otheranusimminent">>
<<if $consensual is 1 and $promiscuity lte 74 and $enemytype is "man" or $consensual is 1 and $deviancy lte 74 and $enemytype isnot "man">>
<<else>>
<<if $penisactiondefault is "penisanusfuck">>
| <label><span class="sub">Penetrate <<his>> ass</span> <<radiobutton "$penisaction" "penisanusfuck" checked>> <<combatpromiscuous5>><<penilevirginitywarning>></label>
<<else>>
| <label><span class="sub">Penetrate <<his>> ass</span> <<radiobutton "$penisaction" "penisanusfuck">> <<combatpromiscuous5>><<penilevirginitywarning>></label>
<</if>>
<</if>>
<<elseif $penis5 is "otheranusentrance" or $penis5 is "otheranusimminent">>
<<if $consensual is 1 and $promiscuity lte 74 and $enemytype is "man" or $consensual is 1 and $deviancy lte 74 and $enemytype isnot "man">>
<<else>>
<<if $penisactiondefault is "penisanusfuck">>
| <label><span class="sub">Penetrate <<his>> ass</span> <<radiobutton "$penisaction" "penisanusfuck" checked>> <<combatpromiscuous5>><<penilevirginitywarning>></label>
<<else>>
| <label><span class="sub">Penetrate <<his>> ass</span> <<radiobutton "$penisaction" "penisanusfuck">> <<combatpromiscuous5>><<penilevirginitywarning>></label>
<</if>>
<</if>>
<<elseif $penis6 is "otheranusentrance" or $penis6 is "otheranusimminent">>
<<if $consensual is 1 and $promiscuity lte 74 and $enemytype is "man" or $consensual is 1 and $deviancy lte 74 and $enemytype isnot "man">>
<<else>>
<<if $penisactiondefault is "penisanusfuck">>
| <label><span class="sub">Penetrate <<his>> ass</span> <<radiobutton "$penisaction" "penisanusfuck" checked>> <<combatpromiscuous5>><<penilevirginitywarning>></label>
<<else>>
| <label><span class="sub">Penetrate <<his>> ass</span> <<radiobutton "$penisaction" "penisanusfuck">> <<combatpromiscuous5>><<penilevirginitywarning>></label>
<</if>>
<</if>>
<</if>>
<</if>>
<</nobr>><</widget>>
:: Widgets Effects Penis [widget]
<<widget "effectspenistovagina">><<nobr>>
<<if $penisaction is "penistovagina">><<set $penisaction to 0>><<submission 10>><<penileskilluse>><<set $penisactiondefault to "penistovagina">><<combatpromiscuity5>>
<<if (1000 - ($rng * 10) - ($enemytrust * 10) - $penileskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<<if $vagina is 0>>
<<submission 2>><<set $penisuse to "vagina">><<set $vagina to "penisentrance">><<set $penisstate to "entrance">><span class="lblue">You press your <<penis>> against the <<person1>><<combatpersons>> pussy.</span>
<<elseif $vagina2 is 0>>
<<submission 2>><<set $penisuse to "vagina">><<set $vagina2 to "penisentrance">><<set $penisstate to "entrance">><span class="lblue">You press your <<penis>> against the <<person2>><<combatpersons>> pussy.</span>
<<elseif $vagina3 is 0>>
<<submission 2>><<set $penisuse to "vagina">><<set $vagina3 to "penisentrance">><<set $penisstate to "entrance">><span class="lblue">You press your <<penis>> against the <<person3>><<combatpersons>> pussy.</span>
<<elseif $vagina4 is 0>>
<<submission 2>><<set $penisuse to "vagina">><<set $vagina4 to "penisentrance">><<set $penisstate to "entrance">><span class="lblue">You press your <<penis>> against the <<person4>><<combatpersons>> pussy.</span>
<<elseif $vagina5 is 0>>
<<submission 2>><<set $penisuse to "vagina">><<set $vagina5 to "penisentrance">><<set $penisstate to "entrance">><span class="lblue">You press your <<penis>> against the <<person5>><<combatpersons>> pussy.</span>
<<elseif $vagina6 is 0>>
<<submission 2>><<set $penisuse to "vagina">><<set $vagina6 to "penisentrance">><<set $penisstate to "entrance">><span class="lblue">You press your <<penis>> against the <<person6>><<combatpersons>> pussy.</span>
<</if>>
<<else>>
<<if $vagina is 0>>
<span class="blue">You try to press your <<penis>> against the <<person1>><<combatpersons>> pussy but <<he>> pushes you away.</span>
<<elseif $vagina2 is 0>>
<span class="blue">You try to press your <<penis>> against the <<person2>><<combatpersons>> pussy but <<he>> pushes you away.</span>
<<elseif $vagina3 is 0>>
<span class="blue">You try to press your <<penis>> against the <<person3>><<combatpersons>> pussy but <<he>> pushes you away.</span>
<<elseif $vagina4 is 0>>
<span class="blue">You try to press your <<penis>> against the <<person4>><<combatpersons>> pussy but <<he>> pushes you away.</span>
<<elseif $vagina5 is 0>>
<span class="blue">You try to press your <<penis>> against the <<person5>><<combatpersons>> pussy but <<he>> pushes you away.</span>
<<elseif $vagina6 is 0>>
<span class="blue">You try to press your <<penis>> against the <<person6>><<combatpersons>> pussy but <<he>> pushes you away.</span>
<</if>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "effectspenistoanus">><<nobr>>
<<if $penisaction is "penistoanus">><<set $penisaction to 0>><<submission 10>><<penileskilluse>><<set $penisactiondefault to "penistoanus">><<combatpromiscuity5>>
<<if (1000 - ($rng * 10) - ($enemytrust * 10) - $penileskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<<if $vagina is 0>>
<<submission 2>><<set $penisuse to "otheranus">><<set $vagina to "otheranusentrance">><<set $penisstate to "otheranusentrance">><span class="lblue">You press your <<penis>> against the <<person1>><<combatpersons>> ass.</span>
<<elseif $vagina2 is 0>>
<<submission 2>><<set $penisuse to "otheranus">><<set $vagina2 to "otheranusentrance">><<set $penisstate to "otheranusentrance">><span class="lblue">You press your <<penis>> against the <<person2>><<combatpersons>> ass.</span>
<<elseif $vagina3 is 0>>
<<submission 2>><<set $penisuse to "otheranus">><<set $vagina3 to "otheranusentrance">><<set $penisstate to "otheranusentrance">><span class="lblue">You press your <<penis>> against the <<person3>><<combatpersons>> ass.</span>
<<elseif $vagina4 is 0>>
<<submission 2>><<set $penisuse to "otheranus">><<set $vagina4 to "otheranusentrance">><<set $penisstate to "otheranusentrance">><span class="lblue">You press your <<penis>> against the <<person4>><<combatpersons>> ass.</span>
<<elseif $vagina5 is 0>>
<<submission 2>><<set $penisuse to "otheranus">><<set $vagina5 to "otheranusentrance">><<set $penisstate to "otheranusentrance">><span class="lblue">You press your <<penis>> against the <<person5>><<combatpersons>> ass.</span>
<<elseif $vagina6 is 0>>
<<submission 2>><<set $penisuse to "otheranus">><<set $vagina6 to "otheranusentrance">><<set $penisstate to "otheranusentrance">><span class="lblue">You press your <<penis>> against the <<person6>><<combatpersons>> ass.</span>
<<elseif $penis is 0>>
<<submission 2>><<set $penisuse to "otheranus">><<set $penis to "otheranusentrance">><<set $penisstate to "otheranusentrance">><span class="lblue">You press your <<penis>> against the <<person1>><<combatpersons>> ass.</span>
<<elseif $penis2 is 0>>
<<submission 2>><<set $penisuse to "otheranus">><<set $penis2 to "otheranusentrance">><<set $penisstate to "otheranusentrance">><span class="lblue">You press your <<penis>> against the <<person2>><<combatpersons>> ass.</span>
<<elseif $penis3 is 0>>
<<submission 2>><<set $penisuse to "otheranus">><<set $penis3 to "otheranusentrance">><<set $penisstate to "otheranusentrance">><span class="lblue">You press your <<penis>> against the <<person3>><<combatpersons>> ass.</span>
<<elseif $penis4 is 0>>
<<submission 2>><<set $penisuse to "otheranus">><<set $penis4 to "otheranusentrance">><<set $penisstate to "otheranusentrance">><span class="lblue">You press your <<penis>> against the <<person4>><<combatpersons>> ass.</span>
<<elseif $penis5 is 0>>
<<submission 2>><<set $penisuse to "otheranus">><<set $penis5 to "otheranusentrance">><<set $penisstate to "otheranusentrance">><span class="lblue">You press your <<penis>> against the <<person5>><<combatpersons>> ass.</span>
<<elseif $penis6 is 0>>
<<submission 2>><<set $penisuse to "otheranus">><<set $penis6 to "otheranusentrance">><<set $penisstate to "otheranusentrance">><span class="lblue">You press your <<penis>> against the <<person6>><<combatpersons>> ass.</span>
<</if>>
<<else>>
<<if $vagina is 0>>
<span class="blue">You try to press your <<penis>> against the <<person1>><<combatpersons>> ass but <<he>> pushes you away.</span>
<<elseif $vagina2 is 0>>
<span class="blue">You try to press your <<penis>> against the <<person1>><<combatpersons>> ass but <<he>> pushes you away.</span>
<<elseif $vagina3 is 0>>
<span class="blue">You try to press your <<penis>> against the <<person1>><<combatpersons>> ass but <<he>> pushes you away.</span>
<<elseif $vagina4 is 0>>
<span class="blue">You try to press your <<penis>> against the <<person1>><<combatpersons>> ass but <<he>> pushes you away.</span>
<<elseif $vagina5 is 0>>
<span class="blue">You try to press your <<penis>> against the <<person1>><<combatpersons>> ass but <<he>> pushes you away.</span>
<<elseif $vagina6 is 0>>
<span class="blue">You try to press your <<penis>> against the <<person1>><<combatpersons>> ass but <<he>> pushes you away.</span>
<<elseif $penis is 0>>
<span class="blue">You try to press your <<penis>> against the <<person1>><<combatpersons>> ass but <<he>> pushes you away.</span>
<<elseif $penis2 is 0>>
<span class="blue">You try to press your <<penis>> against the <<person1>><<combatpersons>> ass but <<he>> pushes you away.</span>
<<elseif $penis3 is 0>>
<span class="blue">You try to press your <<penis>> against the <<person1>><<combatpersons>> ass but <<he>> pushes you away.</span>
<<elseif $penis4 is 0>>
<span class="blue">You try to press your <<penis>> against the <<person1>><<combatpersons>> ass but <<he>> pushes you away.</span>
<<elseif $penis5 is 0>>
<span class="blue">You try to press your <<penis>> against the <<person1>><<combatpersons>> ass but <<he>> pushes you away.</span>
<<elseif $penis6 is 0>>
<span class="blue">You try to press your <<penis>> against the <<person1>><<combatpersons>> ass but <<he>> pushes you away.</span>
<</if>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "effectspenisvaginafuck">><<nobr>>
<<if $penisaction is "penisvaginafuck">><<set $penisaction to 0>><<submission 20>><<penileskilluse>><<set $penisactiondefault to "penisvaginafuck">><<combatpromiscuity5>>
<<if $penilevirginity is 0>>
<<if $vagina is "penisentrance" or $vagina is "penisimminent">><<set $vagina to "penis">>
<span class="pink">You <<peniletext>> thrust deep into the <<person1>><<combatpersons>> pussy.</span>
<<elseif $vagina2 is "penisentrance" or $vagina2 is "penisimminent">><<set $vagina2 to "penis">>
<span class="pink">You <<peniletext>> thrust deep into the <<person2>><<combatpersons>> pussy.</span>
<<elseif $vagina3 is "penisentrance" or $vagina3 is "penisimminent">><<set $vagina3 to "penis">>
<span class="pink">You <<peniletext>> thrust deep into the <<person3>><<combatpersons>> pussy.</span>
<<elseif $vagina4 is "penisentrance" or $vagina4 is "penisimminent">><<set $vagina4 to "penis">>
<span class="pink">You <<peniletext>> thrust deep into the <<person4>><<combatpersons>> pussy.</span>
<<elseif $vagina5 is "penisentrance" or $vagina5 is "penisimminent">><<set $vagina5 to "penis">>
<span class="pink">You <<peniletext>> thrust deep into the <<person5>><<combatpersons>> pussy.</span>
<<elseif $vagina6 is "penisentrance" or $vagina6 is "penisimminent">><<set $vagina6 to "penis">>
<span class="pink">You <<peniletext>> thrust deep into the <<person6>><<combatpersons>> pussy.</span>
<</if>>
<<sex 30>><<penilestat>><<raped>><<penisraped>><<set $penisstate to "penetrated">><<set $speechpenispenetrated to 1>>
<<elseif $penilevirginity is 1>>
<<if $vagina is "penisentrance" or $vagina is "penisimminent">><<set $vagina to "penis">>
<span class="pink">You thrust your virgin penis into the <<person1>><<combatpersons>> pussy.</span><span class="red"> You feel your foreskin separate from your glans, forever robbing you of your purity.</span>
<<elseif $vagina2 is "penisentrance" or $vagina2 is "penisimminent">><<set $vagina2 to "penis">>
<span class="pink">You thrust your virgin penis into the <<person2>><<combatpersons>> pussy.</span><span class="red"> You feel your foreskin separate from your glans, forever robbing you of your purity.</span>
<<elseif $vagina3 is "penisentrance" or $vagina3 is "penisimminent">><<set $vagina3 to "penis">>
<span class="pink">You thrust your virgin penis into the <<person3>><<combatpersons>> pussy.</span><span class="red"> You feel your foreskin separate from your glans, forever robbing you of your purity.</span>
<<elseif $vagina4 is "penisentrance" or $vagina4 is "penisimminent">><<set $vagina4 to "penis">>
<span class="pink">You thrust your virgin penis into the <<person4>><<combatpersons>> pussy.</span><span class="red"> You feel your foreskin separate from your glans, forever robbing you of your purity.</span>
<<elseif $vagina5 is "penisentrance" or $vagina5 is "penisimminent">><<set $vagina5 to "penis">>
<span class="pink">You thrust your virgin penis into the <<person5>><<combatpersons>> pussy.</span><span class="red"> You feel your foreskin separate from your glans, forever robbing you of your purity.</span>
<<elseif $vagina6 is "penisentrance" or $vagina6 is "penisimminent">><<set $vagina6 to "penis">>
<span class="pink">You thrust your virgin penis into the <<person6>><<combatpersons>> pussy.</span><span class="red"> You feel your foreskin separate from your glans, forever robbing you of your purity.</span>
<</if>>
<<sex 100>><<set $penilevirginity to 0>><<bruise penis>><<penilestat>><<violence 30>><<raped>><<penisraped>><<set $penisstate to "penetrated">><<set $speechpenisvirgin to 1>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "effectspenisanusfuck">><<nobr>>
<<if $penisaction is "penisanusfuck">><<set $penisaction to 0>><<submission 20>><<penileskilluse>><<set $penisactiondefault to "penisanusfuck">><<combatpromiscuity5>>
<<if $penilevirginity is 0>>
<<if $vagina is "otheranusentrance" or $vagina is "otheranusimminent">><<set $vagina to "otheranus">>
<span class="pink">You <<peniletext>> thrust deep into the <<person1>><<combatpersons>> ass.</span>
<<elseif $vagina2 is "otheranusentrance" or $vagina2 is "otheranusimminent">><<set $vagina2 to "otheranus">>
<span class="pink">You <<peniletext>> thrust deep into the <<person2>><<combatpersons>> ass.</span>
<<elseif $vagina3 is "otheranusentrance" or $vagina3 is "otheranusimminent">><<set $vagina3 to "otheranus">>
<span class="pink">You <<peniletext>> thrust deep into the <<person3>><<combatpersons>> ass.</span>
<<elseif $vagina4 is "otheranusentrance" or $vagina4 is "otheranusimminent">><<set $vagina4 to "otheranus">>
<span class="pink">You <<peniletext>> thrust deep into the <<person4>><<combatpersons>> ass.</span>
<<elseif $vagina5 is "otheranusentrance" or $vagina5 is "otheranusimminent">><<set $vagina5 to "otheranus">>
<span class="pink">You <<peniletext>> thrust deep into the <<person5>><<combatpersons>> ass.</span>
<<elseif $vagina6 is "otheranusentrance" or $vagina6 is "otheranusimminent">><<set $vagina6 to "otheranus">>
<span class="pink">You <<peniletext>> thrust deep into the <<person6>><<combatpersons>> ass.</span>
<</if>>
<<if $penis is "otheranusentrance" or $penis is "otheranusimminent">><<set $penis to "otheranus">>
<span class="pink">You <<peniletext>> thrust deep into the <<person1>><<combatpersons>> ass.</span>
<<elseif $penis2 is "otheranusentrance" or $penis2 is "otheranusimminent">><<set $penis2 to "otheranus">>
<span class="pink">You <<peniletext>> thrust deep into the <<person2>><<combatpersons>> ass.</span>
<<elseif $penis3 is "otheranusentrance" or $penis3 is "otheranusimminent">><<set $penis3 to "otheranus">>
<span class="pink">You <<peniletext>> thrust deep into the <<person3>><<combatpersons>> ass.</span>
<<elseif $penis4 is "otheranusentrance" or $penis4 is "otheranusimminent">><<set $penis4 to "otheranus">>
<span class="pink">You <<peniletext>> thrust deep into the <<person4>><<combatpersons>> ass.</span>
<<elseif $penis5 is "otheranusentrance" or $penis5 is "otheranusimminent">><<set $penis5 to "otheranus">>
<span class="pink">You <<peniletext>> thrust deep into the <<person5>><<combatpersons>> ass.</span>
<<elseif $penis6 is "otheranusentrance" or $penis6 is "otheranusimminent">><<set $penis6 to "otheranus">>
<span class="pink">You <<peniletext>> thrust deep into the <<person6>><<combatpersons>> ass.</span>
<</if>>
<<sex 30>><<penilestat>><<raped>><<penisraped>><<set $penisstate to "otheranus">><<set $speechotheranus to 1>>
<<elseif $penilevirginity is 1>>
<<if $vagina is "otheranusentrance" or $vagina is "otheranusimminent">><<set $vagina to "otheranus">>
<span class="pink">You thrust your virgin penis into the <<person1>><<combatpersons>> ass.</span><span class="red"> You feel your foreskin separate from your glans, forever robbing you of your purity.</span>
<<elseif $vagina2 is "otheranusentrance" or $vagina2 is "otheranusimminent">><<set $vagina2 to "otheranus">>
<span class="pink">You thrust your virgin penis into the <<person2>><<combatpersons>> ass.</span><span class="red"> You feel your foreskin separate from your glans, forever robbing you of your purity.</span>
<<elseif $vagina3 is "otheranusentrance" or $vagina3 is "otheranusimminent">><<set $vagina3 to "otheranus">>
<span class="pink">You thrust your virgin penis into the <<person3>><<combatpersons>> ass.</span><span class="red"> You feel your foreskin separate from your glans, forever robbing you of your purity.</span>
<<elseif $vagina4 is "otheranusentrance" or $vagina4 is "otheranusimminent">><<set $vagina4 to "otheranus">>
<span class="pink">You thrust your virgin penis into the <<person4>><<combatpersons>> ass.</span><span class="red"> You feel your foreskin separate from your glans, forever robbing you of your purity.</span>
<<elseif $vagina5 is "otheranusentrance" or $vagina5 is "otheranusimminent">><<set $vagina5 to "otheranus">>
<span class="pink">You thrust your virgin penis into the <<person5>><<combatpersons>> ass.</span><span class="red"> You feel your foreskin separate from your glans, forever robbing you of your purity.</span>
<<elseif $vagina6 is "otheranusentrance" or $vagina6 is "otheranusimminent">><<set $vagina6 to "otheranus">>
<span class="pink">You thrust your virgin penis into the <<person6>><<combatpersons>> ass.</span><span class="red"> You feel your foreskin separate from your glans, forever robbing you of your purity.</span>
<</if>>
<<if $penis is "otheranusentrance" or $penis is "otheranusimminent">><<set $penis to "otheranus">>
<span class="pink">You thrust your virgin penis into the <<person1>><<combatpersons>> ass.</span><span class="red"> You feel your foreskin separate from your glans, forever robbing you of your purity.</span>
<<elseif $penis2 is "otheranusentrance" or $penis2 is "otheranusimminent">><<set $penis2 to "otheranus">>
<span class="pink">You thrust your virgin penis into the <<person2>><<combatpersons>> ass.</span><span class="red"> You feel your foreskin separate from your glans, forever robbing you of your purity.</span>
<<elseif $penis3 is "otheranusentrance" or $penis3 is "otheranusimminent">><<set $penis3 to "otheranus">>
<span class="pink">You thrust your virgin penis into the <<person3>><<combatpersons>> ass.</span><span class="red"> You feel your foreskin separate from your glans, forever robbing you of your purity.</span>
<<elseif $penis4 is "otheranusentrance" or $penis4 is "otheranusimminent">><<set $penis4 to "otheranus">>
<span class="pink">You thrust your virgin penis into the <<person4>><<combatpersons>> ass.</span><span class="red"> You feel your foreskin separate from your glans, forever robbing you of your purity.</span>
<<elseif $penis5 is "otheranusentrance" or $penis5 is "otheranusimminent">><<set $penis5 to "otheranus">>
<span class="pink">You thrust your virgin penis into the <<person5>><<combatpersons>> ass.</span><span class="red"> You feel your foreskin separate from your glans, forever robbing you of your purity.</span>
<<elseif $penis6 is "otheranusentrance" or $penis6 is "otheranusimminent">><<set $penis6 to "otheranus">>
<span class="pink">You thrust your virgin penis into the <<person6>><<combatpersons>> ass.</span><span class="red"> You feel your foreskin separate from your glans, forever robbing you of your purity.</span>
<</if>>
<<sex 100>><<set $penilevirginity to 0>><<bruise penis>><<penilestat>><<violence 30>><<raped>><<penisraped>><<set $penisstate to "otheranus">><<set $speechpenisvirgin to 1>>
<</if>>
<</if>>
<</nobr>><</widget>>
:: Widgets Effects Hands [widget]
<<widget "effectshandsclothes">><<nobr>>
<<if $leftaction is "upper" and $rightaction is "upper">><<set $leftaction to 0>><<set $leftactiondefault to "rest">><<set $rightaction to 0>><<set $rightactiondefault to "rest">>
<<if $upperclothes is "naked">>
You clutch the tattered remains of your $upperlast.
<<elseif $open is 1>><<set $upperexposed to 2>><<set $upperstatetop to "midriff">>
<<if $breastsize gte 3>>
You pull down your $upperclothes <span class="lewd">and your <<breasts>> flop out.</span>
<<else>>
You pull down your $upperclothes, <span class="lewd">exposing your <<breastsstop>></span>
<</if>>
<<else>><<set $upperexposed to 2>><<set $upperstate to "chest">>
<<if $breastsize gte 3>>
You pull up your $upperclothes <span class="lewd">and your <<breasts>> flop out.</span>
<<else>>
You pull up your $upperclothes, <span class="lewd">exposing your <<breastsstop>></span>
<</if>>
<</if>>
<<elseif $leftaction is "upper">><<set $leftaction to 0>><<set $leftactiondefault to "rest">>
<<if $upperclothes is "naked">>
You clutch the tattered remains of your $upperlast.
<<elseif $open is 1>><<set $upperexposed to 2>><<set $upperstatetop to "midriff">>
<<if $breastsize gte 3>>
You pull down your $upperclothes <span class="lewd">and your <<breasts>> flop out.</span>
<<else>>
You pull down your $upperclothes, <span class="lewd">exposing your <<breastsstop>></span>
<</if>>
<<else>><<set $upperexposed to 2>><<set $upperstate to "chest">>
<<if $breastsize gte 3>>
You pull up your $upperclothes <span class="lewd">and your <<breasts>> flop out.</span>
<<else>>
You pull up your $upperclothes, <span class="lewd">exposing your <<breastsstop>></span>
<</if>>
<</if>>
<<elseif $rightaction is "upper">><<set $rightaction to 0>><<set $rightactiondefault to "rest">>
<<if $upperclothes is "naked">>
You clutch the tattered remains of your $upperlast.
<<elseif $open is 1>><<set $upperexposed to 2>><<set $upperstatetop to "midriff">>
<<if $breastsize gte 3>>
You pull down your $upperclothes <span class="lewd">and your <<breasts>> flop out.</span>
<<else>>
You pull down your $upperclothes, <span class="lewd">exposing your <<breastsstop>></span>
<</if>>
<<else>><<set $upperexposed to 2>><<set $upperstate to "chest">>
<<if $breastsize gte 3>>
You pull up your $upperclothes <span class="lewd">and your <<breasts>> flop out.</span>
<<else>>
You pull up your $upperclothes, <span class="lewd">exposing your <<breastsstop>></span>
<</if>>
<</if>>
<</if>>
<<if $leftaction is "lower" and $rightaction is "lower">><<set $leftaction to 0>><<set $leftactiondefault to "rest">><<set $rightaction to 0>><<set $rightactiondefault to "rest">><<set $loweranusexposed to 1>><<set $lowervaginaexposed to 1>><<set $lowerexposed to 2>>
<<if $lowerclothes is "naked">>
You clutch the tattered remains of your $lowerlast.
<<elseif $skirt is 1>><<set $skirtdown to 0>>
You lift up your $lowerclothes, <span class="lewd">exposing your <<undiesstop>></span>
<<else>><<set $lowerstate to "thighs">>
You pull down your $lowerclothes, <span class="lewd">exposing your <<undiesstop>></span>
<</if>>
<<elseif $leftaction is "lower">><<set $leftaction to 0>><<set $leftactiondefault to "rest">><<set $loweranusexposed to 1>><<set $lowervaginaexposed to 1>><<set $lowerexposed to 2>>
<<if $lowerclothes is "naked">>
You clutch the tattered remains of your $lowerlast.
<<elseif $skirt is 1>><<set $skirtdown to 0>>
You lift up your $lowerclothes, <span class="lewd">exposing your <<undiesstop>></span>
<<else>><<set $lowerstate to "thighs">>
You pull down your $lowerclothes, <span class="lewd">exposing your <<undiesstop>></span>
<</if>>
<<elseif $rightaction is "lower">><<set $rightaction to 0>><<set $rightactiondefault to "rest">><<set $loweranusexposed to 1>><<set $lowervaginaexposed to 1>><<set $lowerexposed to 2>>
<<if $lowerclothes is "naked">>
You clutch the tattered remains of your $lowerlast.
<<elseif $skirt is 1>><<set $skirtdown to 0>>
You lift up your $lowerclothes, <span class="lewd">exposing your <<undiesstop>></span>
<<else>><<set $lowerstate to "thighs">>
You pull down your $lowerclothes, <span class="lewd">exposing your <<undiesstop>></span>
<</if>>
<</if>>
<<if $leftaction is "under" and $rightaction is "under">><<set $leftaction to 0>><<set $leftactiondefault to "rest">><<set $rightaction to 0>><<set $rightactiondefault to "rest">><<set $underanusexposed to 1>><<set $undervaginaexposed to 1>>
<<set $understate to "thighs">><<set $underexposed to 2>>
<<if $underclothes is "naked">>
You clutch the tattered remains of your $underlast.
<<else>>
You pull down your $underclothes, <span class="lewd">exposing your <<genitalsstop>></span>
<</if>>
<<elseif $leftaction is "under">><<set $leftaction to 0>><<set $leftactiondefault to "rest">><<set $underanusexposed to 1>><<set $undervaginaexposed to 1>><<set $underexposed to 2>>
<<set $understate to "thighs">>
<<if $underclothes is "naked">>
You clutch the tattered remains of your $underlast.
<<else>>
You pull down your $underclothes, <span class="lewd">exposing your <<genitalsstop>></span>
<</if>>
<<elseif $rightaction is "under">><<set $rightaction to 0>><<set $rightactiondefault to "rest">><<set $underanusexposed to 1>><<set $undervaginaexposed to 1>><<set $underexposed to 2>>
<<set $understate to "thighs">>
<<if $underclothes is "naked">>
You clutch the tattered remains of your $underlast.
<<else>>
You pull down your $underclothes, <span class="lewd">exposing your <<genitalsstop>></span>
<</if>>
<</if>>
<</nobr>><</widget>>
:: DP Test [nobr]
<<if $molestationstart is 1>>
<<set $molestationstart to 0>>
<<controlloss>>
<<violence 1>>
<<neutral 1>>
<<molested>>
<<set $event to "molestationhome">>
<<generate1>><<generate2>><<man1init>>
<<set $penis to "vagina">><<set $vaginause to "penis">><<set $vaginastate to "penetrated">>
<<set $penis2 to "anus">><<set $anususe to "penis">><<set $anusstate to "penetrated">>
<</if>>
<<effects>>
<<effectsman>><<man>>
<<stateman>><br>
<br>
<<actionsman>>
<<if $alarm is 1>>
<<if $rescue is 1>>
<span id="next"><<link [[Next->DP Test]]>><</link>></span><<nexttext>>
<<else>>
No one comes to your aid.<<set $alarm to 0>>
<<if $drugged is 1>>Intoxicated as you are, you couldn't cry very convincingly.<</if>><br><br>
<<if $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next->Molestation Ejaculation]]>><</link>></span><<nexttext>>
<<elseif $enemyhealth lte 0>>
<span id="next"><<link [[Next->Molestation Escape]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next->DP Test]]>><</link>></span><<nexttext>>
<</if>>
<</if>>
<<elseif $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next->Molestation Ejaculation]]>><</link>></span><<nexttext>>
<<elseif $enemyhealth lte 0>>
<span id="next"><<link [[Next->Molestation Escape]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next->DP Test]]>><</link>></span><<nexttext>>
<</if>>
:: Widgets Close Img [widget]
<<widget "closeimg">><<nobr>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<<if $vaginaexist is 1 and $undervaginaexposed is 1 and $lowervaginaexposed is 1>>
<<if $vaginastate is "tentacle">>
<img id="closevagina" src="img/sex/close/vaginatentaclepenetratedvfast.gif">
<<elseif $vaginastate is "tentacledeep">>
<img id="closevagina" src="img/sex/close/vaginatentaclepenetratedvfast.gif">
<<elseif $vaginastate is "tentacleentrance">>
<img id="closevagina" src="img/sex/close/vaginatentacleentrancevfast.gif">
<<elseif $vaginastate is "tentacleimminent">>
<img id="closevagina" src="img/sex/close/vaginatentacleentrancevfast.gif">
<<elseif $vaginastate is "penetrated">>
<<if $enemytype is "beast">>
<img id="closevagina" src="img/sex/close/vaginapenetratedbeastvfast.gif">
<<else>>
<img id="closevagina" src="img/sex/close/vaginapenetratedvfast.gif">
<</if>>
<<elseif $vaginastate is "entrance">>
<<if $enemytype is "beast">>
<img id="closevagina" src="img/sex/close/vaginaentrancebeastvfast.gif">
<<else>>
<img id="closevagina" src="img/sex/close/vaginaentrancevfast.gif">
<</if>>
<<elseif $vaginastate is "imminent">>
<<if $enemytype is "beast">>
<img id="closevagina" src="img/sex/close/vaginaentrancebeastvfast.gif">
<<else>>
<img id="closevagina" src="img/sex/close/vaginaentrancevfast.gif">
<</if>>
<<else>>
<img id="closevagina" src="img/sex/close/vagina.gif">
<<if $vaginasemen + $vaginagoo gte 1>>
<img id="closevagina" src="img/sex/close/vaginacum.gif">
<</if>>
<</if>>
<</if>>
<<if $underanusexposed is 1 and $loweranusexposed is 1>>
<<if $anusstate is "tentacle">>
<img id="closeanus" src="img/sex/close/anustentaclepenetratedvfast.gif">
<<elseif $anusstate is "tentacledeep">>
<img id="closeanus" src="img/sex/close/anustentaclepenetratedvfast.gif">
<<elseif $anusstate is "tentacleentrance">>
<img id="closeanus" src="img/sex/close/anustentacleentrancevfast.gif">
<<elseif $anusstate is "tentacleimminent">>
<img id="closeanus" src="img/sex/close/anustentacleentrancevfast.gif">
<<elseif $anusstate is "penetrated">>
<img id="closeanus" src="img/sex/close/anuspenetratedvfast.gif">
<<elseif $anusstate is "entrance">>
<img id="closeanus" src="img/sex/close/anusentrancevfast.gif">
<<elseif $anusstate is "imminent">>
<img id="closeanus" src="img/sex/close/anusentrancevfast.gif">
<<else>>
<img id="closeanus" src="img/sex/close/anus.gif">
<</if>>
<</if>>
<<if $penisexist is 1 and $undervaginaexposed is 1 and $lowervaginaexposed is 1>>
<<if $penisstate is "tentacle">>
<img id="closepenis" src="img/sex/close/penistentaclepenetratedvfast.gif">
<<elseif $penisstate is "tentacledeep">>
<img id="closepenis" src="img/sex/close/penistentaclepenetratedvfast.gif">
<<elseif $penisstate is "tentacleentrance">>
<img id="closepenis" src="img/sex/close/penistentacleentrancevfast.gif">
<<elseif $penisstate is "tentacleimminent">>
<img id="closepenis" src="img/sex/close/penistentacleentrancevfast.gif">
<<elseif $penisstate is "penetrated">>
<img id="closepenis" src="img/sex/close/penispenetratedvfast.gif">
<<elseif $penisstate is "otheranus">>
<img id="closepenis" src="img/sex/close/penispenetratedvfast.gif">
<<elseif $penisstate is "imminent">>
<img id="closepenis" src="img/sex/close/penisentrancevfast.gif">
<<elseif $penisstate is "entrance">>
<img id="closepenis" src="img/sex/close/penisentrancevfast.gif">
<<elseif $penisstate is "otheranusimminent">>
<img id="closepenis" src="img/sex/close/penisentrancevfast.gif">
<<elseif $penisstate is "otheranusentrance">>
<img id="closepenis" src="img/sex/close/penisentrancevfast.gif">
<<else>>
<img id="closepenis" src="img/sex/close/penis.gif">
<</if>>
<</if>>
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 3>>
<<if $vaginaexist is 1 and $undervaginaexposed is 1 and $lowervaginaexposed is 1>>
<<if $vaginastate is "tentacle">>
<img id="closevagina" src="img/sex/close/vaginatentaclepenetratedfast.gif">
<<elseif $vaginastate is "tentacledeep">>
<img id="closevagina" src="img/sex/close/vaginatentaclepenetratedfast.gif">
<<elseif $vaginastate is "tentacleentrance">>
<img id="closevagina" src="img/sex/close/vaginatentacleentrancefast.gif">
<<elseif $vaginastate is "tentacleimminent">>
<img id="closevagina" src="img/sex/close/vaginatentacleentrancefast.gif">
<<elseif $vaginastate is "penetrated">>
<<if $enemytype is "beast">>
<img id="closevagina" src="img/sex/close/vaginapenetratedbeastfast.gif">
<<else>>
<img id="closevagina" src="img/sex/close/vaginapenetratedfast.gif">
<</if>>
<<elseif $vaginastate is "entrance">>
<<if $enemytype is "beast">>
<img id="closevagina" src="img/sex/close/vaginaentrancebeastfast.gif">
<<else>>
<img id="closevagina" src="img/sex/close/vaginaentrancefast.gif">
<</if>>
<<elseif $vaginastate is "imminent">>
<<if $enemytype is "beast">>
<img id="closevagina" src="img/sex/close/vaginaentrancebeastfast.gif">
<<else>>
<img id="closevagina" src="img/sex/close/vaginaentrancefast.gif">
<</if>>
<<else>>
<img id="closevagina" src="img/sex/close/vagina.gif">
<<if $vaginasemen + $vaginagoo gte 1>>
<img id="closevagina" src="img/sex/close/vaginacum.gif">
<</if>>
<</if>>
<</if>>
<<if $underanusexposed is 1 and $loweranusexposed is 1>>
<<if $anusstate is "tentacle">>
<img id="closeanus" src="img/sex/close/anustentaclepenetratedfast.gif">
<<elseif $anusstate is "tentacledeep">>
<img id="closeanus" src="img/sex/close/anustentaclepenetratedfast.gif">
<<elseif $anusstate is "tentacleentrance">>
<img id="closeanus" src="img/sex/close/anustentacleentrancefast.gif">
<<elseif $anusstate is "tentacleimminent">>
<img id="closeanus" src="img/sex/close/anustentacleentrancefast.gif">
<<elseif $anusstate is "penetrated">>
<img id="closeanus" src="img/sex/close/anuspenetratedfast.gif">
<<elseif $anusstate is "entrance">>
<img id="closeanus" src="img/sex/close/anusentrancefast.gif">
<<elseif $anusstate is "imminent">>
<img id="closeanus" src="img/sex/close/anusentrancefast.gif">
<<else>>
<img id="closeanus" src="img/sex/close/anus.gif">
<</if>>
<</if>>
<<if $penisexist is 1 and $undervaginaexposed is 1 and $lowervaginaexposed is 1>>
<<if $penisstate is "tentacle">>
<img id="closepenis" src="img/sex/close/penistentaclepenetratedfast.gif">
<<elseif $penisstate is "tentacledeep">>
<img id="closepenis" src="img/sex/close/penistentaclepenetratedfast.gif">
<<elseif $penisstate is "tentacleentrance">>
<img id="closepenis" src="img/sex/close/penistentacleentrancefast.gif">
<<elseif $penisstate is "tentacleimminent">>
<img id="closepenis" src="img/sex/close/penistentacleentrancefast.gif">
<<elseif $penisstate is "penetrated">>
<img id="closepenis" src="img/sex/close/penispenetratedfast.gif">
<<elseif $penisstate is "otheranus">>
<img id="closepenis" src="img/sex/close/penispenetratedfast.gif">
<<elseif $penisstate is "imminent">>
<img id="closepenis" src="img/sex/close/penisentrancefast.gif">
<<elseif $penisstate is "entrance">>
<img id="closepenis" src="img/sex/close/penisentrancefast.gif">
<<elseif $penisstate is "otheranusimminent">>
<img id="closepenis" src="img/sex/close/penisentrancefast.gif">
<<elseif $penisstate is "otheranusentrance">>
<img id="closepenis" src="img/sex/close/penisentrancefast.gif">
<<else>>
<img id="closepenis" src="img/sex/close/penis.gif">
<</if>>
<</if>>
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<<if $vaginaexist is 1 and $undervaginaexposed is 1 and $lowervaginaexposed is 1>>
<<if $vaginastate is "tentacle">>
<img id="closevagina" src="img/sex/close/vaginatentaclepenetratedmid.gif">
<<elseif $vaginastate is "tentacledeep">>
<img id="closevagina" src="img/sex/close/vaginatentaclepenetratedmid.gif">
<<elseif $vaginastate is "tentacleentrance">>
<img id="closevagina" src="img/sex/close/vaginatentacleentrancemid.gif">
<<elseif $vaginastate is "tentacleimminent">>
<img id="closevagina" src="img/sex/close/vaginatentacleentrancemid.gif">
<<elseif $vaginastate is "penetrated">>
<<if $enemytype is "beast">>
<img id="closevagina" src="img/sex/close/vaginapenetratedbeastmid.gif">
<<else>>
<img id="closevagina" src="img/sex/close/vaginapenetratedmid.gif">
<</if>>
<<elseif $vaginastate is "entrance">>
<<if $enemytype is "beast">>
<img id="closevagina" src="img/sex/close/vaginaentrancebeastmid.gif">
<<else>>
<img id="closevagina" src="img/sex/close/vaginaentrancemid.gif">
<</if>>
<<elseif $vaginastate is "imminent">>
<<if $enemytype is "beast">>
<img id="closevagina" src="img/sex/close/vaginaentrancebeastmid.gif">
<<else>>
<img id="closevagina" src="img/sex/close/vaginaentrancemid.gif">
<</if>>
<<else>>
<img id="closevagina" src="img/sex/close/vagina.gif">
<<if $vaginasemen + $vaginagoo gte 1>>
<img id="closevagina" src="img/sex/close/vaginacum.gif">
<</if>>
<</if>>
<</if>>
<<if $underanusexposed is 1 and $loweranusexposed is 1>>
<<if $anusstate is "tentacle">>
<img id="closeanus" src="img/sex/close/anustentaclepenetratedmid.gif">
<<elseif $anusstate is "tentacledeep">>
<img id="closeanus" src="img/sex/close/anustentaclepenetratedmid.gif">
<<elseif $anusstate is "tentacleentrance">>
<img id="closeanus" src="img/sex/close/anustentacleentrancemid.gif">
<<elseif $anusstate is "tentacleimminent">>
<img id="closeanus" src="img/sex/close/anustentacleentrancemid.gif">
<<elseif $anusstate is "penetrated">>
<img id="closeanus" src="img/sex/close/anuspenetratedmid.gif">
<<elseif $anusstate is "entrance">>
<img id="closeanus" src="img/sex/close/anusentrancemid.gif">
<<elseif $anusstate is "imminent">>
<img id="closeanus" src="img/sex/close/anusentrancemid.gif">
<<else>>
<img id="closeanus" src="img/sex/close/anus.gif">
<</if>>
<</if>>
<<if $penisexist is 1 and $undervaginaexposed is 1 and $lowervaginaexposed is 1>>
<<if $penisstate is "tentacle">>
<img id="closepenis" src="img/sex/close/penistentaclepenetratedmid.gif">
<<elseif $penisstate is "tentacledeep">>
<img id="closepenis" src="img/sex/close/penistentaclepenetratedmid.gif">
<<elseif $penisstate is "tentacleentrance">>
<img id="closepenis" src="img/sex/close/penistentacleentrancemid.gif">
<<elseif $penisstate is "tentacleimminent">>
<img id="closepenis" src="img/sex/close/penistentacleentrancemid.gif">
<<elseif $penisstate is "penetrated">>
<img id="closepenis" src="img/sex/close/penispenetratedmid.gif">
<<elseif $penisstate is "otheranus">>
<img id="closepenis" src="img/sex/close/penispenetratedmid.gif">
<<elseif $penisstate is "imminent">>
<img id="closepenis" src="img/sex/close/penisentrancemid.gif">
<<elseif $penisstate is "entrance">>
<img id="closepenis" src="img/sex/close/penisentrancemid.gif">
<<elseif $penisstate is "otheranusimminent">>
<img id="closepenis" src="img/sex/close/penisentrancemid.gif">
<<elseif $penisstate is "otheranusentrance">>
<img id="closepenis" src="img/sex/close/penisentrancemid.gif">
<<else>>
<img id="closepenis" src="img/sex/close/penis.gif">
<</if>>
<</if>>
<<else>>
<<if $vaginaexist is 1 and $undervaginaexposed is 1 and $lowervaginaexposed is 1>>
<<if $vaginastate is "tentacle">>
<img id="closevagina" src="img/sex/close/vaginatentaclepenetratedslow.gif">
<<elseif $vaginastate is "tentacledeep">>
<img id="closevagina" src="img/sex/close/vaginatentaclepenetratedslow.gif">
<<elseif $vaginastate is "tentacleentrance">>
<img id="closevagina" src="img/sex/close/vaginatentacleentranceslow.gif">
<<elseif $vaginastate is "tentacleimminent">>
<img id="closevagina" src="img/sex/close/vaginatentacleentranceslow.gif">
<<elseif $vaginastate is "penetrated">>
<<if $enemytype is "beast">>
<img id="closevagina" src="img/sex/close/vaginapenetratedbeastslow.gif">
<<else>>
<img id="closevagina" src="img/sex/close/vaginapenetratedslow.gif">
<</if>>
<<elseif $vaginastate is "entrance">>
<<if $enemytype is "beast">>
<img id="closevagina" src="img/sex/close/vaginaentrancebeastslow.gif">
<<else>>
<img id="closevagina" src="img/sex/close/vaginaentranceslow.gif">
<</if>>
<<elseif $vaginastate is "imminent">>
<<if $enemytype is "beast">>
<img id="closevagina" src="img/sex/close/vaginaentrancebeastslow.gif">
<<else>>
<img id="closevagina" src="img/sex/close/vaginaentranceslow.gif">
<</if>>
<<else>>
<img id="closevagina" src="img/sex/close/vagina.gif">
<<if $vaginasemen + $vaginagoo gte 1>>
<img id="closevagina" src="img/sex/close/vaginacum.gif">
<</if>>
<</if>>
<</if>>
<<if $underanusexposed is 1 and $loweranusexposed is 1>>
<<if $anusstate is "tentacle">>
<img id="closeanus" src="img/sex/close/anustentaclepenetratedslow.gif">
<<elseif $anusstate is "tentacledeep">>
<img id="closeanus" src="img/sex/close/anustentaclepenetratedslow.gif">
<<elseif $anusstate is "tentacleentrance">>
<img id="closeanus" src="img/sex/close/anustentacleentranceslow.gif">
<<elseif $anusstate is "tentacleimminent">>
<img id="closeanus" src="img/sex/close/anustentacleentranceslow.gif">
<<elseif $anusstate is "penetrated">>
<img id="closeanus" src="img/sex/close/anuspenetratedslow.gif">
<<elseif $anusstate is "entrance">>
<img id="closeanus" src="img/sex/close/anusentranceslow.gif">
<<elseif $anusstate is "imminent">>
<img id="closeanus" src="img/sex/close/anusentranceslow.gif">
<<else>>
<img id="closeanus" src="img/sex/close/anus.gif">
<</if>>
<</if>>
<<if $penisexist is 1 and $undervaginaexposed is 1 and $lowervaginaexposed is 1>>
<<if $penisstate is "tentacle">>
<img id="closepenis" src="img/sex/close/penistentaclepenetratedslow.gif">
<<elseif $penisstate is "tentacledeep">>
<img id="closepenis" src="img/sex/close/penistentaclepenetratedslow.gif">
<<elseif $penisstate is "tentacleentrance">>
<img id="closepenis" src="img/sex/close/penistentacleentranceslow.gif">
<<elseif $penisstate is "tentacleimminent">>
<img id="closepenis" src="img/sex/close/penistentacleentranceslow.gif">
<<elseif $penisstate is "penetrated">>
<img id="closepenis" src="img/sex/close/penispenetratedslow.gif">
<<elseif $penisstate is "otheranus">>
<img id="closepenis" src="img/sex/close/penispenetratedslow.gif">
<<elseif $penisstate is "imminent">>
<img id="closepenis" src="img/sex/close/penisentranceslow.gif">
<<elseif $penisstate is "entrance">>
<img id="closepenis" src="img/sex/close/penisentranceslow.gif">
<<elseif $penisstate is "otheranusimminent">>
<img id="closepenis" src="img/sex/close/penisentranceslow.gif">
<<elseif $penisstate is "otheranusentrance">>
<img id="closepenis" src="img/sex/close/penisentranceslow.gif">
<<else>>
<img id="closepenis" src="img/sex/close/penis.gif">
<</if>>
<</if>>
<</if>>
<</nobr>><</widget>>
:: Widgets Consensual Man [widget]
<<widget "consensualman">><<nobr>>
<</nobr>><</widget>>
:: Widgets Consensual Actions [widget]
<<widget "consensualman">><<nobr>>
<</nobr>><</widget>>
:: Widgets Consensual Effects [widget]
<<widget "consensualman">><<nobr>>
<</nobr>><</widget>>
|
QuiltedQuail/degrees
|
game/base-combat.twee
|
twee
|
unknown
| 2,385,005 |
:: StorySettings
ifid:a6afb52d-38f2-4cb5-86a8-54bf665670d6
:: StoryTitle
Degrees of Lewdity
:: Start [nobr]
<<effects>>
This work of fiction contains content of a sexual nature and is inappropriate for minors. All characters <span class="hide">[[de->Start][$debug to 1]]</span>picted are at least 18 years of age. Everything is consensual role play, and any animals are actually people in costumes.<br><br>
Save files are stored in your browser's cache. Save to disk to avoid losing them.<br><br>
<<initsettings>>
<<settings>><br><br>
[[Begin->Start2]]
:: PassageHeader
<<set $passage to passage()>><<set $tags to tags()>>
:: Start2 [nobr]
<<effects>>
<<initnpcgender>>
<<set $physiqueage to (1000 * $devlevel)>>
<<set $physique to ($physiqueage / 7) * 3>>
<<set $beauty to ($beautymax / 7)>>
<<if $devlevel gte 12>>
<<set $devstate to 1>>
<<else>>
<<set $devstate to 0>>
<</if>>
<<if $dev is 0>>
<<set $devstate to 1>>
<</if>>
<<if $playergender is "f">>
<<if $devlevel lte 11>>
<<set $breastsize to 0>><<set $breastcup to "none">><<set $breastsizeold to 0>><<set $breastgrowthtimer to 350>>
<<elseif $devlevel lte 13>>
<<set $breastsize to 1>><<set $breastcup to "budding">><<set $breastsizeold to 1>><<set $breastgrowthtimer to 350>>
<<elseif $devlevel lte 15>>
<<set $breastsize to 2>><<set $breastcup to "AA">><<set $breastsizeold to 2>><<set $breastgrowthtimer to 350>>
<<else>>
<<set $breastsize to 3>><<set $breastcup to "B">><<set $breastsizeold to 3>><<set $breastgrowthtimer to 350>>
<</if>>
<</if>>
<<if $playergender is "m">>
<<set $breastsize to 0>><<set $breastcup to "none">><<set $breastsizeold to 0>><<set $breastgrowthtimer to 350>>
<</if>>
<<givestartclothing>>
<<set $intro to 0>>
<<if $hairselect is "black">>
<<set $haircolour to "black">>
<<elseif $hairselect is "brown">>
<<set $haircolour to "brown">>
<<elseif $hairselect is "ginger">>
<<set $haircolour to "ginger">>
<<elseif $hairselect is "blond">>
<<set $haircolour to "blond">>
<<else>>
<<set $haircolour to "red">>
<</if>>
<<set $naturalhaircolour to $haircolour>>
<<if $eyeselect is "dark blue">>
<<set $eyecolour to "dark blue">>
<<elseif $eyeselect is "light blue">>
<<set $eyecolour to "light blue">>
<<elseif $eyeselect is "amber">>
<<set $eyecolour to "amber">>
<<elseif $eyeselect is "hazel">>
<<set $eyecolour to "hazel">>
<<elseif $eyeselect is "green">>
<<set $eyecolour to "green">>
<<else>>
<<set $eyecolour to "purple">>
<</if>>
<<if $awareselect is "innocent">>
<<elseif $awareselect is "knowledgeable">>
<<set $awareness += 200>>
<<set $awarelevel to 1>>
<</if>>
<<set $playergenderappearance to $playergender>>
<<if $playergender is "f">>
<<set $vaginause to 0>>
<<set $vaginastate to 0>>
<<set $vaginaexist to 1>>
<<set $penisuse to "none">>
<<set $penisstate to "none">>
<<set $penisexist to 0>>
<<elseif $playergender is "m">>
<<set $vaginause to "none">>
<<set $vaginastate to "none">>
<<set $vaginaexist to 0>>
<<set $penisuse to 0>>
<<set $penisstate to 0>>
<<set $penisexist to 1>>
<</if>>
<<if $background is "nerd">>
<<set $science += 200>><<set $maths += 200>><<set $english += 200>><<set $history += 200>><<set $school += 800>><<set $cool to 0>>
<<elseif $background is "athlete">>
<<set $physique += ($physiqueage / 4)>><<set $swimmingskill += 200>><<set $science to 100>><<set $maths to 100>><<set $english to 100>><<set $history to 100>><<set $school to 400>>
<<elseif $background is "delinquent">>
<<set $delinquency += 401>><<set $cool += 200>>
<<elseif $background is "promiscuous">>
<<set $promiscuity += 35>>
<<elseif $background is "exhibitionist">>
<<set $exhibitionism += 35>>
<<elseif $background is "deviant">>
<<set $deviancy += 35>>
<<elseif $background is "beautiful">>
<<set $beauty += ($beautymax / 2)>>
<</if>>
Welcome to Degrees of Lewdity!<br><br>
If you want to avoid trouble, dress modestly and stick to safe, well-lit areas. Nights are particularly dangerous. Dressing lewd will attract attention, both good and bad.<br><br>
The new school year starts tomorrow at 9:00. The bus service is the easiest way to get around town. Don't forget your uniform!<br><br>
<span id="next"><<link [[Next|Orphanage Intro]]>><</link>></span>
<br><br>
<<if $debug is 1>>
<<link [[School Start|Oxford Street]]>><<pass 1 day>><</link>>
<br>
<<link [[Science Start|Oxford Street]]>><<pass 1 day>><<pass 2 hours>><</link>>
<br>
<<link [[Maths Start|Oxford Street]]>><<pass 1 day>><<pass 3 hours>><</link>>
<br>
<<link [[English Start|Oxford Street]]>><<pass 1 day>><<pass 4 hours>><</link>>
<br>
<<link [[History Start|Oxford Street]]>><<pass 1 day>><<pass 6 hours>><</link>>
<br>
<<link [[Swimming Start|Oxford Street]]>><<pass 1 day>><<pass 7 hours>><</link>>
<br>
<<link [[Testing Room]]>><<uppernaked>><<lowernaked>><<undernaked>><</link>><br>
<<link [[Robin Low Trauma Low Love|Robin's Room Entrance]]>><<robin>><<endevent>><<set $robinlove to 0>><<set $robinintro to 1>><<set $trauma to ($traumamax / 7) * 2>><<trauma 60>><</link>><br>
<<link [[Robin Low Trauma Medium Love|Robin's Room Entrance]]>><<robin>><<endevent>><<set $robinlove to 50>><<set $robinintro to 1>><<set $trauma to ($traumamax / 7) * 2>><<trauma 60>><</link>><br>
<<link [[Robin Low Trauma High Love|Robin's Room Entrance]]>><<robin>><<endevent>><<set $robinlove to 90>><<set $robinintro to 1>><<set $trauma to ($traumamax / 7) * 2>><<trauma 60>><</link>><br>
<<link [[Robin High Trauma Low Love|Robin's Room Entrance]]>><<robin>><<endevent>><<set $robinlove to 0>><<set $robinintro to 1>><<set $trauma to ($traumamax / 7) * 4>><<trauma 60>><</link>><br>
<<link [[Robin High Trauma Medium Love|Robin's Room Entrance]]>><<robin>><<endevent>><<set $robinlove to 50>><<set $robinintro to 1>><<set $trauma to ($traumamax / 7) * 4>><<trauma 60>><</link>><br>
<<link [[Robin High Trauma High Love|Robin's Room Entrance]]>><<robin>><<endevent>><<set $robinlove to 90>><<set $robinintro to 1>><<set $trauma to ($traumamax / 7) * 4>><<trauma 60>><</link>><br>
<<link [[Robin After Paying Police With Money|Robin's Room Entrance]]>><<robin>><<endevent>><<set $robinpolicepay to 1>><<set $robinintro to 1>><<set $trauma to ($traumamax / 7) * 4>><<trauma 60>><</link>><br>
<<link [[Robin After Paying Police With Body|Robin's Room Entrance]]>><<robin>><<endevent>><<set $robinpolicebody to 1>><<set $robinintro to 1>><<set $trauma to ($traumamax / 7) * 4>><<trauma 60>><</link>><br>
<<link [[Robin's Debt Paid|Robin's Room Entrance]]>><<robin>><<endevent>><<set $robinpaid to 1>><<set $robinintro to 1>><<set $trauma to ($traumamax / 7) * 4>><<trauma 60>><</link>><br>
<</if>>
:: Cheats [nobr]
<<set $menu to 1>>
<<link [[Save|previous()]]>><</link>><br>
<<back>><br><br>
Can cause problems if used during events, or with NPCs around. Use with care.<br><br>
:: Characteristics [nobr]
<<back>><br><br><<set $menu to 1>>
It is the $monthday<<monthday>> of <<month>> $year.
It has been $days days since the game started.<br>
<<schoolterm>>
<br><br>
You are
<<if $wolfgirl gte 6>>
a wolf
<<elseif $angel gte 6>>
an angel
<<elseif $fallenangel gte 2>>
a fallen angel
<<elseif $demon gte 6>>
a demon
<<else>>
a
<</if>>
<<genderstop>><br><br>
You have $eyecolour eyes. <<if $breastsize gte 1>>You have <<breastsstop>><</if>>
<<if $hairlength gte 0 and $hairlength lt 100>>Your $haircolour hair is short.
<<elseif $hairlength gte 100 and $hairlength lt 200>>Your $haircolour hair passes your chin.
<<elseif $hairlength gte 200 and $hairlength lt 300>>Your $haircolour hair comes down to your shoulders.
<<elseif $hairlength gte 300 and $hairlength lt 400>>Your $haircolour hair is quite long, and comes down to the top of your chest.
<<elseif $hairlength gte 400 and $hairlength lt 500>>Your long $haircolour hair hangs down to your nipples.
<<elseif $hairlength gte 500 and $hairlength lt 600>>Your long $haircolour hair reaches the top of your tummy.
<<elseif $hairlength gte 600 and $hairlength lt 700>>Your long $haircolour hair reaches your navel.
<<elseif $hairlength gte 700 and $hairlength lt 800>>Your very long $haircolour hair reaches your thighs.
<<elseif $hairlength gte 800 and $hairlength lt 900>>Your very long $haircolour hair reaches your knees.
<<elseif $hairlength gte 900 and $hairlength lte 999>>Your extremely long $haircolour hair reaches your ankles.
<<elseif $hairlength gte 1000>>Your $haircolour hair is so long you need be careful lest you trip on it!<</if>>
<br><br>
Awareness: <<if $awareness lte 0>><span class="green">You are entirely innocent.</span><br>
<<elseif $awareness gte 1 and $awareness lt 100>><span class="teal">You are almost entirely innocent.</span>
<div class="meter">
<<set $percent=Math.floor(($awareness / 100)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $awareness gte 100 and $awareness lt 200>><span class="lblue">You have a limited understanding of sexuality.</span>
<div class="meter">
<<set $percent=Math.floor((($awareness - 100) / 100)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $awareness gte 200 and $awareness lt 300>><span class="blue">You have a normal understanding of sexuality.</span>
<div class="meter">
<<set $percent=Math.floor((($awareness - 200) / 100)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $awareness gte 300 and $awareness lt 400>><span class="purple">Your knowledge of sexual depravity extends beyond that of most people.</span>
<div class="meter">
<<set $percent=Math.floor((($awareness - 300) / 100)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $awareness gte 400 and $awareness lt 500>><span class="pink">You have seen things that few are privy to.</span>
<div class="meter">
<<set $percent=Math.floor((($awareness - 400) / 100)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $awareness gte 500 and $awareness lte 999>><span class="red">You have peered into the depths of depravity.</span>
<div class="meter">
<<set $percent=Math.floor((($awareness - 500) / 499)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $awareness gte 1000>><span class="red">Your understanding is transcendental.</span><br><</if>>
Purity: <<if $purity gte 1000>><span class="green">You are angelic.</span><br>
<<elseif $purity lte 999 and $purity gt 900>><span class="teal">You don't feel entirely pure.</span>
<div class="meter">
<<set $percent=Math.floor((($purity - 900) / 100)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $purity lte 900 and $purity gt 800>><span class="lblue">You feel slightly soiled.</span>
<div class="meter">
<<set $percent=Math.floor((($purity - 800) / 100)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $purity lte 800 and $purity gt 700>><span class="blue">You feel soiled.</span>
<div class="meter">
<<set $percent=Math.floor((($purity - 700) / 100)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $purity lte 700 and $purity gt 600>><span class="purple">You feel somewhat defiled.</span>
<div class="meter">
<<set $percent=Math.floor((($purity - 600) / 100)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $purity lte 600 and $purity gt 500>><span class="pink">You feel defiled.</span>
<div class="meter">
<<set $percent=Math.floor((($purity - 500) / 100)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $purity lte 500 and $purity gte 1>><span class="red">You feel utterly defiled.</span>
<div class="meter">
<<set $percent=Math.floor(($purity / 500)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $purity gte 0>><span class="red">You are beyond defiled.</span><br><</if>>
Physique: <<if $physique gte ($physiqueage / 7) * 6>><span class="green">Your body is toned and powerful.</span>
<div class="meter">
<<set $percent=Math.floor((($physique - ($physiqueage / 7) * 6) / ($physiqueage / 7))*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $physique gte ($physiqueage / 7) * 5>><span class="teal">Your body is toned and firm.</span>
<div class="meter">
<<set $percent=Math.floor((($physique - ($physiqueage / 7) * 5) / ($physiqueage / 7))*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $physique gte ($physiqueage / 7) * 4>><span class="lblue">Your body is slim and athletic.</span>
<div class="meter">
<<set $percent=Math.floor((($physique - ($physiqueage / 7) * 4) / ($physiqueage / 7))*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $physique gte ($physiqueage / 7) * 3>><span class="blue">Your body is slim.</span>
<div class="meter">
<<set $percent=Math.floor((($physique - ($physiqueage / 7) * 3) / ($physiqueage / 7))*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $physique gte($physiqueage / 7) * 2>><span class="purple">Your body is lithe and slender.</span>
<div class="meter">
<<set $percent=Math.floor((($physique - ($physiqueage / 7) * 2) / ($physiqueage / 7))*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $physique gte ($physiqueage / 7)>><span class="pink">You are skinny.</span>
<div class="meter">
<<set $percent=Math.floor((($physique - ($physiqueage / 7) * 1) / ($physiqueage / 7))*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<else>><span class="red">You are emaciated.</span>
<div class="meter">
<<set $percent=Math.floor(($physique / ($physiqueage / 7))*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<</if>>
Beauty: <<if $beauty gte ($beautymax / 7) * 6>><span class="green">Your beauty is divine.</span>
<div class="meter">
<<set $percent=Math.floor((($beauty - ($beautymax / 7) * 6) / ($beautymax / 7))*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $beauty gte ($beautymax / 7) * 5>><span class="teal">You are ravishing.</span>
<div class="meter">
<<set $percent=Math.floor((($beauty - ($beautymax / 7) * 5) / ($beautymax / 7))*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $beauty gte ($beautymax / 7) * 4>><span class="lblue">You are beautiful.</span>
<div class="meter">
<<set $percent=Math.floor((($beauty - ($beautymax / 7) * 4) / ($beautymax / 7))*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $beauty gte ($beautymax / 7) * 3>><span class="blue">You are charming.</span>
<div class="meter">
<<set $percent=Math.floor((($beauty - ($beautymax / 7) * 3) / ($beautymax / 7))*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $beauty gte($beautymax / 7) * 2>><span class="purple">You are pretty.</span>
<div class="meter">
<<set $percent=Math.floor((($beauty - ($beautymax / 7) * 2) / ($beautymax / 7))*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $beauty gte ($beautymax / 7)>><span class="pink">You are cute.</span>
<div class="meter">
<<set $percent=Math.floor((($beauty - ($beautymax / 7) * 1) / ($beautymax / 7))*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<else>><span class="red">You are plain.</span>
<div class="meter">
<<set $percent=Math.floor(($beauty / ($beautymax / 7))*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<</if>>
Promiscuity: <<if $promiscuity lt 1>><span class="green">You are chaste and pure.</span><br>
<<elseif $promiscuity lt 15>><span class="teal">You are prudish.</span>
<div class="meter">
<<set $percent=Math.floor(($promiscuity/15)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $promiscuity lt 35>><span class="lblue">You are sexually curious.</span>
<div class="meter">
<<set $percent=Math.floor((($promiscuity - 15)/20)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $promiscuity lt 55>><span class="blue">The thought of sexual contact excites you.</span>
<div class="meter">
<<set $percent=Math.floor((($promiscuity - 35)/20)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $promiscuity lt 75>><span class="purple">You crave sexual contact.</span>
<div class="meter">
<<set $percent=Math.floor((($promiscuity - 55)/20)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $promiscuity lt 95>><span class="pink">You are a slut.</span>
<div class="meter">
<<set $percent=Math.floor((($promiscuity - 75)/20)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<else>><span class="red">Your sexual appetite is insatiable.</span>
<div class="meter">
<<set $percent=Math.floor((($promiscuity - 95)/20)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<</if>>
Exhibitionism: <<if $exhibitionism lt 1>><span class="green">You are coy.</span><br>
<<elseif $exhibitionism lt 15>><span class="teal">You are shy.</span>
<div class="meter">
<<set $percent=Math.floor(($exhibitionism/15)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $exhibitionism lt 35>><span class="lblue">You like being sexualized.</span>
<div class="meter">
<<set $percent=Math.floor((($exhibitionism - 15)/20)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $exhibitionism lt 55>><span class="blue">You enjoy lewd attention.</span>
<div class="meter">
<<set $percent=Math.floor((($exhibitionism - 35)/20)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $exhibitionism lt 75>><span class="purple">Feeling exposed excites you.</span>
<div class="meter">
<<set $percent=Math.floor((($exhibitionism - 55)/20)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $exhibitionism lt 95>><span class="pink">You are shameless.</span>
<div class="meter">
<<set $percent=Math.floor((($exhibitionism - 75)/20)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<else>><span class="red">The thought of exposure fills you with wild abandon.</span>
<div class="meter">
<<set $percent=Math.floor((($exhibitionism - 95)/20)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<</if>>
Deviancy: <<if $deviancy lt 1>><span class="green">You are squeamish.</span><br>
<<elseif $deviancy lt 15>><span class="teal">You are conventional.</span>
<div class="meter">
<<set $percent=Math.floor(($deviancy/15)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $deviancy lt 35>><span class="lblue">You are weird.</span>
<div class="meter">
<<set $percent=Math.floor((($deviancy - 15)/20)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $deviancy lt 55>><span class="blue">Your tastes are shocking.</span>
<div class="meter">
<<set $percent=Math.floor((($deviancy - 35)/20)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $deviancy lt 75>><span class="purple">Your desires are scandalous.</span>
<div class="meter">
<<set $percent=Math.floor((($deviancy - 55)/20)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $deviancy lt 95>><span class="pink">You crave acts others wouldn't even conceive of.</span>
<div class="meter">
<<set $percent=Math.floor((($deviancy - 75)/20)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<else>><span class="red">You lust for the unspeakable.</span>
<div class="meter">
<<set $percent=Math.floor((($deviancy - 95)/20)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<</if>>
<br>
Skulduggery: <<if $skulduggery lte 0>><span class="red">None</span><br>
<<elseif $skulduggery gte 1 and $skulduggery lt 100>><span class="pink">F</span> <span class="black"><<print Math.floor($skulduggery)>>%</span>
<div class="meter">
<<set $percent=Math.floor(($skulduggery/100)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $skulduggery gte 100 and $skulduggery lt 200>><span class="pink">F+</span> <span class="black"><<print Math.floor($skulduggery - 100)>>%</span>
<div class="meter">
<<set $percent=Math.floor((($skulduggery - 100)/100)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $skulduggery gte 200 and $skulduggery lt 300>><span class="purple">D</span> <span class="black"><<print $skulduggery - 200>>%</span>
<div class="meter">
<<set $percent=Math.floor((($skulduggery - 200)/100)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $skulduggery gte 300 and $skulduggery lt 400>><span class="purple">D+</span> <span class="black"><<print $skulduggery - 300>>%</span>
<div class="meter">
<<set $percent=Math.floor((($skulduggery - 300)/100)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $skulduggery gte 400 and $skulduggery lt 500>><span class="blue">C</span> <span class="black"><<print $skulduggery - 400>>%</span>
<div class="meter">
<<set $percent=Math.floor((($skulduggery - 400)/100)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $skulduggery gte 500 and $skulduggery lt 600>><span class="blue">C+</span> <span class="black"><<print $skulduggery - 500>>%</span>
<div class="meter">
<<set $percent=Math.floor((($skulduggery - 500)/100)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $skulduggery gte 600 and $skulduggery lt 700>><span class="lblue">B</span> <span class="black"><<print $skulduggery - 600>>%</span>
<div class="meter">
<<set $percent=Math.floor((($skulduggery - 600)/100)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $skulduggery gte 700 and $skulduggery lt 800>><span class="lblue">B+</span> <span class="black"><<print $skulduggery - 700>>%</span>
<div class="meter">
<<set $percent=Math.floor((($skulduggery - 700)/100)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $skulduggery gte 800 and $skulduggery lt 900>><span class="teal">A</span> <span class="black"><<print $skulduggery - 800>>%</span>
<div class="meter">
<<set $percent=Math.floor((($skulduggery - 800)/100)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $skulduggery gte 900 and $skulduggery lt 1000>><span class="teal">A+</span> <span class="black"><<print $skulduggery - 900>>%</span>
<div class="meter">
<<set $percent=Math.floor((($skulduggery - 900)/100)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $skulduggery gte 1000>><span class="green">S</span><br>
<</if>>
<<if $blackmoney gte 1>>
You are carrying £$blackmoney in stolen goods.<br>
<</if>>
Dancing: <<if $danceskill lte 0>><span class="red">None</span><br>
<<elseif $danceskill gte 1 and $danceskill lt 200>><span class="pink">F</span> <span class="black"><<print $danceskill / 2>>%</span>
<div class="meter">
<<set $percent=Math.floor(($danceskill / 200)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $danceskill gte 200 and $danceskill lt 400>><span class="purple">D</span> <span class="black"><<print (($danceskill - 200) / 2)>>%</span>
<div class="meter">
<<set $percent=Math.floor((($danceskill - 200)/ 200)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $danceskill gte 400 and $danceskill lt 600>><span class="blue">C</span> <span class="black"><<print (($danceskill - 400) / 2)>>%</span>
<div class="meter">
<<set $percent=Math.floor((($danceskill - 400)/ 200)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $danceskill gte 600 and $danceskill lt 800>><span class="lblue">B</span> <span class="black"><<print (($danceskill - 600) / 2)>>%</span>
<div class="meter">
<<set $percent=Math.floor((($danceskill - 600)/ 200)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $danceskill gte 800 and $danceskill lt 1000>><span class="teal">A</span> <span class="black"><<print (($danceskill - 800) / 2)>>%</span>
<div class="meter">
<<set $percent=Math.floor((($danceskill - 800)/ 200)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $danceskill gte 1000>><span class="green">S</span><br>
<</if>>
Swimming: <<if $swimmingskill lte 0>><span class="red">None</span><br>
<<elseif $swimmingskill gte 1 and $swimmingskill lt 100>><span class="pink">F</span> <span class="black"><<print $swimmingskill>>%</span>
<div class="meter">
<<set $percent=Math.floor(($swimmingskill/100)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $swimmingskill gte 100 and $swimmingskill lt 200>><span class="pink">F+</span> <span class="black"><<print $swimmingskill - 100>>%</span>
<div class="meter">
<<set $percent=Math.floor((($swimmingskill - 100)/100)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $swimmingskill gte 200 and $swimmingskill lt 300>><span class="purple">D</span> <span class="black"><<print $swimmingskill - 200>>%</span>
<div class="meter">
<<set $percent=Math.floor((($swimmingskill - 200)/100)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $swimmingskill gte 300 and $swimmingskill lt 400>><span class="purple">D+</span> <span class="black"><<print $swimmingskill - 300>>%</span>
<div class="meter">
<<set $percent=Math.floor((($swimmingskill - 300)/100)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $swimmingskill gte 400 and $swimmingskill lt 500>><span class="blue">C</span> <span class="black"><<print $swimmingskill - 400>>%</span>
<div class="meter">
<<set $percent=Math.floor((($swimmingskill - 400)/100)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $swimmingskill gte 500 and $swimmingskill lt 600>><span class="blue">C+</span> <span class="black"><<print $swimmingskill - 500>>%</span>
<div class="meter">
<<set $percent=Math.floor((($swimmingskill - 500)/100)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $swimmingskill gte 600 and $swimmingskill lt 700>><span class="lblue">B</span> <span class="black"><<print $swimmingskill - 600>>%</span>
<div class="meter">
<<set $percent=Math.floor((($swimmingskill - 600)/100)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $swimmingskill gte 700 and $swimmingskill lt 800>><span class="lblue">B+</span> <span class="black"><<print $swimmingskill - 700>>%</span>
<div class="meter">
<<set $percent=Math.floor((($swimmingskill - 700)/100)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $swimmingskill gte 800 and $swimmingskill lt 900>><span class="teal">A</span> <span class="black"><<print $swimmingskill - 800>>%</span>
<div class="meter">
<<set $percent=Math.floor((($swimmingskill - 800)/100)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $swimmingskill gte 900 and $swimmingskill lt 1000>><span class="teal">A+</span> <span class="black"><<print $swimmingskill - 900>>%</span>
<div class="meter">
<<set $percent=Math.floor((($swimmingskill - 900)/100)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $swimmingskill gte 1000>><span class="green">S</span><br>
<</if>>
<br><br>
Seduction: <<if $seductionskill lte 0>><span class="red">None</span><br>
<<elseif $seductionskill gte 1 and $seductionskill lt 200>><span class="pink">F</span> <span class="black"><<print $seductionskill / 2>>%</span>
<div class="meter">
<<set $percent=Math.floor(($seductionskill / 200)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $seductionskill gte 200 and $seductionskill lt 400>><span class="purple">D</span> <span class="black"><<print (($seductionskill - 200) / 2)>>%</span>
<div class="meter">
<<set $percent=Math.floor((($seductionskill - 200)/ 200)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $seductionskill gte 400 and $seductionskill lt 600>><span class="blue">C</span> <span class="black"><<print (($seductionskill - 400) / 2)>>%</span>
<div class="meter">
<<set $percent=Math.floor((($seductionskill - 400)/ 200)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $seductionskill gte 600 and $seductionskill lt 800>><span class="lblue">B</span> <span class="black"><<print (($seductionskill - 600) / 2)>>%</span>
<div class="meter">
<<set $percent=Math.floor((($seductionskill - 600)/ 200)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $seductionskill gte 800 and $seductionskill lt 1000>><span class="teal">A</span> <span class="black"><<print (($seductionskill - 800) / 2)>>%</span>
<div class="meter">
<<set $percent=Math.floor((($seductionskill - 800)/ 200)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $seductionskill gte 1000>><span class="green">S</span><br><</if>>
Oral: <<if $oralskill lte 0>><span class="red">None</span><br>
<<elseif $oralskill gte 1 and $oralskill lt 200>><span class="pink">F</span> <span class="black"><<print $oralskill / 2>>%</span>
<div class="meter">
<<set $percent=Math.floor(($oralskill / 200)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $oralskill gte 200 and $oralskill lt 400>><span class="purple">D</span> <span class="black"><<print (($oralskill - 200) / 2)>>%</span>
<div class="meter">
<<set $percent=Math.floor((($oralskill - 200)/ 200)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $oralskill gte 400 and $oralskill lt 600>><span class="blue">C</span> <span class="black"><<print (($oralskill - 400) / 2)>>%</span>
<div class="meter">
<<set $percent=Math.floor((($oralskill - 400)/ 200)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $oralskill gte 600 and $oralskill lt 800>><span class="lblue">B</span> <span class="black"><<print (($oralskill - 600) / 2)>>%</span>
<div class="meter">
<<set $percent=Math.floor((($oralskill - 600)/ 200)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $oralskill gte 800 and $oralskill lt 1000>><span class="teal">A</span> <span class="black"><<print (($oralskill - 800) / 2)>>%</span>
<div class="meter">
<<set $percent=Math.floor((($oralskill - 800)/ 200)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $oralskill gte 1000>><span class="green">S</span><br><</if>>
<<if $vaginaexist is 1>>
Vaginal: <<if $vaginalskill lte 0>><span class="red">None</span><br>
<<elseif $vaginalskill gte 1 and $vaginalskill lt 200>><span class="pink">F</span> <span class="black"><<print $vaginalskill / 2>>%</span>
<div class="meter">
<<set $percent=Math.floor(($vaginalskill / 200)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $vaginalskill gte 200 and $vaginalskill lt 400>><span class="purple">D</span> <span class="black"><<print (($vaginalskill - 200) / 2)>>%</span>
<div class="meter">
<<set $percent=Math.floor((($vaginalskill - 200)/ 200)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $vaginalskill gte 400 and $vaginalskill lt 600>><span class="blue">C</span> <span class="black"><<print (($vaginalskill - 400) / 2)>>%</span>
<div class="meter">
<<set $percent=Math.floor((($vaginalskill - 400)/ 200)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $vaginalskill gte 600 and $vaginalskill lt 800>><span class="lblue">B</span> <span class="black"><<print (($vaginalskill - 600) / 2)>>%</span>
<div class="meter">
<<set $percent=Math.floor((($vaginalskill - 600)/ 200)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $vaginalskill gte 800 and $vaginalskill lt 1000>><span class="teal">A</span> <span class="black"><<print (($vaginalskill - 800) / 2)>>%</span>
<div class="meter">
<<set $percent=Math.floor((($vaginalskill - 800)/ 200)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $vaginalskill gte 1000>><span class="green">S</span><br><</if>>
<</if>>
<<if $penisexist is 1>>
Penile: <<if $penileskill lte 0>><span class="red">None</span><br>
<<elseif $penileskill gte 1 and $penileskill lt 200>><span class="pink">F</span> <span class="black"><<print $penileskill / 2>>%</span>
<div class="meter">
<<set $percent=Math.floor(($penileskill / 200)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $penileskill gte 200 and $penileskill lt 400>><span class="purple">D</span> <span class="black"><<print (($penileskill - 200) / 2)>>%</span>
<div class="meter">
<<set $percent=Math.floor((($penileskill - 200)/ 200)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $penileskill gte 400 and $penileskill lt 600>><span class="blue">C</span> <span class="black"><<print (($penileskill - 400) / 2)>>%</span>
<div class="meter">
<<set $percent=Math.floor((($penileskill - 400)/ 200)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $penileskill gte 600 and $penileskill lt 800>><span class="lblue">B</span> <span class="black"><<print (($penileskill - 600) / 2)>>%</span>
<div class="meter">
<<set $percent=Math.floor((($penileskill - 600)/ 200)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $penileskill gte 800 and $penileskill lt 1000>><span class="teal">A</span> <span class="black"><<print (($penileskill - 800) / 2)>>%</span>
<div class="meter">
<<set $percent=Math.floor((($penileskill - 800)/ 200)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $penileskill gte 1000>><span class="green">S</span><br><</if>>
<</if>>
Anal: <<if $analskill lte 0>><span class="red">None</span><br>
<<elseif $analskill gte 1 and $analskill lt 200>><span class="pink">F</span> <span class="black"><<print $analskill / 2>>%</span>
<div class="meter">
<<set $percent=Math.floor(($analskill / 200)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $analskill gte 200 and $analskill lt 400>><span class="purple">D</span> <span class="black"><<print (($analskill - 200) / 2)>>%</span>
<div class="meter">
<<set $percent=Math.floor((($analskill - 200)/ 200)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $analskill gte 400 and $analskill lt 600>><span class="blue">C</span> <span class="black"><<print (($analskill - 400) / 2)>>%</span>
<div class="meter">
<<set $percent=Math.floor((($analskill - 400)/ 200)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $analskill gte 600 and $analskill lt 800>><span class="lblue">B</span> <span class="black"><<print (($analskill - 600) / 2)>>%</span>
<div class="meter">
<<set $percent=Math.floor((($analskill - 600)/ 200)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $analskill gte 800 and $analskill lt 1000>><span class="teal">A</span> <span class="black"><<print (($analskill - 800) / 2)>>%</span>
<div class="meter">
<<set $percent=Math.floor((($analskill - 800)/ 200)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $analskill gte 1000>><span class="green">S</span><br><</if>>
Hands: <<if $handskill lte 0>><span class="red">None</span><br>
<<elseif $handskill gte 1 and $handskill lt 200>><span class="pink">F</span> <span class="black"><<print $handskill / 2>>%</span>
<div class="meter">
<<set $percent=Math.floor(($handskill / 200)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $handskill gte 200 and $handskill lt 400>><span class="purple">D</span> <span class="black"><<print (($handskill - 200) / 2)>>%</span>
<div class="meter">
<<set $percent=Math.floor((($handskill - 200)/ 200)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $handskill gte 400 and $handskill lt 600>><span class="blue">C</span> <span class="black"><<print (($handskill - 400) / 2)>>%</span>
<div class="meter">
<<set $percent=Math.floor((($handskill - 400)/ 200)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $handskill gte 600 and $handskill lt 800>><span class="lblue">B</span> <span class="black"><<print (($handskill - 600) / 2)>>%</span>
<div class="meter">
<<set $percent=Math.floor((($handskill - 600)/ 200)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $handskill gte 800 and $handskill lt 1000>><span class="teal">A</span> <span class="black"><<print (($handskill - 800) / 2)>>%</span>
<div class="meter">
<<set $percent=Math.floor((($handskill - 800)/ 200)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $handskill gte 1000>><span class="green">S</span><br><</if>>
Feet: <<if $feetskill lte 0>><span class="red">None</span><br>
<<elseif $feetskill gte 1 and $feetskill lt 200>><span class="pink">F</span> <span class="black"><<print $feetskill / 2>>%</span>
<div class="meter">
<<set $percent=Math.floor(($feetskill / 200)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $feetskill gte 200 and $feetskill lt 400>><span class="purple">D</span> <span class="black"><<print (($feetskill - 200) / 2)>>%</span>
<div class="meter">
<<set $percent=Math.floor((($feetskill - 200)/ 200)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $feetskill gte 400 and $feetskill lt 600>><span class="blue">C</span> <span class="black"><<print (($feetskill - 400) / 2)>>%</span>
<div class="meter">
<<set $percent=Math.floor((($feetskill - 400)/ 200)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $feetskill gte 600 and $feetskill lt 800>><span class="lblue">B</span> <span class="black"><<print (($feetskill - 600) / 2)>>%</span>
<div class="meter">
<<set $percent=Math.floor((($feetskill - 600)/ 200)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $feetskill gte 800 and $feetskill lt 1000>><span class="teal">A</span> <span class="black"><<print (($feetskill - 800) / 2)>>%</span>
<div class="meter">
<<set $percent=Math.floor((($feetskill - 800)/ 200)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $feetskill gte 1000>><span class="green">S</span><br><</if>>
Buttocks: <<if $bottomskill lte 0>><span class="red">None</span><br>
<<elseif $bottomskill gte 1 and $bottomskill lt 200>><span class="pink">F</span> <span class="black"><<print $bottomskill / 2>>%</span>
<div class="meter">
<<set $percent=Math.floor(($bottomskill / 200)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $bottomskill gte 200 and $bottomskill lt 400>><span class="purple">D</span> <span class="black"><<print (($bottomskill - 200) / 2)>>%</span>
<div class="meter">
<<set $percent=Math.floor((($bottomskill - 200)/ 200)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $bottomskill gte 400 and $bottomskill lt 600>><span class="blue">C</span> <span class="black"><<print (($bottomskill - 400) / 2)>>%</span>
<div class="meter">
<<set $percent=Math.floor((($bottomskill - 400)/ 200)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $bottomskill gte 600 and $bottomskill lt 800>><span class="lblue">B</span> <span class="black"><<print (($bottomskill - 600) / 2)>>%</span>
<div class="meter">
<<set $percent=Math.floor((($bottomskill - 600)/ 200)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $bottomskill gte 800 and $bottomskill lt 1000>><span class="teal">A</span> <span class="black"><<print (($bottomskill - 800) / 2)>>%</span>
<div class="meter">
<<set $percent=Math.floor((($bottomskill - 800)/ 200)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $bottomskill gte 1000>><span class="green">S</span><br><</if>>
Thighs: <<if $thighskill lte 0>><span class="red">None</span><br>
<<elseif $thighskill gte 1 and $thighskill lt 200>><span class="pink">F</span> <span class="black"><<print $thighskill / 2>>%</span>
<div class="meter">
<<set $percent=Math.floor(($thighskill / 200)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $thighskill gte 200 and $thighskill lt 400>><span class="purple">D</span> <span class="black"><<print (($thighskill - 200) / 2)>>%</span>
<div class="meter">
<<set $percent=Math.floor((($thighskill - 200)/ 200)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $thighskill gte 400 and $thighskill lt 600>><span class="blue">C</span> <span class="black"><<print (($thighskill - 400) / 2)>>%</span>
<div class="meter">
<<set $percent=Math.floor((($thighskill - 400)/ 200)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $thighskill gte 600 and $thighskill lt 800>><span class="lblue">B</span> <span class="black"><<print (($thighskill - 600) / 2)>>%</span>
<div class="meter">
<<set $percent=Math.floor((($thighskill - 600)/ 200)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $thighskill gte 800 and $thighskill lt 1000>><span class="teal">A</span> <span class="black"><<print (($thighskill - 800) / 2)>>%</span>
<div class="meter">
<<set $percent=Math.floor((($thighskill - 800)/ 200)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $thighskill gte 1000>><span class="green">S</span><br><</if>>
Chest: <<if $chestskill lte 0>><span class="red">None</span><br>
<<elseif $chestskill gte 1 and $chestskill lt 200>><span class="pink">F</span> <span class="black"><<print $chestskill / 2>>%</span>
<div class="meter">
<<set $percent=Math.floor(($chestskill / 200)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $chestskill gte 200 and $chestskill lt 400>><span class="purple">D</span> <span class="black"><<print (($chestskill - 200) / 2)>>%</span>
<div class="meter">
<<set $percent=Math.floor((($chestskill - 200)/ 200)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $chestskill gte 400 and $chestskill lt 600>><span class="blue">C</span> <span class="black"><<print (($chestskill - 400) / 2)>>%</span>
<div class="meter">
<<set $percent=Math.floor((($chestskill - 400)/ 200)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $chestskill gte 600 and $chestskill lt 800>><span class="lblue">B</span> <span class="black"><<print (($chestskill - 600) / 2)>>%</span>
<div class="meter">
<<set $percent=Math.floor((($chestskill - 600)/ 200)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $chestskill gte 800 and $chestskill lt 1000>><span class="teal">A</span> <span class="black"><<print (($chestskill - 800) / 2)>>%</span>
<div class="meter">
<<set $percent=Math.floor((($chestskill - 800)/ 200)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $chestskill gte 1000>><span class="green">S</span><br><</if>>
<br>
__School__<br>
<br>
Science: <<if $science lte 99>><span class="red">F</span> <span class="black"><<print Math.floor($science)>>%</span>
<div class="meter">
<<set $percent=Math.floor(($science / 100)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $science gte 100 and $science lt 200>><span class="pink">E</span> <span class="black"><<print Math.floor($science - 100)>>%</span>
<div class="meter">
<<set $percent=Math.floor((($science - 100)/ 100)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $science gte 200 and $science lt 300>><span class="purple">D</span> <span class="black"><<print Math.floor($science - 200)>>%</span>
<div class="meter">
<<set $percent=Math.floor((($science - 200)/ 100)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $science gte 300 and $science lt 400>><span class="blue">C</span> <span class="black"><<print Math.floor($science - 300)>>%</span>
<div class="meter">
<<set $percent=Math.floor((($science - 300)/ 100)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $science gte 400 and $science lt 500>><span class="lblue">B</span> <span class="black"><<print Math.floor($science - 400)>>%</span>
<div class="meter">
<<set $percent=Math.floor((($science - 400)/ 100)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $science gte 500 and $science lt 700>><span class="teal">A</span> <span class="black"><<print Math.floor((($science - 500) / 2))>>%</span>
<div class="meter">
<<set $percent=Math.floor((($science - 500)/ 200)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $science gte 700>><span class="green">A*</span><br>
<div class="meter">
<<set $percent=Math.floor((($science - 700)/ 300)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<</if>>
Maths: <<if $maths lte 99>><span class="red">F</span> <span class="black"><<print Math.floor($maths)>>%</span>
<div class="meter">
<<set $percent=Math.floor(($maths / 100)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $maths gte 100 and $maths lt 200>><span class="pink">E</span> <span class="black"><<print Math.floor($maths - 100)>>%</span>
<div class="meter">
<<set $percent=Math.floor((($maths - 100)/ 100)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $maths gte 200 and $maths lt 300>><span class="purple">D</span> <span class="black"><<print Math.floor($maths - 200)>>%</span>
<div class="meter">
<<set $percent=Math.floor((($maths - 200)/ 100)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $maths gte 300 and $maths lt 400>><span class="blue">C</span> <span class="black"><<print Math.floor($maths - 300)>>%</span>
<div class="meter">
<<set $percent=Math.floor((($maths - 300)/ 100)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $maths gte 400 and $maths lt 500>><span class="lblue">B</span> <span class="black"><<print Math.floor($maths - 400)>>%</span>
<div class="meter">
<<set $percent=Math.floor((($maths - 400)/ 100)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $maths gte 500 and $maths lt 700>><span class="teal">A</span> <span class="black"><<print Math.floor((($maths - 500) / 2))>>%</span>
<div class="meter">
<<set $percent=Math.floor((($maths - 500)/ 200)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $maths gte 700>><span class="green">A*</span><br>
<div class="meter">
<<set $percent=Math.floor((($maths - 700)/ 300)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<</if>>
English: <<if $english lte 99>><span class="red">F</span> <span class="black"><<print Math.floor($english)>>%</span>
<div class="meter">
<<set $percent=Math.floor(($english / 100)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $english gte 100 and $english lt 200>><span class="pink">E</span> <span class="black"><<print Math.floor($english - 100)>>%</span>
<div class="meter">
<<set $percent=Math.floor((($english - 100)/ 100)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $english gte 200 and $english lt 300>><span class="purple">D</span> <span class="black"><<print Math.floor($english - 200)>>%</span>
<div class="meter">
<<set $percent=Math.floor((($english - 200)/ 100)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $english gte 300 and $english lt 400>><span class="blue">C</span> <span class="black"><<print Math.floor($english - 300)>>%</span>
<div class="meter">
<<set $percent=Math.floor((($english - 300)/ 100)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $english gte 400 and $english lt 500>><span class="lblue">B</span> <span class="black"><<print Math.floor($english - 400)>>%</span>
<div class="meter">
<<set $percent=Math.floor((($english - 400)/ 100)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $english gte 500 and $english lt 700>><span class="teal">A</span> <span class="black"><<print Math.floor((($english - 500) / 2))>>%</span>
<div class="meter">
<<set $percent=Math.floor((($english - 500)/ 200)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $english gte 700>><span class="green">A*</span><br>
<div class="meter">
<<set $percent=Math.floor((($english - 700)/ 300)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<</if>>
History: <<if $history lte 99>><span class="red">F</span> <span class="black"><<print Math.floor($history)>>%</span>
<div class="meter">
<<set $percent=Math.floor(($history / 100)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $history gte 100 and $history lt 200>><span class="pink">E</span> <span class="black"><<print Math.floor($history - 100)>>%</span>
<div class="meter">
<<set $percent=Math.floor((($history - 100)/ 100)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $history gte 200 and $history lt 300>><span class="purple">D</span> <span class="black"><<print Math.floor($history - 200)>>%</span>
<div class="meter">
<<set $percent=Math.floor((($history - 200)/ 100)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $history gte 300 and $history lt 400>><span class="blue">C</span> <span class="black"><<print Math.floor($history - 300)>>%</span>
<div class="meter">
<<set $percent=Math.floor((($history - 300)/ 100)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $history gte 400 and $history lt 500>><span class="lblue">B</span> <span class="black"><<print Math.floor($history - 400)>>%</span>
<div class="meter">
<<set $percent=Math.floor((($history - 400)/ 100)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $history gte 500 and $history lt 700>><span class="teal">A</span> <span class="black"><<print Math.floor((($history - 500) / 2))>>%</span>
<div class="meter">
<<set $percent=Math.floor((($history - 500)/ 200)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<<elseif $history gte 700>><span class="green">A*</span><br>
<div class="meter">
<<set $percent=Math.floor((($history - 700)/ 300)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<</if>>
<<if $antiquemoney gt 0>>
You are carrying antiques worth £$antiquemoney.<br>
<</if>>
Your overall performance is
<<if $school gte 2800>>
<span class="green">exemplary.</span>
<<elseif $school gte 2000>>
<span class="teal">excellent.</span>
<<elseif $school gte 1600>>
<span class="lblue">good.</span>
<<elseif $school gte 1200>>
<span class="blue">okay.</span>
<<elseif $school gte 800>>
<span class="purple">bad.</span>
<<elseif $school gte 400>>
<span class="pink">awful.</span>
<<else>>
<span class="red">appalling.</span>
<</if>>
<br><br>
:: Statistics [nobr]
<<back>><<set $menu to 1>><br>
<br>
__Jobs__<br>
Danced: $dancestat<br>
Drinks served: $drinksservedstat<br>
Tables served: $tablesservedstat<br>
Whored yourself: $prostitutionstat<br>
Forcibly whored out: $forcedprostitutionstat<br>
<br>
__Sex__<br>
Number of orgasms you've experienced: $orgasmstat<br>
Penetrated others: $penilestat<br>
Ejaculated in others: $penileejacstat<br>
Vaginally penetrated: $vaginalstat<br>
Ejaculated in vaginally: $vaginalejacstat<br>
Anally penetrated: $analstat<br>
Ejaculated in anally: $analejacstat<br>
Orally penetrated: $oralstat<br>
Ejaculated in orally: $oralejacstat<br>
Handjobs given: $handstat<br>
Handjob ejaculations: $handejacstat<br>
Footjobs given: $feetstat<br>
Footjob ejaculations: $feetejacstat<br>
Thighjobs given: $thighstat<br>
Thighjob ejaculations: $thighejacstat<br>
Chestjobs given: $cheststat<br>
Chestjob ejaculations: $chestejacstat<br>
Buttjobs given: $bottomstat<br>
Buttjob ejaculations: $bottomejacstat<br>
Hair ejaculated on: $hairejacstat<br>
Tummy ejaculated on: $tummyejacstat<br>
Neck ejaculated on: $neckejacstat<br>
Pussy ejaculated on: $vaginalentranceejacstat<br>
Face ejaculated on: $faceejacstat<br>
Total times you've been ejaculated on or in: $ejacstat<br>
Masturbated: $masturbationstat<br>
Masturbated to orgasm: $masturbationorgasmstat<br>
Minutes spent masturbating: $masturbationtimestat<br>
<br>
<<if $gamemode isnot "soft">>
__Violence__<br>
Molested: $moleststat<br>
Raped: $rapestat<br>
<<if $bestialitydisable is "f">>
Raped by animals: $beastrapestat<br>
<</if>>
<<if $tentacledisable is "f">>
Raped by tentacle monsters: $tentaclerapestat<br>
<</if>>
<<if $voredisable is "f">>
Swallowed: $swallowedstat<br>
<</if>>
<<if $parasitedisable is "f">>
Parasites hosted: $parasitestat<br>
<</if>>
Been hit: $hitstat<br>
Hit others: $attackstat<br>
<br>
<</if>>
__Miscellaneous__<br>
<<if $gamemode isnot "soft">>
Rescued: $rescued<br>
<</if>>
Clothing stripped: $clothesstripstat<br>
Clothing ruined: $clothesruinstat<br>
Passed out: $passoutstat<br>
:: StoryInit
<<set $images to 1>>
<<set $debug to 1>>
<<set $dev to 0>>
<<set $gamemode to "normal">>
<<set $intro to 1>>
<<set $tutorial to 0>>
<<set $initnpccompatibility to 1>>
<<set $controlmax to 1000>>
<<set $control to 1000>>
<<set $time to 420>>
<<set $days to 0>>
<<set $weekday to 1>>
<<set $money to 500>>
<<set $awareness to 0>>
<<set $awarelevel to 0>>
<<set $purity to 1000>>
<<set $devlevel to 10>>
<<set $hairlength to 200>>
<<set $trauma to 0>>
<<set $traumamax to 5000>>
<<set $stressmax to 10010>>
<<set $tirednessmax to 2000>>
<<set $arousalmax to 10000>>
<<set $physique to 3500>>
<<set $physiquemax to 20000>>
<<set $beauty to 100>>
<<set $beautymax to 10000>>
<<set $month to "september">>
<<set $monthday to 4>>
<<set $year to 2018>>
<<set $birthmonth to "september">>
<<set $birthday to 3>>
<<set $npc to 0>>
<<set $dancestudioanger to 0>>
<<set $dancelocation to 0>>
<<set $alarm to 0>>
<<set $finish to 0>>
<<set $id to 0>>
<<set $forest to 0>>
<<set $forestmod to 1>>
<<set $tipcount to 0>>
<<set $tipmod to 1>>
<<set $analshield to 0>>
<<set $blackmoney to 0>>
<<set $crime to 0>>
<<set $crimehistory to 0>>
<<set $collared to 0>>
<<set $collaredpolice to 0>>
<<set $bullytimer to 50>>
<<set $bullytimeroutside to 0>>
<<set $bullyevent to 0>>
<<set $bullyeventoutside to 0>>
<<set $buy to 0>>
<<set $masturbationorgasm to 0>>
<<set $malechance to 50>>
<<set $deviancy to 0>>
<<set $baileydefeated to 0>>
<<set $baileydefeatedlewd to 0>>
<<set $baileydefeatedchain to 0>>
<<set $robinmoney to 300>>
<<set $alluremod to 1>>
<<set $transformed to 0>>
<<set $angelbuild to 0>>
<<set $angel to 0>>
<<set $angelforgive to 0>>
<<set $demonbuild to 0>>
<<set $demon to 0>>
<<set $demonabsorb to 0>>
<<set $seductionskill to 0>>
<<set $oralskill to 0>>
<<set $vaginalskill to 0>>
<<set $analskill to 0>>
<<set $handskill to 0>>
<<set $feetskill to 0>>
<<set $bottomskill to 0>>
<<set $thighskill to 0>>
<<set $chestskill to 0>>
<<set $penileskill to 0>>
<<set $skulduggery to 0>>
<<set $skulduggeryday to 0>>
<<set $danceskill to 0>>
<<set $swimmingskill to 0>>
<<set $hygiene to 0>>
<<set $hunger to 0>>
<<set $thirst to 0>>
<<set $tiredness to 0>>
<<set $arousal to 0>>
<<set $stress to 0>>
<<set $vaginalvirginity to 1>>
<<set $analvirginity to 1>>
<<set $oralvirginity to 1>>
<<set $penilevirginity to 1>>
<<set $comb to 0>>
<<set $pain to 0>>
<<set $combat to 0>>
<<set $location to 0>>
<<set $breastcup to "none">>
<<set $breastsize to 0>>
<<set $breastsizeold to 0>>
<<set $breastsizemax to 12>>
<<set $physiqueuse to 0>>
<<set $rapeavoid to 1>>
<<set $sexavoid to 1>>
<<set $molestavoid to 1>>
<<set $rescued to 0>>
<<set $baileyhospital to 0>>
<<set $squidcount to 0>>
<<set $genderknown to ["Robin", "Bailey"]>>
<<set $vaginause to 0>>
<<set $anususe to 0>>
<<set $mouthuse to 0>>
<<set $leftarm to 0>>
<<set $rightarm to 0>>
<<set $chestuse to 0>>
<<set $penisuse to 0>>
<<set $thighuse to 0>>
<<set $bottomuse to 0>>
<<set $feetuse to 0>>
<<set $vaginastate to 0>>
<<set $anusstate to 0>>
<<set $mouthstate to 0>>
<<set $penisstate to 0>>
<<set $head to 0>>
<<set $front to 0>>
<<set $back to 0>>
<<set $chest to 0>>
<<set $lefthand to "none">>
<<set $lefthand2 to "none">>
<<set $lefthand3 to "none">>
<<set $lefthand4 to "none">>
<<set $lefthand5 to "none">>
<<set $lefthand6 to "none">>
<<set $righthand to "none">>
<<set $righthand2 to "none">>
<<set $righthand3 to "none">>
<<set $righthand4 to "none">>
<<set $righthand5 to "none">>
<<set $righthand6 to "none">>
<<set $penis to "none">>
<<set $penis2 to "none">>
<<set $penis3 to "none">>
<<set $penis4 to "none">>
<<set $penis5 to "none">>
<<set $penis6 to "none">>
<<set $vagina to "none">>
<<set $vagina2 to "none">>
<<set $vagina3 to "none">>
<<set $vagina4 to "none">>
<<set $vagina5 to "none">>
<<set $vagina6 to "none">>
<<set $mouth to "none">>
<<set $mouth2 to "none">>
<<set $mouth3 to "none">>
<<set $mouth4 to "none">>
<<set $mouth5 to "none">>
<<set $mouth6 to "none">>
<<set $gender1 to 0>>
<<set $gender2 to 0>>
<<set $gender3 to 0>>
<<set $gender4 to 0>>
<<set $gender5 to 0>>
<<set $gender6 to 0>>
<<set $pronoun1 to 0>>
<<set $pronoun2 to 0>>
<<set $pronoun3 to 0>>
<<set $pronoun4 to 0>>
<<set $pronoun5 to 0>>
<<set $pronoun6 to 0>>
<<set $description1 to 0>>
<<set $description2 to 0>>
<<set $description3 to 0>>
<<set $description4 to 0>>
<<set $description5 to 0>>
<<set $description6 to 0>>
<<set $dgchance to 0>>
<<set $cbchance to 0>>
<<set $facebruise to 0>>
<<set $chestbruise to 0>>
<<set $tummybruise to 0>>
<<set $vaginabruise to 0>>
<<set $anusbruise to 0>>
<<set $bottombruise to 0>>
<<set $thighbruise to 0>>
<<set $armbruise to 0>>
<<set $neckbruise to 0>>
<<set $rapestat to 0>>
<<set $beastrapestat to 0>>
<<set $tentaclerapestat to 0>>
<<set $moleststat to 0>>
<<set $vaginalstat to 0>>
<<set $vaginalejacstat to 0>>
<<set $analstat to 0>>
<<set $analejacstat to 0>>
<<set $oralstat to 0>>
<<set $oralejacstat to 0>>
<<set $handstat to 0>>
<<set $handejacstat to 0>>
<<set $feetstat to 0>>
<<set $feetejacstat to 0>>
<<set $thighstat to 0>>
<<set $thighejacstat to 0>>
<<set $bottomstat to 0>>
<<set $bottomejacstat to 0>>
<<set $penilestat to 0>>
<<set $penileejacstat to 0>>
<<set $clothesstripstat to 0>>
<<set $clothesruinstat to 0>>
<<set $orgasmstat to 0>>
<<set $vaginalentranceejacstat to 0>>
<<set $faceejacstat to 0>>
<<set $cheststat to 0>>
<<set $chestejacstat to 0>>
<<set $hairejacstat to 0>>
<<set $tummyejacstat to 0>>
<<set $neckejacstat to 0>>
<<set $ejacstat to 0>>
<<set $hitstat to 0>>
<<set $attackstat to 0>>
<<set $prostitutionstat to 0>>
<<set $forcedprostitutionstat to 0>>
<<set $tablesservedstat to 0>>
<<set $parasitestat to 0>>
<<set $passoutstat to 0>>
<<set $masturbationstat to 0>>
<<set $masturbationorgasmstat to 0>>
<<set $masturbationtimestat to 0>>
<<set $danceaction to 0>>
<<set $danceactiondefault to 0>>
<<set $dancestat to 0>>
<<set $dancing to 0>>
<<set $pullaway to 0>>
<<set $novaginal to 0>>
<<set $noanal to 0>>
<<set $nopenile to 0>>
<<set $vaginalchastity to 0>>
<<set $analchastity to 0>>
<<set $penilechastity to 0>>
<<set $drinksservedstat to 0>>
<<set $unclad to 0>>
<<set $speechorgasmweakcumcount to 0>>
<<set $speechorgasmnocumcount to 0>>
<<set $speechorgasmcount to 0>>
<<set $speechorgasmrepeat to 0>>
<<set $underwatertime to 0>>
<<set $underwater to 0>>
<<set $walltype to "wall">>
<<set $submissive to 1000>>
<<set $assertive to 0>>
<<set $assertivedefault to "trauma">>
<<set $assertiveaction to 0>>
<<set $rescue to 0>>
<<set $drugged to 0>>
<<set $drunk to 0>>
<<set $exposed to 0>>
<<set $phase to 0>>
<<set $phase2 to 0>>
<<set $orgasmdown to 0>>
<<set $noise to 0>>
<<set $enemywounded to 0>>
<<set $enemyejaculated to 0>>
<<set $enemyno to 0>>
<<set $semenpuddle to 0>>
<<set $strangle to 0>>
<<set $eventskip to 0>>
<<set $menu to 0>>
<<set $consensual to 0>>
<<set $attention to 0>>
<<set $seconds to 0>>
<<set $minute to 0>>
<<set $orgasmcount to 0>>
<<set $leftboundcarry to 0>>
<<set $rightboundcarry to 0>>
<<set $orgasmcurrent to 0>>
<<set $hospitalintro to 0>>
<<set $traumafocus to 0>>
<<set $pubwhore to 0>>
<<set $npclovehigh to 10>>
<<set $npclovelow to -10>>
<<set $npcdomhigh to 10>>
<<set $npcdomlow to -10>>
<<set $schoolevent to 0>>
<<set $schooleventtimer to 10>>
<<set $flashbackhome to 0>>
<<set $flashbacktown to 0>>
<<set $flashbackbeach to 0>>
<<set $flashbackunderground to 0>>
<<set $flashbackschool to 0>>
<<set $panicviolence to 0>>
<<set $panicparalysis to 0>>
<<set $colouraction to 0>>
<<set $hungerenabled to 0>>
<<set $thirstenabled to 0>>
<<set $hygieneenabled to 0>>
<<set $weather to either("clear", "clear", "clear", "clear", "overcast", "overcast", "overcast", "overcast", "rain", "rain")>>
<<set $exhibitionism to 0>>
<<set $promiscuity to 0>>
<<set $diagnosis to 0>>
<<set $psych to 0>>
<<set $asylum to 0>>
<<set $audience to 0>>
<<set $audienceexcitement to 0>>
<<set $audiencearousal to 0>>
<<set $audiencemod to 1>>
<<set $venuemod to 1>>
<<set $danceevent to 0>>
<<set $dancephysique to 0>>
<<set $hypnosis to 0>>
<<set $pills to 0>>
<<set $medicated to 0>>
<<set $trance to 0>>
<<set $harperexam to 0>>
<<set $schoolterm to 1>>
<<set $schoolday to 0>>
<<set $sciencemissed to 0>>
<<set $mathsmissed to 0>>
<<set $englishmissed to 0>>
<<set $historymissed to 0>>
<<set $swimmingmissed to 0>>
<<set $fame to 0>>
<<set $fameexhibitionism to 0>>
<<set $fameprostitution to 0>>
<<set $famebestiality to 0>>
<<set $famesex to 0>>
<<set $famerape to 0>>
<<set $famegood to 0>>
<<set $famebusiness to 0>>
<<set $mathstrait to 0>>
<<set $englishtrait to 0>>
<<set $sciencetrait to 0>>
<<set $historytrait to 0>>
<<set $wolfgirl to 0>>
<<set $wolfbuild to 0>>
<<set $swarm1 to 0>>
<<set $swarm2 to 0>>
<<set $swarm3 to 0>>
<<set $swarm4 to 0>>
<<set $swarm5 to 0>>
<<set $swarm6 to 0>>
<<set $swarm7 to 0>>
<<set $swarm8 to 0>>
<<set $swarm9 to 0>>
<<set $swarm10 to 0>>
<<set $swarmpending to 0>>
<<set $swarmname to 0>>
<<set $swarmmove to 0>>
<<set $swarmactive to 0>>
<<set $swarmcreature to 0>>
<<set $swarmchestmolest to 0>>
<<set $swarmchestgrab to 0>>
<<set $swarmchestgrabintro to 0>>
<<set $swarmchestgrabclothed to 0>>
<<set $swarmchestclothed to 0>>
<<set $swarmchestcover to 0>>
<<set $swarmactivate to 0>>
<<set $swarmspill to 0>>
<<set $swarmback to 0>>
<<set $swarmbackmolest to 0>>
<<set $swarmbackgrab to 0>>
<<set $swarmbackgrabintro to 0>>
<<set $swarmbackgrabunderclothed to 0>>
<<set $swarmbackunderclothed to 0>>
<<set $swarmbackgrablowerclothed to 0>>
<<set $swarmbacklowerclothed to 0>>
<<set $swarmbackcover to 0>>
<<set $swarmbackinside to 0>>
<<set $swarmbackinsideintro to 0>>
<<set $swarmbackgrablowerchastity to 0>>
<<set $swarmfront to 0>>
<<set $swarmfrontmolest to 0>>
<<set $swarmfrontgrab to 0>>
<<set $swarmfrontgrabintro to 0>>
<<set $swarmfrontgrabunderclothed to 0>>
<<set $swarmfrontunderclothed to 0>>
<<set $swarmfrontgrablowerclothed to 0>>
<<set $swarmfrontlowerclothed to 0>>
<<set $swarmfrontcover to 0>>
<<set $swarmfrontinside to 0>>
<<set $swarmfrontinsideintro to 0>>
<<set $swarmfrontgrablowerchastity to 0>>
<<set $swarmsteady to 0>>
<<set $swarmcount to 0>>
<<set $beasttype to "beast">>
<<set $claws to 1>>
<<set $water to 0>>
<<set $foresthunt to 0>>
<<set $wolfpacktrust to 0>>
<<set $wolfpackfear to 0>>
<<set $sea to 0>>
<<set $penilechastityparasite to 0>>
<<set $vaginalchastityparasite to 0>>
<<set $analchastityparasite to 0>>
<<set $penisparasite to 0>>
<<set $clitparasite to 0>>
<<set $chestparasite to 0>>
<<set $vorestrength to 0>>
<<set $vorestruggle to 0>>
<<set $voretentacles to 0>>
<<set $vorestage to 0>>
<<set $vorecreature to 0>>
<<set $swallowed to 0>>
<<set $swallowedstat to 0>>
<<set $tentacleno to 0>>
<<set $activetentacleno to 0>>
<<set $tentaclehealth to 0>>
<<set $tentacle1 to 0>>
<<set $tentacle1head to 0>>
<<set $tentacle1shaft to 0>>
<<set $tentacle1health to 0>>
<<set $tentacle2 to 0>>
<<set $tentacle2head to 0>>
<<set $tentacle2shaft to 0>>
<<set $tentacle2health to 0>>
<<set $tentacle3 to 0>>
<<set $tentacle3head to 0>>
<<set $tentacle3shaft to 0>>
<<set $tentacle3health to 0>>
<<set $tentacle4 to 0>>
<<set $tentacle4head to 0>>
<<set $tentacle4shaft to 0>>
<<set $tentacle4health to 0>>
<<set $tentacle5 to 0>>
<<set $tentacle5head to 0>>
<<set $tentacle5shaft to 0>>
<<set $tentacle5health to 0>>
<<set $tentacle6 to 0>>
<<set $tentacle6head to 0>>
<<set $tentacle6shaft to 0>>
<<set $tentacle6health to 0>>
<<set $tentacle7 to 0>>
<<set $tentacle7head to 0>>
<<set $tentacle7shaft to 0>>
<<set $tentacle7health to 0>>
<<set $tentacle8 to 0>>
<<set $tentacle8head to 0>>
<<set $tentacle8shaft to 0>>
<<set $tentacle8health to 0>>
<<set $tentacle9 to 0>>
<<set $tentacle9head to 0>>
<<set $tentacle9shaft to 0>>
<<set $tentacle9health to 0>>
<<set $tentacle10 to 0>>
<<set $tentacle10head to 0>>
<<set $tentacle10shaft to 0>>
<<set $tentacle10health to 0>>
<<set $tentacle11 to 0>>
<<set $tentacle11head to 0>>
<<set $tentacle11shaft to 0>>
<<set $tentacle11health to 0>>
<<set $tentacle12 to 0>>
<<set $tentacle12head to 0>>
<<set $tentacle12shaft to 0>>
<<set $tentacle12health to 0>>
<<set $tentacle13 to 0>>
<<set $tentacle13head to 0>>
<<set $tentacle13shaft to 0>>
<<set $tentacle13health to 0>>
<<set $tentacle14 to 0>>
<<set $tentacle14head to 0>>
<<set $tentacle14shaft to 0>>
<<set $tentacle14health to 0>>
<<set $tentacle15 to 0>>
<<set $tentacle15head to 0>>
<<set $tentacle15shaft to 0>>
<<set $tentacle15health to 0>>
<<set $tentacle16 to 0>>
<<set $tentacle16head to 0>>
<<set $tentacle16shaft to 0>>
<<set $tentacle16health to 0>>
<<set $leftleg to 0>>
<<set $rightleg to 0>>
<<set $breastuse to 0>>
<<set $leftnipple to 0>>
<<set $rightnipple to 0>>
<<set $leftarmstate to 0>>
<<set $rightarmstate to 0>>
<<set $feetstate to 0>>
<<set $neckgoo to 0>>
<<set $rightarmgoo to 0>>
<<set $leftarmgoo to 0>>
<<set $thighgoo to 0>>
<<set $bottomgoo to 0>>
<<set $tummygoo to 0>>
<<set $chestgoo to 0>>
<<set $facegoo to 0>>
<<set $hairgoo to 0>>
<<set $feetgoo to 0>>
<<set $vaginagoo to 0>>
<<set $vaginaoutsidegoo to 0>>
<<set $penisgoo to 0>>
<<set $anusgoo to 0>>
<<set $mouthgoo to 0>>
<<set $necksemen to 0>>
<<set $rightarmsemen to 0>>
<<set $leftarmsemen to 0>>
<<set $thighsemen to 0>>
<<set $bottomsemen to 0>>
<<set $tummysemen to 0>>
<<set $chestsemen to 0>>
<<set $facesemen to 0>>
<<set $hairsemen to 0>>
<<set $feetsemen to 0>>
<<set $vaginasemen to 0>>
<<set $vaginaoutsidesemen to 0>>
<<set $penissemen to 0>>
<<set $anussemen to 0>>
<<set $mouthsemen to 0>>
<<set $detention to 0>>
<<set $delinquency to 10>>
<<set $cool to 120>>
<<set $coolmax to 400>>
<<set $school to 800>>
<<set $maths to 200>>
<<set $science to 200>>
<<set $english to 200>>
<<set $history to 200>>
<<set $scienceprogression to 0>>
<<set $audienceselector to 0>>
<<set $audiencecamera to 0>>
<<set $audiencecamera1 to 0>>
<<set $audiencecamera2 to 0>>
<<set $audiencecamera3 to 0>>
<<set $audiencecamera4 to 0>>
<<set $audiencecamera5 to 0>>
<<set $audiencecamera6 to 0>>
<<set $audiencemember to 0>>
<<set $leftactioncarry to "leftcoverface">>
<<set $rightactioncarry to "rightcoverface">>
<<set $feetactioncarry to "rest">>
<<set $mouthactioncarry to "plead">>
<<set $leftactioncarrypain to "leftprotect">>
<<set $rightactioncarrypain to "rightprotect">>
<<set $mouthactioncarrypain to "letout">>
<<set $leftactioncarryorgasm to "leftgrip">>
<<set $rightactioncarryorgasm to "rightgrip">>
<<set $mouthactioncarryorgasm to "letoutorgasm">>
<<set $leftactioncarrydissociation to "leftcurl">>
<<set $rightactioncarrydissociation to "rightcurl">>
<<set $mouthactioncarrydissociation to "noises">>
<<set $scienceproject to "none">>
<<set $yeardays to 0>>
<<set $oxygenmax to 1200>>
<<set $oxygen to 1200>>
<<set $hallucinogen to 0>>
<<set $antiquemoney to 0>>
<<set $antiquemoneyhistory to 0>>
<<clothinginit>>
:: StoryCaption [nobr]
<<if $intro is 0>>
<<weatherdisplay>>
<<exposure>>
<<if $gamemode is "soft">>
<<set $pain to 0>>
<</if>>
<<if $images is 1>><<img>><br>
<br>
<br>
<br>
<br>
<<if window.document.body.clientWidth lt 650>>
<br><br><br><br>
<</if>>
<</if>>
<<exposure>>
<<combateffects>>
<<if $physiquechange is 1>><<set $physiquechange to 0>>
<<if $physiqueuse gte $physique / 1000>>
<span class="gold">Your physique is improving due to all the exercise you are getting.</span><<set $physiqueuse to 0>><br><br>
<<else>>
<span class="pink">You didn't get enough exercise yesterday, your physique has deteriorated slightly as a result.</span><<set $physiqueuse to 0>><br><br>
<</if>>
<</if>>
<<if $swimmingmissedtext isnot 1 and $mathsmissedtext isnot 1 and $sciencemissedtext isnot 1 and $englishmissedtext isnot 1 and $historymissedtext isnot 1>>
<<else>>
<<if $swimmingmissedtext is 1>><<set $swimmingmissedtext to 0>>
<<if $swimmingmissed gte 10>>
<span class="red">You've missed so many swimming lessons that the police have been informed.</span><<crime 5>><br>
<<else>>
<span class="pink">You missed yesterday's swimming lesson.</span><br>
<</if>>
<</if>>
<<if $mathsmissedtext is 1>><<set $mathsmissedtext to 0>>
<<if $mathsmissed gte 10>>
<span class="red">You've missed so many maths lessons that the police have been informed.</span><<crime 5>><br>
<<else>>
<span class="pink">You missed yesterday's maths lesson!</span><br>
<</if>>
<</if>>
<<if $sciencemissedtext is 1>><<set $sciencemissedtext to 0>>
<<if $sciencemissed gte 10>>
<span class="red">You've missed so many science lessons that the police have been informed.</span><<crime 5>><br>
<<else>>
<span class="pink">You missed yesterday's science lesson!</span><br>
<</if>>
<</if>>
<<if $englishmissedtext is 1>><<set $englishmissedtext to 0>>
<<if $englishmissed gte 10>>
<span class="red">You've missed so many english lessons that the police have been informed.</span><<crime 5>><br>
<<else>>
<span class="pink">You missed yesterday's english lesson!</span><br>
<</if>>
<</if>>
<<if $historymissedtext is 1>><<set $historymissedtext to 0>>
<<if $historymissed gte 10>>
<span class="red">You've missed so many history lessons that the police have been informed.</span><<crime 5>><br>
<<else>>
<span class="pink">You missed yesterday's history lesson!</span><br>
<</if>>
<</if>>
<br>
<</if>>
<<if $dev is 1>>
<<set $money = Math.trunc($money)>>
You have £<<print ($money / 100)>><br>
<<else>>
You have £<<print Math.trunc($money / 100)>>.<<if $money % 100 lte 9>>0<</if>><<print $money % 100>><br>
<</if>>
<br>
<<time>>
It is $hour:<<print ($time - $hour * 60).toString().padStart(2, "0")>><br>
It is <<if $weekday eq 1>><<print "Sunday">><<elseif $weekday eq 2>><<print "Monday">><<elseif $weekday eq 3>><<print "Tuesday">><<elseif $weekday eq 4>><<print "Wednesday">><<elseif $weekday eq 5>><<print "Thursday">><<elseif $weekday eq 6>><<print "Friday">><<elseif $weekday eq 7>><<print "Saturday">>.<</if>><br>
<<schoolday>><br>
<br>
<<clothingcaption>>
<br>
<<stripcaption>>
<<if $playergender is "m">>
<<if $playergender isnot $playergenderappearance>>
<<if $breastindicator is 1>>
<span class="pink">Your exposed breasts will make people think you're a girl!</span><br>
<<else>>
<span class="pink">The way you're dressed, people will think you're a girl!</span><br>
<</if>>
<</if>>
<<elseif $playergender is "f">>
<<if $playergender isnot $playergenderappearance>>
<<if $breastindicator is 0 and $upperexposed is 2>>
<span class="pink">Your exposed flat chest will make people think you're a boy!</span><br>
<<else>>
<span class="pink">The way you're dressed, people will think you're a boy!</span><br>
<</if>>
<</if>>
<</if>>
<<preclamp>>
<<clamp>>
<<if $daystate is "night">>
<<set $nightmod to 1.5>>
<<else>>
<<set $nightmod to 1>>
<</if>>
<<if $exposed gte 2>>
<<set $exposedmod to 1.5>>
<<elseif $exposed gte 1>>
<<set $exposedmod to 1.2>>
<<else>>
<<set $exposedmod to 1>>
<</if>>
<<set $allure to (($beauty / 3) + $hairlength / 4 + $upperreveal + $underreveal + $lowerreveal) * $nightmod * $exposedmod>>
<<if $collared gte 1>><<set $allure += 1000>><</if>>
<<if $wolfgirl gte 6>><<set $allure += 500>><</if>>
<<if $demon gte 6>><<set $allure += 500>><</if>>
<<if $angel gte 6>><<set $allure += 500>><</if>>
<<if $fallenangel gte 2>><<set $allure += 500>><</if>>
<<goocount>><<set $allure += ($goocount * 50) + ($semencount * 50)>>
<<if $legsacc is "stockings">><<set $allure += 300>><</if>>
<<if $legsacc is "fishnet stockings">><<set $allure += 300>><</if>>
<<set $allure *= $alluremod>>
<<if $allure gte 8000 * $alluremod>><<set $allure to 8000 * $alluremod>><</if>>
<<if $allure gte 8000>><<set $allure to 8000>><</if>>
<<if $alluretest is 1>>
<<set $allure += 100000>>
<</if>>
<<set $attractiveness to ($beauty / 3) + $hairlength / 4 + $upperreveal + $underreveal + $lowerreveal>>
<<if $wolfgirl gte 6>><<set $attractiveness += 500>><</if>>
<<if $demon gte 6>><<set $attractiveness += 500>><</if>>
<<if $angel gte 6>><<set $attractiveness += 500>><</if>>
<<if $fallenangel gte 2>><<set $attractiveness += 500>><</if>>
<<if $legsacc is "stockings">><<set $attractiveness += 300>><</if>>
<<if $legsacc is "fishnet stockings">><<set $attractiveness += 300>><</if>>
<<set $rng to random(1, 100)>>
<<if $collared gte 1>>
<span class="pink">A collar with a leash attached encases your neck.</span><br>
<</if>>
<<if $vaginalchastityparasite isnot 0>>
<span class="pink">You feel $vaginalchastityparasite squirming inside your vagina.</span><br>
<</if>>
<<if $penilechastityparasite isnot 0>>
<span class="pink">You feel $penilechastityparasite squirming around your penis.</span><br>
<</if>>
<<if $analchastityparasite isnot 0>>
<span class="pink">You feel $analchastityparasite squirming inside your lower intestine.</span><br>
<</if>>
<<if $chestparasite isnot 0>>
<span class="pink">The parasites clinging to your nipples suck and massage you.</span><br>
<</if>>
<<if $penisparasite isnot 0>>
<span class="pink">The parasite clinging to your penis sucks and massages you.</span><br>
<</if>>
<<if $clitparasite isnot 0>>
<span class="pink">The parasite clinging to your clit sucks and massages you.</span><br>
<</if>>
<<if $leftarm is "bound" and $rightarm is "bound">>
<span class="pink">Your arms are bound.</span><br>
<<elseif $leftarm is "bound">>
<span class="purple">Your left arm is bound.</span><br>
<<elseif $rightarm is "bound">>
<span class="purple">Your right arm is bound.</span><br>
<</if>>
<<if $feetuse is "bound">>
<span class="pink">Your legs are bound.</span>
<br>
<</if>>
<<goo>>
<<if $gamemode isnot "soft">>
Pain: <<paincaption>>
<</if>>
Arousal: <<arousalcaption>>
Fatigue: <<tirednesscaption>>
Stress: <<stresscaption>>
Trauma: <<traumacaption>>
<<if $gamemode isnot "soft">>
Control: <<controlcaption>>
<</if>>
Allure: <<allurecaption>>
<<if $underwater is 1>>
Air: <<oxygencaption>>
<</if>>
<<drunk>><<drugged>><<hallucinogen>>
<br>
<<if $tipdisable is "f">>
<span class="gold">Tip:</span> <<tips>>
<br><br>
<</if>>
<<silently>>
<<if $hungerenabled is 1>>
<<if $hunger gte 2000>><<set $stress += ($hunger - 2000)>><<set $physique -= (($hunger - 2000) / 200)>>
<</if>>
<</if>>
<<if $thirstenabled is 1>>
<<if $thirst gte 2000>><<set $stress += ($thirst - 2000)>><<set $physique -= (($thirst - 2000) / 200)>>
<</if>>
<</if>>
<<if $hygieneenabled is 1>>
<<if $hygiene gte 2000>><<set $stress += ($hygiene - 2000)>>
<</if>>
<</if>>
<</silently>>
<<if $debug is 1>>
<<debug>>
<</if>>
<<else>>
<<versioninfo>>
<</if>>
<<if $menu is 1>>
__Colour Key__<br>
<span class="gold">Skill Up/Reward</span><br>
<span class="green">Excellent/Safe</span><br>
<span class="teal">Good/Reliable</span><br>
<span class="lblue">Decent/Hopeful</span><br>
<span class="blue">Okay/Unsure</span><br>
<span class="purple">Poor/Precarious</span><br>
<span class="pink">Bad/Risky</span><br>
<span class="red">Terrible/Dangerous</span><br>
<br>
<span class="def">Defiant</span><br>
<span class="brat">Bratty</span><br>
<span class="meek">Meek</span><br>
<span class="sub">Submissive/Assertive</span><br>
<</if>>
:: StoryMenu
<<if $intro is 0 and $menu is 0 and $dancing is 0 and $combat is 0>>[[Characteristics]]
[[Traits]]
[[Social]]
[[Statistics]]
<<if $cheatsenabled is 1>>[[Cheats]]<</if>>
<</if>>
:: Widgets [widget]
<<widget "toggledebug">><<nobr>>
<<if $debug>> <<set $debug to 1>>
<<else>> <<set $debug to 0>>
<</nobr>><</widget>>
<<widget "statbar">><<nobr>>
<<set _now to $args[0]>><<set _max to $args[1]>>
<div class="meter">
<<set _percent=Math.floor((_now/_max)*100)>>
<<if _now gte _max>>
<<print '<div class="redbar" style="width:' + _percent + '%"></div>'>>
<<elseif _now gte (_max / 5) * 4>>
<<print '<div class="pinkbar" style="width:' + _percent + '%"></div>'>>
<<elseif _now gte (_max / 5) * 3>>
<<print '<div class="purplebar" style="width:' + _percent + '%"></div>'>>
<<elseif _now gte (_max / 5) * 2>>
<<print '<div class="bluebar" style="width:' + _percent + '%"></div>'>>
<<elseif _now gte (_max / 5) * 1>>
<<print '<div class="lbluebar" style="width:' + _percent + '%"></div>'>>
<<elseif _now gte 1>>
<<print '<div class="tealbar" style="width:' + _percent + '%"></div>'>>
<<else>>
<<print '<div class="greenbar" style="width:' + _percent + '%"></div>'>>
<</if>>
</div>
<</nobr>><</widget>>
<<widget "statbarinverted">><<nobr>>
<<set _now to $args[0]>><<set _max to $args[1]>>
<div class="meter">
<<set _percent=Math.floor((_now/_max)*100)>>
<<if _now gte _max>>
<<print '<div class="greenbar" style="width:' + _percent + '%"></div>'>>
<<elseif _now gte (_max / 5) * 4>>
<<print '<div class="tealbar" style="width:' + _percent + '%"></div>'>>
<<elseif _now gte (_max / 5) * 3>>
<<print '<div class="lbluebar" style="width:' + _percent + '%"></div>'>>
<<elseif _now gte (_max / 5) * 2>>
<<print '<div class="bluebar" style="width:' + _percent + '%"></div>'>>
<<elseif _now gte (_max / 5) * 1>>
<<print '<div class="purplebar" style="width:' + _percent + '%"></div>'>>
<<elseif _now gte 1>>
<<print '<div class="pinkbar" style="width:' + _percent + '%"></div>'>>
<<else>>
<<print '<div class="redbar" style="width:' + _percent + '%"></div>'>>
<</if>>
</div>
<</nobr>><</widget>>
<<widget "wateraction">><<nobr>>
<<if $swimmingskill lt 100>><<set $seconds += 18>><<set $oxygen -= 180>>
<<elseif $swimmingskill lt 200>><<set $seconds += 15>><<set $oxygen -= 150>>
<<elseif $swimmingskill lt 300>><<set $seconds += 12>><<set $oxygen -= 120>>
<<elseif $swimmingskill lt 400>><<set $seconds += 10>><<set $oxygen -= 100>>
<<elseif $swimmingskill lt 500>><<set $seconds += 8>><<set $oxygen -= 80>>
<<elseif $swimmingskill lt 600>><<set $seconds += 8>><<set $oxygen -= 80>>
<<elseif $swimmingskill lt 700>><<set $seconds += 7>><<set $oxygen -= 70>>
<<elseif $swimmingskill lt 800>><<set $seconds += 7>><<set $oxygen -= 70>>
<<elseif $swimmingskill lt 900>><<set $seconds += 6>><<set $oxygen -= 60>>
<<elseif $swimmingskill lt 1000>><<set $seconds += 6>><<set $oxygen -= 60>>
<<else>><<set $seconds += 5>><<set $oxygen -= 50>>
<</if>>
<</nobr>><</widget>>
<<widget "underwater">><<nobr>>
<<water>><<set $underwater to 1>><<set $underwatercheck to 1>>
<<if $seconds gte 60>>
<<set $seconds -= 60>>
<<pass 1>>
<</if>>
<<if $oxygen lt 0 and $nooxygen is 1>>
<<set $stress += 1000>>
<<elseif $oxygen lt 0 and $nooxygen isnot 1>>
<<set $nooxygen to 1>>
<<else>>
<<set $nooxygen to 0>>
<</if>>
<span class="lblue">Air:</span>
<<if $oxygen lt 0>>
<span class="red">You can't breathe! Your stress will increase and you'll soon pass out if you can't find air.</span>
<</if>>
<<oxygencaption>>
<<if $underwaterintro isnot 1 and $combat isnot 1>><<set $underwaterintro to 1>>
<i>You can't hold your breath forever. You will pass less time and use less air per action with a higher swimming skill.</i><br><br>
<</if>>
<</nobr>><</widget>>
<<widget "oxygenrefresh">><<nobr>>
<<set $oxygen to $oxygenmax>>
<</nobr>><</widget>>
<<widget "passwater">><<nobr>>
<<if $outside is 1 and $weather is "clear">>
<<if $upperwet gte 1>>
<<set $upperwet -= ($pass * 2)>>
<</if>>
<<if $lowerwet gte 1>>
<<set $lowerwet -= ($pass * 2)>>
<</if>>
<<if $underwet gte 1>>
<<set $underwet -= ($pass * 2)>>
<</if>>
<<elseif $outside is 1 and $weather is "rain">>
<<if $uppertype isnot "naked" and $uppertype isnot "swim">>
<<set $upperwet += $pass>>
<</if>>
<<if $lowertype isnot "naked" and $lowertype isnot "swim">>
<<set $lowerwet += $pass>>
<</if>>
<<if $undertype isnot "naked" and $undertype isnot "chastity">>
<<set $underwet += $pass>>
<</if>>
<<else>>
<<if $upperwet gte 1>>
<<set $upperwet -= $pass>>
<</if>>
<<if $lowerwet gte 1>>
<<set $lowerwet -= $pass>>
<</if>>
<<if $underwet gte 1>>
<<set $underwet -= $pass>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "pass">><<nobr>>
<<if $args[1]>>
<<if $args[1].includes("h", 0)>> <<set $pass to ($args[0]*60)>>
<<elseif $args[1].includes("d", 0)>> <<set $pass to ($args[0]*1440)>> <</if>>
<<elseif $args[0]>> <<set $pass to $args[0]>>
<<else>> <<set $pass to 0>> <</if>>
<<passwater>>
<<if $controlled is 0 and $anxiety gte 2>>
<<set $stress += $pass>>
<<elseif $controlled is 0 and $anxiety gte 1>>
<<else>>
<<set $stress -= $pass>>
<</if>>
<<if $hallucinogen gt 0>><<set $hallucinogen -= $pass>><</if>>
<<if $drunk gt 0>><<set $drunk -= $pass>><</if>>
<<if $drugged gt 0>><<set $drugged -= $pass>><</if>>
<<if $pain gt 0>><<set $pain -= $pass>><</if>>
<<if $pass gt 1200>>
<<set $hunger to 0>><<set $thirst to 0>><<set $hygiene to 0>><<set $tiredness to 0>>
<<else>>
<<set $hunger += $pass>> <<set $thirst += $pass>> <<set $hygiene += $pass>> <<set $tiredness += $pass>>
<</if>>
<<set $time += $pass>> <<set $minute += $pass>>
<<set $arousal -= $pass*10>><<arousalpass>>
<</nobr>><</widget>>
<<widget "neutral">><<nobr>>
<<if $args[0]>>
<<if $consensual isnot 1>>
<<set $stress += 10 * $args[0] >>
<<combattrauma $args[0]>>
<</if>>
<<set $arousal += 20 * $args[0]>>
<<set $enemyarousal += $args[0]>>
<</if>>
<</nobr>><</widget>>
<<widget "sex">><<nobr>>
<<if $args[0]>>
<<if $consensual isnot 1>>
<<set $stress += 10 * $args[0]>>
<<combattrauma $args[0]>>
<<else>>
<<set $stress -= 10 * $args[0]>>
<</if>>
<<set $arousal += 20 * $args[0]>>
<<set $enemyarousal += 2 * $args[0]>>
<</if>>
<</nobr>><</widget>>
<<widget "violence">><<nobr>>
<<if $args[0]>>
<<set $stress += 10 * $args[0]>>
<<combattrauma $args[0]>>
<<set $pain += $args[0]>>
<<if $args[0] gt 6>>
<<set $enemyanger -= 5>>
<<else>>
<<set $enemyanger -= $args[0]>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "submission">><<nobr>>
<<if $args[0]>>
<<if $consensual isnot 1>>
<<set $stress += 10 * $args[0]>>
<<set $submissive += 1>>
<<else>>
<<set $stress -= 10 * $args[0]>>
<<set $assertive += 1>>
<</if>>
<<set $arousal += 20 * $args[0]>>
<<set $enemyarousal += 3 * $args[0]>>
<<set $enemytrust += 2>>
<</if>>
<</nobr>><</widget>>
<<widget "defiance">><<nobr>>
<<if $args[0]>>
<<set $stress -= 10 * $args[0]>>
<<combattrauma -$args[0]>>
<<set $enemyanger += 5 * $args[0]>>
<<set $enemyhealth -= (2 * $args[0] * ($physique / 4000))>>
<<set $submissive -= 1>>
<<set $enemytrust -= 4>>
<</if>>
<</nobr>><</widget>>
<<widget "brat">><<nobr>>
<<if $args[0]>>
<<set $stress += 10 * $args[0]>>
<<combattrauma -$args[0]>>
<<set $enemyanger += 5 * $args[0]>>
<<set $submissive -= 1>>
<<set $enemytrust -= 2>>
<</if>>
<</nobr>><</widget>>
<<widget "meek">><<nobr>>
<<if $args[0]>>
<<if $consensual isnot 1>>
<<set $submissive += 1>>
<<else>>
<<set $assertive += 1>>
<</if>>
<<set $arousal += 20 * $args[0]>>
<<set $enemyarousal += $args[0]>>
<<set $enemytrust += 1>>
<</if>>
<</nobr>><</widget>>
<<widget "crime">><<nobr>>
<<if $args[0]>>
<<set $crime += $args[0]>>
<<set $crimehistory += $args[0]>>
<</if>>
<</nobr>><</widget>>
<<widget "seductionskilluse">><<set $enemyarousal += ($seductionskill / 100)>><<set $seductionskill += 5>><</widget>>
<<widget "seductionskillusecombat">><<set $enemyarousal += ($seductionskill / 100)>><<set $seductionskill += 5>><<set $seductionskillup to 1>><</widget>>
<<widget "oralskilluse">><<set $enemyarousal += ($oralskill / 100)>><<set $oralskill += 5>><<set $oralskillup to 1>><</widget>>
<<widget "vaginalskilluse">><<set $enemyarousal += ($vaginalskill / 100)>><<set $vaginalskill += 5>><<set $vaginalskillup to 1>><</widget>>
<<widget "analskilluse">><<set $enemyarousal += ($analskill / 100)>><<set $analskill += 5>><<set $analskillup to 1>><</widget>>
<<widget "handskilluse">><<set $enemyarousal += ($handskill / 100)>><<set $handskill += 5>><<set $handskillup to 1>><</widget>>
<<widget "feetskilluse">><<set $enemyarousal += ($feetskill / 100)>><<set $feetskill += 5>><<set $feetskillup to 1>><</widget>>
<<widget "bottomskilluse">><<set $enemyarousal += ($bottomskill / 100)>><<set $bottomskill += 5>><<set $bottomskillup to 1>><</widget>>
<<widget "thighskilluse">><<set $enemyarousal += ($thighskill / 100)>><<set $thighskill += 5>><<set $thighskillup to 1>><</widget>>
<<widget "chestskilluse">><<set $enemyarousal += ($chestskill / 100)>><<set $chestskill += 5>><<set $chestskillup to 1>><</widget>>
<<widget "penileskilluse">><<set $enemyarousal += ($penileskill / 100)>><<set $penileskill += 5>><<set $penileskillup to 1>><</widget>>
<<widget "skulduggeryskilluse">><<nobr>>
<<set $skulduggery += 3>><span class="gold"> You learned a thing or two about skulduggery.</span><br><br>
<</nobr>><</widget>>
<<widget "swimmingskilluse">><<nobr>>
<<set $swimmingskill += 9>><span class="gold"> You've become more confident at swimming.</span><br><br>
<</nobr>><</widget>>
<<widget "danceskilluse">><<nobr>>
<<set $danceskill += 1>><span class="gold"> You feel more confident in your dancing abilities.</span>
<</nobr>><</widget>>
<<widget "historyskill">><<nobr>>
<<set $history += 2>><<set $school += 2>>
<<if $faceacc is "glasses">>
<<set $history += 1>><<set $school += 1>>
<</if>>
<</nobr>><</widget>>
<<widget "mathsskill">><<nobr>>
<<set $maths += 2>><<set $school += 2>>
<<if $faceacc is "glasses">>
<<set $maths += 1>><<set $school += 1>>
<</if>>
<</nobr>><</widget>>
<<widget "scienceskill">><<nobr>>
<<set $science += 2>><<set $school += 2>>
<<if $faceacc is "glasses">>
<<set $science += 1>><<set $school += 1>>
<</if>>
<</nobr>><</widget>>
<<widget "englishskill">><<nobr>>
<<set $english += 2>><<set $school += 2>>
<<if $faceacc is "glasses">>
<<set $english += 1>><<set $school += 1>>
<</if>>
<</nobr>><</widget>>
<<widget "physique">><<nobr>>
<<if $args[0]>><<set _temp to $args[0]>><<else>><<set _temp to 1>><</if>>
<<set $physique += 10 * _temp>><<set $physiqueuse += _temp>><span class="gold"> You get a good workout.</span>
<</nobr>><</widget>>
<<widget "bruise">><<nobr>>
<<if $args[0]>>
<<switch $args[0]>>
<<case "face">>
<<set $facebruise += 1>>
<<case "neck">>
<<set $neckbruise += 1>>
<<case "chest">>
<<set $chestbruise += 1>>
<<case "rightarm">>
<<set $rightarmbruise += 1>>
<<case "leftarm">>
<<set $leftarmbruise += 1>>
<<case "tummy">>
<<set $tummybruise += 1>>
<<case "bottom">>
<<set $bottombruise += 1>>
<<case "thigh">>
<<set $thighbruise += 1>>
<<case "anus">>
<<set $anusbruise += 1>>
<<case "vagina">>
<<set $vaginabruise += 1>>
<<case "penis">>
<<set $penisbruise += 1>>
<<case "full">>
<<set $facebruise += 1>>
<<set $neckbruise += 1>>
<<set $chestbruise += 1>>
<<set $rightarmbruise += 1>>
<<set $leftarmbruise += 1>>
<<set $tummybruise += 1>>
<<set $bottombruise += 1>>
<<set $thighbruise += 1>>
<</switch>><</if>>
<</nobr>><</widget>>
<<widget "rapestat">><<set $rapestat += 1>><</widget>>
<<widget "moleststat">><<set $moleststat += 1>><</widget>>
<<widget "vaginalstat">><<set $vaginalstat += 1>><</widget>>
<<widget "vaginalejacstat">><<set $vaginalejacstat += 1>><<set $purity -= 1>><<internalejac>><</widget>>
<<widget "analstat">><<set $analstat += 1>><</widget>>
<<widget "analejacstat">><<set $analejacstat += 1>><<set $purity -= 1>><<internalejac>><</widget>>
<<widget "oralstat">><<set $oralstat += 1>><</widget>>
<<widget "oralejacstat">><<set $oralejacstat += 1>><<set $purity -= 1>><<internalejac>><</widget>>
<<widget "handstat">><<set $handstat += 1>><</widget>>
<<widget "handejacstat">><<set $handejacstat += 1>><</widget>>
<<widget "feetstat">><<set $feetstat += 1>><</widget>>
<<widget "feetejacstat">><<set $feetejacstat += 1>><</widget>>
<<widget "thighstat">><<set $thighstat += 1>><</widget>>
<<widget "thighejacstat">><<set $thighejacstat += 1>><</widget>>
<<widget "cheststat">><<set $cheststat += 1>><</widget>>
<<widget "chestejacstat">><<set $chestejacstat += 1>><</widget>>
<<widget "bottomstat">><<set $bottomstat += 1>><</widget>>
<<widget "bottomejacstat">><<set $bottomejacstat += 1>><</widget>>
<<widget "penilestat">><<set $penilestat += 1>><</widget>>
<<widget "penileejacstat">><<set $penileejacstat += 1>><</widget>>
<<widget "clothesstripstat">><<set $clothesstripstat += 1>><</widget>>
<<widget "clothesruinstat">><<set $clothesruinstat += 1>><</widget>>
<<widget "orgasmstat">><<set $orgasmstat += 1>><</widget>>
<<widget "ejacstat">><<set $ejacstat += 1>><</widget>>
<<widget "hitstat">><<set $hitstat += 1>><</widget>>
<<widget "attackstat">><<set $attackstat += 1>><</widget>>
<<widget "vaginalentranceejacstat">><<set $vaginalentranceejacstat += 1>>
<</widget>>
<<widget "faceejacstat">><<set $faceejacstat += 1>>
<</widget>>
<<widget "hairejacstat">><<set $hairejacstat += 1>>
<</widget>>
<<widget "tummyejacstat">><<set $tummyejacstat += 1>>
<</widget>>
<<widget "neckejacstat">><<set $neckejacstat += 1>>
<</widget>>
<<widget "dancestat">><<set $dancestat += 1>><</widget>>
<<widget "hunger">><<nobr>>
<<if $hunger gte 2000>><span class="red">You are starving!</span>
<<elseif $hunger gte 1600>><span class="pink">You are famished.</span>
<<elseif $hunger gte 1200>><span class="purple">You are hungry.</span>
<<elseif $hunger gte 800>><span class="blue">You are peckish.</span>
<<elseif $hunger gte 400>><span class="lblue">You are satisfied.</span>
<<elseif $hunger gte 1>><span class="teal">You are satiated.</span>
<<elseif $hunger lte 0>><span class="green">You are full.</span>
<</if>>
<</nobr>><</widget>>
<<widget "thirst">><<nobr>>
<<if $thirst gte 2000>><span class="red">You are dehydrated!</span>
<<elseif $thirst gte 1600>><span class="pink">You are really thirsty.</span>
<<elseif $thirst gte 1200>><span class="purple">You are thirsty.</span>
<<elseif $thirst gte 800>><span class="blue">Your throat is dry.</span>
<<elseif $thirst gte 400>><span class="lblue">You are satisfied.</span>
<<elseif $thirst gte 1>><span class="teal">You are satiated.</span>
<<elseif $thirst lte 0>><span class="green">You are full.</span>
<</if>>
<</nobr>><</widget>>
<<widget "tirednesscaption">><<nobr>>
<<if $tiredness gte 2000>><span class="red">You are exhausted.</span>
<<elseif $tiredness gte 1600>><span class="pink">You are fatigued.</span>
<<elseif $tiredness gte 1200>><span class="purple">You are tired.</span>
<<elseif $tiredness gte 800>><span class="blue">You are wearied.</span>
<<elseif $tiredness gte 400>><span class="lblue">You are alert.</span>
<<elseif $tiredness gte 1>><span class="teal">You are wide awake.</span>
<<else>><span class="green">You are refreshed.</span>
<</if>>
<<if $tiredness gte 2000>><<set $stress += (($tiredness - 2000) * 16)>><<set $trauma += (($tiredness - 2000) / 3)>>
<</if>>
<<set $tiredness = Math.clamp($tiredness, 0, $tirednessmax)>>
<<statbar $tiredness $tirednessmax>>
<</nobr>><</widget>>
<<widget "hygiene">><<nobr>>
<<if $hygiene gte 2000>><span class="red">You are filthy.</span>
<<elseif $hygiene gte 1600>><span class="pink">You are soiled.</span>
<<elseif $hygiene gte 1200>><span class="purple">You are smelly.</span>
<<elseif $hygiene gte 800>><span class="blue">You are messy.</span>
<<elseif $hygiene gte 400>><span class="lblue">You are neat.</span>
<<elseif $hygiene gte 1>><span class="teal">You are clean.</span>
<<elseif $hygiene lte 0>><span class="green">You are speckless.</span>
<</if>>
<</nobr>><</widget>>
<<widget "stresscaption">><<nobr>>
<<if $stress gte 10000>><span class="red">You are overwhelmed!</span>
<<elseif $stress gte 8000>><span class="pink">You are distressed.</span>
<<elseif $stress gte 6000>><span class="purple">You are strained.</span>
<<elseif $stress gte 4000>><span class="blue">You are tense.</span>
<<elseif $stress gte 2000>><span class="lblue">You are calm.</span>
<<elseif $stress gte 1>><span class="teal">You are placid.</span>
<<else>><span class="green">You are serene.</span>
<</if>>
<<statbar $stress $stressmax>>
<</nobr>><</widget>>
<<widget "traumacaption">><<nobr>>
<<if $trauma gte $traumamax>><span class="red">You feel numb.</span>
<<elseif $trauma gte ($traumamax / 5) * 4>><span class="pink">You are tormented.</span>
<<elseif $trauma gte ($traumamax / 5) * 3>><span class="purple">You are disturbed.</span>
<<elseif $trauma gte ($traumamax / 5) * 2>><span class="blue">You are troubled.</span>
<<elseif $trauma gte ($traumamax / 5) * 1>><span class="lblue">You are nervous.</span>
<<elseif $trauma gte 1>><span class="teal">You are uneasy.</span>
<<else>><span class="green">You are healthy.</span>
<</if>>
<<statbar $trauma $traumamax>>
<</nobr>><</widget>>
<<widget "controlcaption">><<nobr>>
<<if $control gte $controlmax>><span class="green">You are confident.</span>
<<elseif $control gte ($controlmax / 5) * 4>><span class="teal">You are insecure.</span>
<<elseif $control gte ($controlmax / 5) * 3>><span class="lblue">You are worried.</span>
<<elseif $control gte ($controlmax / 5) * 2>><span class="blue">You are anxious.</span>
<<elseif $control gte ($controlmax / 5) * 1>><span class="purple">You are scared.</span>
<<elseif $control gte 1>><span class="pink">You are frightened.</span>
<<else>><span class="red">You are terrified.</span>
<</if>>
<<statbarinverted $control $controlmax>>
<</nobr>><</widget>>
<<widget "arousalcaption">><<nobr>>
<<if $arousal gte 10000>><span class="red">You're shaking with arousal.</span>
<<elseif $arousal gte 8000>><span class="pink">You feel a heat rising within you.</span>
<<elseif $arousal gte 6000>><span class="purple">You feel horny.</span>
<<elseif $arousal gte 4000>><span class="blue">You feel lustful.</span>
<<elseif $arousal gte 2000>><span class="lblue">You feel aroused.</span>
<<elseif $arousal gte 1>><span class="teal">You feel sensual.</span>
<<else>><span class="green">You feel cold.</span>
<</if>>
<<statbar $arousal $arousalmax>>
<</nobr>><</widget>>
<<widget "allurecaption">><<nobr>>
<<if $allure gte (6000 * $alluremod)>><span class="red">You look like you need to be ravaged.</span>
<<elseif $allure gte (4000 * $alluremod)>><span class="pink">You look perverted.</span>
<<elseif $allure gte (3000 * $alluremod)>><span class="purple">You look lewd.</span>
<<elseif $allure gte (2000 * $alluremod)>><span class="blue">You stand out.</span>
<<elseif $allure gte (1500 * $alluremod)>><span class="lblue">You attract attention.</span>
<<elseif $allure gte (1000 * $alluremod)>><span class="teal">You attract glances.</span>
<<else>><span class="green">You look unremarkable.</span>
<</if>>
<div class="meter">
<<set $percent=Math.floor(($allure/(8000 * $alluremod))*100)>>
<<if $allure gte (6000 * $alluremod)>>
<<print '<div class="redbar" style="width:' + $percent + '%"></div>'>>
<<elseif $allure gte (4000 * $alluremod)>>
<<print '<div class="pinkbar" style="width:' + $percent + '%"></div>'>>
<<elseif $allure gte (3000 * $alluremod)>>
<<print '<div class="purplebar" style="width:' + $percent + '%"></div>'>>
<<elseif $allure gte (2000 * $alluremod)>>
<<print '<div class="bluebar" style="width:' + $percent + '%"></div>'>>
<<elseif $allure gte (1500 * $alluremod)>>
<<print '<div class="lbluebar" style="width:' + $percent + '%"></div>'>>
<<elseif $allure gte (1000 * $alluremod)>>
<<print '<div class="tealbar" style="width:' + $percent + '%"></div>'>>
<<else>>
<<print '<div class="greenbar" style="width:' + $percent + '%"></div>'>>
<</if>>
</div>
<</nobr>><</widget>>
<<widget "oxygencaption">><<nobr>>
<<statbarinverted $oxygen $oxygenmax>>
<</nobr>><</widget>>
<<widget "flashbacktown">><<nobr>>
<span class="red">You hear a car horn blare somewhere in the distance, and you panic. Phantom tendrils probe your body and restrict your limbs as a wordless voice jeers and promises endless debasement. It lasts only a moment, but the impression of violation remains.</span><<garousal>><<gstress>><<gtrauma>><<arousal 6>><<stress 12>><<trauma 6>><br><br>
<</nobr>><</widget>>
<<widget "flashbackhome">><<nobr>>
<span class="red">You hear a car drive past, and you panic. Phantom tendrils probe your body and restrict your limbs as a wordless voice jeers and promises endless debasement. It lasts only a moment, but the impression of violation remains.</span><<garousal>><<gstress>><<gtrauma>><<arousal 6>><<stress 12>><<trauma 6>><br><br>
<</nobr>><</widget>>
<<widget "flashbackbeach">><<nobr>>
<span class="red">You hear a gull squawk, and you panic. Phantom tendrils probe your body and restrict your limbs as a wordless voice jeers and promises endless debasement. It lasts only a moment, but the impression of violation remains.</span><<garousal>><<gstress>><<gtrauma>><<arousal 6>><<stress 12>><<trauma 6>><br><br>
<</nobr>><</widget>>
<<widget "flashbackunderground">><<nobr>>
<span class="red">You feel a tremor through the earth, and you panic. Phantom tendrils probe your body and restrict your limbs as a wordless voice jeers and promises endless debasement. It lasts only a moment, but the impression of violation remains.</span><<garousal>><<gstress>><<gtrauma>><<arousal 6>><<stress 12>><<trauma 6>><br><br>
<</nobr>><</widget>>
<<widget "flashbackschool">><<nobr>>
<span class="red">You remember the last time you were molested at school, and you panic. Phantom tendrils probe your body and restrict your limbs as a wordless voice jeers and promises endless debasement. It lasts only a moment, but the impression of violation remains.</span><<garousal>><<gstress>><<gtrauma>><<arousal 6>><<stress 12>><<trauma 6>><br><br>
<</nobr>><</widget>>
<<widget "drunk">><<nobr>>
<<if $drunk gt 0>>
<<if $drunk lte 120>>
<span class="blue">You are woozy.</span>
<<elseif $drunk lte 240>>
<span class="purple">You are tipsy.</span>
<<elseif $drunk lte 360>>
<span class="purple">You are drunk.</span>
<<elseif $drunk lte 480>>
<span class="pink">You are smashed</span>
<<else>>
<span class="pink">You are wasted</span>
<</if>>
<div class="meter">
<<set $percent=Math.floor(($drunk/1000)*100)>>
<<if $drunk gte 500>>
<<print '<div class="redbar" style="width:' + $percent + '%"></div>'>>
<<elseif $drunk gte 400>>
<<print '<div class="pinkbar" style="width:' + $percent + '%"></div>'>>
<<elseif $drunk gte 300>>
<<print '<div class="purplebar" style="width:' + $percent + '%"></div>'>>
<<elseif $drunk gte 200>>
<<print '<div class="bluebar" style="width:' + $percent + '%"></div>'>>
<<elseif $drunk gte 100>>
<<print '<div class="lbluebar" style="width:' + $percent + '%"></div>'>>
<<elseif $drunk gte 1>>
<<print '<div class="tealbar" style="width:' + $percent + '%"></div>'>>
<<else>>
<<print '<div class="greenbar" style="width:' + $percent + '%"></div>'>>
<</if>>
</div>
<</if>>
<</nobr>><</widget>>
<<widget "drugged">><<nobr>>
<<if $drugged gt 0>>
<span class="pink">A lewd warmth fills you</span>
<div class="meter">
<<set $percent=Math.floor(($drugged/1000)*100)>>
<<if $drugged gte 500>>
<<print '<div class="redbar" style="width:' + $percent + '%"></div>'>>
<<elseif $drugged gte 400>>
<<print '<div class="pinkbar" style="width:' + $percent + '%"></div>'>>
<<elseif $drugged gte 300>>
<<print '<div class="purplebar" style="width:' + $percent + '%"></div>'>>
<<elseif $drugged gte 200>>
<<print '<div class="bluebar" style="width:' + $percent + '%"></div>'>>
<<elseif $drugged gte 100>>
<<print '<div class="lbluebar" style="width:' + $percent + '%"></div>'>>
<<elseif $drugged gte 1>>
<<print '<div class="tealbar" style="width:' + $percent + '%"></div>'>>
<<else>>
<<print '<div class="greenbar" style="width:' + $percent + '%"></div>'>>
<</if>>
</div>
<</if>>
<</nobr>><</widget>>
<<widget "hallucinogen">><<nobr>>
<<if $hallucinogen gt 0>>
<span class="purple">Your perception is altered</span>
<div class="meter">
<<set $percent=Math.floor(($hallucinogen/1000)*100)>>
<<if $hallucinogen gte 500>>
<<print '<div class="redbar" style="width:' + $percent + '%"></div>'>>
<<elseif $hallucinogen gte 400>>
<<print '<div class="pinkbar" style="width:' + $percent + '%"></div>'>>
<<elseif $hallucinogen gte 300>>
<<print '<div class="purplebar" style="width:' + $percent + '%"></div>'>>
<<elseif $hallucinogen gte 200>>
<<print '<div class="bluebar" style="width:' + $percent + '%"></div>'>>
<<elseif $hallucinogen gte 100>>
<<print '<div class="lbluebar" style="width:' + $percent + '%"></div>'>>
<<elseif $hallucinogen gte 1>>
<<print '<div class="tealbar" style="width:' + $percent + '%"></div>'>>
<<else>>
<<print '<div class="greenbar" style="width:' + $percent + '%"></div>'>>
<</if>>
</div>
<</if>>
<</nobr>><</widget>>
<<widget "paincaption">><<nobr>>
<<if $pain gte 100>><span class="red">You sob uncontrollably.</span>
<<elseif $pain gte 80>><span class="pink">You cry and whimper.</span>
<<elseif $pain gte 60>><span class="purple">You are crying.</span>
<<elseif $pain gte 40>><span class="blue">Tears run down your face.</span>
<<elseif $pain gte 20>><span class="lblue">Tears well in your eyes.</span>
<<elseif $pain gte 1>><span class="teal">You are upset.</span>
<<else>><span class="green">You feel okay.</span>
<</if>>
<div class="meter">
<<set $percent=Math.floor(($pain/200)*100)>>
<<if $pain gte 100>>
<<print '<div class="redbar" style="width:' + $percent + '%"></div>'>>
<<elseif $pain gte 80>>
<<print '<div class="pinkbar" style="width:' + $percent + '%"></div>'>>
<<elseif $pain gte 60>>
<<print '<div class="purplebar" style="width:' + $percent + '%"></div>'>>
<<elseif $pain gte 40>>
<<print '<div class="bluebar" style="width:' + $percent + '%"></div>'>>
<<elseif $pain gte 20>>
<<print '<div class="lbluebar" style="width:' + $percent + '%"></div>'>>
<<elseif $pain gte 1>>
<<print '<div class="tealbar" style="width:' + $percent + '%"></div>'>>
<<else>>
<<print '<div class="greenbar" style="width:' + $percent + '%"></div>'>>
<</if>>
</div>
<</nobr>><</widget>>
<<widget "raped">><<nobr>>
<<if $rapeavoid is 1 and $consensual is 0 and $gamemode isnot "soft">>
<<set $rapeavoid to 0>><<set $rapestat += 1>><<set $famerape += $enemyno>><<set $fame += $enemyno>>
<<if $awareness lte 200>>
<<set $awareness += 5>>
<<elseif $awareness lte 400>>
<<set $awareness += 1>>
<</if>>
<<if $enemytype is "beast">>
<<set $beastrapestat += 1>>
<<if $awareness lte 300>>
<<set $awareness += 1>>
<</if>>
<</if>>
<<if $enemytype is "tentacles">>
<<set $tentaclerapestat += 1>>
<<if $awareness lte 400>>
<<set $awareness += 1>>
<</if>>
<</if>>
<<elseif $sexavoid is 1 and $consensual is 1>>
<<set $sexavoid to 0>><<set $famesex += $enemyno>><<set $fame += $enemyno>>
<<controlloss>>
<</if>>
<</nobr>><</widget>>
<<widget "molested">><<nobr>>
<<if $gamemode is "soft">>
<<set $consensual to 1>>
<</if>>
<<if $molestavoid is 1 and $consensual is 0 and $gamemode isnot "soft">>
<<set $molestavoid to 0>>
<<moleststat>>
<<if $location is "town" and $flashbacktown is 0>>
<<set $flashbacktown to 7>>
<</if>>
<<if $location is "home" and $flashbackhome is 0>>
<<set $flashbackhome to 7>>
<</if>>
<<if $location is "beach" and $flashbackbeach is 0>>
<<set $flashbackbeach to 7>>
<</if>>
<<if $awareness lte 200>>
<<set $awareness += 5>>
<<elseif $awareness lte 400>>
<<set $awareness += 1>>
<</if>>
<<if $enemytype is "beast">>
<<if $awareness lte 300>>
<<set $awareness += 1>>
<</if>>
<</if>>
<<if $enemytype is "tentacles">>
<<if $awareness lte 400>>
<<set $awareness += 1>>
<</if>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "consensual">><<nobr>>
<<if $awareness lte 200>>
<<set $awareness += 5>>
<<elseif $awareness lte 400>>
<<set $awareness += 1>>
<</if>>
<<if $enemytype is "beast">>
<<if $awareness lte 300>>
<<set $awareness += 1>>
<</if>>
<</if>>
<<if $enemytype is "tentacles">>
<<if $awareness lte 400>>
<<set $awareness += 1>>
<</if>>
<</if>>
<<set $trueconsensual to 1>>
<</nobr>><</widget>>
<<widget "controlloss">><<nobr>>
<<if $gamemode is "soft">>
<<else>>
<<set $pullaway to 0>>
<<set $novaginal to 0>>
<<set $noanal to 0>>
<<set $nopenile to 0>>
<<if $control gt 1 and $consensual is 0>>
<<if $molesttrait gte 1 and $rapeavoid is 1>>
<<else>>
<<set $controlstart to $control>><<control -25>>
<<if $control gte ($controlmax * 0.74)>>
<span class="purple">Your sense of control wavers.</span>
<<elseif $control gte ($controlmax * 0.49)>>
<span class="purple">Your sense of control falters.</span>
<<elseif $control gte ($controlmax * 0.24)>>
<span class="pink">Your sense of control cracks.</span>
<<elseif $control gte 1>>
<span class="pink">Your sense of control breaks down.</span>
<<else>>
<span class="red">Your sense of control shatters.</span>
<</if>>
<</if>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "beastescape">><<nobr>>
<<trauma 12>><<set $pain += 40>><<set $stress += 400>><<set $lowerintegrity -= 20>><<set $upperintegrity -= 20>><<set $underintegrity -= 20>><<bruise full>><<gstress>><<gtrauma>>
<</nobr>><</widget>>
<<widget "weatherdisplay">><<nobr>>
<<if $images is 1>>
<<if $daystate is "day">>
<img id="daystate" src="img/misc/day.png">
<<if $weather is "clear">>
<img id="weather" src="img/misc/clearday.png">
<<elseif $weather is "overcast">>
<img id="weather" src="img/misc/overcastday.png">
<<elseif $weather is "rain">>
<img id="weather" src="img/misc/rainday.gif">
<</if>>
<<if $location is "beach">>
<img id="location" src="img/misc/beachday.gif">
<<elseif $location is "sea">>
<img id="location" src="img/misc/beachday.gif">
<<elseif $location is "home">>
<img id="location" src="img/misc/homeday.gif">
<<elseif $location is "town">>
<img id="location" src="img/misc/townday.gif">
<<elseif $location is "forest">>
<img id="location" src="img/misc/forestday.png">
<<elseif $location is "lake">>
<img id="location" src="img/misc/lakeday.gif">
<<elseif $location is "underground">>
<img id="location" src="img/misc/deepunderground.png">
<<elseif $location is "school">>
<img id="location" src="img/misc/schoolday.png">
<<elseif $location is "cabin">>
<img id="location" src="img/misc/cabinday.gif">
<<elseif $location is "pool">>
<img id="location" src="img/misc/poolday.gif">
<</if>>
<<elseif $daystate is "night">>
<img id="daystate" src="img/misc/night.png">
<<if $weather is "clear">>
<img id="weather" src="img/misc/clearnight.png">
<<elseif $weather is "overcast">>
<img id="weather" src="img/misc/overcastnight.png">
<<elseif $weather is "rain">>
<img id="weather" src="img/misc/rainnight.gif">
<</if>>
<<if $location is "beach">>
<img id="location" src="img/misc/beachnight.gif">
<<elseif $location is "sea">>
<img id="location" src="img/misc/beachnight.gif">
<<elseif $location is "home">>
<img id="location" src="img/misc/homenight.gif">
<<elseif $location is "town">>
<img id="location" src="img/misc/townnight.gif">
<<elseif $location is "forest">>
<img id="location" src="img/misc/forestnight.png">
<<elseif $location is "lake">>
<img id="location" src="img/misc/lakenight.gif">
<<elseif $location is "underground">>
<img id="location" src="img/misc/deepunderground.png">
<<elseif $location is "school">>
<img id="location" src="img/misc/schoolnight.png">
<<elseif $location is "cabin">>
<img id="location" src="img/misc/cabinnight.gif">
<<elseif $location is "pool">>
<img id="location" src="img/misc/poolnight.gif">
<</if>>
<<elseif $daystate is "dawn">>
<img id="daystate" src="img/misc/dawn.png">
<<if $weather is "clear">>
<img id="weather" src="img/misc/cleardawn.png">
<<elseif $weather is "overcast">>
<img id="weather" src="img/misc/overcastdawn.png">
<<elseif $weather is "rain">>
<img id="weather" src="img/misc/raindawn.gif">
<</if>>
<<if $location is "beach">>
<img id="location" src="img/misc/beachdawn.gif">
<<elseif $location is "sea">>
<img id="location" src="img/misc/beachdawn.gif">
<<elseif $location is "home">>
<img id="location" src="img/misc/homedawn.gif">
<<elseif $location is "town">>
<img id="location" src="img/misc/towndawn.gif">
<<elseif $location is "forest">>
<img id="location" src="img/misc/forestdawn.png">
<<elseif $location is "lake">>
<img id="location" src="img/misc/lakedawn.gif">
<<elseif $location is "underground">>
<img id="location" src="img/misc/deepunderground.png">
<<elseif $location is "school">>
<img id="location" src="img/misc/schooldawn.png">
<<elseif $location is "cabin">>
<img id="location" src="img/misc/cabindawn.gif">
<<elseif $location is "pool">>
<img id="location" src="img/misc/pooldawn.gif">
<</if>>
<<elseif $daystate is "dusk">>
<img id="daystate" src="img/misc/dusk.png">
<<if $weather is "clear">>
<img id="weather" src="img/misc/cleardusk.png">
<<elseif $weather is "overcast">>
<img id="weather" src="img/misc/overcastdusk.png">
<<elseif $weather is "rain">>
<img id="weather" src="img/misc/raindusk.gif">
<</if>>
<<if $location is "beach">>
<img id="location" src="img/misc/beachdusk.gif">
<<elseif $location is "sea">>
<img id="location" src="img/misc/beachdusk.gif">
<<elseif $location is "home">>
<img id="location" src="img/misc/homedusk.gif">
<<elseif $location is "town">>
<img id="location" src="img/misc/towndusk.gif">
<<elseif $location is "forest">>
<img id="location" src="img/misc/forestdusk.png">
<<elseif $location is "lake">>
<img id="location" src="img/misc/lakedusk.gif">
<<elseif $location is "underground">>
<img id="location" src="img/misc/deepunderground.png">
<<elseif $location is "school">>
<img id="location" src="img/misc/schooldusk.png">
<<elseif $location is "cabin">>
<img id="location" src="img/misc/cabindusk.gif">
<<elseif $location is "pool">>
<img id="location" src="img/misc/pooldusk.gif">
<</if>>
<</if>>
<<else>>
<<if $daystate is "day">>
<<if $weather is "clear">>
It's a bright and sunny day.<br>
<<elseif $weather is "rain">>
It's a rainy day.<br>
<<elseif $weather is "overcast">>
Clouds are hiding the sun.<br>
<</if>>
<<elseif $daystate is "night">>
<<if $weather is "clear">>
The stars are shining.<br>
<<elseif $weather is "rain">>
It's a rainy night.<br>
<<elseif $weather is "overcast">>
All starlight is blocked by the clouds.<br>
<</if>>
<<elseif $daystate is "dawn">>
<<if $weather is "clear">>
The sun is rising.<br>
<<elseif $weather is "rain">>
It's a rainy morning.<br>
<<elseif $weather is "overcast">>
It's a cloudy morning.<br>
<</if>>
<<elseif $daystate is "dusk">>
<<if $weather is "clear">>
The sun is setting.<br>
<<elseif $weather is "rain">>
It's a rainy evening.<br>
<<elseif $weather is "overcast">>
It's cloudy evening.<br>
<</if>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "wearandtear">><<nobr>>
<<set $upperintegrity -= 1>><<set $lowerintegrity -= 1>><<set $underintegrity -= 1>>
<</nobr>><</widget>>
<<widget "towelup">><<nobr>>
<<if $exposed gte 1>>
<<if $upperwetstage gte 3>>
<<set $uppertowelnew to 1>><<uppertowel>>
<</if>>
<<if $lowerwetstage gte 3>>
<<set $lowertowelnew to 1>><<lowertowel>>
<</if>>
<<if $upperexposed gte 1>>
<<set $uppertowelnew to 1>><<uppertowel>>
<</if>>
<<if $lowerexposed gte 1>>
<<set $lowertowelnew to 1>><<lowertowel>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "plantupper">><<nobr>>
<<if $upperexposed gte 2 or $upperwetstage gte 3>>
<<set $upperplantnew to 1>><<upperplant>>
<</if>>
<</nobr>><</widget>>
<<widget "plantlower">><<nobr>>
<<if $lowerexposed gte 2 and $underexposed gte 1 or $lowerwetstage gte 3 and $underwetstage gte 3 or $lowerwetstage gte 3 and $underexposed gte 1>>
<<set $lowerplantnew to 1>><<lowerplant>>
<</if>>
<</nobr>><</widget>>
<<widget "plantup">><<nobr>>
<<if $upperexposed gte 2 or $upperwetstage gte 3>>
<<set $upperplantnew to 1>><<upperplant>>
<</if>>
<<if $lowerexposed gte 2 and $underexposed gte 1 or $lowerwetstage gte 3 and $underwetstage gte 3 or $lowerwetstage gte 3 and $underexposed gte 1>>
<<set $lowerplantnew to 1>><<lowerplant>>
<</if>>
<</nobr>><</widget>>
<<widget "schoolspareclothes">><<nobr>>
<<if $uppertype isnot "school" and $lowertype isnot "school">>
<<set $uppertemp to "init">><<schoolshirt>><<set $uppercolour to either("blue", "white", "red", "green", "black", "pink", "purple", "tangerine", "yellow")>><<set $upperintegrity to $schoolshirtintegritymax / 2>>
<<if $clothingselector is "m">><<set $lowertemp to "init">>
<<schoolshorts>><<set $lowercolour to either("blue", "white", "red", "green", "black", "pink", "purple", "tangerine", "yellow")>><<set $lowerintegrity to $schoolshortsintegritymax / 2>>
<<else>><<set $lowertemp to "init">>
<<schoolskirt>><<set $lowercolour to either("blue", "white", "red", "green", "black", "pink", "purple", "tangerine", "yellow")>><<set $lowerintegrity to $schoolskirtintegritymax / 2>>
<</if>>
<<elseif $lowertype isnot "school">><<set $lowertemp to "init">>
<<if $clothingselector is "m">>
<<schoolshorts>><<set $lowercolour to either("blue", "white", "red", "green", "black", "pink", "purple", "tangerine", "yellow")>><<set $lowerintegrity to $schoolshortsintegritymax / 2>>
<<else>>
<<schoolskirt>><<set $lowercolour to either("blue", "white", "red", "green", "black", "pink", "purple", "tangerine", "yellow")>><<set $lowerintegrity to $schoolskirtintegritymax / 2>>
<</if>>
<<elseif $uppertype isnot "school">>
<<set $uppertemp to "init">><<schoolshirt>><<set $uppercolour to either("blue", "white", "red", "green", "black", "pink", "purple", "tangerine", "yellow")>><<set $upperintegrity to $schoolshirtintegritymax / 2>>
<</if>>
<</nobr>><</widget>>
<<widget "spareschoolswimsuit">><<nobr>>
<<set $uppertemp to "init">><<set $lowertemp to "init">><<upperschoolswimsuit>><<set $uppercolour to either("blue", "white", "red", "green", "black", "pink", "purple", "tangerine", "yellow")>><<set $upperintegrity to $schoolshirtintegritymax / 2>>
<<set $lowertemp to "init">><<lowerschoolswimsuit>><<set $lowercolour to either("blue", "white", "red", "green", "black", "pink", "purple", "tangerine", "yellow")>><<set $lowerintegrity to $schoolshortsintegritymax / 2>>
<</nobr>><</widget>>
<<widget "spareschoolswimshorts">><<nobr>>
<<set $lowertemp to "init">><<schoolswimshorts>><<set $lowercolour to either("blue", "white", "red", "green", "black", "pink", "purple", "tangerine", "yellow")>><<set $lowerintegrity to $schoolshortsintegritymax / 2>>
<</nobr>><</widget>>
<<widget "exposure">><<nobr>>
<<if $location isnot "beach" and $location isnot "pool" and $location isnot "sea" and $location isnot "lake">>
<<set $libertine to 0>>
<<else>>
<<set $libertine to 1>>
<</if>>
<<set $upperexposedcarry to $upperexposed>>
<<set $lowerexposedcarry to $lowerexposed>>
<<set $underexposedcarry to $underexposed>>
<<if $upperwetstage gte 3>>
<<set $upperexposed to 2>>
<</if>>
<<if $lowerwetstage gte 3>>
<<set $lowerexposed to 2>>
<</if>>
<<if $underwetstage gte 3>>
<<set $underexposed to 1>>
<</if>>
<<set $breastindicator to 0>>
<<if $crossdressing isnot 1>>
<<if $underexposed gte 1 and $lowerexposed gte 2>>
<<set $playergenderappearance to $playergender>>
<<elseif $lowervaginaexposed gte 1 and $undervaginaexposed gte 1>>
<<set $playergenderappearance to $playergender>>
<<elseif $upperexposed gte 2 and $breastsize gte 3>>
<<set $playergenderappearance to "f">><<set $breastindicator to 1>>
<<elseif $lowergender isnot "n">>
<<set $playergenderappearance to $lowergender>>
<<elseif $uppergender isnot "n">>
<<set $playergenderappearance to $uppergender>>
<<elseif $undergender isnot "n" and $lowerexposed gte 2>>
<<set $playergenderappearance to $undergender>>
<<elseif $upperexposed gte 2 and $breastsize lte 2>>
<<set $playergenderappearance to "m">>
<<else>>
<<set $playergenderappearance to $playergender>>
<</if>>
<</if>>
<<set $exposed to 0>>
<<if $upperexposed gte 1>>
<<if $playergenderappearance is "m">>
<<elseif $libertine gte 1>>
<<else>>
<<set $exposed to 1>>
<</if>>
<</if>>
<<if $upperexposed gte 2 and $playergenderappearance isnot "m">>
<<set $exposed to 1>><<set $topless to 1>>
<<else>>
<<set $topless to 0>>
<</if>>
<<if $lowerexposed gte 1>>
<<if $libertine gte 1>>
<<else>>
<<set $exposed to 1>>
<</if>>
<</if>>
<<if $lowerexposed gte 2>>
<<if $underexposed gte 1>>
<<set $exposed to 2>>
<</if>>
<</if>>
<<set $upperexposed to $upperexposedcarry>>
<<set $lowerexposed to $lowerexposedcarry>>
<<set $underexposed to $underexposedcarry>>
<</nobr>><</widget>>
<<widget "integritycheck">><<nobr>>
<<if $upperclothes isnot "naked">>
<<if $upperintegrity lte 0>><span class="lewd">Your $upperclothes <<upperplural>> ripped into scraps, exposing your <<breastsstop>></span><br><<upperruined>><<clothesruinstat>><<set $upperoff to 0>>
<</if>>
<</if>>
<<if $lowerclothes isnot "naked">>
<<if $lowerintegrity lte 0>><span class="lewd">Your $lowerclothes <<lowerplural>> ripped into scraps, exposing your <<undiesstop>></span><br><<lowerruined>><<clothesruinstat>><<set $loweroff to 0>>
<</if>>
<</if>>
<<if $underclothes isnot "naked">>
<<if $underintegrity lte 0>><span class="lewd">Your $underclothes <<underplural>> ripped into scraps, exposing your <<genitalsstop>></span><br>
<<if $undertype is "chastity">>
<<set $undertype to "brokenchastity">>
<<if $vaginalchastityparasite isnot 0>>
<span class="pink">With the chastity belt gone, the $vaginalchastityparasite fall out of your vagina.</span><br><<set $vaginalchastityparasite to 0>>
<</if>>
<<if $penilechastityparasite isnot 0>>
<span class="pink">With the chastity belt gone, the $penilechastityparasite fall off of your penis.</span><br><<set $penilechastityparasite to 0>>
<</if>>
<<if $analchastityparasite isnot 0>>
<span class="pink">With the chastity belt gone, the $analchastityparasite fall out of your anus.</span><br> <<set $analchastityparasite to 0>>
<</if>>
<<if $analshield is 1>><<set $analshield to 0>>
<</if>>
<</if>>
<<underruined>><<clothesruinstat>><<set $underoff to 0>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "unbind">><<nobr>>
<<set $rightboundcarry to 0>>
<<set $leftboundcarry to 0>>
<<set $leftarm to 0>>
<<set $rightarm to 0>>
<</nobr>><</widget>>
<<widget "bindings">><<nobr>>
<<if $leftarm is "bound" and $position isnot "wall">><<set $leftboundcarry to 1>><</if>>
<<if $rightarm is "bound" and $position isnot "wall">><<set $rightboundcarry to 1>><</if>>
<<if $rightboundcarry is 1 and $rightarm isnot "bound">>
<<set $rightarm to "bound">>
<</if>>
<<if $leftboundcarry is 1 and $leftarm isnot "bound">>
<<set $leftarm to "bound">>
<</if>>
<</nobr>><</widget>>
<<widget "water">><<nobr>>
<<if $uppertype isnot "swim" and $uppertype isnot "naked">>
<<set $upperwet to 200>>
<</if>>
<<if $lowertype isnot "swim" and $lowertype isnot "naked">>
<<set $lowerwet to 200>>
<</if>>
<<if $undertype isnot "swim" and $undertype isnot "naked" and $undertype isnot "chastity">>
<<set $underwet to 200>>
<</if>>
<<waterwash>>
<<set $inwater to 1>>
<</nobr>><</widget>>
<<widget "stripactions">><<nobr>>
<<if $actionuncladoutfit is 1>><<set $actionuncladoutfit to 0>>
Feeling naughty, you remove your $upperclothes.<<uppernaked>><<lowernaked>>
<<if $undertype isnot "naked" and $undertype isnot "chastity">><<exhibitionism1>><br><br><<else>><<exhibitionism2>><br><br>
<</if>>
<</if>>
<<if $actionuncladupper is 1>><<set $actionuncladupper to 0>>
Feeling naughty, you remove your $upperclothes.<<uppernaked>>
<<if $breastsize gte 3>><<exhibitionism1>><<elseif $playergenderappearance isnot "m" and $lowergender isnot "m">><<exhibitionism1>><br><br><<else>><br><br>
<</if>>
<</if>>
<<if $actionuncladlower is 1>><<set $actionuncladlower to 0>>
Feeling naughty, you remove your $lowerclothes.<<lowernaked>>
<<if $undertype isnot "naked" and $undertype isnot "chastity">><<exhibitionism1>><br><br><<else>><<exhibitionism2>><br><br>
<</if>>
<</if>>
<<if $actionuncladunder is 1>><<set $actionuncladunder to 0>>
You remove your $underclothes with shaking fingers.<<undernaked>><<exhibitionism2>><br><br>
<</if>>
<<if $uncladoutfit is 1>>
Put your <<link $upperoff>><<set $eventskip to 1>><<outfiton>><<set $uncladoutfit to 0>><<uncladcheck>><<script>>state.display(state.active.title, null)<</script>><</link>> back on<br>
<</if>>
<<if $uncladupper is 1>>
Put your <<link $upperoff>><<set $eventskip to 1>><<upperon>><<set $uncladupper to 0>><<uncladcheck>><<script>>state.display(state.active.title, null)<</script>><</link>> back on<br>
<</if>>
<<if $uncladlower is 1>>
Put your <<link $loweroff>><<set $eventskip to 1>><<loweron>><<set $uncladlower to 0>><<uncladcheck>><<script>>state.display(state.active.title, null)<</script>><</link>> back on<br>
<</if>>
<<if $uncladunder is 1>>
Put your <<link $underoff>><<set $eventskip to 1>><<underon>><<set $uncladunder to 0>><<uncladcheck>><<script>>state.display(state.active.title, null)<</script>><</link>> back on<br>
<</if>>
<<if $undertype isnot "naked" and $undertype isnot "chastity">>
<<if $upperset is $lowerset>>
Remove your <<link $upperclothes>><<set $eventskip to 1>><<set $actionuncladoutfit to 1>><<set $uncladoutfit to 1>><<uncladcheck>><<script>>state.display(state.active.title, null)<</script>><</link>><<exhibitionist1>><br>
<</if>>
<<else>>
<<if $upperset is $lowerset and $exhibitionism gte 15>>
Remove your <<link $upperclothes>><<set $eventskip to 1>><<set $actionuncladoutfit to 1>><<set $uncladoutfit to 1>><<uncladcheck>><<script>>state.display(state.active.title, null)<</script>><</link>><<exhibitionist2>><br>
<</if>>
<</if>>
<<if $upperset isnot $lowerset and $uppertype isnot "naked">>
Remove your <<link $upperclothes>><<set $eventskip to 1>><<set $actionuncladupper to 1>><<set $uncladupper to 1>><<uncladcheck>><<script>>state.display(state.active.title, null)<</script>><</link>><<if $breastsize gte 3>><<exhibitionist1>><<elseif $playergenderappearance isnot "m" and $lowergender isnot "m">><<exhibitionist1>><</if>><br>
<</if>>
<<if $undertype isnot "naked" and $undertype isnot "chastity">>
<<if $upperset isnot $lowerset and $lowertype isnot "naked">>
Remove your <<link $lowerclothes>><<set $eventskip to 1>><<set $actionuncladlower to 1>><<set $uncladlower to 1>><<uncladcheck>><<script>>state.display(state.active.title, null)<</script>><</link>><<exhibitionist1>><br>
<</if>>
<<else>>
<<if $upperset isnot $lowerset and $lowertype isnot "naked" and $exhibitionism gte 15>>
Remove your <<link $lowerclothes>><<set $eventskip to 1>><<set $actionuncladlower to 1>><<set $uncladlower to 1>><<uncladcheck>><<script>>state.display(state.active.title, null)<</script>><</link>><<exhibitionist2>><br>
<</if>>
<</if>>
<<if $undertype isnot "naked" and $undertype isnot "chastity" and $exhibitionism gte 15>>
Remove your <<link $underclothes>><<set $eventskip to 1>><<set $actionuncladunder to 1>><<set $uncladunder to 1>><<uncladcheck>><<script>>state.display(state.active.title, null)<</script>><</link>><<exhibitionist2>><br>
<</if>>
<</nobr>><</widget>>
<<widget "stripstoreactions">><<nobr>>
<<if $actionuncladoutfit is 1>><<set $actionuncladoutfit to 0>>
<<if $storelocationinit is "wolfcave">>
You remove your $upperclothes. They may be animals, but stripping in front of them makes a chill run through your spine.
<<else>>
You check to make sure no one is around, then slowly remove your $upperclothes. Despite being alone, doing this in a public space makes a chill run through your spine.
<</if>>
<<storeupper>><<storelower>><<storelocation>><<upperundress>><<lowerundress>>
<<if $undertype isnot "naked" and $undertype isnot "chastity">><<exhibitionism1>><br><br>
<<else>>
<<exhibitionism2>><br><br>
<</if>>
<</if>>
<<if $actionuncladupper is 1>><<set $actionuncladupper to 0>>
<<if $storelocationinit is "wolfcave">>
You remove your $upperclothes. They may be animals, but stripping in front of them makes your nipples erect and your newly-exposed skin tingle.
<<else>>
You check to make sure no one is around, then slowly remove your $upperclothes. Despite being alone, doing this in a public space makes your nipples erect and your newly-exposed skin tingle.
<</if>>
<<storeupper>><<storelocation>><<upperundress>>
<<if $breastsize gte 3>><<exhibitionism1>><<elseif $playergenderappearance isnot "m" and $lowergender isnot "m">><<exhibitionism1>><br><br>
<<else>><br><br>
<</if>>
<</if>>
<<if $actionuncladlower is 1>><<set $actionuncladlower to 0>>
<<if $storelocationinit is "wolfcave">>
You remove your $lowerclothes. They may be animals, but stripping in front of them makes you shiver delightfully.
<<else>>
You check to make sure no one is around, then slowly remove your $lowerclothes. Despite being alone, doing this in a public space makes you shiver delightfully.
<</if>>
<<storelower>><<storelocation>><<lowerundress>>
<<if $undertype isnot "naked" and $undertype isnot "chastity">><<exhibitionism1>><br><br>
<<else>>
<<exhibitionism2>><br><br>
<</if>>
<</if>>
<<if $actionuncladunder is 1>><<set $actionuncladunder to 0>>
<<if $storelocationinit is "wolfcave">>
You remove your $lowerclothes. They may be animals, but stripping in front of them makes your skin and <<genitals>> tingle.
<<else>>
You check to make sure no one is around, then slowly remove your $underclothes. Despite being alone, doing this in a public space makes your skin and <<genitals>> tingle.
<</if>>
<<storeunder>><<storelocation>><<underundress>><<exhibitionism2>><br><br>
<</if>>
<<if $storelocationinit is $storelocation>>
<<link "Get Dressed">><<storeon>><<set $eventskip to 1>><<script>>state.display(state.active.title, null)<</script>><</link>><br>
<</if>>
<<if $undertype isnot "naked" and $undertype isnot "chastity">>
<<if $upperset is $lowerset>>
Remove your <<link $upperclothes>><<set $eventskip to 1>><<set $actionuncladoutfit to 1>><<script>>state.display(state.active.title, null)<</script>><</link>><<exhibitionist1>><br>
<</if>>
<<else>>
<<if $upperset is $lowerset and $exhibitionism gte 15>>
Remove your <<link $upperclothes>><<set $eventskip to 1>><<set $actionuncladoutfit to 1>><<script>>state.display(state.active.title, null)<</script>><</link>><<exhibitionist2>><br>
<</if>>
<</if>>
<<if $upperset isnot $lowerset and $uppertype isnot "naked">>
Remove your <<link $upperclothes>><<set $eventskip to 1>><<set $actionuncladupper to 1>><<script>>state.display(state.active.title, null)<</script>><</link>><<if $breastsize gte 3>><<exhibitionist1>><<elseif $playergenderappearance isnot "m" and $lowergender isnot "m">><<exhibitionist1>><</if>><br>
<</if>>
<<if $undertype isnot "naked" and $undertype isnot "chastity">>
<<if $upperset isnot $lowerset and $lowertype isnot "naked">>
Remove your <<link $lowerclothes>><<set $eventskip to 1>><<set $actionuncladlower to 1>><<script>>state.display(state.active.title, null)<</script>><</link>><<exhibitionist1>><br>
<</if>>
<<else>>
<<if $upperset isnot $lowerset and $lowertype isnot "naked" and $exhibitionism gte 15>>
Remove your <<link $lowerclothes>><<set $eventskip to 1>><<set $actionuncladlower to 1>><<script>>state.display(state.active.title, null)<</script>><</link>><<exhibitionist2>><br>
<</if>>
<</if>>
<<if $undertype isnot "naked" and $undertype isnot "chastity" and $exhibitionism gte 15>>
Remove your <<link $underclothes>><<set $eventskip to 1>><<set $actionuncladunder to 1>><<script>>state.display(state.active.title, null)<</script>><</link>><<exhibitionist2>><br>
<</if>>
<br>
<<exposure>>
<</nobr>><</widget>>
<<widget "dancestripeffects">><<nobr>>
<<if $danceaction is "outfitstripbreasts">><<set $danceaction to 0>>
You gracefully remove your $upperclothes, exposing your <<breasts>> and $underclothes. The exhibition of your breasts makes them feel raw and sensitive.
<<set $audiencearousal += 8>><<set $audienceexcitement += 8>><<set $audiencemod += 3>><<arousal 3>><<uppernaked>><<lowernaked>><<exhibitionism4>>
<</if>>
<<if $danceaction is "outfitstripchest">><<set $danceaction to 0>>
<<if $playergender is "f">>
You gracefully remove your $upperclothes, exposing your <<breasts>> and $underclothes. You feel your nipples harden in response to being revealed.
<<else>>
You gracefully remove your $upperclothes, exposing your <<breasts>> and $underclothes. Your feminine countenance makes your revealed chest feel especially lewd.
<</if>>
<<set $audiencearousal += 8>><<set $audienceexcitement += 8>><<set $audiencemod += 3>><<arousal 3>><<uppernaked>><<lowernaked>><<exhibitionism4>>
<</if>>
<<if $danceaction is "outfitstripunder">><<set $danceaction to 0>>
You gracefully remove your $upperclothes, exposing your <<breasts>> and $underclothes. You feel your nipples harden in response to being revealed.
<<set $audiencearousal += 6>><<set $audienceexcitement += 6>><<set $audiencemod += 2>><<arousal 3>><<uppernaked>><<lowernaked>><<exhibitionism3>>
<</if>>
<<if $danceaction is "outfitstripnude">><<set $danceaction to 0>>
You gracefully remove your $upperclothes, exposing your nude form. You shiver with excitement, your body laid totally bare.
<<set $audiencearousal += 10>><<set $audienceexcitement += 10>><<set $audiencemod += 4>><<arousal 3>><<uppernaked>><<lowernaked>><<exhibitionism5>>
<</if>>
<<if $danceaction is "upperstripbreasts">><<set $danceaction to 0>>
You gracefully remove your $upperclothes, exposing your <<breastsstop>> The exhibition of your breasts makes them feel raw and sensitive.
<<set $audiencearousal += 8>><<set $audienceexcitement += 8>><<set $audiencemod += 3>><<arousal 3>><<uppernaked>><<exhibitionism4>>
<</if>>
<<if $danceaction is "upperstripfchest">><<set $danceaction to 0>>
<<if $playergender is "f">>
You gracefully remove your $upperclothes, exposing your <<breastsstop>> You feel your nipples harden in response to being revealed.
<<else>>
You gracefully remove your $upperclothes, exposing your <<breastsstop>> Your feminine countenance makes your revealed chest feel especially lewd.
<</if>>
<<set $audiencearousal += 8>><<set $audienceexcitement += 8>><<set $audiencemod += 3>><<arousal 3>><<uppernaked>><<exhibitionism4>>
<</if>>
<<if $danceaction is "upperstripmchest">><<set $danceaction to 0>>
You gracefully remove your $upperclothes, exposing your <<breastsstop>> You feel your nipples harden in response to being revealed.
<<set $audiencearousal += 2>><<set $audienceexcitement += 2>><<set $audiencemod += 1>><<arousal 3>><<uppernaked>><<exhibitionism1>>
<</if>>
<<if $danceaction is "lowerstripunder">><<set $danceaction to 0>>
You gracefully remove your $lowerclothes, exposing your $underclothes. Being seen in your underwear excites you.
<<set $audiencearousal += 6>><<set $audienceexcitement += 6>><<set $audiencemod += 2>><<arousal 3>><<lowernaked>><<exhibitionism3>>
<</if>>
<<if $danceaction is "lowerstripnude">><<set $danceaction to 0>>
You gracefully remove your $lowerclothes, exposing your <<genitalsstop>>
<<if $uppertype is "naked">>
You shiver with excitement, your body laid totally bare.
<<else>>
Your $upperclothes makes your naked lower half feel particularly conspicuous.
<</if>>
<<set $audiencearousal += 10>><<set $audienceexcitement += 10>><<set $audiencemod += 4>><<arousal 3>><<lowernaked>><<exhibitionism5>>
<</if>>
<<if $danceaction is "understripskirt">><<set $danceaction to 0>>
You gracefully remove your $underclothes from beneath your $lowerclothes. You're careful not to give too much away, but such a lewd gesture thrills you nonetheless.
<<set $audiencearousal += 6>><<set $audienceexcitement += 6>><<set $audiencemod += 2>><<arousal 3>><<undernaked>><<exhibitionism3>>
<</if>>
<<if $danceaction is "understripnude">><<set $danceaction to 0>>
You gracefully remove your $underclothes, exposing your <<genitalsstop>> You shiver with excitement, your body laid totally bare.
<<set $audiencearousal += 10>><<set $audienceexcitement += 10>><<set $audiencemod += 4>><<arousal 3>><<undernaked>><<exhibitionism5>>
<</if>>
<</nobr>><</widget>>
<<widget "dancestripactions">><<nobr>>
<br><br>
<<if $upperset is $lowerset>>
<<if $undertype isnot "naked">>
<<if $breastsize gte 3>>
<<if $exhibitionism gte 55>>
<label><span class="meek">Strip $upperclothes</span> (0:05) <<combatexhibitionist4>> <<radiobutton "$danceaction" "outfitstripbreasts">></label> |
<</if>>
<<elseif $playergenderappearance isnot "m" and $lowergender isnot "m">>
<<if $exhibitionism gte 55>>
<label><span class="meek">Strip $upperclothes</span> (0:05) <<combatexhibitionist4>> <<radiobutton "$danceaction" "outfitstripchest">></label> |
<</if>>
<<else>>
<<if $exhibitionism gte 35>>
<label><span class="meek">Strip $upperclothes</span> (0:05) <<combatexhibitionist3>> <<radiobutton "$danceaction" "outfitstripunder">></label> |
<</if>>
<</if>>
<<else>>
<<if $exhibitionism gte 75>>
<label><span class="meek">Strip $upperclothes</span> (0:05) <<combatexhibitionist5>> <<radiobutton "$danceaction" "outfitstripnude">></label> |
<</if>>
<</if>>
<</if>>
<<if $uppertype isnot "naked" and $upperset isnot $lowerset>>
<<if $breastsize gte 3>>
<<if $exhibitionism gte 55>>
<label><span class="meek">Strip $upperclothes</span> (0:05) <<combatexhibitionist4>> <<radiobutton "$danceaction" "upperstripbreasts">></label> |
<</if>>
<<elseif $playergenderappearance isnot "m" and $lowergender isnot "m">>
<<if $exhibitionism gte 55>>
<label><span class="meek">Strip $upperclothes</span> (0:05) <<combatexhibitionist4>> <<radiobutton "$danceaction" "upperstripfchest">></label> |
<</if>>
<<else>>
<label><span class="meek">Strip $upperclothes</span> (0:05) <<combatexhibitionist1>> <<radiobutton "$danceaction" "upperstripmchest">></label> |
<</if>>
<</if>>
<<if $lowertype isnot "naked" and $upperset isnot $lowerset>>
<<if $undertype isnot "naked" and $undertype isnot "chastity">>
<<if $exhibitionism gte 35>>
<label><span class="meek">Strip $lowerclothes</span> (0:05) <<combatexhibitionist3>> <<radiobutton "$danceaction" "lowerstripunder">></label> |
<</if>>
<<else>>
<<if $exhibitionism gte 75>>
<label><span class="meek">Strip $lowerclothes</span> (0:05) <<combatexhibitionist5>> <<radiobutton "$danceaction" "lowerstripnude">></label> |
<</if>>
<</if>>
<</if>>
<<if $undertype isnot "naked" and $undertype isnot "chastity">>
<<if $lowertype isnot "naked" and $skirt is 1>>
<<if $exhibitionism gte 35>>
<label><span class="meek">Strip $underclothes</span> (0:05) <<combatexhibitionist3>> <<radiobutton "$danceaction" "understripskirt">></label> |
<</if>>
<<elseif $lowertype is "naked">>
<<if $exhibitionism gte 75>>
<label><span class="meek">Strip $underclothes</span> (0:05) <<combatexhibitionist5>> <<radiobutton "$danceaction" "understripnude">></label> |
<</if>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "uncladcheck">><<nobr>>
<<if $uncladoutfit isnot 1 and $uncladupper isnot 1 and $uncladlower isnot 1 and $uncladunder isnot 1>>
<<set $unclad to 0>>
<<else>>
<<set $unclad to 1>>
<</if>>
<</nobr>><</widget>>
<<widget "arousalpass">><<nobr>>
<<if $penilechastityparasite isnot 0>>
<<set $arousal += ($pass * 10)>>
<</if>>
<<if $vaginalchastityparasite isnot 0>>
<<set $arousal += ($pass * 10)>>
<</if>>
<<if $analchastityparasite isnot 0>>
<<set $arousal += ($pass * 10)>>
<</if>>
<<if $chestparasite isnot 0>>
<<set $arousal += ($pass * 10)>>
<</if>>
<<if $penisparasite isnot 0>>
<<set $arousal += ($pass * 10)>>
<</if>>
<<if $clitparasite isnot 0>>
<<set $arousal += ($pass * 10)>>
<</if>>
<</nobr>><</widget>>
<<widget "swimmingcheck">><<nobr>>
<<if $swimmingskill gte $swimmingdifficulty>>
<<set $swimmingcheck to "pass">>
<<else>>
<<set $swimmingcheck to "fail">>
<</if>>
<</nobr>><</widget>>
<<widget "undiestrauma">><<nobr>>
<<if $undertype isnot "naked" and $undertype isnot "chastity">>
<<gtrauma>><<gstress>><<trauma 1>><<stress 2>>
<<else>>
<<gtrauma>><<gstress>><<trauma 3>><<stress 6>>
<</if>>
<</nobr>><</widget>>
<<widget "goo">><<nobr>>
<<goooutsidecount>>
<<if $goooutsidecount gte 1 and $semenoutsidecount gte 1>>
<<if $goooutsidecount + $semenoutsidecount gte 100>>
<span class="red">Lewd fluid drenches you from head to toe.</span><br>
<<elseif $goooutsidecount + $semenoutsidecount gte 25>>
<span class="pink">You are drenched in slime and semen.</span><br>
<<elseif $goooutsidecount + $semenoutsidecount gte 20>>
<span class="purple">You are soaked with slime and semen.</span><br>
<<elseif $goooutsidecount + $semenoutsidecount gte 15>>
<span class="purple">Your skin is slick with slime and semen.</span><br>
<<elseif $goooutsidecount + $semenoutsidecount gte 10>>
<span class="purple">You are wet with slime and semen.</span><br>
<<elseif $goooutsidecount + $semenoutsidecount gte 5>>
<span class="purple">Your skin is moist with slime and semen.</span><br>
<<else>>
<span class="blue">You feel slime and semen on your skin.</span><br>
<</if>>
<<elseif $goooutsidecount gte 1>>
<<if $goooutsidecount gte 25>>
<span class="pink">You are drenched in slime.</span><br>
<<elseif $goooutsidecount gte 20>>
<span class="purple">You are soaked with slime.</span><br>
<<elseif $goooutsidecount gte 15>>
<span class="purple">Your skin is slick with slime.</span><br>
<<elseif $goooutsidecount gte 10>>
<span class="purple">You are wet with slime.</span><br>
<<elseif $goooutsidecount gte 5>>
<span class="purple">Your skin is moist with slime.</span><br>
<<else>>
<span class="blue">You feel slime on your skin.</span><br>
<</if>>
<<elseif $semenoutsidecount gte 1>>
<<if $semenoutsidecount gte 25>>
<span class="pink">You are drenched in semen.</span><br>
<<elseif $semenoutsidecount gte 20>>
<span class="purple">You are soaked with semen.</span><br>
<<elseif $semenoutsidecount gte 15>>
<span class="purple">Your skin is slick with semen.</span><br>
<<elseif $semenoutsidecount gte 10>>
<span class="purple">You are wet with semen.</span><br>
<<elseif $semenoutsidecount gte 5>>
<span class="purple">Your skin is moist with semen.</span><br>
<<else>>
<span class="blue">You feel semen on your skin.</span><br>
<</if>>
<</if>>
<<if $vaginagoo gte 1 and $vaginasemen gte 1>>
<<if $vaginagoo + $vaginasemen gte 5>>
<span class="red">Your womb overflows with slime and semen.</span><br>
<<elseif $vaginagoo + $vaginasemen gte 4>>
<span class="pink">Your <<pussy>> overflows with slime and semen.</span><br>
<<elseif $vaginagoo + $vaginasemen gte 3>>
<span class="pink">Slime and semen flows from your <<pussystop>></span><br>
<<elseif $vaginagoo + $vaginasemen gte 2>>
<span class="pink">Slime and semen stream from your <<pussystop>></span><br>
<<elseif $vaginagoo + $vaginasemen gte 1>>
<span class="pink">Slime and semen drip from your <<pussystop>></span><br>
<</if>>
<<elseif $vaginagoo gte 1>>
<<if $vaginagoo gte 5>>
<span class="red">Your womb overflows with slime.</span>
<<elseif $vaginagoo gte 4>>
<span class="pink">Your <<pussy>> overflows with slime.</span><br>
<<elseif $vaginagoo gte 3>>
<span class="pink">Slime flows from your <<pussystop>></span><br>
<<elseif $vaginagoo gte 2>>
<span class="pink">Slime streams from your <<pussystop>></span><br>
<<elseif $vaginagoo gte 1>>
<span class="pink">Slime drips from your <<pussystop>></span><br>
<</if>>
<<elseif $vaginasemen gte 1>>
<<if $vaginasemen gte 5>>
<span class="red">Your womb overflows with semen.</span>
<<elseif $vaginasemen gte 4>>
<span class="pink">Your <<pussy>> overflows with semen.</span><br>
<<elseif $vaginasemen gte 3>>
<span class="pink">Semen flows from your <<pussystop>></span><br>
<<elseif $vaginasemen gte 2>>
<span class="pink">Semen streams from your <<pussystop>></span><br>
<<elseif $vaginasemen gte 1>>
<span class="pink">Semen drips from your <<pussystop>></span><br>
<</if>>
<</if>>
<<if $anusgoo gte 1 and $anussemen gte 1>>
<<if $anusgoo + $anussemen gte 5>>
<span class="red">Your bowels overflow with slime and semen.</span><br>
<<elseif $anusgoo + $anussemen gte 4>>
<span class="pink">Your <<bottom>> overflows with slime and semen.</span><br>
<<elseif $anusgoo + $anussemen gte 3>>
<span class="pink">Slime and semen flows from your <<bottomstop>></span><br>
<<elseif $anusgoo + $anussemen gte 2>>
<span class="pink">Slime and semen stream from your <<bottomstop>></span><br>
<<elseif $anusgoo + $anussemen gte 1>>
<span class="pink">Slime and semen drip from your <<bottomstop>></span><br>
<</if>>
<<elseif $anusgoo gte 1>>
<<if $anusgoo gte 5>>
<span class="red">Your bowels overflow with slime.</span>
<<elseif $anusgoo gte 4>>
<span class="pink">Your <<bottom>> overflows with slime.</span><br>
<<elseif $anusgoo gte 3>>
<span class="pink">Slime flows from your <<bottomstop>></span><br>
<<elseif $anusgoo gte 2>>
<span class="pink">Slime streams from your <<bottomstop>></span><br>
<<elseif $anusgoo gte 1>>
<span class="pink">Slime drips from your <<bottomstop>></span><br>
<</if>>
<<elseif $anussemen gte 1>>
<<if $anussemen gte 5>>
<span class="red">Your bowels overflow with semen.</span>
<<elseif $anussemen gte 4>>
<span class="pink">Your <<bottom>> overflows with semen.</span><br>
<<elseif $anussemen gte 3>>
<span class="pink">Semen flows from your <<bottomstop>></span><br>
<<elseif $anussemen gte 2>>
<span class="pink">Semen streams from your <<bottomstop>></span><br>
<<elseif $anussemen gte 1>>
<span class="pink">Semen drips from your <<bottomstop>></span><br>
<</if>>
<</if>>
<<if $mouthgoo gte 1 and $mouthsemen gte 1>>
<<if $mouthgoo + $mouthsemen gte 5>>
<span class="red">You keep coughing up slime and semen.</span><br>
<<elseif $mouthgoo + $mouthsemen gte 4>>
<span class="pink">Slime and semen dribble down your chin.</span><br>
<<elseif $mouthgoo + $mouthsemen gte 3>>
<span class="pink">Slime and semen line the sides of your throat.</span><br>
<<elseif $mouthgoo + $mouthsemen gte 2>>
<span class="pink">Slime and semen layer the back of your throat.</span><br>
<<elseif $mouthgoo + $mouthsemen gte 1>>
<span class="purple">The taste of slime and semen permeates your mouth.</span><br>
<</if>>
<<elseif $mouthgoo gte 1>>
<<if $mouthgoo gte 5>>
<span class="red">You keep coughing up slime.</span><br>
<<elseif $mouthgoo gte 4>>
<span class="pink">Slime dribbles down your chin.</span><br>
<<elseif $mouthgoo gte 3>>
<span class="pink">Slime lines the sides of your throat.</span><br>
<<elseif $mouthgoo gte 2>>
<span class="pink">Slime layers the back of your throat.</span><br>
<<elseif $mouthgoo gte 1>>
<span class="purple">The taste of slime permeates your mouth.</span><br>
<</if>>
<<elseif $mouthsemen gte 1>>
<<if $mouthsemen gte 5>>
<span class="red">You keep coughing up semen.</span><br>
<<elseif $mouthsemen gte 4>>
<span class="pink">Semen dribbles down your chin.</span><br>
<<elseif $mouthsemen gte 3>>
<span class="pink">Semen lines the sides of your throat.</span><br>
<<elseif $mouthsemen gte 2>>
<span class="pink">Semen layers the back of your throat.</span><br>
<<elseif $mouthsemen gte 1>>
<span class="purple">The taste of semen permeates your mouth.</span><br>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "goocount">><<nobr>>
<<if $neckgoo gte 5>><<set $neckgoo to 5>><</if>>
<<if $rightarmgoo gte 5>><<set $rightarmgoo to 5>><</if>>
<<if $leftarmgoo gte 5>><<set $leftarmgoo to 5>><</if>>
<<if $thighgoo gte 5>><<set $thighgoo to 5>><</if>>
<<if $bottomgoo gte 5>><<set $bottomgoo to 5>><</if>>
<<if $tummygoo gte 5>><<set $tummygoo to 5>><</if>>
<<if $chestgoo gte 5>><<set $chestgoo to 5>><</if>>
<<if $facegoo gte 5>><<set $facegoo to 5>><</if>>
<<if $hairgoo gte 5>><<set $hairgoo to 5>><</if>>
<<if $feetgoo gte 5>><<set $feetgoo to 5>><</if>>
<<if $vaginaoutsidegoo gte 5>><<set $vaginaoutsidegoo to 5>><</if>>
<<if $vaginagoo gte 5>><<set $vaginagoo to 5>><</if>>
<<if $penisgoo gte 5>><<set $penisgoo to 5>><</if>>
<<if $anusgoo gte 5>><<set $anusgoo to 5>><</if>>
<<if $mouthgoo gte 5>><<set $mouthgoo to 5>><</if>>
<<set $goocount to $neckgoo + $rightarmgoo + $leftarmgoo + $thighgoo + $bottomgoo + $tummygoo + $chestgoo + $facegoo + $hairgoo + $feetgoo + $vaginaoutsidegoo + ($vaginagoo * 3) + ($penisgoo * 3) + ($anusgoo * 3) + ($mouthgoo * 3)>>
<<if $necksemen gte 5>><<set $necksemen to 5>><</if>>
<<if $rightarmsemen gte 5>><<set $rightarmsemen to 5>><</if>>
<<if $leftarmsemen gte 5>><<set $leftarmsemen to 5>><</if>>
<<if $thighsemen gte 5>><<set $thighsemen to 5>><</if>>
<<if $bottomsemen gte 5>><<set $bottomsemen to 5>><</if>>
<<if $tummysemen gte 5>><<set $tummysemen to 5>><</if>>
<<if $chestsemen gte 5>><<set $chestsemen to 5>><</if>>
<<if $facesemen gte 5>><<set $facesemen to 5>><</if>>
<<if $hairsemen gte 5>><<set $hairsemen to 5>><</if>>
<<if $feetsemen gte 5>><<set $feetsemen to 5>><</if>>
<<if $vaginaoutsidesemen gte 5>><<set $vaginaoutsidesemen to 5>><</if>>
<<if $vaginasemen gte 5>><<set $vaginasemen to 5>><</if>>
<<if $penissemen gte 5>><<set $penissemen to 5>><</if>>
<<if $anussemen gte 5>><<set $anussemen to 5>><</if>>
<<if $mouthsemen gte 5>><<set $mouthsemen to 5>><</if>>
<<set $semencount to $necksemen + $rightarmsemen + $leftarmsemen + $thighsemen + $bottomsemen + $tummysemen + $chestsemen + $facesemen + $hairsemen + $feetsemen + $vaginaoutsidesemen + ($vaginasemen * 3) + ($penissemen * 3) + ($anussemen * 3) + ($mouthsemen * 3)>>
<</nobr>><</widget>>
<<widget "goooutsidecount">><<nobr>>
<<if $neckgoo gte 5>><<set $neckgoo to 5>><</if>>
<<if $rightarmgoo gte 5>><<set $rightarmgoo to 5>><</if>>
<<if $leftarmgoo gte 5>><<set $leftarmgoo to 5>><</if>>
<<if $thighgoo gte 5>><<set $thighgoo to 5>><</if>>
<<if $bottomgoo gte 5>><<set $bottomgoo to 5>><</if>>
<<if $tummygoo gte 5>><<set $tummygoo to 5>><</if>>
<<if $chestgoo gte 5>><<set $chestgoo to 5>><</if>>
<<if $facegoo gte 5>><<set $facegoo to 5>><</if>>
<<if $hairgoo gte 5>><<set $hairgoo to 5>><</if>>
<<if $feetgoo gte 5>><<set $feetgoo to 5>><</if>>
<<if $vaginaoutsidegoo gte 5>><<set $vaginaoutsidegoo to 5>><</if>>
<<if $penisgoo gte 5>><<set $penisgoo to 5>><</if>>
<<set $goooutsidecount to $neckgoo + $rightarmgoo + $leftarmgoo + $thighgoo + $bottomgoo + $tummygoo + $chestgoo + $facegoo + $hairgoo + $feetgoo + $vaginaoutsidegoo + ($penisgoo * 3)>>
<<if $necksemen gte 5>><<set $necksemen to 5>><</if>>
<<if $rightarmsemen gte 5>><<set $rightarmsemen to 5>><</if>>
<<if $leftarmsemen gte 5>><<set $leftarmsemen to 5>><</if>>
<<if $thighsemen gte 5>><<set $thighsemen to 5>><</if>>
<<if $bottomsemen gte 5>><<set $bottomsemen to 5>><</if>>
<<if $tummysemen gte 5>><<set $tummysemen to 5>><</if>>
<<if $chestsemen gte 5>><<set $chestsemen to 5>><</if>>
<<if $facesemen gte 5>><<set $facesemen to 5>><</if>>
<<if $hairsemen gte 5>><<set $hairsemen to 5>><</if>>
<<if $feetsemen gte 5>><<set $feetsemen to 5>><</if>>
<<if $vaginaoutsidesemen gte 5>><<set $vaginaoutsidesemen to 5>><</if>>
<<if $penissemen gte 5>><<set $penissemen to 5>><</if>>
<<set $semenoutsidecount to $necksemen + $rightarmsemen + $leftarmsemen + $thighsemen + $bottomsemen + $tummysemen + $chestsemen + $facesemen + $hairsemen + $feetsemen + $vaginaoutsidesemen + ($penissemen * 3)>>
<</nobr>><</widget>>
<<widget "waterwash">><<nobr>>
<<if $combat isnot 1>>
<<if $neckgoo gte 1>><<set $waterwash += 1>><<set $allure += 500>><<set $neckgoo -= 1>><</if>>
<<if $rightarmgoo gte 1>><<set $waterwash += 1>><<set $allure += 500>><<set $rightarmgoo -= 1>><</if>>
<<if $leftarmgoo gte 1>><<set $waterwash += 1>><<set $allure += 500>><<set $leftarmgoo -= 1>><</if>>
<<if $thighgoo gte 1>><<set $waterwash += 1>><<set $allure += 500>><<set $thighgoo -= 1>><</if>>
<<if $bottomgoo gte 1>><<set $waterwash += 1>><<set $allure += 500>><<set $bottomgoo -= 1>><</if>>
<<if $tummygoo gte 1>><<set $waterwash += 1>><<set $allure += 500>><<set $tummygoo -= 1>><</if>>
<<if $chestgoo gte 1>><<set $waterwash += 1>><<set $allure += 500>><<set $chestgoo -= 1>><</if>>
<<if $facegoo gte 1>><<set $waterwash += 1>><<set $allure += 500>><<set $facegoo -= 1>><</if>>
<<if $hairgoo gte 1>><<set $waterwash += 1>><<set $allure += 500>><<set $hairgoo -= 1>><</if>>
<<if $feetgoo gte 1>><<set $waterwash += 1>><<set $allure += 500>><<set $feetgoo -= 1>><</if>>
<<if $vaginaoutsidegoo gte 1>><<set $waterwash += 1>><<set $allure += 500>><<set $vaginaoutsidegoo -= 1>><</if>>
<<if $vaginagoo gte 1>><<set $waterwash += 1>><<set $allure += 500>><<set $vaginagoo -= 1>><</if>>
<<if $penisgoo gte 1>><<set $waterwash += 1>><<set $allure += 500>><<set $penisgoo -= 1>><</if>>
<<if $anusgoo gte 1>><<set $waterwash += 1>><<set $allure += 500>><<set $anusgoo -= 1>><</if>>
<<if $mouthgoo gte 1>><<set $waterwash += 1>><<set $allure += 500>><<set $mouthgoo -= 1>><</if>>
<<if $necksemen gte 1>><<set $waterwash += 1>><<set $necksemen -= 1>><</if>>
<<if $rightarmsemen gte 1>><<set $waterwash += 1>><<set $allure += 500>><<set $rightarmsemen -= 1>><</if>>
<<if $leftarmsemen gte 1>><<set $waterwash += 1>><<set $allure += 500>><<set $leftarmsemen -= 1>><</if>>
<<if $thighsemen gte 1>><<set $waterwash += 1>><<set $allure += 500>><<set $thighsemen -= 1>><</if>>
<<if $bottomsemen gte 1>><<set $waterwash += 1>><<set $allure += 500>><<set $bottomsemen -= 1>><</if>>
<<if $tummysemen gte 1>><<set $waterwash += 1>><<set $allure += 500>><<set $tummysemen -= 1>><</if>>
<<if $chestsemen gte 1>><<set $waterwash += 1>><<set $allure += 500>><<set $chestsemen -= 1>><</if>>
<<if $facesemen gte 1>><<set $waterwash += 1>><<set $allure += 500>><<set $facesemen -= 1>><</if>>
<<if $hairsemen gte 1>><<set $waterwash += 1>><<set $allure += 500>><<set $hairsemen -= 1>><</if>>
<<if $feetsemen gte 1>><<set $waterwash += 1>><<set $allure += 500>><<set $feetsemen -= 1>><</if>>
<<if $vaginaoutsidesemen gte 1>><<set $waterwash += 1>><<set $allure += 500>><<set $vaginaoutsidesemen -= 1>><</if>>
<<if $vaginasemen gte 1>><<set $waterwash += 1>><<set $allure += 500>><<set $vaginasemen -= 1>><</if>>
<<if $penissemen gte 1>><<set $waterwash += 1>><<set $allure += 500>><<set $penissemen -= 1>><</if>>
<<if $anussemen gte 1>><<set $waterwash += 1>><<set $allure += 500>><<set $anussemen -= 1>><</if>>
<<if $mouthsemen gte 1>><<set $waterwash += 1>><<set $allure += 500>><<set $mouthsemen -= 1>><</if>>
<</if>>
<<if $waterwash gte 10>>
<span class="lewd">Copious amounts of lewd fluid washes into the water. You hope it doesn't attract attention.</span>
<<elseif $waterwash gte 5>>
<span class="lewd">Lots of lewd fluid washes into the water. You hope it doesn't attract attention.</span>
<<elseif $waterwash gte 2>>
<span class="lewd">Lewd fluid washes into the water. You hope it doesn't attract attention.</span>
<<elseif $waterwash is 1>>
<span class="lewd">Some lewd fluid washes into the water. You hope it doesn't attract attention.</span>
<</if>>
<<set $waterwash to 0>>
<</nobr>><</widget>>
<<widget "wash">><<nobr>>
<<set $neckgoo to 0>>
<<set $rightarmgoo to 0>>
<<set $leftarmgoo to 0>>
<<set $thighgoo to 0>>
<<set $bottomgoo to 0>>
<<set $tummygoo to 0>>
<<set $chestgoo to 0>>
<<set $facegoo to 0>>
<<set $hairgoo to 0>>
<<set $feetgoo to 0>>
<<set $vaginagoo to 0>>
<<set $vaginaoutsidegoo to 0>>
<<set $penisgoo to 0>>
<<set $anusgoo to 0>>
<<set $mouthgoo to 0>>
<<set $necksemen to 0>>
<<set $rightarmsemen to 0>>
<<set $leftarmsemen to 0>>
<<set $thighsemen to 0>>
<<set $bottomsemen to 0>>
<<set $tummysemen to 0>>
<<set $chestsemen to 0>>
<<set $facesemen to 0>>
<<set $hairsemen to 0>>
<<set $feetsemen to 0>>
<<set $vaginasemen to 0>>
<<set $vaginaoutsidesemen to 0>>
<<set $penissemen to 0>>
<<set $anussemen to 0>>
<<set $mouthsemen to 0>>
<</nobr>><</widget>>
<<widget "tipset">><<nobr>>
<<set $tip to random(1000, 3000)>>
<<if $tip lte 2000>>
<<set $tipreaction to "low">>
<<else>>
<<set $tipreaction to "mid">>
<</if>>
<<set $tip to $tipmod * $tip>>
<<set $tip *= (1 + ($attractiveness / 10000))>>
<<if $mathstrait gte 1>>
<<set $tip *= (1 + ($mathstrait / 4))>>
<</if>>
<<set $tip to Math.trunc($tip)>>
<</nobr>><</widget>>
<<widget "tipreceive">><<nobr>>
You make £<<print ($tip / 100)>>.
<<set $money += $tip>>
<</nobr>><</widget>>
<<widget "stealclothes">><<nobr>>
<<set $stealtextskip to 1>>
<<if $upperoff isnot 0>>
<<uppersteal>>
<</if>>
<<if $loweroff isnot 0>>
<<lowersteal>>
<</if>>
<<if $underoff isnot 0>>
<<understeal>>
<</if>>
<<set $stealtextskip to 0>>
<</nobr>><</widget>>
<<widget "passout">><<nobr>>
<<set $stress -= 5000>>
<<set $passoutstat += 1>>
<</nobr>><</widget>>
<<widget "vaginaraped">><<nobr>>
<<if $angel gte 6>>
<span class="red">Your halo shatters and your wings blacken. An overwhelming sense of loss overcomes you.</span><<set $trauma to $traumamax>><<set $fallenangel to 2>>
<<elseif $angel gte 4>>
<span class="red">Your halo shatters and fades.</span>
<</if>>
<<set $angel to 0>>
<<set $vaginafucked to 1>>
<<set $transformed to 0>>
<</nobr>><</widget>>
<<widget "penisraped">><<nobr>>
<<if $angel gte 6>>
<span class="red">Your halo shatters and your wings blacken. An overwhelming sense of loss overcomes you.</span><<set $trauma to $traumamax>><<set $fallenangel to 2>>
<<elseif $angel gte 4>>
<span class="red">Your halo shatters and fades.</span>
<</if>>
<<set $angel to 0>>
<<set $penisfucked to 1>>
<<set $transformed to 0>>
<</nobr>><</widget>>
<<widget "internalejac">><<nobr>>
<<if $demon gte 6>>
<<set $demonabsorb += 1>>
<</if>>
<</nobr>><</widget>>
<<widget "textmap">><<nobr>>
__Map__<br>
|.....Ba ─ Cl ─ St ─ Me<br>
|..╱ ╲ ╱ ╲ ╱ ╲ ╱ ╲<br>
|Do ─ Co ─ Hi ─ Ox ─ Ha<br>
|..╲ ╱ ╲ ╱ ╲ ╱ ╲ ╱<br>
|.....Da ─ Wo ─ Ni ─ El<br>
<br>
<</nobr>><</widget>>
<<widget "rentday">><<nobr>>
<<if $rentday is 1>>
Sunday.
<<elseif $rentday is 2>>
Monday.
<<elseif $rentday is 3>>
Tuesday.
<<elseif $rentday is 4>>
Wednesday.
<<elseif $rentday is 5>>
Thursday.
<<elseif $rentday is 6>>
Friday.
<<else>>
Saturday.
<</if>>
<</nobr>><</widget>>
<<widget "tearup">><<nobr>>
<<if $pain lte 20>>
<<set $pain to 20>>
<</if>>
<</nobr>><</widget>>
<<widget "roomoptions">><<nobr>>
<<pilloptions>>
<</nobr>><</widget>>
<<widget "pilloptions">><<nobr>>
<<if $pillstaken is 1>><<set $pillstaken to 0>>
You take the pills Doctor Harper prescribed. You feel dizzy.<<gcontrol>><<lawareness>><<awareness -1>><<control 10>><br><br>
<</if>>
<<if $pills gte 1 and $medicated is 0>>
<<link "Take Pills">><<set $medicated += 1>><<set $pillstaken to 1>><<script>>state.display(state.active.title, null)<</script>><</link>><br>
<</if>>
<br>
<</nobr>><</widget>>
:: Widgets Effects [widget]
<<widget "effectstime">><<nobr>>
<<time>>
<<if $time gte 1440>><<set $time -= 1440>><<set $days += 1>><<set $weekday += 1>>
<<if $weekday gte 8>><<set $weekday -= 7>><<week>><</if>>
<<day>>
<<set $physiquechange to 1>>
<</if>>
<<time>>
<<if $minute gte 60>>
<<hour>>
<</if>>
<</nobr>><</widget>>
<<widget "effectswater">><<nobr>>
<<set $wetintro to 0>>
<<if $squidcount is 1>>
<span class="purple">You feel the squid tease your <<genitalsstop>></span><<garousal>><<arousal 1>>
<<elseif $squidcount is 2>>
<span class="purple">You feel the squids tease your <<genitals>> and chest.</span><<garousal>><<arousal 2>>
<<elseif $squidcount is 3>>
<span class="purple">You feel the squids tease your <<genitals>> and <<breastsstop>></span><<garousal>><<arousal 3>>
<<elseif $squidcount is 4>>
<span class="purple">You feel the squids tease your <<genitalscomma>> <<breasts>> and <<bottomstop>></span><<garousal>><<arousal 4>>
<<elseif $squidcount gte 5>>
<span class="purple">You feel $squidcount squid tease your <<genitalscomma>> <<breastscomma>> <<bottomcomma>> and other parts of your body.</span><<garousal>><<arousal 5>><<set $arousal += ($squidcount * 10)>>
<</if>>
<<if $uppertype isnot "naked">>
<<if $upperwet gte 100 and $upperwetstage lt 3>><<set $upperwetstage to 3>><<set $wetintro to 2>>
<span class="lewd">Water soaks through your $upperclothes, exposing your <<breastsstop>></span>
<<elseif $upperwet lt 90 and $upperwetstage gte 3>><<set $upperwetstage to 2>>
<span class="green">Your $upperclothes <<upperhas>> dried, concealing your <<breastsstop>></span>
<<elseif $upperwet gte 80 and $upperwetstage lt 2>><<set $upperwetstage to 2>><<set $wetintro to 1>>
<span class="purple">Your $upperclothes <<upperplural>> wet.</span>
<<elseif $upperwet lt 70 and $upperwetstage gte 2>><<set $upperwetstage to 1>>
<span class="green">Your $upperclothes <<upperplural>> drying out.</span>
<<elseif $upperwet gte 50 and $upperwetstage lt 1>><<set $upperwetstage to 1>>
<span class="blue">Your $upperclothes <<upperplural>> damp.</span>
<<elseif $upperwet lt 40 and $upperwetstage gte 1>><<set $upperwetstage to 0>>
<span class="green">Your $upperclothes <<upperplural>> dry.</span>
<</if>>
<</if>>
<<if $lowertype isnot "naked">>
<<if $lowerwet gte 100 and $lowerwetstage lt 3>><<set $lowerwetstage to 3>><<set $wetintro to 2>>
<span class="lewd">Water soaks through your $lowerclothes, exposing your <<undiesstop>></span>
<<elseif $lowerwet lt 90 and $lowerwetstage gte 3>><<set $lowerwetstage to 2>>
<span class="green">Your $lowerclothes <<lowerhas>> dried, concealing your <<undiesstop>></span>
<<elseif $lowerwet gte 80 and $lowerwetstage lt 2>><<set $lowerwetstage to 2>><<set $wetintro to 1>>
<span class="purple">Your $lowerclothes <<lowerplural>> wet.</span>
<<elseif $lowerwet lt 70 and $lowerwetstage gte 2>><<set $lowerwetstage to 1>>
<span class="green">Your $lowerclothes <<lowerplural>> drying out.</span>
<<elseif $lowerwet gte 50 and $lowerwetstage lt 1>><<set $lowerwetstage to 1>>
<span class="blue">Your $lowerclothes <<lowerplural>> damp.</span>
<<elseif $lowerwet lt 40 and $lowerwetstage gte 1>><<set $lowerwetstage to 0>>
<span class="green">Your $lowerclothes <<lowerplural>> dry.</span>
<</if>>
<</if>>
<<if $undertype isnot "naked" and $undertype isnot "chastity">>
<<if $underwet gte 100 and $underwetstage lt 3>><<set $underwetstage to 3>><<set $wetintro to 2>>
<span class="lewd">Water soaks through your $underclothes, exposing your <<genitalsstop>></span>
<<elseif $underwet lt 90 and $underwetstage gte 3>><<set $underwetstage to 2>>
<span class="green">Your $underclothes <<underhas>> dried, concealing your <<genitalsstop>></span>
<<elseif $underwet gte 80 and $underwetstage lt 2>><<set $underwetstage to 2>><<set $wetintro to 1>>
<span class="purple">Your $underclothes <<underplural>> wet.</span>
<<elseif $underwet lt 70 and $underwetstage gte 2>><<set $underwetstage to 1>>
<span class="green">Your $underclothes <<underplural>> drying out.</span>
<<elseif $underwet gte 50 and $underwetstage lt 1>><<set $underwetstage to 1>>
<span class="blue">Your $underclothes <<underplural>> damp.</span>
<<elseif $underwet lt 40 and $underwetstage gte 1>><<set $underwetstage to 0>>
<span class="green">Your $underclothes <<underplural>> dry.</span>
<</if>>
<</if>>
<<if $wetintro gte 2>>
<<exposure>>
<<if $exhibitionism gte 55>>
You feel a lewd thrill as you look down and see your clothes cling tightly to your body, completely transparent.
<<else>>
You look down in horror at your clothes, which cling tight to your body and are completely transparent.
<</if>>
<<covered>><br><br>
<<elseif $wetintro gte 1>>
<<if $exhibitionism gte 35>>
You feel a lewd thrill as you look down and see your clothes cling tightly to your body, giving a hint of transparency.
<<else>>
You look down anxiously at your clothes, now clinging tightly to your body and giving a hint of transparency.
<</if>>
<br><br>
<</if>>
<</nobr>><</widget>>
<<widget "effects">><<nobr>>
<<compatibility>>
<<effectstime>>
<<effectswater>>
<<if $inwater is 1>>
<<else>>
<<if $squidcount gte 2>>
<span class="blue">The squid drop off you, seeking water.</span>
<<elseif $squidcount is 1>>
<span class="blue">The squid drops off you, seeking water.</span>
<</if>>
<<set $squidcount to 0>>
<</if>>
<<set $inwater to 0>>
<<if $assertiveaction isnot 0>><<set $assertivedefault to $assertiveaction>>
<<if $assertiveaction is "trauma">>
<<set $trauma -= $assertive>>
<<elseif $assertiveaction is "stress">>
<<set $stress -= ($assertive * 10)>>
<<elseif $assertiveaction is "submissive">>
<<set $submissive += ($assertive / 10)>>
<<elseif $assertiveaction is "defiant">>
<<set $submissive -= ($assertive / 10)>>
<</if>>
<<set $assertiveaction to 0; $assertive to 0>>
<</if>>
<<if $trauma gte $traumamax and $hightraumawarning isnot 1>><<set $hightraumawarning to 1>>
<span class="red">You've been so traumatised by predation you can no longer defend yourself. Coming back from this point is possible, but very difficult. You may wish to restart the game.<br>
Promiscuous, exhibitionist and deviant acts are good for managing trauma. They also suspend the effect of many negative traits.</span>
<</if>>
<<if $scienceproject is "ongoing" and $scienceprojectdays is 0 and $scienceprojectwarning isnot 1>><<set $scienceprojectwarning to 1>>
<span class="gold">The science fair is being held in the town hall on Cliff Street today from 9:00 until 18:00.</span>
<</if>>
<<if $eventskipoverrule is 1>>
<<set $eventskipoverrule to 0>>
<<if $exposed is 0>>
<<set $eventskip to 0>>
<</if>>
<</if>>
<<if $hour gte 8 and $hour lt 21>>
<<set $openinghours to 1>>
<<else>>
<<set $openinghours to 0>>
<</if>>
<<if $hour is 21>>
<<set $closinghour to 1>>
<<else>>
<<set $closinghour to 0>>
<</if>>
<<if $underwatercheck gt 0>>
<<set $underwatercheck -= 1>>
<<elseif $underwater is 1>>
<<set $underwater to 0>>
<<oxygenrefresh>>
<</if>>
<<if $demonabsorb gte 1>>
<<if $enemytype is "tentacles">>
<<set $pain -= (20 * $demonabsorb)>>
<<set $stress -= (300 * $demonabsorb)>>
<<else>>
<<set $trauma -= (150 * $demonabsorb)>>
<</if>>
<span class="lewd">You absorb the sexual essence. You feel soothed.</span>
<<set $demonabsorb to 0>>
<</if>>
<<if $control gte ($controlmax / 5) * 2>>
<<set $controlled to 1>>
<<else>>
<<set $controlled to 0>>
<</if>>
<<if $trauma gte 1>>
<<set $sleeptrouble to 1>>
<<else>>
<<set $sleeptrouble to 0>>
<</if>>
<<if $trauma gte ($traumamax / 10) * 1>>
<<set $nightmares to 1>>
<<else>>
<<set $nightmares to 0>>
<</if>>
<<if $trauma gte ($traumamax / 10) * 7>>
<<set $anxiety to 2>>
<<elseif $trauma gte ($traumamax / 10) * 2>>
<<set $anxiety to 1>>
<<else>>
<<set $anxiety to 0>>
<</if>>
<<if $trauma gte ($traumamax / 10) * 8>>
<<set $flashbacks to 1>>
<<else>>
<<set $flashbacks to 0>>
<</if>>
<<if $trauma gte ($traumamax / 10) * 6>>
<<set $panicattacks to 2>>
<<elseif $trauma gte ($traumamax / 10) * 4>>
<<set $panicattacks to 1>>
<<else>>
<<set $panicattacks to 0>>
<</if>>
<<if $trauma gte ($traumamax / 10) * 5>>
<<set $hallucinations to 2>>
<<elseif $trauma gte ($traumamax / 10) * 3>>
<<set $hallucinations to 1>>
<<else>>
<<set $hallucinations to 0>>
<</if>>
<<if $awareness gte 400 or $hallucinogen gt 0>>
<<set $hallucinations to 2>>
<<elseif $awareness gte 300 and $hallucinations lte 1>>
<<set $hallucinations to 1>>
<</if>>
<<if $trauma gte $traumamax>>
<<set $dissociation to 2>>
<<elseif $trauma gte ($traumamax / 10) * 9>>
<<set $dissociation to 1>>
<<else>>
<<set $dissociation to 0>>
<</if>>
<<if $location is "town">>
<<if $flashbacktownready is 1 and $controlled is 0>>
<<set $flashbacktownready to 0>>
<<flashbacktown>>
<</if>>
<</if>>
<<if $location is "home">>
<<if $flashbackhomeready is 1 and $controlled is 0>>
<<set $flashbackhomeready to 0>>
<<flashbackhome>>
<</if>>
<</if>>
<<if $location is "beach">>
<<if $flashbackbeachready is 1 and $controlled is 0>>
<<set $flashbackbeachready to 0>>
<<flashbackbeach>>
<</if>>
<</if>>
<<if $location is "underground">>
<<if $flashbackundergroundready is 1 and $controlled is 0>>
<<set $flashbackundergroundready to 0>>
<<flashbackunderground>>
<</if>>
<</if>>
<<if $location is "school">>
<<if $flashbackschoolready is 1 and $controlled is 0>>
<<set $flashbackschoolready to 0>>
<<flashbackschool>>
<</if>>
<</if>>
<<set $breastindicator to 0>>
<<if $crossdressing isnot 1>>
<<if $underexposed gte 1 and $lowerexposed gte 2>>
<<set $playergenderappearance to $playergender>>
<<elseif $lowervaginaexposed gte 1 and $undervaginaexposed gte 1>>
<<set $playergenderappearance to $playergender>>
<<elseif $upperexposed gte 2 and $breastsize gte 3>>
<<set $playergenderappearance to "f">><<set $breastindicator to 1>>
<<elseif $lowergender isnot "n">>
<<set $playergenderappearance to $lowergender>>
<<elseif $uppergender isnot "n">>
<<set $playergenderappearance to $uppergender>>
<<elseif $undergender isnot "n" and $lowerexposed gte 2>>
<<set $playergenderappearance to $undergender>>
<<elseif $upperexposed gte 2 and $breastsize lte 2>>
<<set $playergenderappearance to "m">>
<<else>>
<<set $playergenderappearance to $playergender>>
<</if>>
<</if>>
<<if $clothingrebuytext is 1>><<set $clothingrebuytext to 0>>
<span class="lblue">Your ruined clothing signals for a replacement.</span>
<</if>>
<<if $clothingrebuyfailedtext is 1>><<set $clothingrebuyfailedtext to 0>>
<span class="purple">Your ruined clothing tries to signal for a replacement, but you can't afford it.</span>
<</if>>
<<integritycheck>>
<<exposure>>
<<set $orgasmdown -= 1>>
<<if $exposed gte 1 and $exposedcheck is 1>><<set $exposedcheck to 0>>
You feel selfconscious about your <<nuditystop>><br>
<</if>>
<<exposure>>
<<if $timer gte 1>>
<<set $timer -= 1>>
<</if>>
<<bindings>>
<br>
<<set $menu to 0>>
<</nobr>><</widget>>
:: Widgets Text [widget]
<<widget "catcall">><<nobr>>
"<<print either("Hey beautiful.",
"Hey gorgeous.",
"Looking good.",
"Looking fine.",
"You look sumptuous,<<girlstop>>",
"You look ravishing,<<girlstop>>",
"You look stunning,<<girlstop>>",
"You look superb,<<girlstop>>",
"Hey <<girlcomma>> want some of this?",
"Nice butt.",
"I'd love a taste of you.")>>"
<</nobr>><</widget>>
<<widget "lewdcatcall">><<nobr>>
"<<print either("Looks like someone wants to be raped.",
"What a slut!",
"What a whore!",
"Why would you dress like that?",
"That's one way to get attention.",
"You can't complain if someone hurts you while walking around like that.",
"L-lewd!")>>"
<</nobr>><</widget>>
<<widget "schoolcatcall">><<nobr>>
"<<print either("Hey sexy.",
"Hey <<girlstop>>",
"Looking good.",
"Looking fine.",
"You look cute,<<girlstop>>",
"You look ravishing,<<girlstop>>",
"You look stunning,<<girlstop>>",
"You look superb,<<girlstop>>",
"Hey <<girlcomma>> want some of this?",
"Nice butt.",
"You look tasty.")>>"
<</nobr>><</widget>>
<<widget "bodyparts">><<print either("hands", "feet", "thighs", "legs", "tummy", "cheek", "bottom", "chest", "face", "arms", "shoulder", "back")>><</widget>>
<<widget "lowerbodyparts">><<print either("hands", "feet", "thighs", "bottom")>><</widget>>
<<widget "upperword">><<nobr>>
<<if $upperword is "a">>a <</if>>
<<if $upperword is "n">><</if>>
<</nobr>><</widget>>
<<widget "lowerword">><<nobr>>
<<if $lowerword is "a">>a <</if>>
<<if $lowerword is "n">><</if>>
<</nobr>><</widget>>
<<widget "underword">><<nobr>>
<<if $underword is "a">>a <</if>>
<<if $underword is "n">><</if>>
<</nobr>><</widget>>
<<widget "upperplural">><<nobr>>
<<if $upperplural is 1>>are
<<else>>is<</if>>
<</nobr>><</widget>>
<<widget "lowerplural">><<nobr>>
<<if $lowerplural is 1>>are
<<else>>is<</if>>
<</nobr>><</widget>>
<<widget "underplural">><<nobr>>
<<if $underplural is 1>>are
<<else>>is<</if>>
<</nobr>><</widget>>
<<widget "upperitis">><<nobr>>
<<if $upperplural is 1>>they are
<<else>>it is<</if>>
<</nobr>><</widget>>
<<widget "loweritis">><<nobr>>
<<if $lowerplural is 1>>they are
<<else>>it is<</if>>
<</nobr>><</widget>>
<<widget "underitis">><<nobr>>
<<if $underplural is 1>>they are
<<else>>it is<</if>>
<</nobr>><</widget>>
<<widget "upperit">><<nobr>>
<<if $upperplural is 1>>them
<<else>>it<</if>>
<</nobr>><</widget>>
<<widget "lowerit">><<nobr>>
<<if $lowerplural is 1>>them
<<else>>it<</if>>
<</nobr>><</widget>>
<<widget "underit">><<nobr>>
<<if $underplural is 1>>them
<<else>>it<</if>>
<</nobr>><</widget>>
<<widget "upperhas">><<nobr>>
<<if $upperplural is 1>>have
<<else>>has<</if>>
<</nobr>><</widget>>
<<widget "lowerhas">><<nobr>>
<<if $lowerplural is 1>>have
<<else>>has<</if>>
<</nobr>><</widget>>
<<widget "underhas">><<nobr>>
<<if $underplural is 1>>have
<<else>>has<</if>>
<</nobr>><</widget>>
<<widget "a">><<nobr>>
<<if $enemyno gte 2 and $enemytype is "man">>
a
<<else>>
<<his>>
<</if>>
<</nobr>><</widget>>
<<widget "theowner">><<nobr>>
<<if $enemyno gte 2 and $enemytype is "man">>
the owner
<<else>>
<<he>>
<</if>>
<</nobr>><</widget>>
<<widget "someones">><<nobr>>
<<if $enemyno gte 2 and $enemytype is "man">>
<<set $rng to random(1, $enemyno)>>
<<if $rng is 1>>
<<his1>>
<<elseif $rng is 2>>
<<his2>>
<<elseif $rng is 3>>
<<his3>>
<<elseif $rng is 4>>
<<his4>>
<<elseif $rng is 5>>
<<his5>>
<<elseif $rng is 6>>
<<his6>>
<</if>>
<<else>>
<<his>>
<</if>>
<</nobr>><</widget>>
<<widget "someone">><<nobr>>
<<if $enemyno gte 2 and $enemytype is "man">>
someone
<<else>>
<<him>>
<</if>>
<</nobr>><</widget>>
<<widget "their">><<nobr>>
<<if $enemyno gte 2 and $enemytype is "man">>
their
<<else>>
<<his>>
<</if>>
<</nobr>><</widget>>
<<widget "he">><<nobr>>
<<if $pronoun is "m">>he
<</if>>
<<if $pronoun is "f">>she
<</if>>
<<if $pronoun is "i">>it
<</if>>
<<if $pronoun is "n">>one
<</if>>
<<if $pronoun is "t">>they
<</if>>
<</nobr>><</widget>>
<<widget "hes">><<nobr>>
<<if $pronoun is "m">>he's
<</if>>
<<if $pronoun is "f">>she's
<</if>>
<<if $pronoun is "i">>its
<</if>>
<<if $pronoun is "n">>one is
<</if>>
<<if $pronoun is "t">>they are
<</if>>
<</nobr>><</widget>>
<<widget "his">><<nobr>>
<<if $pronoun is "m">>his
<</if>>
<<if $pronoun is "f">>her
<</if>>
<<if $pronoun is "i">>its
<</if>>
<<if $pronoun is "n">>the
<</if>>
<<if $pronoun is "t">>their
<</if>>
<</nobr>><</widget>>
<<widget "He">><<nobr>>
<<if $args[0]>>
<<if $enemytype is "man">>
<<if $args[0] is 1>>
<<person1>>
<<elseif $args[0] is 2>>
<<person2>>
<<elseif $args[0] is 3>>
<<person3>>
<<elseif $args[0] is 4>>
<<person4>>
<<elseif $args[0] is 5>>
<<person5>>
<<elseif $args[0] is 6>>
<<person6>>
<</if>>
<</if>>
<<if $pronoun is "m">>He
<</if>>
<<if $pronoun is "f">>She
<</if>>
<<if $pronoun is "i">>It
<</if>>
<<if $pronoun is "n">>One
<</if>>
<<if $pronoun is "t">>They
<</if>>
<<elseif $intro1 is 1>><<set $intro1 to 0>><<person1>>
<<if $npc is 0>>
The <<person>>
<<else>>
$npc
<</if>>
<<elseif $intro2 is 1>><<set $intro2 to 0>><<person2>>The <<person>>
<<elseif $intro3 is 1>><<set $intro3 to 0>><<person3>>The <<person>>
<<elseif $intro4 is 1>><<set $intro4 to 0>><<person4>>The <<person>>
<<elseif $intro5 is 1>><<set $intro5 to 0>><<person5>>The <<person>>
<<elseif $intro6 is 1>><<set $intro6 to 0>><<person6>>The <<person>>
<<else>>
<<if $pronoun is "m">>He
<</if>>
<<if $pronoun is "f">>She
<</if>>
<<if $pronoun is "i">>It
<</if>>
<<if $pronoun is "n">>One
<</if>>
<<if $pronoun is "t">>They
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "His">><<nobr>>
<<if $pronoun is "m">>His
<</if>>
<<if $pronoun is "f">>Her
<</if>>
<<if $pronoun is "i">>Its
<</if>>
<<if $pronoun is "n">>The
<</if>>
<<if $pronoun is "t">>Their
<</if>>
<</nobr>><</widget>>
<<widget "Hes">><<nobr>>
<<if $pronoun is "m">>He's
<</if>>
<<if $pronoun is "f">>She's
<</if>>
<<if $pronoun is "i">>Its
<</if>>
<<if $pronoun is "n">>One is
<</if>>
<<if $pronoun is "t">>They are
<</if>>
<</nobr>><</widget>>
<<widget "him">><<nobr>>
<<if $pronoun is "m">>him
<</if>>
<<if $pronoun is "f">>her
<</if>>
<<if $pronoun is "i">>it
<</if>>
<<if $pronoun is "n">>them
<</if>>
<<if $pronoun is "t">>them
<</if>>
<</nobr>><</widget>>
<<widget "himstop">><<nobr>>
<<if $pronoun is "m">>him.
<</if>>
<<if $pronoun is "f">>her.
<</if>>
<<if $pronoun is "i">>it.
<</if>>
<<if $pronoun is "n">>them.
<</if>>
<<if $pronoun is "t">>them.
<</if>>
<</nobr>><</widget>>
<<widget "himcomma">><<nobr>>
<<if $pronoun is "m">>him,
<</if>>
<<if $pronoun is "f">>her,
<</if>>
<<if $pronoun is "i">>it,
<</if>>
<<if $pronoun is "n">>them,
<</if>>
<<if $pronoun is "t">>them,
<</if>>
<</nobr>><</widget>>
<<widget "Him">><<nobr>>
<<if $pronoun is "m">>Him
<</if>>
<<if $pronoun is "f">>Her
<</if>>
<<if $pronoun is "i">>It
<</if>>
<<if $pronoun is "n">>Them
<</if>>
<<if $pronoun is "t">>Them
<</if>>
<</nobr>><</widget>>
<<widget "his1">><<nobr>>
<<if $enemytype is "man" and $enemyno gte 2>>
<<person1>>
<<if $intro1 is 1>><<set $intro1 to 0>>
the <<persons>>
<<else>>
<<his>>
<</if>>
<<else>>
<<his>>
<</if>>
<</nobr>><</widget>>
<<widget "his2">><<nobr>>
<<if $enemytype is "man" and $enemyno gte 2>>
<<person2>>
<<if $intro2 is 1>><<set $intro2 to 0>>
the <<persons>>
<<else>>
<<his>>
<</if>>
<<else>>
<<his>>
<</if>>
<</nobr>><</widget>>
<<widget "his3">><<nobr>>
<<if $enemytype is "man" and $enemyno gte 2>>
<<person3>>
<<if $intro3 is 1>><<set $intro3 to 0>>
the <<persons>>
<<else>>
<<his>>
<</if>>
<<else>>
<<his>>
<</if>>
<</nobr>><</widget>>
<<widget "his4">><<nobr>>
<<if $enemytype is "man" and $enemyno gte 2>>
<<person4>>
<<if $intro4 is 1>><<set $intro4 to 0>>
the <<persons>>
<<else>>
<<his>>
<</if>>
<<else>>
<<his>>
<</if>>
<</nobr>><</widget>>
<<widget "his5">><<nobr>>
<<if $enemytype is "man" and $enemyno gte 2>>
<<person5>>
<<if $intro5 is 1>><<set $intro5 to 0>>
the <<persons>>
<<else>>
<<his>>
<</if>>
<<else>>
<<his>>
<</if>>
<</nobr>><</widget>>
<<widget "his6">><<nobr>>
<<if $enemytype is "man" and $enemyno gte 2>>
<<person6>>
<<if $intro6 is 1>><<set $intro6 to 0>>
the <<persons>>
<<else>>
<<his>>
<</if>>
<<else>>
<<his>>
<</if>>
<</nobr>><</widget>>
<<widget "himself">><<nobr>>
<<if $pronoun is "m">>
himself
<<else>>
herself
<</if>>
<</nobr>><</widget>>
<<widget "himselfcomma">><<nobr>>
<<if $pronoun is "m">>
himself,
<<else>>
herself,
<</if>>
<</nobr>><</widget>>
<<widget "himselfstop">><<nobr>>
<<if $pronoun is "m">>
himself.
<<else>>
herself.
<</if>>
<</nobr>><</widget>>
<<widget "people">><<nobr>>
<<if $malechance is 100>>
men
<<elseif $malechance is 0>>
women
<<else>>
men and women
<</if>>
<</nobr>><</widget>>
<<widget "peoplestop">><<nobr>>
<<if $malechance is 100>>
men.
<<elseif $malechance is 0>>
women.
<<else>>
men and women.
<</if>>
<</nobr>><</widget>>
<<widget "peoplecomma">><<nobr>>
<<if $malechance is 100>>
men,
<<elseif $malechance is 0>>
women,
<<else>>
men and women,
<</if>>
<</nobr>><</widget>>
<<widget "peopley">><<nobr>>
<<if $malechance is 100>>
boys
<<elseif $malechance is 0>>
girls
<<else>>
boys and girls
<</if>>
<</nobr>><</widget>>
<<widget "peopleystop">><<nobr>>
<<if $malechance is 100>>
boys.
<<elseif $malechance is 0>>
girls.
<<else>>
boys and girls.
<</if>>
<</nobr>><</widget>>
<<widget "peopleycomma">><<nobr>>
<<if $malechance is 100>>
boys,
<<elseif $malechance is 0>>
girls,
<<else>>
boys and girls,
<</if>>
<</nobr>><</widget>>
<<widget "persony">><<nobr>>
<<set $rng to random(1, 100)>>
<<if $malechance is 100>>
boy
<<elseif $malechance is 0>>
girl
<<elseif $rng gte 51>>
boy
<<else>>
girl
<</if>>
<</nobr>><</widget>>
<<widget "personycomma">><<nobr>>
<<set $rng to random(1, 100)>>
<<if $malechance is 100>>
boy,
<<elseif $malechance is 0>>
girl,
<<elseif $rng gte 51>>
boy,
<<else>>
girl,
<</if>>
<</nobr>><</widget>>
<<widget "personystop">><<nobr>>
<<set $rng to random(1, 100)>>
<<if $malechance is 100>>
boy.
<<elseif $malechance is 0>>
girl.
<<elseif $rng gte 51>>
boy.
<<else>>
girl.
<</if>>
<</nobr>><</widget>>
<<widget "pshe">><<nobr>><<if $playergenderappearance is "m">>he<<elseif $playergenderappearance is "f">>she<</if>><</nobr>><</widget>>
<<widget "pShe">><<nobr>><<if $playergenderappearance is "m">>He<<elseif $playergenderappearance is "f">>She<</if>><</nobr>><</widget>>
<<widget "pshes">><<nobr>><<if $playergenderappearance is "m">>he's<<elseif $playergenderappearance is "f">>she's<</if>><</nobr>><</widget>>
<<widget "pShes">><<nobr>><<if $playergenderappearance is "m">>He's<<elseif $playergenderappearance is "f">>She's<</if>><</nobr>><</widget>>
<<widget "pher">><<nobr>><<if $playergenderappearance is "m">>his<<elseif $playergenderappearance is "f">>her<</if>><</nobr>><</widget>>
<<widget "phercomma">><<nobr>><<if $playergenderappearance is "m">>his,<<elseif $playergenderappearance is "f">>her,<</if>><</nobr>><</widget>>
<<widget "pherstop">><<nobr>><<if $playergenderappearance is "m">>his.<<elseif $playergenderappearance is "f">>her.<</if>><</nobr>><</widget>>
<<widget "pHer">><<nobr>><<if $playergenderappearance is "m">>His<<elseif $playergenderappearance is "f">>Her<</if>><</nobr>><</widget>>
<<widget "phim">><<nobr>><<if $playergenderappearance is "m">>him<<elseif $playergenderappearance is "f">>her<</if>><</nobr>><</widget>>
<<widget "phimcomma">><<nobr>><<if $playergenderappearance is "m">>him,<<elseif $playergenderappearance is "f">>her,<</if>><</nobr>><</widget>>
<<widget "phimstop">><<nobr>><<if $playergenderappearance is "m">>him.<<elseif $playergenderappearance is "f">>her.<</if>><</nobr>><</widget>>
<<widget "pHim">><<nobr>><<if $playergenderappearance is "m">>Him<<elseif $playergenderappearance is "f">>Her<</if>><</nobr>><</widget>>
<<widget "pherself">><<nobr>><<if $playergenderappearance is "m">>himself<<elseif $playergenderappearance is "f">>herself<</if>><</nobr>><</widget>>
<<widget "pHerself">><<nobr>><<if $playergenderappearance is "m">>Himself<<elseif $playergenderappearance is "f">>Herself<</if>><</nobr>><</widget>>
<<widget "animals">><<nobr>>
<<print either("Bees", "elephants", "bunnies", "octopi", "chimps", "squid", "molluscs", "monkeys", "wasps", "baboons", "wolves", "bears", "elk", "seals", "dolphins", "whales", "jellyfish", "cats", "lions", "tigers", "cheetahs", "wild dogs", "panthers", "moles", "badgers", "honey badgers", "ducks", "geese", "sparrows", "robins", "perch", "pike", "salmon", "sturgeon", "frogs", "newts", "crocodiles", "toads", "hawks", "eagles", "cuttlefish", "pythons", "anacondas", "adders", "cobras", "sturgeon", "trout", "salmon", "tuna", "deer", "robins")>>
<</nobr>><</widget>>
<<widget "garden">><<nobr>>
<<print either("prune flowers", "prune trees", "prune bushes", "water flowers", "remove weeds")>>
<</nobr>><</widget>>
<<widget "breasts">><<nobr>>
<<if $breastcup is "none">>
<<if $playergender is "f">>
<<if $dev is 1>>
<<print "undeveloped breasts">>
<<else>>
<<print "nipples">>
<</if>>
<<else>>
<<print "nipples">>
<</if>>
<</if>>
<<if $breastcup is "budding">>
<<if $dev is 1>>
<<print "budding breasts">>
<<else>>
<<print "budding breasts">>
<</if>>
<</if>>
<<if $breastcup is "AA">>
<<print "tiny breasts">>
<</if>>
<<if $breastcup is "B">>
<<print "small breasts">>
<</if>>
<<if $breastcup is "C">>
<<print "pert breasts">>
<</if>>
<<if $breastcup is "D">>
<<print "modest breasts">>
<</if>>
<<if $breastcup is "DD">>
<<print "full breasts">>
<</if>>
<<if $breastcup is "DDD">>
<<print "large breasts">>
<</if>>
<<if $breastcup is "F">>
<<print "ample breasts">>
<</if>>
<<if $breastcup is "G">>
<<print "massive breasts">>
<</if>>
<<if $breastcup is "H">>
<<print "huge breasts">>
<</if>>
<<if $breastcup is "I">>
<<print "gigantic breasts">>
<</if>>
<<if $breastcup is "J">>
<<print "enormous breasts">>
<</if>>
<</nobr>><</widget>>
<<widget "breastsstop">><<nobr>>
<<if $breastcup is "none">>
<<if $playergender is "f">>
<<if $dev is 1>>
<<print "undeveloped breasts.">>
<<else>>
<<print "nipples.">>
<</if>>
<<else>>
<<print "nipples.">>
<</if>>
<</if>>
<<if $breastcup is "budding">>
<<if $dev is 1>>
<<print "budding breasts.">>
<<else>>
<<print "budding breasts.">>
<</if>>
<</if>>
<<if $breastcup is "AA">>
<<print "tiny breasts.">>
<</if>>
<<if $breastcup is "B">>
<<print "small breasts.">>
<</if>>
<<if $breastcup is "C">>
<<print "pert breasts.">>
<</if>>
<<if $breastcup is "D">>
<<print "modest breasts.">>
<</if>>
<<if $breastcup is "DD">>
<<print "full breasts.">>
<</if>>
<<if $breastcup is "DDD">>
<<print "large breasts.">>
<</if>>
<<if $breastcup is "F">>
<<print "ample breasts.">>
<</if>>
<<if $breastcup is "G">>
<<print "massive breasts.">>
<</if>>
<<if $breastcup is "H">>
<<print "huge breasts.">>
<</if>>
<<if $breastcup is "I">>
<<print "gigantic breasts.">>
<</if>>
<<if $breastcup is "J">>
<<print "enormous breasts.">>
<</if>>
<</nobr>><</widget>>
<<widget "breastscomma">><<nobr>>
<<if $breastcup is "none">>
<<if $playergender is "f">>
<<if $dev is 1>>
<<print "undeveloped breasts,">>
<<else>>
<<print "nipples,">>
<</if>>
<<else>>
<<print "nipples,">>
<</if>>
<</if>>
<<if $breastcup is "budding">>
<<if $dev is 1>>
<<print "budding breasts,">>
<<else>>
<<print "budding breasts,">>
<</if>>
<</if>>
<<if $breastcup is "AA">>
<<print "tiny breasts,">>
<</if>>
<<if $breastcup is "B">>
<<print "small breasts,">>
<</if>>
<<if $breastcup is "C">>
<<print "pert breasts,">>
<</if>>
<<if $breastcup is "D">>
<<print "modest breasts,">>
<</if>>
<<if $breastcup is "DD">>
<<print "full breasts,">>
<</if>>
<<if $breastcup is "DDD">>
<<print "large breasts,">>
<</if>>
<<if $breastcup is "F">>
<<print "ample breasts,">>
<</if>>
<<if $breastcup is "G">>
<<print "massive breasts,">>
<</if>>
<<if $breastcup is "H">>
<<print "huge breasts,">>
<</if>>
<<if $breastcup is "I">>
<<print "gigantic breasts,">>
<</if>>
<<if $breastcup is "J">>
<<print "enormous breasts,">>
<</if>>
<</nobr>><</widget>>
<<widget "bottom">><<nobr>>
<<set $rng to random(1, 100)>>
<<if $rng gte 91>>
ass
<<else>>
ass
<</if>>
<</nobr>><</widget>>
<<widget "bottomstop">><<nobr>>
<<set $rng to random(1, 100)>>
<<if $rng gte 91>>
ass.
<<else>>
ass.
<</if>>
<</nobr>><</widget>>
<<widget "bottomcomma">><<nobr>>
<<set $rng to random(1, 100)>>
<<if $rng gte 91>>
ass,
<<else>>
ass,
<</if>>
<</nobr>><</widget>>
<<widget "pussy">><<nobr>>
<<if $devstate gte 1>>
<<if $orgasmcount gte 23>>
<<if $orgasmdown gte 1>>
tortured pussy
<<else>>
spent pussy
<</if>>
<<elseif $orgasmcount gte 9>>
<<if $orgasmdown gte 1>>
twitching pussy
<<else>>
tired pussy
<</if>>
<<else>>
<<if $orgasmdown gte 1>>
twitching pussy
<<else>>
<<if $arousal gte 8000>>
tingling pussy
<<elseif $arousal gte 6000>>
cunt
<<elseif $arousal gte 4000>>
pussy
<<elseif $arousal gte 2000>>
quim
<<else>>
pussy
<</if>>
<</if>>
<</if>>
<<else>>
<<if $orgasmcount gte 23>>
<<if $orgasmdown gte 1>>
tortured little pussy
<<else>>
spent little pussy
<</if>>
<<elseif $orgasmcount gte 9>>
<<if $orgasmdown gte 1>>
twitching pussy
<<else>>
tired little pussy
<</if>>
<<else>>
<<if $orgasmdown gte 1>>
twitching pussy
<<else>>
<<if $arousal gte 8000>>
tingling pussy
<<elseif $arousal gte 6000>>
tiny cunt
<<elseif $arousal gte 4000>>
tiny pussy
<<elseif $arousal gte 2000>>
tiny quim
<<else>>
tiny pussy
<</if>>
<</if>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "pussystop">><<nobr>>
<<if $devstate gte 1>>
<<if $orgasmcount gte 23>>
<<if $orgasmdown gte 1>>
tortured pussy.
<<else>>
spent pussy.
<</if>>
<<elseif $orgasmcount gte 9>>
<<if $orgasmdown gte 1>>
twitching pussy.
<<else>>
tired pussy.
<</if>>
<<else>>
<<if $orgasmdown gte 1>>
twitching pussy.
<<else>>
<<if $arousal gte 8000>>
tingling pussy.
<<elseif $arousal gte 6000>>
cunt.
<<elseif $arousal gte 4000>>
pussy.
<<elseif $arousal gte 2000>>
quim.
<<else>>
pussy.
<</if>>
<</if>>
<</if>>
<<else>>
<<if $orgasmcount gte 23>>
<<if $orgasmdown gte 1>>
tortured little pussy.
<<else>>
spent little pussy.
<</if>>
<<elseif $orgasmcount gte 9>>
<<if $orgasmdown gte 1>>
twitching pussy.
<<else>>
tired little pussy.
<</if>>
<<else>>
<<if $orgasmdown gte 1>>
twitching pussy.
<<else>>
<<if $arousal gte 8000>>
tingling pussy.
<<elseif $arousal gte 6000>>
tiny cunt.
<<elseif $arousal gte 4000>>
tiny pussy.
<<elseif $arousal gte 2000>>
tiny quim.
<<else>>
tiny pussy.
<</if>>
<</if>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "pussycomma">><<nobr>>
<<if $devstate gte 1>>
<<if $orgasmcount gte 23>>
<<if $orgasmdown gte 1>>
tortured pussy,
<<else>>
spent pussy,
<</if>>
<<elseif $orgasmcount gte 9>>
<<if $orgasmdown gte 1>>
twitching pussy,
<<else>>
tired pussy,
<</if>>
<<else>>
<<if $orgasmdown gte 1>>
twitching pussy,
<<else>>
<<if $arousal gte 8000>>
tingling pussy,
<<elseif $arousal gte 6000>>
cunt,
<<elseif $arousal gte 4000>>
pussy,
<<elseif $arousal gte 2000>>
quim,
<<else>>
pussy,
<</if>>
<</if>>
<</if>>
<<else>>
<<if $orgasmcount gte 23>>
<<if $orgasmdown gte 1>>
tortured little pussy,
<<else>>
spent little pussy,
<</if>>
<<elseif $orgasmcount gte 9>>
<<if $orgasmdown gte 1>>
twitching pussy,
<<else>>
tired little pussy,
<</if>>
<<else>>
<<if $orgasmdown gte 1>>
twitching pussy,
<<else>>
<<if $arousal gte 8000>>
tingling pussy,
<<elseif $arousal gte 6000>>
tiny cunt,
<<elseif $arousal gte 4000>>
tiny pussy,
<<elseif $arousal gte 2000>>
tiny quim,
<<else>>
tiny pussy,
<</if>>
<</if>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "penis">><<nobr>>
<<if $devstate gte 1>>
<<if $orgasmcount gte 23>>
<<if $orgasmdown gte 1>>
tortured penis
<<else>>
spent penis
<</if>>
<<elseif $orgasmcount gte 9>>
<<if $orgasmdown gte 1>>
twitching penis
<<else>>
tired penis
<</if>>
<<else>>
<<if $orgasmdown gte 1>>
twitching penis
<<else>>
<<if $arousal gte 8000>>
tingling penis
<<elseif $arousal gte 6000>>
penis
<<elseif $arousal gte 4000>>
penis
<<elseif $arousal gte 2000>>
penis
<<else>>
penis
<</if>>
<</if>>
<</if>>
<<else>>
<<if $orgasmcount gte 23>>
<<if $orgasmdown gte 1>>
tortured little penis
<<else>>
spent little penis
<</if>>
<<elseif $orgasmcount gte 9>>
<<if $orgasmdown gte 1>>
twitching penis
<<else>>
tired little penis
<</if>>
<<else>>
<<if $orgasmdown gte 1>>
twitching penis
<<else>>
<<if $arousal gte 8000>>
tingling penis
<<elseif $arousal gte 6000>>
tiny penis
<<elseif $arousal gte 4000>>
tiny penis
<<elseif $arousal gte 2000>>
tiny penis
<<else>>
tiny penis
<</if>>
<</if>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "penisstop">><<nobr>>
<<if $devstate gte 1>>
<<if $orgasmcount gte 23>>
<<if $orgasmdown gte 1>>
tortured penis.
<<else>>
spent penis.
<</if>>
<<elseif $orgasmcount gte 9>>
<<if $orgasmdown gte 1>>
twitching penis.
<<else>>
tired penis.
<</if>>
<<else>>
<<if $orgasmdown gte 1>>
twitching penis.
<<else>>
<<if $arousal gte 8000>>
tingling penis.
<<elseif $arousal gte 6000>>
penis.
<<elseif $arousal gte 4000>>
penis.
<<elseif $arousal gte 2000>>
penis.
<<else>>
penis.
<</if>>
<</if>>
<</if>>
<<else>>
<<if $orgasmcount gte 23>>
<<if $orgasmdown gte 1>>
tortured little penis.
<<else>>
spent little penis.
<</if>>
<<elseif $orgasmcount gte 9>>
<<if $orgasmdown gte 1>>
twitching penis.
<<else>>
tired little penis.
<</if>>
<<else>>
<<if $orgasmdown gte 1>>
twitching penis.
<<else>>
<<if $arousal gte 8000>>
tingling penis.
<<elseif $arousal gte 6000>>
tiny penis.
<<elseif $arousal gte 4000>>
tiny penis.
<<elseif $arousal gte 2000>>
tiny penis.
<<else>>
tiny penis.
<</if>>
<</if>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "peniscomma">><<nobr>>
<<if $devstate gte 1>>
<<if $orgasmcount gte 23>>
<<if $orgasmdown gte 1>>
tortured penis,
<<else>>
spent penis,
<</if>>
<<elseif $orgasmcount gte 9>>
<<if $orgasmdown gte 1>>
twitching penis,
<<else>>
tired penis,
<</if>>
<<else>>
<<if $orgasmdown gte 1>>
twitching penis,
<<else>>
<<if $arousal gte 8000>>
tingling penis,
<<elseif $arousal gte 6000>>
penis,
<<elseif $arousal gte 4000>>
penis,
<<elseif $arousal gte 2000>>
penis,
<<else>>
penis,
<</if>>
<</if>>
<</if>>
<<else>>
<<if $orgasmcount gte 23>>
<<if $orgasmdown gte 1>>
tortured little penis,
<<else>>
spent little penis,
<</if>>
<<elseif $orgasmcount gte 9>>
<<if $orgasmdown gte 1>>
twitching penis,
<<else>>
tired little penis,
<</if>>
<<else>>
<<if $orgasmdown gte 1>>
twitching penis,
<<else>>
<<if $arousal gte 8000>>
tingling penis,
<<elseif $arousal gte 6000>>
tiny penis,
<<elseif $arousal gte 4000>>
tiny penis,
<<elseif $arousal gte 2000>>
tiny penis,
<<else>>
tiny penis,
<</if>>
<</if>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "reveal7">><span class="red">lewd</span><</widget>>
<<widget "reveal6">><span class="pink">risqué</span><</widget>>
<<widget "reveal5">><span class="purple">seductive</span><</widget>>
<<widget "reveal4">><span class="blue">comfy</span><</widget>>
<<widget "reveal3">><span class="lblue">tasteful</span><</widget>>
<<widget "reveal2">><span class="teal">smart</span><</widget>>
<<widget "reveal1">><span class="green">sophisticated</span><</widget>>
<<widget "integrity1">><span class="red">fragile</span><</widget>>
<<widget "integrity2">><span class="pink">delicate</span><</widget>>
<<widget "integrity3">><span class="purple">fine</span><</widget>>
<<widget "integrity4">><span class="blue">solid</span><</widget>>
<<widget "integrity5">><span class="lblue">firm</span><</widget>>
<<widget "integrity6">><span class="teal">sturdy</span><</widget>>
<<widget "integrity7">><span class="green">tough</span><</widget>>
<<widget "strokes">><<nobr>>
<<if $enemyanger gte ($enemyangermax / 5) * 4 and $enemyarousal gte ($enemyarousalmax / 5) * 4>>savagely toys with
<<elseif $enemyanger gte ($enemyangermax / 5) * 4 and $enemyarousal gte ($enemyarousalmax / 5) * 2>>viciously toys with
<<elseif $enemyanger gte ($enemyangermax / 5) * 4>>brutally rubs
<<elseif $enemyanger gte ($enemyangermax / 5) * 2 and $enemyarousal gte ($enemyarousalmax / 5) * 4>>roughly rubs
<<elseif $enemyanger gte ($enemyangermax / 5) * 2 and $enemyarousal gte ($enemyarousalmax / 5) * 2>>firmly strokes
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 4>>passionately strokes
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>vigorously strokes
<<else>>gently caresses
<</if>>
<</nobr>><</widget>>
<<widget "person">><<nobr>>
<<if $npcadult is 1>>
<<if $pronoun is "m">>$description man
<<elseif $pronoun is "f">>$description woman
<</if>>
<<else>>
<<if $pronoun is "m">>$description boy
<<elseif $pronoun is "f">>$description girl
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "personstop">><<nobr>>
<<if $npcadult is 1>>
<<if $pronoun is "m">>$description man.
<<elseif $pronoun is "f">>$description woman.
<</if>>
<<else>>
<<if $pronoun is "m">>$description boy.
<<elseif $pronoun is "f">>$description girl.
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "personcomma">><<nobr>>
<<if $npcadult is 1>>
<<if $pronoun is "m">>$description man,
<<elseif $pronoun is "f">>$description woman,
<</if>>
<<else>>
<<if $pronoun is "m">>$description boy,
<<elseif $pronoun is "f">>$description girl,
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "persons">><<nobr>>
<<if $npcadult is 1>>
<<if $pronoun is "m">>$description man's
<<elseif $pronoun is "f">>$description woman's
<</if>>
<<else>>
<<if $pronoun is "m">>$description boy's
<<elseif $pronoun is "f">>$description girl's
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "combatperson">><<nobr>>
<<if $enemytype is "beast">>
$beasttype
<<elseif $npc isnot 0>>
$npcdescription
<<elseif $npcadult is 1>>
<<if $pronoun is "m">>$description man
<<elseif $pronoun is "f">>$description woman
<</if>>
<<else>>
<<if $pronoun is "m">>$description boy
<<elseif $pronoun is "f">>$description girl
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "combatpersoncomma">><<nobr>>
<<if $enemytype is "beast">>
$beasttype,
<<elseif $npc isnot 0>>
$npcdescription,
<<elseif $npcadult is 1>>
<<if $pronoun is "m">>$description man,
<<elseif $pronoun is "f">>$description woman,
<</if>>
<<else>>
<<if $pronoun is "m">>$description boy,
<<elseif $pronoun is "f">>$description girl,
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "combatpersonstop">><<nobr>>
<<if $enemytype is "beast">>
$beasttype.
<<elseif $npc isnot 0>>
$npcdescription.
<<elseif $npcadult is 1>>
<<if $pronoun is "m">>$description man.
<<elseif $pronoun is "f">>$description woman.
<</if>>
<<else>>
<<if $pronoun is "m">>$description boy.
<<elseif $pronoun is "f">>$description girl.
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "combatpersons">><<nobr>>
<<if $enemytype is "beast">>
$beasttype's
<<elseif $npc isnot 0>>
$npcdescription's
<<elseif $npcadult is 1>>
<<if $pronoun is "m">>$description man's
<<elseif $pronoun is "f">>$description woman's
<</if>>
<<else>>
<<if $pronoun is "m">>$description boy's
<<elseif $pronoun is "f">>$description girl's
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "person1">><<nobr>>
<<set $npcadult to $npcadult1>>
<<set $pronoun to $pronoun1>>
<<set $description to $description1>>
<</nobr>><</widget>>
<<widget "person2">><<nobr>>
<<set $npcadult to $npcadult2>>
<<set $pronoun to $pronoun2>>
<<set $description to $description2>>
<</nobr>><</widget>>
<<widget "person3">><<nobr>>
<<set $npcadult to $npcadult3>>
<<set $pronoun to $pronoun3>>
<<set $description to $description3>>
<</nobr>><</widget>>
<<widget "person4">><<nobr>>
<<set $npcadult to $npcadult4>>
<<set $pronoun to $pronoun4>>
<<set $description to $description4>>
<</nobr>><</widget>>
<<widget "person5">><<nobr>>
<<set $npcadult to $npcadult5>>
<<set $pronoun to $pronoun5>>
<<set $description to $description5>>
<</nobr>><</widget>>
<<widget "person6">><<nobr>>
<<set $npcadult to $npcadult6>>
<<set $pronoun to $pronoun6>>
<<set $description to $description6>>
<</nobr>><</widget>>
<<widget "personpenis">><<nobr>>
<<if $penis isnot "none">>
penis
<<else>>
clit
<</if>>
<</nobr>><</widget>>
<<widget "personpenisstop">><<nobr>>
<<if $penis isnot "none">>
penis.
<<else>>
clit.
<</if>>
<</nobr>><</widget>>
<<widget "personpeniscomma">><<nobr>>
<<if $penis isnot "none">>
penis,
<<else>>
clit,
<</if>>
<</nobr>><</widget>>
<<widget "girl">><<nobr>>
<<if $playergenderappearance is "f">>
girl
<<elseif $playergenderappearance is "m">>
boy
<</if>>
<</nobr>><</widget>>
<<widget "girlstop">><<nobr>>
<<if $playergenderappearance is "f">>
girl.
<<elseif $playergenderappearance is "m">>
boy.
<</if>>
<</nobr>><</widget>>
<<widget "girlcomma">><<nobr>>
<<if $playergenderappearance is "f">>
girl,
<<elseif $playergenderappearance is "m">>
boy,
<</if>>
<</nobr>><</widget>>
<<widget "girls">><<nobr>>
<<if $playergenderappearance is "f">>
girls
<<elseif $playergenderappearance is "m">>
boys
<</if>>
<</nobr>><</widget>>
<<widget "girlsstop">><<nobr>>
<<if $playergenderappearance is "f">>
girls.
<<elseif $playergenderappearance is "m">>
boys.
<</if>>
<</nobr>><</widget>>
<<widget "girlscomma">><<nobr>>
<<if $playergenderappearance is "f">>
girls,
<<elseif $playergenderappearance is "m">>
boys,
<</if>>
<</nobr>><</widget>>
<<widget "lass">><<nobr>>
<<if $playergenderappearance is "f">>
lass
<<elseif $playergenderappearance is "m">>
lad
<</if>>
<</nobr>><</widget>>
<<widget "lasscomma">><<nobr>>
<<if $playergenderappearance is "f">>
lass,
<<elseif $playergenderappearance is "m">>
lad,
<</if>>
<</nobr>><</widget>>
<<widget "lassstop">><<nobr>>
<<if $playergenderappearance is "f">>
lass.
<<elseif $playergenderappearance is "m">>
lad.
<</if>>
<</nobr>><</widget>>
<<widget "genderstop">><<nobr>>
<<if $playergender is "f">>
girl.
<<elseif $playergender is "m">>
boy.
<</if>>
<</nobr>><</widget>>
<<widget "gendercomma">><<nobr>>
<<if $playergender is "f">>
girl,
<<elseif $playergender is "m">>
boy,
<</if>>
<</nobr>><</widget>>
<<widget "gender">><<nobr>>
<<if $playergender is "f">>
girl
<<elseif $playergender is "m">>
boy
<</if>>
<</nobr>><</widget>>
<<widget "genitals">><<nobr>>
<<if $penisexist is 1>>
<<if $penilevirginity is 1>>
virgin penis
<<else>>
penis
<</if>>
<</if>>
<<if $penisexist is 1 and $vaginaexist is 1>>
and
<</if>>
<<if $vaginaexist is 1>>
<<if $vaginalvirginity is 1>>
virgin pussy
<<else>>
pussy
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "genitalsstop">><<nobr>>
<<if $penisexist is 1>>
<<if $penilevirginity is 1>>
virgin penis.
<<else>>
penis.
<</if>>
<<elseif $vaginaexist is 1>>
<<if $vaginalvirginity is 1>>
virgin pussy.
<<else>>
pussy.
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "genitalscomma">><<nobr>>
<<if $penisexist is 1>>
<<if $penilevirginity is 1>>
virgin penis,
<<else>>
penis,
<</if>>
<<elseif $vaginaexist is 1>>
<<if $vaginalvirginity is 1>>
virgin pussy,
<<else>>
pussy,
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "lstress">><<nobr>> |
<span class="green">- Stress </span>
<</nobr>><</widget>>
<<widget "llstress">><<nobr>> |
<span class="green">- - Stress </span>
<</nobr>><</widget>>
<<widget "lllstress">><<nobr>> |
<span class="green">- - - Stress </span>
<</nobr>><</widget>>
<<widget "gstress">><<nobr>> |
<span class="red">+ Stress </span>
<</nobr>><</widget>>
<<widget "ggstress">><<nobr>> |
<span class="red">+ + Stress </span>
<</nobr>><</widget>>
<<widget "gggstress">><<nobr>> |
<span class="red">+ + + Stress </span>
<</nobr>><</widget>>
<<widget "ltiredness">><<nobr>> |
<span class="green">- Fatigue </span>
<</nobr>><</widget>>
<<widget "gtiredness">><<nobr>> |
<span class="red">+ Fatigue </span>
<</nobr>><</widget>>
<<widget "larousal">><<nobr>> |
<span class="green">- Arousal </span>
<</nobr>><</widget>>
<<widget "llarousal">><<nobr>> |
<span class="green">- - Arousal </span>
<</nobr>><</widget>>
<<widget "lllarousal">><<nobr>> |
<span class="green">- - - Arousal </span>
<</nobr>><</widget>>
<<widget "garousal">><<nobr>> |
<span class="red">+ Arousal </span>
<</nobr>><</widget>>
<<widget "ggarousal">><<nobr>> |
<span class="red">+ + Arousal </span>
<</nobr>><</widget>>
<<widget "gggarousal">><<nobr>> |
<span class="red">+ + + Arousal </span>
<</nobr>><</widget>>
<<widget "ltrauma">><<nobr>> |
<span class="green">- Trauma </span>
<</nobr>><</widget>>
<<widget "lltrauma">><<nobr>> |
<span class="green">- - Trauma </span>
<</nobr>><</widget>>
<<widget "llltrauma">><<nobr>> |
<span class="green">- - - Trauma </span>
<</nobr>><</widget>>
<<widget "gtrauma">><<nobr>> |
<span class="red">+ Trauma </span>
<</nobr>><</widget>>
<<widget "ggtrauma">><<nobr>> |
<span class="red">+ + Trauma </span>
<</nobr>><</widget>>
<<widget "gggtrauma">><<nobr>> |
<span class="red">+ + + Trauma </span>
<</nobr>><</widget>>
<<widget "lcontrol">><<nobr>> |
<span class="red">- Control </span>
<</nobr>><</widget>>
<<widget "llcontrol">><<nobr>> |
<span class="red">- - Control </span>
<</nobr>><</widget>>
<<widget "lllcontrol">><<nobr>> |
<span class="red">- - - Control </span>
<</nobr>><</widget>>
<<widget "gcontrol">><<nobr>> |
<span class="green">+ Control </span>
<</nobr>><</widget>>
<<widget "ggcontrol">><<nobr>> |
<span class="green">+ + Control </span>
<</nobr>><</widget>>
<<widget "gggcontrol">><<nobr>> |
<span class="green">+ + + Control </span>|
<</nobr>><</widget>>
<<widget "lcombatcontrol">><<nobr>> |
<span class="red">- Control </span>|
<</nobr>><</widget>>
<<widget "llcombatcontrol">><<nobr>> |
<span class="red">- - Control </span>|
<</nobr>><</widget>>
<<widget "lllcombatcontrol">><<nobr>> |
<span class="red">- - - Control </span>|
<</nobr>><</widget>>
<<widget "gcombatcontrol">><<nobr>> |
<span class="green">+ Control </span>|
<</nobr>><</widget>>
<<widget "ggcombatcontrol">><<nobr>> |
<span class="green">+ + Control </span>|
<</nobr>><</widget>>
<<widget "gggcombatcontrol">><<nobr>> |
<span class="green">+ + + Control </span>|
<</nobr>><</widget>>
<<widget "lpain">><<nobr>> |
<span class="green">- Pain </span>
<</nobr>><</widget>>
<<widget "gpain">><<nobr>> |
<span class="red">+ Pain </span>
<</nobr>><</widget>>
<<widget "loxygen">><<nobr>> |
<span class="blue">- Air </span>
<</nobr>><</widget>>
<<widget "goxygen">><<nobr>> |
<span class="teal">+ Air </span>
<</nobr>><</widget>>
<<widget "lawareness">><<nobr>> |
<span class="blue">- Awareness </span>
<</nobr>><</widget>>
<<widget "gawareness">><<nobr>> |
<span class="lblue">+ Awareness </span>
<</nobr>><</widget>>
<<widget "gscience">><<nobr>> |
<span class="green">+ Science </span>
<</nobr>><</widget>>
<<widget "ggscience">><<nobr>> |
<span class="green">+ + Science </span>
<</nobr>><</widget>>
<<widget "gggscience">><<nobr>> |
<span class="green">+ + + Science </span>
<</nobr>><</widget>>
<<widget "gmaths">><<nobr>> |
<span class="green">+ Maths </span>
<</nobr>><</widget>>
<<widget "ggmaths">><<nobr>> |
<span class="green">+ + Maths </span>
<</nobr>><</widget>>
<<widget "gggmaths">><<nobr>> |
<span class="green">+ + +Maths </span>
<</nobr>><</widget>>
<<widget "genglish">><<nobr>> |
<span class="green">+ English </span>
<</nobr>><</widget>>
<<widget "ggenglish">><<nobr>> |
<span class="green">+ + English </span>
<</nobr>><</widget>>
<<widget "gggenglish">><<nobr>> |
<span class="green">+ + + English </span>
<</nobr>><</widget>>
<<widget "ghistory">><<nobr>> |
<span class="green">+ History </span>
<</nobr>><</widget>>
<<widget "gghistory">><<nobr>> |
<span class="green">+ + History </span>
<</nobr>><</widget>>
<<widget "ggghistory">><<nobr>> |
<span class="green">+ + + History </span>
<</nobr>><</widget>>
<<widget "gswimming">><<nobr>> |
<span class="green">+ Swimming </span>
<</nobr>><</widget>>
<<widget "ggswimming">><<nobr>> |
<span class="green">+ + Swimming </span>
<</nobr>><</widget>>
<<widget "gggswimming">><<nobr>> |
<span class="green">+ + + Swimming </span>
<</nobr>><</widget>>
<<widget "lharass">><<nobr>> |
<span class="teal">Decreases chance of harassment </span>
<</nobr>><</widget>>
<<widget "gharass">><<nobr>> |
<span class="pink">Increases chance of harassment </span>
<</nobr>><</widget>>
<<widget "gdelinquency">><<nobr>> |
<span class="red">+ Delinquency </span>
<</nobr>><</widget>>
<<widget "ggdelinquency">><<nobr>> |
<span class="red">+ + Delinquency </span>
<</nobr>><</widget>>
<<widget "gggdelinquency">><<nobr>> |
<span class="red">+ + + Delinquency </span>
<</nobr>><</widget>>
<<widget "ldelinquency">><<nobr>> |
<span class="green">- Delinquency </span>
<</nobr>><</widget>>
<<widget "lldelinquency">><<nobr>> |
<span class="green">- Delinquency </span>
<</nobr>><</widget>>
<<widget "llldelinquency">><<nobr>> |
<span class="green">- - - Delinquency </span>
<</nobr>><</widget>>
<<widget "gcool">><<nobr>> |
<span class="green">+ Status </span>
<</nobr>><</widget>>
<<widget "ggcool">><<nobr>> |
<span class="green">+ + Status </span>
<</nobr>><</widget>>
<<widget "gggcool">><<nobr>> |
<span class="green">+ + + Status </span>
<</nobr>><</widget>>
<<widget "lcool">><<nobr>> |
<span class="red">- Status </span>
<</nobr>><</widget>>
<<widget "llcool">><<nobr>> |
<span class="red">- - Status </span>
<</nobr>><</widget>>
<<widget "lllcool">><<nobr>> |
<span class="red">- - - Status </span>
<</nobr>><</widget>>
<<widget "gtrust">><<nobr>> |
<span class="green">+ Trust </span>
<</nobr>><</widget>>
<<widget "ltrust">><<nobr>> |
<span class="red">- Trust </span>
<</nobr>><</widget>>
<<widget "glove">><<nobr>> |
<span class="green">+ Love </span>
<</nobr>><</widget>>
<<widget "llove">><<nobr>> |
<span class="red">- Love </span>
<</nobr>><</widget>>
<<widget "glust">><<nobr>> |
<span class="lewd">+ Lust </span>
<</nobr>><</widget>>
<<widget "llust">><<nobr>> |
<span class="teal">- Lust </span>
<</nobr>><</widget>>
<<widget "gdom">><<nobr>> |
<span class="purple">+ NPC Dominance</span>
<</nobr>><</widget>>
<<widget "ldom">><<nobr>> |
<span class="lblue">- NPC Dominance</span>
<</nobr>><</widget>>
<<widget "exhibitionist1">><<nobr>> |
<span class="teal">Exhibitionism 1 </span>
<</nobr>><</widget>>
<<widget "exhibitionist2">><<nobr>> |
<span class="lblue">Exhibitionism 2 </span>
<</nobr>><</widget>>
<<widget "exhibitionist3">><<nobr>> |
<span class="blue">Exhibitionism 3 </span>
<</nobr>><</widget>>
<<widget "exhibitionist4">><<nobr>> |
<span class="purple">Exhibitionism 4 </span>
<</nobr>><</widget>>
<<widget "exhibitionist5">><<nobr>> |
<span class="pink">Exhibitionism 5 </span>
<</nobr>><</widget>>
<<widget "combatexhibitionist1">><<nobr>>
<span class="teal">Exhibitionism 1 </span>
<</nobr>><</widget>>
<<widget "combatexhibitionist2">><<nobr>>
<span class="lblue">Exhibitionism 2 </span>
<</nobr>><</widget>>
<<widget "combatexhibitionist3">><<nobr>>
<span class="blue">Exhibitionism 3 </span>
<</nobr>><</widget>>
<<widget "combatexhibitionist4">><<nobr>>
<span class="purple">Exhibitionism 4 </span>
<</nobr>><</widget>>
<<widget "combatexhibitionist5">><<nobr>>
<span class="pink">Exhibitionism 5 </span>
<</nobr>><</widget>>
<<widget "promiscuous1">><<nobr>> |
<span class="teal">Promiscuity 1 </span>
<</nobr>><</widget>>
<<widget "promiscuous2">><<nobr>> |
<span class="lblue">Promiscuity 2 </span>
<</nobr>><</widget>>
<<widget "promiscuous3">><<nobr>> |
<span class="blue">Promiscuity 3 </span>
<</nobr>><</widget>>
<<widget "promiscuous4">><<nobr>> |
<span class="purple">Promiscuity 4 </span>
<</nobr>><</widget>>
<<widget "promiscuous5">><<nobr>> |
<span class="pink">Promiscuity 5 </span>
<</nobr>><</widget>>
<<widget "combatpromiscuous1">><<nobr>>
<<if $consensual is 1>>
<<if $enemytype is "man">>
<span class="teal">Promiscuity 1 </span>
<<else>>
<span class="teal">Deviancy 1 </span>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "combatpromiscuous2">><<nobr>>
<<if $consensual is 1>>
<<if $enemytype is "man">>
<span class="lblue">Promiscuity 2 </span>
<<else>>
<span class="lblue">Deviancy 2 </span>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "combatpromiscuous3">><<nobr>>
<<if $consensual is 1>>
<<if $enemytype is "man">>
<span class="blue">Promiscuity 3 </span>
<<else>>
<span class="blue">Deviancy 3 </span>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "combatpromiscuous4">><<nobr>>
<<if $consensual is 1>>
<<if $enemytype is "man">>
<span class="purple">Promiscuity 4 </span>
<<else>>
<span class="purple">Deviancy 4 </span>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "combatpromiscuous5">><<nobr>>
<<if $consensual is 1>>
<<if $enemytype is "man">>
<span class="pink">Promiscuity 5 </span>
<<else>>
<span class="pink">Deviancy 5 </span>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "deviant1">><<nobr>> |
<span class="teal">Deviancy 1 </span>
<</nobr>><</widget>>
<<widget "deviant2">><<nobr>> |
<span class="lblue">Deviancy 2 </span>
<</nobr>><</widget>>
<<widget "deviant3">><<nobr>> |
<span class="blue">Deviancy 3 </span>
<</nobr>><</widget>>
<<widget "deviant4">><<nobr>> |
<span class="purple">Deviancy 4 </span>
<</nobr>><</widget>>
<<widget "deviant5">><<nobr>> |
<span class="pink">Deviancy 5 </span>
<</nobr>><</widget>>
<<widget "combatdeviant1">><<nobr>>
<<if $consensual is 1>>
<span class="teal">Deviancy 1 </span>
<</if>>
<</nobr>><</widget>>
<<widget "combatdeviant2">><<nobr>>
<<if $consensual is 1>>
<span class="lblue">Deviancy 2 </span>
<</if>>
<</nobr>><</widget>>
<<widget "combatdeviant3">><<nobr>>
<<if $consensual is 1>>
<span class="blue">Deviancy 3 </span>
<</if>>
<</nobr>><</widget>>
<<widget "combatdeviant4">><<nobr>>
<<if $consensual is 1>>
<span class="purple">Deviancy 4 </span>
<</if>>
<</nobr>><</widget>>
<<widget "combatdeviant5">><<nobr>>
<<if $consensual is 1>>
<span class="pink">Deviancy 5 </span>
<</if>>
<</nobr>><</widget>>
<<widget "admires">><<nobr>>
<<print either("leers at", "admires", "ogles", "eyes up")>>
<</nobr>><</widget>>
<<widget "crime">><<nobr>>
| <span class="red">Crime </span>
<</nobr>><</widget>>
<<widget "defianttext">><<nobr>>
| <span class="def">Defiant </span>
<</nobr>><</widget>>
<<widget "submissivetext">><<nobr>>
| <span class="sub">Submissive </span>
<</nobr>><</widget>>
<<widget "month">><<nobr>>
<<if $month is "january">>
January
<<elseif $month is "february">>
February
<<elseif $month is "march">>
March
<<elseif $month is "april">>
April
<<elseif $month is "may">>
May
<<elseif $month is "june">>
June
<<elseif $month is "july">>
July
<<elseif $month is "august">>
August
<<elseif $month is "september">>
September
<<elseif $month is "october">>
October
<<elseif $month is "november">>
November
<<elseif $month is "december">>
December
<</if>>
<</nobr>><</widget>>
<<widget "monthday">><<nobr>>
<<if $monthday is 1>>st
<<elseif $monthday is 21>>st
<<elseif $monthday is 31>>st
<<elseif $monthday is 2>>nd
<<elseif $monthday is 22>>nd
<<elseif $monthday is 3>>rd
<<elseif $monthday is 23>>rd
<<else>>th
<</if>>
<</nobr>><</widget>>
<<widget "openinghours">><<nobr>>
A sign reads "Opening hours: 08:00 - 21:00"<br>
<</nobr>><</widget>>
<<widget "groin">><<nobr>>
<<if $lowertype isnot "naked" and $skirt isnot 1>>
<<genitals>> through your $lowerclothes
<<elseif $undertype isnot "naked">>
<<genitals>> through your $underclothes
<<else>>
<<genitals>>
<</if>>
<</nobr>><</widget>>
<<widget "groinstop">><<nobr>>
<<if $lowertype isnot "naked" and $skirt isnot 1>>
<<genitals>> through your $lowerclothes.
<<elseif $undertype isnot "naked">>
<<genitals>> through your $underclothes.
<<else>>
<<genitalsstop>>
<</if>>
<</nobr>><</widget>>
<<widget "groincomma">><<nobr>>
<<if $lowertype isnot "naked" and $skirt isnot 1>>
<<genitals>> through your $lowerclothes,
<<elseif $undertype isnot "naked">>
<<genitals>> through your $underclothes,
<<else>>
<<genitalscomma>>
<</if>>
<</nobr>><</widget>>
<<widget "crotch">><<nobr>>
<<if $lowertype isnot "naked">>
$lowerclothes
<<elseif $undertype isnot "naked">>
$underclothes
<<else>>
<<genitals>>
<</if>>
<</nobr>><</widget>>
<<widget "crotchstop">><<nobr>>
<<if $lowertype isnot "naked">>
$lowerclothes.
<<elseif $undertype isnot "naked">>
$underclothes.
<<else>>
<<genitalsstop>>
<</if>>
<</nobr>><</widget>>
<<widget "crotchcomma">><<nobr>>
<<if $lowertype isnot "naked">>
$lowerclothes,
<<elseif $undertype isnot "naked">>
$underclothes,
<<else>>
<<genitalscomma>>
<</if>>
<</nobr>><</widget>>
<<widget "undies">><<nobr>>
<<if $undertype isnot "naked">>
$underclothes
<<else>>
<<genitals>>
<</if>>
<</nobr>><</widget>>
<<widget "undiesstop">><<nobr>>
<<if $undertype isnot "naked">>
$underclothes.
<<else>>
<<genitalsstop>>
<</if>>
<</nobr>><</widget>>
<<widget "undiescomma">><<nobr>>
<<if $undertype isnot "naked">>
$underclothes,
<<else>>
<<genitalscomma>>
<</if>>
<</nobr>><</widget>>
<<widget "undiesstop">><<nobr>>
<<if $undertype isnot "naked">>
$underclothes.
<<else>>
<<genitalsstop>>
<</if>>
<</nobr>><</widget>>
<<widget "bottoms">><<nobr>>
<<if $upperset is $lowerset>>
$upperclothes
<<else>>
$lowerclothes
<</if>>
<</nobr>><</widget>>
<<widget "bottomsstop">><<nobr>>
<<if $upperset is $lowerset>>
$upperclothes.
<<else>>
$lowerclothes.
<</if>>
<</nobr>><</widget>>
<<widget "bottomscomma">><<nobr>>
<<if $upperset is $lowerset>>
$upperclothes,
<<else>>
$lowerclothes,
<</if>>
<</nobr>><</widget>>
<<widget "outfit">><<nobr>>
<<if $upperset is $lowerset>>
$upperclothes<<set $stripset to 1>>
<<else>>
$upperclothes and $lowerclothes<<set $stripset to 0>>
<</if>>
<</nobr>><</widget>>
<<widget "outfitstop">><<nobr>>
<<if $upperset is $lowerset>>
$upperclothes.<<set $stripset to 1>>
<<else>>
$upperclothes and $lowerclothes.<<set $stripset to 0>>
<</if>>
<</nobr>><</widget>>
<<widget "outfitcomma">><<nobr>>
<<if $upperset is $lowerset>>
$upperclothes,<<set $stripset to 1>>
<<else>>
$upperclothes and $lowerclothes,<<set $stripset to 0>>
<</if>>
<</nobr>><</widget>>
<<widget "nuditystop">><<nobr>><<exposure>>
<<if $undertype is "naked" and $lowertype is "naked">>
<<if $uppertype isnot "naked">>
<span class="lewd">exposed <<genitalsstop>></span> Your covered chest makes your bare lower half feel more conspicuous.
<<else>>
<span class="lewd">exposed </span>
<<if $breastsize gte 3>>
<<if $playergender is "m">>
<span class="lewd"><<genitals>> and <<breastsstop>></span>
<<else>>
<span class="lewd"><<genitals>> and <<breastsstop>></span>
<</if>>
<<else>>
<<if $playergender is "m">>
<<if $playergenderappearance is "f">>
<span class="lewd"><<genitals>> and <<breastscomma>> made salacious by your feminine demeanor.</span>
<<else>>
<<genitalsstop>>
<</if>>
<<else>>
<span class="lewd"><<genitals>> and <<breastsstop>></span>
<</if>>
<</if>>
<</if>>
<<elseif $uppertype is "naked" and $playergenderappearance is "f">>
<span class="lewd">exposed <<breastsstop>></span>
<<if $lowertype is "naked">>Only your $underclothes give you a shred of decency.
<</if>>
<<elseif $lowertype is "naked">>
<span class="lewd">exposed $underclothes.</span>
<<else>>
<span class="lewd">lewd outfit.</span>
<<if $lowertype is "naked" and $uppertype is "naked">>Only your $underclothes give you a shred of decency.
<</if>>
<</if>>
<<if $leftarm is "bound" and $rightarm is "bound" and $position isnot "wall">>
With your arms bound, you can't even cover yourself, leaving you feeling utterly helpless.
<</if>>
<</nobr>><</widget>>
<<widget "stripobject">><<nobr>>
<<set $upperintegrity -= $stripintegrity>><<set $lowerintegrity -= $stripintegrity>><<set $underintegrity -= $stripintegrity>>
<<if $uppertype isnot "naked" and $upperintegrity lte 0 and $lowertype isnot "naked" and $lowerintegrity lte 0 and $undertype isnot "naked" and $underintegrity lte 0>>
<span class="lewd">Your clothing snags on a $stripobject, tearing it from your body and leaving you totally bare!</span>
<<elseif $uppertype isnot "naked" and $upperintegrity lte 0 and $lowertype isnot "naked" and $lowerintegrity lte 0>>
<span class="lewd">Your <<outfit>> <<if $stripset is 1>>snags on a $stripobject, and is torn clean off your body.<<else>>snag on a $stripobject, and are torn from you body.<</if>></span>
<<elseif $uppertype isnot "naked" and $upperintegrity lte 0 and $undertype isnot "naked" and $underintegrity lte 0>>
<span class="lewd">Your $upperclothes and $underclothes snag on a $stripobject and are torn from your body.</span>
<<elseif $lowertype isnot "naked" and $lowerintegrity lte 0 and $undertype isnot "naked" and $underintegrity lte 0>>
<span class="lewd">Your $lowerclothes and $underclothes snag on a $stripobject and are torn from your body.</span>
<<elseif $uppertype isnot "naked" and $upperintegrity lte 0>>
<span class="lewd">Your $upperclothes snags on a $stripobject and is torn from your body.</span>
<<elseif $lowertype isnot "naked" and $lowerintegrity lte 0>>
<span class="lewd">Your $lowerclothes <<if $lowerplural is 1>>snag on a $stripobject and are torn from your body.<<else>>snags on a $stripobject and is torn from your body.<</if>></span>
<<elseif $undertype isnot "naked" and $underintegrity lte 0>>
<span class="lewd">Your $underclothes <<if $underplural is 1>>snag on a $stripobject and are torn from your body.<<else>>snags on a $stripobject and is torn from your body.<</if>></span>
<</if>>
<<if $upperclothes isnot "naked">>
<<if $upperintegrity lte 0>><<upperruined>><<clothesruinstat>><<set $upperoff to 0>>
<</if>>
<</if>>
<<if $lowerclothes isnot "naked">>
<<if $lowerintegrity lte 0>><<lowerruined>><<clothesruinstat>><<set $loweroff to 0>>
<</if>>
<</if>>
<<if $underclothes isnot "naked">>
<<if $underintegrity lte 0>>
<<if $undertype is "chastity">>
<<set $undertype to "brokenchastity">>
<</if>>
<<underruined>><<clothesruinstat>><<set $underoff to 0>>
<</if>>
<</if>>
<<exposure>>
<<if $exposed gte 1>>
You can't help but be conscious of your <<nuditystop>>
<</if>>
<</nobr>><</widget>>
<<widget "seductiontext">><<nobr>>
<<if $seductionskill gte 0 and $seductionskill lt 200>><span class="pink">awkwardly</span>
<<elseif $seductionskill gte 200 and $seductionskill lt 400>><span class="purple">cautiously</span>
<<elseif $seductionskill gte 400 and $seductionskill lt 600>><span class="blue">rhythmically</span>
<<elseif $seductionskill gte 600 and $seductionskill lt 800>><span class="lblue">smoothly</span>
<<elseif $seductionskill gte 800 and $seductionskill lt 1000>><span class="teal">skillfully</span>
<<elseif $seductionskill gte 1000>><span class="green">expertly</span><</if>>
<</nobr>><</widget>>
<<widget "oraltext">><<nobr>>
<<if $oralskill gte 0 and $oralskill lt 200>><span class="pink">awkwardly</span>
<<elseif $oralskill gte 200 and $oralskill lt 400>><span class="purple">cautiously</span>
<<elseif $oralskill gte 400 and $oralskill lt 600>><span class="blue">rhythmically</span>
<<elseif $oralskill gte 600 and $oralskill lt 800>><span class="lblue">smoothly</span>
<<elseif $oralskill gte 800 and $oralskill lt 1000>><span class="teal">skillfully</span>
<<elseif $oralskill gte 1000>><span class="green">expertly</span><</if>>
<</nobr>><</widget>>
<<widget "vaginaltext">><<nobr>>
<<if $vaginalskill gte 0 and $vaginalskill lt 200>><span class="pink">awkwardly</span>
<<elseif $vaginalskill gte 200 and $vaginalskill lt 400>><span class="purple">cautiously</span>
<<elseif $vaginalskill gte 400 and $vaginalskill lt 600>><span class="blue">rhythmically</span>
<<elseif $vaginalskill gte 600 and $vaginalskill lt 800>><span class="lblue">smoothly</span>
<<elseif $vaginalskill gte 800 and $vaginalskill lt 1000>><span class="teal">skillfully</span>
<<elseif $vaginalskill gte 1000>><span class="green">expertly</span><</if>>
<</nobr>><</widget>>
<<widget "peniletext">><<nobr>>
<<if $penileskill gte 1 and $penileskill lt 200>><span class="pink">awkwardly</span>
<<elseif $penileskill gte 200 and $penileskill lt 400>><span class="purple">cautiously</span>
<<elseif $penileskill gte 400 and $penileskill lt 600>><span class="blue">rhythmically</span>
<<elseif $penileskill gte 600 and $penileskill lt 800>><span class="lblue">smoothly</span>
<<elseif $penileskill gte 800 and $penileskill lt 1000>><span class="teal">skillfully</span>
<<elseif $penileskill gte 1000>><span class="green">expertly</span><</if>>
<</nobr>><</widget>>
<<widget "analtext">><<nobr>>
<<if $analskill gte 0 and $analskill lt 200>><span class="pink">awkwardly</span>
<<elseif $analskill gte 200 and $analskill lt 400>><span class="purple">cautiously</span>
<<elseif $analskill gte 400 and $analskill lt 600>><span class="blue">rhythmically</span>
<<elseif $analskill gte 600 and $analskill lt 800>><span class="lblue">smoothly</span>
<<elseif $analskill gte 800 and $analskill lt 1000>><span class="teal">skillfully</span>
<<elseif $analskill gte 1000>><span class="green">expertly</span><</if>>
<</nobr>><</widget>>
<<widget "handtext">><<nobr>>
<<if $handskill gte 0 and $handskill lt 200>><span class="pink">awkwardly</span>
<<elseif $handskill gte 200 and $handskill lt 400>><span class="purple">cautiously</span>
<<elseif $handskill gte 400 and $handskill lt 600>><span class="blue">rhythmically</span>
<<elseif $handskill gte 600 and $handskill lt 800>><span class="lblue">smoothly</span>
<<elseif $handskill gte 800 and $handskill lt 1000>><span class="teal">skillfully</span>
<<elseif $handskill gte 1000>><span class="green">expertly</span><</if>>
<</nobr>><</widget>>
<<widget "feettext">><<nobr>>
<<if $feetskill gte 0 and $feetskill lt 200>><span class="pink">awkwardly</span>
<<elseif $feetskill gte 200 and $feetskill lt 400>><span class="purple">cautiously</span>
<<elseif $feetskill gte 400 and $feetskill lt 600>><span class="blue">rhythmically</span>
<<elseif $feetskill gte 600 and $feetskill lt 800>><span class="lblue">smoothly</span>
<<elseif $feetskill gte 800 and $feetskill lt 1000>><span class="teal">skillfully</span>
<<elseif $feetskill gte 1000>><span class="green">expertly</span><</if>>
<</nobr>><</widget>>
<<widget "bottomtext">><<nobr>>
<<if $bottomskill gte 0 and $bottomskill lt 200>><span class="pink">awkwardly</span>
<<elseif $bottomskill gte 200 and $bottomskill lt 400>><span class="purple">cautiously</span>
<<elseif $bottomskill gte 400 and $bottomskill lt 600>><span class="blue">rhythmically</span>
<<elseif $bottomskill gte 600 and $bottomskill lt 800>><span class="lblue">smoothly</span>
<<elseif $bottomskill gte 800 and $bottomskill lt 1000>><span class="teal">skillfully</span>
<<elseif $bottomskill gte 1000>><span class="green">expertly</span><</if>>
<</nobr>><</widget>>
<<widget "thightext">><<nobr>>
<<if $thighskill gte 0 and $thighskill lt 200>><span class="pink">awkwardly</span>
<<elseif $thighskill gte 200 and $thighskill lt 400>><span class="purple">cautiously</span>
<<elseif $thighskill gte 400 and $thighskill lt 600>><span class="blue">rhythmically</span>
<<elseif $thighskill gte 600 and $thighskill lt 800>><span class="lblue">smoothly</span>
<<elseif $thighskill gte 800 and $thighskill lt 1000>><span class="teal">skillfully</span>
<<elseif $thighskill gte 1000>><span class="green">expertly</span>
<</if>>
<</nobr>><</widget>>
<<widget "chesttext">><<nobr>>
<<if $chestskill gte 0 and $chestskill lt 200>><span class="pink">awkwardly</span>
<<elseif $chestskill gte 200 and $chestskill lt 400>><span class="purple">cautiously</span>
<<elseif $chestskill gte 400 and $chestskill lt 600>><span class="blue">rhythmically</span>
<<elseif $chestskill gte 600 and $chestskill lt 800>><span class="lblue">smoothly</span>
<<elseif $chestskill gte 800 and $chestskill lt 1000>><span class="teal">skillfully</span>
<<elseif $chestskill gte 1000>><span class="green">expertly</span><</if>>
<</nobr>><</widget>>
<<widget "swimmingtext">><<nobr>>
<<if $swimmingskill gte 0 and $swimmingskill lt 200>><span class="pink">haphazardly</span>
<<elseif $swimmingskill gte 200 and $swimmingskill lt 400>><span class="purple">awkwardly</span>
<<elseif $swimmingskill gte 400 and $swimmingskill lt 600>><span class="blue">adequately</span>
<<elseif $swimmingskill gte 600 and $swimmingskill lt 800>><span class="lblue">smoothly</span>
<<elseif $swimmingskill gte 800 and $swimmingskill lt 1000>><span class="teal">skillfully</span>
<<elseif $swimmingskill gte 1000>><span class="green">expertly</span><</if>>
<</nobr>><</widget>>
<<widget "nervously">><<nobr>>
<<if $exhibitionism lte 15>>
nervously
<<elseif $exhibitionism lte 35>>
timidly
<<elseif $exhibitionism lte 55>>
shyly
<<elseif $exhibitionism lte 75>>
confidently
<<elseif $exhibitionism lte 95>>
eagerly
<<else>>
breathlessly
<</if>>
<</nobr>><</widget>>
<<widget "schoolday">><<nobr>>
<<if $schoolterm is 1 and $weekday is 1>>
You have school tomorrow
<<elseif $schoolterm is 1 and $weekday isnot 1 and $weekday isnot 7>>
It's a school day
<<elseif $schoolterm is 0 and $weekday is 1>>
There's no school tomorrow
<</if>>
<</nobr>><</widget>>
<<widget "schoolterm">><<nobr>>
<<if $month is "january">>
<<if $schoolterm is 1>>
School finishes on the first Monday of April.
<<else>>
School starts on the first Monday of January.
<</if>>
<<elseif $month is "february">>
School finishes on the first Monday of April.
<<elseif $month is "march">>
School finishes on the first Monday of April.
<<elseif $month is "april">>
<<if $schoolterm is 1>>
School finishes on the first Monday of April.
<<else>>
Schools starts on the first Monday of May.
<</if>>
<<elseif $month is "may">>
<<if $schoolterm is 1>>
Schools finishes on the first Monday of July.
<<else>>
Schools starts on the first Monday of May.
<</if>>
<<elseif $month is "june">>
Schools finishes on the first Monday of July.
<<elseif $month is "july">>
<<if $schoolterm is 1>>
School finishes on the first Monday of July.
<<else>>
School starts on the first Monday of September.
<</if>>
<<elseif $month is "august">>
School starts on the first Monday of September.
<<elseif $month is "september">>
<<if $schoolterm is 1>>
School finishes on the first Monday of December.
<<else>>
School starts on the first Monday of September.
<</if>>
<<elseif $month is "october">>
School finishes on the first Monday of December.
<<elseif $month is "november">>
School finishes on the first Monday of December.
<<elseif $month is "december">>
<<if $schoolterm is 1>>
School finishes on the first Monday of December.
<<else>>
School starts on the first Monday of January.
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "sir">><<nobr>>
<<if $pronoun is "m">>
sir
<<else>>
miss
<</if>>
<</nobr>><</widget>>
<<widget "sirstop">><<nobr>>
<<if $pronoun is "m">>
sir.
<<else>>
miss.
<</if>>
<</nobr>><</widget>>
<<widget "sircomma">><<nobr>>
<<if $pronoun is "m">>
sir,
<<else>>
miss,
<</if>>
<</nobr>><</widget>>
<<widget "lewdness">><<nobr>>
<<exposure>>
<<if $underexposed gte 1 and $lowerexposed gte 2 and $upperexposed lte 1>>
<span class="lewd">exposed <<genitals>></span>
<<elseif $underexposed lte 0 and $lowerexposed gte 2 and $upperexposed lte 1>>
<span class="lewd">exposed $underclothes</span>
<<elseif $upperexposed gte 2 and $lowerexposed lte 1 and $playergenderappearance is "m" and $playergender is "m">>
<span class="lewd">lewdness</span>
<<elseif $upperexposed gte 2 and $lowerexposed lte 1>>
<span class="lewd">exposed <<breasts>></span>
<<elseif $upperexposed gte 2 and $lowerexposed gte 2 and $underexposed lte 0 and $playergenderappearance is "m" and $playergender is "m">>
<span class="lewd">exposed $underclothes</span>
<<elseif $upperexposed gte 2 and $lowerexposed gte 2 and $underexposed lte 0>>
<span class="lewd">exposed <<breasts>> and $underclothes</span>
<<elseif $underexposed gte 1 and $lowerexposed gte 2 and $playergenderappearance is "m" and $playergender is "m">>
<span class="lewd">exposed <<genitals>></span>
<<elseif $upperexposed gte 2 and $lowerexposed gte 2 and $underexposed gte 1>>
<span class="lewd">exposed <<breasts>> and <<genitals>></span>
<<else>>
<span class="lewd">lewdness</span>
<</if>>
<</nobr>><</widget>>
<<widget "covered">><<nobr>>
<<exposure>>
<<if $leftarm is "bound" and $rightarm is "bound" and $exposed gte 1>>
<<if $exposed gte 2 and $exhibitionism lt 95>>
With your arms bound, you can do nothing to shield your <<lewdness>> from prying eyes.
<<elseif $exposed gte 2>>
With your arms bound, you can do nothing to shield your <<lewdness>> from prying eyes. You quiver with excitement.
<<elseif $exhibitionism lt 55>>
With your arms bound, you can do nothing to shield your <<lewdness>> from prying eyes.
<<else>>
With your arms bound, you can do nothing to shield your <<lewdness>> from prying eyes. You quiver with excitement.
<</if>>
<<elseif $exposed gte 2 and $exhibitionism lt 95>>
<<if $underexposed gte 1 and $lowerexposed gte 2 and $upperexposed lte 1>>
You cover your <span class="lewd">exposed <<genitals>></span> with your hands.
<<elseif $underexposed lte 0 and $lowerexposed gte 2 and $upperexposed lte 1>>
You cover your <span class="lewd">exposed $underclothes</span> with your hands.
<<elseif $upperexposed gte 2 and $lowerexposed lte 1 and $playergenderappearance is "m" and $playergender is "m">>
You cover your chest with your hands.
<<elseif $upperexposed gte 2 and $lowerexposed lte 1>>
You cover your <span class="lewd">exposed <<breasts>></span> with your hands.
<<elseif $upperexposed gte 2 and $lowerexposed gte 2 and $underexposed lte 0 and $playergenderappearance is "m" and $playergender is "m">>
You cover your <span class="lewd">exposed $underclothes</span> with your hands.
<<elseif $upperexposed gte 2 and $lowerexposed gte 2 and $underexposed lte 0>>
You cover your <span class="lewd">exposed <<breasts>> and $underclothes</span> with your hands.
<<elseif $underexposed gte 1 and $lowerexposed gte 2 and $playergenderappearance is "m" and $playergender is "m">>
You cover your <span class="lewd">exposed <<genitals>></span> with your hands.
<<elseif $upperexposed gte 2 and $lowerexposed gte 2 and $underexposed gte 1>>
You cover your <span class="lewd">exposed <<breasts>> and <<genitals>></span> with your hands.
<<else>>
You cover the <span class="lewd">lewder</span> parts of your outfit with your hands.
<</if>>
<<elseif $exposed gte 2>>
<<if $underexposed gte 1 and $lowerexposed gte 2 and $upperexposed lte 1>>
Your <span class="lewd">exposed <<genitals>></span> makes you quiver with excitement.
<<elseif $underexposed lte 0 and $lowerexposed gte 2 and $upperexposed lte 1>>
Your <span class="lewd">exposed $underclothes</span> <<if $underplural is 1>>make<<else>>makes<</if>> you quiver with excitement.
<<elseif $upperexposed gte 2 and $lowerexposed lte 1 and $playergenderappearance is "m" and $playergender is "m">>
Your exposed chest makes you quiver with excitement.
<<elseif $upperexposed gte 2 and $lowerexposed lte 1>>
Your <span class="lewd">exposed <<breasts>></span> <<if $breastcup is "none">>makes<<else>>make<</if>> you quiver with excitement.
<<elseif $upperexposed gte 2 and $lowerexposed gte 2 and $underexposed lte 0 and $playergenderappearance is "m" and $playergender is "m">>
Your <span class="lewd">exposed $underclothes</span> <<if $underplural is 1>>make<<else>>makes<</if>> you quiver with excitement.
<<elseif $upperexposed gte 2 and $lowerexposed gte 2 and $underexposed lte 0>>
Your <span class="lewd">exposed <<breasts>> and $underclothes</span> make you quiver with excitement.
<<elseif $underexposed gte 1 and $lowerexposed gte 2 and $playergenderappearance is "m" and $playergender is "m">>
Your <span class="lewd">exposed <<genitals>></span> makes you quiver with excitement.
<<elseif $upperexposed gte 2 and $lowerexposed gte 2 and $underexposed gte 1>>
Your <span class="lewd">exposed <<breasts>> and <<genitals>></span> make you quiver with excitement.
<<else>>
The <span class="lewd">lewder</span> parts of your outfit make you quiver with excitement.
<</if>>
<<elseif $exposed gte 1 and $exhibitionism lt 55>>
<<if $underexposed gte 1 and $lowerexposed gte 2 and $upperexposed lte 1>>
You cover your <span class="lewd">exposed <<genitals>></span> with your hands.
<<elseif $underexposed lte 0 and $lowerexposed gte 2 and $upperexposed lte 1>>
You cover your <span class="lewd">exposed $underclothes</span> with your hands.
<<elseif $upperexposed gte 2 and $lowerexposed lte 1 and $playergenderappearance is "m" and $playergender is "m">>
You cover your chest with your hands.
<<elseif $upperexposed gte 2 and $lowerexposed lte 1>>
You cover your <span class="lewd">exposed <<breasts>></span> with your hands.
<<elseif $upperexposed gte 2 and $lowerexposed gte 2 and $underexposed lte 0 and $playergenderappearance is "m" and $playergender is "m">>
You cover your <span class="lewd">exposed $underclothes</span> with your hands.
<<elseif $upperexposed gte 2 and $lowerexposed gte 2 and $underexposed lte 0>>
You cover your <span class="lewd">exposed <<breasts>> and $underclothes</span> with your hands.
<<elseif $underexposed gte 1 and $lowerexposed gte 2 and $playergenderappearance is "m" and $playergender is "m">>
You cover your <span class="lewd">exposed <<genitals>></span> with your hands.
<<elseif $upperexposed gte 2 and $lowerexposed gte 2 and $underexposed gte 1>>
You cover your <span class="lewd">exposed <<breasts>> and <<genitals>></span> with your hands.
<<else>>
You cover the <span class="lewd">lewder</span> parts of your outfit with your hands.
<</if>>
<<elseif $exposed gte 1>>
<<if $underexposed gte 1 and $lowerexposed gte 2 and $upperexposed lte 1>>
Your <span class="lewd">exposed <<genitals>></span> makes you quiver with excitement.
<<elseif $underexposed lte 0 and $lowerexposed gte 2 and $upperexposed lte 1>>
Your <span class="lewd">exposed $underclothes</span> <<if $underplural is 1>>make<<else>>makes<</if>> you quiver with excitement.
<<elseif $upperexposed gte 2 and $lowerexposed lte 1 and $playergenderappearance is "m" and $playergender is "m">>
Your exposed chest makes you quiver with excitement.
<<elseif $upperexposed gte 2 and $lowerexposed lte 1>>
Your <span class="lewd">exposed <<breasts>></span> <<if $breastcup is "none">>makes<<else>>make<</if>> you quiver with excitement.
<<elseif $upperexposed gte 2 and $lowerexposed gte 2 and $underexposed lte 0 and $playergenderappearance is "m" and $playergender is "m">>
Your <span class="lewd">exposed $underclothes</span> <<if $underplural is 1>>make<<else>>makes<</if>> you quiver with excitement.
<<elseif $upperexposed gte 2 and $lowerexposed gte 2 and $underexposed lte 0>>
Your <span class="lewd">exposed <<breasts>> and $underclothes</span> make you quiver with excitement.
<<elseif $underexposed gte 1 and $lowerexposed gte 2 and $playergenderappearance is "m" and $playergender is "m">>
Your <span class="lewd">exposed <<genitals>></span> makes you quiver with excitement.
<<elseif $upperexposed gte 2 and $lowerexposed gte 2 and $underexposed gte 1>>
Your <span class="lewd">exposed <<breasts>> and <<genitals>></span> make you quiver with excitement.
<<else>>
The <span class="lewd">lewder</span> parts of your outfit make you quiver with excitement.
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "prostate">><<nobr>>
<<if $vaginaexist is 1>>
womb
<<else>>
prostate
<</if>>
<</nobr>><</widget>>
<<widget "prostatestop">><<nobr>>
<<if $vaginaexist is 1>>
womb.
<<else>>
prostate.
<</if>>
<</nobr>><</widget>>
<<widget "prostatecomma">><<nobr>>
<<if $vaginaexist is 1>>
womb,
<<else>>
prostate,
<</if>>
<</nobr>><</widget>>
<<widget "bitch">><<nobr>>
<<if $playergenderappearance is "m">>
bitch
<<else>>
bitch
<</if>>
<</nobr>><</widget>>
<<widget "bitchstop">><<nobr>>
<<if $playergenderappearance is "m">>
bitch.
<<else>>
bitch.
<</if>>
<</nobr>><</widget>>
<<widget "bitchcomma">><<nobr>>
<<if $playergenderappearance is "m">>
bitch,
<<else>>
bitch,
<</if>>
<</nobr>><</widget>>
<<widget "tearful">><<nobr>>
<<if $trauma gte $traumamax>>
Eyes glazed and empty,
<<elseif $trauma gte ($traumamax / 5) * 4>>
<<if $stress gte 8000>>
<<if $arousal gte 8000>>
<<if $pain gte 100>>
Tendrils of darkness whip and writhe against your skin as
<<elseif $pain gte 40>>
Tendrils of darkness writhe against your skin as
<<else>>
A strange mist closes around you and probes your most sensitive spots as
<</if>>
<<elseif $arousal gte 2000>>
<<if $pain gte 100>>
A mass of darkness follows you, prodding and spanking your behind as
<<elseif $pain gte 40>>
You hear phantom voices mocking you as
<<else>>
The shadows seem to close in on you as
<</if>>
<<else>>
<<if $pain gte 100>>
Tendrils of darkness whip and cut at your skin as
<<elseif $pain gte 40>>
Tendrils of darkness poke you as
<<else>>
You think you see eyes watching from the shadows as
<</if>>
<</if>>
<<elseif $stress gte 2000>>
<<if $arousal gte 8000>>
<<if $pain gte 100>>
Your tortured body and mind yearn for more punishment as
<<elseif $pain gte 40>>
Fantasies of violent sex intrude as
<<else>>
Your tortured mind yearns for more punishment as
<</if>>
<<elseif $arousal gte 2000>>
<<if $pain gte 100>>
Surprised that nothing is trying to hurt you,
<<elseif $pain gte 40>>
Surprised that nothing is trying to rape you,
<<else>>
Surprised that nothing is trying to fuck you,
<</if>>
<<else>>
<<if $pain gte 100>>
Feeling deserving of the pain you're in,
<<elseif $pain gte 40>>
You imagine figures stalking you as
<<else>>
You feel like you're being watched as
<</if>>
<</if>>
<<else>>
<<if $arousal gte 8000>>
<<if $pain gte 100>>
Thoughts about being sexually tortured intrude as
<<elseif $pain gte 40>>
Thoughts about being restrained and whipped intrude as
<<else>>
Thoughts about being a sex slave intrude as
<</if>>
<<elseif $arousal gte 2000>>
<<if $pain gte 100>>
Thoughts about being violently raped intrude as
<<elseif $pain gte 40>>
Thoughts about being brutally raped intrude as
<<else>>
Thoughts about being raped intrude as
<</if>>
<<else>>
<<if $pain gte 100>>
Feeling entirely deserving of the pain you're in,
<<elseif $pain gte 40>>
Though mentally and physically tormented,
<<else>>
You feel utterly worthless as
<</if>>
<</if>>
<</if>>
<<elseif $trauma gte ($traumamax / 5) * 2>>
<<if $stress gte 8000>>
<<if $arousal gte 8000>>
<<if $pain gte 100>>
A part of you savours the pain you're in as
<<elseif $pain gte 40>>
Tearful and worried that you're losing your mind,
<<else>>
Though worried that you're losing your mind,
<</if>>
<<elseif $arousal gte 2000>>
<<if $pain gte 100>>
Though afraid something will attack you,
<<elseif $pain gte 40>>
Though afraid something will jump you,
<<else>>
Feeling on the verge of panic,
<</if>>
<<else>>
<<if $pain gte 100>>
Though hurt and vulnerable,
<<elseif $pain gte 40>>
You feel self-conscious about the tears on your face as
<<else>>
You jump at every unexpected movement as
<</if>>
<</if>>
<<elseif $stress gte 2000>>
<<if $arousal gte 8000>>
<<if $pain gte 100>>
Hurt and ashamed,
<<elseif $pain gte 40>>
Despite your pain, a primal yearning swells within as
<<else>>
Shameful thoughts intrude as
<</if>>
<<elseif $arousal gte 2000>>
<<if $pain gte 100>>
You hope no one tries to assault you as
<<elseif $pain gte 40>>
Though afraid you're being followed,
<<else>>
You fear that someone is stalking you as
<</if>>
<<else>>
<<if $pain gte 100>>
You feel fragile and vulnerable as
<<elseif $pain gte 40>>
You sob as
<<else>>
You try to keep it together as
<</if>>
<</if>>
<<else>>
<<if $arousal gte 8000>>
<<if $pain gte 100>>
Feeling ashamed and in pain,
<<elseif $pain gte 40>>
Tears cover your ashamed face as
<<else>>
Ashamed of the feelings rising within you,
<</if>>
<<elseif $arousal gte 2000>>
<<if $pain gte 100>>
Your body hurts yet tingles shamefully as
<<elseif $pain gte 40>>
You sob at the injustice of it all as
<<else>>
Your <<genitals>> involuntarily twitches as
<</if>>
<<else>>
<<if $pain gte 100>>
Feeling lost and in pain,
<<elseif $pain gte 40>>
You try and fail to hold back your tears as
<<else>>
Shaken,
<</if>>
<</if>>
<</if>>
<<else>>
<<if $stress gte 8000>>
<<if $arousal gte 8000>>
<<if $pain gte 100>>
You're an emotional wreck as
<<elseif $pain gte 40>>
Feeling emotionally and physically tender,
<<else>>
Though afraid your body will betray you,
<</if>>
<<elseif $arousal gte 2000>>
<<if $pain gte 100>>
Hurt and afraid,
<<elseif $pain gte 40>>
You struggle to cope with the myriad feelings assailing you as
<<else>>
You feel faint as
<</if>>
<<else>>
<<if $pain gte 100>>
You know you must look like a complete mess as
<<elseif $pain gte 40>>
You wonder what you did to deserve this as
<<else>>
Though at your wits' end,
<</if>>
<</if>>
<<elseif $stress gte 2000>>
<<if $arousal gte 8000>>
<<if $pain gte 100>>
You feel a primal yearning beneath your pain as
<<elseif $pain gte 40>>
Though humiliated by your body's signs of arousal,
<<else>>
Though embarrassed by your body's signs of arousal,
<</if>>
<<elseif $arousal gte 2000>>
<<if $pain gte 100>>
Shaken and hurt,
<<elseif $pain gte 40>>
Your body tingles painfully as
<<else>>
You feel self-conscious about the lewd warmth within you as
<</if>>
<<else>>
<<if $pain gte 100>>
Face covered in tears,
<<elseif $pain gte 40>>
Feeling battered, but still determined to make the best of things,
<<else>>
Still determined to make the best of things,
<</if>>
<</if>>
<<else>>
<<if $arousal gte 8000>>
<<if $pain gte 100>>
Your tortured body trembles with arousal as
<<elseif $pain gte 40>>
Tears run down your flushed cheeks as
<<else>>
Your body trembles with arousal as
<</if>>
<<elseif $arousal gte 2000>>
<<if $pain gte 100>>
Your body hurts and tingles as
<<elseif $pain gte 40>>
Your body feels sensitive as
<<else>>
You feel horny as
<</if>>
<<else>>
<<if $pain gte 100>>
Your whole body hurts as
<<elseif $pain gte 40>>
You wipe away your tears as
<<else>>
You waste no time as
<</if>>
<</if>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "slithers">><<nobr>>
<<set $rng to random(1, 100)>>
<<if $rng gte 95>>
slithers
<<elseif $rng gte 90>>
writhes
<<elseif $rng gte 85>>
wriggles
<<elseif $rng gte 80>>
wiggles
<<elseif $rng gte 75>>
crawls
<<elseif $rng gte 70>>
slides
<<elseif $rng gte 65>>
slinks
<<elseif $rng gte 60>>
glides
<<elseif $rng gte 55>>
slips
<<elseif $rng gte 50>>
squirms
<<elseif $rng gte 45>>
worms
<<elseif $rng gte 40>>
twists
<<elseif $rng gte 35>>
twitches
<<elseif $rng gte 30>>
shivers
<<elseif $rng gte 25>>
trembles
<<elseif $rng gte 20>>
jerks
<<elseif $rng gte 15>>
crawls
<<elseif $rng gte 10>>
flutters
<<elseif $rng gte 5>>
meanders
<<elseif $rng gte 0>>
slips
<</if>>
<</nobr>><</widget>>
<<widget "wallet">><<nobr>>
<<if $pronoun is "m">>wallet<<else>>purse<</if>>
<</nobr>><</widget>>
<<widget "walletcomma">><<nobr>>
<<if $pronoun is "m">>wallet,<<else>>purse,<</if>>
<</nobr>><</widget>>
<<widget "walletstop">><<nobr>>
<<if $pronoun is "m">>wallet.<<else>>purse.<</if>>
<</nobr>><</widget>>
<<widget "pullup">><<nobr>>
<<if $upperset is $lowerset>>
pull down
<<elseif $uppertype isnot "naked">>
pull up
<<else>>
bare
<</if>>
<</nobr>><</widget>>
<<widget "pulldown">><<nobr>>
<<if $skirt is 1>>
lift up
<<elseif $lowerset isnot $upperset>>
pull down
<<else>>
bare
<</if>>
<</nobr>><</widget>>
<<widget "pullsup">><<nobr>>
<<if $upperset is $lowerset>>
pulls down
<<elseif $uppertype isnot "naked">>
pulls up
<<else>>
bares
<</if>>
<</nobr>><</widget>>
<<widget "pullsdown">><<nobr>>
<<if $skirt is 1>>
lifts up
<<elseif $lowerset isnot $upperset>>
pulls down
<<else>>
bares
<</if>>
<</nobr>><</widget>>
<<widget "glans">><<nobr>>
<<if $penisuse is 0>>
glans
<<else>>
shaft
<</if>>
<</nobr>><</widget>>
<<widget "glanscomma">><<nobr>>
<<if $penisuse is 0>>
glans,
<<else>>
shaft,
<</if>>
<</nobr>><</widget>>
<<widget "glansstop">><<nobr>>
<<if $penisuse is 0>>
glans.
<<else>>
shaft.
<</if>>
<</nobr>><</widget>>
<<widget "testicles">><<nobr>>
testes
<</nobr>><</widget>>
<<widget "testiclescomma">><<nobr>>
testes,
<</nobr>><</widget>>
<<widget "testiclesstop">><<nobr>>
testes.
<</nobr>><</widget>>
<<widget "swimmingdifficultytext0">><<nobr>>
| <span class="green">These waters look safe</span>
<</nobr>><</widget>>
<<widget "swimmingdifficultytext100">><<nobr>>
<<if $swimmingskill gte 100>>
| <span class="green">These waters look safe</span>
<<elseif $swimmingskill gte 50>>
| <span class="pink">These waters look risky</span>
<<else>>
| <span class="red">These waters look dangerous</span>
<</if>>
<</nobr>><</widget>>
<<widget "swimmingdifficultytext200">><<nobr>>
<<if $swimmingskill gte 200>>
| <span class="green">These waters look safe</span>
<<elseif $swimmingskill gte 100>>
| <span class="pink">These waters look risky</span>
<<else>>
| <span class="red">These waters look dangerous</span>
<</if>>
<</nobr>><</widget>>
<<widget "swimmingdifficultytext300">><<nobr>>
<<if $swimmingskill gte 300>>
| <span class="green">These waters look safe</span>
<<elseif $swimmingskill gte 150>>
| <span class="pink">These waters look risky</span>
<<else>>
| <span class="red">These waters look dangerous</span>
<</if>>
<</nobr>><</widget>>
<<widget "swimmingdifficultytext400">><<nobr>>
<<if $swimmingskill gte 400>>
| <span class="green">These waters look safe</span>
<<elseif $swimmingskill gte 200>>
| <span class="pink">These waters look risky</span>
<<else>>
| <span class="red">These waters look dangerous</span>
<</if>>
<</nobr>><</widget>>
<<widget "nexttext">><<nobr>>
(<i>Enter</i>)
<</nobr>><</widget>>
<<widget "monk">><<nobr>>
<<if $pronoun is "m">>
monk
<<else>>
nun
<</if>>
<</nobr>><</widget>>
<<widget "monks">><<nobr>>
<<if $pronoun is "m">>
monks
<<else>>
nuns
<</if>>
<</nobr>><</widget>>
<<widget "vaginalvirginitywarning">><<nobr>>
<<if $vaginalvirginity is 1>>
<span class="red"> This action will deflower you.</span>
<</if>>
<</nobr>><</widget>>
<<widget "penilevirginitywarning">><<nobr>>
<<if $penilevirginity is 1>>
<span class="red"> This action will deflower you.</span>
<</if>>
<</nobr>><</widget>>
<<widget "wolfgirl">><<nobr>>
<<if $playergenderappearance is "m">>
| <span class="blue">Wolfboy</span>
<<else>>
| <span class="blue">Wolfgirl</span>
<</if>>
<</nobr>><</widget>>
<<widget "fallenangel">><<nobr>>
| <span class="black">Fallen Angel</span>
<</nobr>><</widget>>
:: Traits [nobr]
<<back>><br><br><<set $menu to 1>>
<<if $vaginalvirginity is 1 and $penilevirginity is 1>>
<span class="green">Virgin</span> - Your purity recovers faster. Your virginity might be worth something.<br><br>
<</if>>
<<if $wolfgirl gte 2>>
Fangs - Biting is three times as effective.<br>
<</if>>
<<if $wolfgirl gte 6>>
Wolf <<girl>> - The spirit of the wild lives within you, making you more defiant over time. Your ears and tail make you more conspicuous.<br>
<</if>>
<<if $fallenangel gte 2>>
<span class="black">Fallen angel</span> - The world is so cruel. You feel less pure by the day.<br>
<</if>>
<<if $angel gte 6>>
<span class="gold">Angel</span> - You radiate purity. Unlocks the "forgive" action once per encounter, removing any trauma gained so far. Beware, losing your virginity will remove this trait and leave you broken.<br>
<</if>>
<<if $demon gte 6>>
<<if $playergenderappearance is "m">>
<<if $playergender is "m">>
<span class="red">Incubus</span>
<<else>>
<span class="red">Incubus (female)</span>
<</if>>
<<else>>
<<if $playergender is "m">>
<span class="red">Succubus (male)</span>
<<else>>
<span class="red">Succubus</span>
<</if>>
<</if>>
- You're devoid of purity. You lose trauma when something cums inside you, or you cum inside something else. Tentacles reduce stress and pain instead of trauma. Beware, ending a day with anything but minimum purity will be very stressful.<br>
<</if>>
<<if $submissive gte 1150 and $submissive lte 1499>>
<span class="meek">Meek</span> - Unlocks the "Moan" action.<br>
<</if>>
<<if $submissive gte 1500>>
<span class="sub">Submissive</span> - unlocks the "Moan" action.<br>
<</if>>
<<if $submissive lte 850 and $submissive gte 501>>
<span class="brat">Bratty</span> - unlocks the "Demand" action.<br>
<</if>>
<<if $submissive lte 500>>
<span class="def">Defiant</span> - unlocks the "Demand" action.<br>
<</if>>
<<if $orgasmtrait gte 1>>
<span class="lewd">Orgasm Addict</span> - So many orgasms has had a physiological effect. Cumming is more difficult but pleasurable orgasms relieve more stress and painful orgasms no longer increase stress.<br>
<</if>>
<<if $ejactrait gte 1>>
<span class="lewd">Cum Dump</span> - You've become accustomed to the scent of ejaculate and can take advantage of its calming effect. Your stress is reduced hourly depending on how much slime and semen covers you.<br>
<</if>>
<<if $molesttrait gte 1>>
<span class="lewd">Plaything</span> - You've learned to better cope with psychological trauma. Being molested no longer removes your sense of control (rape still does).<br>
<</if>>
<<if $rapetrait gte 1>>
<span class="lewd">Fucktoy</span> - You've been raped so much, but you've learned how to cope. Trauma increases more slowly.<br>
<</if>>
<<if $bestialitytrait gte 1>>
<span class="lewd">Bitch</span> - Animals have tried to breed with you so often that you're used to it. Trauma increases more slowly when attacked by animals.<br>
<</if>>
<<if $tentacletrait gte 1>>
<span class="lewd">Prey</span> - Many tentacles have had their way with your body. Trauma increases more slowly when attacked by tentacles.<br>
<</if>>
<<if $voretrait gte 1>>
<span class="lewd">Tasty</span> - You've found your way into the belly of many a creature. They'll have a harder time swallowing you as they savour your taste.<br>
<</if>>
<<if $robinpaid gte 1>>
<span class="lblue">Robin's protector</span> - Robin is dependent on you. You need to be strong. Increases daily trauma decay.<br>
<</if>>
<br>
<<if $englishtrait is 1>>
<span class="blue">Passable English</span> - Speech actions (plead, moan, demand, apologise, mock, tease) are twice as effective.<br>
<<elseif $englishtrait is 2>>
<span class="lblue">Decent English</span> - Speech actions (plead, moan, demand, apologise, mock, tease) are three times as effective.<br>
<<elseif $englishtrait is 3>>
<span class="teal">Good English</span> - Speech actions (plead, moan, demand, apologise, mock, tease) are four times as effective.<br>
<<elseif $englishtrait is 4>>
<span class="green">Excellent English</span> - Speech actions (plead, moan, demand, apologise, mock, tease) are five times as effective.<br>
<</if>>
<<if $sciencetrait is 1>>
<span class="blue">Passable Science</span> - Pain is slightly easier to cope with.<br>
<<elseif $sciencetrait is 2>>
<span class="lblue">Decent Science</span> - Pain is moderately easier to cope with.<br>
<<elseif $sciencetrait is 3>>
<span class="teal">Good Science</span> - Pain is easier to cope with.<br>
<<elseif $sciencetrait is 4>>
<span class="green">Excellent Science</span> - Pain is much easier to cope with.<br>
<</if>>
<<if $historytrait is 1>>
<span class="blue">Passable History</span> - You know there are secret paths around town.<br>
<<elseif $historytrait is 2>>
<span class="lblue">Decent History</span> - You know of a few secret paths around town.<br>
<<elseif $historytrait is 3>>
<span class="teal">Good History</span> - You know of several secret paths around town.<br>
<<elseif $historytrait is 4>>
<span class="green">Excellent History</span> - You know of many secret paths around town.<br>
<</if>>
<<if $mathstrait is 1>>
<span class="blue">Passable Maths</span> - You make 25% more from tips and negotiated fees.<br>
<<elseif $mathstrait is 2>>
<span class="lblue">Decent Maths</span> - You make 50% more from tips and negotiated fees.<br>
<<elseif $mathstrait is 3>>
<span class="teal">Good Maths</span> - You make 75% more from tips and negotiated fees.<br>
<<elseif $mathstrait is 4>>
<span class="green">Excellent Maths</span> - You make 100% more from tips and negotiated fees.<br>
<</if>>
<<if $schooltrait is 1>>
<span class="blue">Okay at school</span> - Your performance at school has improved your self-esteem, slightly increasing your daily trauma decay.<br>
<<elseif $schooltrait is 2>>
<span class="lblue">Decent at school</span> - Your performance at school has improved your self-esteem, moderately increasing your daily trauma decay.<br>
<<elseif $schooltrait is 3>>
<span class="teal">Good at school</span> - Your performance at school has improved your self-esteem, increasing your daily trauma decay.<br>
<<elseif $schooltrait is 4>>
<span class="green">Excellent at school</span> - Your performance at school has improved your self-esteem, greatly increasing your daily trauma decay.<br>
<</if>>
<br>
<<if $controlled is 0>>
<<if $sleeptrouble gte 1>>
Insomnia - <span class="red">Sleep less effective</span><br>
<</if>>
<<if $nightmares gte 1>>
Nightmares - <span class="red">Sleep is stressful</span><br>
<</if>>
<<if $anxiety gte 1>>
Anxiety Disorder - <span class="red">Stress won't automatically decrease over time</span><br>
<</if>>
<<if $anxiety gte 2>>
Severe Anxiety Disorder - <span class="red">Stress increases over time</span><br>
<</if>>
<<if $flashbacks gte 1>>
Flashbacks - <span class="red">May relive nasty experiences</span><br>
<</if>>
<<if $panicattacks gte 1>>
Panic Attacks - <span class="red">Chance of paralysis</span><br>
<</if>>
<<if $panicattacks gte 2>>
Severe Panic Attacks - <span class="red">Chance of uncontrollable violent outbursts</span><br>
<</if>>
<<if $hallucinations gte 1>>
Hallucinations - <span class="red">More dangers during encounters</span><br>
<</if>>
<<if $hallucinations gte 2>>
Severe Hallucinations - <span class="red">More dangerous world</span><br>
<</if>>
<<if $dissociation gte 1>>
Visibly Disturbed - <span class="red">There's something wrong with you, and people can tell</span><br>
<</if>>
<<if $dissociation gte 2>>
Dissociation - <span class="red">Nothing feels real</span><br>
<</if>>
<<else>>
<<if $sleeptrouble gte 1>>
<span class="blue">Controlled</span> Insomnia - <span class="black">Sleep less effective</span><br>
<</if>>
<<if $nightmares gte 1>>
<span class="blue">Controlled</span> Nightmares - <span class="black">Sleep is stressful</span><br>
<</if>>
<<if $anxiety gte 1>>
<span class="blue">Controlled</span> Anxiety Disorder - <span class="black">Stress won't automatically decrease over time</span><br>
<</if>>
<<if $anxiety gte 2>>
<span class="blue">Controlled</span> Severe Anxiety Disorder - <span class="black">Stress increases over time</span><br>
<</if>>
<<if $flashbacks gte 1>>
<span class="blue">Controlled</span> Flashbacks - <span class="black">May relive nasty experiences</span><br>
<</if>>
<<if $panicattacks gte 1>>
<span class="blue">Controlled</span> Panic Attacks - <span class="black">Chance of paralysis</span><br>
<</if>>
<<if $panicattacks gte 2>>
<span class="blue">Controlled</span> Severe Panic Attacks - <span class="black">Chance of uncontrollable violent outbursts</span><br>
<</if>>
<<if $hallucinations gte 1>>
<span class="blue">Controlled</span> Hallucinations - <span class="black">More dangers during encounters</span><br>
<</if>>
<<if $hallucinations gte 2>>
<span class="blue">Controlled</span> Severe Hallucinations - <span class="black">More dangers in the world</span><br>
<</if>>
<<if $dissociation gte 1>>
Visibly Disturbed - <span class="red">There's something wrong with you, and people can tell</span><br>
<</if>>
<<if $dissociation gte 2>>
<span class="blue">Controlled</span> Dissociation - <span class="black">Nothing feels real</span><br>
<</if>>
<</if>>
<<if $syndromeeden gte 1>>
Stockholm Syndrome: Eden - <span class="red">It must be lonely living on your own in the woods.</span><br>
<</if>>
<<if $syndromewolves gte 1>>
Stockholm Syndrome: Wolves - <span class="red">They're just cute animals.</span><br>
<</if>>
<br>
:: Widgets Exhibitionism [widget]
<<widget "exhibitionism1">><<nobr>>
<<if $control lt $controlmax>>
<<if $exhibitionism lte 19>>
<<set $exhibitionism += 2>>
Performing such a lewd act excites you and <span class="green">restores your sense of control and self-worth</span>, for now.<<ggcontrol>><<control 25>><<set $arousal += 100>><<set $stress -= 300>><<combattrauma -30>><<ltrauma>><<lstress>><<garousal>>
<<elseif $exhibitionism gte 20>>
While performing such a lewd act excites you, it does nothing to lift the cloud hanging over you. <span class="pink">You need to do something more extreme.</span><<set $arousal += 100>><<garousal>>
<<if $exhibitionismstress1 isnot 1>><<set $exhibitionismstress1 to 1>><<lstress>><<set $stress -= 100>>
<</if>>
<</if>>
<<else>>
<<if $exhibitionism lte 19>>
<<set $exhibitionism += 2>>
You already feel in control, but performing such a lewd act <span class="green">soothes</span> and excites you.<<control 25>><<set $arousal += 100>><<set $stress -= 300>><<combattrauma -30>><<ltrauma>><<lstress>><<garousal>>
<<elseif $exhibitionism gte 20>>
You already feel in control and the act is <span class="pink">too tame to soothe</span>, but it does excite you.<<set $arousal += 100>><<garousal>>
<<if $exhibitionismstress1 isnot 1>><<set $exhibitionismstress1 to 1>><<lstress>><<set $stress -= 100>>
<</if>>
<</if>>
<</if>>
<br><br><</nobr>><</widget>>
<<widget "exhibitionism2">><<nobr>>
<<if $control lt $controlmax>>
<<if $exhibitionism lte 39>>
<<set $exhibitionism += 2>>
Performing such a lewd act excites you and <span class="green">restores your sense of control and self-worth</span>, for now.<<ggcontrol>><<control 25>><<set $arousal += 200>><<set $stress -= 600>><<combattrauma -60>><<ltrauma>><<lstress>><<garousal>>
<<elseif $exhibitionism gte 40>>
While performing such a lewd act excites you, it does nothing to lift the cloud hanging over you. <span class="pink">You need to do something more extreme.</span><<set $arousal += 100>><<garousal>>
<<if $exhibitionismstress2 isnot 1>><<set $exhibitionismstress2 to 1>><<lstress>><<set $stress -= 200>>
<</if>>
<</if>>
<<else>>
<<if $exhibitionism lte 39>>
<<set $exhibitionism += 2>>
You already feel in control, but performing such a lewd act <span class="green">soothes</span> and excites you.<<control 25>><<set $arousal += 600>><<set $stress -= 200>><<combattrauma -60>><<ltrauma>><<lstress>><<garousal>>
<<elseif $exhibitionism gte 40>>
You already feel in control and the act is <span class="pink">too tame to soothe</span>, but it does excite you.<<set $arousal += 200>><<garousal>>
<<if $exhibitionismstress2 isnot 1>><<set $exhibitionismstress2 to 1>><<lstress>><<set $stress -= 200>>
<</if>>
<</if>>
<</if>>
<br><br><</nobr>><</widget>>
<<widget "exhibitionism3">><<nobr>>
<<if $control lt $controlmax>>
<<if $exhibitionism lte 59>>
<<set $exhibitionism += 2>>
Performing such a lewd act excites you and <span class="green">restores your sense of control and self-worth</span>, for now.<<ggcontrol>><<control 25>><<set $arousal += 300>><<set $stress -= 900>><<combattrauma -90>><<ltrauma>><<lstress>><<garousal>>
<<elseif $exhibitionism gte 60>>
While performing such a lewd act excites you, it does nothing to lift the cloud hanging over you. <span class="pink">You need to do something more extreme.</span><<set $arousal += 300>><<garousal>>
<<if $exhibitionismstress3 isnot 1>><<set $exhibitionismstress3 to 1>><<lstress>><<set $stress -= 300>>
<</if>>
<</if>>
<<else>>
<<if $exhibitionism lte 59>>
<<set $exhibitionism += 2>>
You already feel in control, but performing such a lewd act <span class="green">soothes</span> and excites you.<<control 25>><<set $arousal += 300>><<set $stress -= 900>><<combattrauma -90>><<ltrauma>><<lstress>><<garousal>>
<<elseif $exhibitionism gte 60>>
You already feel in control and the act is <span class="pink">too tame to soothe</span>, but it does excite you.<<set $arousal += 300>><<garousal>>
<<if $exhibitionismstress3 isnot 1>><<set $exhibitionismstress3 to 1>><<lstress>><<set $stress -= 300>>
<</if>>
<</if>>
<</if>>
<br><br><</nobr>><</widget>>
<<widget "exhibitionism4">><<nobr>>
<<if $control lt $controlmax>>
<<if $exhibitionism lte 79>>
<<set $exhibitionism += 2>>
Performing such a lewd act excites you and <span class="green">restores your sense of control and self-worth</span>, for now.<<ggcontrol>><<control 25>><<set $arousal += 400>><<set $stress -= 1200>><<combattrauma -120>><<ltrauma>><<lstress>><<garousal>>
<<elseif $exhibitionism gte 80>>
While performing such a lewd act excites you, it does nothing to lift the cloud hanging over you. <span class="pink">You need to do something more extreme.</span><<set $arousal += 400>><<garousal>>
<<if $exhibitionismstress4 isnot 1>><<set $exhibitionismstress4 to 1>><<lstress>><<set $stress -= 400>>
<</if>>
<</if>>
<<else>>
<<if $exhibitionism lte 79>>
<<set $exhibitionism += 2>>
You already feel in control, but performing such a lewd act <span class="green">soothes</span> and excites you.<<control 25>><<set $arousal += 400>><<set $stress -= 1200>><<combattrauma -120>><<ltrauma>><<lstress>><<garousal>>
<<elseif $exhibitionism gte 80>>
You already feel in control and the act is <span class="pink">too tame to soothe</span>, but it does excite you.<<set $arousal += 400>><<garousal>>
<<if $exhibitionismstress4 isnot 1>><<set $exhibitionismstress4 to 1>><<lstress>><<set $stress -= 400>>
<</if>>
<</if>>
<</if>>
<br><br><</nobr>><</widget>>
<<widget "exhibitionism5">><<nobr>>
<<if $control lt $controlmax>>
<<if $exhibitionism lte 99>>
<<set $exhibitionism += 2>>
Performing such a lewd act excites you and <span class="green">restores your sense of control and self-worth</span>, for now.<<ggcontrol>><<control 25>><<set $arousal += 500>><<set $stress -= 1500>><<combattrauma -150>><<ltrauma>><<lstress>><<garousal>>
<<elseif $exhibitionism gte 100>>
While performing such a lewd act excites you, it does nothing to lift the cloud hanging over you. <span class="pink">You need to do something more extreme.</span><<set $arousal += 500>><<garousal>>
<<if $exhibitionismstress5 isnot 1>><<set $exhibitionismstress5 to 1>><<lstress>><<set $stress -= 500>>
<</if>>
<</if>>
<<else>>
<<if $exhibitionism lte 99>>
<<set $exhibitionism += 2>>
You already feel in control, but performing such a lewd act <span class="green">soothes</span> and excites you.<<control 25>><<set $arousal += 500>><<set $stress -= 1500>><<combattrauma -150>><<ltrauma>><<lstress>><<garousal>>
<<elseif $exhibitionism gte 100>>
You already feel in control and the act is <span class="pink">too tame to soothe</span>, but it does excite you.<<set $arousal += 500>><<garousal>>
<<if $exhibitionismstress5 isnot 1>><<set $exhibitionismstress5 to 1>><<lstress>><<set $stress -= 500>>
<</if>>
<</if>>
<</if>>
<br><br><</nobr>><</widget>>
<<widget "exhibitionismstreet">><<nobr>>
<<if $exposed is 1>><<set $arousal += 20>>
<<if $daystate is "night">>
You are standing on a public street in a state of undress! The cold night air blows against your bare skin. There appears to be no one else around, but you don't know how long that will last.<br><br>
You feel intense embarrassment at your exposure
<<if $leftarm is "bound" and $rightarm is "bound">>
but with your arms bound you can do nothing to hide your nakedness.
<<else>>
and cover yourself as best you can.
<</if>><br><br>
It's dark enough that you could remain mostly concealed by sticking to the shadows. Alternatively you could avoid the street entirely. You might feel less exposed but there's something foreboding about the darkness.<br><br>
<<else>>
You are standing on a public street in a state of undress! You take cover behind a parked car, shielding you from view for now.
You feel intense embarrassment at your exposure
<<if $leftarm is "bound" and $rightarm is "bound">>
but with your arms bound you can do nothing to hide your nakedness.
<<else>>
and cover yourself as best you can.
<</if>>
<br><br>
<</if>>
<<elseif $exposed is 2>><<set $arousal += 50>>
<<if $daystate is "night">>
You are standing on a public street with your vulnerables exposed! The cold night air blows against your bare skin. There appears to be no one else around, but you don't know how long that will last.
You feel intense embarrassment at your exposure
<<if $leftarm is "bound" and $rightarm is "bound">>
but with your arms bound you can do nothing to hide your nakedness.
<<else>>
and cover yourself as best you can.
<</if>><br><br>
It's dark enough that you could remain mostly concealed by sticking to the shadows. Alternatively you could avoid the street entirely. You might feel less exposed but there's something foreboding about the darkness.<br><br>
<<else>>
You are standing on a public street with your vulnerables exposed for all to see! You take cover behind a parked car, shielding you from view for now.
You feel intense embarrassment at your exposure
<<if $leftarm is "bound" and $rightarm is "bound">>
but with your arms bound you can do nothing to hide your nakedness.
<<else>>
and cover yourself as best you can.
<</if>>
<br><br>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "exhibitionismalley">><<nobr>>
<<if $exposed is 1>><<set $arousal += 20>>
<<if $daystate is "night">>
You are standing in a public alley in a state of undress! The cold night air blows against your bare skin. There appears to be no one else around, but you don't know how long that will last.<br><br>
You feel intense embarrassment at your exposure
<<if $leftarm is "bound" and $rightarm is "bound">>
but with your arms bound you can do nothing to hide your nakedness.
<<else>>
and cover yourself as best you can.
<</if>><br><br>
<<else>>
You are standing in a public alley in a state of undress.
You feel intense embarrassment at your exposure
<<if $leftarm is "bound" and $rightarm is "bound">>
but with your arms bound you can do nothing to hide your nakedness.
<<else>>
and cover yourself as best you can.
<</if>>
<br><br>
<</if>>
<<elseif $exposed is 2>><<set $arousal += 50>>
<<if $daystate is "night">>
You are standing in a public alley with your vulnerables exposed! The cold night air blows against your bare skin. There appears to be no one else around, but you don't know how long that will last.
You feel intense embarrassment at your exposure
<<if $leftarm is "bound" and $rightarm is "bound">>
but with your arms bound you can do nothing to hide your nakedness.
<<else>>
and cover yourself as best you can.
<</if>><br><br>
<<else>>
You are standing in a public alley with your vulnerables exposed!
You feel intense embarrassment at your exposure
<<if $leftarm is "bound" and $rightarm is "bound">>
but with your arms bound you can do nothing to hide your nakedness.
<<else>>
and cover yourself as best you can.
<</if>>
<</if>>
<</if>>
<br><br>
<</nobr>><</widget>>
<<widget "exhibitionismpark">><<nobr>>
<<if $exposed is 1>><<set $arousal += 20>>
<<if $daystate is "night">>
You are hiding behind a bush. The cold night air blows against your bare skin. <br><br>
You feel intense embarrassment at your exposure
<<if $leftarm is "bound" and $rightarm is "bound">>
but with your arms bound you can do nothing to hide your nakedness.
<<else>>
and cover yourself as best you can.
<</if>><br><br>
<<else>>
You are hiding behind a bush. If you're careful you might be able to remain concealed by hiding behind vegetation.<br>
Regardless, you feel intense embarrassment at your exposure
<<if $leftarm is "bound" and $rightarm is "bound">>
but with your arms bound you can do nothing to hide your nakedness.
<<else>>
and cover yourself as best you can.
<</if>>
<br><br>
<</if>>
<<elseif $exposed is 2>><<set $arousal += 50>>
<<if $daystate is "night">>
You are hiding behind a bush. The cold night air blows against your bare skin.
You feel intense embarrassment at your exposure
<<if $leftarm is "bound" and $rightarm is "bound">>
but with your arms bound you can do nothing to hide your nakedness.
<<else>>
and cover yourself as best you can.
<</if>><br><br>
<<else>>
You are hiding behind a bush. If you're careful you might be able to remain concealed by hiding behind vegetation.<br>
Regardless, you feel intense embarrassment at your exposure
<<if $leftarm is "bound" and $rightarm is "bound">>
but with your arms bound you can do nothing to hide your nakedness.
<<else>>
and cover yourself as best you can.
<</if>>
<</if>>
<</if>>
<br><br>
<</nobr>><</widget>>
<<widget "exhibitionismgarden">><<nobr>>
<<if $exposed is 1>><<set $arousal += 20>>
<<if $daystate is "night">>
You are hiding behind the garden shed. The cold night air blows against your bare skin. You hope you can make it to your bedrom without anyone seeing you.<br><br>
You feel intense embarrassment at your exposure
<<if $leftarm is "bound" and $rightarm is "bound">>
but with your arms bound you can do nothing to hide your nakedness.
<<else>>
and cover yourself as best you can.
<</if>><br><br>
<<else>>
You are hiding behind the garden shed. You hope you can make it to your bedrom without anyone seeing you.<br><br>
You feel intense embarrassment at your exposure
<<if $leftarm is "bound" and $rightarm is "bound">>
but with your arms bound you can do nothing to hide your nakedness.
<<else>>
and cover yourself as best you can.
<</if>>
<br><br>
<</if>>
<<elseif $exposed is 2>><<set $arousal += 50>>
<<if $daystate is "night">>
You are hiding behind the garden shed. The cold night air blows against your bare skin. You hope you can make it to your bedrom without anyone seeing you.<br><br>
You feel intense embarrassment at your exposure
<<if $leftarm is "bound" and $rightarm is "bound">>
but with your arms bound you can do nothing to hide your nakedness.
<<else>>
and cover yourself as best you can.
<</if>><br><br>
<<else>>
You are hiding behind the garden shed. You hope you can make it to your bedrom without anyone seeing you.<br><br>
You feel intense embarrassment at your exposure
<<if $leftarm is "bound" and $rightarm is "bound">>
but with your arms bound you can do nothing to hide your nakedness.
<<else>>
and cover yourself as best you can.
<</if>>
<</if>>
<</if>>
<br><br>
<</nobr>><</widget>>
<<widget "exhibitionismroof">><<nobr>>
<<if $exposed is 1>><<set $arousal += 20>>
<<if $daystate is "night">>
The cool night breeze makes you shiver. The open air makes you feel more exposed than ever despite no one being around.<br><br>
You feel intense embarrassment at your exposure
<<if $leftarm is "bound" and $rightarm is "bound">>
but with your arms bound you can do nothing to hide your nakedness.
<<else>>
and cover yourself as best you can.
<</if>><br><br>
<<else>>
The open air makes you feel more exposed than ever despite no one being around.<br><br>
You feel intense embarrassment at your exposure
<<if $leftarm is "bound" and $rightarm is "bound">>
but with your arms bound you can do nothing to hide your nakedness.
<<else>>
and cover yourself as best you can.
<</if>>
<br><br>
<</if>>
<<elseif $exposed is 2>><<set $arousal += 50>>
<<if $daystate is "night">>
The cool night breeze makes you shiver. The open air makes you feel more exposed than ever despite no one being around.<br><br>
You feel intense embarrassment at your exposure
<<if $leftarm is "bound" and $rightarm is "bound">>
but with your arms bound you can do nothing to hide your nakedness.
<<else>>
and cover yourself as best you can.
<</if>><br><br>
<<else>>
The open air makes you feel more exposed than ever despite no one being around.<br><br>
You feel intense embarrassment at your exposure
<<if $leftarm is "bound" and $rightarm is "bound">>
but with your arms bound you can do nothing to hide your nakedness.
<<else>>
and cover yourself as best you can.
<</if>>
<</if>>
<</if>>
<br><br>
<</nobr>><</widget>>
<<widget "exhibitionismbuilding">><<nobr>>
<<if $exposed is 1>><<set $arousal += 20>>
<<if $daystate is "night">>
You are alone, but being in such a lewd state of dress is as terrifying as it is thrilling.<br><br>
You feel intense embarrassment at your exposure
<<if $leftarm is "bound" and $rightarm is "bound">>
but with your arms bound you can do nothing to hide your nakedness.
<<else>>
and cover yourself as best you can.
<</if>><br><br>
<<else>>
You are dressed lewdly in a public space! You feel excitement and terror in equal measure.<br><br>
You also feel intensely embarrassed at your exposure
<<if $leftarm is "bound" and $rightarm is "bound">>
but with your arms bound you can do nothing to hide your nakedness.
<<else>>
and cover yourself as best you can.
<</if>>
<br><br>
<</if>>
<<elseif $exposed is 2>><<set $arousal += 50>>
<<if $daystate is "night">>
You are alone, but being in such a lewd state of dress is as terrifying as it is thrilling.<br><br>
You feel intense embarrassment at your exposure
<<if $leftarm is "bound" and $rightarm is "bound">>
but with your arms bound you can do nothing to hide your nakedness.
<<else>>
and cover yourself as best you can.
<</if>><br><br>
<<else>>
You are in public with your unmentionables uncovered! You feel excitement and terror in equal measure.<br><br>
You also feel intensely embarrassed at your exposure
<<if $leftarm is "bound" and $rightarm is "bound">>
but with your arms bound you can do nothing to hide your nakedness.
<<else>>
and cover yourself as best you can.
<</if>>
<</if>>
<</if>>
<br><br>
<</nobr>><</widget>>
<<widget "exhibitionismbeach">><<nobr>>
<<if $exposed is 1>><<set $arousal += 20>>
<<if $daystate is "night">>
You are alone, but being in such a lewd state of dress is as terrifying as it is thrilling.<br><br>
You feel intense embarrassment at your exposure
<<if $leftarm is "bound" and $rightarm is "bound">>
but with your arms bound you can do nothing to hide your nakedness.
<<else>>
and cover yourself as best you can.
<</if>><br><br>
<<else>>
You are dressed too lewdly even for here! You feel excitement and terror in equal measure. If you keep low you might be able to use the numerous windbreakers scattered across the beach to shield yourself.<br><br>
You feel intensely embarrassed at your exposure
<<if $leftarm is "bound" and $rightarm is "bound">>
but with your arms bound you can do nothing to hide your nakedness.
<<else>>
and cover yourself as best you can.
<</if>>
<br><br>
<</if>>
<<elseif $exposed is 2>><<set $arousal += 50>>
<<if $daystate is "night">>
You are alone, but being in such a lewd state of dress is as terrifying as it is thrilling. You feel intense embarrassment at your exposure
<<if $leftarm is "bound" and $rightarm is "bound">>
but with your arms bound you can do nothing to hide your nakedness.
<<else>>
and cover yourself as best you can.
<</if>><br><br>
<<else>>
You are in broad daylight with your unmentionables uncovered! This is no good, no good at all! Maybe if you keep low you might be able to use the numerous windbreakers scattered across the beach to shield your nudity.<br><br>
<br><br>
You feel intensely embarrassed at your exposure
<<if $leftarm is "bound" and $rightarm is "bound">>
but with your arms bound you can do nothing to hide your nakedness.
<<else>>
and cover yourself as best you can.
<</if>>
<</if>>
<</if>>
<br><br>
<</nobr>><</widget>>
<<widget "exhibitionclassroom">><<nobr>>
<<if $exposed gte 1>>
You're alone in the room, but being exposed in this often-crowded space makes you feel vulnerable and conscious of your <<nuditystop>><br><br>
<</if>>
<</nobr>><</widget>>
:: Widgets Stats [widget]
<<widget "trauma">><<nobr>>
<<if $args[0]>>
<<if $args[0] gte 0>>
<<set $trauma += ($args[0] * 3) - (($args[0] * 1.5) * ($control / $controlmax))>>
<<if $dev is 1>><<set $control -= $args[0]>><</if>>
<<else>>
<<set $trauma += ($args[0] * 3) + (($args[0] * 1.5) * ($control / $controlmax))>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "combattrauma">><<nobr>>
<<if $args[0]>>
<<if $args[0] gte 0>>
<<set $trauma += ($args[0] * 1) - (($args[0] * 0.5) * ($control / $controlmax))>>
<<if $dev is 1>><<set $control -= $args[0]>><</if>>
<<else>>
<<set $trauma += ($args[0] * 1) + (($args[0] * 0.5) * ($control / $controlmax))>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "straighttrauma">><<nobr>>
<<if $args[0]>>
<<set $trauma += ($args[0] * 1)>>
<</if>>
<</nobr>><</widget>>
<<widget "control">><<nobr>>
<<if $args[0]>>
<<set $control += ($args[0] * 10)>>
<</if>>
<</nobr>><</widget>>
<<widget "combatcontrol">><<nobr>>
<<if $args[0]>>
<<set $control += ($args[0] * 10)>>
<<if $control gte $controlstart>>
<<set $control to $controlstart>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "stress">><<nobr>>
<<if $args[0]>>
<<set $stress += ($args[0] * 80)>>
<</if>>
<</nobr>><</widget>>
<<widget "arousal">><<nobr>>
<<if $args[0]>>
<<set $arousal += ($args[0] * 100)>>
<</if>>
<</nobr>><</widget>>
<<widget "tiredness">><<nobr>>
<<if $args[0]>>
<<set $tiredness += ($args[0] * 20)>>
<</if>>
<</nobr>><</widget>>
<<widget "pain">><<nobr>>
<<if $args[0]>>
<<set $pain += ($args[0] * 4)>>
<</if>>
<</nobr>><</widget>>
<<widget "delinquency">><<nobr>>
<<if $args[0]>>
<<if $args[0] gt 0>>
<<set $detention += ($args[0] * 10)>>
<</if>>
<<set $delinquency += ($args[0] * 4)>>
<</if>>
<</nobr>><</widget>>
<<widget "status">><<nobr>>
<<if $args[0]>>
<<if $args[0] gt 0>>
<<set $cool += ($args[0] * 1)>>
<<if $faceacc is "cool shades">>
<<set $cool += ($args[0] * 1)>>
<</if>>
<<if $headacc is "beanie">>
<<set $cool += ($args[0] * 1)>>
<</if>>
<<elseif $args[0] lt 0>>
<<set $cool *= (1 - ($args[0] / -100))>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "awareness">><<nobr>>
<<if $args[0]>>
<<set $awareness += ($args[0])>>
<</if>>
<</nobr>><</widget>>
<<widget "humiliation10">><<nobr>>
<<set $stress += 40>>
<<trauma 1>>
<</nobr>><</widget>>
<<widget "wolfpacktrust">><<nobr>>
<<set $wolfpacktrust += 1>>
<span class="green">The pack trusts you a little more.</span>
<</nobr>><</widget>>
<<widget "wolfpackfear">><<nobr>>
<<set $wolfpackfear += 1>>
<span class="green">The pack fears you a little more.</span>
<</nobr>><</widget>>
<<widget "gferocity">><<nobr>>
<<set $wolfpackferocity += 1>>
| <span class="blue">+ Ferocity</span>
<</nobr>><</widget>>
<<widget "gharmony">><<nobr>>
<<set $wolfpackharmony += 1>>
| <span class="lblue">+ Harmony</span>
<</nobr>><</widget>>
<<widget "lferocity">><<nobr>>
<<set $wolfpackferocity -= 1>>
| <span class="purple">- Ferocity</span>
<</nobr>><</widget>>
<<widget "lharmony">><<nobr>>
<<set $wolfpackharmony -= 1>>
| <span class="pink">- Harmony</span>
<</nobr>><</widget>>
<<widget "submissive1">><<nobr>>
<<set $submissive += 1>>
<</nobr>><</widget>>
<<widget "defiant1">><<nobr>>
<<set $submissive -= 1>>
<</nobr>><</widget>>
:: Widgets Difficulty [widget]
<<widget "chestdifficulty">><<nobr>>
<<if (990 - ($enemytrust * 10) - $chestskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<span class="green"> (Very Easy) </span>
<<elseif (800 - ($enemytrust * 10) - $chestskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<span class="teal"> (Easy) </span>
<<elseif (600 - ($enemytrust * 10) - $chestskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<span class="lblue"> (Medium) </span>
<<elseif (400 - ($enemytrust * 10) - $chestskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<span class="blue"> (Challenging) </span>
<<elseif (200 - ($enemytrust * 10) - $chestskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<span class="purple"> (Hard) </span>
<<elseif (1 - ($enemytrust * 10) - $chestskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<span class="pink"> (Very Hard) </span>
<<else>>
<span class="red"> (Impossible) </span>
<</if>>
<</nobr>><</widget>>
<<widget "seductiondifficulty">><<nobr>>
<<if $combat is 1>>
<<if (990 - ($enemytrust * 10) - $seductionskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<span class="green"> (Very Easy) </span>
<<elseif (800 - ($enemytrust * 10) - $seductionskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<span class="teal"> (Easy) </span>
<<elseif (600 - ($enemytrust * 10) - $seductionskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<span class="lblue"> (Medium) </span>
<<elseif (400 - ($enemytrust * 10) - $seductionskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<span class="blue"> (Challenging) </span>
<<elseif (200 - ($enemytrust * 10) - $seductionskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<span class="purple"> (Hard) </span>
<<elseif (1 - ($enemytrust * 10) - $seductionskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<span class="pink"> (Very Hard) </span>
<<else>>
<span class="red"> (Impossible) </span>
<</if>>
<<else>>
<<if 990 - $seductionskill - ($attractiveness / 10) lte -100>>
<span class="green"> (Very Easy) </span>
<<elseif 800 - $seductionskill - ($attractiveness / 10) lte -100>>
<span class="teal"> (Easy) </span>
<<elseif 600 - $seductionskill - ($attractiveness / 10) lte -100>>
<span class="lblue"> (Medium) </span>
<<elseif 400 - $seductionskill - ($attractiveness / 10) lte -100>>
<span class="blue"> (Challenging) </span>
<<elseif 200 - $seductionskill - ($attractiveness / 10) lte -100>>
<span class="purple"> (Hard) </span>
<<elseif 1 - $seductionskill - ($attractiveness / 10) lte -100>>
<span class="pink"> (Very Hard) </span>
<<else>>
<span class="red"> (Impossible) </span>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "oraldifficulty">><<nobr>>
<<if (990 - ($enemytrust * 10) - $oralskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<span class="green"> (Very Easy) </span>
<<elseif (800 - ($enemytrust * 10) - $oralskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<span class="teal"> (Easy) </span>
<<elseif (600 - ($enemytrust * 10) - $oralskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<span class="lblue"> (Medium) </span>
<<elseif (400 - ($enemytrust * 10) - $oralskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<span class="blue"> (Challenging) </span>
<<elseif (200 - ($enemytrust * 10) - $oralskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<span class="purple"> (Hard) </span>
<<elseif (1 - ($enemytrust * 10) - $oralskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<span class="pink"> (Very Hard) </span>
<<else>>
<span class="red"> (Impossible) </span>
<</if>>
<</nobr>><</widget>>
<<widget "vaginaldifficulty">><<nobr>>
<<if (990 - ($enemytrust * 10) - $vaginalskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<span class="green"> (Very Easy) </span>
<<elseif (800 - ($enemytrust * 10) - $vaginalskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<span class="teal"> (Easy) </span>
<<elseif (600 - ($enemytrust * 10) - $vaginalskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<span class="lblue"> (Medium) </span>
<<elseif (400 - ($enemytrust * 10) - $vaginalskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<span class="blue"> (Challenging) </span>
<<elseif (200 - ($enemytrust * 10) - $vaginalskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<span class="purple"> (Hard) </span>
<<elseif (1 - ($enemytrust * 10) - $vaginalskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<span class="pink"> (Very Hard) </span>
<<else>>
<span class="red"> (Impossible) </span>
<</if>>
<</nobr>><</widget>>
<<widget "analdifficulty">><<nobr>>
<<if (990 - ($enemytrust * 10) - $analskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<span class="green"> (Very Easy) </span>
<<elseif (800 - ($enemytrust * 10) - $analskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<span class="teal"> (Easy) </span>
<<elseif (600 - ($enemytrust * 10) - $analskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<span class="lblue"> (Medium) </span>
<<elseif (400 - ($enemytrust * 10) - $analskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<span class="blue"> (Challenging) </span>
<<elseif (200 - ($enemytrust * 10) - $analskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<span class="purple"> (Hard) </span>
<<elseif (1 - ($enemytrust * 10) - $analskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<span class="pink"> (Very Hard) </span>
<<else>>
<span class="red"> (Impossible) </span>
<</if>>
<</nobr>><</widget>>
<<widget "handdifficulty">><<nobr>>
<<if (990 - ($enemytrust * 10) - $handskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<span class="green"> (Very Easy) </span>
<<elseif (800 - ($enemytrust * 10) - $handskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<span class="teal"> (Easy) </span>
<<elseif (600 - ($enemytrust * 10) - $handskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<span class="lblue"> (Medium) </span>
<<elseif (400 - ($enemytrust * 10) - $handskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<span class="blue"> (Challenging) </span>
<<elseif (200 - ($enemytrust * 10) - $handskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<span class="purple"> (Hard) </span>
<<elseif (1 - ($enemytrust * 10) - $handskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<span class="pink"> (Very Hard) </span>
<<else>>
<span class="red"> (Impossible) </span>
<</if>>
<</nobr>><</widget>>
<<widget "feetdifficulty">><<nobr>>
<<if (990 - ($enemytrust * 10) - $feetskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<span class="green"> (Very Easy) </span>
<<elseif (800 - ($enemytrust * 10) - $feetskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<span class="teal"> (Easy) </span>
<<elseif (600 - ($enemytrust * 10) - $feetskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<span class="lblue"> (Medium) </span>
<<elseif (400 - ($enemytrust * 10) - $feetskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<span class="blue"> (Challenging) </span>
<<elseif (200 - ($enemytrust * 10) - $feetskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<span class="purple"> (Hard) </span>
<<elseif (1 - ($enemytrust * 10) - $feetskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<span class="pink"> (Very Hard) </span>
<<else>>
<span class="red"> (Impossible) </span>
<</if>>
<</nobr>><</widget>>
<<widget "bottomdifficulty">><<nobr>>
<<if (990 - ($enemytrust * 10) - $bottomskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<span class="green"> (Very Easy) </span>
<<elseif (800 - ($enemytrust * 10) - $bottomskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<span class="teal"> (Easy) </span>
<<elseif (600 - ($enemytrust * 10) - $bottomskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<span class="lblue"> (Medium) </span>
<<elseif (400 - ($enemytrust * 10) - $bottomskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<span class="blue"> (Challenging) </span>
<<elseif (200 - ($enemytrust * 10) - $bottomskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<span class="purple"> (Hard) </span>
<<elseif (1 - ($enemytrust * 10) - $bottomskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<span class="pink"> (Very Hard) </span>
<<else>>
<span class="red"> (Impossible) </span>
<</if>>
<</nobr>><</widget>>
<<widget "thighdifficulty">><<nobr>>
<<if (990 - ($enemytrust * 10) - $thighskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<span class="green"> (Very Easy) </span>
<<elseif (800 - ($enemytrust * 10) - $thighskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<span class="teal"> (Easy) </span>
<<elseif (600 - ($enemytrust * 10) - $thighskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<span class="lblue"> (Medium) </span>
<<elseif (400 - ($enemytrust * 10) - $thighskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<span class="blue"> (Challenging) </span>
<<elseif (200 - ($enemytrust * 10) - $thighskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<span class="purple"> (Hard) </span>
<<elseif (1 - ($enemytrust * 10) - $thighskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<span class="pink"> (Very Hard) </span>
<<else>>
<span class="red"> (Impossible) </span>
<</if>>
<</nobr>><</widget>>
<<widget "peniledifficulty">><<nobr>>
<<if (990 - ($enemytrust * 10) - $penileskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<span class="green"> (Very Easy) </span>
<<elseif (800 - ($enemytrust * 10) - $penileskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<span class="teal"> (Easy) </span>
<<elseif (600 - ($enemytrust * 10) - $penileskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<span class="lblue"> (Medium) </span>
<<elseif (400 - ($enemytrust * 10) - $penileskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<span class="blue"> (Challenging) </span>
<<elseif (200 - ($enemytrust * 10) - $penileskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<span class="purple"> (Hard) </span>
<<elseif (1 - ($enemytrust * 10) - $penileskill + $enemyanger) lte (($enemyarousalmax / ($enemyarousal + 1)) * 100)>>
<span class="pink"> (Very Hard) </span>
<<else>>
<span class="red"> (Impossible) </span>
<</if>>
<</nobr>><</widget>>
<<widget "skulduggerycheck">><<nobr>>
<<set $skulduggeryroll to random(1, 1000)>>
<<if $skulduggery gte $skulduggerydifficulty>>
<<set $skulduggerysuccess to 1>><span class="green">You succeed in your skulduggery. </span>
<<elseif $skulduggery + 100 gte $skulduggerydifficulty>>
<<if $skulduggeryroll gte 100>>
<<set $skulduggerysuccess to 1>><span class="green">You succeed in your skulduggery. </span>
<<else>>
<<set $skulduggerysuccess to 0>><span class="red">You fail in your skulduggery. </span>
<</if>>
<<elseif $skulduggery + 200 gte $skulduggerydifficulty>>
<<if $skulduggeryroll gte 300>>
<<set $skulduggerysuccess to 1>><span class="green">You succeed in your skulduggery. </span>
<<else>>
<<set $skulduggerysuccess to 0>><span class="red">You fail in your skulduggery. </span>
<</if>>
<<elseif $skulduggery + 300 gte $skulduggerydifficulty>>
<<if $skulduggeryroll gte 500>>
<<set $skulduggerysuccess to 1>><span class="green">You succeed in your skulduggery. </span>
<<else>>
<<set $skulduggerysuccess to 0>><span class="red">You fail in your skulduggery. </span>
<</if>>
<<elseif $skulduggery + 400 gte $skulduggerydifficulty>>
<<if $skulduggeryroll gte 700>>
<<set $skulduggerysuccess to 1>><span class="green">You succeed in your skulduggery. </span>
<<else>>
<<set $skulduggerysuccess to 0>><span class="red">You fail in your skulduggery. </span>
<</if>>
<<elseif $skulduggery + 500 gte $skulduggerydifficulty>>
<<if $skulduggeryroll gte 900>>
<<set $skulduggerysuccess to 1>><span class="green">You succeed in your skulduggery. </span>
<<else>>
<<set $skulduggerysuccess to 0>><span class="red">You fail in your skulduggery. </span>
<</if>>
<<else>>
<<set $skulduggerysuccess to 0>><span class="red">You fail in your skulduggery. </span>
<</if>>
<</nobr>><</widget>>
<<widget "skulduggerydifficulty">><<nobr>>
<<if $skulduggery gte $skulduggerydifficulty>>
<span class="green"> (Very Easy) </span>
<<elseif $skulduggery + 100 gte $skulduggerydifficulty>>
<span class="teal"> (Easy) </span>
<<elseif $skulduggery + 200 gte $skulduggerydifficulty>>
<span class="lblue"> (Medium) </span>
<<elseif $skulduggery + 300 gte $skulduggerydifficulty>>
<span class="blue"> (Challenging) </span>
<<elseif $skulduggery + 400 gte $skulduggerydifficulty>>
<span class="purple"> (Hard) </span>
<<elseif $skulduggery + 500 gte $skulduggerydifficulty>>
<span class="pink"> (Very Hard) </span>
<<else>>
<span class="red"> (Impossible) </span>
<</if>>
<</nobr>><</widget>>
<<widget "skulduggeryrequired">><<nobr>>
Skulduggery required:
<<if $lock lte 0>><span class="red">None</span>
<<elseif $lock gte 1 and $lock lt 100>><span class="pink">F</span>
<<elseif $lock gte 100 and $lock lt 200>><span class="pink">F+</span>
<<elseif $lock gte 200 and $lock lt 300>><span class="purple">D</span>
<<elseif $lock gte 300 and $lock lt 400>><span class="purple">D+</span>
<<elseif $lock gte 400 and $lock lt 500>><span class="blue">C</span>
<<elseif $lock gte 500 and $lock lt 600>><span class="blue">C+</span>
<<elseif $lock gte 600 and $lock lt 700>><span class="lblue">B</span>
<<elseif $lock gte 700 and $lock lt 800>><span class="lblue">B+</span>
<<elseif $lock gte 800 and $lock lt 900>><span class="teal">A</span>
<<elseif $lock gte 900 and $lock lt 1000>><span class="teal">A+</span>
<<elseif $lock gte 1000>><span class="green">S</span>
<</if>>
<</nobr>><</widget>>
<<widget "seductioncheck">><<nobr>>
Attractiveness rating:
<<if $attractiveness gte 5000>>
<span class="green">S</span>
<<elseif $attractiveness gte 4000>>
<span class="teal">A</span>
<<elseif $attractiveness gte 3000>>
<span class="lblue">B</span>
<<elseif $attractiveness gte 2000>>
<span class="blue">C</span>
<<elseif $attractiveness gte 1000>>
<span class="purple">D</span>
<<else>>
<span class="pink">F</span>
<</if>>
<br>
Seduction Skill: <<if $seductionskill lte 0>><span class="red">None</span>
<<elseif $seductionskill gte 1 and $seductionskill lt 200>><span class="pink">F</span>
<<elseif $seductionskill gte 200 and $seductionskill lt 400>><span class="purple">D</span>
<<elseif $seductionskill gte 400 and $seductionskill lt 600>><span class="blue">C</span>
<<elseif $seductionskill gte 600 and $seductionskill lt 800>><span class="lblue">B</span>
<<elseif $seductionskill gte 800 and $seductionskill lt 1000>><span class="teal">A</span>
<<elseif $seductionskill gte 1000>><span class="green">S</span><</if>>
<br>
Overall rating:
<<if $attractiveness + ($seductionskill * 5) gte 10000>>
<span class="green">S</span><<set $seductionrating to 6>>
<<elseif $attractiveness + ($seductionskill * 5) gte 8000>>
<span class="teal">A</span><<set $seductionrating to 5>>
<<elseif $attractiveness + ($seductionskill * 5) gte 6000>>
<span class="lblue">B</span><<set $seductionrating to 4>>
<<elseif $attractiveness + ($seductionskill * 5) gte 4000>>
<span class="blue">C</span><<set $seductionrating to 3>>
<<elseif $attractiveness + ($seductionskill * 5) gte 2000>>
<span class="purple">D</span><<set $seductionrating to 2>>
<<else>>
<span class="pink">F</span><<set $seductionrating to 1>>
<</if>>
<br>
Required rating:
<<if $seductiondifficulty gte 10000>>
<span class="green">S</span><<set $seductionrequired to 6>>
<<elseif $seductiondifficulty gte 8000>>
<span class="teal">A</span><<set $seductionrequired to 5>>
<<elseif $seductiondifficulty gte 6000>>
<span class="lblue">B</span><<set $seductionrequired to 4>>
<<elseif $seductiondifficulty gte 4000>>
<span class="blue">C</span><<set $seductionrequired to 3>>
<<elseif $seductiondifficulty gte 2000>>
<span class="purple">D</span><<set $seductionrequired to 2>>
<<else>>
<span class="pink">F</span><<set $seductionrequired to 1>>
<</if>>
<</nobr>><</widget>><br>
:: Widgets Disable [widget]
<<widget "disable">><<nobr>>
<<if $penisuse is "cover">>
<<set $penisuse to 0>>
<</if>>
<<if $anususe is "cover">>
<<set $anususe to 0>>
<</if>>
<<if $vaginause is "cover">>
<<set $vaginause to 0>>
<</if>>
<<if $penisuse is "clit">>
<<set $penisuse to 0>>
<<set $penisstate to 0>>
<<if $vagina is "frot">>
<<set $vagina to 0>>
<<elseif $vagina2 is "frot">>
<<set $vagina2 to 0>>
<<elseif $vagina3 is "frot">>
<<set $vagina3 to 0>>
<<elseif $vagina4 is "frot">>
<<set $vagina4 to 0>>
<<elseif $vagina5 is "frot">>
<<set $vagina5 to 0>>
<<elseif $vagina6 is "frot">>
<<set $vagina6 to 0>>
<</if>>
<</if>>
<<if $penisuse is "otheranusrub">>
<<set $penisuse to 0>>
<<set $penisstate to 0>>
<<if $vagina is "otheranusfrot">>
<<set $vagina to 0>>
<<elseif $vagina2 is "otheranusfrot">>
<<set $vagina2 to 0>>
<<elseif $vagina3 is "otheranusfrot">>
<<set $vagina3 to 0>>
<<elseif $vagina4 is "otheranusfrot">>
<<set $vagina4 to 0>>
<<elseif $vagina5 is "otheranusfrot">>
<<set $vagina5 to 0>>
<<elseif $vagina6 is "otheranusfrot">>
<<set $vagina6 to 0>>
<</if>>
<<if $penis is "otheranusfrot">>
<<set $penis to 0>>
<<elseif $penis2 is "otheranusfrot">>
<<set $penis2 to 0>>
<<elseif $penis3 is "otheranusfrot">>
<<set $penis3 to 0>>
<<elseif $penis4 is "otheranusfrot">>
<<set $penis4 to 0>>
<<elseif $penis5 is "otheranusfrot">>
<<set $penis5 to 0>>
<<elseif $penis6 is "otheranusfrot">>
<<set $penis6 to 0>>
<</if>>
<</if>>
<<if $feetuse is "othervagina">>
<<set $feetuse to 0>>
<<if $vagina is "feet">>
<<set $vagina to 0>>
<<elseif $vagina2 is "feet">>
<<set $vagina2 to 0>>
<<elseif $vagina3 is "feet">>
<<set $vagina3 to 0>>
<<elseif $vagina4 is "feet">>
<<set $vagina4 to 0>>
<<elseif $vagina5 is "feet">>
<<set $vagina5 to 0>>
<<elseif $vagina6 is "feet">>
<<set $vagina6 to 0>>
<</if>>
<</if>>
<<if $feetuse is "penis">>
<<set $feetuse to 0>>
<<if $penis is "feet">>
<<set $penis to 0>>
<<elseif $penis2 is "feet">>
<<set $penis2 to 0>>
<<elseif $penis3 is "feet">>
<<set $penis3 to 0>>
<<elseif $penis4 is "feet">>
<<set $penis4 to 0>>
<<elseif $penis5 is "feet">>
<<set $penis5 to 0>>
<<elseif $penis6 is "feet">>
<<set $penis6 to 0>>
<</if>>
<</if>>
<<disablearms>>
<<if $bottomuse is "penis">>
<<set $bottomuse to 0>><<set $anusstate to 0>>
<<if $penis is "cheeks">>
<<set $penis to 0>>
<<elseif $penis2 is "cheeks">>
<<set $penis2 to 0>>
<<elseif $penis3 is "cheeks">>
<<set $penis3 to 0>>
<<elseif $penis4 is "cheeks">>
<<set $penis4 to 0>>
<<elseif $penis5 is "cheeks">>
<<set $penis5 to 0>>
<<elseif $penis6 is "cheeks">>
<<set $penis6 to 0>>
<</if>>
<</if>>
<<if $bottomuse is "mouth">>
<<set $bottomuse to 0>>
<<if $mouth is "bottom">><<set $mouth to 0>>
<<if $penis is "othermouth">>
<<set $penis to 0>>
<</if>>
<<if $vagina is "othermouth">>
<<set $vagina to 0>>
<</if>>
<</if>>
<<if $mouth2 is "bottom">><<set $mouth2 to 0>>
<<if $penis2 is "othermouth">>
<<set $penis2 to 0>>
<</if>>
<<if $vagina2 is "othermouth">>
<<set $vagina2 to 0>>
<</if>>
<</if>>
<<if $mouth3 is "bottom">><<set $mouth3 to 0>>
<<if $penis3 is "othermouth">>
<<set $penis3 to 0>>
<</if>>
<<if $vagina3 is "othermouth">>
<<set $vagina3 to 0>>
<</if>>
<</if>>
<<if $mouth4 is "bottom">><<set $mouth4 to 0>>
<<if $penis4 is "othermouth">>
<<set $penis4 to 0>>
<</if>>
<<if $vagina4 is "othermouth">>
<<set $vagina4 to 0>>
<</if>>
<</if>>
<<if $mouth5 is "bottom">><<set $mouth5 to 0>>
<<if $penis5 is "othermouth">>
<<set $penis5 to 0>>
<</if>>
<<if $vagina5 is "othermouth">>
<<set $vagina5 to 0>>
<</if>>
<</if>>
<<if $mouth6 is "bottom">><<set $mouth6 to 0>>
<<if $penis6 is "othermouth">>
<<set $penis to 0>>
<</if>>
<<if $vagina6 is "othermouth">>
<<set $vagina to 0>>
<</if>>
<</if>>
<</if>>
<<if $thighuse is "penis">>
<<set $thighuse to 0>>
<<if $penis is "thighs">>
<<set $penis to 0>>
<<elseif $penis2 is "thighs">>
<<set $penis2 to 0>>
<<elseif $penis3 is "thighs">>
<<set $penis3 to 0>>
<<elseif $penis4 is "thighs">>
<<set $penis4 to 0>>
<<elseif $penis5 is "thighs">>
<<set $penis5 to 0>>
<<elseif $penis6 is "thighs">>
<<set $penis6 to 0>>
<</if>>
<</if>>
<<if $thighuse is "mouth">>
<<set $thighuse to 0>>
<<if $mouth is "thigh">><<set $mouth to 0>>
<<if $penis is "othermouth">>
<<set $penis to 0>>
<</if>>
<<if $vagina is "othermouth">>
<<set $vagina to 0>>
<</if>>
<</if>>
<<if $mouth2 is "thigh">><<set $mouth2 to 0>>
<<if $penis2 is "othermouth">>
<<set $penis2 to 0>>
<</if>>
<<if $vagina2 is "othermouth">>
<<set $vagina2 to 0>>
<</if>>
<</if>>
<<if $mouth3 is "thigh">><<set $mouth3 to 0>>
<<if $penis3 is "othermouth">>
<<set $penis3 to 0>>
<</if>>
<<if $vagina3 is "othermouth">>
<<set $vagina3 to 0>>
<</if>>
<</if>>
<<if $mouth4 is "thigh">><<set $mouth4 to 0>>
<<if $penis4 is "othermouth">>
<<set $penis4 to 0>>
<</if>>
<<if $vagina4 is "othermouth">>
<<set $vagina4 to 0>>
<</if>>
<</if>>
<<if $mouth5 is "thigh">><<set $mouth5 to 0>>
<<if $penis5 is "othermouth">>
<<set $penis5 to 0>>
<</if>>
<<if $vagina5 is "othermouth">>
<<set $vagina5 to 0>>
<</if>>
<</if>>
<<if $mouth6 is "thigh">><<set $mouth6 to 0>>
<<if $penis6 is "othermouth">>
<<set $penis to 0>>
<</if>>
<<if $vagina6 is "othermouth">>
<<set $vagina to 0>>
<</if>>
<</if>>
<</if>>
<<if $chestuse isnot 0>>
<<set $chestuse to 0>>
<<if $penis is "chest">>
<<set $penis to 0>>
<<elseif $penis2 is "chest">>
<<set $penis2 to 0>>
<<elseif $penis3 is "chest">>
<<set $penis3 to 0>>
<<elseif $penis4 is "chest">>
<<set $penis4 to 0>>
<<elseif $penis5 is "chest">>
<<set $penis5 to 0>>
<<elseif $penis6 is "chest">>
<<set $penis6 to 0>>
<</if>>
<</if>>
<<if $feetuse isnot "grappled" and $feetuse isnot "bound">><<set $feetuse to 0>>
<</if>>
<<if $tentacle1head is "feet">>
<<set $leftleg to 0>>
<<set $rightleg to 0>>
<<set $tentacle1head to 0>>
<</if>>
<<if $tentacle2head is "feet">>
<<set $leftleg to 0>>
<<set $rightleg to 0>>
<<set $tentacle2head to 0>>
<</if>>
<<if $tentacle3head is "feet">>
<<set $leftleg to 0>>
<<set $rightleg to 0>>
<<set $tentacle3head to 0>>
<</if>>
<<if $tentacle4head is "feet">>
<<set $leftleg to 0>>
<<set $rightleg to 0>>
<<set $tentacle4head to 0>>
<</if>>
<<if $tentacle5head is "feet">>
<<set $leftleg to 0>>
<<set $rightleg to 0>>
<<set $tentacle5head to 0>>
<</if>>
<<if $tentacle6head is "feet">>
<<set $leftleg to 0>>
<<set $rightleg to 0>>
<<set $tentacle6head to 0>>
<</if>>
<<if $tentacle7head is "feet">>
<<set $leftleg to 0>>
<<set $rightleg to 0>>
<<set $tentacle7head to 0>>
<</if>>
<<if $tentacle8head is "feet">>
<<set $leftleg to 0>>
<<set $rightleg to 0>>
<<set $tentacle8head to 0>>
<</if>>
<<if $tentacle9head is "feet">>
<<set $leftleg to 0>>
<<set $rightleg to 0>>
<<set $tentacle9head to 0>>
<</if>>
<<if $tentacle10head is "feet">>
<<set $leftleg to 0>>
<<set $rightleg to 0>>
<<set $tentacle10head to 0>>
<</if>>
<<if $tentacle11head is "feet">>
<<set $leftleg to 0>>
<<set $rightleg to 0>>
<<set $tentacle11head to 0>>
<</if>>
<<if $tentacle12head is "feet">>
<<set $leftleg to 0>>
<<set $rightleg to 0>>
<<set $tentacle12head to 0>>
<</if>>
<<if $tentacle13head is "feet">>
<<set $leftleg to 0>>
<<set $rightleg to 0>>
<<set $tentacle13head to 0>>
<</if>>
<<if $tentacle14head is "feet">>
<<set $leftleg to 0>>
<<set $rightleg to 0>>
<<set $tentacle14head to 0>>
<</if>>
<<if $tentacle15head is "feet">>
<<set $leftleg to 0>>
<<set $rightleg to 0>>
<<set $tentacle15head to 0>>
<</if>>
<<if $tentacle16head is "feet">>
<<set $leftleg to 0>>
<<set $rightleg to 0>>
<<set $tentacle16head to 0>>
<</if>>
<<if $tentacle1head is "leftarm">>
<<set $leftarm to 0>>
<<set $tentacle1head to 0>>
<</if>>
<<if $tentacle2head is "leftarm">>
<<set $leftarm to 0>>
<<set $tentacle2head to 0>>
<</if>>
<<if $tentacle3head is "leftarm">>
<<set $leftarm to 0>>
<<set $tentacle3head to 0>>
<</if>>
<<if $tentacle4head is "leftarm">>
<<set $leftarm to 0>>
<<set $tentacle4head to 0>>
<</if>>
<<if $tentacle5head is "leftarm">>
<<set $leftarm to 0>>
<<set $tentacle5head to 0>>
<</if>>
<<if $tentacle6head is "leftarm">>
<<set $leftarm to 0>>
<<set $tentacle6head to 0>>
<</if>>
<<if $tentacle7head is "leftarm">>
<<set $leftarm to 0>>
<<set $tentacle7head to 0>>
<</if>>
<<if $tentacle8head is "leftarm">>
<<set $leftarm to 0>>
<<set $tentacle8head to 0>>
<</if>>
<<if $tentacle9head is "leftarm">>
<<set $leftarm to 0>>
<<set $tentacle9head to 0>>
<</if>>
<<if $tentacle10head is "leftarm">>
<<set $leftarm to 0>>
<<set $tentacle10head to 0>>
<</if>>
<<if $tentacle11head is "leftarm">>
<<set $leftarm to 0>>
<<set $tentacle11head to 0>>
<</if>>
<<if $tentacle12head is "leftarm">>
<<set $leftarm to 0>>
<<set $tentacle12head to 0>>
<</if>>
<<if $tentacle13head is "leftarm">>
<<set $leftarm to 0>>
<<set $tentacle13head to 0>>
<</if>>
<<if $tentacle14head is "leftarm">>
<<set $leftarm to 0>>
<<set $tentacle14head to 0>>
<</if>>
<<if $tentacle15head is "leftarm">>
<<set $leftarm to 0>>
<<set $tentacle15head to 0>>
<</if>>
<<if $tentacle16head is "leftarm">>
<<set $leftarm to 0>>
<<set $tentacle16head to 0>>
<</if>>
<<if $tentacle1head is "rightarm">>
<<set $rightarm to 0>>
<<set $tentacle1head to 0>>
<</if>>
<<if $tentacle2head is "rightarm">>
<<set $rightarm to 0>>
<<set $tentacle2head to 0>>
<</if>>
<<if $tentacle3head is "rightarm">>
<<set $rightarm to 0>>
<<set $tentacle3head to 0>>
<</if>>
<<if $tentacle4head is "rightarm">>
<<set $rightarm to 0>>
<<set $tentacle4head to 0>>
<</if>>
<<if $tentacle5head is "rightarm">>
<<set $rightarm to 0>>
<<set $tentacle5head to 0>>
<</if>>
<<if $tentacle6head is "rightarm">>
<<set $rightarm to 0>>
<<set $tentacle6head to 0>>
<</if>>
<<if $tentacle7head is "rightarm">>
<<set $rightarm to 0>>
<<set $tentacle7head to 0>>
<</if>>
<<if $tentacle8head is "rightarm">>
<<set $rightarm to 0>>
<<set $tentacle8head to 0>>
<</if>>
<<if $tentacle9head is "rightarm">>
<<set $rightarm to 0>>
<<set $tentacle9head to 0>>
<</if>>
<<if $tentacle10head is "rightarm">>
<<set $rightarm to 0>>
<<set $tentacle10head to 0>>
<</if>>
<<if $tentacle11head is "rightarm">>
<<set $rightarm to 0>>
<<set $tentacle11head to 0>>
<</if>>
<<if $tentacle12head is "rightarm">>
<<set $rightarm to 0>>
<<set $tentacle12head to 0>>
<</if>>
<<if $tentacle13head is "rightarm">>
<<set $rightarm to 0>>
<<set $tentacle13head to 0>>
<</if>>
<<if $tentacle14head is "rightarm">>
<<set $rightarm to 0>>
<<set $tentacle14head to 0>>
<</if>>
<<if $tentacle15head is "rightarm">>
<<set $rightarm to 0>>
<<set $tentacle15head to 0>>
<</if>>
<<if $tentacle16head is "rightarm">>
<<set $rightarm to 0>>
<<set $tentacle16head to 0>>
<</if>>
<</nobr>><</widget>>
<<widget "disablearms">><<nobr>>
<<disableleftarm>>
<<disablerightarm>>
<</nobr>><</widget>>
<<widget "disableleftarm">><<nobr>>
<<if $leftarm is "othervagina">>
<<if $vagina is "leftarm">>
<<set $vagina to 0>>
<<elseif $vagina2 is "leftarm">>
<<set $vagina2 to 0>>
<<elseif $vagina3 is "leftarm">>
<<set $vagina3 to 0>>
<<elseif $vagina4 is "leftarm">>
<<set $vagina4 to 0>>
<<elseif $vagina5 is "leftarm">>
<<set $vagina5 to 0>>
<<elseif $vagina6 is "leftarm">>
<<set $vagina6 to 0>>
<</if>>
<</if>>
<<if $leftarm is "penis">>
<<if $penis is "leftarm">>
<<set $penis to 0>>
<<elseif $penis2 is "leftarm">>
<<set $penis2 to 0>>
<<elseif $penis3 is "leftarm">>
<<set $penis3 to 0>>
<<elseif $penis4 is "leftarm">>
<<set $penis4 to 0>>
<<elseif $penis5 is "leftarm">>
<<set $penis5 to 0>>
<<elseif $penis6 is "leftarm">>
<<set $penis6 to 0>>
<</if>>
<</if>>
<<if $leftarm isnot "grappled" and $leftarm isnot "bound">><<set $leftarm to 0>>
<</if>>
<</nobr>><</widget>>
<<widget "disablerightarm">><<nobr>>
<<if $rightarm is "othervagina">>
<<if $vagina is "rightarm">>
<<set $vagina to 0>>
<<elseif $vagina2 is "rightarm">>
<<set $vagina2 to 0>>
<<elseif $vagina3 is "rightarm">>
<<set $vagina3 to 0>>
<<elseif $vagina4 is "rightarm">>
<<set $vagina4 to 0>>
<<elseif $vagina5 is "rightarm">>
<<set $vagina5 to 0>>
<<elseif $vagina6 is "rightarm">>
<<set $vagina6 to 0>>
<</if>>
<</if>>
<<if $rightarm is "penis">>
<<if $penis is "rightarm">>
<<set $penis to 0>>
<<elseif $penis2 is "rightarm">>
<<set $penis2 to 0>>
<<elseif $penis3 is "rightarm">>
<<set $penis3 to 0>>
<<elseif $penis4 is "rightarm">>
<<set $penis4 to 0>>
<<elseif $penis5 is "rightarm">>
<<set $penis5 to 0>>
<<elseif $penis6 is "rightarm">>
<<set $penis6 to 0>>
<</if>>
<</if>>
<<if $rightarm isnot "grappled" and $rightarm isnot "bound">><<set $rightarm to 0>>
<</if>>
<</nobr>><</widget>>
:: Widgets Clamp [widget]
<<widget "preclamp">><<nobr>>
<<if $trauma gte $traumamax>>
<<set $beauty -= (($trauma - $traumamax) / 5)>>
<</if>>
<</nobr>><</widget>>
<<widget "clamp">><<nobr>>
<<if $devlevel lte 19>>
<<set $beauty = Math.clamp($beauty, 0, $beautymax)>>
<<set $physique = Math.clamp($physique, 0, $physiqueage)>>
<<else>>
<<set $beauty = Math.clamp($beauty, 0, $beautymax)>>
<<set $physique = Math.clamp($physique, 0, 20000)>>
<</if>>
<<set $upperwet = Math.clamp($upperwet, 0, 200)>>
<<set $lowerwet = Math.clamp($lowerwet, 0, 200)>>
<<set $underwet = Math.clamp($underwet, 0, 200)>>
<<set $demonbuild = Math.clamp($demonbuild, 0, 100)>>
<<set $angelbuild = Math.clamp($angelbuild, 0, 100)>>
<<set $wolfbuild = Math.clamp($wolfbuild, 0, 100)>>
<<set $seductionskill = Math.clamp($seductionskill, 0, 1000)>>
<<set $oralskill = Math.clamp($oralskill, 0, 1000)>>
<<set $vaginalskill = Math.clamp($vaginalskill, 0, 1000)>>
<<set $analskill = Math.clamp($analskill, 0, 1000)>>
<<set $handskill = Math.clamp($handskill, 0, 1000)>>
<<set $feetskill = Math.clamp($feetskill, 0, 1000)>>
<<set $bottomskill = Math.clamp($bottomskill, 0, 1000)>>
<<set $thighskill = Math.clamp($thighskill, 0, 1000)>>
<<set $chestskill = Math.clamp($chestskill, 0, 1000)>>
<<set $penileskill = Math.clamp($penileskill, 0, 1000)>>
<<set $hunger = Math.clamp($hunger, 0, 2000)>>
<<set $thirst = Math.clamp($thirst, 0, 2000)>>
<<set $hygiene = Math.clamp($hygiene, 0, 2000)>>
<<set $arousal = Math.clamp($arousal, 0, $arousalmax)>>
<<set $stress = Math.clamp($stress, 0, $stressmax)>>
<<set $hairlength = Math.clamp($hairlength, 0, 1000)>>
<<set $trauma = Math.clamp($trauma, 0, $traumamax)>>
<<if $gamemode is "soft">>
<<set $control = Math.clamp($control, 1000, $controlmax)>>
<<else>>
<<set $control = Math.clamp($control, 0, $controlmax)>>
<</if>>
<<set $awareness = Math.clamp($awareness, 0, 1000)>>
<<set $submissive = Math.clamp($submissive, 0, 2000)>>
<<if $vaginalvirginity is 1 and $penilevirginity is 1>><<set $purity = Math.clamp($purity, 0, 1000)>><<else>><<set $purity = Math.clamp($purity, 0, 999)>><</if>>
<<set $time = Math.clamp($time, 0, 1440)>>
<<set $minute = Math.clamp($minute, 0, 1440)>>
<<set $orgasmcount = Math.clamp($orgasmcount, 0, 25)>>
<<set $english to Math.clamp($english, 0, 1000)>>
<<set $maths to Math.clamp($maths, 0, 1000)>>
<<set $science to Math.clamp($science, 0, 1000)>>
<<set $history to Math.clamp($history, 0, 1000)>>
<<set $school to Math.clamp($school, 0, 4000)>>
<<set $cool to Math.clamp($cool, 0, $coolmax)>>
<<set $delinquency to Math.clamp($delinquency, 0, 1000)>>
<<set $skulduggery to Math.clamp($skulduggery, 0, 1000)>>
<<set $danceskill to Math.clamp($danceskill, 0, 1000)>>
<<set $swimmingskill to Math.clamp($swimmingskill, 0, 1000)>>
<<set $enemyanger to Math.clamp($enemyanger, - 200, 200)>>
<<set $audienceexcitement to Math.clamp($audienceexcitement, 0, 100)>>
<<set $audiencearousal to Math.clamp($audiencearousal, 0, 100)>>
<<if $gamemode is "soft">>
<<set $pain to Math.clamp($pain, 0, 0)>>
<<else>>
<<set $pain to Math.clamp($pain, 0, 200)>>
<</if>>
<<set $facebruise to Math.clamp($facebruise , 0, 100)>>
<<set $chestbruise to Math.clamp($chestbruise, 0, 100)>>
<<set $tummybruise to Math.clamp($tummybruise, 0, 100)>>
<<set $vaginabruise to Math.clamp($vaginabruise, 0, 100)>>
<<set $anusbruise to Math.clamp($anusbruise, 0, 100)>>
<<set $bottombruise to Math.clamp($bottombruise, 0, 100)>>
<<set $thighbruise to Math.clamp($thighbruise, 0, 100)>>
<<set $armbruise to Math.clamp($armbruise, 0, 100)>>
<<set $neckbruise to Math.clamp($neckbruise, 0, 100)>>
<<set $breastsize to Math.clamp($breastsize, 0, 12)>>
<<set $exhibitionism to Math.clamp($exhibitionism, 0, 100)>>
<<set $promiscuity to Math.clamp($promiscuity, 0, 100)>>
<<set $deviancy to Math.clamp($deviancy, 0, 100)>>
<<set $hallucinogen to Math.clamp($hallucinogen, 0, 1000)>>
<<set $drunk to Math.clamp($drunk, 0, 1000)>>
<<set $drugged to Math.clamp($drugged, 0, 1000)>>
<</nobr>><</widget>>
:: Widgets Promiscuity [widget]
<<widget "promiscuity1">><<nobr>>
<<if $control lt $controlmax>>
<<if $promiscuity lte 19>>
<<set $promiscuity += 2>>
Performing such a lewd act excites you and <span class="green">restores your sense of control and self-worth</span>, for now.<<ggcontrol>><<control 25>><<set $arousal += 100>><<set $stress -= 300>><<combattrauma -30>><<ltrauma>><<lstress>><<garousal>>
<<elseif $promiscuity gte 20>>
While performing such a lewd act excites you, it does nothing to lift the cloud hanging over you. <span class="pink">You need to do something more extreme.</span><<set $arousal += 100>><<garousal>>
<<if $promiscuitystress1 isnot 1>><<set $promiscuitystress1 to 1>><<lstress>><<set $stress -= 100>>
<</if>>
<</if>>
<<else>>
<<if $promiscuity lte 19>>
<<set $promiscuity += 1>>
You already feel in control, but performing such a lewd act <span class="green">soothes</span> and excites you.<<control 25>><<set $arousal += 100>><<set $stress -= 300>><<combattrauma -30>><<ltrauma>><<lstress>><<garousal>>
<<elseif $promiscuity gte 20>>
You already feel in control and the act is <span class="pink">too tame to soothe</span>, but it does excite you.<<set $arousal += 100>><<garousal>>
<<if $promiscuitystress1 isnot 1>><<set $promiscuitystress1 to 1>><<lstress>><<set $stress -= 100>>
<</if>>
<</if>>
<</if>>
<br><br><</nobr>><</widget>>
<<widget "promiscuity2">><<nobr>>
<<if $control lt $controlmax>>
<<if $promiscuity lte 39>>
<<set $promiscuity += 2>>
Performing such a lewd act excites you and <span class="green">restores your sense of control and self-worth</span>, for now.<<ggcontrol>><<control 25>><<set $arousal += 200>><<set $stress -= 600>><<combattrauma -60>><<ltrauma>><<lstress>><<garousal>>
<<elseif $promiscuity gte 40>>
While performing such a lewd act excites you, it does nothing to lift the cloud hanging over you. <span class="pink">You need to do something more extreme.</span><<set $arousal += 200>><<garousal>>
<<if $promiscuitystress2 isnot 1>><<set $promiscuitystress2 to 1>><<lstress>><<set $stress -= 200>>
<</if>>
<</if>>
<<else>>
<<if $promiscuity lte 39>>
<<set $promiscuity += 1>>
You already feel in control, but performing such a lewd act <span class="green">soothes</span> and excites you.<<control 25>><<set $arousal += 200>><<set $stress -= 600>><<combattrauma -60>><<ltrauma>><<lstress>><<garousal>>
<<elseif $promiscuity gte 40>>
You already feel in control and the act is <span class="pink">too tame to soothe</span>, but it does excite you.<<set $arousal += 200>><<garousal>>
<<if $promiscuitystress2 isnot 1>><<set $promiscuitystress2 to 1>><<lstress>><<set $stress -= 200>>
<</if>>
<</if>>
<</if>>
<br><br><</nobr>><</widget>>
<<widget "promiscuity3">><<nobr>>
<<if $control lt $controlmax>>
<<if $promiscuity lte 59>>
<<set $promiscuity += 2>>
Performing such a lewd act excites you and <span class="green">restores your sense of control and self-worth</span>, for now.<<ggcontrol>><<control 25>><<set $arousal += 300>><<set $stress -= 900>><<combattrauma -90>><<ltrauma>><<lstress>><<garousal>>
<<elseif $promiscuity gte 60>>
While performing such a lewd act excites you, it does nothing to lift the cloud hanging over you. <span class="pink">You need to do something more extreme.</span><<set $arousal += 300>><<garousal>>
<<if $promiscuitystress3 isnot 1>><<set $promiscuitystress3 to 1>><<lstress>><<set $stress -= 300>>
<</if>>
<</if>>
<<else>>
<<if $promiscuity lte 59>>
<<set $promiscuity += 1>>
You already feel in control, but performing such a lewd act <span class="green">soothes</span> and excites you.<<control 25>><<set $arousal += 300>><<set $stress -= 900>><<combattrauma -90>><<ltrauma>><<lstress>><<garousal>>
<<elseif $promiscuity gte 60>>
You already feel in control and the act is <span class="pink">too tame to soothe</span>, but it does excite you.<<set $arousal += 300>><<garousal>>
<<if $promiscuitystress3 isnot 1>><<set $promiscuitystress3 to 1>><<lstress>><<set $stress -= 300>>
<</if>>
<</if>>
<</if>>
<br><br><</nobr>><</widget>>
<<widget "promiscuity4">><<nobr>>
<<if $control lt $controlmax>>
<<if $promiscuity lte 79>>
<<set $promiscuity += 2>>
Performing such a lewd act excites you and <span class="green">restores your sense of control and self-worth</span>, for now.<<ggcontrol>><<control 25>><<set $arousal += 400>><<set $stress -= 1200>><<combattrauma -120>><<ltrauma>><<lstress>><<garousal>>
<<elseif $promiscuity gte 80>>
While performing such a lewd act excites you, it does nothing to lift the cloud hanging over you. <span class="pink">You need to do something more extreme.</span><<set $arousal += 400>><<garousal>>
<<if $promiscuitystress4 isnot 1>><<set $promiscuitystress4 to 1>><<lstress>><<set $stress -= 400>>
<</if>>
<</if>>
<<else>>
<<if $promiscuity lte 79>>
<<set $promiscuity += 1>>
You already feel in control, but performing such a lewd act <span class="green">soothes</span> and excites you.<<control 25>><<set $arousal += 400>><<set $stress -= 1200>><<combattrauma -120>><<ltrauma>><<lstress>><<garousal>>
<<elseif $promiscuity gte 80>>
You already feel in control and the act is <span class="pink">too tame to soothe</span>, but it does excite you.<<set $arousal += 400>><<garousal>>
<<if $promiscuitystress4 isnot 1>><<set $promiscuitystress4 to 1>><<lstress>><<set $stress -= 400>>
<</if>>
<</if>>
<</if>>
<br><br><</nobr>><</widget>>
<<widget "promiscuity5">><<nobr>>
<<if $control lt $controlmax>>
<<if $promiscuity lte 99>>
<<set $promiscuity += 2>>
Performing such a lewd act excites you and <span class="green">restores your sense of control and self-worth</span>, for now.<<ggcontrol>><<control 25>><<set $arousal += 500>><<set $stress -= 1500>><<combattrauma -150>><<ltrauma>><<lstress>><<garousal>>
<<elseif $promiscuity gte 100>>
While performing such a lewd act excites you, it does nothing to lift the cloud hanging over you. <span class="pink">You need to do something more extreme.</span><<set $arousal += 500>><<garousal>>
<<if $promiscuitystress5 isnot 1>><<set $promiscuitystress5 to 1>><<lstress>><<set $stress -= 500>>
<</if>>
<</if>>
<<else>>
<<if $promiscuity lte 99>>
<<set $promiscuity += 1>>
You already feel in control, but performing such a lewd act <span class="green">soothes</span> and excites you.<<control 25>><<set $arousal += 500>><<set $stress -= 1500>><<combattrauma -150>><<ltrauma>><<lstress>><<garousal>>
<<elseif $promiscuity gte 100>>
You already feel in control and the act is <span class="pink">too tame to soothe</span>, but it does excite you.<<set $arousal += 500>><<garousal>>
<<if $promiscuitystress5 isnot 1>><<set $promiscuitystress5 to 1>><<lstress>><<set $stress -= 500>>
<</if>>
<</if>>
<</if>>
<br><br><</nobr>><</widget>>
<<widget "combatpromiscuity1">><<nobr>>
<<if $enemytype is "man">>
<<if $consensual is 1>>
<<if $control lt $controlmax>>
<<if $promiscuity lte 19>>
<<set $promiscuity += 2>>
You prepare to perform a particularly lewd act, <span class="green">restoring your sense of control.</span><<ggcontrol>><<control 25>><<set $arousal += 100>><<set $stress -= 300>><<combattrauma -30>><<ltrauma>><<lstress>><<garousal>>
<<elseif $promiscuity gte 20>>
You prepare to perform a particularly lewd act, <span class="pink">though its too tame to soothe.</span><<set $arousal += 100>><<garousal>>
<<if $promiscuitystress1 isnot 1>><<set $promiscuitystress1 to 1>><<lstress>><<set $stress -= 100>>
<</if>>
<</if>>
<<else>>
<<if $promiscuity lte 19>>
<<set $promiscuity += 1>>
You prepare to perform a particularly lewd act, <span class="green">soothing and exciting you.</span><<control 25>><<set $arousal += 100>><<set $stress -= 300>><<combattrauma -30>><<ltrauma>><<lstress>><<garousal>>
<<elseif $promiscuity gte 20>>
You prepare to perform a particularly lewd act, <span class="pink">though it's too tame to soothe.</span><<set $arousal += 100>><<garousal>>
<<if $promiscuitystress1 isnot 1>><<set $promiscuitystress1 to 1>><<lstress>><<set $stress -= 100>>
<</if>>
<</if>>
<</if>>
<</if>>
<<else>>
<<combatdeviancy1>>
<</if>>
<</nobr>><</widget>>
<<widget "combatpromiscuity2">><<nobr>>
<<if $enemytype is "man">>
<<if $consensual is 1>>
<<if $control lt $controlmax>>
<<if $promiscuity lte 39>>
<<set $promiscuity += 2>>
You prepare to perform a particularly lewd act, <span class="green">restoring your sense of control.</span><<ggcontrol>><<control 25>><<set $arousal += 200>><<set $stress -= 600>><<combattrauma -60>><<ltrauma>><<lstress>><<garousal>>
<<elseif $promiscuity gte 40>>
You prepare to perform a particularly lewd act, <span class="pink">though its too tame to soothe you.</span><<set $arousal += 200>><<garousal>>
<<if $promiscuitystress2 isnot 1>><<set $promiscuitystress2 to 1>><<lstress>><<set $stress -= 200>>
<</if>>
<</if>>
<<else>>
<<if $promiscuity lte 39>>
<<set $promiscuity += 1>>
You prepare to perform a particularly lewd act, <span class="green">soothing and exciting you.</span><<control 25>><<set $arousal += 200>><<set $stress -= 600>><<combattrauma -60>><<ltrauma>><<lstress>><<garousal>>
<<elseif $promiscuity gte 40>>
You prepare to perform a particularly lewd act, <span class="pink">though it's too tame to soothe.</span><<set $arousal += 200>><<garousal>>
<<if $promiscuitystress2 isnot 1>><<set $promiscuitystress2 to 1>><<lstress>><<set $stress -= 200>>
<</if>>
<</if>>
<</if>>
<</if>>
<<else>>
<<combatdeviancy2>>
<</if>>
<</nobr>><</widget>>
<<widget "combatpromiscuity3">><<nobr>>
<<if $enemytype is "man">>
<<if $consensual is 1>>
<<if $control lt $controlmax>>
<<if $promiscuity lte 59>>
<<set $promiscuity += 2>>
You prepare to perform a particularly lewd act, <span class="green">restoring your sense of control.</span><<ggcontrol>><<control 25>><<set $arousal += 300>><<set $stress -= 900>><<combattrauma -90>><<ltrauma>><<lstress>><<garousal>>
<<elseif $promiscuity gte 60>>
You prepare to perform a particularly lewd act, <span class="pink">though its too tame to soothe you.</span><<set $arousal += 300>><<garousal>>
<<if $promiscuitystress3 isnot 1>><<set $promiscuitystress3 to 1>><<lstress>><<set $stress -= 300>>
<</if>>
<</if>>
<<else>>
<<if $promiscuity lte 59>>
<<set $promiscuity += 1>>
You prepare to perform a particularly lewd act, <span class="green">soothing and exciting you.</span><<control 25>><<set $arousal += 300>><<set $stress -= 900>><<combattrauma -90>><<ltrauma>><<lstress>><<garousal>>
<<elseif $promiscuity gte 60>>
You prepare to perform a particularly lewd act, <span class="pink">though it's too tame to soothe.</span><<set $arousal += 300>><<garousal>>
<<if $promiscuitystress3 isnot 1>><<set $promiscuitystress3 to 1>><<lstress>><<set $stress -= 300>>
<</if>>
<</if>>
<</if>>
<</if>>
<<else>>
<<combatdeviancy3>>
<</if>>
<</nobr>><</widget>>
<<widget "combatpromiscuity4">><<nobr>>
<<if $enemytype is "man">>
<<if $consensual is 1>>
<<if $control lt $controlmax>>
<<if $promiscuity lte 79>>
<<set $promiscuity += 2>>
You prepare to perform a particularly lewd act, <span class="green">restoring your sense of control.</span><<ggcontrol>><<control 25>><<set $arousal += 400>><<set $stress -= 1200>><<combattrauma -120>><<ltrauma>><<lstress>><<garousal>>
You prepare to perform a particularly lewd act, <span class="pink">though its too tame to soothe you.</span><<set $arousal += 400>><<garousal>>
<<if $promiscuitystress4 isnot 1>><<set $promiscuitystress4 to 1>><<lstress>><<set $stress -= 400>>
<</if>>
<</if>>
<<else>>
<<if $promiscuity lte 79>>
<<set $promiscuity += 1>>
You prepare to perform a particularly lewd act, <span class="green">soothing and exciting you.</span><<control 25>><<set $arousal += 400>><<set $stress -= 1200>><<combattrauma -120>><<ltrauma>><<lstress>><<garousal>>
<<elseif $promiscuity gte 80>>
You prepare to perform a particularly lewd act, <span class="pink">though it's too tame to soothe.</span><<set $arousal += 400>><<garousal>>
<<if $promiscuitystress4 isnot 1>><<set $promiscuitystress4 to 1>><<lstress>><<set $stress -= 400>>
<</if>>
<</if>>
<</if>>
<</if>>
<<else>>
<<combatdeviancy4>>
<</if>>
<</nobr>><</widget>>
<<widget "combatpromiscuity5">><<nobr>>
<<if $enemytype is "man">>
<<if $consensual is 1>>
<<if $control lt $controlmax>>
<<if $promiscuity lte 99>>
<<set $promiscuity += 2>>
You prepare to perform a particularly lewd act, <span class="green">restoring your sense of control.</span><<ggcontrol>><<control 25>><<set $arousal += 500>><<set $stress -= 1500>><<combattrauma -150>><<ltrauma>><<lstress>><<garousal>>
<<elseif $promiscuity gte 100>>
You prepare to perform a particularly lewd act, <span class="pink">though its too tame to soothe you.</span><<set $arousal += 500>><<garousal>>
<<if $promiscuitystress5 isnot 1>><<set $promiscuitystress5 to 1>><<lstress>><<set $stress -= 500>>
<</if>>
<</if>>
<<else>>
<<if $promiscuity lte 99>>
<<set $promiscuity += 1>>
You prepare to perform a particularly lewd act, <span class="green">soothing and exciting you.</span><<control 25>><<set $arousal += 500>><<set $stress -= 1500>><<combattrauma -150>><<ltrauma>><<lstress>><<garousal>>
<<elseif $promiscuity gte 100>>
You prepare to perform a particularly lewd act, <span class="pink">though it's too tame to soothe.</span><<set $arousal += 500>><<garousal>>
<<if $promiscuitystress5 isnot 1>><<set $promiscuitystress5 to 1>><<lstress>><<set $stress -= 500>>
<</if>>
<</if>>
<</if>>
<</if>>
<<else>>
<<combatdeviancy5>>
<</if>>
<</nobr>><</widget>>
:: Widgets Named Npcs [widget]
<<widget "endnpc">><<nobr>>
<<if $npc is "Charlie">><<set $npc to 0>><<charlieend>><</if>>
<<if $npc is "Darryl">><<set $npc to 0>><<darrylend>><</if>>
<<if $npc is "Harper">><<set $npc to 0>><<harperend>><</if>>
<<if $npc is "Jordan">><<set $npc to 0>><<jordanend>><</if>>
<<if $npc is "Briar">><<set $npc to 0>><<briarend>><</if>>
<<if $npc is "River">><<set $npc to 0>><<riverend>><</if>>
<<if $npc is "Leighton">><<set $npc to 0>><<leightonend>><</if>>
<<if $npc is "Mason">><<set $npc to 0>><<masonend>><</if>>
<<if $npc is "Winter">><<set $npc to 0>><<winterend>><</if>>
<<if $npc is "Doren">><<set $npc to 0>><<dorenend>><</if>>
<<if $npc is "Sirris">><<set $npc to 0>><<sirrisend>><</if>>
<<if $npc is "Eden">><<set $npc to 0>><<edenend>><</if>>
<<if $npc is "Sam">><<set $npc to 0>><<samend>><</if>>
<<if $npc is "Landry">><<set $npc to 0>><<landryend>><</if>>
<<if $npc is "Bailey">><<set $npc to 0>><<baileyend>><</if>>
<<if $npc is "Whitney">><<set $npc to 0>><<whitneyend>><</if>>
<<if $npc is "Robin">><<set $npc to 0>><<robinend>><</if>>
<<if $npc is "Avery">><<set $npc to 0>><<averyend>><</if>>
<</nobr>><</widget>>
<<widget "initnpcgender">><<nobr>>
<<if $charliegender is undefined>>
<<if $malechance lt random(1, 100)>>
<<set $charliegender to "f">>
<<else>>
<<set $charliegender to "m">>
<</if>>
<</if>>
<<if $charliegenitals is undefined>>
<<if $charliegender is "m">>
<<if random(0, 99) gte $cbchance>>
<<set $charliegenitals to "penis">>
<<else>>
<<set $charliegenitals to "vagina">>
<</if>>
<<elseif $charliegender is "f">>
<<if random(0, 99) gte $dgchance>>
<<set $charliegenitals to "vagina">>
<<else>>
<<set $charliegenitals to "penis">>
<</if>>
<</if>>
<</if>>
<<if $darrylgender is undefined>>
<<if $malechance lt random(1, 100)>>
<<set $darrylgender to "f">>
<<else>>
<<set $darrylgender to "m">>
<</if>>
<</if>>
<<if $darrylgenitals is undefined>>
<<if $darrylgender is "m">>
<<if random(0, 99) gte $cbchance>>
<<set $darrylgenitals to "penis">>
<<else>>
<<set $darrylgenitals to "vagina">>
<</if>>
<<elseif $darrylgender is "f">>
<<if random(0, 99) gte $dgchance>>
<<set $darrylgenitals to "vagina">>
<<else>>
<<set $darrylgenitals to "penis">>
<</if>>
<</if>>
<</if>>
<<if $harpergender is undefined>>
<<if $malechance lt random(1, 100)>>
<<set $harpergender to "f">>
<<else>>
<<set $harpergender to "m">>
<</if>>
<</if>>
<<if $harpergenitals is undefined>>
<<if $harpergender is "m">>
<<if random(0, 99) gte $cbchance>>
<<set $harpergenitals to "penis">>
<<else>>
<<set $harpergenitals to "vagina">>
<</if>>
<<elseif $harpergender is "f">>
<<if random(0, 99) gte $dgchance>>
<<set $harpergenitals to "vagina">>
<<else>>
<<set $harpergenitals to "penis">>
<</if>>
<</if>>
<</if>>
<<if $jordangender is undefined>>
<<if $malechance lt random(1, 100)>>
<<set $jordangender to "f">>
<<else>>
<<set $jordangender to "m">>
<</if>>
<</if>>
<<if $jordangenitals is undefined>>
<<if $jordangender is "m">>
<<if random(0, 99) gte $cbchance>>
<<set $jordangenitals to "penis">>
<<else>>
<<set $jordangenitals to "vagina">>
<</if>>
<<elseif $jordangender is "f">>
<<if random(0, 99) gte $dgchance>>
<<set $jordangenitals to "vagina">>
<<else>>
<<set $jordangenitals to "penis">>
<</if>>
<</if>>
<</if>>
<<if $briargender is undefined>>
<<if $malechance lt random(1, 100)>>
<<set $briargender to "f">>
<<else>>
<<set $briargender to "m">>
<</if>>
<</if>>
<<if $briargenitals is undefined>>
<<if $briargender is "m">>
<<if random(0, 99) gte $cbchance>>
<<set $briargenitals to "penis">>
<<else>>
<<set $briargenitals to "vagina">>
<</if>>
<<elseif $briargender is "f">>
<<if random(0, 99) gte $dgchance>>
<<set $briargenitals to "vagina">>
<<else>>
<<set $briargenitals to "penis">>
<</if>>
<</if>>
<</if>>
<<if $rivergender is undefined>>
<<if $malechance lt random(1, 100)>>
<<set $rivergender to "f">>
<<else>>
<<set $rivergender to "m">>
<</if>>
<</if>>
<<if $rivergenitals is undefined>>
<<if $rivergender is "m">>
<<if random(0, 99) gte $cbchance>>
<<set $rivergenitals to "penis">>
<<else>>
<<set $rivergenitals to "vagina">>
<</if>>
<<elseif $rivergender is "f">>
<<if random(0, 99) gte $dgchance>>
<<set $rivergenitals to "vagina">>
<<else>>
<<set $rivergenitals to "penis">>
<</if>>
<</if>>
<</if>>
<<if $leightongender is undefined>>
<<if $malechance lt random(1, 100)>>
<<set $leightongender to "f">>
<<else>>
<<set $leightongender to "m">>
<</if>>
<</if>>
<<if $leightongenitals is undefined>>
<<if $leightongender is "m">>
<<if random(0, 99) gte $cbchance>>
<<set $leightongenitals to "penis">>
<<else>>
<<set $leightongenitals to "vagina">>
<</if>>
<<elseif $leightongender is "f">>
<<if random(0, 99) gte $dgchance>>
<<set $leightongenitals to "vagina">>
<<else>>
<<set $leightongenitals to "penis">>
<</if>>
<</if>>
<</if>>
<<if $masongender is undefined>>
<<if $malechance lt random(1, 100)>>
<<set $masongender to "f">>
<<else>>
<<set $masongender to "m">>
<</if>>
<</if>>
<<if $masongenitals is undefined>>
<<if $masongender is "m">>
<<if random(0, 99) gte $cbchance>>
<<set $masongenitals to "penis">>
<<else>>
<<set $masongenitals to "vagina">>
<</if>>
<<elseif $masongender is "f">>
<<if random(0, 99) gte $dgchance>>
<<set $masongenitals to "vagina">>
<<else>>
<<set $masongenitals to "penis">>
<</if>>
<</if>>
<</if>>
<<if $wintergender is undefined>>
<<if $malechance lt random(1, 100)>>
<<set $wintergender to "f">>
<<else>>
<<set $wintergender to "m">>
<</if>>
<</if>>
<<if $wintergenitals is undefined>>
<<if $wintergender is "m">>
<<if random(0, 99) gte $cbchance>>
<<set $wintergenitals to "penis">>
<<else>>
<<set $wintergenitals to "vagina">>
<</if>>
<<elseif $wintergender is "f">>
<<if random(0, 99) gte $dgchance>>
<<set $wintergenitals to "vagina">>
<<else>>
<<set $wintergenitals to "penis">>
<</if>>
<</if>>
<</if>>
<<if $dorengender is undefined>>
<<if $malechance lt random(1, 100)>>
<<set $dorengender to "f">>
<<else>>
<<set $dorengender to "m">>
<</if>>
<</if>>
<<if $dorengenitals is undefined>>
<<if $dorengender is "m">>
<<if random(0, 99) gte $cbchance>>
<<set $dorengenitals to "penis">>
<<else>>
<<set $dorengenitals to "vagina">>
<</if>>
<<elseif $dorengender is "f">>
<<if random(0, 99) gte $dgchance>>
<<set $dorengenitals to "vagina">>
<<else>>
<<set $dorengenitals to "penis">>
<</if>>
<</if>>
<</if>>
<<if $sirrisgender is undefined>>
<<if $malechance lt random(1, 100)>>
<<set $sirrisgender to "f">>
<<else>>
<<set $sirrisgender to "m">>
<</if>>
<</if>>
<<if $sirrisgenitals is undefined>>
<<if $sirrisgender is "m">>
<<if random(0, 99) gte $cbchance>>
<<set $sirrisgenitals to "penis">>
<<else>>
<<set $sirrisgenitals to "vagina">>
<</if>>
<<elseif $sirrisgender is "f">>
<<if random(0, 99) gte $dgchance>>
<<set $sirrisgenitals to "vagina">>
<<else>>
<<set $sirrisgenitals to "penis">>
<</if>>
<</if>>
<</if>>
<<if $edengender is undefined>>
<<if $malechance lt random(1, 100)>>
<<set $edengender to "f">>
<<else>>
<<set $edengender to "m">>
<</if>>
<</if>>
<<if $edengenitals is undefined>>
<<if $edengender is "m">>
<<if random(0, 99) gte $cbchance>>
<<set $edengenitals to "penis">>
<<else>>
<<set $edengenitals to "vagina">>
<</if>>
<<elseif $edengender is "f">>
<<if random(0, 99) gte $dgchance>>
<<set $edengenitals to "vagina">>
<<else>>
<<set $edengenitals to "penis">>
<</if>>
<</if>>
<</if>>
<<if $samgender is undefined>>
<<if $malechance lt random(1, 100)>>
<<set $samgender to "f">>
<<else>>
<<set $samgender to "m">>
<</if>>
<</if>>
<<if $samgenitals is undefined>>
<<if $samgender is "m">>
<<if random(0, 99) gte $cbchance>>
<<set $samgenitals to "penis">>
<<else>>
<<set $samgenitals to "vagina">>
<</if>>
<<elseif $samgender is "f">>
<<if random(0, 99) gte $dgchance>>
<<set $samgenitals to "vagina">>
<<else>>
<<set $samgenitals to "penis">>
<</if>>
<</if>>
<</if>>
<<if $landrygender is undefined>>
<<if $malechance lt random(1, 100)>>
<<set $landrygender to "f">>
<<else>>
<<set $landrygender to "m">>
<</if>>
<</if>>
<<if $landrygenitals is undefined>>
<<if $landrygender is "m">>
<<if random(0, 99) gte $cbchance>>
<<set $landrygenitals to "penis">>
<<else>>
<<set $landrygenitals to "vagina">>
<</if>>
<<elseif $landrygender is "f">>
<<if random(0, 99) gte $dgchance>>
<<set $landrygenitals to "vagina">>
<<else>>
<<set $landrygenitals to "penis">>
<</if>>
<</if>>
<</if>>
<<if $baileygender is undefined>>
<<if $malechance lt random(1, 100)>>
<<set $baileygender to "f">>
<<else>>
<<set $baileygender to "m">>
<</if>>
<</if>>
<<if $baileygenitals is undefined>>
<<if $baileygender is "m">>
<<if random(0, 99) gte $cbchance>>
<<set $baileygenitals to "penis">>
<<else>>
<<set $baileygenitals to "vagina">>
<</if>>
<<elseif $baileygender is "f">>
<<if random(0, 99) gte $dgchance>>
<<set $baileygenitals to "vagina">>
<<else>>
<<set $baileygenitals to "penis">>
<</if>>
<</if>>
<</if>>
<<if $whitneygender is undefined>>
<<if $malechance lt random(1, 100)>>
<<set $whitneygender to "f">>
<<else>>
<<set $whitneygender to "m">>
<</if>>
<</if>>
<<if $whitneygenitals is undefined>>
<<if $whitneygender is "m">>
<<if random(0, 99) gte $cbchance>>
<<set $whitneygenitals to "penis">>
<<else>>
<<set $whitneygenitals to "vagina">>
<</if>>
<<elseif $whitneygender is "f">>
<<if random(0, 99) gte $dgchance>>
<<set $whitneygenitals to "vagina">>
<<else>>
<<set $whitneygenitals to "penis">>
<</if>>
<</if>>
<</if>>
<<if $robingender is undefined>>
<<if $malechance lt random(1, 100)>>
<<set $robingender to "f">>
<<else>>
<<set $robingender to "m">>
<</if>>
<</if>>
<<if $robingenitals is undefined>>
<<if $robingender is "m">>
<<if random(0, 99) gte $cbchance>>
<<set $robingenitals to "penis">>
<<else>>
<<set $robingenitals to "vagina">>
<</if>>
<<elseif $robingender is "f">>
<<if random(0, 99) gte $dgchance>>
<<set $robingenitals to "vagina">>
<<else>>
<<set $robingenitals to "penis">>
<</if>>
<</if>>
<</if>>
<<if $averygender is undefined>>
<<if $malechance lt random(1, 100)>>
<<set $averygender to "f">>
<<else>>
<<set $averygender to "m">>
<</if>>
<</if>>
<<if $averygenitals is undefined>>
<<if $averygender is "m">>
<<if random(0, 99) gte $cbchance>>
<<set $averygenitals to "penis">>
<<else>>
<<set $averygenitals to "vagina">>
<</if>>
<<elseif $averygender is "f">>
<<if random(0, 99) gte $dgchance>>
<<set $averygenitals to "vagina">>
<<else>>
<<set $averygenitals to "penis">>
<</if>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "relationshiptext">><<nobr>>
<<if $npctextlove gte $npclovehigh>>
<<if $npctextdom gte $npcdomhigh>>
$npctextname the $npctextdescription thinks you're <span class="green">adorable.</span>
<<elseif $npctextdom lte $npcdomlow>>
$npctextname the $npctextdescription thinks you're <span class="green">inspiring.</span>
<<else>>
$npctextname the $npctextdescription thinks you're <span class="green">delightful.</span>
<</if>>
<<elseif $npctextlove lte $npclovelow>>
<<if $npctextdom gte $npcdomhigh>>
$npctextname the $npctextdescription thinks you're <span class="red">pathetic.</span>
<<elseif $npctextdom lte $npcdomlow>>
$npctextname the $npctextdescription thinks you're <span class="red">irritating.</span>
<<else>>
$npctextname the $npctextdescription thinks you're <span class="red">terrible.</span>
<</if>>
<<else>>
<<if $npctextdom gte $npcdomhigh>>
$npctextname the $npctextdescription thinks you're <span class="pink">cute.</span>
<<elseif $npctextdom lte $npcdomlow>>
$npctextname the $npctextdescription <span class="teal">looks up to you.</span>
<<else>>
$npctextname the $npctextdescription has no strong opinion of you.
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "initcharlie">><<nobr>>
<<set $initcharlie to 1>>
<<set $charlietrust to 0>>
<<set $charlielove to 0>>
<<set $charliedom to 0>>
<</nobr>><</widget>>
<<widget "charlie">><<nobr>>
<<if $initcharlie isnot 1>>
<<initcharlie>>
<</if>>
<<set $enemyno += 1>>
<<set $npc to "Charlie">>
<<set $pronoun1 to $charliegender>><<set $charlieactivegender to $charliegender>>
<<set $lefthand to 0>>
<<set $righthand to 0>>
<<set $mouth to 0>>
<<set $anus to 0>>
<<if $charliegenitals is "penis">>
<<set $penis to "clothed">>
<<elseif $charliegenitals is "vagina">>
<<set $vagina to "clothed">>
<</if>>
<<set $insecurity1 to "ethics">>
<<if $pronoun1 is "f">>
<<set $npcdescription to "dance coach">>
<<else>>
<<set $npcdescription to "dance coach">>
<</if>>
<<set $npcadult1 to 1>>
<<set $npcchild1 to 0>>
<</nobr>><</widget>>
<<widget "charlierelationship">><<nobr>>
<<if $initcharlie is 1>>
<<set $npctextlove to $charlielove>>
<<set $npctextdom to $charliedom>>
<<set $npctextname to "Charlie">>
<<set $npctextdescription to "dance coach">>
<<relationshiptext>>
<br>
<</if>>
<</nobr>><</widget>>
<<widget "charlieend">><<nobr>>
<<set $charlietrust += ($enemytrust / 100)>>
<</nobr>><</widget>>
<<widget "initdarryl">><<nobr>>
<<set $initdarryl to 1>>
<<set $darryltrust to 0>>
<<set $darryllove to 0>>
<<set $darryldom to 0>>
<</nobr>><</widget>>
<<widget "darryl">><<nobr>>
<<if $initdarryl isnot 1>>
<<initdarryl>>
<</if>>
<<set $enemyno += 1>>
<<set $npc to "Darryl">>
<<set $pronoun1 to $darrylgender>><<set $darrylactivegender to $darrylgender>>
<<set $lefthand to 0>>
<<set $righthand to 0>>
<<set $mouth to 0>>
<<set $anus to 0>>
<<if $darrylgenitals is "penis">>
<<set $penis to "clothed">>
<<elseif $darrylgenitals is "vagina">>
<<set $vagina to "clothed">>
<</if>>
<<set $insecurity1 to "ethics">>
<<if $pronoun1 is "f">>
<<set $npcdescription to "club owner">>
<<else>>
<<set $npcdescription to "club owner">>
<</if>>
<<set $npcadult1 to 1>>
<<set $npcchild1 to 0>>
<</nobr>><</widget>>
<<widget "darrylrelationship">><<nobr>>
<<if $initdarryl is 1>>
<<set $npctextlove to $darryllove>>
<<set $npctextdom to $darryldom>>
<<set $npctextname to "Darryl">>
<<set $npctextdescription to "club owner">>
<<relationshiptext>>
<br>
<</if>>
<</nobr>><</widget>>
<<widget "darrylend">><<nobr>>
<<set $darryltrust += ($enemytrust / 100)>>
<</nobr>><</widget>>
<<widget "initharper">><<nobr>>
<<set $initharper to 1>>
<<set $harpertrust to 0>>
<<set $harperlove to 0>>
<<set $harperdom to 0>>
<</nobr>><</widget>>
<<widget "harper">><<nobr>>
<<if $initharper isnot 1>>
<<initharper>>
<</if>>
<<set $enemyno += 1>>
<<set $npc to "Harper">>
<<set $pronoun1 to $harpergender>><<set $harperactivegender to $harpergender>>
<<set $lefthand to 0>>
<<set $righthand to 0>>
<<set $mouth to 0>>
<<set $anus to 0>>
<<if $harpergenitals is "penis">>
<<set $penis to "clothed">>
<<elseif $harpergenitals is "vagina">>
<<set $vagina to "clothed">>
<</if>>
<<set $insecurity1 to "skill">>
<<if $pronoun1 is "f">>
<<set $npcdescription to "doctor">>
<<else>>
<<set $npcdescription to "doctor">>
<</if>>
<<set $npcadult1 to 1>>
<<set $npcchild1 to 0>>
<</nobr>><</widget>>
<<widget "harperrelationship">><<nobr>>
<<if $initharper is 1>>
<<set $npctextlove to $harperlove>>
<<set $npctextdom to $harperdom>>
<<set $npctextname to "Harper">>
<<set $npctextdescription to "doctor">>
<<relationshiptext>>
<br>
<</if>>
<</nobr>><</widget>>
<<widget "harperend">><<nobr>>
<<set $harpertrust += ($enemytrust / 100)>>
<</nobr>><</widget>>
<<widget "initjordan">><<nobr>>
<<set $initjordan to 1>>
<<set $jordantrust to 0>>
<<set $jordanlove to 0>>
<<set $jordandom to 0>>
<</nobr>><</widget>>
<<widget "jordan">><<nobr>>
<<if $initjordan isnot 1>>
<<initjordan>>
<</if>>
<<set $enemyno += 1>>
<<set $npc to "Jordan">>
<<set $pronoun1 to $jordangender>><<set $jordanactivegender to $jordangender>>
<<set $lefthand to 0>>
<<set $righthand to 0>>
<<set $mouth to 0>>
<<set $anus to 0>>
<<if $jordangenitals is "penis">>
<<set $penis to "clothed">>
<<elseif $jordangenitals is "vagina">>
<<set $vagina to "clothed">>
<</if>>
<<set $insecurity1 to "ethics">>
<<if $pronoun1 is "f">>
<<set $npcdescription to "priestess">>
<<else>>
<<set $npcdescription to "priest">>
<</if>>
<<set $npcadult1 to 1>>
<<set $npcchild1 to 0>>
<</nobr>><</widget>>
<<widget "jordanrelationship">><<nobr>>
<<if $initjordan is 1>>
<<set $npctextlove to $jordanlove>>
<<set $npctextdom to $jordandom>>
<<set $npctextname to "Jordan">>
<<if $jordangender is "f">>
<<set $npctextdescription to "priestess">>
<<else>>
<<set $npctextdescription to "priest">>
<</if>>
<<relationshiptext>>
<br>
<</if>>
<</nobr>><</widget>>
<<widget "jordanend">><<nobr>>
<<set $jordantrust += ($enemytrust / 100)>>
<</nobr>><</widget>>
<<widget "initbriar">><<nobr>>
<<set $initbriar to 1>>
<<set $briartrust to 0>>
<<set $briarlove to 0>>
<<set $briardom to 0>>
<</nobr>><</widget>>
<<widget "briar">><<nobr>>
<<if $initbriar isnot 1>>
<<initbriar>>
<</if>>
<<set $enemyno += 1>>
<<set $npc to "Briar">>
<<set $pronoun1 to $briargender>><<set $briaractivegender to $briargender>>
<<set $lefthand to 0>>
<<set $righthand to 0>>
<<set $mouth to 0>>
<<set $anus to 0>>
<<if $briargenitals is "penis">>
<<set $penis to "clothed">>
<<elseif $briargenitals is "vagina">>
<<set $vagina to "clothed">>
<</if>>
<<set $insecurity1 to "looks">>
<<if $pronoun1 is "f">>
<<set $npcdescription to "brothel owner">>
<<else>>
<<set $npcdescription to "brothel owner">>
<</if>>
<<set $npcadult1 to 1>>
<<set $npcchild1 to 0>>
<</nobr>><</widget>>
<<widget "briarrelationship">><<nobr>>
<<if $initbriar is 1>>
<<set $npctextlove to $briarlove>>
<<set $npctextdom to $briardom>>
<<set $npctextname to "Briar">>
<<set $npctextdescription to "brothel owner">>
<<relationshiptext>>
<br>
<</if>>
<</nobr>><</widget>>
<<widget "briarend">><<nobr>>
<<set $briartrust += ($enemytrust / 100)>>
<</nobr>><</widget>>
<<widget "initriver">><<nobr>>
<<set $initriver to 1>>
<<set $rivertrust to 0>>
<<set $riverlove to 0>>
<<set $riverdom to 0>>
<<if $rivergender is "m">>
//River teaches maths at the local school. His short brown hair is flecked with grey and his piercing blue eyes scrutinize his surroundings. Students tend to be well-behaved in his class.//
<<else>>
//River teaches maths at the local school. Her long brown hair is flecked with grey and her piercing blue eyes scrutinize her surroundings. Students tend to be well-behaved in her class.//
<</if>>
<</nobr>><</widget>>
<<widget "river">><<nobr>>
<<if $initriver isnot 1>>
<<initriver>>
<</if>>
<<set $enemyno += 1>>
<<set $npc to "River">>
<<set $pronoun1 to $rivergender>><<set $riveractivegender to $rivergender>>
<<set $lefthand to 0>>
<<set $righthand to 0>>
<<set $mouth to 0>>
<<set $anus to 0>>
<<if $rivergenitals is "penis">>
<<set $penis to "clothed">>
<<elseif $rivergenitals is "vagina">>
<<set $vagina to "clothed">>
<</if>>
<<set $insecurity1 to "ethics">>
<<if $pronoun1 is "f">>
<<set $npcdescription to "maths teacher">>
<<else>>
<<set $npcdescription to "maths teacher">>
<</if>>
<<set $npcadult1 to 1>>
<<set $npcchild1 to 0>>
<</nobr>><</widget>>
<<widget "riverrelationship">><<nobr>>
<<if $initriver is 1>>
<<set $npctextlove to $riverlove>>
<<set $npctextdom to $riverdom>>
<<set $npctextname to "River">>
<<set $npctextdescription to "maths teacher">>
<<relationshiptext>>
<br>
<</if>>
<</nobr>><</widget>>
<<widget "riverend">><<nobr>>
<<set $rivertrust += ($enemytrust / 100)>>
<</nobr>><</widget>>
<<widget "initleighton">><<nobr>>
<<set $initleighton to 1>>
<<set $leightontrust to 0>>
<<set $leightonlove to 0>>
<<set $leightondom to 0>>
<<if $leightongender is "m">>
//Leighton is the headmaster of the local school. He has green eyes and well-kept greying black hair. Tall and stately, he has a paternal, but firm attitude towards the students at his school.//
<<else>>
//Leighton is the headmistress of the local school. She has green eyes and greying black hair, held behind her head in a bun. Tall and stately, she has a maternal, but firm attitude towards the students at her school.//
<</if>>
<</nobr>><</widget>>
<<widget "leighton">><<nobr>>
<<if $initleighton isnot 1>>
<<initleighton>>
<</if>>
<<set $enemyno += 1>>
<<set $npc to "Leighton">>
<<set $pronoun1 to $leightongender>><<set $leightonactivegender to $leightongender>>
<<set $lefthand to 0>>
<<set $righthand to 0>>
<<set $mouth to 0>>
<<set $anus to 0>>
<<if $leightongenitals is "penis">>
<<set $penis to "clothed">>
<<elseif $leightongenitals is "vagina">>
<<set $vagina to "clothed">>
<</if>>
<<set $insecurity1 to "skill">>
<<if $pronoun1 is "f">>
<<set $npcdescription to "headmistress">>
<<else>>
<<set $npcdescription to "headmaster">>
<</if>>
<<set $npcadult1 to 1>>
<<set $npcchild1 to 0>>
<</nobr>><</widget>>
<<widget "leightonrelationship">><<nobr>>
<<if $initleighton is 1>>
<<set $npctextlove to $leightonlove>>
<<set $npctextdom to $leightondom>>
<<set $npctextname to "Leighton">>
<<if $leightongender is "f">>
<<set $npctextdescription to "headmistress">>
<<else>>
<<set $npctextdescription to "headmaster">>
<</if>>
<<relationshiptext>>
<br>
<</if>>
<</nobr>><</widget>>
<<widget "leightonend">><<nobr>>
<<set $leightontrust += ($enemytrust / 100)>>
<</nobr>><</widget>>
<<widget "initmason">><<nobr>>
<<set $initmason to 1>>
<<set $masontrust to 0>>
<<set $masonlove to 0>>
<<set $masondom to 0>>
<<if $masongender is "m">>
//Mason is the swimming teacher at the local school. He's the youngest teacher, only a few years older than some of the students. His toned body is naturally shown off during class, but if he notices the way he's leered at, he gives no indication.//
<<else>>
//Mason is the swimming teacher at the local school. She's the youngest teacher, only a few years older than some of the students. Her toned body is naturally shown off during class, but if she notices the way she's leered at, she gives no indication.//
<</if>>
<</nobr>><</widget>>
<<widget "mason">><<nobr>>
<<if $initmason isnot 1>>
<<initmason>>
<</if>>
<<set $enemyno += 1>>
<<set $npc to "Mason">>
<<set $pronoun1 to $masongender>><<set $masonactivegender to $masongender>>
<<set $lefthand to 0>>
<<set $righthand to 0>>
<<set $mouth to 0>>
<<set $anus to 0>>
<<if $masongenitals is "penis">>
<<set $penis to "clothed">>
<<elseif $masongenitals is "vagina">>
<<set $vagina to "clothed">>
<</if>>
<<set $insecurity1 to "ethics">>
<<if $pronoun1 is "f">>
<<set $npcdescription to "swimming teacher">>
<<else>>
<<set $npcdescription to "swimming teacher">>
<</if>>
<<set $npcadult1 to 1>>
<<set $npcchild1 to 0>>
<</nobr>><</widget>>
<<widget "masonrelationship">><<nobr>>
<<if $initmason is 1>>
<<set $npctextlove to $masonlove>>
<<set $npctextdom to $masondom>>
<<set $npctextname to "Mason">>
<<set $npctextdescription to "swimming teacher">>
<<relationshiptext>>
<br>
<</if>>
<</nobr>><</widget>>
<<widget "masonend">><<nobr>>
<<set $masontrust += ($enemytrust / 100)>>
<</nobr>><</widget>>
<<widget "initwinter">><<nobr>>
<<set $initwinter to 1>>
<<set $wintertrust to 0>>
<<set $winterlove to 0>>
<<set $winterdom to 0>>
<<if $wintergender is "m">>
//Winter teaches history at the local school. He's an older gentleman, well-groomed and sophisticated.//
<<else>>
//Winter teaches history at the local school. She's an older lady, well-groomed and sophisticated.//
<</if>>
<</nobr>><</widget>>
<<widget "winter">><<nobr>>
<<if $initwinter isnot 1>>
<<initwinter>>
<</if>>
<<set $enemyno += 1>>
<<set $npc to "Winter">>
<<set $pronoun1 to $wintergender>><<set $winteractivegender to $wintergender>>
<<set $lefthand to 0>>
<<set $righthand to 0>>
<<set $mouth to 0>>
<<set $anus to 0>>
<<if $wintergenitals is "penis">>
<<set $penis to "clothed">>
<<elseif $wintergenitals is "vagina">>
<<set $vagina to "clothed">>
<</if>>
<<set $insecurity1 to "skill">>
<<if $pronoun1 is "f">>
<<set $npcdescription to "history teacher">>
<<else>>
<<set $npcdescription to "history teacher">>
<</if>>
<<set $npcadult1 to 1>>
<<set $npcchild1 to 0>>
<</nobr>><</widget>>
<<widget "winterrelationship">><<nobr>>
<<if $initwinter is 1>>
<<set $npctextlove to $winterlove>>
<<set $npctextdom to $winterdom>>
<<set $npctextname to "Winter">>
<<set $npctextdescription to "history teacher">>
<<relationshiptext>>
<br>
<</if>>
<</nobr>><</widget>>
<<widget "winterend">><<nobr>>
<<set $wintertrust += ($enemytrust / 100)>>
<</nobr>><</widget>>
<<widget "initdoren">><<nobr>>
<<set $initdoren to 1>>
<<set $dorentrust to 0>>
<<set $dorenlove to 0>>
<<set $dorendom to 0>>
<<if $dorengender is "m">>
//Doren teaches english at the local school. His shaggy red hair and beard give him a savage look.//
<<else>>
//Doren teaches english at the local school. Her shaggy red hair gives her a savage look.//
<</if>>
<</nobr>><</widget>>
<<widget "doren">><<nobr>>
<<if $initdoren isnot 1>>
<<initdoren>>
<</if>>
<<set $enemyno += 1>>
<<set $npc to "Doren">>
<<set $pronoun1 to $dorengender>><<set $dorenactivegender to $dorengender>>
<<set $lefthand to 0>>
<<set $righthand to 0>>
<<set $mouth to 0>>
<<set $anus to 0>>
<<if $dorengenitals is "penis">>
<<set $penis to "clothed">>
<<elseif $dorengenitals is "vagina">>
<<set $vagina to "clothed">>
<</if>>
<<set $insecurity1 to "ethics">>
<<if $pronoun1 is "f">>
<<set $npcdescription to "english teacher">>
<<else>>
<<set $npcdescription to "english teacher">>
<</if>>
<<set $npcadult1 to 1>>
<<set $npcchild1 to 0>>
<</nobr>><</widget>>
<<widget "dorenrelationship">><<nobr>>
<<if $initdoren is 1>>
<<set $npctextlove to $dorenlove>>
<<set $npctextdom to $dorendom>>
<<set $npctextname to "Doren">>
<<set $npctextdescription to "english teacher">>
<<relationshiptext>>
<br>
<</if>>
<</nobr>><</widget>>
<<widget "dorenend">><<nobr>>
<<set $dorentrust += ($enemytrust / 100)>>
<</nobr>><</widget>>
<<widget "initsirris">><<nobr>>
<<set $initsirris to 1>>
<<set $sirristrust to 0>>
<<set $sirrislove to 0>>
<<set $sirrisdom to 0>>
<<if $sirrisgender is "m">>
//Sirris teaches science at the local school. He's calm and patient, which sometimes leads to a disordered classroom.//
<<else>>
//Sirris teaches science at the local school. She's calm and patient, which sometimes leads to a disordered classroom.//
<</if>>
<</nobr>><</widget>>
<<widget "sirris">><<nobr>>
<<if $initsirris isnot 1>>
<<initsirris>>
<</if>>
<<set $enemyno += 1>>
<<set $npc to "Sirris">>
<<set $pronoun1 to $sirrisgender>><<set $sirrisactivegender to $sirrisgender>>
<<set $lefthand to 0>>
<<set $righthand to 0>>
<<set $mouth to 0>>
<<set $anus to 0>>
<<if $sirrisgenitals is "penis">>
<<set $penis to "clothed">>
<<elseif $sirrisgenitals is "vagina">>
<<set $vagina to "clothed">>
<</if>>
<<set $insecurity1 to "ethics">>
<<if $pronoun1 is "f">>
<<set $npcdescription to "science teacher">>
<<else>>
<<set $npcdescription to "science teacher">>
<</if>>
<<set $npcadult1 to 1>>
<<set $npcchild1 to 0>>
<</nobr>><</widget>>
<<widget "sirrisrelationship">><<nobr>>
<<if $initsirris is 1>>
<<set $npctextlove to $sirrislove>>
<<set $npctextdom to $sirrisdom>>
<<set $npctextname to "Sirris">>
<<set $npctextdescription to "science teacher">>
<<relationshiptext>>
<br>
<</if>>
<</nobr>><</widget>>
<<widget "sirrisend">><<nobr>>
<<set $sirristrust += ($enemytrust / 100)>>
<</nobr>><</widget>>
<<widget "initeden">><<nobr>>
<<set $initeden to 1>>
<<set $edentrust to 0>>
<<set $edenlove to 0>>
<<set $edendom to 0>>
<</nobr>><</widget>>
<<widget "eden">><<nobr>>
<<if $initeden isnot 1>>
<<initeden>>
<</if>>
<<set $npc to "Eden">>
<<set $pronoun1 to $edengender>><<set $edenactivegender to $edengender>>
<<set $lefthand to 0>>
<<set $righthand to 0>>
<<set $mouth to 0>>
<<set $anus to 0>>
<<if $edengenitals is "penis">>
<<set $penis to "clothed">>
<<elseif $edengenitals is "vagina">>
<<set $vagina to "clothed">>
<</if>>
<<set $insecurity1 to "looks">>
<<if $pronoun1 is "f">>
<<set $npcdescription to "huntress">>
<<else>>
<<set $npcdescription to "hunter">>
<</if>>
<<set $npcadult1 to 1>>
<<set $npcchild1 to 0>>
<<set $enemyno += 1>>
<</nobr>><</widget>>
<<widget "edenrelationship">><<nobr>>
<<if $initeden is 1>>
<<set $npctextlove to $edenlove>>
<<set $npctextdom to $edendom>>
<<set $npctextname to "Eden">>
<<if $edengender is "f">>
<<set $npctextdescription to "huntress">>
<<else>>
<<set $npctextdescription to "hunter">>
<</if>>
<<relationshiptext>>
<br>
<</if>>
<</nobr>><</widget>>
<<widget "edenend">><<nobr>>
<<set $edentrust += ($enemytrust / 100)>>
<</nobr>><</widget>>
<<widget "initsam">><<nobr>>
<<set $initsam to 1>>
<<set $samtrust to 0>>
<<set $samlove to 0>>
<<set $samdom to 0>>
<</nobr>><</widget>>
<<widget "sam">><<nobr>>
<<if $initsam isnot 1>>
<<initsam>>
<</if>>
<<set $enemyno += 1>>
<<set $npc to "Sam">>
<<set $pronoun1 to $samgender>><<set $samactivegender to $samgender>>
<<set $lefthand to 0>>
<<set $righthand to 0>>
<<set $mouth to 0>>
<<set $anus to 0>>
<<if $samgenitals is "penis">>
<<set $penis to "clothed">>
<<elseif $samgenitals is "vagina">>
<<set $vagina to "clothed">>
<</if>>
<<set $insecurity1 to "ethics">>
<<if $pronoun1 is "f">>
<<set $npcdescription to "cafe owner">>
<<else>>
<<set $npcdescription to "cafe owner">>
<</if>>
<<set $npcadult1 to 1>>
<<set $npcchild1 to 0>>
<</nobr>><</widget>>
<<widget "samrelationship">><<nobr>>
<<if $initsam is 1>>
<<set $npctextlove to $samlove>>
<<set $npctextdom to $samdom>>
<<set $npctextname to "Sam">>
<<set $npctextdescription to "cafe owner">>
<<relationshiptext>>
<br>
<</if>>
<</nobr>><</widget>>
<<widget "samend">><<nobr>>
<<set $samtrust += ($enemytrust / 100)>>
<</nobr>><</widget>>
<<widget "initlandry">><<nobr>>
<<set $initlandry to 1>>
<<set $landrytrust to 0>>
<<set $landrylove to 0>>
<<set $landrydom to 0>>
<</nobr>><</widget>>
<<widget "landry">><<nobr>>
<<if $initlandry isnot 1>>
<<initlandry>>
<</if>>
<<set $enemyno += 1>>
<<set $npc to "Landry">>
<<set $pronoun1 to $landrygender>><<set $landryactivegender to $landrygender>>
<<set $lefthand to 0>>
<<set $righthand to 0>>
<<set $mouth to 0>>
<<set $anus to 0>>
<<if $landrygenitals is "penis">>
<<set $penis to "clothed">>
<<elseif $landrygenitals is "vagina">>
<<set $vagina to "clothed">>
<</if>>
<<set $insecurity1 to "skill">>
<<if $pronoun1 is "f">>
<<set $npcdescription to "criminal">>
<<else>>
<<set $npcdescription to "criminal">>
<</if>>
<<set $npcadult1 to 1>>
<<set $npcchild1 to 0>>
<</nobr>><</widget>>
<<widget "landryrelationship">><<nobr>>
<<if $initlandry is 1>>
<<set $npctextlove to $landrylove>>
<<set $npctextdom to $landrydom>>
<<set $npctextname to "Landry">>
<<set $npctextdescription to "criminal">>
<<relationshiptext>>
<br>
<</if>>
<</nobr>><</widget>>
<<widget "landryend">><<nobr>>
<<set $landrytrust += ($enemytrust / 100)>>
<</nobr>><</widget>>
<<widget "initbailey">><<nobr>>
<<set $initbailey to 1>>
<<set $baileytrust to 0>>
<<set $baileylove to 0>>
<<set $baileydom to 0>>
<</nobr>><</widget>>
<<widget "bailey">><<nobr>>
<<if $initbailey isnot 1>>
<<initbailey>>
<</if>>
<<set $enemyno += 1>>
<<set $npc to "Bailey">>
<<set $pronoun1 to $baileygender>><<set $baileyactivegender to $baileygender>>
<<set $lefthand to 0>>
<<set $righthand to 0>>
<<set $mouth to 0>>
<<set $anus to 0>>
<<if $baileygenitals is "penis">>
<<set $penis to "clothed">>
<<elseif $baileygenitals is "vagina">>
<<set $vagina to "clothed">>
<</if>>
<<set $insecurity1 to "weak">>
<<if $pronoun1 is "f">>
<<set $npcdescription to "caretaker">>
<<else>>
<<set $npcdescription to "caretaker">>
<</if>>
<<set $npcadult1 to 1>>
<<set $npcchild1 to 0>>
<</nobr>><</widget>>
<<widget "baileyrelationship">><<nobr>>
<<if $initbailey is 1>>
<<set $npctextlove to $baileylove>>
<<set $npctextdom to $baileydom>>
<<set $npctextname to "Bailey">>
<<set $npctextdescription to "caretaker">>
<<relationshiptext>>
<br>
<</if>>
<</nobr>><</widget>>
<<widget "baileyend">><<nobr>>
<<set $baileytrust += ($enemytrust / 100)>>
<</nobr>><</widget>>
<<widget "initwhitney">><<nobr>>
<<set $initwhitney to 1>>
<<set $whitneytrust to 0>>
<<set $whitneylove to 0>>
<<set $whitneydom to 10>>
<<set $whitneylust to 0>>
<<set $whitneystate to "active">>
<</nobr>><</widget>>
<<widget "whitney">><<nobr>>
<<if $initwhitney isnot 1>>
<<initwhitney>>
<</if>>
<<set $enemyno += 1>>
<<set $npc to "Whitney">>
<<set $pronoun1 to $whitneygender>><<set $whitneyactivegender to $whitneygender>>
<<set $lefthand to 0>>
<<set $righthand to 0>>
<<set $mouth to 0>>
<<set $anus to 0>>
<<if $whitneygenitals is "penis">>
<<set $penis to "clothed">>
<<elseif $whitneygenitals is "vagina">>
<<set $vagina to "clothed">>
<</if>>
<<set $insecurity1 to "looks">>
<<if $pronoun1 is "f">>
<<set $npcdescription to "bully">>
<<else>>
<<set $npcdescription to "bully">>
<</if>>
<<set $npcadult1 to 0>>
<<set $npcchild1 to 0>>
<</nobr>><</widget>>
<<widget "whitneyrelationship">><<nobr>>
<<if $initwhitney is 1>>
<<set $npctextlove to $whitneylove>>
<<set $npctextdom to $whitneydom>>
<<set $npctextname to "Whitney">>
<<set $npctextdescription to "bully">>
<<relationshiptext>>
<br>
<</if>>
<</nobr>><</widget>>
<<widget "whitneyend">><<nobr>>
<<set $whitneytrust += ($enemytrust / 100)>>
<</nobr>><</widget>>
<<widget "initrobin">><<nobr>>
<<set $initrobin to 1>>
<<set $robintrust to 0>>
<<set $robinlove to 0>>
<<set $robindom to 0>>
<<set $robinlust to 0>>
<<set $robintrauma to 0>>
<</nobr>><</widget>>
<<widget "robin">><<nobr>>
<<if $initrobin isnot 1>>
<<initrobin>>
<</if>>
<<set $enemyno += 1>>
<<set $npc to "Robin">>
<<set $pronoun1 to $robingender>><<set $robinactivegender to $robingender>>
<<set $lefthand to 0>>
<<set $righthand to 0>>
<<set $mouth to 0>>
<<set $anus to 0>>
<<if $robingenitals is "penis">>
<<set $penis to "clothed">>
<<elseif $robingenitals is "vagina">>
<<set $vagina to "clothed">>
<</if>>
<<set $insecurity1 to "ethics">>
<<if $pronoun1 is "f">>
<<set $npcdescription to "orphan">>
<<else>>
<<set $npcdescription to "orphan">>
<</if>>
<<set $npcadult1 to 0>>
<<set $npcchild1 to 0>>
<</nobr>><</widget>>
<<widget "robinrelationship">><<nobr>>
Robin
<<if $robinromance is 1>>
<span class="lewd">loves you.</span>
<<elseif $robintrauma gte 80>>
<span class="red">is traumatised.</span>
<<elseif $robintrauma gte 40>>
<span class="red">is in pain.</span>
<<elseif $robintrauma gte 10>>
<span class="purple">is troubled.</span>
<<else>>
<span class="teal">looks up to you.</span>
<</if>>
<br>
<</nobr>><</widget>>
<<widget "robinend">><<nobr>>
<<set $robintrust += ($enemytrust / 100)>>
<</nobr>><</widget>>
<<widget "initavery">><<nobr>>
<<set $initavery to 1>>
<<set $averytrust to 0>>
<<set $averylove to 0>>
<<set $averydom to 0>>
<<set $averylust to 0>>
<<set $averytrauma to 0>>
<</nobr>><</widget>>
<<widget "avery">><<nobr>>
<<if $initavery isnot 1>>
<<initavery>>
<</if>>
<<set $enemyno += 1>>
<<set $npc to "Avery">>
<<set $pronoun1 to $averygender>><<set $averyactivegender to $averygender>>
<<set $lefthand to 0>>
<<set $righthand to 0>>
<<set $mouth to 0>>
<<set $anus to 0>>
<<if $averygenitals is "penis">>
<<set $penis to "clothed">>
<<elseif $averygenitals is "vagina">>
<<set $vagina to "clothed">>
<</if>>
<<set $insecurity1 to "weak">>
<<if $pronoun1 is "f">>
<<set $npcdescription to "orphan">>
<<else>>
<<set $npcdescription to "orphan">>
<</if>>
<<set $npcadult1 to 0>>
<<set $npcchild1 to 0>>
<</nobr>><</widget>>
<<widget "averyrelationship">><<nobr>>
<<if $initavery is 1>>
<<set $npctextlove to $averylove>>
<<set $npctextdom to $averydom>>
<<set $npctextname to "Avery">>
<<if $averygender is "m">>
<<set $npctextdescription to "businessman">>
<<else>>
<<set $npctextdescription to "businesswoman">>
<</if>>
<<relationshiptext>>
<br>
<</if>>
<</nobr>><</widget>>
<<widget "averyend">><<nobr>>
<<set $averytrust += ($enemytrust / 100)>>
<</nobr>><</widget>>
:: Widgets Time [widget]
<<widget "day">><<nobr>><<set $comb to 0>>
<<set $renttime -= 1>>
<<set $motherwake to 0>>
<<set $exhibitionism -= 1>>
<<set $promiscuity -= 1>>
<<set $deviancy -= 1>>
<<set $harpervisit to 0>>
<<set $yeardays += 1>>
<<set $scienceinterrupted to 0>>
<<set $mathsinterrupted to 0>>
<<set $englishinterrupted to 0>>
<<set $historyinterrupted to 0>>
<<set $swimminginterrupted to 0>>
<<set $headinterrupted to 0>>
<<set $luncheaten to 0>>
<<set $canteenapproach to 0>>
<<set $detentionattended to 0>>
<<if $whitneyromance is 1>>
<<set $bullytimer += 20>>
<<set $bullytimeroutside += 10>>
<<elseif $whitneydom gte 20>>
<<set $bullytimer += 20>>
<<set $bullytimeroutside += 10>>
<<else>>
<<set $bullytimer += 10>>
<<set $bullytimeroutside += 5>>
<</if>>
<<if $whitneylust gte 1>>
<<set $bullytimer += ($whitneylust / 5)>>
<<set $bullytimeroutside += ($whitneylust / 10)>>
<</if>>
<<set $policecollarseduceattempt to 0>>
<<set $beachstrip to 0>>
<<if $compoundstate is 1>>
<<set $compoundstate to 0>>
<</if>>
<<set $schooleventtimer -= 1>>
<<if $robindebtevent gt 0>>
<<set $robindebtevent -= 1>>
<</if>>
<<if $robintrauma gt 0>>
<<set $robintrauma -= 1>>
<</if>>
<<set $robinschoolmorning to 0>>
<<set $robinschoolafternoon to 0>>
<<set $baileyvisit to 0>>
<<set $robinwalk to 0>>
<<set $robinwakeday to 0>>
<<set $wolfwake to 0>>
<<if $weekday is 7 and $brothelshow isnot "none" and $brothelshowdone isnot 1 and $brothelshowintro is 1>>
<<set $brothelshowmissed to 1>><<set $brothelshow to "none">>
<</if>>
<<if $weekday is 7>>
<<set $brothelshowdone to 0>>
<</if>>
<<set $robinhugcry to 0>>
<<set $robinhugcomplain to 0>>
<<set $robinblame to 0>>
<<set $robinpersecute to 0>>
<<set $robinpolicebody to 0>>
<<set $robinpolicepay to 0>>
<<if $scienceproject is "ongoing">>
<<set $scienceprojectdays -= 1>>
<<if $scienceprojectdays lt 0>>
<<set $scienceproject to "done">>
<<scienceprojectfinish>>
<</if>>
<</if>>
<<if $lakecouple is 1>>
<<set $lakecouple to 0>>
<</if>>
<<set $medicated *= 0.5>>
<<set $medicated = Math.trunc($medicated)>>
<<if $medicated gt 0>>
<<set $medicated -= 1>>
<</if>>
<<set $boysroomentered to 0>>
<<set $girlsroomentered to 0>>
<<set $exhibitionismstress1 to 0>>
<<set $exhibitionismstress2 to 0>>
<<set $exhibitionismstress3 to 0>>
<<set $exhibitionismstress4 to 0>>
<<set $exhibitionismstress5 to 0>>
<<set $promiscuitystress1 to 0>>
<<set $promiscuitystress2 to 0>>
<<set $promiscuitystress3 to 0>>
<<set $promiscuitystress4 to 0>>
<<set $promiscuitystress5 to 0>>
<<set $deviancystress1 to 0>>
<<set $deviancystress2 to 0>>
<<set $deviancystress3 to 0>>
<<set $deviancystress4 to 0>>
<<set $deviancystress5 to 0>>
<<trauma -10>>
<<if $schooltrait is 4>>
<<trauma -40>>
<<elseif $schooltrait is 3>>
<<trauma -30>>
<<elseif $schooltrait is 2>>
<<trauma -20>>
<<elseif $schooltrait is 1>>
<<trauma -10>>
<</if>>
<<if $robinpaid gte 1>>
<<trauma -25>>
<</if>>
<<if $awareness gte 300>>
<<set $awarelevel to 2>>
<<elseif $awareness gte 200>>
<<set $awarelevel to 1>>
<<else>>
<<set $awarelevel to 0>>
<</if>>
<<set $monthday += 1>>
<<if $month is "january">>
<<if $monthday gt 31>>
<<set $monthday to 1>>
<<set $month to "february">>
<</if>>
<<elseif $month is "february">>
<<if $monthday gt 28>>
<<set $monthday to 1>>
<<set $month to "march">>
<</if>>
<<elseif $month is "march">>
<<if $monthday gt 31>>
<<set $monthday to 1>>
<<set $month to "april">>
<</if>>
<<elseif $month is "april">>
<<if $monthday gt 30>>
<<set $monthday to 1>>
<<set $month to "may">>
<</if>>
<<elseif $month is "may">>
<<if $monthday gt 31>>
<<set $monthday to 1>>
<<set $month to "june">>
<</if>>
<<elseif $month is "june">>
<<if $monthday gt 30>>
<<set $monthday to 1>>
<<set $month to "july">>
<</if>>
<<elseif $month is "july">>
<<if $monthday gt 31>>
<<set $monthday to 1>>
<<set $month to "august">>
<</if>>
<<elseif $month is "august">>
<<if $monthday gt 31>>
<<set $monthday to 1>>
<<set $month to "september">><<year>>
<</if>>
<<elseif $month is "september">>
<<if $monthday gt 30>>
<<set $monthday to 1>>
<<set $month to "october">>
<</if>>
<<elseif $month is "october">>
<<if $monthday gt 31>>
<<set $monthday to 1>>
<<set $month to "november">>
<</if>>
<<elseif $month is "november">>
<<if $monthday gt 30>>
<<set $monthday to 1>>
<<set $month to "december">>
<</if>>
<<elseif $month is "december">>
<<if $monthday gt 31>>
<<set $monthday to 1>>
<<set $month to "january">>
<<set $year += 1>>
<</if>>
<</if>>
<<if $schoolday is 1>>
<<if $scienceattended isnot 1>>
<<set $sciencemissed += 1>><<set $sciencemissedtext to 1>>
<<else>>
<<set $sciencemissed -= 1>>
<</if>>
<<if $mathsattended isnot 1>>
<<set $mathsmissed += 1>><<set $mathsmissedtext to 1>>
<<else>>
<<set $mathsmissed -= 1>>
<</if>>
<<if $englishattended isnot 1>>
<<set $englishmissed += 1>><<set $englishmissedtext to 1>>
<<else>>
<<set $englishmissed -= 1>>
<</if>>
<<if $historyattended isnot 1>>
<<set $historymissed += 1>><<set $historymissedtext to 1>>
<<else>>
<<set $historymissed -= 1>>
<</if>>
<<if $swimmingattended isnot 1>>
<<set $swimmingmissed += 1>><<set $swimmingmissedtext to 1>>
<<else>>
<<set $swimmingmissed -= 1>>
<</if>>
<<set $scienceattended to 0>>
<<set $mathsattended to 0>>
<<set $englishattended to 0>>
<<set $historyattended to 0>>
<<set $swimmingattended to 0>>
<</if>>
<<if $month is "january">>
<<if $weekday is 1>>
<<set $schoolterm to 1>>
<</if>>
<<if $weekday is 2>>
<<set $schoolterm to 1>>
<</if>>
<<elseif $month is "february">>
<<elseif $month is "march">>
<<elseif $month is "april">>
<<if $weekday is 7>>
<<set $schoolterm to 0>>
<</if>>
<<elseif $month is "may">>
<<if $weekday is 1>>
<<set $schoolterm to 1>>
<</if>>
<<if $weekday is 2>>
<<set $schoolterm to 1>>
<</if>>
<<elseif $month is "june">>
<<elseif $month is "july">>
<<if $weekday is 7>>
<<set $schoolterm to 0>>
<</if>>
<<elseif $month is "august">>
<<elseif $month is "september">>
<<if $weekday is 1>>
<<set $schoolterm to 1>>
<</if>>
<<if $weekday is 2>>
<<set $schoolterm to 1>>
<</if>>
<<elseif $month is "october">>
<<elseif $month is "november">>
<<elseif $month is "december">>
<<if $weekday is 7>>
<<set $schoolterm to 0>>
<</if>>
<</if>>
<<if $weekday isnot 1 and $weekday isnot 7 and $schoolterm is 1>>
<<set $schoolday to 1>>
<<else>>
<<set $schoolday to 0>>
<</if>>
<<if $weekday isnot 1>>
<<if $robindebtevent gte 1>>
<<else>>
<<set $robinmissing to 0>>
<</if>>
<</if>>
<<if $birthmonth is $month and $birthday is $monthday>>
<<set $devlevel += 1>>
<<if $devlevel gte 18>>
<<set $id to 1>>
<</if>>
<</if>>
<<if $purity lte 0>>
<<if $fallenangel gte 2>>
<<set $demonbuild to 30>>
<<set $demon to 6>>
<<set $fallenangel to 1>>
<span class="gold">Your blackened wings turn blacker still. Your shattered halo fades. Horns sprout from your scalp and a tail sprouts from your lower back. Your sense of loss is replaced with a desire for revenge.</span><<garousal>><<arousal 6>>
<</if>>
<<set $demonbuild += 1>>
<<else>>
<<set $demonbuild -= 1>>
<</if>>
<<if $purity gte 1 and $demon gte 6>>
<span class="red">You feel a terrible light sear through you.</span><<gstress>><<set $stress += $stressmax>>
<</if>>
<<set $purity += 1>>
<<if $vaginalvirginity is 1 and $penilevirginity is 1>>
<<set $purity += 2>>
<<if $purity gte 1000>>
<<set $angelbuild += 2>>
<</if>>
<</if>>
<<set $angelbuild -= 1>>
<<if $fallenangel gte 2>>
<<set $purity -= 10>>
<</if>>
<<set $physiqueage to (1000 * $devlevel)>>
<<if $physique gte 1000>>
<<set $physique to ($physique - ($physique / 2000))>>
<</if>>
<<set $hairlength += 3>>
<<if $headacc is "hairpin">>
<<set $hairlength += 27>>
<</if>>
<<if $schoolterm is 1>>
<<if $weekday is 2 or $weekday is 3 or $weekday is 4 or $weekday is 5 or $weekday is 6>>
<<set $science -= (1 + $science / 100)>>
<<set $maths -= (1 + $maths / 100)>>
<<set $english -= (1 + $english / 100)>>
<<set $history -= (1 + $history / 100)>>
<<set $school -= (4 + $school / 400)>>
<<set $delinquency -= 1>>
<<if $schoolfameblackmail isnot undefined>>
<<set $schoolfameblackmail += 1>>
<</if>>
<</if>>
<</if>>
<<if $breastsize is 0>>
<<if $purity gte 1000>>
<<set $breastgrowthtimer += 100>>
<<elseif $purity lte 960>>
<<set $breastgrowthtimer -= 100>>
<</if>>
<<elseif $breastsize is 1>>
<<if $purity gte 960>>
<<set $breastgrowthtimer += 100>>
<<elseif $purity lte 920>>
<<set $breastgrowthtimer -= 100>>
<</if>>
<<elseif $breastsize is 2>>
<<if $purity gte 920>>
<<set $breastgrowthtimer += 100>>
<<elseif $purity lte 880>>
<<set $breastgrowthtimer -= 100>>
<</if>>
<<elseif $breastsize is 3>>
<<if $purity gte 880>>
<<set $breastgrowthtimer += 100>>
<<elseif $purity lte 840>>
<<set $breastgrowthtimer -= 100>>
<</if>>
<<elseif $breastsize is 4>>
<<if $purity gte 840>>
<<set $breastgrowthtimer += 100>>
<<elseif $purity lte 800>>
<<set $breastgrowthtimer -= 100>>
<</if>>
<<elseif $breastsize is 5>>
<<if $purity gte 800>>
<<set $breastgrowthtimer += 100>>
<<elseif $purity lte 760>>
<<set $breastgrowthtimer -= 100>>
<</if>>
<<elseif $breastsize is 6>>
<<if $purity gte 760>>
<<set $breastgrowthtimer += 100>>
<<elseif $purity lte 720>>
<<set $breastgrowthtimer -= 100>>
<</if>>
<<elseif $breastsize is 7>>
<<if $purity gte 720>>
<<set $breastgrowthtimer += 100>>
<<elseif $purity lte 680>>
<<set $breastgrowthtimer -= 100>>
<</if>>
<<elseif $breastsize is 8>>
<<if $purity gte 680>>
<<set $breastgrowthtimer += 100>>
<<elseif $purity lte 640>>
<<set $breastgrowthtimer -= 100>>
<</if>>
<<elseif $breastsize is 9>>
<<if $purity gte 640>>
<<set $breastgrowthtimer += 100>>
<<elseif $purity lte 600>>
<<set $breastgrowthtimer -= 100>>
<</if>>
<<elseif $breastsize is 10>>
<<if $purity gte 600>>
<<set $breastgrowthtimer += 100>>
<<elseif $purity lte 560>>
<<set $breastgrowthtimer -= 100>>
<</if>>
<<elseif $breastsize is 11>>
<<if $purity gte 560>>
<<set $breastgrowthtimer += 100>>
<<elseif $purity lte 520>>
<<set $breastgrowthtimer -= 100>>
<</if>>
<<elseif $breastsize is 12>>
<<if $purity gte 520>>
<<set $breastgrowthtimer += 100>>
<<elseif $purity lte 480>>
<<set $breastgrowthtimer -= 100>>
<</if>>
<</if>>
<<if $chestparasite gte 1>>
<<set $breastgrowthtimer -= 300>>
<</if>>
<<if $breastsize lt $breastsizemax>>
<<set $breastgrowthtimer -= (1000 / ($purity + 1))>>
<<if $breastgrowthtimer lte 0>>
<<set $breastsize += 1>>
<<set $breastgrowthtimer += 700>>
<</if>>
<<elseif $devstate is 0 and $dev is 1>>
<<if $devlevel * 83 gte $purity>>
<<set $devstate to 1>>
<<set $breastgrowthtimer to 701>>
<<if $dev is 1>>
<span class="gold">You feel a change come over you.</span>
<</if>>
<</if>>
<</if>>
<<if $breastgrowthtimer gt 1000>>
<<set $breastgrowthtimer to 1000>>
<</if>>
<<if $breastgrowthtimer lt 0>>
<<set $breastgrowthtimer to 0>>
<</if>>
<<set $beauty += (100 - (($trauma / $traumamax) * 100))>>
<<set $weather to either("clear", "clear", "clear", "clear", "overcast", "overcast", "overcast", "overcast", "rain", "rain")>>
<<if $flashbacktown isnot 0>>
<<set $flashbacktown -= 1>>
<</if>>
<<if $flashbackhome isnot 0>>
<<set $flashbackhome -= 1>>
<</if>>
<<if $flashbackbeach isnot 0>>
<<set $flashbackbeach -= 1>>
<</if>>
<<if $flashbackunderground isnot 0>>
<<set $flashbackunderground -= 1>>
<</if>>
<<if $flashbackschool isnot 0>>
<<set $flashbackschool -= 1>>
<</if>>
<<if $flashbacktown is 1>>
<<set $flashbacktownready to 1>>
<</if>>
<<if $flashbackhome is 1>>
<<set $flashbackhomeready to 1>>
<</if>>
<<if $flashbackbeach is 1>>
<<set $flashbackbeachready to 1>>
<</if>>
<<if $flashbackunderground is 1>>
<<set $flashbackundergroundready to 1>>
<</if>>
<<if $flashbackschool is 1>>
<<set $flashbackflashbackschoolready to 1>>
<</if>>
<<if $breastsize isnot $breastsizeold>>
<<if $breastsize is 0>><<set $breastcup to "none">>
<<if $breastsize gt $breastsizeold>>
<span class="purple">Your chest feels heavy. Your breasts have grown.</span>
<<elseif $breastsize lt $breastsizeold>>
<span class="purple">Your chest feels light. Your breasts have become smaller.</span>
<</if>>
<<set $breastsizeold to 0>>
<<elseif $breastsize is 1>><<set $breastcup to "budding">>
<<if $breastsize gt $breastsizeold>>
<span class="purple">Your chest feels heavy. Your breasts have grown.</span>
<<elseif $breastsize lt $breastsizeold>>
<span class="purple">Your chest feels light. Your breasts have become smaller.</span>
<</if>>
<<set $breastsizeold to 1>>
<<elseif $breastsize is 2>><<set $breastcup to "AA">>
<<if $breastsize gt $breastsizeold>>
<span class="purple">Your chest feels heavy. Your breasts have grown.</span>
<<elseif $breastsize lt $breastsizeold>>
<span class="purple">Your chest feels light. Your breasts have become smaller.</span>
<</if>>
<<set $breastsizeold to 2>>
<<elseif $breastsize is 3>><<set $breastcup to "B">>
<<if $breastsize gt $breastsizeold>>
<span class="purple">Your chest feels heavy. Your breasts have grown.</span>
<<elseif $breastsize lt $breastsizeold>>
<span class="purple">Your chest feels light. Your breasts have become smaller.</span>
<</if>>
<<set $breastsizeold to 3>>
<<elseif $breastsize is 4>><<set $breastcup to "C">>
<<if $breastsize gt $breastsizeold>>
<span class="purple">Your chest feels heavy. Your breasts have grown.</span>
<<elseif $breastsize lt $breastsizeold>>
<span class="purple">Your chest feels light. Your breasts have become smaller.</span>
<</if>>
<<set $breastsizeold to 4>>
<<elseif $breastsize is 5>><<set $breastcup to "D">>
<<if $breastsize gt $breastsizeold>>
<span class="purple">Your chest feels heavy. Your breasts have grown.</span>
<<elseif $breastsize lt $breastsizeold>>
<span class="purple">Your chest feels light. Your breasts have become smaller.</span>
<</if>>
<<set $breastsizeold to 5>>
<<elseif $breastsize is 6>><<set $breastcup to "DD">>
<<if $breastsize gt $breastsizeold>>
<span class="purple">Your chest feels heavy. Your breasts have grown.</span>
<<elseif $breastsize lt $breastsizeold>>
<span class="purple">Your chest feels light. Your breasts have become smaller.</span>
<</if>>
<<set $breastsizeold to 6>>
<<elseif $breastsize is 7>><<set $breastcup to "DDD">>
<<if $breastsize gt $breastsizeold>>
<span class="purple">Your chest feels heavy. Your breasts have grown.</span>
<<elseif $breastsize lt $breastsizeold>>
<span class="purple">Your chest feels light. Your breasts have become smaller.</span>
<</if>>
<<set $breastsizeold to 7>>
<<elseif $breastsize is 8>><<set $breastcup to "F">>
<<if $breastsize gt $breastsizeold>>
<span class="purple">Your chest feels heavy. Your breasts have grown.</span>
<<elseif $breastsize lt $breastsizeold>>
<span class="purple">Your chest feels light. Your breasts have become smaller.</span>
<</if>>
<<set $breastsizeold to 8>>
<<elseif $breastsize is 9>><<set $breastcup to "G">>
<<if $breastsize gt $breastsizeold>>
<span class="purple">Your chest feels heavy. Your breasts have grown.</span>
<<elseif $breastsize lt $breastsizeold>>
<span class="purple">Your chest feels light. Your breasts have become smaller.</span>
<</if>>
<<set $breastsizeold to 9>>
<<elseif $breastsize is 10>><<set $breastcup to "H">>
<<if $breastsize gt $breastsizeold>>
<span class="purple">Your chest feels heavy. Your breasts have grown.</span>
<<elseif $breastsize lt $breastsizeold>>
<span class="purple">Your chest feels light. Your breasts have become smaller.</span>
<</if>>
<<set $breastsizeold to 10>>
<<elseif $breastsize is 11>><<set $breastcup to "I">>
<<if $breastsize gt $breastsizeold>>
<span class="purple">Your chest feels heavy. Your breasts have grown.</span>
<<elseif $breastsize lt $breastsizeold>>
<span class="purple">Your chest feels light. Your breasts have become smaller.</span>
<</if>>
<<set $breastsizeold to 11>>
<<elseif $breastsize gte 12>><<set $breastcup to "J">>
<<if $breastsize gt $breastsizeold>>
<span class="purple">Your chest feels heavy. Your breasts have grown.</span>
<<elseif $breastsize lt $breastsizeold>>
<span class="purple">Your chest feels light. Your breasts have become smaller.</span>
<</if>>
<<set $breastsizeold to 12>>
<<if $breastsize gt 12>><<set $breastsize to 12>><</if>>
<</if>>
<</if>>
<<if $english gte 700>>
<<set $englishtrait to 4>>
<<elseif $english gte 500>>
<<set $englishtrait to 3>>
<<elseif $english gte 400>>
<<set $englishtrait to 2>>
<<elseif $english gte 300>>
<<set $englishtrait to 1>>
<<else>>
<<set $englishtrait to 0>>
<</if>>
<<if $maths gte 700>>
<<set $mathstrait to 4>>
<<elseif $maths gte 500>>
<<set $mathstrait to 3>>
<<elseif $maths gte 400>>
<<set $mathstrait to 2>>
<<elseif $maths gte 300>>
<<set $mathstrait to 1>>
<<else>>
<<set $mathstrait to 0>>
<</if>>
<<if $science gte 700>>
<<set $sciencetrait to 4>>
<<elseif $science gte 500>>
<<set $sciencetrait to 3>>
<<elseif $science gte 400>>
<<set $sciencetrait to 2>>
<<elseif $science gte 300>>
<<set $sciencetrait to 1>>
<<else>>
<<set $sciencetrait to 0>>
<</if>>
<<if $history gte 700>>
<<set $historytrait to 4>>
<<elseif $history gte 500>>
<<set $historytrait to 3>>
<<elseif $history gte 400>>
<<set $historytrait to 2>>
<<elseif $history gte 300>>
<<set $historytrait to 1>>
<<else>>
<<set $historytrait to 0>>
<</if>>
<<if $school gte 2800>>
<<set $schooltrait to 4>>
<<elseif $school gte 2000>>
<<set $schooltrait to 3>>
<<elseif $school gte 1600>>
<<set $schooltrait to 2>>
<<elseif $school gte 1200>>
<<set $schooltrait to 1>>
<<else>>
<<set $schooltrait to 0>>
<</if>>
<<if $orgasmstat gte 1000 and $orgasmtrait isnot 1>>
<span class="gold">You've gained the "Orgasm Addict" trait.</span><<set $orgasmtrait to 1>>
<</if>>
<<if $ejacstat gte 1000 and $ejactrait isnot 1>>
<span class="gold">You've gained the "Cum Dump" trait.</span><<set $ejactrait to 1>>
<</if>>
<<if $moleststat gte 1000 and $molesttrait isnot 1>>
<span class="gold">You've gained the "Plaything" trait.</span><<set $molesttrait to 1>>
<</if>>
<<if $rapestat gte 500 and $rapetrait isnot 1>>
<span class="gold">You've gained the "Fucktoy" trait.</span><<set $rapetrait to 1>>
<</if>>
<<if $beastrapestat gte 100 and $bestialitytrait isnot 1>>
<span class="gold">You've gained the "Bitch" trait.</span><<set $bestialitytrait to 1>>
<</if>>
<<if $tentaclerapestat gte 50 and $tentacletrait isnot 1>>
<span class="gold">You've gained the "Prey" trait.</span><<set $tentacletrait to 1>>
<</if>>
<<if $swallowedstat gte 20 and $voretrait isnot 1>>
<span class="gold">You've gained the "Tasty" trait.</span><<set $voretrait to 1>>
<</if>>
<<set $edenbreakfast to 0>>
<<set $edenbed to 0>>
<<set $edenbath to 0>>
<<set $edenchoplust to 0>>
<<set $edenhunting to 0>>
<<set $edendays += 1>>
<<if $edengarden gte 1>>
<<set $edengarden -= 1>>
<</if>>
<<if $edenshrooms gte 1>>
<<set $edenshrooms -= 1>>
<</if>>
<<if $edenspring gte 1>>
<<set $edenspring -= 1>>
<</if>>
<<set $edenwake to 0>>
<<if $skulduggery gte 100 and $skulduggeryday lt 100>>
<span class="gold">Your skulduggery has improved to </span><span class="pink">F+.</span>
<<elseif $skulduggery gte 200 and $skulduggeryday lt 200>>
<span class="gold">Your skulduggery has improved to </span><span class="purple">D.</span>
<<elseif $skulduggery gte 300 and $skulduggeryday lt 300>>
<span class="gold">Your skulduggery has improved to </span><span class="purple">D+.</span>
<<elseif $skulduggery gte 400 and $skulduggeryday lt 400>>
<span class="gold">Your skulduggery has improved to </span><span class="blue">C.</span>
<<elseif $skulduggery gte 500 and $skulduggeryday lt 500>>
<span class="gold">Your skulduggery has improved to </span><span class="blue">C+.</span>
<<elseif $skulduggery gte 600 and $skulduggeryday lt 600>>
<span class="gold">Your skulduggery has improved to </span><span class="lblue">B.</span>
<<elseif $skulduggery gte 700 and $skulduggeryday lt 700>>
<span class="gold">Your skulduggery has improved to </span><span class="lblue">B+.</span>
<<elseif $skulduggery gte 800 and $skulduggeryday lt 800>>
<span class="gold">Your skulduggery has improved to </span><span class="teal">A.</span>
<<elseif $skulduggery gte 900 and $skulduggeryday lt 900>>
<span class="gold">Your skulduggery has improved to </span><span class="teal">A+.</span>
<<elseif $skulduggery gte 1000 and $skulduggeryday lt 1000>>
<span class="gold">Your skulduggery has improved to </span><span class="Green">S.</span>
<</if>>
<<set $skulduggeryday to $skulduggery>>
<<if $wolfbuild gte 1>>
<<set $wolfbuild -= 1>>
<</if>>
<<if $wolfgirl gte 6>>
<<set $submissive -= 20>>
<</if>>
<<if $wolfgirl is 0 and $wolfbuild gte 5 and $transformdisable is "f" and $transformed isnot 1>><<set $wolfgirl to 1>><<set $transformed to 1>>
<span class="gold">You have a strange toothache.</span><br><br>
<<elseif $wolfgirl is 1 and $wolfbuild gte 10 and $transformdisable is "f">><<set $wolfgirl to 2>>
<span class="gold">Your mouth feels different. You explore your mouth and wince as your tongue presses against your new fangs.</span><br><br>
<<elseif $wolfgirl is 1 and $wolfbuild lt 5>><<set $wolfgirl to 0>><<set $transformed to 0>>
<span class="gold">Your toothache has stopped.</span><br><br>
<<elseif $wolfgirl is 2 and $wolfbuild gte 15 and $transformdisable is "f">><<set $wolfgirl to 3>>
<<if $hirsutedisable is "f">>
<span class="gold">Your scalp and pubic area itch.</span><br><br>
<<else>>
<span class="gold">Your scalp itches.</span><br><br>
<</if>>
<<elseif $wolfgirl is 2 and $wolfbuild lt 10>><<set $wolfgirl to 1>>
<span class="gold">Your fangs have turned into regular teeth.</span><br><br>
<<elseif $wolfgirl is 3 and $wolfbuild gte 20 and $transformdisable is "f">><<set $wolfgirl to 4>>
<<if $hirsutedisable is "f">>
<span class="gold">You feel something on your head. You reach up and tug, but it hurts. You have a new pair of wolf ears. You also notice long and fluffy hair has grown in your pubic area.</span><br><br>
<<else>>
<span class="gold">You feel something on your head. You reach up and tug, but it hurts. You have a new pair of wolf ears. </span><br><br>
<</if>>
<<elseif $wolfgirl is 3 and $wolfbuild lt 15>><<set $wolfgirl to 2>>
<<if $hirsutedisable is "f">>
<span class="gold">Your scalp and pubic area no longer itch.</span><br><br>
<<else>>
<span class="gold">Your scalp no longer itches.</span><br><br>
<</if>>
<<elseif $wolfgirl is 4 and $wolfbuild gte 25 and $transformdisable is "f">><<set $wolfgirl to 5>>
<span class="gold">Your lower back itches.</span><br><br>
<<elseif $wolfgirl is 4 and $wolfbuild lte 20>><<set $wolfgirl to 3>>
<<if $hirsutedisable is "f">>
<span class="gold">Your wolf ears and extra body hair have disappeared.</span><br>
<<else>>
<span class="gold">Your wolf ears have disappeared.</span><br>
<</if>>
<br>
<<elseif $wolfgirl is 5 and $wolfbuild gte 30 and $transformdisable is "f">><<set $wolfgirl to 6>>
<span class="gold">Your bottom feels heavier than usual. You reach behind you and feel your new wolf tail.</span><br><br>
<<elseif $wolfgirl is 5 and $wolfbuild lt 25>><<set $wolfgirl to 4>>
<span class="gold">Your lower back has stopped itching.</span><br><br>
<<elseif $wolfgirl is 6 and $wolfbuild lt 30>><span class="gold">Your balance feels different. Your wolf tail has disappeared.</span><<set $wolfgirl to 5>><br><br>
<</if>>
<<if $angel is 0 and $angelbuild gte 25 and $transformdisable is "f" and $transformed isnot 1>><<set $angel to 1>><<set $transformed to 1>>
<span class="gold">Despite everything, you have managed to remain a pure <<genderstop>> The thought makes you happy.</span><br><br>
<<elseif $angel is 1 and $angelbuild gte 30 and $transformdisable is "f">><<set $angel to 2>>
<span class="gold">You are pure and feel determined to keep it that way.</span><br><br>
<<elseif $angel is 1 and $angelbuild lt 25>><<set $angel to 0>><<set $transformed to 0>>
<span class="gold">You feel soiled.</span><br><br>
<<elseif $angel is 2 and $angelbuild gte 35 and $transformdisable is "f">><<set $angel to 3>>
<span class="gold">You feel a weight lift from your shoulders.</span><br><br>
<<elseif $angel is 2 and $angelbuild lt 30>><<set $angel to 1>>
<span class="gold">You feel dirty.</span><br><br>
<<elseif $angel is 3 and $angelbuild gte 40 and $transformdisable is "f">><<set $angel to 4>>
<span class="gold">A golden light shines down you.</span><br><br>
<<elseif $angel is 3 and $angelbuild lt 35>><<set $angel to 2>>
<span class="gold">You feel a weight bear down on you.</span><br><br>
<<elseif $angel is 4 and $angelbuild gte 45 and $transformdisable is "f">><<set $angel to 5>>
<span class="gold">You feel a soothing warmth in your back.</span><br><br>
<<elseif $angel is 4 and $angelbuild lte 40>><<set $angel to 3>>
<span class="gold">The light above you fades.</span><br>
<br>
<<elseif $angel is 5 and $angelbuild gte 50 and $transformdisable is "f">><<set $angel to 6>>
<span class="gold">You feel lighter. Your new wings caress your face.</span><br><br>
<<elseif $angel is 5 and $angelbuild lt 45>><<set $angel to 4>>
<span class="gold">The soothing warmth in your back fades.</span><br><br>
<<elseif $angel is 6 and $angelbuild lt 50>><span class="gold">Your wings fade away.</span><<set $angel to 5>><br><br>
<</if>>
<<if $demon is 0 and $demonbuild gte 5 and $transformdisable is "f" and $transformed isnot 1>><<set $demon to 1>><<set $transformed to 1>>
<span class="gold">Your scalp itches.</span><<garousal>><<arousal 6>><br><br>
<<elseif $demon is 1 and $demonbuild gte 10 and $transformdisable is "f">><<set $demon to 2>>
<span class="gold">Horns sprout from your scalp.</span><<garousal>><<arousal 6>><br><br>
<<elseif $demon is 1 and $demonbuild lt 5>><<set $demon to 0>><<set $transformed to 0>>
<span class="gold">You feel an invisible light burn away your impurity.</span><br><br>
<<elseif $demon is 2 and $demonbuild gte 15 and $transformdisable is "f">><<set $demon to 3>>
<span class="gold">Your <<bottom>> itches.</span><<garousal>><<arousal 6>><br><br>
<<elseif $demon is 2 and $demonbuild lt 10>><<set $demon to 1>>
<span class="gold">Your horns recede.</span><br><br>
<<elseif $demon is 3 and $demonbuild gte 20 and $transformdisable is "f">><<set $demon to 4>>
<span class="gold">A tail sprouts from your lower back.</span><<garousal>><<arousal 6>><br><br>
<<elseif $demon is 3 and $demonbuild lt 15>><<set $demon to 2>>
<span class="gold">The itching in your <<bottom>> stops.</span><br><br>
<<elseif $demon is 4 and $demonbuild gte 25 and $transformdisable is "f">><<set $demon to 5>>
<span class="gold">You feel a burning sensation in your back.</span><<garousal>><<arousal 6>><br><br>
<<elseif $demon is 4 and $demonbuild lte 20>><<set $demon to 3>>
<span class="gold">Your tail recedes.</span><br>
<br>
<<elseif $demon is 5 and $demonbuild gte 30 and $transformdisable is "f">><<set $demon to 6>>
<span class="gold">You feel lighter. Your new wings caress your face.</span><<garousal>><<arousal 6>><br><br>
<<elseif $demon is 5 and $demonbuild lt 25>><<set $demon to 4>>
<span class="gold">The burning in your back ceases.</span><br><br>
<<elseif $demon is 6 and $demonbuild lt 30>><span class="gold">Your wings recede.</span><<set $demon to 5>><br><br>
<</if>>
<</nobr>><</widget>>
<<widget "hour">><<nobr>>
<<for $minute gte 60>>
<<set $minute -= 60>><<orgasmhour>><<control 1>>
<<if $ejactrait gte 1>>
<<set $stress -= (($goocount + $semencount) * 10)>>
<</if>>
<<set $edenlust += 1>>
<</for>>
<<if $wolfevent is 0>>
<<set $wolfevent to 1>>
<</if>>
<</nobr>><</widget>>
<<widget "advancetohour">><<nobr>>
<<set _min to $time - ($hour * 60)>>
<<pass _min>>
<</nobr>><</widget>>
<<widget "week">><<nobr>>
<<if $robindebt gte 0>>
<<set $robindebt += 1>>
<</if>>
<<if $robinpaid isnot 1 and $robindebt gte $robindebtlimit and $robindebtevent lte 0>>
<<set $robintrauma to 100>><<set $robineventnote to 1>><<set $robinmissing to 1>>
<</if>>
<<set $robinmoney to 300>>
<<if $edenfreedom gte 1 and $edenshopping is 2>>
<<set $edenshopping to 0>>
<</if>>
<<set $dancestudiotheft to 0>>
<<set $oceanbreezetheft to 0>>
<<set $stripclubtheft to 0>>
<<set $clothingshoptheft to 0>>
<<set $hairdresserstheft to 0>>
<</nobr>><</widget>>
<<widget "year">><<nobr>>
<<set $yeardays to 0>>
<<set $scienceproject to "none">>
<</nobr>><</widget>>
:: Widgets Orgasm [widget]
<<widget "orgasm">><<nobr>>
<<if $orgasmcount lte 1>>
<<set $stress -= 200>>
<<if $drugged gte 1>>
<<set $arousal -= 4000>><<set $drugged -= 20>>
<<else>>
<<set $arousal -= 8000>>
<</if>>
<span class="pink">You shudder from the sudden release.</span><br><br>
<<elseif $orgasmcount lte 2>>
<<set $stress -= 200>>
<<if $drugged gte 1>>
<<set $arousal -= 5000>><<set $drugged -= 20>>
<<else>>
<<set $arousal -= 9000>>
<</if>>
<span class="pink">You shudder from the sudden release.</span><br><br>
<<elseif $orgasmcount lte 3>>
<<set $stress -= 200>>
<<if $drugged gte 1>>
<<set $arousal -= 6000>><<set $drugged -= 20>>
<<else>>
<<set $arousal -= 10000>>
<</if>>
<span class="pink">You shudder from the sudden release.</span><br><br>
<<elseif $orgasmcount lte 4>>
<<set $stress -= 200>>
<<if $drugged gte 1>>
<<set $arousal -= 7000>><<set $drugged -= 20>>
<<else>>
<<set $arousal -= 10000>>
<</if>>
<span class="pink">You shudder from the sudden release.</span><br><br>
<<elseif $orgasmcount lte 5>>
<<set $stress -= 200>>
<<if $drugged gte 1>>
<<set $arousal -= 8000>><<set $drugged -= 20>>
<<else>>
<<set $arousal -= 10000>>
<</if>>
<span class="pink">You feel spent.</span><br><br>
<<elseif $orgasmcount lte 6>>
<<set $stress -= 100>>
<<if $drugged gte 1>>
<<set $arousal -= 7000>><<set $drugged -= 20>>
<<else>>
<<set $arousal -= 10000>>
<</if>>
<span class="pink">Despite feeling like you've nothing left to give, the orgasm is intense.</span><br><br>
<<elseif $orgasmcount lte 7>>
<<set $stress -= 100>>
<<if $drugged gte 1>>
<<set $arousal -= 6000>><<set $drugged -= 20>>
<<else>>
<<set $arousal -= 10000>>
<</if>>
<span class="pink">Despite feeling like you've nothing left to give, the orgasm is intense.</span><br><br>
<<elseif $orgasmcount lte 8>>
<<set $stress -= 100>>
<<if $drugged gte 1>>
<<set $arousal -= 5000>><<set $drugged -= 20>>
<<else>>
<<set $arousal -= 10000>>
<</if>>
<span class="pink">Despite feeling like you've nothing left to give, the orgasm is intense.</span><br><br>
<<elseif $orgasmcount lte 9>>
<<if $drugged gte 1>>
<<set $arousal -= 4000>><<set $drugged -= 20>>
<<else>>
<<set $arousal -= 10000>>
<</if>>
<span class="pink">Your body is tiring from the repeated climaxes.</span><br><br>
<<elseif $orgasmcount lte 10>>
<<if $drugged gte 1>>
<<set $arousal -= 3000>><<set $drugged -= 20>>
<<else>>
<<set $arousal -= 10000>>
<</if>>
<span class="pink">Your body is tiring from the repeated climaxes.</span><br><br>
<<elseif $orgasmcount lte 11>>
<<if $drugged gte 1>>
<<set $arousal -= 2000>><<set $drugged -= 20>>
<<else>>
<<set $arousal -= 10000>>
<</if>>
<span class="pink">Your body is tiring from the repeated climaxes.</span><br><br>
<<elseif $orgasmcount lte 18>>
<<if $drugged gte 1>>
<<set $arousal -= 2000>><<set $drugged -= 20>>
<<else>>
<<set $arousal -= 10000>>
<</if>>
<<set $stress += 100>><span class="pink">The repeated orgasms are causing you great strain. You don't want to cum anymore.</span><br><br>
<<elseif $orgasmcount lte 23>>
<<if $drugged gte 1>>
<<set $arousal -= 2000>><<set $drugged -= 20>>
<<else>>
<<set $arousal -= 10000>>
<</if>>
<<set $stress += 100>><<combattrauma 10>><span class="pink">Your mind and body buckle under the continued orgasms.</span><br><br>
<<else>>
<<if $drugged gte 1>>
<<set $arousal -= 2000>><<set $drugged -= 20>>
<<else>>
<<set $arousal -= 10000>>
<</if>>
<<set $stress += 100>><<combattrauma 10>><<set $pain += 5>>
<span class="red">You've had so many orgasms in such a short span of time that you no longer gain any pleasure from them. They're painful, both physically and psychologically.</span><br><br>
<</if>>
<<if $orgasmtrait gte 1>>
<<set $stress -= 100>>
<</if>>
<<set $orgasmcurrent += 1>>
<</nobr>><</widget>>
<<widget "orgasmpassage">><<nobr>>
<<set $orgasmcount += 1>><<orgasmstat>><<set $orgasmdown to 3>><<set $speechcum += 1>><<set $speechorgasmcount += 1>>
<<if $penisexist is 1 and $devstate is 1>>
<<if $orgasmcount gte 24>>
<span class="red">You are overcome by sensation and your body is tormented by another orgasm. You produce no cum, as your reserves are utterly spent.</span>
<<else>>
<<if $penisparasite is 1>>
You are overcome by sensation. You ejaculate into the parasite latched onto your penis.
<<elseif $penisuse is "othervagina">>
<<if $penisstate is "penetrated">><<penileejacstat>>
<span class="pink">You are overcome by sensation and ejaculate deep into <<his>> womb.</span><<set $purity -= 1>><<internalejac>>
<<else>>
<span class="pink">You are overcome by sensation and ejaculate on <<his>> pussy.</span>
<</if>>
<<elseif $penisuse is "otheranus">>
<<if $penisstate is "otheranus">><<penileejacstat>>
<span class="pink">You are overcome by sensation and ejaculate deep into <<his>> bowels.</span><<set $purity -= 1>><<internalejac>>
<<else>>
<span class="pink">You are overcome by sensation and ejaculate on <<his>> ass.</span>
<</if>>
<<elseif $penisuse is "othermouth">>
<<if $penisstate is "othermouth">>
<<penileejacstat>>
<span class="pink">You are overcome by sensation and ejaculate into <<his>> mouth.</span><<set $purity -= 1>><<internalejac>>
<<else>>
<span class="pink">You are overcome by sensation and ejaculate on <<his>> face.</span>
<</if>>
<<elseif $penisuse is "tentacle">>
<<if $penisstate isnot "tentacleentrance" and $penisstate isnot "tentacleimminent">><<penileejacstat>>
<span class="pink">You are overcome by sensation. The tentacle milks you of your semen.</span><<set $purity -= 1>><<internalejac>>
<<else>>
<span class="pink">You are overcome by sensation and ejaculate on the tentacle.</span>
<</if>>
<<else>>
<span class="pink">You are overcome by sensation. A surge of cum erupts from your penis.</span>
<</if>>
<<if $orgasmcount gte 18>>
<span class="pink">Exhausted, your body only manages to produce a few droplets of watery cum.</span>
<<elseif $orgasmcount gte 12>>
<span class="pink">Tired from overuse, your cum is thin and watery.</span>
<<elseif $orgasmcount gte 6>>
<span class="pink">The repeated orgasms are taking their toll, reducing the amount of cum your body manages to produce.</span>
<</if>>
<</if>>
<<else>>
<span class="pink">You are overcome by sensation and climax.</span>
<</if>>
<<if $swarmchestgrab gte 1>><span class="pink">Your convulsions launch the $swarmcreature away from your chest.</span>
<<set $swarmchestgrab to 0>>
<</if>>
<<if $swarm1 is "chest">><<set $swarm1 to "active">>
<</if>>
<<if $swarm2 is "chest">><<set $swarm2 to "active">>
<</if>>
<<if $swarm3 is "chest">><<set $swarm3 to "active">>
<</if>>
<<if $swarm4 is "chest">><<set $swarm4 to "active">>
<</if>>
<<if $swarm5 is "chest">><<set $swarm5 to "active">>
<</if>>
<<if $swarm6 is "chest">><<set $swarm6 to "active">>
<</if>>
<<if $swarm7 is "chest">><<set $swarm7 to "active">>
<</if>>
<<if $swarm8 is "chest">><<set $swarm8 to "active">>
<</if>>
<<if $swarm9 is "chest">><<set $swarm9 to "active">>
<</if>>
<<if $swarm10 is "chest">><<set $swarm10 to "active">>
<</if>>
<<orgasm>>
<</nobr>><</widget>>
<<widget "orgasmstreet">><<nobr>>
<<orgasmpassage>>
<<if $exposed gte 1>>
<<if $daystate isnot "night">>
You steady yourself as your spasms subside, feeling exposed and hoping the noise hasn't given away your hiding place.
<<else>>
You steady yourself as your spasms subside, feeling exposed and hoping the noise hasn't attracted attention.
<</if>>
<<else>>
<<if $daystate isnot "night">>
The sight and sound of a <<girl>> convulsing in climax draws attention, and as you regain control you find yourself stared at from all directions. Face red, you flee the scene.<<gtrauma>><<gstress>><<trauma 6>><<stress 12>><<fameexhibitionism 10>>
<<else>>
You steady yourself as your spasms subside, and hope the noise hasn't attracted attention.
<</if>>
<</if>>
<br><br>
<</nobr>><</widget>>
<<widget "orgasmforest">><<nobr>>
<<orgasmpassage>>
<<if $exposed gte 1>>
<<if $daystate isnot "night">>
You steady yourself against a tree as your spasms subside.
<<else>>
You steady yourself against a tree as your spasms subside.
<</if>>
<<else>>
<<if $daystate isnot "night">>
You steady yourself against a tree as your spasms subside.
<<else>>
You steady yourself against a tree as your spasms subside.
<</if>>
<</if>>
<br><br>
<</nobr>><</widget>>
<<widget "orgasmbeach">><<nobr>>
<<orgasmpassage>>
<<if $exposed gte 1>>
<<if $daystate isnot "night">>
You steady yourself as your spasms subside, feeling exposed and hoping the noise hasn't given away your hiding place.
<<else>>
You steady yourself as your spasms subside, feeling exposed on the open beach.
<</if>>
<<else>>
<<if $daystate isnot "night">>
The sight and sound of a <<girl>> convulsing in climax draws attention, and as you regain control you find yourself stared at from all across the beach. Face red, you flee the scene.<<gtrauma>><<gstress>><<trauma 6>><<stress 12>><<fameexhibitionism 10>>
<<else>>
You steady yourself as your spasms subside, feeling exposed on the open beach.
<</if>>
<</if>>
<br><br>
<</nobr>><</widget>>
<<widget "orgasmhour">><<nobr>>
<<if $purity gte 990>>
<<set $orgasmcount -= 1>>
<<elseif $purity gte 900>>
<<set $orgasmcount -= 2>>
<<elseif $purity gte 800>>
<<set $orgasmcount -= 3>>
<<elseif $purity gte 700>>
<<set $orgasmcount -= 4>>
<<elseif $purity gte 600>>
<<set $orgasmcount -= 5>>
<<elseif $purity gte 500>>
<<set $orgasmcount -= 6>>
<<elseif $purity gte 400>>
<<set $orgasmcount -= 7>>
<<elseif $purity gte 300>>
<<set $orgasmcount -= 8>>
<<elseif $purity gte 200>>
<<set $orgasmcount -= 9>>
<<elseif $purity gte 100>>
<<set $orgasmcount -= 10>>
<<else>>
<<set $orgasmcount -= 11>>
<</if>>
<</nobr>><</widget>>
:: Widgets Breasts Img [widget]
<<widget "breastsidle">><<nobr>>
<<if $upperexposed gte 2>>
<<if $breastcup is "none">>
<</if>>
<<if $breastcup is "budding">>
<img id="sexmouth" src="img/sex/doggy/idle/body/doggyidlebreaststiny.png">
<</if>>
<<if $breastcup is "AA">>
<img id="sexmouth" src="img/sex/doggy/idle/body/doggyidlebreaststiny.png">
<</if>>
<<if $breastcup is "B">>
<img id="sexmouth" src="img/sex/doggy/idle/body/doggyidlebreastssmall.png">
<</if>>
<<if $breastcup is "C">>
<img id="sexmouth" src="img/sex/doggy/idle/body/doggyidlebreastssmall.png">
<</if>>
<<if $breastcup is "D">>
<img id="sexmouth" src="img/sex/doggy/idle/body/doggyidlebreastslarge.png">
<</if>>
<<if $breastcup is "DD">>
<img id="sexmouth" src="img/sex/doggy/idle/body/doggyidlebreastslarge.png">
<</if>>
<<if $breastcup is "DDD">>
<img id="sexmouth" src="img/sex/doggy/idle/body/doggyidlebreastslarge.png">
<</if>>
<<if $breastcup is "F">>
<img id="sexmouth" src="img/sex/doggy/idle/body/doggyidlebreastshuge.png">
<</if>>
<<if $breastcup is "G">>
<img id="sexmouth" src="img/sex/doggy/idle/body/doggyidlebreastshuge.png">
<</if>>
<<if $breastcup is "H">>
<img id="sexmouth" src="img/sex/doggy/idle/body/doggyidlebreastshuge.png">
<</if>>
<<if $breastcup is "I">>
<img id="sexmouth" src="img/sex/doggy/idle/body/doggyidlebreastshuge.png">
<</if>>
<<if $breastcup is "J">>
<img id="sexmouth" src="img/sex/doggy/idle/body/doggyidlebreastshuge.png">
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "breastsactiveslow">><<nobr>>
<<if $breastcup is "none">>
<</if>>
<<if $breastcup is "budding">>
<img id="sexmouth" src="img/sex/doggy/active/body/doggyactivebreaststinyslow.gif">
<</if>>
<<if $breastcup is "AA">>
<img id="sexmouth" src="img/sex/doggy/active/body/doggyactivebreaststinyslow.gif">
<</if>>
<<if $breastcup is "B">>
<img id="sexmouth" src="img/sex/doggy/active/body/doggyactivebreastssmallslow.gif">
<</if>>
<<if $breastcup is "C">>
<img id="sexmouth" src="img/sex/doggy/active/body/doggyactivebreastssmallslow.gif">
<</if>>
<<if $breastcup is "D">>
<img id="sexmouth" src="img/sex/doggy/active/body/doggyactivebreastslargeslow.gif">
<</if>>
<<if $breastcup is "DD">>
<img id="sexmouth" src="img/sex/doggy/active/body/doggyactivebreastslargeslow.gif">
<</if>>
<<if $breastcup is "DDD">>
<img id="sexmouth" src="img/sex/doggy/active/body/doggyactivebreastslargeslow.gif">
<</if>>
<<if $breastcup is "F">>
<img id="sexmouth" src="img/sex/doggy/active/body/doggyactivebreastshugeslow.gif">
<</if>>
<<if $breastcup is "G">>
<img id="sexmouth" src="img/sex/doggy/active/body/doggyactivebreastshugeslow.gif">
<</if>>
<<if $breastcup is "H">>
<img id="sexmouth" src="img/sex/doggy/active/body/doggyactivebreastshugeslow.gif">
<</if>>
<<if $breastcup is "I">>
<img id="sexmouth" src="img/sex/doggy/active/body/doggyactivebreastshugeslow.gif">
<</if>>
<<if $breastcup is "J">>
<img id="sexmouth" src="img/sex/doggy/active/body/doggyactivebreastshugeslow.gif">
<</if>>
<</nobr>><</widget>>
<<widget "breastsactivemid">><<nobr>>
<<if $breastcup is "none">>
<</if>>
<<if $breastcup is "budding">>
<img id="sexmouth" src="img/sex/doggy/active/body/doggyactivebreaststinymid.gif">
<</if>>
<<if $breastcup is "AA">>
<img id="sexmouth" src="img/sex/doggy/active/body/doggyactivebreaststinymid.gif">
<</if>>
<<if $breastcup is "B">>
<img id="sexmouth" src="img/sex/doggy/active/body/doggyactivebreastssmallmid.gif">
<</if>>
<<if $breastcup is "C">>
<img id="sexmouth" src="img/sex/doggy/active/body/doggyactivebreastssmallmid.gif">
<</if>>
<<if $breastcup is "D">>
<img id="sexmouth" src="img/sex/doggy/active/body/doggyactivebreastslargemid.gif">
<</if>>
<<if $breastcup is "DD">>
<img id="sexmouth" src="img/sex/doggy/active/body/doggyactivebreastslargemid.gif">
<</if>>
<<if $breastcup is "DDD">>
<img id="sexmouth" src="img/sex/doggy/active/body/doggyactivebreastslargemid.gif">
<</if>>
<<if $breastcup is "F">>
<img id="sexmouth" src="img/sex/doggy/active/body/doggyactivebreastshugemid.gif">
<</if>>
<<if $breastcup is "G">>
<img id="sexmouth" src="img/sex/doggy/active/body/doggyactivebreastshugemid.gif">
<</if>>
<<if $breastcup is "H">>
<img id="sexmouth" src="img/sex/doggy/active/body/doggyactivebreastshugemid.gif">
<</if>>
<<if $breastcup is "I">>
<img id="sexmouth" src="img/sex/doggy/active/body/doggyactivebreastshugemid.gif">
<</if>>
<<if $breastcup is "J">>
<img id="sexmouth" src="img/sex/doggy/active/body/doggyactivebreastshugemid.gif">
<</if>>
<</nobr>><</widget>>
<<widget "breastsactivefast">><<nobr>>
<<if $breastcup is "none">>
<</if>>
<<if $breastcup is "budding">>
<img id="sexmouth" src="img/sex/doggy/active/body/doggyactivebreaststinyfast.gif">
<</if>>
<<if $breastcup is "AA">>
<img id="sexmouth" src="img/sex/doggy/active/body/doggyactivebreaststinyfast.gif">
<</if>>
<<if $breastcup is "B">>
<img id="sexmouth" src="img/sex/doggy/active/body/doggyactivebreastssmallfast.gif">
<</if>>
<<if $breastcup is "C">>
<img id="sexmouth" src="img/sex/doggy/active/body/doggyactivebreastssmallfast.gif">
<</if>>
<<if $breastcup is "D">>
<img id="sexmouth" src="img/sex/doggy/active/body/doggyactivebreastslargefast.gif">
<</if>>
<<if $breastcup is "DD">>
<img id="sexmouth" src="img/sex/doggy/active/body/doggyactivebreastslargefast.gif">
<</if>>
<<if $breastcup is "DDD">>
<img id="sexmouth" src="img/sex/doggy/active/body/doggyactivebreastslargefast.gif">
<</if>>
<<if $breastcup is "F">>
<img id="sexmouth" src="img/sex/doggy/active/body/doggyactivebreastshugefast.gif">
<</if>>
<<if $breastcup is "G">>
<img id="sexmouth" src="img/sex/doggy/active/body/doggyactivebreastshugefast.gif">
<</if>>
<<if $breastcup is "H">>
<img id="sexmouth" src="img/sex/doggy/active/body/doggyactivebreastshugefast.gif">
<</if>>
<<if $breastcup is "I">>
<img id="sexmouth" src="img/sex/doggy/active/body/doggyactivebreastshugefast.gif">
<</if>>
<<if $breastcup is "J">>
<img id="sexmouth" src="img/sex/doggy/active/body/doggyactivebreastshugefast.gif">
<</if>>
<</nobr>><</widget>>
<<widget "breastsactivevfast">><<nobr>>
<<if $breastcup is "none">>
<</if>>
<<if $breastcup is "budding">>
<img id="sexmouth" src="img/sex/doggy/active/body/doggyactivebreaststinyvfast.gif">
<</if>>
<<if $breastcup is "AA">>
<img id="sexmouth" src="img/sex/doggy/active/body/doggyactivebreaststinyvfast.gif">
<</if>>
<<if $breastcup is "B">>
<img id="sexmouth" src="img/sex/doggy/active/body/doggyactivebreastssmallvfast.gif">
<</if>>
<<if $breastcup is "C">>
<img id="sexmouth" src="img/sex/doggy/active/body/doggyactivebreastssmallvfast.gif">
<</if>>
<<if $breastcup is "D">>
<img id="sexmouth" src="img/sex/doggy/active/body/doggyactivebreastslargevfast.gif">
<</if>>
<<if $breastcup is "DD">>
<img id="sexmouth" src="img/sex/doggy/active/body/doggyactivebreastslargevfast.gif">
<</if>>
<<if $breastcup is "DDD">>
<img id="sexmouth" src="img/sex/doggy/active/body/doggyactivebreastslargevfast.gif">
<</if>>
<<if $breastcup is "F">>
<img id="sexmouth" src="img/sex/doggy/active/body/doggyactivebreastshugevfast.gif">
<</if>>
<<if $breastcup is "G">>
<img id="sexmouth" src="img/sex/doggy/active/body/doggyactivebreastshugevfast.gif">
<</if>>
<<if $breastcup is "H">>
<img id="sexmouth" src="img/sex/doggy/active/body/doggyactivebreastshugevfast.gif">
<</if>>
<<if $breastcup is "I">>
<img id="sexmouth" src="img/sex/doggy/active/body/doggyactivebreastshugevfast.gif">
<</if>>
<<if $breastcup is "J">>
<img id="sexmouth" src="img/sex/doggy/active/body/doggyactivebreastshugevfast.gif">
<</if>>
<</nobr>><</widget>>
:: Widgets Actions Text [widget]
<<widget "actionsmouththighrub">><<nobr>>
<<if $enemytype is "beast">>
<<if $arousal gte 8000>>
<<if $enemyanger gte (($enemyangermax / 5) * 2)>>
You <<thightext>> press your thigh into the $beasttype's mouth, keeping it at bay. It bites down a little harder than you would like, you hope it doesn't consider you food.
<<else>>
You <<thightext>> press your thigh into the $beasttype's mouth, keeping it at bay.
<</if>>
<<else>>
<<if $enemyanger gte (($enemyangermax / 5) * 2)>>
You <<thightext>> press your thigh into the $beasttype's mouth, keeping it at bay. It bites down a little harder than you would like, you hope it doesn't consider you food.
<<else>>
You <<thightext>> press your thigh into the $beasttype's mouth, keeping it at bay.
<</if>>
<</if>>
<<else>>
<<if $arousal gte 8000>>
<<if $pain gte 40>>
You <<thightext>> keep your shaking thigh pressed against <<their>> mouth.
<<else>>
You <<thightext>> keep your trembling thigh pressed against <<their>> mouth.
<</if>>
<<else>>
<<if $pain gte 40>>
You <<thightext>> keep your quivering thigh pressed against <<their>> mouth.
<<else>>
You <<thightext>> keep your thigh pressed against <<their>> mouth.
<</if>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionsothermouthpenistease">><<nobr>>
<<if $enemytype is "beast">>
<<if $arousal gte 8000>>
<<if $pain gte 40>>
You <<peniletext>> and carefully rub the $beasttype's lips with your <<penisstop>>
<<else>>
You <<peniletext>> rub the $beasttype's lips with your <<penisstop>>
<</if>>
<<else>>
<<if $pain gte 40>>
You <<peniletext>> and carefully prod the $beasttype's lips with your <<penisstop>>
<<else>>
You <<peniletext>> prod the $beasttype's lips with your <<penisstop>>
<</if>>
<</if>>
<<else>>
<<if $arousal gte 8000>>
<<if $pain gte 40>>
You <<peniletext>> rub your <<penis>> against <<their>> lips.
<<else>>
You <<peniletext>> slap your <<penis>> against <<their>> lips.
<</if>>
<<else>>
<<if $pain gte 40>>
You <<peniletext>> rub your <<penis>> against <<their>> cheek.
<<else>>
You <<peniletext>> slap your <<penis>> against <<their>> cheek.
<</if>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionsothermouthpenisrub">><<nobr>>
<<if $enemytype is "beast">>
<<if $arousal gte 8000>>
<<if $pain gte 40>>
You <<peniletext>> and carefully rub the $beasttype's tongue with your <<penisstop>>
<<else>>
You <<peniletext>> rub the $beasttype's tongue with your <<penisstop>>
<</if>>
<<else>>
<<if $pain gte 40>>
You <<peniletext>> and carefully prod the $beasttype's tongue with your <<penisstop>>
<<else>>
You <<peniletext>> prod the $beasttype's tongue with your <<penisstop>>
<</if>>
<</if>>
<<else>>
<<if $arousal gte 8000>>
<<if $pain gte 40>>
You <<peniletext>> rub the tip of your <<penis>> between <<their>> lips.
<<else>>
You <<peniletext>> caress <<their>> lips with your <<penisstop>>
<</if>>
<<else>>
<<if $pain gte 40>>
You <<peniletext>> circle <<their>> lips with the tip of your <<penisstop>>
<<else>>
You <<peniletext>> prod <<their>> lips with the tip of your <<penisstop>>
<</if>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionsothermouthpenisthrust">><<nobr>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<<if $arousal gte 8000>>
Your <<penis>> is ruthlessly fucked by <<their>> mouth. Driven by instinct, you <<peniletext>> push back as you approach your peak.
<<elseif $arousal gte 4000>>
Your <<penis>> is ruthlessly fucked by <<their>> mouth. You <<peniletext>> push back against the movements.
<<else>>
Your <<penis>> is ruthlessly fucked by <<their>> mouth. You <<peniletext>> push back, trying to reduce your discomfort.
<</if>>
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<<if $arousal gte 8000>>
Your <<penis>> is hungrily enveloped by <<their>> mouth. Driven by instinct, you <<peniletext>> push back as you approach your peak.
<<elseif $arousal gte 4000>>
Your <<penis>> is hungrily enveloped by <<their>> mouth. You <<peniletext>> push back against the movements.
<<else>>
Your <<penis>> is hungrily enveloped by <<their>> mouth. You <<peniletext>> push back, trying to reduce your discomfort.
<</if>>
<<else>>
<<if $arousal gte 8000>>
Your <<penis>> is rhythmically engulfed and regurgitated by <<their>> mouth. Driven by instinct, you <<peniletext>> push back as you approach your peak.
<<elseif $arousal gte 4000>>
Your <<penis>> is rhythmically engulfed and regurgitated by <<their>> mouth. You <<peniletext>> push back against the movements.
<<else>>
Your <<penis>> is rhythmically engulfed and regurgitated by <<their>> mouth. You <<peniletext>> push back, trying to reduce your discomfort.
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionsothermouthpenisescape">><<nobr>>
<<if $enemytype is "beast">>
<<if $enemyanger lte 20>>
<span class="blue">You shift your pelvis, moving your <<penis>> away from the $beasttype's mouth before it can envelop you.</span> It doesn't give up however.
<<elseif $enemyanger lte 100>>
<span class="blue">You shift your pelvis, moving your <<penis>> away from the beast's incessant probing before it can envelop you.</span> It snarls in frustration.
<<else>>
<span class="blue">You shift your pelvis, moving your <<penis>> away from the beast's savage probing before it can envelop you.</span>
<</if>>
<<else>>
<<if $pain lte 20>>
<span class="blue">You shift your pelvis, moving your <<penis>> away from <<their>> mouth.</span>
<<elseif $pain lte 60>>
<span class="blue">You shift your pelvis, moving your <<penis>> away from <<their>> mouth.</span>
<<else>>
<span class="blue">You shift your pelvis in desperation, moving your <<penis>> away from <<their>> mouth.</span>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionsothermouthvaginatease">><<nobr>>
<<if $enemytype is "beast">>
<<if $arousal gte 8000>>
<<if $pain gte 40>>
You <<vaginaltext>> and carefully rub the $beasttype's lips with your <<pussystop>>
<<else>>
You <<vaginaltext>> rub the $beasttype's lips with your <<pussystop>>
<</if>>
<<else>>
<<if $pain gte 40>>
You <<vaginaltext>> and carefully kiss the $beasttype's lips with your <<pussystop>>
<<else>>
You <<vaginaltext>> kiss the $beasttype's lips with your <<pussystop>>
<</if>>
<</if>>
<<else>>
<<if $arousal gte 8000>>
<<if $pain gte 40>>
You <<vaginaltext>> rub your <<pussy>> against <<their>> lips.
<<else>>
You <<vaginaltext>> smooch <<their>> lips with your <<pussystop>>
<</if>>
<<else>>
<<if $pain gte 40>>
You <<vaginaltext>> rub your <<pussy>> against <<their>> cheek.
<<else>>
You <<vaginaltext>> kiss <<their>> cheek with your <<pussystop>>
<</if>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionsothermouthvaginarub">><<nobr>>
<<if $enemytype is "beast">>
<<if $arousal gte 8000>>
<<if $pain gte 40>>
You <<vaginaltext>> and carefully rub the $beasttype's tongue with your <<pussystop>>
<<else>>
You <<vaginaltext>> rub the $beasttype's tongue with your <<pussystop>>
<</if>>
<<else>>
<<if $pain gte 40>>
You <<vaginaltext>> and carefully kiss the $beasttype's tongue with your <<pussystop>>
<<else>>
You <<vaginaltext>> kiss the $beasttype's tongue with your <<pussystop>>
<</if>>
<</if>>
<<else>>
<<if $arousal gte 8000>>
<<if $pain gte 40>>
You <<vaginaltext>> your <<pussy>> against <<their>> tongue.
<<else>>
You <<vaginaltext>> caress <<their>> tongue with your <<pussystop>>
<</if>>
<<else>>
<<if $pain gte 40>>
You <<vaginaltext>> kiss <<their>> tongue with your <<pussystop>>
<<else>>
You <<vaginaltext>> rub <<their>> lips with your <<pussystop>>
<</if>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionsothermouthvaginathrust">><<nobr>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<<if $arousal gte 8000>>
Your <<pussy>> is ruthlessly fucked by <<their>> tongue as <<their>> lips knead your labia. Driven by instinct, you <<vaginaltext>> push back as you approach your peak.
<<elseif $arousal gte 4000>>
Your <<pussy>> is ruthlessly fucked by <<their>> tongue as <<their>> lips knead your labia. You <<vaginaltext>> push back against the movements.
<<else>>
Your <<pussy>> is ruthlessly fucked by <<their>> tongue as <<their>> lips knead your labia. You <<vaginaltext>> push back, trying to reduce your discomfort.
<</if>>
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<<if $arousal gte 8000>>
Your <<pussy>> is hungrily penetrated by <<their>> tongue as <<their>> lips knead your labia. Driven by instinct, you <<vaginaltext>> push back as you approach your peak.
<<elseif $arousal gte 4000>>
Your <<pussy>> is hungrily penetrated by <<their>> tongue as <<their>> lips knead your labia. You <<vaginaltext>> push back against the movements.
<<else>>
Your <<pussy>> is hungrily penetrated by <<their>> tongue as <<their>> lips knead your labia. You <<vaginaltext>> push back, trying to reduce your discomfort.
<</if>>
<<else>>
<<if $arousal gte 8000>>
Your <<pussy>> is rhythmically invaded by <<their>> tongue as <<their>> lips knead your labia. Driven by instinct, you <<vaginaltext>> push back as you approach your peak.
<<elseif $arousal gte 4000>>
Your <<pussy>> is rhythmically invaded by <<their>> tongue as <<their>> lips knead your labia. You <<vaginaltext>> push back against the movements.
<<else>>
Your <<pussy>> is rhythmically invaded by <<their>> tongue as <<their>> lips knead your labia. You <<vaginaltext>> push back, trying to reduce your discomfort.
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionsothermouthvaginaescape">><<nobr>>
<<if $enemytype is "beast">>
<<if $enemyanger lte 20>>
<span class="blue">You shift your pelvis, moving your <<pussy>> away from the $beasttype's mouth before it can penetrate you.</span> It doesn't give up however.
<<elseif $enemyanger lte 100>>
<span class="blue">You shift your pelvis, moving your <<pussy>> away from the beast's incessant probing before it can penetrate you.</span> It snarls in frustration.
<<else>>
<span class="blue">You shift your pelvis, moving your <<pussy>> away from the beast's savage probing before it can penetrate you.</span>
<</if>>
<<else>>
<<if $pain lte 20>>
<span class="blue">You shift your pelvis, moving your <<pussy>> away from <<their>> mouth.</span>
<<elseif $pain lte 60>>
<span class="blue">You shift your pelvis, moving your <<pussy>> away from <<their>> mouth.</span>
<<else>>
<span class="blue">You shift your pelvis in desperation, moving your <<pussy>> away from <<their>> mouth.</span>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionsmouthbottomrub">><<nobr>>
<<if $enemytype is "beast">>
<<if $arousal gte 8000>>
<<if $enemyanger gte (($enemyangermax / 5) * 2)>>
You <<bottomtext>> press your <<bottom>> into the $beasttype's mouth, keeping it at bay. It bites down a little harder than you would like. You hope it doesn't consider you food.
<<else>>
You <<bottomtext>> press your <<bottom>> into the $beasttype's mouth, keeping it at bay.
<</if>>
<<else>>
<<if $enemyanger gte (($enemyangermax / 5) * 2)>>
You <<bottomtext>> press your <<bottom>> into the $beasttype's mouth, keeping it at bay. It bites down a little harder than you would like. You hope it doesn't consider you food.
<<else>>
You <<bottomtext>> press your <<bottom>> into the $beasttype's mouth, keeping it at bay.
<</if>>
<</if>>
<<else>>
<<if $arousal gte 8000>>
<<if $pain gte 40>>
You <<bottomtext>> keep your shaking <<bottom>> pressed against <<their>> mouth.
<<else>>
You <<bottomtext>> keep your trembling <<bottom>> pressed against <<their>> mouth.
<</if>>
<<else>>
<<if $pain gte 40>>
You <<bottomtext>> keep your quivering <<bottom>> pressed against <<their>> mouth.
<<else>>
You <<bottomtext>> keep your <<bottom>> pressed against <<their>> mouth.
<</if>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionsothermouthanustease">><<nobr>>
<<if $enemytype is "beast">>
<<if $arousal gte 8000>>
<<if $pain gte 40>>
You <<analtext>> and carefully rub the $beasttype's lips with your <<bottomstop>>
<<else>>
You <<analtext>> rub the $beasttype's lips with your <<bottomstop>>
<</if>>
<<else>>
<<if $pain gte 40>>
You <<analtext>> and carefully rub the $beasttype's face with your <<bottomstop>>
<<else>>
You <<analtext>> rub the $beasttype's face with your <<bottomstop>>
<</if>>
<</if>>
<<else>>
<<if $arousal gte 8000>>
<<if $pain gte 40>>
You <<analtext>> rub your <<bottom>> against <<their>> lips.
<<else>>
You <<analtext>> rub <<their>> face with your <<bottomstop>>
<</if>>
<<else>>
<<if $pain gte 40>>
You <<analtext>> rub your <<bottom>> against <<their>> cheek.
<<else>>
You <<analtext>> rub <<their>> cheek with your <<bottomstop>>
<</if>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionsothermouthanusrub">><<nobr>>
<<if $enemytype is "beast">>
<<if $arousal gte 8000>>
<<if $pain gte 40>>
You <<analtext>> and carefully rub your anus against the $beasttype's tongue.
<<else>>
You <<analtext>> rub your anus against the $beasttype's tongue.
<</if>>
<<else>>
<<if $pain gte 40>>
You <<analtext>> and carefully rub your <<bottom>> against the $beasttype's tongue.
<<else>>
You <<analtext>> rub your <<bottom>> against the $beasttype's tongue.
<</if>>
<</if>>
<<else>>
<<if $arousal gte 8000>>
<<if $pain gte 40>>
You <<analtext>> your anus against <<their>> tongue.
<<else>>
You <<analtext>> caress <<their>> tongue with your anus.
<</if>>
<<else>>
<<if $pain gte 40>>
You <<analtext>> rub <<their>> tongue with your <<bottomstop>>
<<else>>
You <<analtext>> rub <<their>> lips with your <<bottomstop>>
<</if>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionsothermouthanusthrust">><<nobr>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<<if $arousal gte 8000>>
Your <<bottom>> is ruthlessly fucked by <<their>> tongue as <<their>> lips knead your anus. Driven by instinct, you <<analtext>> push back as you approach your peak.
<<elseif $arousal gte 4000>>
Your <<bottom>> is ruthlessly fucked by <<their>> tongue as <<their>> lips knead your anus. You <<analtext>> push back against the movements.
<<else>>
Your <<bottom>> is ruthlessly fucked by <<their>> tongue as <<their>> lips knead your anus. You <<analtext>> push back, trying to reduce your discomfort.
<</if>>
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<<if $arousal gte 8000>>
Your <<bottom>> is hungrily penetrated by <<their>> tongue as <<their>> lips knead your anus. Driven by instinct, you <<analtext>> push back as you approach your peak.
<<elseif $arousal gte 4000>>
Your <<bottom>> is hungrily penetrated by <<their>> tongue as <<their>> lips knead your anus. You <<analtext>> push back against the movements.
<<else>>
Your <<bottom>> is hungrily penetrated by <<their>> tongue as <<their>> lips knead your anus. You <<analtext>> push back, trying to reduce your discomfort.
<</if>>
<<else>>
<<if $arousal gte 8000>>
Your <<bottom>> is rhythmically invaded by <<their>> tongue as <<their>> lips knead your anus. Driven by instinct, you <<analtext>> push back as you approach your peak.
<<elseif $arousal gte 4000>>
Your <<bottom>> is rhythmically invaded by <<their>> tongue as <<their>> lips knead your anus. You <<analtext>> push back against the movements.
<<else>>
Your <<bottom>> is rhythmically invaded by <<their>> tongue as <<their>> lips knead your anus. You <<analtext>> push back, trying to reduce your discomfort.
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionsothermouthanusescape">><<nobr>>
<<if $enemytype is "beast">>
<<if $enemyanger lte 20>>
<span class="blue">You shift your pelvis, moving your <<bottom>> away from the $beasttype's mouth before it can penetrate you.</span> It doesn't give up however.
<<elseif $enemyanger lte 100>>
<span class="blue">You shift your pelvis, moving your <<bottom>> away from the beast's incessant probing before it can penetrate you.</span> It snarls in frustration.
<<else>>
<span class="blue">You shift your pelvis, moving your <<bottom>> away from the beast's savage probing before it can penetrate you.</span>
<</if>>
<<else>>
<<if $pain lte 20>>
<span class="blue">You shift your pelvis, moving your <<bottom>> away from <<their>> mouth.</span>
<<elseif $pain lte 60>>
<span class="blue">You shift your pelvis, moving your <<bottom>> away from <<their>> mouth.</span>
<<else>>
<span class="blue">You shift your pelvis in desperation, moving your <<bottom>> away from <<their>> mouth.</span>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionspenisstroke">><<nobr>>
<<if $enemytype is "beast">>
You gingerly caress the beast's penis.
<<else>>
<<if $consensual is 1>>
<<if $arousal lte 6000>>
You reach for <<someones>> penis and gently caress its length.
<<else>>
You eagerly reach for <<someones>> penis and caress its length.
<</if>>
<<else>>
You gingerly rub <<someones>> penis.
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionsstroke">><<nobr>>
<<if $enemytype is "beast">>
You pat the $beasttype on the head.
<<else>>
<<if $consensual is 1>>
<<if $arousal lte 6000>>
You gently stroke <<someones>> skin.
<<else>>
You passionately caress <<someones>> skin.
<</if>>
<<else>>
You timidly stroke <<someones>> skin.
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionshit">><<nobr>>
<<if $enemytype is "beast">>
<<if $pain lte 20>>
You smack the $beasttype with your hand.
<<elseif $pain lte 60>>
You fight through pain and smack the $beasttype with your hand.
<<else>>
Pained and terrified, you flail at the $beasttype.
<</if>>
<<else>>
<<if $pain lte 20>>
You strike <<him>> with your hand.
<<elseif $pain lte 60>>
You fight through the pain and strike at <<someone>> with your hand.
<<else>>
Pained and terrified, you flail in self-defence.
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionsclitstroke">><<nobr>>
<<if $consensual is 1>>
<<if $arousal lte 6000>>
You <<handtext>> stroke <<their>> clitoris between your fingers.
<<else>>
Eager, you <<handtext>> fondle <<their>> clitoris between your fingers.
<</if>>
<<else>>
Hoping to mollify, you <<handtext>> stroke <<their>> clitoris between your fingers.
<</if>>
<</nobr>><</widget>>
<<widget "actionskick">><<nobr>>
<<if $enemytype is "beast">>
<<if $pain lte 20>>
You kick the $beasttype.
<<elseif $pain lte 60>>
You try to kick the $beasttype away from you.
<<else>>
You desperately try to kick the $beasttype away.
<</if>>
<<else>>
<<if $pain lte 20>>
Defiant, you lash out with your feet.
<<elseif $pain lte 60>>
Though hurt, you lash out with your feet.
<<else>>
You lash out in desperation.
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionsfeetrub">><<nobr>>
<<if $enemytype is "beast">>
You fondle <<their>> penis with your toes.
<<else>>
<<if $consensual is 1>>
<<if $arousal lte 6000>>
You fondle <<someones>> penis with your toes.
<<else>>
You eagerly stroke <<someones>> penis with your toes.
<</if>>
<<else>>
You stroke <<someones>> penis with your toes.
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionsgrabrub">><<nobr>>
<<if $enemytype is "beast">>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
You <<feettext>> hold <<his>> penis between your feet as <<he>> furiously humps against them.
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
You <<feettext>> hold the penis between your feet as <<he>> humps against them.
<<else>>
You <<feettext>> hold and rub the penis between your feet.
<</if>>
<<else>>
<<if $consensual is 1>>
<<if $arousal lte 6000>>
You keep <<their>> penis held firmly between your feet as you <<feettext>> stroke and fondle the glans with your toes.
<<else>>
You <<feettext>> hold and rub <<their>> penis between your feet.
<</if>>
<<else>>
You <<feettext>> occupy <<their>> penis with your feet, rubbing the glans between your toes.
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionsfeetpussy">><<nobr>>
<<if $consensual is 1>>
<<if $arousal lte 6000>>
You <<feettext>> fondle <<their>> vulva with your toes.
<<else>>
You <<feettext>> stroke <<their>> vulva with your toes.
<</if>>
<<else>>
You <<feettext>> press your feet against <<their>> pelvis and fondle <<their>> pussy with your toes.
<</if>>
<</nobr>><</widget>>
<<widget "actionskiss">><<nobr>>
<<if $enemytype is "beast">>
You kiss the $beasttype on the head.
<<else>>
<<if $consensual is 1>>
<<if $arousal lte 6000>>
You flutter your lips against <<someones>> skin.
<<else>>
You kiss <<someones>> skin, tongue first.
<</if>>
<<else>>
You press your lips against <<someones>> skin.
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionsplead">><<nobr>>
<<if $enemytype is "beast">>
<<if $vaginastate is "imminent">>
<<if $vaginalvirginity is 1>>
<<if $awarelevel gte 1>>
You plead. "No! I don't want to lose my virginity to a $beasttype!"
<<else>>
You plead. "Why are you poking me there? Stop!"
<</if>>
<<else>>
You plead. "No, don't put it in!"
<</if>>
<<elseif $penisstate is "imminent">>
<<if $penilevirginity is 1>>
<<if $awarelevel gte 1>>
You plead. "No! I don't want to lose my virginity to a $beasttype!"
<<else>>
You plead. "Stop pushing my private place like that, you're making me feel strange."
<</if>>
<<else>>
You plead. "Please don't put it in!"
<</if>>
<<elseif $penisstate is "otheranusimminent">>
<<if $penilevirginity is 1>>
<<if $awarelevel gte 1>>
You plead. "No! I don't want to lose my virginity to a $beasttype!"
<<else>>
You plead. "Stop pushing my private place like that, you're making me feel strange."
<</if>>
<<else>>
You plead. "Please don't put it in!"
<</if>>
<<elseif $anusstate is "imminent">>
<<if $analvirginity is 1>>
<<if $awarelevel gte 1>>
You plead. "Why are you poking me there? What do you want?"
<<else>>
You plead. "Don't poke me there, it's dirty!"
<</if>>
<<else>>
You plead. "No, not there! I don't want it!"
<</if>>
<<elseif $vaginastate is "penetrated">>
<<if $arousal lte 2000>>
You plead. "Take it out, take it out!"
<<elseif $arousal lte 8000>>
You plead. "Please, just take it out!"
<<else>>
You plead. "P-please... s-someone help..."
<</if>>
<<elseif $penisstate is "penetrated">>
<<if $arousal lte 2000>>
You plead. "Take it out, take it out!"
<<elseif $arousal lte 8000>>
You plead. "Please, just take it out!"
<<else>>
You plead. "P-please... s-someone help..."
<</if>>
<<elseif $penisstate is "otheranus">>
<<if $arousal lte 2000>>
You plead. "Take it out, take it out!"
<<elseif $arousal lte 8000>>
You plead. "Please, just take it out!"
<<else>>
You plead. "P-please... s-someone help..."
<</if>>
<<elseif $anusstate is "penetrated">>
<<if $arousal lte 2000>>
You plead. "Take it out, take it out!"
<<elseif $arousal lte 8000>>
You plead. "Please, just take it out!"
<<else>>
You plead. "P-please... s-someone help..."
<</if>>
<<elseif $exposed gte 2>>
<<if $rng lte 20>>
You plead. "W-why are you looking at me like that?"
<<elseif $rng lte 40>>
You plead. "That's not for you!"
<<elseif $rng lte 60>>
You plead. "D-don't look."
<<elseif $rng lte 80>>
You plead. "No, don't look at me!"
<<else>>
You plead. "Please be a good $beasttype, you're scaring me."
<</if>>
<<else>>
<<if $awarelevel gte 1>>
<<if $pain lte 20>>
You plead. "You're a good $beasttype right? You'll let me go?"
<<elseif $pain lte 60>>
You weep and plead. "Why are you hurting me? I'm not a threat!"
<<else>>
You cry and plead. "It hurts! Why are you doing this? Let me go!"
<</if>>
<<else>>
<<if $pain lte 20>>
<<if $rng lte 35>>
You plead. "You're a good $beasttype right? You'll let me go?"
<<elseif $rng lte 70>>
You plead. "What are you doing? I haven't been mean to you!"
<<else>>
You plead. "I don't like this, leave me alone!"
<</if>>
<<elseif $pain lte 60>>
You weep and plead. "You're hurting me!"
<<else>>
You cry and plead. "P-please stop hurting me!"
<</if>>
<</if>>
<</if>>
<<else>>
<<if $vaginastate is "imminent">>
<<if $vaginalvirginity is 1>>
<<if $awarelevel gte 1>>
You plead. "Please don't put it in, I'm a virgin!"
<<else>>
You plead. "Please stop poking me there, that's my private place!"
<</if>>
<<else>>
You plead. "Please don't put it in!"
<</if>>
<<elseif $penisstate is "imminent">>
<<if $penilevirginity is 1>>
<<if $awarelevel gte 1>>
You plead. "Please don't put it in, I'm a virgin!"
<<else>>
You plead. "Stop pushing my private place like that, you're making me feel strange."
<</if>>
<<else>>
You plead. "Please don't put it in!"
<</if>>
<<elseif $penisstate is "otheranusimminent">>
<<if $penilevirginity is 1>>
<<if $awarelevel gte 1>>
You plead. "Please don't put it in, I'm a virgin!"
<<else>>
You plead. "Stop pushing my private place like that, you're making me feel strange."
<</if>>
<<else>>
You plead. "Please don't put it in!"
<</if>>
<<elseif $anusstate is "imminent">>
<<if $analvirginity is 1>>
<<if $awarelevel gte 1>>
You plead. "Why are you poking me there? Please stop."
<<else>>
You plead. "Don't poke me there, it's dirty!"
<</if>>
<<else>>
You plead. "No, not there! I don't want it!"
<</if>>
<<elseif $vaginastate is "penetrated">>
<<if $arousal lte 2000>>
You plead. "Take it out, take it out!"
<<elseif $arousal lte 8000>>
You plead. "Please, I-I'll do what you ask, just take it out!"
<<else>>
You plead. "I c-can't... h-help it. P-please stop."
<</if>>
<<elseif $penisstate is "penetrated">>
<<if $arousal lte 2000>>
You plead. "Take it out, take it out!"
<<elseif $arousal lte 8000>>
You plead. "Please, I-I'll do what you ask, just take it out!"
<<else>>
You plead. "I c-can't... h-help it. P-please stop."
<</if>>
<<elseif $penisstate is "otheranus">>
<<if $arousal lte 2000>>
You plead. "Take it out, take it out!"
<<elseif $arousal lte 8000>>
You plead. "Please, I-I'll do what you ask, just take it out!"
<<else>>
You plead. "I c-can't... h-help it. P-please stop."
<</if>>
<<elseif $anusstate is "penetrated">>
<<if $arousal lte 2000>>
You plead. "Take it out, take it out!"
<<elseif $arousal lte 8000>>
You plead. "Please, I-I'll do what you ask, just take it out!"
<<else>>
You plead. "I c-can't... h-help it. P-please stop."
<</if>>
<<elseif $exposed gte 2 and $rng gte 51>>
<<set $rng to random(1, 100)>>
<<if $rng lte 20>>
You plead. "That's my private place! Don't look!"
<<elseif $rng lte 40>>
You plead. "Please don't look at me like that, it's scary."
<<elseif $rng lte 60>>
You plead. "I don't like being exposed like this, please stop looking."
<<elseif $rng lte 80>>
You plead. "No, don't look at me!"
<<else>>
You plead. "Please don't stare at me."
<</if>>
<<else>>
<<if $awarelevel gte 1>>
<<if $pain lte 20>>
You plead. "Please, just let me go."
<<elseif $pain lte 60>>
You weep and plead. "You're hurting me, please stop!"
<<else>>
You cry and plead. "It hurts! Why are you doing this? Let me go!"
<</if>>
<<else>>
<<if $pain lte 20>>
<<if $rng lte 35>>
You plead. "Please stop touching me, you're making me feel all funny."
<<elseif $rng lte 70>>
You plead. "Stop, I promise I haven't done anything wrong!"
<<else>>
You plead. "You're making me feel strange. Please stop."
<</if>>
<<elseif $pain lte 60>>
You weep and plead. "Please no, you're hurting me!"
<<else>>
You cry and plead. "P-please stop hurting me!"
<</if>>
<</if>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionsmoan">><<nobr>>
<<if $enemytype is "beast">>
<<if $vaginastate is "imminent">>
<<if $vaginalvirginity is 1>>
<<if $awarelevel gte 1>>
You moan. "You want to breed with me? But it's my first time."
<<else>>
You giggle. "Why are you poking my cunny? Silly $beasttype!"
<</if>>
<<else>>
You moan. "You want to put it in? Be gentle with me."
<</if>>
<<elseif $penisstate is "imminent">>
<<if $penilevirginity is 1>>
<<if $awarelevel gte 1>>
You moan. "You want to breed with me? But it's my first time."
<<else>>
You giggle. "Why are you poking my willy? Silly $beasttype!"
<</if>>
<<else>>
You moan. "You want to put it in? Be gentle with me."
<</if>>
<<elseif $penisstate is "otheranusimminent">>
<<if $penilevirginity is 1>>
<<if $awarelevel gte 1>>
You moan. "You want to breed with me? But it's my first time."
<<else>>
You giggle. "Why are you poking my willy? Silly $beasttype!"
<</if>>
<<else>>
You moan. "You want to put it in? Be gentle with me."
<</if>>
<<elseif $anusstate is "imminent">>
<<if $analvirginity is 1>>
<<if $awarelevel gte 1>>
You moan. "You want to breed with me? Please be gentle, that hole hasn't been used before."
<<else>>
You giggle. "Why are you poking my bottom? Silly $beasttype!"
<</if>>
<<else>>
You moan. "You want to put it in? Be gentle with me."
<</if>>
<<elseif $vaginastate is "penetrated">>
<<if $arousal lte 2000>>
You moan. "A $beasttype's cock is inside me, mating with me."
<<elseif $arousal lte 8000>>
You moan. "Good $beasttype. B-breed me with your $beasttype cock."
<<else>>
You moan. "I-I'm gonna cum, from a $beasttype f-fucking my pussy."
<</if>>
<<elseif $penisstate is "penetrated">>
<<if $arousal lte 2000>>
You moan. "A $beasttype is swallowing my cock, mating with me."
<<elseif $arousal lte 8000>>
You moan. "Good $beasttype. I'll fill you with my s-seed."
<<else>>
You moan. "I-I'm gonna cum... from a $beasttype mating with me."
<</if>>
<<elseif $penisstate is "penetrated">>
<<if $arousal lte 2000>>
You moan. "A $beasttype is swallowing my cock, mating with me."
<<elseif $arousal lte 8000>>
You moan. "Good $beasttype. I'll fill you with my s-seed."
<<else>>
You moan. "I-I'm gonna cum... from a $beasttype mating with me."
<</if>>
<<elseif $anusstate is "penetrated">>
<<if $arousal lte 2000>>
You moan. "A $beasttype's cock is inside my ass, mating with me."
<<elseif $arousal lte 8000>>
You moan. "Good $beasttype. F-fill my ass with your seed."
<<else>>
You moan. "I-I'm gonna cum... from a $beasttype fucking my ass."
<</if>>
<<elseif $exposed gte 2>>
<<if $rng lte 20>>
You moan. "You like what you see?"
<<elseif $rng lte 40>>
You giggle. "Do I look tasty?"
<<elseif $rng lte 60>>
You moan. "I-I'm all exposed in front of a $beasttype. What will it do with me?"
<<elseif $rng lte 80>>
You moan. "Look closer, I want you to see everything."
<<else>>
You moan. "You can do more than just look, you know."
<</if>>
<<else>>
<<if $awarelevel gte 1>>
<<if $arousal lte 2000>>
You moan. "Good $beasttype. Please be gentle with me."
<<elseif $arousal lte 6000>>
You moan. "You want to breed with me? I'm flattered."
<<else>>
You gasp and moan. "B-breed me. Make me your $beasttype bitch."
<</if>>
<<else>>
<<if $arousal lte 2000>>
<<if $rng lte 35>>
You moan. "Good $beasttype. Please be gentle with me."
<<elseif $rng lte 70>>
You giggle. "You're tickling me!"
<<else>>
You giggle. "Do you want to be friends, $beasttype?"
<</if>>
<<elseif $arousal lte 6000>>
You moan. "You're making me feel strange."
<<else>>
You gasp and moan. "Y-you're m-making me feel strange."
<</if>>
<</if>>
<</if>>
<<else>>
<<if $vaginastate is "imminent">>
<<if $vaginalvirginity is 1>>
<<if $awarelevel gte 1>>
You moan. "Please be gentle with my pussy, It's my first time."
<<else>>
You moan. "Poking me there is making me feel funny!"
<</if>>
<<else>>
You moan. "Please stop teasing me, my pussy aches for you!"
<</if>>
<<elseif $penisstate is "imminent">>
<<if $penilevirginity is 1>>
<<if $awarelevel gte 1>>
You moan. "Please be gentle with my penis, It's my first time."
<<else>>
You moan. "My willy feels funny when you make it poke you there!"
<</if>>
<<else>>
You moan. "Please hurry and swallow me, I can't take any teasing!"
<</if>>
<<elseif $penisstate is "otheranusimminent">>
<<if $penilevirginity is 1>>
<<if $awarelevel gte 1>>
You moan. "Please be gentle with my penis, It's my first time."
<<else>>
You moan. "My willy feels funny when you make it poke you there!"
<</if>>
<<else>>
You moan. "Please hurry and swallow me, I can't take any teasing!"
<</if>>
<<elseif $anusstate is "imminent">>
<<if $analvirginity is 1>>
<<if $awarelevel gte 1>>
You moan. "I don't know why you like my ass so much, but it's making me feel good."
<<else>>
You giggle. "You're making my bottom tickle!"
<</if>>
<<else>>
You moan. "I can't wait for you to fill my ass."
<</if>>
<<elseif $vaginastate is "penetrated">>
<<if $arousal lte 2000>>
You moan. "That's it, fill my pussy."
<<elseif $arousal lte 8000>>
You moan. "You're making my pussy feel so good!"
<<else>>
You moan. "D-don't stop... I'm gonna c-cum."
<</if>>
<<elseif $penisstate is "otheranus">>
<<if $arousal lte 2000>>
You moan. "It's so warm inside you."
<<elseif $arousal lte 8000>>
You moan. "T-take all of me!"
<<else>>
You moan. "D-don't stop... I'm gonna c-cum."
<</if>>
<<elseif $penisstate is "otheranus">>
<<if $arousal lte 2000>>
You moan. "It's so warm inside you."
<<elseif $arousal lte 8000>>
You moan. "T-take all of me!"
<<else>>
You moan. "D-don't stop... I'm gonna c-cum."
<</if>>
<<elseif $anusstate is "penetrated">>
<<if $arousal lte 2000>>
You moan. "That's it, fill my ass up."
<<elseif $arousal lte 8000>>
You moan. "K-keep going."
<<else>>
You moan. "D-don't stop... I'm gonna c-cum."
<</if>>
<<elseif $exposed gte 2 and $rng gte 51>>
<<set $rng to random(1, 100)>>
<<if $rng lte 20>>
You moan. "You like what you see?"
<<elseif $rng lte 40>>
You moan. "I'm unwrapped and ready for you."
<<elseif $rng lte 60>>
You moan. "I-I'm all exposed and vulnerable. What will you do with me?"
<<elseif $rng lte 80>>
You moan. "Y-you can see everything."
<<else>>
You moan. "You can do more than just look."
<</if>>
<<else>>
<<if $awarelevel gte 1>>
<<if $arousal lte 2000>>
You moan. "I'm all yours."
<<elseif $arousal lte 6000>>
You moan. "You're making me feel so good!"
<<else>>
You gasp and moan. "I'm gonna c-cum!"
<</if>>
<<else>>
<<if $arousal lte 2000>>
<<if $rng lte 35>>
You giggle. "You're making me feel funny."
<<elseif $rng lte 70>>
You moan. "Will you take care of me?"
<<else>>
You giggle. "You're very strong!"
<</if>>
<<elseif $arousal lte 6000>>
You moan. "You're making me feel strange. Don't stop."
<<else>>
You gasp and moan. "D-don't... s-stop..."
<</if>>
<</if>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionsdemand">><<nobr>>
<<if $enemytype is "beast">>
<<if $vaginastate is "imminent">>
<<if $vaginalvirginity is 1>>
<<if $awarelevel gte 1>>
You speak. "There's no way I'm letting a filthy $beasttype take my virginity!"
<<else>>
You speak. "Stop poking me there, stupid $beasttype."
<</if>>
<<else>>
You speak. "I'm not letting a $beasttype fuck me. Get off!"
<</if>>
<<elseif $penisstate is "imminent">>
<<if $penilevirginity is 1>>
<<if $awarelevel gte 1>>
You speak. "There's no way I'm letting a filthy $beasttype take my virginity!"
<<else>>
You speak. "Stop poking me there, stupid $beasttype."
<</if>>
<<else>>
You speak. "I'm not letting a $beasttype fuck me. Get off!"
<</if>>
<<elseif $penisstate is "otheranusimminent">>
<<if $penilevirginity is 1>>
<<if $awarelevel gte 1>>
You speak. "There's no way I'm letting a filthy $beasttype ass take my virginity!"
<<else>>
You speak. "Stop poking me there, stupid $beasttype."
<</if>>
<<else>>
You speak. "I'm not letting a $beasttype fuck me. Get off!"
<</if>>
<<elseif $anusstate is "imminent">>
<<if $analvirginity is 1>>
<<if $awarelevel gte 1>>
You speak. "What do you think you're doing back there? Stop it!"
<<else>>
You speak. "Stop poking my bottom. Stupid $beasttype."
<</if>>
<<else>>
You speak. "Get the fuck away from my ass!"
<</if>>
<<elseif $vaginastate is "penetrated">>
<<if $arousal lte 2000>>
You speak. "Take your filthy $beasttype cock out of my pussy right now!"
<<elseif $arousal lte 8000>>
You speak. "Get off of me you fucking $beasttype, I'm not your toy!"
<<else>>
You speak. "I-I'm not gonna cum from a stupid $beasttype fucking me... I'm not..."
<</if>>
<<elseif $penisstate is "penetrated">>
<<if $arousal lte 2000>>
You speak. "Release me this instant, stupid $beasttype!"
<<elseif $arousal lte 8000>>
You speak. "Get off of me you fucking $beasttype, I'm not your toy!"
<<else>>
You speak. "I-I'm not gonna cum from a stupid $beasttype fucking me... I'm not..."
<</if>>
<<elseif $penisstate is "otheranus">>
<<if $arousal lte 2000>>
You speak. "Release me this instant, stupid $beasttype!"
<<elseif $arousal lte 8000>>
You speak. "Get off of me you fucking $beasttype, I'm not your toy!"
<<else>>
You speak. "I-I'm not gonna cum from a stupid $beasttype fucking me... I'm not..."
<</if>>
<<elseif $anusstate is "penetrated">>
<<if $arousal lte 2000>>
You speak. "Get your filthy $beasttype cock out of my ass right now!"
<<elseif $arousal lte 8000>>
You speak. "Get off of me you fucking $beasttype, I'm not your toy!"
<<else>>
You speak. "I-I'm not gonna cum from a stupid $beasttype fucking my ass... I'm not..."
<</if>>
<<elseif $exposed gte 2>>
<<if $rng lte 20>>
You speak. "Get away from my private place!"
<<elseif $rng lte 40>>
You speak. "You like what you see, $beasttype? I'll make you pay for it."
<<elseif $rng lte 60>>
You speak. "Don't you dare look, filthy creature."
<<elseif $rng lte 80>>
You speak. "I might be exposed, but I'm not afraid of you!"
<<else>>
You speak. "You like what you see? Of course you do, stupid $beasttype."
<</if>>
<<else>>
<<if $awarelevel gte 1>>
<<if $arousal lte 2000>>
You speak. "Stupid $beasttype. Get away from me."
<<elseif $arousal lte 6000>>
You speak. "Get the fuck away from me, right now!"
<<else>>
You gasp. "Y-you'll pay for this, stupid $beasttype."
<</if>>
<<else>>
<<if $arousal lte 2000>>
<<if $rng lte 35>>
You speak. "Stupid $beasttype. Shoo!"
<<elseif $rng lte 70>>
You speak. "I don't want to play with you. Go away."
<<else>>
You speak. "Go away, you're filthy."
<</if>>
<<elseif $arousal lte 6000>>
You speak. "I want to you go away, isn't that clear?"
<<else>>
You gasp. "I-I hate you, stupid $beasttype."
<</if>>
<</if>>
<</if>>
<<else>>
<<if $vaginastate is "imminent">>
<<if $vaginalvirginity is 1>>
<<if $awarelevel gte 1>>
You speak. "If you take my virginity I'll never forgive you."
<<else>>
You speak. "That's my special place. You're not allowed there!"
<</if>>
<<else>>
You speak. "Get that disgusting thing away from me!"
<</if>>
<<elseif $penisstate is "imminent">>
<<if $penilevirginity is 1>>
<<if $awarelevel gte 1>>
You speak. "If you take my virginity I'll never forgive you."
<<else>>
You speak. "That's my special place. You're not allowed there!"
<</if>>
<<else>>
You speak. "Get that disgusting thing away from me!"
<</if>>
<<elseif $penisstate is "otheranusimminent">>
<<if $penilevirginity is 1>>
<<if $awarelevel gte 1>>
You speak. "If you take my virginity I'll never forgive you."
<<else>>
You speak. "That's my special place. You're not allowed there!"
<</if>>
<<else>>
You speak. "Get your disgusting ass away from me!"
<</if>>
<<elseif $anusstate is "imminent">>
<<if $analvirginity is 1>>
<<if $awarelevel gte 1>>
You speak. "I don't know what you think you're doing, but you're gonna get the fuck away from me this instant."
<<else>>
You speak. "I don't know why you're poking my bottom, but stop right now!"
<</if>>
<<else>>
You speak. "Get away from my ass, pervert!"
<</if>>
<<elseif $vaginastate is "penetrated">>
<<if $arousal lte 2000>>
You speak. "Get out of my pussy right now!"
<<elseif $arousal lte 8000>>
You speak. "Get off me, rapist scum!"
<<else>>
You speak. "I-If you make me c-cum, I'll never forgive you."
<</if>>
<<elseif $penisstate is "penetrated">>
<<if $arousal lte 2000>>
You speak. "Get off my penis right now!"
<<elseif $arousal lte 8000>>
You speak. "Get off me, rapist scum!"
<<else>>
You speak. "I-If you make me c-cum, I'll never forgive you."
<</if>>
<<elseif $penisstate is "otheranus">>
<<if $arousal lte 2000>>
You speak. "Get off my penis right now!"
<<elseif $arousal lte 8000>>
You speak. "Get your ass off me, rapist scum!"
<<else>>
You speak. "I-If you make me c-cum, I'll never forgive you."
<</if>>
<<elseif $anusstate is "penetrated">>
<<if $arousal lte 2000>>
You speak. "Get out of my ass right now!"
<<elseif $arousal lte 8000>>
You speak. "Get off me, rapist scum!"
<<else>>
You speak. "I-If you make me c-cum, I'll never forgive you."
<</if>>
<<elseif $exposed gte 2 and $rng gte 51>>
<<set $rng to random(1, 100)>>
<<if $rng lte 20>>
You speak. "Get away from my private place!"
<<elseif $rng lte 40>>
You speak. "You like what you see, you useless fuck? I'll make you pay for it."
<<elseif $rng lte 60>>
You speak. "Don't you dare look, rapist piece of shit."
<<elseif $rng lte 80>>
You speak. "I might be exposed, but I'm not afraid of you!"
<<else>>
You speak. "You like what you see? Of course you do, pervert."
<</if>>
<<else>>
<<if $awarelevel gte 1>>
<<if $arousal lte 2000>>
You speak. "Get away from me, pervert."
<<elseif $arousal lte 6000>>
You speak. "Stop touching me right now or I'll make you pay!"
<<else>>
You gasp. "I-I'm not gonna cum... I'm not."
<</if>>
<<else>>
<<if $arousal lte 2000>>
<<if $rng lte 35>>
You speak. "Go away!"
<<elseif $rng lte 70>>
You speak. "I don't like you, get away from me."
<<else>>
You speak. "Stop touching me."
<</if>>
<<elseif $arousal lte 6000>>
You speak. "Leave me alone."
<<else>>
You gasp. "I-It's your fault I feel strange. Go away!"
<</if>>
<</if>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionsmock">><<nobr>>
<<if $enemytype is "beast">>
<<if $vaginastate is "imminent">>
<<if $vaginalvirginity is 1>>
<<if $awarelevel gte 1>>
You speak. "There's no way I'm letting a filthy $beasttype take my virginity!"
<<else>>
You speak. "Stop poking me there, stupid $beasttype."
<</if>>
<<else>>
You speak. "I'm not letting a $beasttype fuck me. Get off!"
<</if>>
<<elseif $penisstate is "imminent">>
<<if $penilevirginity is 1>>
<<if $awarelevel gte 1>>
You speak. "There's no way I'm letting a filthy $beasttype take my virginity!"
<<else>>
You speak. "Stop poking me there, stupid $beasttype."
<</if>>
<<else>>
You speak. "I'm not letting a $beasttype fuck me. Get off!"
<</if>>
<<elseif $penisstate is "otheranusimminent">>
<<if $penilevirginity is 1>>
<<if $awarelevel gte 1>>
You speak. "There's no way I'm letting a filthy $beasttype ass take my virginity!"
<<else>>
You speak. "Stop poking me there, stupid $beasttype."
<</if>>
<<else>>
You speak. "I'm not letting a $beasttype fuck me. Get off!"
<</if>>
<<elseif $anusstate is "imminent">>
<<if $analvirginity is 1>>
<<if $awarelevel gte 1>>
You speak. "What do you think you're doing back there? Stop it!"
<<else>>
You speak. "Stop poking my bottom. Stupid $beasttype."
<</if>>
<<else>>
You speak. "Get the fuck away from my ass!"
<</if>>
<<elseif $vaginastate is "penetrated">>
<<if $arousal lte 2000>>
You speak. "Take your filthy $beasttype cock out of my pussy right now!"
<<elseif $arousal lte 8000>>
You speak. "Get off of me you fucking $beasttype, I'm not your toy!"
<<else>>
You speak. "I-I'm not gonna cum from a stupid $beasttype fucking me... I'm not..."
<</if>>
<<elseif $penisstate is "penetrated">>
<<if $arousal lte 2000>>
You speak. "Release me this instant, stupid $beasttype!"
<<elseif $arousal lte 8000>>
You speak. "Get off of me you fucking $beasttype, I'm not your toy!"
<<else>>
You speak. "I-I'm not gonna cum from a stupid $beasttype fucking me... I'm not..."
<</if>>
<<elseif $penisstate is "otheranus">>
<<if $arousal lte 2000>>
You speak. "Release me this instant, stupid $beasttype!"
<<elseif $arousal lte 8000>>
You speak. "Get off of me you fucking $beasttype, I'm not your toy!"
<<else>>
You speak. "I-I'm not gonna cum from a stupid $beasttype fucking me... I'm not..."
<</if>>
<<elseif $anusstate is "penetrated">>
<<if $arousal lte 2000>>
You speak. "Get your filthy $beasttype cock out of my ass right now!"
<<elseif $arousal lte 8000>>
You speak. "Get off of me you fucking $beasttype, I'm not your toy!"
<<else>>
You speak. "I-I'm not gonna cum from a stupid $beasttype fucking my ass... I'm not..."
<</if>>
<<elseif $exposed gte 2>>
<<if $rng lte 20>>
You speak. "Get away from my private place!"
<<elseif $rng lte 40>>
You speak. "You like what you see, $beasttype? I'll make you pay for it."
<<elseif $rng lte 60>>
You speak. "Don't you dare look, filthy creature."
<<elseif $rng lte 80>>
You speak. "I might be exposed, but I'm not afraid of you!"
<<else>>
You speak. "You like what you see? Of course you do, stupid $beasttype."
<</if>>
<<else>>
<<if $awarelevel gte 1>>
<<if $arousal lte 2000>>
You speak. "Stupid $beasttype. Get away from me."
<<elseif $arousal lte 6000>>
You speak. "Get the fuck away from me, right now!"
<<else>>
You gasp. "Y-you'll pay for this, stupid $beasttype."
<</if>>
<<else>>
<<if $arousal lte 2000>>
<<if $rng lte 35>>
You speak. "Stupid $beasttype. Shoo!"
<<elseif $rng lte 70>>
You speak. "I don't want to play with you. Go away."
<<else>>
You speak. "Go away, you're filthy."
<</if>>
<<elseif $arousal lte 6000>>
You speak. "I want to you go away, isn't that clear?"
<<else>>
You gasp. "I-I hate you, stupid $beasttype."
<</if>>
<</if>>
<</if>>
<<else>>
<<if $vaginastate is "imminent">>
<<if $vaginalvirginity is 1>>
<<if $awarelevel gte 1>>
You speak. "If you take my virginity I'll never forgive you."
<<else>>
You speak. "That's my special place. You're not allowed there!"
<</if>>
<<else>>
You speak. "Get that disgusting thing away from me!"
<</if>>
<<elseif $penisstate is "imminent">>
<<if $penilevirginity is 1>>
<<if $awarelevel gte 1>>
You speak. "If you take my virginity I'll never forgive you."
<<else>>
You speak. "That's my special place. You're not allowed there!"
<</if>>
<<else>>
You speak. "Get that disgusting thing away from me!"
<</if>>
<<elseif $penisstate is "otheranusimminent">>
<<if $penilevirginity is 1>>
<<if $awarelevel gte 1>>
You speak. "If you take my virginity I'll never forgive you."
<<else>>
You speak. "That's my special place. You're not allowed there!"
<</if>>
<<else>>
You speak. "Get your disgusting ass away from me!"
<</if>>
<<elseif $anusstate is "imminent">>
<<if $analvirginity is 1>>
<<if $awarelevel gte 1>>
You speak. "I don't know what you think you're doing, but you're gonna get the fuck away from me this instant."
<<else>>
You speak. "I don't know why you're poking my bottom, but stop right now!"
<</if>>
<<else>>
You speak. "Get away from my ass, pervert!"
<</if>>
<<elseif $vaginastate is "penetrated">>
<<if $arousal lte 2000>>
You speak. "Get out of my pussy right now!"
<<elseif $arousal lte 8000>>
You speak. "Get off me, rapist scum!"
<<else>>
You speak. "I-If you make me c-cum, I'll never forgive you."
<</if>>
<<elseif $penisstate is "penetrated">>
<<if $arousal lte 2000>>
You speak. "Get off my penis right now!"
<<elseif $arousal lte 8000>>
You speak. "Get off me, rapist scum!"
<<else>>
You speak. "I-If you make me c-cum, I'll never forgive you."
<</if>>
<<elseif $penisstate is "otheranus">>
<<if $arousal lte 2000>>
You speak. "Get off my penis right now!"
<<elseif $arousal lte 8000>>
You speak. "Get your ass off me, rapist scum!"
<<else>>
You speak. "I-If you make me c-cum, I'll never forgive you."
<</if>>
<<elseif $anusstate is "penetrated">>
<<if $arousal lte 2000>>
You speak. "Get out of my ass right now!"
<<elseif $arousal lte 8000>>
You speak. "Get off me, rapist scum!"
<<else>>
You speak. "I-If you make me c-cum, I'll never forgive you."
<</if>>
<<elseif $exposed gte 2 and $rng gte 51>>
<<set $rng to random(1, 100)>>
<<if $rng lte 20>>
You speak. "Get away from my private place!"
<<elseif $rng lte 40>>
You speak. "You like what you see, you useless fuck? I'll make you pay for it."
<<elseif $rng lte 60>>
You speak. "Don't you dare look, rapist piece of shit."
<<elseif $rng lte 80>>
You speak. "I might be exposed, but I'm not afraid of you!"
<<else>>
You speak. "You like what you see? Of course you do, pervert."
<</if>>
<<else>>
<<if $awarelevel gte 1>>
<<if $arousal lte 2000>>
You speak. "Get away from me, pervert."
<<elseif $arousal lte 6000>>
You speak. "Stop touching me right now or I'll make you pay!"
<<else>>
You gasp. "I-I'm not gonna cum... I'm not."
<</if>>
<<else>>
<<if $arousal lte 2000>>
<<if $rng lte 35>>
You speak. "Go away!"
<<elseif $rng lte 70>>
You speak. "I don't like you, get away from me."
<<else>>
You speak. "Stop touching me."
<</if>>
<<elseif $arousal lte 6000>>
You speak. "Leave me alone."
<<else>>
You gasp. "I-It's your fault I feel strange. Go away!"
<</if>>
<</if>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionsmock">><<nobr>>
<<if $mockaction is "penis">>
<<if $vaginause is "penis">>
<<if $vaginastate is "penetrated">>
<<if $mockcycle is 0>><<set $mockcycle += 1>>
"I can barely feel it,"
<<elseif $mockcycle is 1>><<set $mockcycle += 1>>
"The last cock was much larger,"
<<elseif $mockcycle is 2>><<set $mockcycle += 1>>
"Is it even in yet?"
<<elseif $mockcycle is 3>><<set $mockcycle += 1>>
"Don't you have something bigger?"
<<else>><<set $mockcycle to 0>>
"How disappointing,"
<</if>>
<<else>>
<<if $mockcycle is 0>><<set $mockcycle += 1>>
"I bet the thought of entering my pussy is driving you mad,"
<<elseif $mockcycle is 1>><<set $mockcycle += 1>>
"I'm not sure you're big enough,"
<<elseif $mockcycle is 2>><<set $mockcycle += 1>>
"What are you waiting for?,"
<<elseif $mockcycle is 3>><<set $mockcycle += 1>>
"I bet you cum before you get it in,"
<<else>><<set $mockcycle to 0>>
"Do you even know how to use that thing?"
<</if>>
<</if>>
<<elseif $anususe is "penis">>
<<if $anusstate is "penetrated">>
<<if $mockcycle is 0>><<set $mockcycle += 1>>
"I can barely feel it,"
<<elseif $mockcycle is 1>><<set $mockcycle += 1>>
"The last cock was much larger,"
<<elseif $mockcycle is 2>><<set $mockcycle += 1>>
"Is it even in yet?"
<<elseif $mockcycle is 3>><<set $mockcycle += 1>>
"Don't you have something bigger?"
<<else>><<set $mockcycle to 0>>
"How disappointing,"
<</if>>
<<else>>
<<if $mockcycle is 0>><<set $mockcycle += 1>>
"I bet the thought of entering my ass is driving you mad,"
<<elseif $mockcycle is 1>><<set $mockcycle += 1>>
"I'm not sure you're big enough,"
<<elseif $mockcycle is 2>><<set $mockcycle += 1>>
"What are you waiting for?,"
<<elseif $mockcycle is 3>><<set $mockcycle += 1>>
"I bet you cum before you get it in,"
<<else>><<set $mockcycle to 0>>
"Do you even know how to use that thing?"
<</if>>
<</if>>
<<else>>
<<if $mockcycle is 0>><<set $mockcycle += 1>>
"How disappointing,"
<<elseif $mockcycle is 1>><<set $mockcycle += 1>>
"You're pathetic,"
<<elseif $mockcycle is 2>><<set $mockcycle += 1>>
"Is that all you've got?"
<<elseif $mockcycle is 3>><<set $mockcycle += 1>>
"Your little thing doesn't frighten me,"
<<else>><<set $mockcycle to 0>>
"Your cock is so small,"
<</if>>
<</if>>
<<elseif $mockaction is "pussy">>
<<if $penisuse is "vagina">>
<<if $penisstate is "penetrated">>
<<if $mockcycle is 0>><<set $mockcycle += 1>>
"You're confident for someone getting pounded,"
<<elseif $mockcycle is 1>><<set $mockcycle += 1>>
"I'm gonna fill your womb,"
<<elseif $mockcycle is 2>><<set $mockcycle += 1>>
"Your pussy feels weird,"
<<elseif $mockcycle is 3>><<set $mockcycle += 1>>
"I think you've had one too many cocks in you,"
<<else>><<set $mockcycle to 0>>
"What's it like getting fucked like this?"
<</if>>
<<else>>
<<if $mockcycle is 0>><<set $mockcycle += 1>>
"You're such a slut,"
<<elseif $mockcycle is 1>><<set $mockcycle += 1>>
"I don't think you're ready for my cock,"
<<elseif $mockcycle is 2>><<set $mockcycle += 1>>
"You think you can handle it?"
<<elseif $mockcycle is 3>><<set $mockcycle += 1>>
"I bet you try to ride every cock you see,"
<<else>><<set $mockcycle to 0>>
"You're very eager to take me inside you,"
<</if>>
<</if>>
<<else>>
<<if $mockcycle is 0>><<set $mockcycle += 1>>
"You're so wet already,"
<<elseif $mockcycle is 1>><<set $mockcycle += 1>>
"You're eager to get fucked,"
<<elseif $mockcycle is 2>><<set $mockcycle += 1>>
"I bet your pussy has had lots of use,"
<<elseif $mockcycle is 3>><<set $mockcycle += 1>>
"You might be too wide for me,"
<<else>><<set $mockcycle to 0>>
"Your pussy looks weird,"
<</if>>
<</if>>
<<elseif $mockaction is "skill">>
<<if $vaginause is "penis">>
<<if $vaginastate is "penetrated">>
<<if $mockcycle is 0>><<set $mockcycle += 1>>
"At least you're trying,"
<<elseif $mockcycle is 1>><<set $mockcycle += 1>>
"You're boring me,"
<<elseif $mockcycle is 2>><<set $mockcycle += 1>>
"Your cock is so clumsy,"
<<elseif $mockcycle is 3>><<set $mockcycle += 1>>
"Do you even know how to use that thing?"
<<else>><<set $mockcycle to 0>>
"Is this your first time?"
<</if>>
<<else>>
<<if $mockcycle is 0>><<set $mockcycle += 1>>
"Careful where you point that,"
<<elseif $mockcycle is 1>><<set $mockcycle += 1>>
"You won't last long,"
<<elseif $mockcycle is 2>><<set $mockcycle += 1>>
"I bet this is new to you,"
<<elseif $mockcycle is 3>><<set $mockcycle += 1>>
"You're not good enough for my pussy,"
<<else>><<set $mockcycle to 0>>
"I don't expect much,"
<</if>>
<</if>>
<<elseif $anususe is "penis">>
<<if $anusstate is "penetrated">>
<<if $mockcycle is 0>><<set $mockcycle += 1>>
"At least you're trying,"
<<elseif $mockcycle is 1>><<set $mockcycle += 1>>
"You're boring me,"
<<elseif $mockcycle is 2>><<set $mockcycle += 1>>
"Your cock is so clumsy,"
<<elseif $mockcycle is 3>><<set $mockcycle += 1>>
"Do you even know how to use that thing?"
<<else>><<set $mockcycle to 0>>
"Is this your first time?"
<</if>>
<<else>>
<<if $mockcycle is 0>><<set $mockcycle += 1>>
"Careful where you point that,"
<<elseif $mockcycle is 1>><<set $mockcycle += 1>>
"You won't last long,"
<<elseif $mockcycle is 2>><<set $mockcycle += 1>>
"I bet this is new to you,"
<<elseif $mockcycle is 3>><<set $mockcycle += 1>>
"You're not good enough for my ass,"
<<else>><<set $mockcycle to 0>>
"I don't expect much,"
<</if>>
<</if>>
<<elseif $penisuse is "vagina" or $penisuse is "otheranus">>
<<if $penisstate is "penetrated" or $penisstate is "otheranus">>
<<if $mockcycle is 0>><<set $mockcycle += 1>>
"At least you're trying,"
<<elseif $mockcycle is 1>><<set $mockcycle += 1>>
"You're not making me cum,"
<<elseif $mockcycle is 2>><<set $mockcycle += 1>>
"Move your hips more. Do I have to do everything?"
<<elseif $mockcycle is 3>><<set $mockcycle += 1>>
"Do you even know what you're doing?"
<<else>><<set $mockcycle to 0>>
"Is this your first time?"
<</if>>
<<else>>
<<if $mockcycle is 0>><<set $mockcycle += 1>>
"Careful where you point that,"
<<elseif $mockcycle is 1>><<set $mockcycle += 1>>
"You won't last long,"
<<elseif $mockcycle is 2>><<set $mockcycle += 1>>
"I doubt you know how handle it,"
<<elseif $mockcycle is 3>><<set $mockcycle += 1>>
"You're not good enough for my penis,"
<<else>><<set $mockcycle to 0>>
"I don't expect much,"
<</if>>
<</if>>
<<else>>
<<if $mockcycle is 0>><<set $mockcycle += 1>>
"At least you're trying,"
<<elseif $mockcycle is 1>><<set $mockcycle += 1>>
"Wake me when it's over,"
<<elseif $mockcycle is 2>><<set $mockcycle += 1>>
"I'd be better off using my hand,"
<<elseif $mockcycle is 3>><<set $mockcycle += 1>>
"You don't know what you're doing, do you?"
<<else>><<set $mockcycle to 0>>
"You're bad at this,"
<</if>>
<</if>>
<<elseif $mockaction is "weak">>
<<if $vaginause is "penis">>
<<if $vaginastate is "penetrated">>
<<if $mockcycle is 0>><<set $mockcycle += 1>>
"Tired already?"
<<elseif $mockcycle is 1>><<set $mockcycle += 1>>
"I don't normally let such weaklings inside me,"
<<elseif $mockcycle is 2>><<set $mockcycle += 1>>
"Careful you don't have a heart attack,"
<<elseif $mockcycle is 3>><<set $mockcycle += 1>>
"You're too weak to keep this up,"
<<else>><<set $mockcycle to 0>>
"You're wearing out fast,"
<</if>>
<<else>>
<<if $mockcycle is 0>><<set $mockcycle += 1>>
"I don't think you're strong enough to push it in,"
<<elseif $mockcycle is 1>><<set $mockcycle += 1>>
"It goes in when I say so,"
<<elseif $mockcycle is 2>><<set $mockcycle += 1>>
"You gonna faint on me?"
<<elseif $mockcycle is 3>><<set $mockcycle += 1>>
"I could keep you away forever,"
<<else>><<set $mockcycle to 0>>
"If you want my pussy, you'll need to work harder than that,"
<</if>>
<</if>>
<<elseif $anususe is "penis">>
<<if $anusstate is "penetrated">>
<<if $mockcycle is 0>><<set $mockcycle += 1>>
"Tired already?"
<<elseif $mockcycle is 1>><<set $mockcycle += 1>>
"I don't normally let such weaklings inside me,"
<<elseif $mockcycle is 2>><<set $mockcycle += 1>>
"Careful you don't have a heart attack,"
<<elseif $mockcycle is 3>><<set $mockcycle += 1>>
"You're too weak to keep this up,"
<<else>><<set $mockcycle to 0>>
"You're wearing out fast,"
<</if>>
<<else>>
<<if $mockcycle is 0>><<set $mockcycle += 1>>
"I don't think you're strong enough to push it in,"
<<elseif $mockcycle is 1>><<set $mockcycle += 1>>
"It goes in when I say so,"
<<elseif $mockcycle is 2>><<set $mockcycle += 1>>
"You gonna faint on me?"
<<elseif $mockcycle is 3>><<set $mockcycle += 1>>
"I could keep you away forever,"
<<else>><<set $mockcycle to 0>>
"If you want my ass, you'll need to work harder than that,"
<</if>>
<</if>>
<<elseif $penisuse is "vagina" or $penisuse is "otheranus">>
<<if $penisstate is "penetrated" or $penisstate is "otheranus">>
<<if $mockcycle is 0>><<set $mockcycle += 1>>
"Tired already?"
<<elseif $mockcycle is 1>><<set $mockcycle += 1>>
"I don't normally fuck such weaklings,"
<<elseif $mockcycle is 2>><<set $mockcycle += 1>>
"Careful you don't have a heart attack,"
<<elseif $mockcycle is 3>><<set $mockcycle += 1>>
"You're too weak to keep this up,"
<<else>><<set $mockcycle to 0>>
"You're wearing out fast,"
<</if>>
<<else>>
<<if $mockcycle is 0>><<set $mockcycle += 1>>
"I don't think you're strong enough to push it in,"
<<elseif $mockcycle is 1>><<set $mockcycle += 1>>
"It goes in when I say so,"
<<elseif $mockcycle is 2>><<set $mockcycle += 1>>
"You gonna faint on me?"
<<elseif $mockcycle is 3>><<set $mockcycle += 1>>
"I could keep you away forever,"
<<else>><<set $mockcycle to 0>>
"If you want my penis, you'll need to work harder than that,"
<</if>>
<</if>>
<<else>>
<<if $mockcycle is 0>><<set $mockcycle += 1>>
"You're so weak,"
<<elseif $mockcycle is 1>><<set $mockcycle += 1>>
"This is only happening because I let it,"
<<elseif $mockcycle is 2>><<set $mockcycle += 1>>
"I'm doing this out of pity,"
<<elseif $mockcycle is 3>><<set $mockcycle += 1>>
"You couldn't even force someone to fuck you,"
<<else>><<set $mockcycle to 0>>
"Is that all you've got?"
<</if>>
<</if>>
<<elseif $mockaction is "looks">>
<<if $vaginause is "penis">>
<<if $vaginastate is "penetrated">>
<<if $mockcycle is 0>><<set $mockcycle += 1>>
"At least don't make me look at your face,"
<<elseif $mockcycle is 1>><<set $mockcycle += 1>>
"You could only ever get someone to fuck you through force,"
<<elseif $mockcycle is 2>><<set $mockcycle += 1>>
"Hurry up. I don't want to look at you anymore,"
<<elseif $mockcycle is 3>><<set $mockcycle += 1>>
"I hope I don't have to fuck anyone as ugly as you again,"
<<else>><<set $mockcycle to 0>>
"I hope you're enjoying this. It's more than you deserve,"
<</if>>
<<else>>
<<if $mockcycle is 0>><<set $mockcycle += 1>>
"The thought of someone so revolting fucking me is making me queasy,"
<<elseif $mockcycle is 1>><<set $mockcycle += 1>>
"You want me to pity fuck you?"
<<elseif $mockcycle is 2>><<set $mockcycle += 1>>
"I don't want any part of your disgusting body inside me,"
<<elseif $mockcycle is 3>><<set $mockcycle += 1>>
"I've never fucked anyone as ugly as you,"
<<else>><<set $mockcycle to 0>>
"I look too good for you,"
<</if>>
<</if>>
<<elseif $anususe is "penis">>
<<if $anusstate is "penetrated">>
<<if $mockcycle is 0>><<set $mockcycle += 1>>
"At least don't make me look at your face,"
<<elseif $mockcycle is 1>><<set $mockcycle += 1>>
"You could only ever get someone to fuck you through force,"
<<elseif $mockcycle is 2>><<set $mockcycle += 1>>
"Hurry up. I don't want to look at you anymore,"
<<elseif $mockcycle is 3>><<set $mockcycle += 1>>
"I hope I don't have to fuck anyone as ugly as you again,"
<<else>><<set $mockcycle to 0>>
"I hope you're enjoying this. It's more than you deserve,"
<</if>>
<<else>>
<<if $mockcycle is 0>><<set $mockcycle += 1>>
"The thought of someone so revolting fucking me is making me queasy,"
<<elseif $mockcycle is 1>><<set $mockcycle += 1>>
"You want me to pity fuck you?"
<<elseif $mockcycle is 2>><<set $mockcycle += 1>>
"I don't want any part of your disgusting body inside me,"
<<elseif $mockcycle is 3>><<set $mockcycle += 1>>
"I've never fucked anyone as ugly as you,"
<<else>><<set $mockcycle to 0>>
"I look too good for you,"
<</if>>
<</if>>
<<elseif $penisuse is "vagina" or $penisuse is "otheranus">>
<<if $penisstate is "penetrated" or $penisstate is "otheranus">>
<<if $mockcycle is 0>><<set $mockcycle += 1>>
"At least don't make me look at your face,"
<<elseif $mockcycle is 1>><<set $mockcycle += 1>>
"You could only ever get someone to fuck you through force,"
<<elseif $mockcycle is 2>><<set $mockcycle += 1>>
"Hurry up. I don't want to look at you anymore,"
<<elseif $mockcycle is 3>><<set $mockcycle += 1>>
"I hope I don't have to fuck anyone as ugly as you again,"
<<else>><<set $mockcycle to 0>>
"I hope you're enjoying this. It's more than you deserve,"
<</if>>
<<else>>
<<if $mockcycle is 0>><<set $mockcycle += 1>>
"The thought of someone so revolting fucking me is making me queasy,"
<<elseif $mockcycle is 1>><<set $mockcycle += 1>>
"You want me to pity fuck you?"
<<elseif $mockcycle is 2>><<set $mockcycle += 1>>
"I don't want any part of me inside your disgusting body,"
<<elseif $mockcycle is 3>><<set $mockcycle += 1>>
"I've never fucked anyone as ugly as you,"
<<else>><<set $mockcycle to 0>>
"I look too good for you,"
<</if>>
<</if>>
<<else>>
<<if $mockcycle is 0>><<set $mockcycle += 1>>
"I'm out of your league,"
<<elseif $mockcycle is 1>><<set $mockcycle += 1>>
"I don't want to see your face again,"
<<elseif $mockcycle is 2>><<set $mockcycle += 1>>
"You're plain, at best,"
<<elseif $mockcycle is 3>><<set $mockcycle += 1>>
"Ew, gross,"
<<else>><<set $mockcycle to 0>>
"Your body looks weird,"
<</if>>
<</if>>
<<else>>
<<if $vaginause is "penis">>
<<if $vaginastate is "penetrated">>
<<if $mockcycle is 0>><<set $mockcycle += 1>>
"I hope you're happy defiling me like this,"
<<elseif $mockcycle is 1>><<set $mockcycle += 1>>
"You're ravaging an innocent <<girlstop>> Shame on you,"
<<elseif $mockcycle is 2>><<set $mockcycle += 1>>
"You'll be punished for this,"
<<elseif $mockcycle is 3>><<set $mockcycle += 1>>
"You're a bad person to be doing such things to my pussy,"
<<else>><<set $mockcycle to 0>>
"You're so cruel,"
<</if>>
<<else>>
<<if $mockcycle is 0>><<set $mockcycle += 1>>
"Are you really going to defile my innocent pussy?"
<<elseif $mockcycle is 1>><<set $mockcycle += 1>>
"Do you like being rough with <<girls>> like me?"
<<elseif $mockcycle is 2>><<set $mockcycle += 1>>
"You might hurt me with that,"
<<elseif $mockcycle is 3>><<set $mockcycle += 1>>
"Do you still think you're a good person?"
<<else>><<set $mockcycle to 0>>
"My pussy might not be able to take it,"
<</if>>
<</if>>
<<elseif $anususe is "penis">>
<<if $anusstate is "penetrated">>
<<if $mockcycle is 0>><<set $mockcycle += 1>>
"I hope you're happy defiling me like this,"
<<elseif $mockcycle is 1>><<set $mockcycle += 1>>
"You're ravaging an innocent <<girlstop>> Shame on you,"
<<elseif $mockcycle is 2>><<set $mockcycle += 1>>
"You'll be punished for this,"
<<elseif $mockcycle is 3>><<set $mockcycle += 1>>
"You're a bad person to be doing such things to my ass,"
<<else>><<set $mockcycle to 0>>
"You're so cruel,"
<</if>>
<<else>>
<<if $mockcycle is 0>><<set $mockcycle += 1>>
"Are you really going to defile my innocent ass?"
<<elseif $mockcycle is 1>><<set $mockcycle += 1>>
"Do you like being rough with <<girls>> like me?"
<<elseif $mockcycle is 2>><<set $mockcycle += 1>>
"You might hurt me with that,"
<<elseif $mockcycle is 3>><<set $mockcycle += 1>>
"Do you still think you're a good person?"
<<else>><<set $mockcycle to 0>>
"My ass might not be able to take it,"
<</if>>
<</if>>
<<elseif $penisuse is "vagina" or $penisuse is "otheranus">>
<<if $penisstate is "penetrated" or $penisstate is "otheranus">>
<<if $mockcycle is 0>><<set $mockcycle += 1>>
"I hope you're happy defiling me like this,"
<<elseif $mockcycle is 1>><<set $mockcycle += 1>>
"You're ravaging an innocent <<girlstop>> Shame on you,"
<<elseif $mockcycle is 2>><<set $mockcycle += 1>>
"You'll be punished for this,"
<<elseif $mockcycle is 3>><<set $mockcycle += 1>>
"You're a bad person to be doing such things to my penis,"
<<else>><<set $mockcycle to 0>>
"You're so cruel,"
<</if>>
<<else>>
<<if $mockcycle is 0>><<set $mockcycle += 1>>
"Are you really going to defile my innocent penis?"
<<elseif $mockcycle is 1>><<set $mockcycle += 1>>
"Do you like being rough with <<girls>> like me?"
<<elseif $mockcycle is 2>><<set $mockcycle += 1>>
"You might hurt me with that,"
<<elseif $mockcycle is 3>><<set $mockcycle += 1>>
"Do you still think you're a good person?"
<<else>><<set $mockcycle to 0>>
"My penis might not be able to take it,"
<</if>>
<</if>>
<<else>>
<<if $mockcycle is 0>><<set $mockcycle += 1>>
"You're so mean,"
<<elseif $mockcycle is 1>><<set $mockcycle += 1>>
"Are you really the sort of person who treats innocent <<girls>> this way?"
<<elseif $mockcycle is 2>><<set $mockcycle += 1>>
"What you're doing is wrong,"
<<elseif $mockcycle is 3>><<set $mockcycle += 1>>
"How will you live with yourself?"
<<else>><<set $mockcycle to 0>>
"You're a bad person,"
<</if>>
<</if>>
<</if>>
you say in a <<if $consensual is 1>>teasing<<else>>mocking<</if>> tone.
<<if $enemyno is 1>>
<<if $mockaction is $insecurity1>>
<<if $consensual is 1>>
<span class="teal"><<He>> breathes faster as you speak.</span>
<<else>>
<span class="teal"><<He>> winces at your words.</span><<gcombatcontrol>>
<</if>>
<<else>>
<span class="pink"><<He>> isn't impressed by your words.</span>
<</if>>
<<else>>
<<if $mockaction is $insecurity1>>
<<if $consensual is 1>>
<span class="teal">The <<person1>><<person>> breathes faster as you speak.</span>
<<else>>
<span class="teal">The <<person1>><<person>> winces at your words.</span><<gcombatcontrol>>
<</if>>
<<elseif $mockaction is $insecurity2>>
<<if $consensual is 1>>
<span class="teal">The <<person2>><<person>> breathes faster as you speak.</span>
<<else>>
<span class="teal">The <<person2>><<person>> winces at your words.</span><<gcombatcontrol>>
<</if>>
<<elseif $mockaction is $insecurity3>>
<<if $consensual is 1>>
<span class="teal">The <<person3>><<person>> breathes faster as you speak.</span>
<<else>>
<span class="teal">The <<person3>><<person>> winces at your words.</span><<gcombatcontrol>>
<</if>>
<<elseif $mockaction is $insecurity4>>
<<if $consensual is 1>>
<span class="teal">The <<person4>><<person>> breathes faster as you speak.</span>
<<else>>
<span class="teal">The <<person4>><<person>> winces at your words.</span><<gcombatcontrol>>
<</if>>
<<elseif $mockaction is $insecurity5>>
<<if $consensual is 1>>
<span class="teal">The <<person5>><<person>> breathes faster as you speak.</span>
<<else>>
<span class="teal">The <<person5>><<person>> winces at your words.</span><<gcombatcontrol>>
<</if>>
<<elseif $mockaction is $insecurity6>>
<<if $consensual is 1>>
<span class="teal">The <<person6>><<person>> breathes faster as you speak.</span>
<<else>>
<span class="teal">The <<person6>><<person>> winces at your words.</span><<gcombatcontrol>>
<</if>>
<<else>>
<span class="pink">None are impressed by your words.</span>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionspeniskiss">><<nobr>>
You <<oraltext>> kiss the tip of <<their>> penis.
<</nobr>><</widget>>
<<widget "actionspenislick">><<nobr>>
You <<oraltext>> lick <<their>> penis.
<</nobr>><</widget>>
<<widget "actionspenissuck">><<nobr>>
<<if $enemytype is "beast">>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
You <<oraltext>> suck the penis invading your mouth as the $beasttype pounds furiously.
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
You <<oraltext>> suck the penis invading your mouth as the $beasttype humps your face excitedly.
<<else>>
You <<oraltext>> suck the penis penetrating your mouth.
<</if>>
<<else>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
You <<oraltext>> suck the penis invading your mouth as <<theowner>> thrusts against you.
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
You <<oraltext>> suck the penis invading your mouth as <<theowner>> grinds against you.
<<else>>
You <<oraltext>> suck the penis penetrating your mouth.
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionspussylick">><<nobr>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
You <<oraltext>> lick the pussy pressing against your mouth as <<theowner>> rubs against you.
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
You <<oraltext>> lick the pussy pressing against your mouth as <<theowner>> grinds against you.
<<else>>
You <<oraltext>> lick the pussy pressing against your mouth.
<</if>>
<</nobr>><</widget>>
<<widget "actionskissback">><<nobr>>
<<if $mouthstate is "kissentrance">>
You gently brush your lips against theirs.
<<elseif $mouthstate is "kissimminent">>
<<if $arousal lte 2000>>
You kiss them back, softly.
<<elseif $arousal lte 8000>>
You kiss them back, parting their lips with your own.
<<else>>
You kiss them back, parting their lips with your tongue.
<</if>>
<<elseif $mouthstate is "kiss">>
You kiss them back, caressing their tongue with your own.
<</if>>
<</nobr>><</widget>>
<<widget "actionscheekrub">><<nobr>>
<<if $enemytype is "beast">>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
You <<bottomtext>> rub the penis between your cheeks as the $beasttype pounds furiously.
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
You <<bottomtext>> rub the penis between your cheeks as the $beasttype humps back excitedly.
<<else>>
You <<bottomtext>> rub the penis between your cheeks.
<</if>>
<<else>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
You <<bottomtext>> rub the penis between your cheeks as <<theowner>> thrusts against you.
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
You <<bottomtext>> rub the penis between your cheeks as <<theowner>> thrusts against you.
<<else>>
You <<bottomtext>> rub the penis between your cheeks.
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionsthighrub">><<nobr>>
<<if $enemytype is "beast">>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
You <<thightext>> rub the penis between your thighs as the $beasttype pounds furiously. You jerk in shock whenever it incidentally rubs against your <<genitalsstop>>
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
You <<thightext>> rub the penis between your thighs as the $beasttype humps back excitedly. You jerk in shock whenever it incidentally rubs against your <<genitalsstop>>
<<else>>
You <<thightext>> rub the penis between your thighs. You jerk in shock whenever it incidentally rubs against your <<genitalsstop>>
<</if>>
<<else>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
You <<thightext>> rub the penis between your thighs as <<theowner>> thrusts against you. You jerk in shock whenever it incidentally rubs against your <<genitalsstop>>
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
You <<thightext>> rub the penis between your thighs as <<theowner>> thrusts against you. You jerk in shock whenever it incidentally rubs against your <<genitalsstop>>
<<else>>
You <<thightext>> rub the penis between your thighs. You jerk in shock whenever it incidentally rubs against your <<genitalsstop>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionspenistip">><<nobr>>
You <<vaginaltext>> kiss the tip of <<their>> penis with your <<pussystop>>
<</nobr>><</widget>>
<<widget "actionspenisrub">><<nobr>>
You <<vaginaltext>> rub back against the penis probing your <<pussystop>>
<</nobr>><</widget>>
<<widget "actionspenisride">><<nobr>>
<<if $enemytype is "beast">>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<<if $arousal gte 8000>>
The $beasttype savagely hammers in and out of your <<pussystop>> Driven by instinct, you <<vaginaltext>> push back as you approach your peak.
<<elseif $arousal gte 4000>>
The $beasttype savagely hammers in and out of your <<pussystop>> You <<vaginaltext>> push back against its movements.
<<else>>
The $beasttype savagely hammers in and out of your <<pussystop>> You <<vaginaltext>> move with it, trying to reduce your discomfort.
<</if>>
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<<if $arousal gte 8000>>
The $beasttype relentlessly pounds your <<pussystop>> Driven by instinct, you <<vaginaltext>> push back as you approach your peak.
<<elseif $arousal gte 4000>>
The $beasttype relentlessly pounds your <<pussystop>> You <<vaginaltext>> push back against its movements.
<<else>>
The $beasttype relentlessly pounds your <<pussystop>> You <<vaginaltext>> move with it, trying to reduce your discomfort.
<</if>>
<<else>>
<<if $arousal gte 8000>>
The $beasttype rhythmically fucks your <<pussystop>> Driven by instinct, you <<vaginaltext>> push back as you approach your peak.
<<elseif $arousal gte 4000>>
The $beasttype rhythmically fucks your <<pussystop>> You <<vaginaltext>> push back against its movements.
<<else>>
The $beasttype rhythmically fucks your <<pussystop>> You <<vaginaltext>> move with it, trying to reduce your discomfort.
<</if>>
<</if>>
<<else>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<<if $arousal gte 8000>>
Your <<pussy>> is ruthlessly fucked. Driven by instinct, you <<vaginaltext>> push back as you approach your peak.
<<elseif $arousal gte 4000>>
Your <<pussy>> is ruthlessly fucked. You <<vaginaltext>> push back against the movements.
<<else>>
Your <<pussy>> is ruthlessly fucked. You <<vaginaltext>> push back, trying to reduce your discomfort.
<</if>>
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<<if $arousal gte 8000>>
Your <<pussy>> is relentlessly pounded. Driven by instinct, you <<vaginaltext>> push back as you approach your peak.
<<elseif $arousal gte 4000>>
Your <<pussy>> is relentlessly pounded. You <<vaginaltext>> push back against the movements.
<<else>>
Your <<pussy>> is relentlessly pounded. You <<vaginaltext>> push back, trying to reduce your discomfort.
<</if>>
<<else>>
<<if $arousal gte 8000>>
Your <<pussy>> yields to the repeated insertions. Driven by instinct, you <<vaginaltext>> push back as you approach your peak.
<<elseif $arousal gte 4000>>
Your <<pussy>> yields to the repeated insertions. You <<vaginaltext>> push back against the movements.
<<else>>
Your <<pussy>> yields to the repeated insertions. You <<vaginaltext>> push back, trying to reduce your discomfort.
<</if>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionspenistake">><<nobr>>
<<if $enemytype is "beast">>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<<if $arousal gte 8000>>
The $beasttype savagely hammers in and out of your <<pussystop>>
<<elseif $arousal gte 4000>>
The $beasttype savagely hammers in and out of your <<pussystop>>
<<else>>
The $beasttype savagely hammers in and out of your <<pussystop>>
<</if>>
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<<if $arousal gte 8000>>
The $beasttype relentlessly pounds your <<pussystop>>
<<elseif $arousal gte 4000>>
The $beasttype relentlessly pounds your <<pussystop>>
<<else>>
The $beasttype relentlessly pounds your <<pussystop>>
<</if>>
<<else>>
<<if $arousal gte 8000>>
The $beasttype rhythmically fucks your <<pussystop>>
<<elseif $arousal gte 4000>>
The $beasttype rhythmically fucks your <<pussystop>>
<<else>>
The $beasttype rhythmically fucks your <<pussystop>>
<</if>>
<</if>>
<<else>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<<if $arousal gte 8000>>
Your <<pussy>> is ruthlessly fucked.
<<elseif $arousal gte 4000>>
Your <<pussy>> is ruthlessly fucked.
<<else>>
Your <<pussy>> is ruthlessly fucked.
<</if>>
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<<if $arousal gte 8000>>
Your <<pussy>> is relentlessly pounded.
<<elseif $arousal gte 4000>>
Your <<pussy>> is relentlessly pounded.
<<else>>
Your <<pussy>> is relentlessly pounded.
<</if>>
<<else>>
<<if $arousal gte 8000>>
Your <<pussy>> yields to the repeated insertions.
<<elseif $arousal gte 4000>>
Your <<pussy>> yields to the repeated insertions.
<<else>>
Your <<pussy>> yields to the repeated insertions.
<</if>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionsclitrub">><<nobr>>
You <<peniletext>> frot your penis against <<their>> clit.
<</nobr>><</widget>>
<<widget "actionspussyrub">><<nobr>>
You <<peniletext>> rub your penis against <<their>> pussy.
<</nobr>><</widget>>
<<widget "actionspussytease">><<nobr>>
You <<peniletext>> rub your penis against <<their>> labia.
<</nobr>><</widget>>
<<widget "actionspussythrust">><<nobr>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<<if $arousal gte 8000>>
Your <<penis>> is ruthlessly fucked by <<their>> pussy. Driven by instinct, you <<peniletext>> push back as you approach your peak.
<<elseif $arousal gte 4000>>
Your <<penis>> is ruthlessly fucked by <<their>> pussy. You <<peniletext>> push back against the movements.
<<else>>
Your <<penis>> is ruthlessly fucked by <<their>> pussy. You <<peniletext>> push back, trying to reduce your discomfort.
<</if>>
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<<if $arousal gte 8000>>
Your <<penis>> is hungrily devoured by <<their>> pussy. Driven by instinct, you <<peniletext>> push back as you approach your peak.
<<elseif $arousal gte 4000>>
Your <<penis>> is hungrily devoured by <<their>> pussy. You <<peniletext>> push back against the movements.
<<else>>
Your <<penis>> is hungrily devoured by <<their>> pussy. You <<peniletext>> push back, trying to reduce your discomfort.
<</if>>
<<else>>
<<if $arousal gte 8000>>
Your <<penis>> is rhythmically swallowed and regurgitated by <<their>> pussy. Driven by instinct, you <<peniletext>> push back as you approach your peak.
<<elseif $arousal gte 4000>>
Your <<penis>> is rhythmically swallowed and regurgitated by <<their>> pussy. You <<peniletext>> push back against the movements.
<<else>>
Your <<penis>> is rhythmically swallowed and regurgitated by <<their>> pussy. You <<peniletext>> push back, trying to reduce your discomfort.
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionspussytake">><<nobr>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<<if $arousal gte 8000>>
Your <<penis>> is ruthlessly fucked by <<their>> pussy.
<<elseif $arousal gte 4000>>
Your <<penis>> is ruthlessly fucked by <<their>> pussy.
<<else>>
Your <<penis>> is ruthlessly fucked by <<their>> pussy.
<</if>>
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<<if $arousal gte 8000>>
Your <<penis>> is hungrily devoured by <<their>> pussy.
<<elseif $arousal gte 4000>>
Your <<penis>> is hungrily devoured by <<their>> pussy.
<<else>>
Your <<penis>> is hungrily devoured by <<their>> pussy.
<</if>>
<<else>>
<<if $arousal gte 8000>>
Your <<penis>> is rhythmically swallowed and regurgitated by <<their>> pussy.
<<elseif $arousal gte 4000>>
Your <<penis>> is rhythmically swallowed and regurgitated by <<their>> pussy.
<<else>>
Your <<penis>> is rhythmically swallowed and regurgitated by <<their>> pussy.
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionsotheranusrub">><<nobr>>
You <<peniletext>> frot your <<penis>> against <<their>> ass.
<</nobr>><</widget>>
<<widget "actionsotheranustease">><<nobr>>
You <<peniletext>> tease <<their>> anus with your <<penisstop>>
<</nobr>><</widget>>
<<widget "actionsotheranusthrust">><<nobr>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<<if $arousal gte 8000>>
Your <<penis>> is ruthlessly fucked by <<their>> ass. Driven by instinct, you <<peniletext>> push back as you approach your peak.
<<elseif $arousal gte 4000>>
Your <<penis>> is ruthlessly fucked by <<their>> ass. You <<peniletext>> push back against the movements.
<<else>>
Your <<penis>> is ruthlessly fucked by <<their>> ass. You <<peniletext>> push back, trying to reduce your discomfort.
<</if>>
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<<if $arousal gte 8000>>
Your <<penis>> is hungrily devoured by <<their>> ass. Driven by instinct, you <<peniletext>> push back as you approach your peak.
<<elseif $arousal gte 4000>>
Your <<penis>> is hungrily devoured by <<their>> ass. You <<peniletext>> push back against the movements.
<<else>>
Your <<penis>> is hungrily devoured by <<their>> ass. You <<peniletext>> push back, trying to reduce your discomfort.
<</if>>
<<else>>
<<if $arousal gte 8000>>
Your <<penis>> is rhythmically swallowed and regurgitated by <<their>> ass. Driven by instinct, you <<peniletext>> push back as you approach your peak.
<<elseif $arousal gte 4000>>
Your <<penis>> is rhythmically swallowed and regurgitated by <<their>> ass. You <<peniletext>> push back against the movements.
<<else>>
Your <<penis>> is rhythmically swallowed and regurgitated by <<their>> ass. You <<peniletext>> push back, trying to reduce your discomfort.
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionsotheranustake">><<nobr>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<<if $arousal gte 8000>>
Your <<penis>> is ruthlessly fucked by <<their>> ass.
<<elseif $arousal gte 4000>>
Your <<penis>> is ruthlessly fucked by <<their>> ass.
<<else>>
Your <<penis>> is ruthlessly fucked by <<their>> ass.
<</if>>
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<<if $arousal gte 8000>>
Your <<penis>> is hungrily devoured by <<their>> ass.
<<elseif $arousal gte 4000>>
Your <<penis>> is hungrily devoured by <<their>> ass.
<<else>>
Your <<penis>> is hungrily devoured by <<their>> ass.
<</if>>
<<else>>
<<if $arousal gte 8000>>
Your <<penis>> is rhythmically swallowed and regurgitated by <<their>> ass.
<<elseif $arousal gte 4000>>
Your <<penis>> is rhythmically swallowed and regurgitated by <<their>> ass.
<<else>>
Your <<penis>> is rhythmically swallowed and regurgitated by <<their>> ass.
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionsanusrub">><<nobr>>
You <<analtext>> move your hips, rubbing your <<bottom>> against <<their>> penis.
<</nobr>><</widget>>
<<widget "actionsanusthrust">><<nobr>>
<<if $enemytype is "beast">>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<<if $arousal gte 8000>>
The $beasttype savagely hammers in and out of your anus. Driven by instinct, you <<analtext>> push back as you approach your peak.
<<elseif $arousal gte 4000>>
The $beasttype savagely hammers in and out of your anus. You <<analtext>> push back against its movements.
<<else>>
The $beasttype savagely hammers in and out of your anus. You <<analtext>> move with it, trying to reduce your discomfort.
<</if>>
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<<if $arousal gte 8000>>
The $beasttype relentlessly pounds your anus. Driven by instinct, you <<analtext>> push back as you approach your peak.
<<elseif $arousal gte 4000>>
The $beasttype relentlessly pounds your anus. You <<analtext>> push back against its movements.
<<else>>
The $beasttype relentlessly pounds your anus. You <<analtext>> move with it, trying to reduce your discomfort.
<</if>>
<<else>>
<<if $arousal gte 8000>>
The $beasttype rhythmically fucks your anus. Driven by instinct, you <<analtext>> push back as you approach your peak.
<<elseif $arousal gte 4000>>
The $beasttype rhythmically fucks your anus. You <<analtext>> push back against its movements.
<<else>>
The $beasttype rhythmically fucks your anus. You <<analtext>> move with it, trying to reduce your discomfort.
<</if>>
<</if>>
<<else>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<<if $arousal gte 8000>>
Your anus is ruthlessly fucked. Driven by instinct, you <<analtext>> push back as you approach your peak.
<<elseif $arousal gte 4000>>
Your anus is ruthlessly fucked. You <<analtext>> push back against the movements.
<<else>>
Your anus is ruthlessly fucked. You <<analtext>> push back, trying to reduce your discomfort.
<</if>>
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<<if $arousal gte 8000>>
Your anus is relentlessly pounded. Driven by instinct, you <<analtext>> push back as you approach your peak.
<<elseif $arousal gte 4000>>
Your anus is relentlessly pounded. You <<analtext>> push back against the movements.
<<else>>
Your anus is relentlessly pounded. You <<analtext>> push back, trying to reduce your discomfort.
<</if>>
<<else>>
<<if $arousal gte 8000>>
Your anus yields to the repeated insertions. Driven by instinct, you <<analtext>> push back as you approach your peak.
<<elseif $arousal gte 4000>>
Your anus yields to the repeated insertions. You <<analtext>> push back against the movements.
<<else>>
Your anus yields to the repeated insertions. You <<analtext>> push back, trying to reduce your discomfort.
<</if>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionsanustake">><<nobr>>
<<if $enemytype is "beast">>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<<if $arousal gte 8000>>
The $beasttype savagely hammers in and out of your anus.
<<elseif $arousal gte 4000>>
The $beasttype savagely hammers in and out of your anus.
<<else>>
The $beasttype savagely hammers in and out of your anus.
<</if>>
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<<if $arousal gte 8000>>
The $beasttype relentlessly pounds your anus.
<<elseif $arousal gte 4000>>
The $beasttype relentlessly pounds your anus.
<<else>>
The $beasttype relentlessly pounds your anus.
<</if>>
<<else>>
<<if $arousal gte 8000>>
The $beasttype rhythmically fucks your anus.
<<elseif $arousal gte 4000>>
The $beasttype rhythmically fucks your anus.
<<else>>
The $beasttype rhythmically fucks your anus.
<</if>>
<</if>>
<<else>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<<if $arousal gte 8000>>
Your anus is ruthlessly fucked.
<<elseif $arousal gte 4000>>
Your anus is ruthlessly fucked.
<<else>>
Your anus is ruthlessly fucked.
<</if>>
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<<if $arousal gte 8000>>
Your anus is relentlessly pounded.
<<elseif $arousal gte 4000>>
Your anus is relentlessly pounded.
<<else>>
Your anus is relentlessly pounded.
<</if>>
<<else>>
<<if $arousal gte 8000>>
Your anus yields to the repeated insertions.
<<elseif $arousal gte 4000>>
Your anus yields to the repeated insertions.
<<else>>
Your anus yields to the repeated insertions.
<</if>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionsshaftrub">><<nobr>>
<<if $enemytype is "beast">>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
You <<handtext>> hold <<his>> penis in your hand as <<he>> furiously humps against it.
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
You <<handtext>> hold the penis in your hand as <<he>> humps against it.
<<else>>
You <<handtext>> hold and rub the penis in your hand.
<</if>>
<<else>>
<<if $consensual is 1>>
<<if $arousal lte 6000>>
You keep <<their>> penis held firmly in your hand as you <<handtext>> stroke and work the shaft.
<<else>>
You <<handtext>> hold and rub <<their>> shaft in your hand.
<</if>>
<<else>>
You <<handtext>> occupy <<their>> penis with your hand, working the shaft with your fingers.
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionsvaginaescape">><<nobr>>
<<if $enemytype is "beast">>
<<if $enemyanger lte 20>>
<span class="blue">You shift your pelvis, moving your <<pussy>> away from the beast's probing before it can penetrate you.</span> It doesn't give up however.
<<elseif $enemyanger lte 100>>
<span class="blue">You shift your pelvis, moving your <<pussy>> away from the beast's incessant probing before it can penetrate you.</span> It snarls in frustration.
<<else>>
<span class="blue">You shift your pelvis, moving your <<pussy>> away from the beast's savage probing before it can penetrate you.</span> It frenziedly tries to regain purchase, furious at its attempt to breed being impeded.
<</if>>
<<else>>
<<if $pain lte 20>>
<span class="blue">You shift your pelvis, moving your <<pussy>> away from <<their>> penis.</span>
<<elseif $pain lte 60>>
<span class="blue">You shift your pelvis, moving your <<pussy>> away from <<their>> penis.</span>
<<else>>
<span class="blue">You shift your pelvis in desperation, moving your <<pussy>> away from <<their>> penis.</span>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "actionspenisescape">><<nobr>>
<<if $pain lte 20>>
<span class="blue">You shift your pelvis, moving your <<penis>> away from <<their>> pussy.</span>
<<elseif $pain lte 60>>
<span class="blue">You shift your pelvis, moving your <<penis>> away from <<their>> pussy.</span>
<<else>>
<span class="blue">You shift your pelvis in desperation, moving your <<penis>> away from <<their>> pussy.</span>
<</if>>
<</nobr>><</widget>>
<<widget "actionsotheranusescape">><<nobr>>
<<if $pain lte 20>>
<span class="blue">You shift your pelvis, moving your <<penis>> away from <<their>> ass.</span>
<<elseif $pain lte 60>>
<span class="blue">You shift your pelvis, moving your <<penis>> away from <<their>> ass.</span>
<<else>>
<span class="blue">You shift your pelvis in desperation, moving your <<penis>> away from <<their>> ass.</span>
<</if>>
<</nobr>><</widget>>
<<widget "actionsanusescape">><<nobr>>
<<if $enemytype is "beast">>
<<if $enemyanger lte 20>>
<span class="blue">You shift your pelvis, moving your <<bottom>> away from the beast's probing before it can penetrate you.</span> It doesn't give up however.
<<elseif $enemyanger lte 100>>
<span class="blue">You shift your pelvis, moving your <<bottom>> away from the beast's incessant probing before it can penetrate you.</span> It snarls in frustration.
<<else>>
<span class="blue">You shift your pelvis, moving your <<bottom>> away from the beast's savage probing before it can penetrate you.</span> It frenziedly tries to regain purchase, furious at its attempt to breed being impeded.
<</if>>
<<else>>
<<if $pain lte 20>>
<span class="blue">You shift your pelvis, moving your <<bottom>> away from <<their>> penis.</span>
<<elseif $pain lte 60>>
<span class="blue">You shift your pelvis, moving your <<bottom>> away from <<their>> penis.</span>
<<else>>
<span class="blue">You shift your pelvis in desperation, moving your <<bottom>> away from <<their>> penis.</span>
<</if>>
<</if>>
<</nobr>><</widget>>
:: Widgets Speech [widget]
<<widget "cumspeech">><<nobr>>
<<set $rng to random(1, 100)>>
<<if $playergenderappearance is "m">>
<<if $devstate gte 1>>
<<if $orgasmcount gte 24 and $speechorgasmnocumcount is 0>><<set $speechorgasmnocumcount += 1>>
<<He>> speaks. "You climaxed but nothing came out! What's wrong with you?"
<<elseif $speechorgasmnocumcount gte 1>>
<<if $speechorgasmrepeat is 0>><<set $speechorgasmrepeat += 1>>
<<if $rng lte 35>>
<<He>> speaks. "Have you been over-milked or were you always this pathetic?"
<<elseif $rng lte 70>>
<<He>> speaks. "You better not be faking it."
<<else>>
<<He>> speaks. "You should be embarrassed by your lack of ejaculate."
<</if>>
<<else>><<set $speechorgasmrepeat += 1>>
<<if $rng lte 35>>
<<He>> speaks. "I think we've worn <<phim>> out already."
<<elseif $rng lte 70>>
<<He>> speaks. "Still nothing coming out. This is disappointing."
<<else>>
<<He>> speaks. "Maybe if we're a bit rougher we'll get some semen to come out?"
<</if>>
<</if>>
<<elseif $orgasmcount gte 18 and $speechorgasmweakcumcount is 0>><<set $speechorgasmweakcumcount += 1>>
<<He>> speaks. "Is that really all the cum you can manage?"
<<else>>
<<if $speechorgasmcount is 1>>
<<if $speechorgasmrepeat is 1>><<set $speechorgasmrepeat += 1>>
<<He>> speaks. "You're cumming! That's it, let it out, don't hold any back."
<<else>><<set $speechorgasmrepeat += 1>>
<<He>> speaks. "<<pShe>> really is cumming!"
<</if>>
<<elseif $speechorgasmcount is 2>>
<<if $speechorgasmrepeat is 0>><<set $speechorgasmrepeat += 1>>
<<He>> speaks. "You're releasing even more cum! Have you no shame?"
<<else>><<set $speechorgasmrepeat += 1>>
<<He>> speaks. "Cumming again? <<pShe>> is so dirty!"
<</if>>
<<elseif $speechorgasmcount is 3>>
<<if $speechorgasmrepeat is 0>><<set $speechorgasmrepeat += 1>>
<<He>> speaks. "Don't try to hide it, you like being milked of your cum."
<<else>><<set $speechorgasmrepeat += 1>>
<<He>> speaks. "<<pShe>> is cumming again? This is great!"
<</if>>
<<elseif $speechorgasmcount is 4>>
<<if $speechorgasmrepeat is 0>><<set $speechorgasmrepeat += 1>>
<<He>> speaks. "Let out all your precious dick-milk."
<<else>><<set $speechorgasmrepeat += 1>>
<<He>> speaks. "We'll milk <<pHim>> dry at this rate."
<</if>>
<<elseif $speechorgasmcount is 5>>
<<if $speechorgasmrepeat is 0>><<set $speechorgasmrepeat += 1>>
<<He>> speaks. "You've cum so much! You're making a real mess you know."
<<else>><<set $speechorgasmrepeat += 1>>
<<He>> speaks. "I want to keep some of <<pher>> cum for later."
<</if>>
<<else>>
<<if $speechorgasmrepeat is 0>><<set $speechorgasmrepeat += 1>>
<<He>> speaks. "So much cum, I don't know whether to be impressed or embarrassed for you."
<<else>><<set $speechorgasmrepeat += 1>>
<<He>> speaks. "<<pShe>> has cum so much. Is <<pshe>> going to be okay?"
<</if>>
<</if>>
<</if>>
<<else>>
<<if $speechorgasmcount is 1>>
<<if $speechorgasmrepeat is 0>><<set $speechorgasmrepeat += 1>>
<<He>> speaks. "You're cumming! But there's no actual cum, I guess you're still too young."
<<else>><<set $speechorgasmrepeat += 1>>
<<He>> speaks. "<<pShe>> might be too young to ejaculate, but look at <<pher>> little dick twitch!"
<</if>>
<<elseif $speechorgasmcount is 2>>
<<if $speechorgasmrepeat is 0>><<set $speechorgasmrepeat += 1>>
<<He>> speaks. "Another orgasm already? You're really sensitive!"
<<else>><<set $speechorgasmrepeat += 1>>
<<He>> speaks. "<<pHer>> orgasmic spasms are so cute!"
<</if>>
<<elseif $speechorgasmcount is 3>>
<<if $speechorgasmrepeat is 0>><<set $speechorgasmrepeat += 1>>
<<He>> speaks. "I see you've reached your peak again, you dirty <<girlstop>>"
<<else>><<set $speechorgasmrepeat += 1>>
<<He>> speaks. "All this attention is getting <<phim>> off really easily."
<</if>>
<<elseif $speechorgasmcount is 4>>
<<if $speechorgasmrepeat is 0>><<set $speechorgasmrepeat += 1>>
<<He>> speaks. "Don't worry, I'm sure you'll be a fountain of cum one day."
<<else>><<set $speechorgasmrepeat += 1>>
<<He>> speaks. "The look on <<pher>> face when <<pshe>> cums is priceless."
<</if>>
<<elseif $speechorgasmcount is 5>>
<<if $speechorgasmrepeat is 0>><<set $speechorgasmrepeat += 1>>
<<He>> speaks. "I'll never get tired of your orgasms."
<<else>><<set $speechorgasmrepeat += 1>>
<<He>> speaks. "I didn't know making a little <<girl>> cum over and over would be so much fun!"
<</if>>
<<else>>
<<if $speechorgasmrepeat is 0>><<set $speechorgasmrepeat += 1>>
<<He>> speaks. "Just when I think you can't possibly have any left in you, you spasm again!"
<<else>><<set $speechorgasmrepeat += 1>>
<<He>> speaks. "Careful not to overdo it, <<pshe>> might break if <<pshe>> cums too much."
<</if>>
<</if>>
<</if>>
<<else>>
<<if $speechorgasmcount is 1>>
<<if $speechorgasmrepeat is 0>><<set $speechorgasmrepeat += 1>>
<<He>> speaks. "I knew you'd enjoy it, your spasms don't lie."
<<else>><<set $speechorgasmrepeat += 1>>
<<He>> speaks. "<<pShe>> spasms so delightfully when <<pshe>> cums."
<</if>>
<<elseif $speechorgasmcount is 2>>
<<if $speechorgasmrepeat is 0>><<set $speechorgasmrepeat += 1>>
<<He>> speaks. "How does this orgasm feel? Better than the last I bet."
<<else>><<set $speechorgasmrepeat += 1>>
<<He>> speaks. "<<pHer>> pussy is absolutely drenched!"
<</if>>
<<elseif $speechorgasmcount is 3>>
<<if $speechorgasmrepeat is 0>><<set $speechorgasmrepeat += 1>>
<<He>> speaks. "You're cumming again? You're such a dirty slut!"
<<else>><<set $speechorgasmrepeat += 1>>
<<He>> speaks. "<<pShe>> is so very sensitive."
<</if>>
<<elseif $speechorgasmcount is 4>>
<<if $speechorgasmrepeat is 0>><<set $speechorgasmrepeat += 1>>
<<He>> speaks. "I hope you remember me, what with all these orgasms I'm giving you."
<<else>><<set $speechorgasmrepeat += 1>>
<<He>> speaks. "<<pShe>> is cumming again? This is great."
<</if>>
<<elseif $speechorgasmcount is 5>>
<<if $speechorgasmrepeat is 0>><<set $speechorgasmrepeat += 1>>
<<He>> speaks. "You're cumming over and over again, you must be quite the slut!"
<<else>><<set $speechorgasmrepeat += 1>>
<<He>> speaks. "<<pShe>> is cumming again! Such a nasty bitch."
<</if>>
<<else>>
<<if $speechorgasmrepeat is 0>><<set $speechorgasmrepeat += 1>>
<<He>> speaks. "Making a <<girl>> cum repeatedly is so much fun."
<<else>><<set $speechorgasmrepeat += 1>>
<<He>> speaks. "Careful not to overdo it, <<pshe>> might break if <<pshe>> cums too much."
<</if>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "combatspeech">><<nobr>>
<<set $rng to random(1, 100)>>
<<if $speechcrossdressangry is 1>>
<<if $rng gte 81>>
<<He>> glares at your newly-exposed <<genitalsstop>> "You thought you could trick me? Time to show you your place."
<<elseif $rng gte 61>>
<<He>> glares at your newly-exposed <<genitalsstop>> "I bet you're real happy you tricked me. You won't be smiling when I'm through with you."
<<elseif $rng gte 41>>
<<He>> glares at your newly-exposed <<genitalsstop>> "Fucking <<bitchcomma>> I'm gonna fuck you like you're a <<if $playergender is "m">>girl<<else>>boy<</if>> anyway."
<<elseif $rng gte 21>>
<<He>> glares at your newly-exposed <<genitalsstop>> "You think that's funny? I'm gonna fuck you senseless anyway."
<<else>>
<<He>> glares at your newly-exposed <<genitalsstop>> "You'll pay for this, slut."
<</if>>
<<elseif $speechcrossdressaroused is 1>>
<<if $rng gte 81>>
<<He>> gazes with hunger at your newly exposed <<genitalsstop>> "What a treat!"
<<elseif $rng gte 61>>
<<He>> gazes with hunger at your newly exposed <<genitalsstop>> "You're full of surprises."
<<elseif $rng gte 41>>
<<He>> gazes with hunger at your newly exposed <<genitalsstop>> "Nothing gets me going like a crossdressing slut."
<<elseif $rng gte 21>>
<<He>> gazes with hunger at your newly exposed <<genitalsstop>> "It's like unwrapping a present."
<<else>>
<<He>> gazes with hunger at your newly exposed <<genitalsstop>> "Sneaky slut, I know just what to do with you."
<</if>>
<<elseif $speechcrossdressshock is 1>>
<<if $rng gte 81>>
<<He>> stares at your <<genitals>> in shock. "I'm not normally into this sort of thing. You're pretty cute though."
<<elseif $rng gte 61>>
<<He>> stares at your <<genitals>> in shock. "I never thought it could look so tasty."
<<elseif $rng gte 41>>
<<He>> stares at your <<genitals>> in shock. "You're a sneaky one."
<<elseif $rng gte 21>>
<<He>> stares at your <<genitals>> in shock. "This is fine too."
<<else>>
<<He>> stares at your <<genitals>> in shock. "You had me completely fooled."
<</if>>
<<elseif $speechcrossdressdisappointed is 1>>
<<if $rng gte 81>>
<<He>> looks at your <<genitals>> and sighs. "This isn't what I signed up for."
<<elseif $rng gte 61>>
<<He>> looks at your <<genitals>> and sighs. "I've come this far I guess."
<<elseif $rng gte 41>>
<<He>> looks at your <<genitals>> and sighs. "Cute, but that isn't what I wanted."
<<elseif $rng gte 21>>
<<He>> looks at your <<genitals>> and sighs. "I bet you think this is funny."
<<else>>
<<He>> looks at your <<genitals>> and sighs. "Why do I keep falling for this?"
<</if>>
<<elseif $speechgenitals is 1>>
<<if $playergenderappearance is $playergender>>
<<if $playergender is "m">>
<<if $devstate gte 1>>
<<if $enemyanger lte 20>>
<<He>> <<admires>> your newly-exposed <<genitalsstop>> "Your dick looks delicious!"
<<elseif $enemyanger lte 100>>
<<He>> <<admires>> your newly-exposed <<genitalsstop>> "You're really vulnerable now, you'd better not piss me off."
<<else>>
<<He>> <<admires>> your newly-exposed <<genitalsstop>> "There, now you're exposed like the slut you are."
<</if>>
<<else>>
<<if $enemyanger lte 20>>
<<He>> <<admires>> your newly-exposed <<genitalsstop>> "Your little cock is so cute!"
<<elseif $enemyanger lte 100>>
<<He>> laughs at your newly-exposed <<genitalsstop>> "It's so small!"
<<else>>
<<He>> <<admires>> your newly-exposed <<genitalsstop>> "I knew it wouldn't be very impressive, but this is just pathetic."
<</if>>
<</if>>
<<else>>
<<if $devstate is 0>>
<<if $enemyanger lte 20>>
<<He>> <<admires>> your newly-exposed <<genitalsstop>> "Aww, your little pussy is so cute!"
<<elseif $enemyanger lte 100>>
<<He>> <<admires>> your newly-exposed <<genitalsstop>> "Your pussy is so youthful, I wonder how much it could take."
<<else>>
<<He>> <<admires>> your newly-exposed <<genitalsstop>> "I can see everything now, whore."
<</if>>
<<else>>
<<if $enemyanger lte 20>>
<<He>> <<admires>> your newly-exposed <<genitalsstop>> "Your pussy is so enticing!"
<<elseif $enemyanger lte 100>>
<<He>> <<admires>> your newly-exposed <<genitalsstop>> "Don't be shy, a pussy like this was made to be exposed."
<<else>>
<<He>> <<admires>> your newly-exposed <<genitalsstop>> "There, now you're exposed like the slut you are."
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $speechbreasts is 1>>
<<if $playergenderappearance is $playergender>>
<<if $playergender is "m">>
<<if $breastsize lte 0>>
<<He>> <<admires>> your newly-exposed <<breastsstop>>
<<elseif $breastsize lte 1>>
<<He>> <<admires>> your newly-exposed <<breastsstop>>
<<elseif $breastsize lte 2>>
<<He>> <<admires>> your newly-exposed <<breastsstop>> "That's a nice pair of bitch-tits you've got there."
<<elseif $breastsize lte 4>>
<<He>> <<admires>> your newly-exposed <<breastsstop>> "You have breasts like a woman!"
<<else>>
<<He>> <<admires>> your newly-exposed <<breastsstop>> "Those things are gigantic! Maybe you'll share some boy-milk."
<</if>>
<<else>>
<<if $breastsize lte 0>>
<<He>> <<admires>> your newly-exposed <<breastsstop>> "Don't be ashamed about being flat, it's really cute."
<<elseif $breastsize lte 1>>
<<He>> <<admires>> your newly-exposed <<breastsstop>> "Nothing quite like developing breasts. So lewd and cute."
<<elseif $breastsize lte 2>>
<<He>> <<admires>> your newly-exposed <<breastsstop>> "Your small breasts are so lewd."
<<elseif $breastsize lte 4>>
<<He>> <<admires>> your newly-exposed <<breastsstop>> "Don't be ashamed about having your breasts displayed like this, it's what they're for."
<<else>>
<<He>> <<admires>> your newly-exposed <<breastsstop>> "They're so big! You'd make a fine cow."
<</if>>
<</if>>
<</if>>
<<elseif $speechscream is 1>><<set $speechscream to 0>>
<<if $rng lte 20>>
<<He>> speaks. "Shut your fucking mouth."
<<elseif $rng lte 40>>
<<He>> speaks. "Are you trying to make me hurt you? Be quiet!"
<<elseif $rng lte 60>>
<<He>> speaks. "Things are going to be difficult for you if you keep resisting."
<<elseif $rng lte 80>>
<<He>> speaks. "Stupid slut, no one's going to help you."
<<else>>
<<He>> speaks. "Crying for help? No one gives a shit."
<</if>>
<<elseif $speechvaginaescape is 1>><<set $speechvaginaescape to 0>>
<<if $enemyanger lte 20>>
<<if $rng lte 35>>
<<He>> speaks. "I can't enjoy you properly if you keep squirming around."
<<elseif $rng lte 70>>
<<He>> speaks. "Be still now."
<<else>>
<<He>> speaks. "You're a feisty little thing!"
<</if>>
<<elseif $enemyanger lte 100>>
<<if $rng lte 35>>
<<He>> speaks. "Keep pretending you don't want to be fucked, I'm not fooled."
<<elseif $rng lte 70>>
<<He>> speaks. "Stop resisting."
<<else>>
<<He>> speaks. "I love it when you squirm."
<</if>>
<<else>>
<<if $rng lte 35>>
<<He>> speaks. "Do you think that will stop me, bitch?"
<<elseif $rng lte 70>>
<<He>> speaks. "The sooner you accept that you're nothing but a cock-sleeve the easier it'll be for you."
<<else>>
<<He>> speaks. "Your pussy is mine slut, stop fighting it."
<</if>>
<</if>>
<<elseif $speechpenisescape is 1>><<set $speechpenisescape to 0>>
<<if $enemyanger lte 20>>
<<if $rng lte 35>>
<<He>> speaks. "I can't enjoy you properly if you keep squirming around."
<<elseif $rng lte 70>>
<<He>> speaks. "Be still now."
<<else>>
<<He>> speaks. "You're a feisty little thing!"
<</if>>
<<elseif $enemyanger lte 100>>
<<if $rng lte 35>>
<<He>> speaks. "Keep pretending you don't want to be fucked, I'm not fooled."
<<elseif $rng lte 70>>
<<He>> speaks. "Stop resisting."
<<else>>
<<He>> speaks. "I love it when you squirm."
<</if>>
<<else>>
<<if $rng lte 35>>
<<He>> speaks. "Do you think that will stop me, bitch?"
<<elseif $rng lte 70>>
<<He>> speaks. "The sooner you accept that you're nothing but a piece of fuckmeat the easier it'll be for you."
<<else>>
<<He>> speaks. "Your dick is mine slut, stop fighting it."
<</if>>
<</if>>
<<elseif $speechotheranusescape is 1>><<set $speechotheranusescape to 0>>
<<if $enemyanger lte 20>>
<<if $rng lte 35>>
<<He>> speaks. "I can't enjoy you properly if you keep squirming around."
<<elseif $rng lte 70>>
<<He>> speaks. "Be still now."
<<else>>
<<He>> speaks. "You're a feisty little thing!"
<</if>>
<<elseif $enemyanger lte 100>>
<<if $rng lte 35>>
<<He>> speaks. "Keep pretending you don't want to be fucked, I'm not fooled."
<<elseif $rng lte 70>>
<<He>> speaks. "Stop resisting."
<<else>>
<<He>> speaks. "I love it when you squirm."
<</if>>
<<else>>
<<if $rng lte 35>>
<<He>> speaks. "Do you think that will stop me, bitch?"
<<elseif $rng lte 70>>
<<He>> speaks. "The sooner you accept that you're nothing but a piece of fuckmeat the easier it'll be for you."
<<else>>
<<He>> speaks. "Your dick is mine slut, stop fighting it."
<</if>>
<</if>>
<<elseif $speechanusescape is 1>><<set $speechanusescape to 0>>
<<if $enemyanger lte 20>>
<<if $rng lte 35>>
<<He>> speaks. "I can't enjoy you properly if you keep squirming around."
<<elseif $rng lte 70>>
<<He>> speaks. "Be still now."
<<else>>
<<He>> speaks. "You're a feisty little thing!"
<</if>>
<<elseif $enemyanger lte 100>>
<<if $rng lte 35>>
<<He>> speaks. "Keep pretending you don't want to be fucked, I'm not fooled."
<<elseif $rng lte 70>>
<<He>> speaks. "Stop resisting."
<<else>>
<<He>> speaks. "I love it when you squirm."
<</if>>
<<else>>
<<if $rng lte 35>>
<<He>> speaks. "Do you think that will stop me, bitch?"
<<elseif $rng lte 70>>
<<He>> speaks. "The sooner you accept that you're nothing but a cock-sleeve the easier it'll be for you."
<<else>>
<<He>> speaks. "Your ass is mine slut, stop fighting it."
<</if>>
<</if>>
<<elseif $speechpenispenetrated is 1>>
<<if $devstate gte 1>>
<<if $enemyanger lte 20>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<<He>> is lost in the moment. "Yes! Yes! Give it to me! AH!"
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<<He>> speaks hushedly. "I've been needing this so badly."
<<else>>
<<He>> speaks. "You feel so good inside me."
<</if>>
<<elseif $enemyanger lte 100>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<<He>> is lost in the moment. "UHH! That's it...Not long now... AH!"
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<<He>> speaks hushedly. "That's it right there, good <<girlstop>>"
<<else>>
<<He>> speaks "I've been waiting too long for this, don't even think about stopping!"
<</if>>
<<else>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<<He>> is lost in the moment. "You... Stupid... AHH!"
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<<He>> mocks you. "What's it like having your dick dominated like this?"
<<else>>
<<He>> mocks you. "You're right where you belong."
<</if>>
<</if>>
<<else>>
<<if $enemyanger lte 20>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<<He>> is lost in the moment. "Oh! You... I... AHHH!"
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<<He>> speaks hushedly. "You're so cute when you're being fucked."
<<else>>
<<He>> speaks. "Just relax, I'll look after your dick."
<</if>>
<<elseif $enemyanger lte 100>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<<He>> is lost in the moment. "Keep... going... not long now."
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<<He>> speaks. "Nothing like a the cock of a little <<girlstop>>"
<<else>>
<<He>> speaks. "You like being inside me, don't you?"
<</if>>
<<else>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<<He>> is lost in the moment. "You... Stupid... AHH!"
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<<He>> speaks hushedly. "You make a good fucktoy."
<<else>>
<<He>> speaks. "You're mine now, <<girlstop>>"
<</if>>
<</if>>
<</if>>
<<elseif $speechotheranuspenetrated is 1>>
<<if $devstate gte 1>>
<<if $enemyanger lte 20>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<<He>> is lost in the moment. "Yes! Yes! Give it to me! Fill me up!"
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<<He>> speaks hushedly. "I've been needing this so badly."
<<else>>
<<He>> speaks. "You feel so good inside me."
<</if>>
<<elseif $enemyanger lte 100>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<<He>> is lost in the moment. "UHH! That's it...Not long now... AH!"
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<<He>> speaks hushedly. "That's it right there, good <<girlstop>>"
<<else>>
<<He>> speaks "I've been waiting too long for this, don't even think about stopping!"
<</if>>
<<else>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<<He>> is lost in the moment. "You... Stupid... AHH!"
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<<He>> mocks you. "What's it like having your dick dominated like this?"
<<else>>
<<He>> mocks you. "You're right where you belong."
<</if>>
<</if>>
<<else>>
<<if $enemyanger lte 20>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<<He>> is lost in the moment. "Oh! You... I... AHHH!"
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<<He>> speaks hushedly. "You're so cute when you're being fucked."
<<else>>
<<He>> speaks. "Just relax, I'll look after your dick."
<</if>>
<<elseif $enemyanger lte 100>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<<He>> is lost in the moment. "Keep... going... not long now."
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<<He>> speaks. "Nothing like a the cock of a little <<girlstop>>"
<<else>>
<<He>> speaks. "You like being inside me, don't you?"
<</if>>
<<else>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<<He>> is lost in the moment. "You... Stupid... AHH!"
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<<He>> speaks hushedly. "You make a good fucktoy."
<<else>>
<<He>> speaks. "You're mine now, <<girlstop>>"
<</if>>
<</if>>
<</if>>
<<elseif $speechvaginapenetrated is 1>>
<<if $devstate gte 1>>
<<if $enemyanger lte 20>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<<He>> is lost in the moment. "I'm gonna fill you up soon, I hope you're ready!"
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<<He>> speaks. "You feel so nice around my dick."
<<else>>
<<He>> speaks. "Your pussy is so warm."
<</if>>
<<elseif $enemyanger lte 100>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<<He>> is lost in the moment. "That's it! Take it, whore!"
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<<He>> speaks hushedly. "Good <<girlstop>>"
<<else>>
<<He>> speaks "Your body is welcoming me at least."
<</if>>
<<else>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<<He>> is lost in the moment. "Take it! Take it all you worthless slut!"
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<<He>> mocks you. "What's it like having your pussy dominated like this?"
<<else>>
<<He>> mocks you. "You're right where you belong."
<</if>>
<</if>>
<<else>>
<<if $enemyanger lte 20>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<<He>> is lost in the moment. "Your little pussy is so good!"
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<<He>> speaks hushedly. "You're so cute when you're being fucked."
<<else>>
<<He>> speaks. "Just relax, I'll look after you."
<</if>>
<<elseif $enemyanger lte 100>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<<He>> is lost in the moment. "Keep... going... not long now."
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<<He>> speaks. "Nothing like a the cunt of a little <<girlstop>>"
<<else>>
<<He>> speaks. "You like being filled like this, don't you?"
<</if>>
<<else>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<<He>> is lost in the moment. "Don't act like you didn't want this, I can feel you squeezing my dick, begging for my cum."
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<<He>> speaks hushedly. "This is your place, remember that."
<<else>>
<<He>> speaks. "You're mine now, <<girlstop>>"
<</if>>
<</if>>
<</if>>
<<elseif $speechanuspenetrated is 1>>
<<if $devstate gte 1>>
<<if $enemyanger lte 20>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<<He>> is lost in the moment. "I'm gonna fill you up soon, I hope you're ready!"
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<<He>> speaks. "You feel so nice around my dick."
<<else>>
<<He>> speaks. "Your butt is so warm."
<</if>>
<<elseif $enemyanger lte 100>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<<He>> is lost in the moment. "That's it! Take it, whore!"
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<<He>> speaks hushedly. "Good <<girlstop>>"
<<else>>
<<He>> speaks "Your body is welcoming me at least."
<</if>>
<<else>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<<He>> is lost in the moment. "Take it! Take it all you worthless slut!"
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<<He>> mocks you. "What's it like having your ass dominated like this?"
<<else>>
<<He>> mocks you. "You're right where you belong."
<</if>>
<</if>>
<<else>>
<<if $enemyanger lte 20>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<<He>> is lost in the moment. "Your little butt is so tight!"
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<<He>> speaks hushedly. "You're so cute when you're being fucked."
<<else>>
<<He>> speaks. "Just relax, I'll look after you."
<</if>>
<<elseif $enemyanger lte 100>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<<He>> is lost in the moment. "Keep... going... not long now."
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<<He>> speaks. "Nothing like a little <<girl>> fucktoy."
<<else>>
<<He>> speaks. "You like being filled like this, don't you?"
<</if>>
<<else>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<<He>> is lost in the moment. "Don't act like you didn't want this, I can feel you squeezing my dick, begging for my cum."
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<<He>> speaks hushedly. "This is your place, remember that."
<<else>>
<<He>> speaks. "You're mine now, <<girlstop>>"
<</if>>
<</if>>
<</if>>
<<elseif $speechmouthpenetrated is 1>>
<<if $devstate gte 1>>
<<if $enemyanger lte 20>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<<He>> is lost in the moment. "I'm gonna fill you up soon, I hope you're ready!"
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<<He>> speaks. "You feel so nice around my dick."
<<else>>
<<He>> speaks. "Your mouth is so warm."
<</if>>
<<elseif $enemyanger lte 100>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<<He>> is lost in the moment. "That's it! Take it, whore!"
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<<He>> speaks hushedly. "Good <<girlstop>>"
<<else>>
<<He>> speaks "Your throat is welcoming me at least."
<</if>>
<<else>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<<He>> is lost in the moment. "Take it! Take it all you worthless slut!"
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<<He>> mocks you. "What's it like being dominated like this?"
<<else>>
<<He>> mocks you. "You're right where you belong."
<</if>>
<</if>>
<<else>>
<<if $enemyanger lte 20>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<<He>> is lost in the moment. "Keep going, I'm almost there!"
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<<He>> speaks hushedly. "You're so cute with your lips around my dick."
<<else>>
<<He>> speaks. "Just relax, I'll look after you."
<</if>>
<<elseif $enemyanger lte 100>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<<He>> is lost in the moment. "Keep... going... not long now."
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<<He>> speaks. "Nothing like a little <<girl>> as a fucktoy."
<<else>>
<<He>> speaks. "You like being filled like this, don't you?"
<</if>>
<<else>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<<He>> is lost in the moment. "Don't act like you didn't want this, your mouth was made for it."
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<<He>> speaks hushedly. "This is your place, remember that."
<<else>>
<<He>> speaks. "You're mine now, <<girlstop>>"
<</if>>
<</if>>
<</if>>
<<elseif $speechvaginaimminent is 1>>
<<if $vaginalvirginity is 1>>
<<if $enemyanger lte 60>>
<<He>> speaks. "My dick is pressing against your virgin pussy... I could deflower you at any moment."
<<else>>
<<He>> speaks. "I'm an inch away from taking your virginity, bitch."
<</if>>
<<else>>
<<if $enemyanger lte 60>>
<<He>> speaks. "Just having the tip pressing against you like this is driving me mad!"
<<else>>
<<He>> speaks. "I hope your pussy is ready, I sure am."
<</if>>
<</if>>
<<elseif $speechpenisimminent is 1>>
<<if $penilevirginity is 1>>
<<if $enemyanger lte 60>>
<<He>> speaks. "My pussy is pressing against your virgin dick... I could deflower you at any moment."
<<else>>
<<He>> speaks. "I'm an inch away from taking your virginity, bitch."
<</if>>
<<else>>
<<if $enemyanger lte 60>>
<<He>> speaks. "Just having the tip pressing against me like this is driving me mad!"
<<else>>
<<He>> speaks. "I hope your dick is ready, I sure am."
<</if>>
<</if>>
<<elseif $speechotheranusimminent is 1>>
<<if $penilevirginity is 1>>
<<if $enemyanger lte 60>>
<<He>> speaks. "My ass is pressing against your virgin dick... I could deflower you at any moment."
<<else>>
<<He>> speaks. "I'm an inch away from taking your virginity, bitch."
<</if>>
<<else>>
<<if $enemyanger lte 60>>
<<He>> speaks. "Just having the tip pressing against me like this is driving me mad!"
<<else>>
<<He>> speaks. "I hope your dick is ready, I sure am."
<</if>>
<</if>>
<<elseif $speechanusimminent is 1>>
<<if $analvirginity is 1>>
<<if $enemyanger lte 60>>
<<He>> speaks. "My dick is pressing against your virgin ass... It's gonna be a tight fit!"
<<else>>
<<He>> speaks. "I'm an inch away from taking your anal virginity, bitch."
<</if>>
<<else>>
<<if $enemyanger lte 60>>
<<He>> speaks. "Just having the tip pressing against you like this is driving me mad!"
<<else>>
<<He>> speaks. "I hope your ass is ready, my dick sure is!"
<</if>>
<</if>>
<<elseif $speechmouthimminent is 1>>
<<if $oralvirginity is 1>>
<<if $enemyanger lte 60>>
<<He>> speaks. "You've never tasted dick before have you? You're in for a treat!"
<<else>>
<<He>> speaks. "You've never tasted dick before have you? If you bite me, I'll fuck you up."
<</if>>
<<else>>
<<if $enemyanger lte 60>>
<<He>> speaks. "Just having the tip pressing against you like this is driving me mad!"
<<else>>
<<He>> speaks. "Open wide, whore."
<</if>>
<</if>>
<<elseif $speechapologise is 1>>
<<if $enemyanger lte 20>>
<<He>> speaks. "How could I be mad at a little hottie like you?"
<<elseif $enemyanger lte 100>>
<<He>> speaks. "I can think of a few ways you can make it up to me."
<<else>>
<<He>> speaks. "You better not be lying to me, or you'll be real sorry."
<</if>>
<<elseif $speechvaginaentrance is 1>>
<<if $playergenderappearance is "m">>
<<if $enemyanger lte 20>>
<<He>> speaks. "Don't worry, I'll be gentle with your cock."
<<elseif $enemyanger lte 100>>
<<He>> speaks. "I can't wait to fuck you."
<<else>>
<<He>> speaks. "Don't try to squirm. You're mine."
<</if>>
<<else>>
<<if $enemyanger lte 20>>
<<He>> speaks. "Don't worry, I'll be gentle with your pussy."
<<elseif $enemyanger lte 100>>
<<He>> speaks. "I can't wait to fuck you."
<<else>>
<<He>> speaks. "Don't try to squirm away. You're mine."
<</if>>
<</if>>
<<elseif $speechanusentrance is 1>>
<<if $enemyanger lte 20>>
<<He>> speaks. "Don't worry, I'll be gentle with your ass."
<<elseif $enemyanger lte 100>>
<<He>> speaks. "I can't wait to fuck you."
<<else>>
<<He>> speaks. "Don't try to squirm away, your little ass is mine."
<</if>>
<<elseif $speechmouthentrance is 1>>
<<if $enemyanger lte 20>>
<<He>> speaks. "Let's see that tongue of yours."
<<elseif $enemyanger lte 100>>
<<He>> speaks. "I can't wait to feel your tongue on my dick."
<<else>>
<<He>> speaks. "I want your lips around my dick. Now."
<</if>>
<<elseif $speechpenisentrance is 1>>
<<if $playergenderappearance is "f">>
<<if $enemyanger lte 20>>
<<He>> speaks. "Your pussy is so close to mine, the anticipation is almost too much!"
<<elseif $enemyanger lte 100>>
<<He>> speaks. "Your pussy is eager for mine, don't try to hide it."
<<else>>
<<He>> speaks. "I hope you satisfy me, for your sake."
<</if>>
<<else>>
<<if $enemyanger lte 20>>
<<He>> speaks. "Your dick is so close to my pussy, the anticipation is almost too much!"
<<elseif $enemyanger lte 100>>
<<He>> speaks. "Your dick is eager for my pussy, don't try to hide it."
<<else>>
<<He>> speaks. "I hope you satisfy me, for your sake."
<</if>>
<</if>>
<<elseif $speechotheranusentrance is 1>>
<<if $enemyanger lte 20>>
<<He>> speaks. "Is my ass making you feel good?"
<<elseif $enemyanger lte 100>>
<<He>> speaks. "Your dick is eager for my ass, don't try to hide it."
<<else>>
<<He>> speaks. "I hope you satisfy me, for your sake."
<</if>>
<<elseif $speechvaginawithhold is 1>>
<<if $enemyanger lte 20>>
<<He>> speaks. "I really wish I could fuck you, guess I'll have to make do."
<<elseif $enemyanger lte 100>>
<<He>> speaks. "Are you sure you don't want my dick? Your pussy seems to."
<<else>>
<<He>> speaks. "Fuck, I can't hold back like this for long."
<</if>>
<<elseif $speechanuswithhold is 1>>
<<if $enemyanger lte 20>>
<<He>> speaks. "I really wish I could ass fuck you, guess I'll have to make do."
<<elseif $enemyanger lte 100>>
<<He>> speaks. "Are you sure you don't want my dick? Your ass is so close..."
<<else>>
<<He>> speaks. "Fuck, I can't hold back like this for long."
<</if>>
<<elseif $speechpeniswithhold is 1>>
<<if $enemyanger lte 20>>
<<He>> speaks. "I can't take this, I need you inside me!"
<<elseif $enemyanger lte 100>>
<<He>> speaks. "I can't take this, I need you inside me!"
<<else>>
<<He>> speaks. "Fuck, I can't hold back like this for long."
<</if>>
<<elseif $speechotheranuswithhold is 1>>
<<if $enemyanger lte 20>>
<<He>> speaks. "I can't take this, I need you inside me!"
<<elseif $enemyanger lte 100>>
<<He>> speaks. "I can't take this, I need you inside me!"
<<else>>
<<He>> speaks. "Fuck, I can't hold back like this for long."
<</if>>
<<elseif $speechvagina is 1>>
<<if $arousal gte 8000>>
<<if $enemyanger lte 20>>
<<He>> speaks. "Your pussy is so moist! You need it bad, don't you?"
<<elseif $enemyanger lte 100>>
<<He>> speaks. "You're sopping wet down here!"
<<else>>
<<He>> speaks. "Don't pretend you don't want this. Your pussy is far too wet."
<</if>>
<<else>>
<<if $enemyanger lte 20>>
<<He>> speaks. "Don't worry, I'll soon have your pussy drenched."
<<elseif $enemyanger lte 100>>
<<He>> speaks. "How do you like the feel of me moving inside you?"
<<else>>
<<He>> speaks. "You like being treated like a cheap harlot, don't lie."
<</if>>
<</if>>
<<elseif $speechpenis is 1>>
<<if $arousal gte 8000>>
<<if $enemyanger lte 20>>
<<He>> speaks. "Your dick is so hard! You need it bad, don't you?"
<<elseif $enemyanger lte 100>>
<<He>> speaks. "Don't pretend you don't want this, not with a dick this hard."
<<else>>
<<He>> speaks. "Don't pretend you don't want this, not with a dick this hard."
<</if>>
<<else>>
<<if $enemyanger lte 20>>
<<He>> speaks. "Does my hand make you feel good?"
<<elseif $enemyanger lte 100>>
<<He>> speaks. "You like that, don't you."
<<else>>
<<He>> speaks. "Your dick is in my hand, I hope you realise who's in charge now."
<</if>>
<</if>>
<<elseif $speechanus is 1>>
<<if $enemyanger lte 20>>
<<He>> speaks. "Does my finger make you feel good?"
<<elseif $enemyanger lte 100>>
<<He>> speaks. "You like that, don't you."
<<else>>
<<He>> speaks. "You better start being good, I can be much rougher than this." <<He>> moves the finger in your anus more violently to demonstrate the point.
<</if>>
<<elseif $speechvaginamouth is 1>>
<<if $enemyanger lte 20>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<<He>> is lost in the moment. "Ohh! Not long now!"
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<<He>> speaks. "How do you like the taste of my juices?"
<<else>>
<<He>> speaks. "Let's see what your tongue is capable of."
<</if>>
<<elseif $enemyanger lte 100>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<<He>> is lost in the moment. "Mmm, it feels so good!"
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<<He>> speaks. "Now's your chance to satisfy me."
<<else>>
<<He>> speaks. "You don't want to disappoint me, do you?"
<</if>>
<<else>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<<He>> is lost in the moment. "OHH! Your tongue, you stupid... AHH!"
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<<He>> speaks. "You better swallow all my juices."
<<else>>
<<He>> speaks. "Nothing like rubbing my cunt in a fucktoy's face to remind them who's boss."
<</if>>
<</if>>
<<elseif $speechvaginavagina is 1>>
<<if $enemyanger lte 20>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<<He>> is lost in the moment. "Ohh! Not long now!"
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<<He>> speaks. "How do you like the feel of my pussy against yours?"
<<else>>
<<He>> speaks. "How do you like the feel of my pussy against yours?"
<</if>>
<<elseif $enemyanger lte 100>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<<He>> is lost in the moment. "Mmm, it feels so good!"
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<<He>> speaks. "Our juices are mingling together."
<<else>>
<<He>> speaks. "You don't want to disappoint me, do you? Rub harder."
<</if>>
<<else>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<<He>> is lost in the moment. "OHH! Your pussy is so good!"
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<<He>> speaks. "You act like you don't want this, but your pussy is drenching me."
<<else>>
<<He>> speaks. "You like that, slut?"
<</if>>
<</if>>
<<elseif $speechbeat is 1>>
<<if $rng lte 10>>
<<He>> speaks. "That's the least you deserve, bitch!"
<<elseif $rng lte 20>>
<<He>> speaks. "You want some more of this? Huh?"
<<elseif $rng lte 30>>
<<He>> speaks. "Hurts, don't it."
<<elseif $rng lte 40>>
<<He>> speaks. "I'll beat you into submission if I have to."
<<elseif $rng lte 50>>
<<He>> speaks. "Take that you stupid fuck!"
<<elseif $rng lte 60>>
<<He>> speaks. "There's plenty more punishment to come, whore."
<<elseif $rng lte 70>>
<<He>> speaks. "I love it when sluts cower."
<<elseif $rng lte 80>>
<<He>> speaks. "I'll have my fun, even if I have to beat it out of you."
<<elseif $rng lte 90>>
<<He>> speaks. "Maybe you like being beaten? I can accommodate that."
<<else>>
<<He>> speaks. "Afraid of me yet?"
<</if>>
<<elseif $speechhit is 1>>
<<if $enemyanger lte 20>>
<<if $rng lte 35>>
<<He>> is annoyed by your attack. "Now why'd you go and do that?"
<<elseif $rng lte 70>>
<<He>> is annoyed by your attack. "Come on, don't be like that."
<<else>>
<<He>> is annoyed by your attack. "Ow! Not so rough!"
<</if>>
<<elseif $enemyanger lte 100>>
<<if $rng lte 35>>
<<He>> is annoyed by your attack. "You're starting to piss me off."
<<elseif $rng lte 70>>
<<He>> is annoyed by your attack. "Are you trying to get yourself hurt?"
<<else>>
<<He>> is annoyed by your attack. "Keep this up and you'll be in a lot of trouble, little <<girlstop>>"
<</if>>
<<else>>
<<if $rng lte 35>>
<<He>> is enraged by your attack. "I'm going to fucking murder you if you don't stop."
<<elseif $rng lte 70>>
<<He>> is enraged by your attack. "I'm going to show you your place, <<bitchstop>>"
<<else>>
<<He>> is enraged by your attack. "Ungrateful piece of shit."
<</if>>
<</if>>
<<elseif $speechthroat is 1>>
<<if $rng lte 20>>
<<He>> tightens <<his>> grip around your throat. "What's the matter? Trouble breathing?"
<<elseif $rng lte 40>>
<<He>> tightens <<his>> grip around your throat. "Don't lose consciousness just yet, I want you to be awake for this."
<<elseif $rng lte 60>>
<<He>> tightens <<his>> grip around your throat. "You better start being nice to me if you want to breathe freely."
<<elseif $rng lte 80>>
<<He>> tightens <<his>> grip around your throat. "Too tight for you? Maybe you should stop being such a brat."
<<else>>
<<He>> tightens <<his>> grip around your throat. "I love it when they squirm."
<</if>>
<<elseif $speechvaginafoot is 1>>
<<if $enemyanger lte 20>>
<<He>> speaks. "I can feel you leaking on my toes."
<<elseif $enemyanger lte 100>>
<<He>> speaks. "I know you like being trodden on like this, don't pretend otherwise."
<<else>>
<<He>> speaks. "It's probably best I use my foot, I don't know where your slutty slit has been."
<</if>>
<<elseif $speechpenisfoot is 1>>
<<if $enemyanger lte 20>>
<<He>> speaks. "Do you like the feel of my feet?"
<<elseif $enemyanger lte 100>>
<<He>> speaks. "I know you like being trodden on like this, don't pretend otherwise."
<<else>>
<<He>> speaks. "It's probably best I use my foot, I don't know where your filthy dick has been."
<</if>>
<<elseif $speechchastity is 1>>
<<if $enemyanger lte 20>>
<<if $rng lte 35>>
<<He>> speaks. "This belt is on pretty tight."
<<elseif $rng lte 70>>
<<He>> speaks. "I can't get it off."
<<else>>
<<He>> speaks. "I really want to get under this thing."
<</if>>
<<elseif $enemyanger lte 100>>
<<if $rng lte 35>>
<<He>> speaks. "Oh, you little tease."
<<elseif $rng lte 70>>
<<He>> speaks. "Fuck, how do I get this off?"
<<else>>
<<He>> speaks. "Just you wait until I get this off of you. Oh, the fun we'll have."
<</if>>
<<else>>
<<if $rng lte 35>>
<<He>> speaks. "Something's gonna break, either you or this belt."
<<elseif $rng lte 70>>
<<He>> speaks. "Fuck you, and fuck this belt."
<<else>>
<<He>> speaks. "Just you wait until I get this off."
<</if>>
<</if>>
<<elseif $speechstripstruggle is 1>>
<<if $enemyanger lte 20>>
<<if $rng lte 35>>
<<He>> speaks. "Come on, don't be shy."
<<elseif $rng lte 70>>
<<He>> speaks. "You're so beautiful, I have to see more of you."
<<else>>
<<He>> speaks. "I really want to get under this thing."
<</if>>
<<elseif $enemyanger lte 100>>
<<if $rng lte 35>>
<<He>> speaks. "Oh, you little tease."
<<elseif $rng lte 70>>
<<He>> speaks. "Stop struggling!"
<<else>>
<<He>> speaks. "If you let me take your clothes off, things will go easier for you."
<</if>>
<<else>>
<<if $rng lte 35>>
<<He>> speaks. "Give me your clothes, bitch!"
<<elseif $rng lte 70>>
<<He>> speaks. "You're getting stripped, slut. Stop fighting it."
<<else>>
<<He>> speaks. "Your clothes belong to me now, stop struggling."
<</if>>
<</if>>
<<elseif $speechstruggle is 1>>
<<if $enemyanger lte 20>>
<<if $rng lte 35>>
<<He>> speaks. "You're a feisty little thing!"
<<elseif $rng lte 70>>
<<He>> speaks. "Calm down, you're not going to be hurt."
<<else>>
<<He>> speaks. "Just be calm and let it happen."
<</if>>
<<elseif $enemyanger lte 100>>
<<if $rng lte 35>>
<<He>> speaks. "Stop struggling, or I'll get angry."
<<elseif $rng lte 70>>
<<He>> speaks. "If you don't want things to get worse, then calm down."
<<else>>
<<He>> speaks. "A good <<girl>> wouldn't struggle. Do you want to be punished?"
<</if>>
<<else>>
<<if $rng lte 35>>
<<He>> speaks. "Be still, you ungrateful bitch!"
<<elseif $rng lte 70>>
<<He>> speaks. "Stop struggling and accept your place."
<<else>>
<<He>> speaks. "Stupid slut! Stop it!"
<</if>>
<</if>>
<<elseif $speechspank is 1>>
<<if $enemyanger lte 20>>
<<if $rng lte 35>>
<<He>> speaks. "Have you learned your lesson yet?"
<<elseif $rng lte 70>>
<<He>> speaks. "If you're a good <<girl>> in the future, then you won't need to be punished."
<<else>>
<<He>> speaks. "This hurts me more than it hurts you."
<</if>>
<<elseif $enemyanger lte 100>>
<<if $rng lte 35>>
<<He>> speaks. "I could spank you far harder than this if I wanted."
<<elseif $rng lte 70>>
<<He>> speaks. "If you don't want things to get worse, then stop acting like a brat."
<<else>>
<<He>> speaks. "You've been a bad <<girlstop>> So you get punished. It's as simple as that."
<</if>>
<<else>>
<<if $rng lte 35>>
<<He>> speaks. "You're going to take your punishment, and when I'm done you're going to thank me for it!"
<<elseif $rng lte 70>>
<<He>> speaks. "You deserve far worse than this."
<<else>>
<<He>> speaks. "I'm gonna spank your butt raw, little <<girlstop>>"
<</if>>
<</if>>
<<elseif $speecharms is 1>>
<<if $enemyanger lte 20>>
<<if $rng lte 35>>
<<He>> speaks. "If I give you your arms back, will you be good?"
<<elseif $rng lte 70>>
<<He>> speaks. "Some people like being restrained, you know."
<<else>>
<<He>> speaks. "It's cute when they can't use their arms."
<</if>>
<<elseif $enemyanger lte 100>>
<<if $rng lte 35>>
<<He>> speaks. "I'd release your arms if I was sure you wouldn't be a brat."
<<elseif $rng lte 70>>
<<He>> speaks. "If you prove that you're nice, then I won't have to restrain you."
<<else>>
<<He>> speaks. "You're completely helpless."
<</if>>
<<else>>
<<if $rng lte 35>>
<<He>> speaks. "You're completely at my mercy, get used to it."
<<elseif $rng lte 70>>
<<He>> speaks. "Try to struggle free, I dare you."
<<else>>
<<He>> speaks. "I know you love being restrained like this, you dirty slut."
<</if>>
<</if>>
<<elseif $speechclit is 1>>
<<if $enemyanger lte 20>>
<<if $rng lte 35>>
<<He>> speaks. "Does having your clit teased feel good?"
<<elseif $rng lte 70>>
<<He>> speaks. "Your little clit is so cute!"
<<else>>
<<He>> speaks. "Your clit is really firm. I guess that means you like it."
<</if>>
<<elseif $enemyanger lte 100>>
<<if $rng lte 35>>
<<He>> speaks. "Your clit is so much fun to play with."
<<elseif $rng lte 70>>
<<He>> speaks. "I could hurt instead of pleasure you you know, best be a good <<girlstop>>"
<<else>>
<<He>> speaks. "You don't want to annoy me, not with your clit vulnerable like this."
<</if>>
<<else>>
<<if $rng lte 35>>
<<He>> speaks. "You like having your bean toyed with, bitch?"
<<elseif $rng lte 70>>
<<He>> speaks. "Nothing like teasing some slut's clit to assert your superiority."
<<else>>
<<He>> speaks. "The fucktoy reacts to having its clit teased, what a surprise."
<</if>>
<</if>>
<<elseif $speechglans is 1>>
<<if $enemyanger lte 20>>
<<if $rng lte 35>>
<<He>> speaks. "Does having your dick played with feel good?"
<<elseif $rng lte 70>>
<<He>> speaks. "Your face is so cute when your dick is being teased like this!"
<<else>>
<<He>> speaks. "Your dick is really firm. I guess that means you like it."
<</if>>
<<elseif $enemyanger lte 100>>
<<if $rng lte 35>>
<<He>> speaks. "Your dick is so much fun to play with."
<<elseif $rng lte 70>>
<<He>> speaks. "I could hurt instead of pleasure you you know, best be a good <<girlstop>>"
<<else>>
<<He>> speaks. "You don't want to annoy me, not with your dick vulnerable like this."
<</if>>
<<else>>
<<if $rng lte 35>>
<<He>> speaks. "You like having your dick toyed with, bitch?"
<<elseif $rng lte 70>>
<<He>> speaks. "Nothing like teasing some fucktoy's dick to assert your superiority."
<<else>>
<<He>> speaks. "The fucktoy reacts to having its glans teased, what a surprise."
<</if>>
<</if>>
<<elseif $speechbottom is 1>>
<<if $enemyanger lte 20>>
<<if $rng lte 35>>
<<He>> speaks. "Does having your butt fondled feel good?"
<<elseif $rng lte 70>>
<<He>> speaks. "Your face is so cute when your butt is being teased like this!"
<<else>>
<<He>> speaks. "Your butt is so shapely."
<</if>>
<<elseif $enemyanger lte 100>>
<<if $rng lte 35>>
<<He>> speaks. "Your butt is so much fun to play with."
<<elseif $rng lte 70>>
<<He>> speaks. "I could hurt instead of pleasure you you know, best be a good <<girlstop>>"
<<else>>
<<He>> speaks. "If you annoy me, I'll give you a spanking."
<</if>>
<<else>>
<<if $rng lte 35>>
<<He>> speaks. "You like having your ass toyed with, bitch?"
<<elseif $rng lte 70>>
<<He>> speaks. "Bitches like you deserve a hard spanking."
<<else>>
<<He>> speaks. "Nice ass. At least you've got something going for you, slut."
<</if>>
<</if>>
<<elseif $speechhair is 1>>
<<if $enemyanger lte 20>>
<<if $rng lte 35>>
<<He>> speaks. "Your hair is fun to play with."
<<elseif $rng lte 70>>
<<He>> speaks. "Your hair is silky smooth."
<<else>>
<<He>> speaks. "Your hair is so beautiful."
<</if>>
<<elseif $enemyanger lte 100>>
<<if $rng lte 35>>
<<He>> speaks. "Your hair is fun to yank around."
<<elseif $rng lte 70>>
<<He>> speaks. "I could really hurt you if I pulled hard enough, best be a good <<girlstop>>"
<<else>>
<<He>> speaks. "Your hair makes a fine leash."
<</if>>
<<else>>
<<if $rng lte 35>>
<<He>> speaks. "You like having your hair pulled, bitch?"
<<elseif $rng lte 70>>
<<He>> speaks. "You're staying right where I want you."
<<else>>
<<He>> speaks. "You'll give me what I want, or I'll keep pulling."
<</if>>
<</if>>
<<elseif $speechchestrub is 1>>
<<if $playergenderappearance is "m">>
<<if $enemyanger lte 20>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<<He>> is lost in the moment. "I'm gonna cum all over your chest!"
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<<He>> speaks. "I bet your nipples are a weak spot."
<<else>>
<<He>> speaks. "Do you like the sight of my dick?"
<</if>>
<<elseif $enemyanger lte 100>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<<He>> is lost in the moment. "You'll be drenched when I'm done!"
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<<He>> speaks. "Nothing quite like getting off on a boy's chest."
<<else>>
<<He>> speaks. "Be on your best behaviour, or I'll find some other part of you to fuck."
<</if>>
<<else>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<<He>> is lost in the moment. "I'm gonna mark you with my seed!"
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<<He>> speaks. "You'll be begging for more when I'm done, fuckboy."
<<else>>
<<He>> speaks. "Don't get any delusions of grandeur, you're just a cum rag."
<</if>>
<</if>>
<<else>>
<<if $enemyanger lte 20>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<<He>> is lost in the moment. "I'm gonna cum all over your flat chest!"
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<<He>> speaks. "Flat breasts are so lewd..."
<<else>>
<<He>> speaks. "Don't be ashamed of your small breasts, it's cute."
<</if>>
<<elseif $enemyanger lte 100>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<<He>> speaks. "They may be small, but your breasts feel good on my dick."
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<<He>> speaks. "Keep it up, whore."
<<else>>
<<He>> speaks. "Your breasts are so small. You'll have to make it up to me in other ways."
<</if>>
<<else>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<<He>> speaks. "I'm gonna cover your pathetic excuse for breasts in my seed, and you're gonna thank me for it."
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<<He>> speaks. "What's it like to have such an inadequate rack?"
<<else>>
<<He>> speaks. "Your breasts are pathetic by the way."
<</if>>
<</if>>
<</if>>
<<elseif $speechbreastrub is 1>>
<<if $enemyanger lte 20>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<<He>> speaks. "I'm gonna cum all over your delicious breasts!"
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<<He>> speaks. "Nothing like a boob job from a cutie."
<<else>>
<<He>> speaks. "My dick feels so good between your breasts."
<</if>>
<<elseif $enemyanger lte 100>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<<He>> speaks. "Careful, or I might squirt in your face."
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<<He>> speaks. "Your boobs were made for pleasuring dick."
<<else>>
<<He>> speaks. "Keep those tits of yours around my dick."
<</if>>
<<else>>
<<if $enemyarousal gte ($enemyarousalmax / 5) * 4>>
<<He>> speaks. "That's it, take it between your tits like the slut you are."
<<elseif $enemyarousal gte ($enemyarousalmax / 5) * 2>>
<<He>> speaks. "Take it, bitch!"
<<else>>
<<He>> speaks. "You better be good at this, for your sake."
<</if>>
<</if>>
<<elseif $speechplead is 1>>
<<if $enemyanger lte 20>>
<<if $rng lte 20>>
<<He>> speaks. "You don't want to stop really."
<<elseif $rng lte 40>>
<<He>> speaks. "Don't be silly, you're enjoying this."
<<elseif $rng lte 60>>
<<He>> speaks. "It'll be over before you know it."
<<elseif $rng lte 80>>
<<He>> speaks. "You're not going to be hurt you know."
<<else>>
<<He>> speaks. "Don't worry, I'll be gentle."
<</if>>
<<elseif $enemyanger lte 100>>
<<if $rng lte 20>>
<<He>> speaks. "This is happening, one way or another."
<<elseif $rng lte 40>>
<<He>> speaks. "Don't try to guilt me."
<<elseif $rng lte 60>>
<<He>> speaks. "You say that, but your body tells a different story."
<<elseif $rng lte 80>>
<<He>> speaks. "I'm not stopping until I'm satisfied."
<<else>>
<<He>> speaks. "All the more reason to please me, it'll be over faster."
<</if>>
<<else>>
<<if $rng lte 20>>
<<He>> speaks. "Don't make me laugh, a slut like you can't get enough of this."
<<elseif $rng lte 40>>
<<He>> speaks. "We're not stopping until I'm done, whore."
<<elseif $rng lte 60>>
<<He>> speaks. "You're a selfish little shit aren't you."
<<elseif $rng lte 80>>
<<He>> speaks. "Did I give you permission to speak?"
<<else>>
<<He>> speaks. "Don't make me laugh, <<bitchstop>> You're gagging for this."
<</if>>
<</if>>
<<elseif $speechmoan is 1>>
<<if $enemyanger lte 20>>
<<if $rng lte 20>>
<<He>> speaks. "I knew you'd love it."
<<elseif $rng lte 40>>
<<He>> speaks. "Don't worry, I'll use you properly."
<<elseif $rng lte 60>>
<<He>> speaks. "Your voice is so cute."
<<elseif $rng lte 80>>
<<He>> speaks. "You're such a good <<girlstop>>"
<<else>>
<<He>> speaks. "You're so precious."
<</if>>
<<elseif $enemyanger lte 100>>
<<if $rng lte 20>>
<<He>> speaks. "That's more like it."
<<elseif $rng lte 40>>
<<He>> speaks. "Trying to butter me up? You still need to be punished."
<<elseif $rng lte 60>>
<<He>> speaks. "You like that? Filthy slut."
<<elseif $rng lte 80>>
<<He>> speaks. "You'd make a fine pet."
<<else>>
<<He>> speaks. "Keep this up and it'll end well for you."
<</if>>
<<else>>
<<if $rng lte 20>>
<<He>> speaks. "Shut up, <<bitchcomma>> I'm on to your tricks."
<<elseif $rng lte 40>>
<<He>> speaks. "You have a sweet mouth, but I know you're a rotten whore."
<<elseif $rng lte 60>>
<<He>> speaks. "You're a submissive little shit aren't you."
<<elseif $rng lte 80>>
<<He>> speaks. "Did I give you permission to speak?"
<<else>>
<<He>> speaks. "Don't make me laugh, <<bitchstop>> You're a manipulative whore."
<</if>>
<</if>>
<<elseif $speechdemand is 1>>
<<if $enemyanger lte 20>>
<<if $rng lte 20>>
<<He>> speaks. "You certainly have a mouth on you."
<<elseif $rng lte 40>>
<<He>> speaks. "You shouldn't be so rude to your betters."
<<elseif $rng lte 60>>
<<He>> speaks. "You better start being nicer, or I'll get meaner."
<<elseif $rng lte 80>>
<<He>> speaks. "You're such a naughty <<girlstop>>"
<<else>>
<<He>> speaks. "Careful, that's no way to speak to me."
<</if>>
<<elseif $enemyanger lte 100>>
<<if $rng lte 20>>
<<He>> speaks. "Keep talking like that and I'll show you just how little you're worth."
<<elseif $rng lte 40>>
<<He>> speaks. "How dare you talk to me like that."
<<elseif $rng lte 60>>
<<He>> speaks. "If you don't start being more polite, I'll fuck you up."
<<elseif $rng lte 80>>
<<He>> speaks. "You're not making this any easier on yourself."
<<else>>
<<He>> speaks. "Keep this up and it won't end well for you."
<</if>>
<<else>>
<<if $rng lte 20>>
<<He>> speaks. "Shut the fuck up, <<bitchstop>>"
<<elseif $rng lte 40>>
<<He>> speaks. "Shut up, or I'll shut you up."
<<elseif $rng lte 60>>
<<He>> speaks. "You're a bratty little shit aren't you."
<<elseif $rng lte 80>>
<<He>> speaks. "Did I give you permission to speak?"
<<else>>
<<He>> speaks. "Don't make me laugh, <<bitchstop>> You're a weak little toy."
<</if>>
<</if>>
<<elseif $speechforgive is 1>>
<<if $enemyanger lte 20>>
<<if $rng lte 20>>
<<He>> laughs. "You forgive me? How cute."
<<elseif $rng lte 40>>
<<He>> laughs. "You forgive me? For what?"
<<elseif $rng lte 60>>
<<He>> speaks. "Shush, <<girlstop>>"
<<elseif $rng lte 80>>
<<He>> speaks. "You're a sweet little thing."
<<else>>
<<He>> laughs. "You can't be this cute."
<</if>>
<<elseif $enemyanger lte 100>>
<<if $rng lte 20>>
<<He>> speaks. "Forgive me for what?."
<<elseif $rng lte 40>>
<<He>> speaks. "I don't like what you're implying, <<girlstop>>"
<<elseif $rng lte 60>>
<<He>> speaks. "Don't worry yourself, I'll give you plenty to forgive."
<<elseif $rng lte 80>>
<<He>> speaks. "Did I ask for your forgiveness? Better keep it zipped."
<<else>>
<<He>> speaks. "Forgive me? That's presumptuous for a <<bitch>> in your position."
<</if>>
<<else>>
<<if $rng lte 20>>
<<He>> speaks. "Shut the fuck up, <<bitchstop>>"
<<elseif $rng lte 40>>
<<He>> speaks. "Don't make me laugh, <<bitchstop>> Toys like you are made to be played with."
<<elseif $rng lte 60>>
<<He>> speaks. "You're a presumptuous little shit, aren't you."
<<elseif $rng lte 80>>
<<He>> speaks. "Did I give you permission to speak?"
<<else>>
<<He>> speaks. "There's nothing wrong with putting you to your proper use."
<</if>>
<</if>>
<<elseif $speechvaginaflaunt is 1>>
<<if $playergenderappearance is "m">>
<<if $rng lte 35>>
<<He>> coos. "I can't wait to swallow your dick."
<<elseif $rng lte 70>>
<<He>> coos. "Just look at the effect you're having on me."
<<else>>
<<He>> coos. "Like what you see?"
<</if>>
<<else>>
<<if $rng lte 35>>
<<He>> coos. "I'm rather proud of my body, I'm sure you can see why."
<<elseif $rng lte 70>>
<<He>> coos. "Just look at the effect you're having on me."
<<else>>
<<He>> coos. "Like what you see?"
<</if>>
<</if>>
<<elseif $speechcoverface is 1>>
<<if $enemyanger lte 20>>
<<if $rng lte 35>>
<<He>> speaks. "Aww look, the little <<girl>> is covering <<pher>> face."
<<elseif $rng lte 70>>
<<He>> speaks. "<<pShe>> is so shy!"
<<else>>
<<He>> speaks. "Don't be shy little <<girlstop>>"
<</if>>
<<elseif $enemyanger lte 100>>
<<if $rng lte 35>>
<<He>> speaks. "Don't think you won't be recognized."
<<elseif $rng lte 70>>
<<He>> speaks. "Something to hide?"
<<else>>
<<He>> speaks. "If covering your face makes this easier for you, fine."
<</if>>
<<else>>
<<if $rng lte 35>>
<<He>> speaks. "<<pShe>> is covering <<pher>> face! How pathetic."
<<elseif $rng lte 70>>
<<He>> speaks. "Cover your face if you want slut, you can't hide everything."
<<else>>
<<He>> speaks. "At least I don't have to look at your whore face."
<</if>>
<</if>>
<<elseif $speechcoverpenis is 1>>
<<if $enemyanger lte 20>>
<<if $rng lte 35>>
<<He>> speaks. "Stop hiding your penis from me and I'll make you feel good."
<<elseif $rng lte 70>>
<<He>> speaks. "Why are you hiding your penis from me?"
<<else>>
<<He>> speaks. "There's no reason to be shy."
<</if>>
<<elseif $enemyanger lte 100>>
<<if $rng lte 35>>
<<He>> speaks. "Come on, let me see your penis."
<<elseif $rng lte 70>>
<<He>> speaks. "Something to hide?"
<<else>>
<<He>> speaks. "Stop covering your penis, I want to see it."
<</if>>
<<else>>
<<if $rng lte 35>>
<<He>> speaks. "If you don't stop covering your dick I'll beat you until you do."
<<elseif $rng lte 70>>
<<He>> speaks. "Let me see your dick. Now."
<<else>>
<<He>> speaks. "Stop covering your fucktoy dick or I'll stop being so courteous."
<</if>>
<</if>>
<<elseif $speechcovervagina is 1>>
<<if $enemyanger lte 20>>
<<if $rng lte 35>>
<<He>> speaks. "Stop hiding your pussy from me and I'll make you feel good."
<<elseif $rng lte 70>>
<<He>> speaks. "Why are you hiding your pussy from me?"
<<else>>
<<He>> speaks. "There's no reason to be shy."
<</if>>
<<elseif $enemyanger lte 100>>
<<if $rng lte 35>>
<<He>> speaks. "Come on, let me see your pussy."
<<elseif $rng lte 70>>
<<He>> speaks. "Something to hide?"
<<else>>
<<He>> speaks. "Stop covering your pussy, I want to see it."
<</if>>
<<else>>
<<if $rng lte 35>>
<<He>> speaks. "If you don't stop covering your cunt I'll beat you until you do."
<<elseif $rng lte 70>>
<<He>> speaks. "Let me see your pussy. Now."
<<else>>
<<He>> speaks. "Stop covering your whore cunt or I'll stop being so courteous."
<</if>>
<</if>>
<<elseif $speechapologiseno is 1>>
<<if $enemyanger lte 20>>
<<if $rng lte 35>>
<<He>> speaks. "Shhh, you've already apologised."
<<elseif $rng lte 70>>
<<He>> speaks. "That's very polite, but I already know you're sorry."
<<else>>
<<He>> speaks. "I know you're sorry, don't worry about it."
<</if>>
<<elseif $enemyanger lte 100>>
<<if $rng lte 35>>
<<He>> speaks. "I heard you the first time."
<<elseif $rng lte 70>>
<<He>> speaks. "Quit whining"
<<else>>
<<He>> speaks. "Shush <<girlstop>>"
<</if>>
<<else>>
<<if $rng lte 35>>
<<He>> speaks. "Shut up, bitch."
<<elseif $rng lte 70>>
<<He>> speaks. "Shut up before I give you something to choke on."
<<else>>
<<He>> speaks. "Do you have permission to speak, slut?"
<</if>>
<</if>>
<<else>>
<<basespeech>>
<</if>>
<</nobr>><</widget>>
<<widget "basespeech">><<nobr>>
<<if $enemyanger lte 20>>
<<set $rng to random(1, 100)>>
<<He>> whispers.
<<if $rng lte 5>>
"You are so beautiful."
<<elseif $rng lte 10>>
"You are so very pretty."
<<elseif $rng lte 15>>
"You're such a gorgeous <<girlstop>>"
<<elseif $rng lte 20>>
"I bet you get a lot of attention."
<<elseif $rng lte 25>>
"You are so very cute."
<<elseif $rng lte 30>>
"You're so lovely."
<<elseif $rng lte 35>>
"Be a good <<girl>> and I won't hurt you."
<<elseif $rng lte 40>>
"Be a good <<girl>> and I'll make you feel good."
<<elseif $rng lte 45>>
"If you make me feel good, I'll make you feel good too."
<<elseif $rng lte 50>>
"Your skin is so smooth."
<<elseif $rng lte 55>>
"I want to kiss you all over."
<<elseif $rng lte 60>>
"You're a delicate thing, aren't you?"
<<elseif $rng lte 65>>
"You are wonderful."
<<elseif $rng lte 70>>
"Your body is so appealing."
<<elseif $rng lte 75>>
"Don't be ashamed of your body."
<<elseif $rng lte 80>>
"You look so fragile."
<<elseif $rng lte 85>>
"You're like an angel."
<<elseif $rng lte 90>>
"Your <<breasts>> are so cute."
<<elseif $rng lte 95>>
"You smell nice."
<<elseif $rng lte 100>>
"You're such a cute <<girlstop>>"
<</if>>
<<elseif $enemyanger lte 100>>
<<set $rng to random(1, 100)>>
<<He>> gives you a stern look.
<<if $rng lte 5>>
"Don't try my patience."
<<elseif $rng lte 10>>
"Bad sluts get hurt."
<<elseif $rng lte 15>>
"You're not a bad <<girl>>, are you?"
<<elseif $rng lte 20>>
"Don't think I won't hurt you."
<<elseif $rng lte 25>>
"You're so fucking sexy."
<<elseif $rng lte 30>>
"I wonder how much you could take."
<<elseif $rng lte 35>>
"This is happening, you might aswell make it easy on yourself."
<<elseif $rng lte 40>>
"Be a good <<girl>> and things will be easier for you."
<<elseif $rng lte 45>>
"I'm going to have fun with your body."
<<elseif $rng lte 50>>
"Don't defy me."
<<elseif $rng lte 55>>
"You were made for this."
<<elseif $rng lte 60>>
"I can tell you're enjoying this."
<<elseif $rng lte 65>>
"This is your fault, you know."
<<elseif $rng lte 70>>
"You like this, don't you."
<<elseif $rng lte 75>>
"You're on thin ice, <<girlstop>>"
<<elseif $rng lte 80>>
"Don't think you've seen the worst of me."
<<elseif $rng lte 85>>
"I own you now."
<<elseif $rng lte 90>>
"It's not over until I say it's over."
<<elseif $rng lte 95>>
"You're a fun toy, but don't get any ideas."
<<elseif $rng lte 100>>
"You should treat your betters with respect."
<</if>>
<<else>>
<<set $rng to random(1, 100)>>
<<He>> looks at you with fury.
<<if $rng lte 5>>
"Fucking whore."
<<elseif $rng lte 10>>
"You're just a filthy slut."
<<elseif $rng lte 15>>
"You're a vessel for cum, nothing more."
<<elseif $rng lte 20>>
"You should be happy anyone is giving a worthless piece of shit like you attention."
<<elseif $rng lte 25>>
"I haven't killed you yet, you should show gratitude."
<<elseif $rng lte 30>>
"I'm going to break you, in so many ways."
<<elseif $rng lte 35>>
"You'll show me respect before I'm done."
<<elseif $rng lte 40>>
"I wonder where I'll dump you when I'm done."
<<elseif $rng lte 45>>
"Even rape is too good for a bitch like you."
<<elseif $rng lte 50>>
"You deserve this, bitch."
<<elseif $rng lte 55>>
"You enjoy being treated like this. Don't try to deny it."
<<elseif $rng lte 60>>
"You're a worthless fucktoy."
<<elseif $rng lte 65>>
"You look pretty good, for useless trash."
<<elseif $rng lte 70>>
"Getting me off is your only purpose, don't forget."
<<elseif $rng lte 75>>
"I know you like this, you stupid slut."
<<elseif $rng lte 80>>
"You deserve far worse than this, whore."
<<elseif $rng lte 85>>
"You're a worthless slut."
<<elseif $rng lte 90>>
"I'm going to hurt you, and you're going to like it."
<<elseif $rng lte 95>>
"There's only one thing a <<girl>> like you is good for."
<<elseif $rng lte 100>>
"You're such a wretched tramp."
<</if>>
<</if>>
<</nobr>><</widget>>
:: Widgets Debug [widget]
<<widget "debug">><<nobr>>
Allure: <<print $allure>><br>
Rng: <<print $rng>><br>
Danger: <<print $danger>><br>
<<back>><br>
<<link [[test|Test]]>><<set $molestationstart to 0>><</link>><br>
[[Home|Bedroom]]<br>
<<link [[pass an hour|$passage]]>><<pass 1 hour>><</link>><br>
<<link [[pass 5 hours|$passage]]>><<pass 5 hours>><</link>><br>
<<link [[pass 16 hours|$passage]]>><<pass 16 hours>><</link>><br>
<<link [[pass 23 hours|$passage]]>><<pass 23 hours>><</link>><br>
<<link [[pass a week|$passage]]>><<pass 7 days>><</link>><br>
<<link [[Strip|$passage]]>><<upperundress>><<lowerundress>><<underundress>><</link>><br>
<<link [[Trust me|$passage]]>><<set $enemytrust += 2000>><</link>><br>
<<link [[Hate me|$passage]]>><<set $enemytrust -= 2000>><<set $enemyanger += 1000>><</link>><br>
<<link [[Super Punch|$passage]]>><<set $enemyhealth to 0>><</link>><br>
<<link [[Super Stroke|$passage]]>><<set $enemyarousal to $enemyarousalmax>><</link>><br>
<<link [[Frigify|$passage]]>><<set $enemyarousal to 0>><</link>><br>
<<link [[Start Robin Event|$passage]]>><<set $robindebt to 9>><</link>><br>
<<link [[School Start|Oxford Street]]>><<pass 1 day>><</link>>
<br>
<<link [[Rape Me->Molestation]]>><<set $molestationstart to 1>><</link>><br>
<<link [[Sex Me|Beach Day Encounter Sex]]>><<generate1>><<person1>><<set $sexstart to 1>><</link>><br>
<<link [[DP Test]]>><<set $molestationstart to 1>><</link>><br>
<<link [[Gang Rape Me->Gang]]>><<set $molestationstart to 1>><</link>><br>
<<link [[Monster Rape Me->Monster Test]]>><<set $molestationstart to 1>><</link>><br>
<<link [[Beast Rape Me|Street Dogs]]>><<set $molestationstart to 1>><</link>><br>
<<link [[Beast Sex Me|Sea Dolphins Sex]]>><<set $sexstart to 1>><</link>><br>
<<link [[Bailey Test->Bus move]]>><<set $molestationstart to 1>><<bailey>><<person1>><</link>><br>
<<link [[Leighton Test->Bus move]]>><<set $molestationstart to 1>><<leighton>><<person1>><</link>><br>
<<link [[Enslave Me->Underground Intro]]>><<generate1>><<generate2>><<person1>><</link>><br>
<<link [[Work as a dancer|Brothel Dance]]>><<set $dancing to 1>><<set $venuemod to 3>><<stress -4>><<tiredness 4>><<set $dancelocation to "brothel">><</link>><br>
<<link [[Eden Start|Eden Cabin]]>><<set $syndromeeden to 1>><<set $edenlust to 0>><<set $edenshrooms to 0>><<set $edengarden to 0>><<set $edenspring to 0>><</link>><br>
<<link [[Clothing Shop|Clothing Shop]]>><</link>>
<br>
<<link [[Wake up|Ambulance rescue]]>><<pass 1 hour>><</link>>
<br>
<<link [[Appointment|Hospital Foyer]]>><<set $weekday to 6>><<set $time to 960>><</link>><br>
<<link [[Deep forest|Forest]]>><<set $forest to 80>><</link>><br>
<<link [[Penis Inspection|Penis Inspection]]>><<weekpass>><<weekpass>><<leighton>><<person1>><</link>><br>
<<link [[Testing Room]]>><<uppernaked>><<lowernaked>><<undernaked>><</link>><br>
<<if $alluretest is 1>>
<<link [[Stop Being Alluring|$passage]]>><<set $alluretest to 0>><</link>><br>
<<else>>
<<link [[Become Alluring|$passage]]>><<set $alluretest to 1>><</link>><br>
<</if>>
<br>
<<link [[RNG 1|$passage]]>><<set $rng to 1>><</link>><br>
<<link [[RNG 21|$passage]]>><<set $rng to 21>><</link>><br>
<<link [[RNG 41|$passage]]set $rng to 41>><</link>><br>
<<link [[RNG 61|$passage]]set $rng to 61>><</link>><br>
<<link [[RNG 81|$passage]]set $rng to 81>><</link>><br>
<<link [[RNG 100|$passage]]>><<set $rng to 100>><</link>><br>
<br>
<<link [[Fame|$passage]]>><<set $fame += 4000>><<set $fameexhibitionism += 1000>><<set $famesex += 1000>><<set $famerape += 1000>><<set $famebestiality += 1000>><<set $fameprostitution += 1000>><</link>><br>
<<link [[Fame Sex|$passage]]>><<set $fame += 4000>><<set $famesex += 4000>><</link>><br>
<<link [[Timer|$passage]]>><<set $timer -= 60>><</link>><br>
<<link [[Age Up|$passage]]>><<set $devlevel += 1>><</link>><br>
<<link [[Stress|$passage]]>><<set $stress += 5000>><</link>><br>
<<link [[Destress|$passage]]>><<set $stress -= 5000>><</link>><br>
<<link [[Traumatise me|$passage]]>><<set $trauma += 2000>><</link>><br>
<<link [[DeTraumatise me|$passage]]>><<set $trauma -= 2000>><</link>><br>
<<link [[Exhibitionism|$passage]]>><<set $exhibitionism += 20>><</link>><br>
<<link [[Promiscuity|$passage]]>><<set $promiscuity += 20>><</link>><br>
<<link [[Full Lewd|$passage]]>><<set $promiscuity += 100>><<set $exhibitionism += 100>><<set $deviancy += 100>><</link>><br>
<<link [[Beauty|$passage]]>><<set $beauty += 10000>><</link>><br>
<<link [[Physique|$passage]]>><<set $physique += 2000>><</link>><br>
<<link [[Sunlight|$passage]]>><<set $weather to "clear">><</link>><br>
<<link [[Booze|$passage]]>><<set $drunk += 60>><</link>><br>
<<link [[Drugged|$passage]]>><<set $drugged += 600>><</link>><br>
<<link [[Hallucinogen|$passage]]>><<set $hallucinogen += 600>><</link>><br>
<<link [[Seduction|$passage]]>><<set $seductionskill += 200>><</link>><br>
<<link [[Skulduggery|$passage]]>><<set $skulduggery += 200>><</link>><br>
<<link [[Crime|$passage]]>><<set $crime += 500>><</link>><br>
<<link [[Breasts up|$passage]]>><<set $breastsize += 1>><</link>><br>
<<link [[Breasts down|$passage]]>><<set $breastsize -= 1>><</link>><br>
<<link [[Chastity Belt|$passage]]>><<set $analshield to 0>><<set $chastitybeltnew to 1>><<set $chastitybeltno to 1>><<set $chastitybeltnew to 1>><<chastitybelt>><</link>><br>
<<link [[Collar|$passage]]>><<set $collared to 1>><</link>><br>
<<link [[Bind|$passage]]>><<set $leftarm to "bound">><<set $rightarm to "bound">><</link>><br>
<<link [[Money|$passage]]>><<set $money += 500000>><</link>><br>
<<link [[Grow hair|$passage]]>><<set $hairlength += 100>><</link>><br>
<<link [[Arousal|$passage]]>><<set $arousal += 10000>><</link>><br>
<<link [[Arousal down|$passage]]>><<set $arousal -= 10000>><</link>><br>
<<link [[Parasite|$passage]]>><<set $chestparasite to 1>><</link>><br>
<<link [[Chastity Parasite|$passage]]>><<set $analchastityparasite to "worms">><</link>><br>
<<link [[Month|$passage]]>><<set $monthday += 31>><<day>><</link>><br>
<<link [[Delinquency|$passage]]>><<set $delinquency += 1000>><</link>><br>
<<link [[Detention|$passage]]>><<set $detention += 10>><</link>><br>
<<link [[School Marks|$passage]]>><<set $school += 8000>><<set $science += 800>><<set $maths += 800>><<set $english += 800>><<set $history += 800>><</link>><br>
<<link [[All Skills|$passage]]>><<set $school += 448>><<set $science += 112>><<set $maths += 112>><<set $english += 112>><<set $history += 112>><<set $skulduggery += 112>><<set $danceskill += 112>><<set $swimmingskill += 112>><<set $bottomskill += 112>><<set $seductionskill += 112>><<set $handskill += 112>><<set $feetskill += 112>><<set $chestskill += 112>><<set $thighskill += 112>><<set $oralskill += 112>><<set $analskill += 112>><<set $vaginalskill += 112>><<set $penileskill += 112>><</link>><br>
<<link [[All Skills Super|$passage]]>><<set $school += 4000>><<set $science += 1000>><<set $maths += 1000>><<set $english += 1000>><<set $history += 1000>><<set $skulduggery += 1000>><<set $danceskill += 1000>><<set $swimmingskill += 1000>><<set $bottomskill += 1000>><<set $seductionskill += 1000>><<set $handskill += 1000>><<set $feetskill += 1000>><<set $chestskill += 1000>><<set $thighskill += 1000>><<set $oralskill += 1000>><<set $analskill += 1000>><<set $vaginalskill += 1000>><<set $penileskill += 1000>><</link>><br>
<<link [[Status|$passage]]>><<set $cool += 400>><</link>><br>
<<link [[Status Down|$passage]]>><<set $cool -= 400>><</link>><br>
<<link [[Destroy Swimming Outfits|$passage]]>><<set $upperschoolswimsuitno to 0>><<set $lowerschoolswimsuitno to 0>><<set $schoolswimshortsno to 0>><</link>><br>
<<link [[Towels|$passage]]>><<clothesontowel>><</link>><br>
<<link [[Submission|$passage]]>><<set $submissive += 250>><</link>><br>
<<link [[Defiance|$passage]]>><<set $submissive -= 250>><</link>><br>
<<link [[Imprison Me|Underground Intro2]]>><<generate1>><<person1>><</link>><br>
<<link [[Towels Please|$passage]]>><<towelup>><</link>><br>
<<link [[Pain Up|$passage]]>><<set $pain += 50>><</link>><br>
<<link [[Pain Down|$passage]]>><<set $pain -= 50>><</link>><br>
<<link [[Robin Love|$passage]]>><<set $robinlove += 100>><<set $robinlust += 100>><</link>>
<br>
<<link [[Robin Romance|$passage]]>><<set $robinnote to 1>><</link>>
<br>
<<link [[Stats Up|$passage]]>>
<<set $orgasmstat += 2000>>
<<set $ejacstat += 2000>>
<<set $moleststat += 2000>>
<<set $rapestat += 1000>>
<<set $beastrapestat += 500>>
<<set $tentaclerapestat += 200>>
<<set $swallowedstat += 100>>
<<set $prostitutionstat += 10>>
<</link>>
<br>
<<if $clothingrebuy is 1>>
<<link [[Disable Clothing Rebuy|$passage]]>><<set $clothingrebuy to 0>><</link>>
<<else>>
<<link [[Enable Clothing Rebuy|$passage]]>><<set $clothingrebuy to 1>><</link>>
<</if>><br>
<<link [[Almost Destroy Lowerclothes|$passage]]>><<set $lowerintegrity to 1>><</link>><br>
<<link [[Almost Destroy Upperclothes|$passage]]>><<set $upperintegrity to 1>><</link>><br>
<<link [[Damage Lowerclothes|$passage]]>><<set $lowerintegrity -= 200>><</link>><br>
<<link [[Damage Upperclothes|$passage]]>><<set $upperintegrity -= 200>><</link>><br>
<<link [[Damage Underclothes|$passage]]>><<set $underintegrity -= 200>><</link>><br>
<<link [[Swimming Skill|$passage]]>><<set $swimmingskill += 100>><</link>>
<br>
<<link [[Disable Hands|$passage]]>><<set $lefthand to 0>><<set $righthand to 0>><</link>>
<br>
<<link [[Purity Down|$passage]]>><<set $purity -= 500>><</link>>
<br>
<<if $wolfgirl is 6>>
<<link [[Wolf off|$passage]]>><<set $wolfgirl to 0>><</link>><br>
<<else>>
<<link [[Wolf up|$passage]]>><<set $wolfgirl += 1>><</link>><br>
<</if>>
<<link [[Wolf build up|$passage]]>><<set $wolfbuild += 40>><</link>><br>
<<link [[Wolf build down|$passage]]>><<set $wolfbuild -= 40>><</link>><br>
<<link [[Angel build up|$passage]]>><<set $angelbuild += 40>><</link>><br>
<<link [[Angel build down|$passage]]>><<set $angelbuild -= 40>><</link>><br>
<<if $demontest is 1>>
<<link [[Demon build up|$passage]]>><<set $demonbuild += 40>><</link>><br>
<<link [[Demon build down|$passage]]>><<set $demonbuild -= 40>><</link>><br>
<</if>>
<<link [[Awareness up|$passage]]>><<set $awareness += 200>><</link>><br>
<<link [[Awareness down|$passage]]>><<set $awareness -= 200>><</link>><br>
<<link [[Goo Me|$passage]]>><<set $anussemen += 5>><<set $anusgoo += 5>><<set $bottomsemen += 5>><<set $bottomgoo += 5>><</link>><br>
<<link [[Undertemp off|$passage]]>><<set $undertemp to 0>><</link>><br>
<<link [[Drench me|$passage]]>><<set $upperwet to 200>><<set $lowerwet to 200>><<set $underwet to 200>><</link>><br>
<<link [[Bully Timer|$passage]]>><<set $bullytimer to 100>><<set $bullytimeroutside to 100>><</link>><br>
<<link [[Whitney Lower Dominance|$passage]]>><<set $whitneydom -= 20>><</link>><br>
<<link [[Whitney Raise Dominance|$passage]]>><<set $whitneydom += 20>><</link>><br>
<<link [[Whitney Love|$passage]]>><<set $whitneylove += 20>><<set $whitneylust += 20>><</link>><br>
<<link [[Pub Whore|$passage]]>><<set $pubwhore += 10>><</link>><br>
<</nobr>><</widget>>
:: Widgets Audience [widget]
<<widget "audiencecamera">><<nobr>>
<<exposure>>
<<if $audienceselector is 1>>
<<set $audiencedesc to "excited">>
<<set $audiencecamera to $audiencecamera1>>
<<elseif $audienceselector is 2>>
<<set $audiencedesc to "blushing">>
<<set $audiencecamera to $audiencecamera2>>
<<elseif $audienceselector is 3>>
<<set $audiencedesc to "eager">>
<<set $audiencecamera to $audiencecamera3>>
<<elseif $audienceselector is 4>>
<<set $audiencedesc to "lusty">>
<<set $audiencecamera to $audiencecamera4>>
<<elseif $audienceselector is 5>>
<<set $audiencedesc to "avid">>
<<set $audiencecamera to $audiencecamera5>>
<<elseif $audienceselector is 6>>
<<set $audiencedesc to "vigorous">>
<<set $audiencecamera to $audiencecamera6>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $rng gte 81 and $facepic isnot 1>><<set $facepic to 1>>
The $audiencedesc $audiencecamera points <<ahis>> camera at your face. A light flashes as <<ahe>> takes a picture.
<<if $vaginastate is "penetrated">>
<<if $enemytype is "beast">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
"<<pShes>> cumming with an animal dick in <<pher>> cunt! I can't believe it."
<<else>>
"A $beasttype is fucking you in public and you're having an orgasm. I don't know how you stand the shame."
<</if>>
<<else>>
<<if $face is "covered">>
"You're fucking a $beasttype, don't pretend you have any dignity."
<<else>>
"So glad I was here to see this <<bitch>> get bred."
<</if>>
<</if>>
<<else>>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
"It's normal to cum while your pussy is filled, you don't need to be shy."
<<else>>
"Look how cute she looks when <<pshe>> cums. Fuck <<pher>> pussy harder."
<</if>>
<<else>>
<<if $face is "covered">>
"Don't be shy, I want to see your face while your pussy is ravaged."
<<else>>
"Your face looks so cute while your pussy is pounded."
<</if>>
<</if>>
<</if>>
<<elseif $vaginastate is "imminent">>
<<if $enemytype is "beast">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
"Is <<pshe>> cumming already? <<pShes>> such a $beasttype slut."
<<else>>
"Just the thought of that $beasttype dick entering is enough to make <<phim>> cum."
<</if>>
<<else>>
<<if $face is "covered">>
"Move your hands, I want to see your expression when the $beasttype fucks you."
<<else>>
"I want a picture of <<pher>> expression when it fuckers <<pher>> proper."
<</if>>
<</if>>
<<else>>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
"Is <<pshe>> cumming already?"
<<else>>
"Just the anticipation is enough to make <<phim>> cum."
<</if>>
<<else>>
<<if $face is "covered">>
"Move your hands, I want to see your expression when it goes in."
<<else>>
"I want a picture of <<pher>> expression when it goes in."
<</if>>
<</if>>
<</if>>
<<elseif $vaginastate is "entrance">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
"Is <<pshe>> cumming already?"
<<else>>
"Just the anticipation is enough to make <<phim>> cum."
<</if>>
<<else>>
<<if $face is "covered">>
"Move your hands, I want to see your expression when it goes in."
<<else>>
"I want a picture of <<pher>> expression when it goes in."
<</if>>
<</if>>
<<elseif $penisstate is "penetrated">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
"It's normal to cum while your penis is ravaged, you don't need to be shy."
<<else>>
"Look how cute she looks when <<pshe>> cums. Fuck <<phim>> harder."
<</if>>
<<else>>
<<if $face is "covered">>
"Don't be shy, I want to see your face while your penis is ravaged."
<<else>>
"Look how cute <<pshe>> looks with <<pher>> penis being pounded. Fuck <<phim>> harder."
<</if>>
<</if>>
<<elseif $penisstate is "imminent">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
"Is <<pshe>> cumming already?"
<<else>>
"Just the anticipation is enough to make <<phim>> cum."
<</if>>
<<else>>
<<if $face is "covered">>
"Move your hands, I want to see your expression when it goes in."
<<else>>
"I want to snap a picture of <<pher>> expression when it goes in."
<</if>>
<</if>>
<<elseif $penisstate is "entrance">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
"Is <<pshe>> cumming already?"
<<else>>
"Just the anticipation is enough to make <<phim>> cum."
<</if>>
<<else>>
<<if $face is "covered">>
"Move your hands, I want to see your expression when it goes in."
<<else>>
"I want to snap a picture of <<pher>> expression when it goes in."
<</if>>
<</if>>
<<elseif $penisstate is "otheranus">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
"Move your hands, I want to see what you look like while cumming in someone's ass."
<<else>>
"I think your ass is making <<phim>> cum. Fuck <<phim>> harder."
<</if>>
<<else>>
<<if $face is "covered">>
"You're shy about fucking someone's ass? That's adorable."
<<else>>
"Look how cute <<pshe>> looks with <<pher>> penis being pounded. Fuck <<phim>> harder."
<</if>>
<</if>>
<<elseif $penisstate is "otheranusimminent">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
"Don't be shy, letting the camera see your orgasm face."
<<else>>
"Just pressing your ass against <<pher>> dick is making <<phim>> cum."
<</if>>
<<else>>
<<if $face is "covered">>
"Move your hands, I want to see your expression when it goes in."
<<else>>
"<<pShes>> blushing! How cute."
<</if>>
<</if>>
<<elseif $penisstate is "otheranusentrance">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
"Don't be shy, let the camera see your orgasm face."
<<else>>
"Just pressing your ass against <<pher>> dick is making <<phim>> cum."
<</if>>
<<else>>
<<if $face is "covered">>
"Move your hands, I want to see your expression when it goes in."
<<else>>
"<<pShes>> blushing! How cute."
<</if>>
<</if>>
<<elseif $anusstate is "penetrated">>
<<if $enemytype is "beast">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
"You're cumming with a $beasttype balls-deep in your ass, how much dignity is covering your face preserving?"
<<else>>
"I got a nice picture of <<pher>> $beasttype fucker orgasm face."
<</if>>
<<else>>
<<if $face is "covered">>
"Come on, let's see your face. I want to see how you look having your ass fucked by a $beasttype."
<<else>>
"<<pShe>> looks so cute having <<pher>> ass fucked by that $beasttype."
<</if>>
<</if>>
<<else>>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
"You're cumming while having your ass fucked, how much dignity is covering your face preserving?"
<<else>>
"I got a nice picture of <<pher>> orgasm face."
<</if>>
<<else>>
<<if $face is "covered">>
"Come on, let's see your face. I want to see how you look having your ass fucked."
<<else>>
"<<pShe>> looks so cute having <<pher>> ass ravaged."
<</if>>
<</if>>
<</if>>
<<elseif $anusstate is "imminent">>
<<if $enemytype is "beast">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
"You can cover your face if you want, we can all tell you're cumming hard for that $beasttype."
<<else>>
"<<pShes>> cumming this hard with the $beasttype pressing just the tip into <<pher>> ass."
<</if>>
<<else>>
<<if $face is "covered">>
"Don't be shy, I want a good picture of your face when your ass is skewered by that $beasttype."
<<else>>
"Smile for the camera like a good $beasttype <<bitchcomma>> you slut."
<</if>>
<</if>>
<<else>>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
"You can cover your face if you want, we can all tell you're cumming hard."
<<else>>
"<<pShes>> cumming this hard with just the tip pressing into <<pher>> ass."
<</if>>
<<else>>
<<if $face is "covered">>
"Don't be shy, I want a good picture of your face when your ass is skewered."
<<else>>
"Smile for the camera like a good anal slut."
<</if>>
<</if>>
<</if>>
<<elseif $anusstate is "entrance">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
"You can cover your face if you want, we can all tell you're cumming hard."
<<else>>
"<<pShes>> cumming this hard with just the tip pressing into <<pher>> ass."
<</if>>
<<else>>
<<if $face is "covered">>
"Don't be shy, I want a good picture of your face when your ass is skewered."
<<else>>
"Smile for the camera like a good anal slut."
<</if>>
<</if>>
<<elseif $mouthstate is "penetrated">>
<<if $enemytype is "beast">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
"Look at how cute <<pshe>> looks cumming while slurping on that $beasttype dick. <<pShes>> so shy about it too."
<<else>>
"Look at how cute <<pshe>> looks cumming while slurping on that $beasttype dick."
<</if>>
<<else>>
<<if $face is "covered">>
"Move your hand <<bitchcomma>> you're getting in the way of the action."
<<else>>
"Do you like the taste of $beasttype dick?"
<</if>>
<</if>>
<<else>>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
"Look at how cute <<pshe>> looks cumming while slurping on a dick. <<pShes>> so shy about it too."
<<else>>
"Look at how cute <<pshe>> looks cumming while slurping on a dick."
<</if>>
<<else>>
<<if $face is "covered">>
"Move your hand <<bitchcomma>> you're getting in the way of the action."
<<else>>
"Such a nice shot of your face being fucked."
<</if>>
<</if>>
<</if>>
<<elseif $mouthstate is "imminent">>
<<if $enemytype is "beast">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
"Cover your face all you want, we know you love it."
<<else>>
"<<pShes>> cumming already, <<pshe>> just can't wait for the $beasttype dick."
<</if>>
<<else>>
<<if $face is "covered">>
"Move <<pher>> hand, I want to catch the look on <<pher>> face when it starts fucking <<pher>> mouth."
<<else>>
"I want to catch the look on <<pher>> face when it starts fucking <<pher>> mouth."
<</if>>
<</if>>
<<else>>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
"Cover your face all you want, we know you love it."
<<else>>
"<<pShes>> cumming already, now's the time to give <<phim>> a taste of dick."
<</if>>
<<else>>
<<if $face is "covered">>
"Move <<pher>> hand, I want to catch the look on <<pher>> face when you start fucking <<pher>> mouth."
<<else>>
"I want to catch the look on <<pher>> face when you start fucking <<pher>> mouth."
<</if>>
<</if>>
<</if>>
<<elseif $mouthstate is "entrance">>
<<if $enemytype is "beast">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
"Cover your face all you want, we know you love it."
<<else>>
"<<pShes>> cumming already, <<pshe>> just can't wait for the $beasttype dick."
<</if>>
<<else>>
<<if $face is "covered">>
"Move <<pher>> hand, I want to catch the look on <<pher>> face when it starts fucking <<pher>> mouth."
<<else>>
"I want to catch the look on <<pher>> face when it starts fucking <<pher>> mouth."
<</if>>
<</if>>
<<else>>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
"Cover your face all you want, we know you love it."
<<else>>
"<<pShes>> cumming already, now's the time to give <<phim>> a taste of dick."
<</if>>
<<else>>
<<if $face is "covered">>
"Move <<pher>> hand, I want to catch the look on <<pher>> face when you start fucking <<pher>> mouth."
<<else>>
"I want to catch the look on <<pher>> face when you start fucking <<pher>> mouth."
<</if>>
<</if>>
<</if>>
<<elseif $vaginastate is "othermouth">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
"You can't hide it, having your pussy licked is too much for you."
<<else>>
"Look at <<phim>> squirm! Your tongue's too much for <<phimstop>>"
<</if>>
<<else>>
<<if $face is "covered">>
"What's the matter? Ashamed of having your pussy licked?"
<<else>>
"Tongue-fuck <<phim>> harder, I want to see <<phim>> squirm.
<</if>>
<</if>>
<<elseif $vaginastate is "othermouthimminent">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
"You can't hide your orgasm from the camera."
<<else>>
"<<pShes>> cumming, it might be too much for <<phim>> if you tongue-fuck <<phim>> now. Do it."
<</if>>
<<else>>
<<if $face is "covered">>
"Don't be shy, you like having your pussy eaten don't you."
<<else>>
"You like having your pussy eaten, don't you."
<</if>>
<</if>>
<<elseif $vaginastate is "othermouthentrance">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
"You can't hide your orgasm from the camera."
<<else>>
"<<pShes>> cumming, it might be too much for <<phim>> if you tongue-fuck <<phim>> now. Do it."
<</if>>
<<else>>
<<if $face is "covered">>
"Don't be shy, you like having your pussy eaten don't you."
<<else>>
"You like having your pussy eaten, don't you."
<</if>>
<</if>>
<<elseif $penisstate is "othermouth">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
"Don't be shy, it's normal to cum while having your penis sucked."
<<else>>
"I got the perfect picture of <<pher>> orgasm face."
<</if>>
<<else>>
<<if $face is "covered">>
"<<pShes>> embarrassed about having <<pher>> penis sucked! How adorable."
<<else>>
"Suck <<phim>> harder, I want to see how cute <<pshe>> looks."
<</if>>
<</if>>
<<elseif $penisstate is "othermouthimminent">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
"<<pShes>> cumming already, sucking now might be too much for <<phimstop>> Do it."
<<else>>
"<<pShes>> cumming already, sucking now might be too much for <<phimstop>> Do it."
<</if>>
<<else>>
<<if $face is "covered">>
"Move your hand, I want to see your expression when your penis starts getting sucked."
<<else>>
"I can't wait to see <<pher>> expression when you start sucking."
<</if>>
<</if>>
<<elseif $penisstate is "othermouthentrance">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
"<<pShes>> cumming already, sucking now might be too much for <<phimstop>> Do it."
<<else>>
"<<pShes>> cumming already, sucking now might be too much for <<phimstop>> Do it."
<</if>>
<<else>>
<<if $face is "covered">>
"Move your hand, I want to see your expression when your penis starts getting sucked."
<<else>>
"I can't wait to see <<pher>> expression when you start sucking."
<</if>>
<</if>>
<<elseif $anusstate is "othermouth">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
"No point hiding your face, we can all tell you're a pervert."
<<else>>
"This slut likes having <<pher>> ass eaten."
<</if>>
<<else>>
<<if $face is "covered">>
"Move your hand <<bitchcomma>> I want to see how you feel about having your ass eaten."
<<else>>
"Probe <<pher>> ass harder, I think <<pshe>> likes it."
<</if>>
<</if>>
<<elseif $anusstate is "othermouthimminent">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
"No point hiding your face, we can all tell you're a pervert."
<<else>>
"This slut likes having <<pher>> ass eaten."
<</if>>
<<else>>
<<if $face is "covered">>
"Move your hand <<bitchcomma>> I want to see how you feel about having your ass eaten."
<<else>>
"Probe <<pher>> ass harder, I think <<pshe>> likes it."
<</if>>
<</if>>
<<elseif $anusstate is "othermouthentrance">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
"No point hiding your face, we can all tell you're a pervert."
<<else>>
"This slut likes having <<pher>> ass eaten."
<</if>>
<<else>>
<<if $face is "covered">>
"Move your hand <<bitchcomma>> I want to see how you feel about having your ass eaten."
<<else>>
"Probe <<pher>> ass harder, I think <<pshe>> likes it."
<</if>>
<</if>>
<<elseif $mouthstate is "kiss">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
"Is <<pShe>> cumming from being kissed? Is that pure or lewd?"
<<else>>
"<<pShes>> cumming from being kissed! Is that pure or lewd?"
<</if>>
<<else>>
<<if $face is "covered">>
"<<pShes>> shy about being kissed, how adorable."
<<else>>
"Such a romantic image."
<</if>>
<</if>>
<<elseif $mouthstate is "kissimminent">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
"Is <<pShe>> cumming from being kissed? Is that pure or lewd?"
<<else>>
"<<pShes>> cumming from being kissed! Is that pure or lewd?"
<</if>>
<<else>>
<<if $face is "covered">>
"<<pShes>> shy about being kissed, how adorable."
<<else>>
"Such a romantic image."
<</if>>
<</if>>
<<elseif $mouthstate is "kissentrance">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
"Is <<pShe>> cumming from being kissed? Is that pure or lewd?"
<<else>>
"<<pShes>> cumming from being kissed! Is that pure or lewd?"
<</if>>
<<else>>
<<if $face is "covered">>
"<<pShes>> shy about being kissed, how adorable."
<<else>>
"Such a romantic image."
<</if>>
<</if>>
<<else>>
<<if $orgasmdown gte 1>>
<<if $enemytype is "beast">>
<<if $face is "covered">>
"Are you ashamed to be cumming for that $beasttype?"
<<else>>
"That $beasttype can really make you cum hard, and I have proof."
<</if>>
<<else>>
<<if $face is "covered">>
"You can hide your face, but not your orgasm."
<<else>>
"Your orgasm face is so cute, and I have proof."
<</if>>
<</if>>
<<else>>
<<if $face is "covered">>
<<if $pain gte 80>>
"Hide your face if you want, we can see your tears."
<<elseif $pain gte 40>>
"You can't hide your tears from the camera."
<<else>>
"Don't be shy, let the camera see that pretty face of yours."
<</if>>
<<else>>
<<if $pain gte 80>>
"<<pShes>> crying. How pathetic."
<<elseif $pain gte 40>>
"Don't be upset. Smile for the camera."
<<else>>
"Smile <<girlstop>>"
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $rng gte 61 and $breastpic isnot 1>><<set $breastpic to 1>>
The $audiencedesc $audiencecamera points <<ahis>> camera at your <<breastsstop>> A light flashes as <<ahe>> takes a picture.
<<set $rng to random(1, 100)>>
<<if $breastsize is 0>>
<<if $playergenderappearance is "m">>
<<if $upperexposed gte 2>>
<<if $rng gte 67>>
"Boys have such cute nipples."
<<elseif $rng gte 33>>
"That sleek chest of yours is a thing of beauty."
<<else>>
"Don't be shy, there's nothing lewd about your boy nipples."
<</if>>
<<else>>
<<if $rng gte 67>>
"Get his top off, I wanna see that fine young chest."
<<elseif $rng gte 33>>
"I wish I could take a picture of what's under his top."
<<else>>
"Even clothed I can tell you have a lovely chest."
<</if>>
<</if>>
<<else>>
<<if $upperexposed gte 2>>
<<if $rng gte 67>>
"Your flat chest looks delicious."
<<elseif $rng gte 33>>
"<<pHer>> chest is so flat <<pshe>> could pass as a boy."
<<else>>
"It's important I take pictures of her cute chest. I'll need them later."
<</if>>
<<else>>
<<if $rng gte 67>>
"I can't wait to see under her top."
<<elseif $rng gte 33>>
"Do other girls tease you for your flat chest?"
<<else>>
"Don't worry, you're cute even without boobs."
<</if>>
<</if>>
<</if>>
<<elseif $breastsize lte 2>>
<<if $playergenderappearance is "m">>
<<if $upperexposed gte 2>>
<<if $rng gte 67>>
"Your flabby chest is almost like a girl's."
<<elseif $rng gte 33>>
"Look at those little tits. I bet the other boys pick on you."
<<else>>
"Don't be shy, there's nothing lewd about your boy nipples, even if they look like a girl's."
<</if>>
<<else>>
<<if $rng gte 67>>
"Get his top off, I wanna see that fine young chest."
<<elseif $rng gte 33>>
"I wish I could take a picture of what's under his top."
<<else>>
"Even clothed I can tell you have a lovely chest."
<</if>>
<</if>>
<<else>>
<<if $upperexposed gte 2>>
<<if $rng gte 67>>
"Her tiny breasts are so cute."
<<elseif $rng gte 33>>
"Now however large your breasts grow, I'll have evidence of when they were small and cute."
<<else>>
"Don't be ashamed of your small breasts, they're adorable."
<</if>>
<<else>>
<<if $rng gte 67>>
"I can see the shape of <<pher>> developing breasts beneath <<pher>> $upperclothes."
<<elseif $rng gte 33>>
"Get <<pher>> top off, I want a picture of <<pher>> breasts."
<<else>>
"I can't wait to see <<pher>> little breasts, I bet they're superb."
<</if>>
<</if>>
<</if>>
<<elseif $breastsize lte 5>>
<<if $upperexposed gte 2>>
<<if $rng gte 67>>
"Your breasts are very photogenic."
<<elseif $rng gte 33>>
"Your breasts are mesmerising."
<<else>>
"This picture of your breasts will come in handy."
<</if>>
<<else>>
<<if $rng gte 67>>
"Get <<pher>> top off, I want a picture of <<pher>> breasts."
<<elseif $rng gte 33>>
"Don't be embarrassed, it's not like your breasts are exposed yet."
<<else>>
"Even clothed I can tell how lovely <<pher>> breasts are."
<</if>>
<</if>>
<<elseif $breastsize lte 8>>
<<if $upperexposed gte 2>>
<<if $rng gte 67>>
"<<pHer>> breasts flop about so beautifully."
<<elseif $rng gte 33>>
"Those are some impressive mammaries."
<<else>>
"Don't be ashamed, you should be proud of such large breasts."
<</if>>
<<else>>
<<if $rng gte 67>>
"Are <<pher>> breasts really as large as they seem? Only one way to find out."
<<elseif $rng gte 33>>
"Get <<pher>> top off, I want a picture of <<pher>> large breasts for later use."
<<else>>
"Breasts that large are lewd even under clothes."
<</if>>
<</if>>
<<else>>
<<if $upperexposed gte 2>>
<<if $rng gte 67>>
"Those are some gigantic udders."
<<elseif $rng gte 33>>
"You could feed every baby in town with those."
<<else>>
"Glad I got photographic proof, no one would believe how big they were otherwise."
<</if>>
<<else>>
<<if $rng gte 67>>
"You can't fake breasts this large, surely."
<<elseif $rng gte 33>>
"Get <<pher>> top off, I want a picture of these massive things."
<<else>>
"Breasts this huge are lewd even under clothes."
<</if>>
<</if>>
<</if>>
<<elseif $rng gte 41 and $bottompic isnot 1>><<set $bottompic to 1>>
The $audiencedesc $audiencecamera points <<ahis>> camera at your <<bottomstop>> A light flashes as <<ahe>> takes a picture.
<<set $rng to random(1, 100)>>
<<if $anusstate is "penetrated">>
<<if $enemytype is "beast">>
<<if $orgasmdown gte 1>>
"I got a nice close-up of the $beasttype ravaging <<pher>> <<girl>> ass while <<pshe>> cums."
<<else>>
"I got a nice close-up of the $beasttype ravaging <<pher>> <<girl>> ass."
<</if>>
<<else>>
<<if $orgasmdown gte 1>>
"I got a nice close-up of <<pher>> <<girl>> ass getting fucked. Look at <<pher>> shake."
<<else>>
"I got a nice close-up of <<pher>> <<girl>> ass getting fucked."
<</if>>
<</if>>
<<elseif $anusstate is "imminent">>
<<if $enemytype is "beast">>
<<if $orgasmdown gte 1>>
"<<pShes>> already cumming, I wonder how <<pshe>> would take a proper anal fucking from that $beasttype."
<<else>>
"I want to catch the moment it starts fucking <<phim>> proper."
<</if>>
<<else>>
<<if $orgasmdown gte 1>>
"<<pShes>> already cumming, I wonder how <<pshe>> would take a proper anal fucking."
<<else>>
"I want to catch the moment it goes in <<pher>> ass."
<</if>>
<</if>>
<<elseif $anusstate is "entrance">>
<<if $enemytype is "beast">>
<<if $orgasmdown gte 1>>
"I think it's gonna fuck <<pher>> slut ass!"
<<else>>
"I think it's gonna fuck <<pher>> ass!"
<</if>>
<<else>>
<<if $orgasmdown gte 1>>
"I hope you're going all-in on this little slut's ass."
<<else>>
"I hope you're going all-in on <<pher>> ass."
<</if>>
<</if>>
<<elseif $anusstate is "othermouth">>
<<if $orgasmdown gte 1>>
"<<pShes>> responding to having <<pher>> ass eaten."
<<else>>
"You're really getting in there."
<</if>>
<<elseif $anusstate is "othermouthimminent">>
<<if $orgasmdown gte 1>>
"What does little <<girl>> ass taste like?"
<<else>>
"How's <<pshe>> taste."
<</if>>
<<elseif $anusstate is "othermouthentrance">>
<<if $orgasmdown gte 1>>
"It might be too much for <<phimstop>> I can't wait."
<<else>>
"You're actually gonna eat <<pher>> ass?"
<</if>>
<<else>>
<<if $orgasmdown gte 1>>
<<if $lowerexposed gte 2 and $underexposed gte 1>>
<<if $rng gte 67>>
"I got a nice shot of <<pher>> bare ass."
<<elseif $rng gte 33>>
"I've never seen such a spankable ass."
<<else>>
"<<pHer>> orgasm is making <<pher>> ass shake beautifully."
<</if>>
<<else>>
<<if $rng gte 67>>
"<<pShes>> such a lewd little <<girlcomma>> <<pshe>> needs to be punished."
<<elseif $rng gte 33>>
"Get <<pher>> clothes off while <<pshe>> spasms, I want a clear shot of <<pher>> ass."
<<else>>
"<<pHer>> ass is so lewd, even clothed."
<</if>>
<</if>>
<<else>>
<<if $lowerexposed gte 2 and $underexposed gte 1>>
<<if $rng gte 67>>
"Are you embarrassed about your ass being exposed like this?"
<<elseif $rng gte 33>>
"I got a great shot of <<pher>> ass."
<<else>>
"<<pHer>> naked ass is so lewd."
<</if>>
<<else>>
<<if $rng gte 67>>
"This <<girl>> has a fine ass."
<<elseif $rng gte 33>>
"Bare <<pher>> ass, I want a better picture."
<<else>>
"Even clothed <<pher>> ass looks good."
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $rng gte 21 and $genitalpic isnot 1>><<set $genitalpic to 1>>
The $audiencedesc $audiencecamera points <<ahis>> camera at your <<genitalsstop>> A light flashes as <<ahe>> takes a picture.
<<set $rng to random(1, 100)>>
<<if $vaginastate is "penetrated">>
<<if $enemytype is "beast">>
<<if $orgasmdown gte 1>>
"I got a nice shot of <<pher>> shuddering on that dick."
<<else>>
"Wow, <<pher>> pussy is really getting pounded by that $beasttype."
<</if>>
<<else>>
<<if $orgasmdown gte 1>>
"I got a nice shot of <<pher>> shuddering on that dick."
<<else>>
"Wow, <<pher>> pussy is really getting a pounding."
<</if>>
<</if>>
<<elseif $vaginastate is "imminent">>
<<if $enemytype is "beast">>
<<if $orgasmdown gte 1>>
"<<pHer>> <<bitch>> pussy is twitching and it's not even in yet. <<pShe>> can't wait to be bred."
<<else>>
"I hope I catch the moment <<pher>> pussy is first violated."
<</if>>
<<else>>
<<if $orgasmdown gte 1>>
"<<pHer>> pussy is twitching and it's not even in yet. Such a slut."
<<else>>
"I hope I catch the moment <<pher>> pussy is first violated."
<</if>>
<</if>>
<<elseif $vaginastate is "entrance">>
<<if $enemytype is "beast">>
<<if $orgasmdown gte 1>>
"<<pShes>> cumming from such little stimulation, fucking <<pher>> pussy might break <<phim>> fully."
<<else>>
"Your pussy is about to get the treatment it deserves."
<</if>>
<<else>>
<<if $orgasmdown gte 1>>
"<<pShes>> cumming from such little stimulation, fucking a $beasttype might break <<phim>> fully."
<<else>>
"Your pussy is about to get the treatment it deserves."
<</if>>
<</if>>
<<elseif $penisstate is "penetrated">>
<<if $orgasmdown gte 1>>
"I got a nice shot of <<phim>> shuddering in that pussy."
<<else>>
"Wow, <<pher>> penis is really getting a pounding."
<</if>>
<<elseif $penisstate is "imminent">>
<<if $orgasmdown gte 1>>
"<<pHer>> penis is twitching and it's not even in yet. Such a slut."
<<else>>
"I hope I catch the moment <<pher>> penis is first violated."
<</if>>
<<elseif $penisstate is "entrance">>
<<if $orgasmdown gte 1>>
"<<pShes>> cumming from such little stimulation, fucking <<phim>> might break <<phim>> fully."
<<else>>
"Your penis is about to get the treatment it deserves."
<</if>>
<<elseif $penisstate is "otheranus">>
<<if $orgasmdown gte 1>>
"I got a nice shot of <<phim>> shuddering in that ass."
<<else>>
"Wow, <<pher>> penis is really getting a pounding."
<</if>>
<<elseif $penisstate is "otheranusimminent">>
<<if $orgasmdown gte 1>>
"<<pHer>> penis is twitching and it's not even in yet. Such a slut."
<<else>>
"I hope I catch the moment <<pher>> penis is first violated."
<</if>>
<<elseif $penisstate is "otheranusentrance">>
<<if $orgasmdown gte 1>>
"<<pShes>> cumming from such little stimulation, fucking <<phim>> might break <<phim>> fully."
<<else>>
"Your penis is about to get the treatment it deserves."
<</if>>
<<elseif $vaginastate is "othermouth">>
<<if $orgasmdown gte 1>>
"<<pHer>> pussy is twitching so delightfully."
<<else>>
"You're really getting your tongue in there."
<</if>>
<<elseif $vaginastate is "othermouthimminent">>
<<if $orgasmdown gte 1>>
"Does <<pher>> pussy juice taste good?"
<<else>>
"Does <<pher>> pussy taste good?"
<</if>>
<<elseif $vaginastate is "othermouthentrance">>
<<if $orgasmdown gte 1>>
"Does <<pher>> pussy juice taste good?"
<<else>>
"Does <<pher>> pussy taste good?"
<</if>>
<<elseif $penisstate is "othermouth">>
<<if $orgasmdown gte 1>>
"Does <<pher>> cum taste good?"
<<else>>
"I can tell <<pshes>> cumming into your mouth."
<</if>>
<<elseif $penisstate is "othermouthimminent">>
<<if $orgasmdown gte 1>>
"Take <<phim>> into your mouth already, I want to see <<phim>> squirm more."
<<else>>
"Does <<pher>> penis taste good?"
<</if>>
<<elseif $penisstate is "othermouthentrance">>
<<if $orgasmdown gte 1>>
"Take <<phim>> into your mouth already, I want to see <<phim>> squirm more."
<<else>>
"Does <<pher>> penis taste good?"
<</if>>
<<else>>
<<if $orgasmdown gte 1>>
<<if $penisexist is 1 >>
<<if $devstate gte 1 and $orgasmcount lt 24>>
<<if $rng gte 67>>
"I got a shot of <<pher>> cum flying through the air."
<<elseif $rng gte 33>>
"Look at <<phim>> squirt!"
<<else>>
"I caught <<phim>> cumming on camera. How shameful."
<</if>>
<<else>>
<<if $rng gte 67>>
"I got a shot of <<phim>> cumming, but nothing came out."
<<elseif $rng gte 33>>
"This <<girl>> can't even cum properly, pathetic."
<<else>>
"<<pHer>> orgasm is disappointingly dry. I got it on camera at least."
<</if>>
<</if>>
<<else>>
<<if $vaginause is "cover">>
"Move your hand, I want a clear shot of your pussy while you cum."
<<else>>
"I got a perfect shot of <<pher>> pussy twitching in climax."
<</if>>
<</if>>
<<else>>
<<if $underexposed gte 1 and $lowerexposed gte 2>>
<<if $penisexist is 1>>
<<if $penisuse is "cover">>
<<if $rng gte 67>>
"Move your hand, I want to see your little penis."
<<elseif $rng gte 33>>
"Aww, <<pshes>> shy."
<<else>>
"Someone move <<pher>> hand out the way, I want a shot of <<pher>> penis."
<</if>>
<<else>>
<<if $rng gte 67>>
"I got a great picture of <<pher>> cute penis."
<<elseif $rng gte 33>>
"Don't be shy, everyone should know how beautiful your penis is."
<<else>>
"If you don't want your penis photographed, you shouldn't act like a slut."
<</if>>
<</if>>
<<else>>
<<if $vaginause is "cover">>
<<if $rng gte 67>>
"Move your hand, I want to see your little pussy."
<<elseif $rng gte 33>>
"Aww, <<pshes>> shy."
<<else>>
"Someone move <<pher>> hand out the way, I want a shot of <<pher>> pussy."
<</if>>
<<else>>
<<if $rng gte 67>>
"I got a great picture of <<pher>> cute pussy."
<<elseif $rng gte 33>>
"Don't be shy, everyone should know how beautiful your pussy is."
<<else>>
"If you don't want your pussy photographed, you shouldn't act like a slut."
<</if>>
<</if>>
<</if>>
<<else>>
<<if $playergenderappearance is "m">>
<<if $penisuse is "cover">>
<<if $rng gte 67>>
"Move your hand, I want to see your little penis."
<<elseif $rng gte 33>>
"Aww, <<pshes>> shy."
<<else>>
"Someone move <<pher>> hand out the way, I want a shot of <<pher>> penis."
<</if>>
<<else>>
<<if $rng gte 67>>
"I got a great picture of <<pher>> cute penis."
<<elseif $rng gte 33>>
"Don't be shy, everyone should know how beautiful your penis is."
<<else>>
"If you don't want your penis photographed, you shouldn't act like a slut."
<</if>>
<</if>>
<<else>>
<<if $vaginause is "cover">>
<<if $rng gte 67>>
"Move your hand, I want to see your little pussy."
<<elseif $rng gte 33>>
"Aww, <<pshes>> shy."
<<else>>
"Someone move <<pher>> hand out the way, I want a shot of <<pher>> pussy."
<</if>>
<<else>>
<<if $rng gte 67>>
"I got a great picture of <<pher>> cute pussy."
<<elseif $rng gte 33>>
"Don't be shy, everyone should know how beautiful your pussy is."
<<else>>
"If you don't want your pussy photographed, you shouldn't act like a slut."
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<elseif $bodypic isnot 1>><<set $bodypic to 1>>
The $audiencedesc $audiencecamera leans back so <<ahis>> camera can take in the whole scene. A light flashes as <<ahe>> takes a picture.
<<if $vaginastate is "penetrated">>
<<if $enemytype is "beast">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
"Cover your face if you want, you're still a $beasttype's bitch."
<<else>>
"The $beasttype's fucked <<phim>> to orgasm, and I have proof."
<</if>>
<<else>>
<<if $face is "covered">>
"Stop hiding your face and smile for the camera."
<<else>>
"Good $beasttype, show this bitch <<pher>> place."
<</if>>
<</if>>
<<else>>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
"Cover your face if you want, it just makes the scene hotter."
<<else>>
"You've fucked <<phim>> to orgasm. Keep going."
<</if>>
<<else>>
<<if $face is "covered">>
"Stop hiding your face and smile for the camera."
<<else>>
"Show this slut what <<pshes>> good for."
<</if>>
<</if>>
<</if>>
<<elseif $vaginastate is "imminent">>
<<if $enemytype is "beast">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
"Cumming already? It isn't even fucking you yet."
<<else>>
"Your cunt belongs to that $beasttype now, slut."
<</if>>
<<else>>
<<if $face is "covered">>
"Stop covering your face, I want to capture your expression when it goes in."
<<else>>
"Your cunt belongs to that $beasttype now."
<</if>>
<</if>>
<<else>>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
"<<pHer>> pussy isn't being fucked yet <<pshes>> still cumming."
<<else>>
"There's no escaping now, slut."
<</if>>
<<else>>
<<if $face is "covered">>
"Stop covering your face, I want to capture your expression when it goes in."
<<else>>
"What are you waiting for? Fuck <<phim>> now."
<</if>>
<</if>>
<</if>>
<<elseif $vaginastate is "entrance">>
<<if $enemytype is "beast">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
"Cumming already? It isn't even fucking you yet."
<<else>>
"Your cunt belongs to that $beasttype now, slut."
<</if>>
<<else>>
<<if $face is "covered">>
"Stop covering your face, I want to capture your expression when it goes in."
<<else>>
"Your cunt belongs to that $beasttype now."
<</if>>
<</if>>
<<else>>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
"<<pHer>> pussy isn't being fucked yet <<pshes>> still cumming."
<<else>>
"There's no escaping now, slut."
<</if>>
<<else>>
<<if $face is "covered">>
"Stop covering your face, I want to capture your expression when it goes in."
<<else>>
"What are you waiting for? Fuck <<phim>> now."
<</if>>
<</if>>
<</if>>
<<elseif $penisstate is "penetrated">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
"Cover your face if you want, it just makes the scene hotter."
<<else>>
"You've fucked <<phim>> to orgasm. Keep going."
<</if>>
<<else>>
<<if $face is "covered">>
"Stop hiding your face and smile for the camera."
<<else>>
"Show this fucktoy what <<pshes>> good for."
<</if>>
<</if>>
<<elseif $penisstate is "imminent">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
"<<pHer>> penis isn't being fucked yet <<pshes>> still cumming."
<<else>>
"There's no escaping now, slut."
<</if>>
<<else>>
<<if $face is "covered">>
"Stop covering your face, I want to capture your expression when it goes in."
<<else>>
"What are you waiting for? Fuck <<phim>> now."
<</if>>
<</if>>
<<elseif $penisstate is "entrance">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
"<<pHer>> penis isn't being fucked yet <<pshes>> still cumming."
<<else>>
"There's no escaping now, slut."
<</if>>
<<else>>
<<if $face is "covered">>
"Stop covering your face, I want to capture your expression when it goes in."
<<else>>
"What are you waiting for? Fuck <<phim>> now."
<</if>>
<</if>>
<<elseif $penisstate is "otheranus">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
"Look at <<pher>> body writhe."
<<else>>
"You've fucked <<pher>> to orgasm. Keep going."
<</if>>
<<else>>
<<if $face is "covered">>
"<<pShes>> so shy and cute."
<<else>>
"Show this fucktoy what <<pshes>> good for."
<</if>>
<</if>>
<<elseif $penisstate is "otheranusimminent">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
"<<pHer>> penis isn't being fucked yet <<pshes>> still cumming."
<<else>>
"There's no escaping now, slut."
<</if>>
<<else>>
<<if $face is "covered">>
"Stop covering your face, I want to capture your expression when it goes in."
<<else>>
"What are you waiting for? Fuck <<phim>> now."
<</if>>
<</if>>
<<elseif $penisstate is "otheranusentrance">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
"<<pHer>> penis isn't being fucked yet <<pshes>> still cumming."
<<else>>
"There's no escaping now, slut."
<</if>>
<<else>>
<<if $face is "covered">>
"Stop covering your face, I want to capture your expression when it goes in."
<<else>>
"What are you waiting for? Fuck <<phim>> now."
<</if>>
<</if>>
<<elseif $anusstate is "penetrated">>
<<if $enemytype is "beast">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
"You're cumming with a $beasttype's dick in your ass, how much dignity do you think you're protecting?
<<else>>
"That's right, cum on that animal dick. Show the world what a <<bitch>> you are."
<</if>>
<<else>>
<<if $face is "covered">>
"Good $beasttype, fuck this <<bitch>> hard."
<<else>>
"Good $beasttype, show this <<girl>> <<pher>> place."
<</if>>
<</if>>
<<else>>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
"You're cumming with a dick in your ass, how much dignity do you think you're protecting?
<<else>>
"That's right, cum on that dick. Show the world what a huge slut you are."
<</if>>
<<else>>
<<if $face is "covered">>
"Fuck <<phim>> harder!"
<<else>>
"Keep ravaging this <<girls>> ass, I want more pictures."
<</if>>
<</if>>
<</if>>
<<elseif $anusstate is "imminent">>
<<if $enemytype is "beast">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
"You love it, don't pretend otherwise."
<<else>>
"This <<bitch>> can't help it."
<</if>>
<<else>>
<<if $face is "covered">>
"Move your hands, I want to see your expression when your ass is violated."
<<else>>
"Good $beasttype, make <<phim>> your bitch."
<</if>>
<</if>>
<<else>>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
"You can't hide your orgasm from us."
<<else>>
"This <<bitch>> can't help it."
<</if>>
<<else>>
<<if $face is "covered">>
"Move your hands, I want to see your expression when your ass is violated."
<<else>>
"Fuck <<phimcomma>> make <<phim>> squirm."
<</if>>
<</if>>
<</if>>
<<elseif $anusstate is "entrance">>
<<if $enemytype is "beast">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
"You can't hide your orgasm from us."
<<else>>
"This <<bitch>> can't help it."
<</if>>
<<else>>
<<if $face is "covered">>
"A good fucking will teach this <<bitch>> <<pher>> place."
<<else>>
"I think it's gonna fuck <<phimcomma>> I can't wait to get a picture."
<</if>>
<</if>>
<<else>>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
"You can't hide your orgasm from us."
<<else>>
"This <<bitch>> can't help it."
<</if>>
<<else>>
<<if $face is "covered">>
"This <<girl>> needs to learn <<pher>> place."
<<else>>
"Fuck <<phimcomma>> make <<phim>> squirm."
<</if>>
<</if>>
<</if>>
<<elseif $mouthstate is "penetrated">>
<<if $enemytype is "beast">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
"It's amazing what <<pshe>> can fit in there."
<<else>>
"I hope it cums down <<pher>> throat while <<pshe>> orgasms."
<</if>>
<<else>>
<<if $face is "covered">>
"I doubt the $beasttype cares which hole it fucks."
<<else>>
"You like the taste of $beasttype dick, don't you."
<</if>>
<</if>>
<<else>>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
"It's amazing what <<pshe>> can fit in there."
<<else>>
"I hope you cum down <<pher>> throat while <<pshe>> orgasms."
<</if>>
<<else>>
<<if $face is "covered">>
"No hole is off-limits."
<<else>>
"Is that dick tasty? Don't answer with your mouth full."
<</if>>
<</if>>
<</if>>
<<elseif $mouthstate is "imminent">>
<<if $enemytype is "beast">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
"Move <<pher>> hands, I want the camera to see who this <<bitch>> is."
<<else>>
"You'll look great cumming with a mouthful of $beasttype dick."
<</if>>
<<else>>
<<if $face is "covered">>
"Don't stop there, show this <<bitch>> how much <<pshes>> worth."
<<else>>
"I want to see this <<bitch>> get a mouthful."
<</if>>
<</if>>
<<else>>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
"Move <<pher>> hands, I want the camera to see who this slut is."
<<else>>
"You'll look great cumming with a mouthful of dick."
<</if>>
<<else>>
<<if $face is "covered">>
"Don't stop there, show this <<bitch>> how much <<pshes>> worth."
<<else>>
"I want to see this <<bitch>> get a mouthful."
<</if>>
<</if>>
<</if>>
<<elseif $mouthstate is "entrance">>
<<if $enemytype is "beast">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
"Move <<pher>> hands, I want the camera to see who this <<bitch>> is."
<<else>>
"You'll look great cumming with a mouthful of $beasttype dick."
<</if>>
<<else>>
<<if $face is "covered">>
"Don't stop there, show this <<bitch>> how much <<pshes>> worth."
<<else>>
"I want to see this <<bitch>> get a mouthful."
<</if>>
<</if>>
<<else>>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
"Move <<pher>> hands, I want the camera to see who this slut is."
<<else>>
"You'll look great cumming with a mouthful of dick."
<</if>>
<<else>>
<<if $face is "covered">>
"Don't stop there, show this <<bitch>> how much <<pshes>> worth."
<<else>>
"I want to see this <<bitch>> get a mouthful."
<</if>>
<</if>>
<</if>>
<<elseif $vaginastate is "othermouth">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
"Careful not to suffocate <<phimcomma>> I want more pictures first."
<<else>>
"<<pShes>> cumming, guess <<pshe>> is just a fucktoy."
<</if>>
<<else>>
<<if $face is "covered">>
"That's it, put <<pher>> mouth to work."
<<else>>
"Is that pussy tasty? Don't answer with your mouth full."
<</if>>
<</if>>
<<elseif $vaginastate is "othermouthimminent">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
"Move <<pher>> hands, I want the camera to see who this slut is."
<<else>>
"You'll look great cumming with a mouthful of cunt."
<</if>>
<<else>>
<<if $face is "covered">>
"Don't stop there, show this <<bitch>> how much <<pshes>> worth."
<<else>>
"Put <<pher>> <<bitch>> mouth to work."
<</if>>
<</if>>
<<elseif $vaginastate is "othermouthentrance">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
"Move <<pher>> hands, I want the camera to see who this slut is."
<<else>>
"You'll look great cumming with a mouthful of cunt."
<</if>>
<<else>>
<<if $face is "covered">>
"Don't stop there, show this <<bitch>> how much <<pshes>> worth."
<<else>>
"Put <<pher>> <<bitch>> mouth to work."
<</if>>
<</if>>
<<elseif $penisstate is "othermouth">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
"<<pShes>> shy about cumming into your mouth, how cute."
<<else>>
"This <<girl>> is clearly enjoying it, don't stop."
<</if>>
<<else>>
<<if $face is "covered">>
"<<pShes>> shy about having <<pher>> dick sucked, how cute."
<<else>>
"Smile for the camera <<girlcomma>> you should be happy about having your penis sucked."
<</if>>
<</if>>
<<elseif $penisstate is "othermouthimminent">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
"I hope you milk <<phim>> dry."
<<else>>
"Aren't you worried you'll get cum on your face?"
<</if>>
<<else>>
<<if $face is "covered">>
"Lick <<phim>> good and proper."
<<else>>
"I hope I get a shot of <<phim>> cumming on your face."
<</if>>
<</if>>
<<elseif $penisstate is "othermouthentrance">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
"I hope you milk <<phim>> dry."
<<else>>
"Aren't you worried you'll get cum on your face?"
<</if>>
<<else>>
<<if $face is "covered">>
"Lick <<phim>> good and proper."
<<else>>
"I hope I get a shot of <<phim>> cumming on your face."
<</if>>
<</if>>
<<elseif $anusstate is "othermouth">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
"<<pShes>> embarrassed! How adorable."
<<else>>
"Cumming with someone's tongue in your ass, you're a lewd <<girl>> aren't you."
<</if>>
<<else>>
<<if $face is "covered">>
"I can't get a clear shot of <<pher>> face with <<pher>> hands in the way."
<<else>>
"Another nice picture of this slut."
<</if>>
<</if>>
<<elseif $anusstate is "othermouthimminent">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
"<<pShes>> embarrassed! How adorable."
<<else>>
"<<pShes>> cumming already, be careful not to make <<phim>> faint."
<</if>>
<<else>>
<<if $face is "covered">>
"I don't know what you think covering your face achieves."
<<else>>
"Are you gonna lick <<phim>> out? I need a picture of that."
<</if>>
<</if>>
<<elseif $anusstate is "othermouthentrance">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
"<<pShes>> embarrassed! How adorable."
<<else>>
"<<pShes>> cumming already, be careful not to make <<pher>> faint."
<</if>>
<<else>>
<<if $face is "covered">>
"I don't know what you think covering your face achieves."
<<else>>
"Are you gonna lick <<phim>> out? I need a picture of that."
<</if>>
<</if>>
<<elseif $mouthstate is "kiss">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
"Don't hide your pretty face."
<<else>>
"Is that kiss really so pleasurable or is <<pshe>> cumming?"
<</if>>
<<else>>
<<if $face is "covered">>
"How cute and romantic."
<<else>>
"How romantic."
<</if>>
<</if>>
<<elseif $mouthstate is "kissimminent">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
"Don't hide your pretty face."
<<else>>
"Is that kiss really so pleasurable or is <<pshe>> cumming?"
<</if>>
<<else>>
<<if $face is "covered">>
"How cute and romantic."
<<else>>
"How romantic."
<</if>>
<</if>>
<<elseif $mouthstate is "kissentrance">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
"Is <<pshe>> shaking because <<pshes>> shy?"
<<else>>
"<<pShes>> shaking in anticipation."
<</if>>
<<else>>
<<if $face is "covered">>
"How cute and romantic."
<<else>>
"How romantic."
<</if>>
<</if>>
<<else>>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
"What a slut."
<<else>>
"I hope <<pher>> convulsions come across in the picture."
<</if>>
<<else>>
<<if $face is "covered">>
<<if $pain gte 80>>
"I think <<pshes>> hurt. Don't stop."
<<elseif $pain gte 40>>
"Don't bother hiding your tears, we can all see."
<<else>>
"Move your hands <<bitchcomma>> I want a picture of your face."
<</if>>
<<else>>
<<if $pain gte 80>>
"Now everyone will know how pathetic you are."
<<elseif $pain gte 40>>
"That's a nice shot. Are those tears?"
<<else>>
"Can't wait to share this with my friends."
<</if>>
<</if>>
<</if>>
<</if>>
<</if>>
<<if $face isnot "covered">>
<<if $exposed is 1>>
<<fameexhibitionism 1>>
<<elseif $exposed gte 2>>
<<fameexhibitionism 2>>
<</if>>
<<if $consensual is 1>>
<<famesex 1>>
<<else>>
<<famerape 1>>
<</if>>
<<if $enemytype is "beast">>
<<famebestiality 1>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "ahis">><<nobr>>
<<if $audiencecamera is "man">>
his
<<elseif $audiencecamera is "boy">>
his
<<elseif $audiencecamera is "woman">>
her
<<elseif $audiencecamera is "girl">>
her
<</if>>
<</nobr>><</widget>>
<<widget "ahe">><<nobr>>
<<if $audiencecamera is "man">>
he
<<elseif $audiencecamera is "boy">>
he
<<elseif $audiencecamera is "woman">>
she
<<elseif $audiencecamera is "girl">>
she
<</if>>
<</nobr>><</widget>>
<<widget "audiencespeech">><<nobr>>
<<set $audiencemember to 0>>
<<set $rng to random(1, 100)>>
<<if $location is "school" or $location is "pool">>
<<if $malechance is 0>>
<<set $audiencemember to "girl">>
<<elseif $malechance is 100>>
<<set $audiencemember to "boy">>
<<elseif $rng gte 50>>
<<set $audiencemember to "boy">>
<<else>>
<<set $audiencemember to "girl">>
<</if>>
<<else>>
<<if $malechance is 0>>
<<set $audiencemember to "woman">>
<<elseif $malechance is 100>>
<<set $audiencemember to "man">>
<<elseif $rng gte 50>>
<<set $audiencemember to "man">>
<<else>>
<<set $audiencemember to "woman">>
<</if>>
<</if>>
<<set $rng to random(1, 100)>>
<<if $rng gte 91 and $audiencecamera6 is 0>>
<span class="pink">A $audiencemember pulls out a phone and points the camera at you.</span>
<<if $audiencecamera1 is 0>>
<<set $audiencecamera1 to $audiencemember>>
<<elseif $audiencecamera2 is 0>>
<<set $audiencecamera2 to $audiencemember>>
<<elseif $audiencecamera3 is 0>>
<<set $audiencecamera3 to $audiencemember>>
<<elseif $audiencecamera4 is 0>>
<<set $audiencecamera4 to $audiencemember>>
<<elseif $audiencecamera5 is 0>>
<<set $audiencecamera5 to $audiencemember>>
<<elseif $audiencecamera6 is 0>>
<<set $audiencecamera6 to $audiencemember>>
<</if>>
<<else>>
<<if $vaginastate is "penetrated">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
<<else>>
<</if>>
<<else>>
<<if $face is "covered">>
<<else>>
<</if>>
<</if>>
<<elseif $vaginastate is "imminent">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
<<else>>
<</if>>
<<else>>
<<if $face is "covered">>
<<else>>
<</if>>
<</if>>
<<elseif $vaginastate is "entrance">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
<<else>>
<</if>>
<<else>>
<<if $face is "covered">>
<<else>>
<</if>>
<</if>>
<<elseif $penisstate is "penetrated">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
<<else>>
<</if>>
<<else>>
<<if $face is "covered">>
<<else>>
<</if>>
<</if>>
<<elseif $penisstate is "imminent">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
<<else>>
<</if>>
<<else>>
<<if $face is "covered">>
<<else>>
<</if>>
<</if>>
<<elseif $penisstate is "entrance">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
<<else>>
<</if>>
<<else>>
<<if $face is "covered">>
<<else>>
<</if>>
<</if>>
<<elseif $penisstate is "otheranus">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
<<else>>
<</if>>
<<else>>
<<if $face is "covered">>
<<else>>
<</if>>
<</if>>
<<elseif $penisstate is "otheranusimminent">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
<<else>>
<</if>>
<<else>>
<<if $face is "covered">>
<<else>>
<</if>>
<</if>>
<<elseif $penisstate is "otheranusentrance">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
<<else>>
<</if>>
<<else>>
<<if $face is "covered">>
<<else>>
<</if>>
<</if>>
<<elseif $anusstate is "penetrated">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
<<else>>
<</if>>
<<else>>
<<if $face is "covered">>
<<else>>
<</if>>
<</if>>
<<elseif $anusstate is "imminent">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
<<else>>
<</if>>
<<else>>
<<if $face is "covered">>
<<else>>
<</if>>
<</if>>
<<elseif $anusstate is "entrance">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
<<else>>
<</if>>
<<else>>
<<if $face is "covered">>
<<else>>
<</if>>
<</if>>
<<elseif $mouthstate is "penetrated">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
<<else>>
<</if>>
<<else>>
<<if $face is "covered">>
<<else>>
<</if>>
<</if>>
<<elseif $mouthstate is "imminent">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
<<else>>
<</if>>
<<else>>
<<if $face is "covered">>
<<else>>
<</if>>
<</if>>
<<elseif $mouthstate is "entrance">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
<<else>>
<</if>>
<<else>>
<<if $face is "covered">>
<<else>>
<</if>>
<</if>>
<<elseif $vaginastate is "othermouth">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
<<else>>
<</if>>
<<else>>
<<if $face is "covered">>
<<else>>
<</if>>
<</if>>
<<elseif $vaginastate is "othermouthimminent">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
<<else>>
<</if>>
<<else>>
<<if $face is "covered">>
<<else>>
<</if>>
<</if>>
<<elseif $vaginastate is "othermouthentrance">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
<<else>>
<</if>>
<<else>>
<<if $face is "covered">>
<<else>>
<</if>>
<</if>>
<<elseif $penisstate is "othermouth">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
<<else>>
<</if>>
<<else>>
<<if $face is "covered">>
<<else>>
<</if>>
<</if>>
<<elseif $penisstate is "othermouthimminent">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
<<else>>
<</if>>
<<else>>
<<if $face is "covered">>
<<else>>
<</if>>
<</if>>
<<elseif $penisstate is "othermouthentrance">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
<<else>>
<</if>>
<<else>>
<<if $face is "covered">>
<<else>>
<</if>>
<</if>>
<<elseif $anusstate is "othermouth">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
<<else>>
<</if>>
<<else>>
<<if $face is "covered">>
<<else>>
<</if>>
<</if>>
<<elseif $anusstate is "othermouthimminent">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
<<else>>
<</if>>
<<else>>
<<if $face is "covered">>
<<else>>
<</if>>
<</if>>
<<elseif $anusstate is "othermouthentrance">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
<<else>>
<</if>>
<<else>>
<<if $face is "covered">>
<<else>>
<</if>>
<</if>>
<<elseif $mouthstate is "kiss">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
<<else>>
<</if>>
<<else>>
<<if $face is "covered">>
<<else>>
<</if>>
<</if>>
<<elseif $mouthstate is "kissimminent">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
<<else>>
<</if>>
<<else>>
<<if $face is "covered">>
<<else>>
<</if>>
<</if>>
<<elseif $mouthstate is "kissentrance">>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
<<else>>
<</if>>
<<else>>
<<if $face is "covered">>
<<else>>
<</if>>
<</if>>
<<else>>
<<if $orgasmdown gte 1>>
<<if $face is "covered">>
<<else>>
<</if>>
<<else>>
<<if $face is "covered">>
<<else>>
<</if>>
<</if>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "audience">><<nobr>>
<<if $enemyanger gte 100>>
<<if $enemyarousal gte (($enemyarousalmax / 10) * 8)>>
The audience is skittish but crowds around, as if you're a rare but dangerous animal.
<<elseif $enemyarousal gte (($enemyarousalmax / 10) * 4)>>
Most of the audience keep their distance, afraid you'll lash out.
<<else>>
The audience keep their distance, afraid you'll lash out.
<</if>>
<<elseif $enemyanger gte 60>>
<<if $enemyarousal gte (($enemyarousalmax / 10) * 8)>>
The audience crowds around, their eagerness at odds with their caution.
<<elseif $enemyarousal gte (($enemyarousalmax / 10) * 4)>>
The audience watches from a safe distance. The more daring among them inch closer.
<<else>>
The audience watches from a safe distance.
<</if>>
<<elseif $enemyanger gte 20>>
<<if $enemyarousal gte (($enemyarousalmax / 10) * 8)>>
The audience crowds around, excited to see what happens next.
<<elseif $enemyarousal gte (($enemyarousalmax / 10) * 4)>>
The excited audience crowds around.
<<else>>
The audience watches with interest.
<</if>>
<<else>>
<<if $enemyarousal gte (($enemyarousalmax / 10) * 8)>>
The audience crowds around, vying for a good vantage.
<<elseif $enemyarousal gte (($enemyarousalmax / 10) * 4)>>
The audience watches with interest. Some push through the crowd for a better vantage.
<<else>>
The audience watches with interest.
<</if>>
<</if>>
<br>
<<if $audiencecamera1 isnot 0>>
<<set $audienceselector to 1>>
<<audiencecamera>>
<br>
<</if>>
<<if $audiencecamera2 isnot 0>>
<<set $audienceselector to 2>>
<<audiencecamera>>
<br>
<</if>>
<<if $audiencecamera3 isnot 0>>
<<set $audienceselector to 3>>
<<audiencecamera>>
<br>
<</if>>
<<if $audiencecamera4 isnot 0>>
<<set $audienceselector to 4>>
<<audiencecamera>>
<br>
<</if>>
<<if $audiencecamera5 isnot 0>>
<<set $audienceselector to 5>>
<<audiencecamera>>
<br>
<</if>>
<<if $audiencecamera6 isnot 0>>
<<set $audienceselector to 6>>
<<audiencecamera>>
<br>
<</if>>
<<set $facepic to 0>>
<<set $breastpic to 0>>
<<set $bottompic to 0>>
<<set $genitalpic to 0>>
<<set $bodypic to 0>>
<<if $audiencecamera1 isnot 0 and $face is "covered">>
<span class="teal">At least your face is hidden.</span><br>
<</if>>
<<audiencespeech>>
<br>
<<if $rng - $enemyanger + (($enemyarousalmax / $enemyarousal) * 100) gte 0>>
<<audiencespeech>>
<br>
<</if>>
<<if $rng - $enemyanger + (($enemyarousalmax / $enemyarousal) * 100) gte 20>>
<<audiencespeech>>
<br>
<</if>>
<<if $rng - $enemyanger + (($enemyarousalmax / $enemyarousal) * 100) gte 40>>
<<audiencespeech>>
<br>
<</if>>
<<if $rng - $enemyanger + (($enemyarousalmax / $enemyarousal) * 100) gte 60>>
<<audiencespeech>>
<br>
<</if>>
<<if $rng - $enemyanger + (($enemyarousalmax / $enemyarousal) * 100) gte 80>>
<<audiencespeech>>
<br>
<</if>>
<br>
<</nobr>><</widget>>
<<set $audienceselector to 0>>
<<set $audiencecamera to 0>>
<<set $audiencecamera1 to 0>>
<<set $audiencecamera2 to 0>>
<<set $audiencecamera3 to 0>>
<<set $audiencecamera4 to 0>>
<<set $audiencecamera5 to 0>>
<<set $audiencecamera6 to 0>>
<<set $audiencemember to 0>>
:: Widgets Tips [widget]
<<widget "tips">><<nobr>>
<<if $tipcount is 0>><<set $tipcount += 1>>
Arousal increases during lewd acts, and decreases over time or when you orgasm.
<<elseif $tipcount is 1>><<set $tipcount += 1>>
Fatigue increases over time. High fatigue increases stress and trauma, but you can sleep to remove it.
<<elseif $tipcount is 2>><<set $tipcount += 1>>
Stress increases when you are assaulted.
<<elseif $tipcount is 3>><<set $tipcount += 1>>
You will pass out if stress gets too high, making you vulnerable.
<<elseif $tipcount is 4>><<set $tipcount += 1>>
Stress usually decreases over time. Fun or relaxing activities also reduce it, as do orgasms.
<<elseif $tipcount is 5>><<set $tipcount += 1>>
Trauma increases when you are assaulted, harassed or humiliated. Trauma slowly decreases over time.
<<elseif $tipcount is 6>><<set $tipcount += 1>>
High trauma causes psychological problems, but also opens up new options.
<<elseif $tipcount is 7>><<set $tipcount += 1>>
Wilfully performing lewd acts will restore your sense of control, mitigating the effects of psychological trauma.
<<elseif $tipcount is 8>><<set $tipcount += 1>>
Feeling in control will diminish when violated.
<<elseif $tipcount is 9>><<set $tipcount += 1>>
Frequently performing lewd acts will inure you to them, allowing more options but requiring more extreme behaviour to achieve a sense of control.
<<elseif $tipcount is 10>><<set $tipcount += 1>>
There are three categories of lewd act; promiscuous, exhibitionist and deviant.
<<elseif $tipcount is 11>><<set $tipcount += 1>>
Higher promiscuity allows you to initiate lewder acts during consensual encounters.
<<elseif $tipcount is 12>><<set $tipcount += 1>>
Higher exhibitionism allows lewder acts while dancing.
<<elseif $tipcount is 13>><<set $tipcount += 1>>
Promiscuous, exhibitionist and deviant acts can put you in danger. Be careful.
<<elseif $tipcount is 14>><<set $tipcount += 1>>
You can buy new clothing at the High Street shopping centre.
<<elseif $tipcount is 15>><<set $tipcount += 1>>
You need to wear a uniform to attend school. If you forget it, you might be able to borrow a spare from somewhere.
<<elseif $tipcount is 16>><<set $tipcount += 1>>
If your clothes get destroyed or stolen, you'll have to buy more. You could always just wrap yourself in towels, but it might attract attention.
<<elseif $tipcount is 17>><<set $tipcount += 1>>
Try to get home before dark. There are some nasty people about.
<<elseif $tipcount is 18>><<set $tipcount += 1>>
You can buy a chastity belt from the temple on Wolf Street. They give them out for free to virgins.
<<elseif $tipcount is 19>><<set $tipcount += 1>>
The forest is dangerous. People sometimes never return.
<<elseif $tipcount is 20>><<set $tipcount += 1>>
No matter how bad things seem, there's always a way out.
<<elseif $tipcount is 21>><<set $tipcount += 1>>
If you need some money, the cafe on Cliff Street is always hiring, and is fairly safe.
<<elseif $tipcount is 22>><<set $tipcount += 1>>
You'll need a swimsuit for school. You probably don't want to borrow one.
<<elseif $tipcount is 23>><<set $tipcount += 1>>
Your physique will deteriorate if you don't get enough exercise.
<<elseif $tipcount is 24>><<set $tipcount += 1>>
Swimming close to shore is easy. You should practice in a safe environment before swimming further out.
<<elseif $tipcount is 25>><<set $tipcount += 1>>
Going without underwear makes you more vulnerable, particularly if you're wearing a skirt.
<<elseif $tipcount is 26>><<set $tipcount += 1>>
Lower purity can speed up breast growth.
<<elseif $tipcount is 27>><<set $tipcount += 1>>
A topless girl with a flat chest can sometimes pass as a boy.
<<elseif $tipcount is 28>><<set $tipcount += 1>>
If your arms are bound, you should be able to free yourself once in a safe place.
<<elseif $tipcount is 29>><<set $tipcount += 1>>
The hospital on Nightingale Street has facilities for dealing with large parasites.
<<elseif $tipcount is 30>><<set $tipcount += 1>>
If a situation seems dangerous, it probably is.
<<elseif $tipcount is 31>><<set $tipcount += 1>>
A chastity belt is a good way to protect your virginity.
<<elseif $tipcount is 32>><<set $tipcount += 1>>
There's a club on Connudatus Street that features erotic dancers. They're always hiring.
<<elseif $tipcount is 33>><<set $tipcount += 1>>
There are rumours of an underground brothel somewhere in town.
<<elseif $tipcount is 34>><<set $tipcount += 1>>
If you want to learn how to dance, there's a studio on Barb Street.
<<elseif $tipcount is 35>><<set $tipcount += 1>>
The storm drains allow quick, secretive travel around town. Rumours of giant lizards are surely wrong.
<<elseif $tipcount is 36>><<set $tipcount += 1>>
Traveling through alleyways allows you to shave time off journeys, but unsavoury figures lurk there.
<<elseif $tipcount is 37>><<set $tipcount += 1>>
If you sense something hunting you in the forest, get out before it's too late.
<<elseif $tipcount is 38>><<set $tipcount += 1>>
The kids at school can be evil. Particularly towards those with a low social status.
<<elseif $tipcount is 39>><<set $tipcount += 1>>
It's hard to be popular at school and endear yourself to the teachers at the same time. You'll have to make sacrifices.
<<elseif $tipcount is 40>><<set $tipcount += 1>>
If you get a reputation as a delinquent, teachers will no longer respond to your cries for help.
<<elseif $tipcount is 41>><<set $tipcount += 1>>
If you lose your virginity, you'll never be entirely pure again.
<<elseif $tipcount is 42>><<set $tipcount += 1>>
If you orgasm, you'll temporarily lose focus.
<<elseif $tipcount is 43>><<set $tipcount += 1>>
Too many orgasms in a short span of time can be bad for one's mental state.
<<elseif $tipcount is 44>><<set $tipcount += 1>>
When the odds are stacked against you, fighting can make things worse.
<<elseif $tipcount is 45>><<set $tipcount += 1>>
A little defiance can go a long way.
<<elseif $tipcount is 46>><<set $tipcount += 1>>
There are some mental problems that cannot be fully controlled.
<<elseif $tipcount is 47>><<set $tipcount += 1>>
The better your physique, the more effort needed to maintain and improve it.
<<elseif $tipcount is 48>><<set $tipcount += 1>>
Your <span class="def">defiant</span> acts cause more pain if you have a good physique.
<<elseif $tipcount is 49>><<set $tipcount += 1>>
Tactical use of <span class="brat">bratty</span> actions can be very powerful.
<<elseif $tipcount is 50>><<set $tipcount += 1>>
Apologising more than once is pointless.
<<elseif $tipcount is 51>><<set $tipcount += 1>>
Genitals are not the only thing that can rob you of your virginity.
<<elseif $tipcount is 52>><<set $tipcount += 1>>
Be mindful if you crossdress, some people don't take kindly to it.
<<elseif $tipcount is 53>><<set $tipcount += 1>>
Semen and other lewd fluids will stick around until you wash.
<<elseif $tipcount is 54>><<set $tipcount += 1>>
Walking around covered in lewd fluid will attract attention.
<<elseif $tipcount is 55>><<set $tipcount += 1>>
Tentacles can ejaculate a lot, but quickly tire when they do.
<<elseif $tipcount is 56>><<set $tipcount += 1>>
When half or more of a monster's tentacles are tired, the monster will withdraw.
<<elseif $tipcount is 57>><<set $tipcount += 1>>
Individual tentacles are easy to deal with.
<<elseif $tipcount is 58>><<set $tipcount += 1>>
Milking tentacles is easier if you're skilled with the body part you're using.
<<elseif $tipcount is 59>><<set $tipcount += 1>>
Attempts to influence a molester are less likely to succeed as they become angrier and hornier.
<<elseif $tipcount is 60>><<set $tipcount += 1>>
<span class="sub">Submissive</span> and <span class="meek">meek</span> acts will make someone trust you more, making them easier to influence.
<<elseif $tipcount is 61>><<set $tipcount += 1>>
You can escape from most encounters by inflicting enough pain through <span class="def">defiant</span> acts.
<<elseif $tipcount is 62>><<set $tipcount += 1>>
Enraged assailants will become less hostile as they take their anger out on you.
<<elseif $tipcount is 63>><<set $tipcount += 1>>
If you suffer too much pain, you'll be disabled and unable to act until you recover.
<<elseif $tipcount is 64>><<set $tipcount += 1>>
If you're small or out of shape fighting might just make things worse for you.
<<elseif $tipcount is 65>><<set $tipcount += 1>>
An assailant foiled by a chastity belt will become angrier.
<<elseif $tipcount is 66>><<set $tipcount += 1>>
Assailants might stop gagging you if they trust you more.
<<elseif $tipcount is 67>><<set $tipcount += 1>>
It's much harder to build social status than it is to lose it.
<<elseif $tipcount is 68>><<set $tipcount += 1>>
The tips you make dancing are based on the size of the audience, their arousal and how impressed they are.
<<elseif $tipcount is 69>><<set $tipcount += 1>>
A large, aroused audience can be dangerous.
<<elseif $tipcount is 70>><<set $tipcount += 1>>
Some venues are safer to dance in than others.
<<elseif $tipcount is 71>><<set $tipcount += 1>>
A skilled dancer garners interest more easily.
<<elseif $tipcount is 72>><<set $tipcount += 1>>
Even an unskilled dancer can garner attention, if they're willing to strip.
<<elseif $tipcount is 73>><<set $tipcount += 1>>
Performing lewd or promiscuous acts will inure you to them, even if you already feel in control.
<<elseif $tipcount is 74>><<set $tipcount += 1>>
Alcohol will extend the effect of aphrodisiacs, and vice versa.
<<elseif $tipcount is 75>><<set $tipcount += 1>>
Being consistently <span class="sub">submissive</span> or <span class="def">defiant</span> can alter your personality and open new options.
<<elseif $tipcount is 76>><<set $tipcount += 1>>
Each turn during an encounter represents ten seconds.
<<elseif $tipcount is 77>><<set $tipcount += 1>>
Anything that increases delinquency will give you detention.
<<elseif $tipcount is 78>><<set $tipcount += 1>>
Your skulduggery determines your ability to perform underhanded acts, including deceiving people and picking locks.
<<elseif $tipcount is 79>><<set $tipcount += 1>>
You can sell stolen goods in the pub on Harvest Street.
<<elseif $tipcount is 80>><<set $tipcount += 1>>
Criminal acts may come back to haunt you.
<<elseif $tipcount is 81>><<set $tipcount += 1>>
News of your lewdness will spread quickly if people take pictures of you in the act.
<<elseif $tipcount is 82>><<set $tipcount += 1>>
You can cover your face to prevent a picture from being linked to you.
<<elseif $tipcount is 83>><<set $tipcount += 1>>
Word of your lewdness will slowly spread, even without hard evidence.
<<elseif $tipcount is 84>><<set $tipcount += 1>>
Allure increases the amount made from tips.
<<elseif $tipcount is 85>><<set $tipcount += 1>>
<span class="def">Defiant</span> acts reduce stress and trauma.
<<elseif $tipcount is 86>><<set $tipcount += 1>>
<span class="brat">Bratty</span> acts reduce trauma but increase stress.
<<elseif $tipcount is 87>><<set $tipcount += 1>>
<span class="sub">Submissive</span> acts reduce trauma but increase stress.
<<elseif $tipcount is 88>><<set $tipcount += 1>>
<span class="meek">Meek</span> acts impact neither stress nor trauma.
<<elseif $tipcount is 89>><<set $tipcount += 1>>
In addition to enter, you can press the z or n key to end the turn.
<<elseif $tipcount is 90>><<set $tipcount += 1>>
Being raped is more traumatic than just being molested.
<<elseif $tipcount is 91>><<set $tipcount += 1>>
Parasites latched onto your chest will make your breasts grow faster.
<<elseif $tipcount is 92>><<set $tipcount += 1>>
Purity drops when something cums inside you, or you cum inside something else.
<<elseif $tipcount is 93>><<set $tipcount += 1>>
Ingesting wolf cum can have strange effects on the body.
<<elseif $tipcount is 94>><<set $tipcount += 1>>
Awareness enables more actions during masturbation.
<<elseif $tipcount is 95>><<set $tipcount += 1>>
Beauty increases over time, but excess trauma will decrease it.
<<elseif $tipcount is 96>><<set $tipcount += 1>>
The police station can remove collars.
<<elseif $tipcount is 97>><<set $tipcount += 1>>
It's possible to afford Bailey's demands, no matter how harsh.
<<elseif $tipcount is 98>><<set $tipcount += 1>><<set $tipcount -= $tipcount>>
Higher deviancy allows you to initiate lewder acts during consensual encounters with beasts.
<</if>>
<</nobr>><</widget>>
:: Widgets Clothing Caption [widget]
<<widget "clothingcaption">><<nobr>>
<<if $upperclothes is "naked">>
<<if $lowerclothes is "naked">>
<<if $underclothes is "naked">>
<span class="red">You are completely naked!</span>
<</if>>
<<if $underclothes isnot "naked">>
<span class="pink">You are wearing nothing but a <<if $undertype isnot "chastity">>pair of <</if>><<underintegrity>> $undercolour $underclothes.</span>
<</if>>
<</if>>
<<if $lowerclothes isnot "naked">>
<<if $underclothes is "naked">>
<span class="pink">You are topless and wearing no underwear</span> but your lower half is covered by <<lowerword>> <<lowerintegrity>> $lowercolour $lowerclothes.
<</if>>
<<if $underclothes isnot "naked">>
<span class="pink">You are topless</span> with <<lowerword>> <<lowerintegrity>> $lowercolour $lowerclothes and <<underword>> <<underintegrity>> $undercolour $underclothes.
<</if>>
<</if>>
<<elseif $upperclothes isnot "naked">>
<<if $lowerclothes is "naked">>
<<if $underclothes is "naked">>
<<if $upperonepiece is 1 and $lowerset isnot $upperset>>
You are wearing <<upperword>> <<upperintegrity>> $uppercolour $upperclothes that has been torn at the waist <span class="red"> leaving your bottom half completely exposed!</span>
<<else>>
<span class="red">Your bottom half is completely exposed!</span> You are wearing <<upperword>> <<upperintegrity>> $uppercolour $upperclothes.
<</if>>
<</if>>
<<if $underclothes isnot "naked">>
<<if $upperonepiece is 1 and $lowerset isnot $upperset>>
You are wearing <<upperword>> <<upperintegrity>> $uppercolour $upperclothes that has been torn at the waist <span class="purple"> leaving your <<underword>> <<underintegrity>> $undercolour $underclothes exposed.</span>
<<else>>
You are wearing <<upperword>> <<upperintegrity>> $uppercolour $upperclothes and <span class="purple">exposed <<underword>> <<underintegrity>> $undercolour $underclothes.</span>
<</if>>
<</if>>
<</if>>
<<if $lowerclothes isnot "naked">>
<<if $underclothes is "naked">>
You are wearing <<upperword>> <<upperintegrity>> $uppercolour $upperclothes
<<if $loweronepiece isnot 1>>and <<lowerword>> <<lowerintegrity>> $lowercolour $lowerclothes
<</if>>
<span class="purple"><<if $lowertype is "swim">>and<<else>>but<</if>> you are not wearing underwear.</span>
<</if>>
<<if $underclothes isnot "naked">><<nobr>>
You are wearing <<upperword>> <<upperintegrity>> $uppercolour $upperclothes
<<if $loweronepiece isnot 1>>with <<lowerword>> <<lowerintegrity>> $lowercolour $lowerclothes
<</if>>and <<underword>> <<underintegrity>> $undercolour $underclothes.
<</nobr>><</if>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "stripcaption">><<nobr>>
<<if $uppertype isnot "naked" and $upperwetstage gte 3 and $lowertype isnot "naked" and $lowerwetstage gte 3 and $undertype isnot "naked" and $undertype isnot "chastity" and $underwetstage gte 3>>
<<if $upperset is $lowerset>>
<br>Your $upperclothes, skirt and $underclothes are drenched, <span class="pink">revealing your <<breasts>> and <<genitalsstop>></span><br>
<<else>>
<br>Your $upperclothes, $lowerclothes and $underclothes are drenched, <span class="pink">revealing your <<breasts>> and <<genitalsstop>></span><br>
<</if>>
<<elseif $uppertype isnot "naked" and $upperwetstage gte 3 and $lowerwetstage gte 3 and $lowertype isnot "naked">>
<<if $upperset is $lowerset>>
<br>Your $upperclothes and skirt are drenched, <span class="purple">revealing your <<breasts>> and <<undiesstop>></span><br>
<<else>>
<br>Your $upperclothes and $lowerclothes are drenched, <span class="purple">revealing your <<breasts>> and <<undiesstop>></span><br>
<</if>>
<<elseif $uppertype isnot "naked" and $upperwetstage gte 3>>
<br>Your $upperclothes <<upperplural>> drenched, <span class="purple">revealing your <<breastsstop>></span><br>
<<elseif $lowertype isnot "naked" and $lowerwetstage gte 3 and $undertype isnot "naked" and $undertype isnot "chastity" and $underwetstage gte 3>>
<br>Your $lowerclothes and $underclothes are drenched, <span class="pink">revealing your <<genitalsstop>></span><br>
<<elseif $lowertype isnot "naked" and $lowerwetstage gte 3>>
<br>Your $lowerclothes <<lowerplural>> drenched, <span class="purple">revealing your <<undiesstop>></span><br>
<<elseif $undertype isnot "naked" and $undertype isnot "chastity" and $underwetstage gte 3>>
<br>Your $underclothes <<underplural>> drenched, <span class="pink">revealing your <<genitalsstop>></span><br>
<<elseif $uppertype isnot "naked" and $upperexposed is 2 and $lowertype isnot "naked" and $lowerexposed is 2 and $undertype isnot "naked" and $undertype isnot "chastity" and $understate isnot "waist">>
<<if $upperset is $lowerset>>
<br>Your $upperclothes, skirt and $underclothes have been pulled aside, <span class="pink">revealing your <<breasts>> and <<genitalsstop>></span><br>
<<else>>
<br>Your $upperclothes, $lowerclothes and $underclothes have been pulled aside, <span class="pink">revealing your <<breasts>> and <<genitalsstop>></span><br>
<</if>>
<<elseif $uppertype isnot "naked" and $upperexposed is 2 and $lowerexposed is 2 and $lowertype isnot "naked">>
<<if $upperset is $lowerset>>
<br>Your $upperclothes and skirt have been pulled aside, <span class="purple">revealing your <<breasts>> and <<undiesstop>></span><br>
<<else>>
<br>Your $upperclothes and $lowerclothes have been pulled aside, <span class="purple">revealing your <<breasts>> and <<undiesstop>></span><br>
<</if>>
<<elseif $uppertype isnot "naked" and $upperexposed is 2>>
<br>Your $upperclothes <<upperhas>> been pulled aside, <span class="purple">revealing your <<breastsstop>></span><br>
<<elseif $lowertype isnot "naked" and $lowerexposed is 2 and $undertype isnot "naked" and $undertype isnot "chastity" and $understate isnot "waist">>
<br>Your $lowerclothes <<lowerhas>> been pulled aside and your $underclothes pulled down, <span class="pink">revealing your <<genitalsstop>></span><br>
<<elseif $lowertype isnot "naked" and $lowerexposed is 2>>
<br>Your $lowerclothes <<lowerhas>> been pulled aside, <span class="purple">revealing your <<undiesstop>></span><br>
<<elseif $undertype isnot "naked" and $undertype isnot "chastity" and $understate isnot "waist">>
<br>Your $underclothes <<underhas>> been pulled down to your $understate, <span class="pink">revealing your <<genitalsstop>></span><br>
<</if>>
<</nobr>><</widget>>
:: Widgets Fame [widget]
<<widget "fameexhibitionism">><<nobr>>
<<if $args[0]>>
<<set $fame += $args[0]>>
<<set $fameexhibitionism += $args[0]>>
<</if>>
<</nobr>><</widget>>
<<widget "fameprostitution">><<nobr>>
<<if $args[0]>>
<<set $fame += $args[0]>>
<<set $fameprostitution += $args[0]>>
<</if>>
<</nobr>><</widget>>
<<widget "famebestiality">><<nobr>>
<<if $args[0]>>
<<set $fame += $args[0]>>
<<set $famebestiality += $args[0]>>
<</if>>
<</nobr>><</widget>>
<<widget "famerape">><<nobr>>
<<if $args[0]>>
<<set $fame += $args[0]>>
<<set $famerape += $args[0]>>
<</if>>
<</nobr>><</widget>>
<<widget "famesex">><<nobr>>
<<if $args[0]>>
<<set $fame += $args[0]>>
<<set $famesex += $args[0]>>
<</if>>
<</nobr>><</widget>>
<<widget "famegood">><<nobr>>
<<if $args[0]>>
<<set $fame += $args[0]>>
<<set $famegood += $args[0]>>
<</if>>
<</nobr>><</widget>>
<<widget "famebusiness">><<nobr>>
<<if $args[0]>>
<<set $fame += $args[0]>>
<<set $famebusiness += $args[0]>>
<</if>>
<</nobr>><</widget>>
<<widget "famedance">><<nobr>>
<<exposure>>
<<if $exposed gte 2>>
<<set $fameexhibitionism += $audience>>
<<set $fame += $audience>>
<<elseif $exposed gte 1>>
<<set $fameexhibitionism += ($audience * 2)>>
<<set $fame += ($audience * 2)>>
<</if>>
<</nobr>><</widget>>
:: Widgets Settings [widget]
<<widget "initsettings">><<nobr>>
<label>Male <<radiobutton "$playergender" "m">></label>
| <label>Female <<radiobutton "$playergender" "f" checked>></label>
<br><br>
<<if $dev is 1>>
<span class="red">Harder</span> <-----------------------------------------------> <span class="green">Easier</span><br>
| <label>6 <<radiobutton "$devlevel" 6>></label>
| <label>7 <<radiobutton "$devlevel" 7>></label>
| <label>8 <<radiobutton "$devlevel" 8>></label>
| <label>9 <<radiobutton "$devlevel" 9>></label>
| <label>10 <<radiobutton "$devlevel" 10 checked>></label>
| <label>11 <<radiobutton "$devlevel" 11>></label>
| <label>12 <<radiobutton "$devlevel" 12>></label>
| <label>13 <<radiobutton "$devlevel" 13>></label>
| <label>14 <<radiobutton "$devlevel" 14>></label>
| <label>15 <<radiobutton "$devlevel" 15>></label>
| <label>16 <<radiobutton "$devlevel" 16>></label>
<<else>>
<span class="gold">Body size</span> - A smaller body makes you inflict less damage during encounters, making defiance harder.<br>
| <label>Tiny <<radiobutton "$devlevel" 6>></label>
| <label>Small <<radiobutton "$devlevel" 10 checked>></label>
| <label>Normal <<radiobutton "$devlevel" 12>></label>
| <label>Large <<radiobutton "$devlevel" 16>></label>
<</if>>
<br><br>
Eye Colour<br>
<label><span class="purple">Purple <<radiobutton "$eyeselect" "purple" checked>></span></label>
| <label><span class="blue">Dark Blue</span> <<radiobutton "$eyeselect" "dark blue">></label>
| <label><span class="lblue">Light Blue</span> <<radiobutton "$eyeselect" "light blue">></label>
| <label><span class="tangerine">Amber</span> <<radiobutton "$eyeselect" "amber">></label>
| <label><span class="brown">Hazel</span> <<radiobutton "$eyeselect" "hazel">></label>
| <label><span class="green">Green</span> <<radiobutton "$eyeselect" "green">></label><br><br>
Hair Colour<br>
<label><span class="red">Red</span> <<radiobutton "$hairselect" "red" checked>></label>
| <label><span class="black">Black</span> <<radiobutton "$hairselect" "black">></label>
| <label><span class="brown">Brown</span> <<radiobutton "$hairselect" "brown">></label>
| <label><span class="gold">Blond</span> <<radiobutton "$hairselect" "blond">></label>
| <label><span class="tangerine">Ginger</span> <<radiobutton "$hairselect" "ginger">></label><br><br>
<span class="gold">Awareness</span> - Whether your character knows a thing or two about sex despite their lack of experience.<br>
<label>Innocent <<radiobutton "$awareselect" "innocent" checked>></label>
| <label>Knowledgeable<<radiobutton "$awareselect" "knowledgeable">></label>
<br><br>
<span class="gold">Background</span><br>
<label><span class="gold">Waif</span> <<radiobutton "$background" "waif" checked>> - No special advantages or disadvantages. <i>Recommended for beginners.</i></label><br>
<label><span class="gold">Nerd</span> <<radiobutton "$background" "nerd">> - Good at school. Picked on.</label><br>
<label><span class="gold">Athlete</span> <<radiobutton "$background" "athlete">> - Physically capable. Grades have suffered.</label><br>
<label><span class="gold">Delinquent</span> <<radiobutton "$background" "delinquent">> - Your antics have made you popular with other students. Less so with the teachers.</label><br>
<label><span class="gold">Promiscuous</span> <<radiobutton "$background" "promiscuous">> - You've experimented sexually.</label><br>
<label><span class="gold">Exhibitionist</span> <<radiobutton "$background" "exhibitionist">> - You have an affinity for exposing yourself in public places.</label><br>
<label><span class="gold">Deviant</span> <<radiobutton "$background" "deviant">> - You really like animals.</label><br>
<label><span class="gold">Beautiful</span> <<radiobutton "$background" "beautiful">> - You turn heads. <i>Not recommended for beginners.</i></label><br>
<br>
<hr>
Options (can be changed in-game from your bedroom)<br><br>
<</nobr>><</widget>>
<<widget "settings">><<nobr>>
<label>Normal mode
<<if $gamemode is "normal">>
<<radiobutton "$gamemode" "normal" checked>>
<<else>>
<<radiobutton "$gamemode" "normal">>
<</if>>
- Survive in a dangerous world.</label><br>
<label>Soft mode
<<if $gamemode is "soft">>
<<radiobutton "$gamemode" "soft" checked>>
<<else>>
<<radiobutton "$gamemode" "soft">>
<</if>>
- For those who prefer a lighthearted lewd adventure, though the game is still dark in places. <span class="red">This is an experimental feature. It may be changed or removed in the future.</span></label><br>
<br>
Percentage of people attracted to you that are male.<br>
<<numberslider "$malechance" $malechance 0 100 1>><br><br>
<<if $dgchance gte 0>>
Percentage of women that have penises.<br>
<<numberslider "$dgchance" $dgchance 0 100 1>><br><br>
<<else>>
Percentage of women that have penises.<br>
<<numberslider "$dgchance" 0 0 100 1>><br><br>
<</if>>
<<if $cbchance gte 0>>
Percentage of men that have vaginas.<br>
<<numberslider "$cbchance" $cbchance 0 100 1>><br><br>
<<else>>
Percentage of men that have vaginas.<br>
<<numberslider "$cbchance" 0 0 100 1>><br><br>
<</if>>
<<if $whitechance isnot undefined>>
Likelihood of npcs having pale skin.<br>
<<numberslider "$whitechance" $whitechance 0 100 1>><br><br>
<<else>>
Likelihood of npcs having pale skin.<br>
<<numberslider "$whitechance" 90 0 100 1>><br><br>
<</if>>
<<if $blackchance isnot undefined>>
Likelihood of npcs having dark skin.<br>
<<numberslider "$blackchance" $blackchance 0 100 1>><br><br>
<<else>>
Likelihood of npcs having dark skin.<br>
<<numberslider "$blackchance" 10 0 100 1>><br><br>
<</if>>
The rate that events are triggered by allure. Default is 1.0.<br>
<<numberslider "$alluremod" $alluremod 0.5 2 0.1>><br><br>
<<if $bestialitydisable is "t">>
<label>Enable bestiality <<radiobutton "$bestialitydisable" "f">></label>
| <label>Disable bestiality <<radiobutton "$bestialitydisable" "t" checked>></label><br><br>
<<else>>
<label>Enable bestiality <<radiobutton "$bestialitydisable" "f" checked>></label>
| <label>Disable bestiality <<radiobutton "$bestialitydisable" "t">></label><br><br>
<</if>>
<<if $swarmdisable is "t">>
<label>Enable swarms of tiny creatures (Eels, worms, bugs etc.) <<radiobutton "$swarmdisable" "f">></label>
| <label>Disable swarms <<radiobutton "$swarmdisable" "t" checked>></label><br><br>
<<else>>
<label>Enable swarms of tiny creatures (Eels, worms, bugs etc.) <<radiobutton "$swarmdisable" "f" checked>></label>
| <label>Disable swarms <<radiobutton "$swarmdisable" "t">></label><br><br>
<</if>>
<<if $parasitedisable is "t">>
<label>Enable parasites <<radiobutton "$parasitedisable" "f">></label>
| <label>Disable parasites <<radiobutton "$parasitedisable" "t" checked>></label><br><br>
<<else>>
<label>Enable parasites <<radiobutton "$parasitedisable" "f" checked>></label>
| <label>Disable parasites <<radiobutton "$parasitedisable" "t">></label><br><br>
<</if>>
<<if $slimedisable is "t">>
<label>Enable slimes <<radiobutton "$slimedisable" "f">></label>
| <label>Disable slimes <<radiobutton "$slimedisable" "t" checked>></label><br><br>
<<else>>
<label>Enable slimes <<radiobutton "$slimedisable" "f" checked>></label>
| <label>Disable slimes <<radiobutton "$slimedisable" "t">></label><br><br>
<</if>>
<<if $voredisable is "t">>
<label>Enable vore <<radiobutton "$voredisable" "f">></label>
| <label>Disable vore <<radiobutton "$voredisable" "t" checked>></label><br><br>
<<else>>
<label>Enable vore <<radiobutton "$voredisable" "f" checked>></label>
| <label>Disable vore <<radiobutton "$voredisable" "t">></label><br><br>
<</if>>
<<if $tentacledisable is "t">>
<label>Enable tentacles <<radiobutton "$tentacledisable" "f">></label>
| <label>Disable tentacles <<radiobutton "$tentacledisable" "t" checked>></label><br><br>
<<else>>
<label>Enable tentacles <<radiobutton "$tentacledisable" "f" checked>></label>
| <label>Disable tentacles <<radiobutton "$tentacledisable" "t">></label><br><br>
<</if>>
<<if $analdisable is "t">>
<label>Enable anal <<radiobutton "$analdisable" "f">></label>
| <label>Disable anal <<radiobutton "$analdisable" "t" checked>></label><br><br>
<<else>>
<label>Enable anal <<radiobutton "$analdisable" "f" checked>></label>
| <label>Disable anal <<radiobutton "$analdisable" "t">></label><br><br>
<</if>>
<<if $transformdisable is "t">>
<label>Enable transformations <<radiobutton "$transformdisable" "f">></label>
| <label>Disable transformations <<radiobutton "$transformdisable" "t" checked>></label><br><br>
<<else>>
<label>Enable transformations <<radiobutton "$transformdisable" "f" checked>></label>
| <label>Disable transformations <<radiobutton "$transformdisable" "t">></label><br><br>
<</if>>
<<if $hirsutedisable is "f">>
<label>Enable hirsute/hairy wolf transformation <<radiobutton "$hirsutedisable" "f" checked>></label>
| <label>Disable hirsute/hairy wolf transformation <<radiobutton "$hirsutedisable" "t">></label><br><br>
<<else>>
<label>Enable hirsute/hairy wolf transformation <<radiobutton "$hirsutedisable" "f">></label>
| <label>Disable hirsute/hairy wolf transformation <<radiobutton "$hirsutedisable" "t" checked>></label><br><br>
<</if>>
Maximum player character breast size. Breasts already above this size won't shrink.<br>
<<if $breastsizemax is 0>>
| <label>Flat <<radiobutton "$breastsizemax" 0 checked>></label>
<<else>>
| <label>Flat <<radiobutton "$breastsizemax" 0>></label>
<</if>>
<<if $breastsizemax is 1>>
| <label>Budding <<radiobutton "$breastsizemax" 1 checked>></label>
<<else>>
| <label>Budding <<radiobutton "$breastsizemax" 1>></label>
<</if>>
<<if $breastsizemax is 2>>
| <label>Tiny <<radiobutton "$breastsizemax" 2 checked>></label>
<<else>>
| <label>Tiny <<radiobutton "$breastsizemax" 2>></label>
<</if>>
<<if $breastsizemax is 3>>
| <label>Small <<radiobutton "$breastsizemax" 3 checked>></label>
<<else>>
| <label>Small <<radiobutton "$breastsizemax" 3>></label>
<</if>>
<<if $breastsizemax is 4>>
| <label>Pert <<radiobutton "$breastsizemax" 4 checked>></label>
<<else>>
| <label>Pert <<radiobutton "$breastsizemax" 4>></label>
<</if>>
<<if $breastsizemax is 5>>
| <label>Modest <<radiobutton "$breastsizemax" 5 checked>></label>
<<else>>
| <label>Modest <<radiobutton "$breastsizemax" 5>></label>
<</if>>
<<if $breastsizemax is 6>>
| <label>Full <<radiobutton "$breastsizemax" 6 checked>></label>
<<else>>
| <label>Full <<radiobutton "$breastsizemax" 6>></label>
<</if>>
<<if $breastsizemax is 7>>
| <label>Large <<radiobutton "$breastsizemax" 7 checked>></label>
<<else>>
| <label>Large <<radiobutton "$breastsizemax" 7>></label>
<</if>>
<<if $breastsizemax is 8>>
| <label>Ample <<radiobutton "$breastsizemax" 8 checked>></label>
<<else>>
| <label>Ample <<radiobutton "$breastsizemax" 8>></label>
<</if>>
<<if $breastsizemax is 9>>
| <label>Massive <<radiobutton "$breastsizemax" 9 checked>></label>
<<else>>
| <label>Massive <<radiobutton "$breastsizemax" 9>></label>
<</if>>
<<if $breastsizemax is 10>>
| <label>Huge <<radiobutton "$breastsizemax" 10 checked>></label>
<<else>>
| <label>Huge <<radiobutton "$breastsizemax" 10>></label>
<</if>>
<<if $breastsizemax is 11>>
| <label>Gigantic <<radiobutton "$breastsizemax" 11 checked>></label>
<<else>>
| <label>Gigantic <<radiobutton "$breastsizemax" 11>></label>
<</if>>
<<if $breastsizemax is 12>>
| <label>Enormous <<radiobutton "$breastsizemax" 12 checked>></label>
<<else>>
| <label>Enormous <<radiobutton "$breastsizemax" 12>></label>
<</if>>
<br><br>
<<if $tipdisable is "t">>
<label>Enable hints and tips <<radiobutton "$tipdisable" "f">></label>
| <label>Disable tips <<radiobutton "$tipdisable" "t" checked>></label><br><br>
<<else>>
<label>Enable hints and tips <<radiobutton "$tipdisable" "f" checked>></label>
| <label>Disable tips <<radiobutton "$tipdisable" "t">></label><br><br>
<</if>>
<</nobr>><</widget>>
<<widget "npcsettings">><<nobr>>
Robin the orphan<br>
<<if $robingender is "f">>
<label>Female <<radiobutton "$robingender" "f" checked>></label>
<<else>>
<label>Female <<radiobutton "$robingender" "f">></label>
<</if>>
|
<<if $robingender is "m">>
<label>Male <<radiobutton "$robingender" "m" checked>></label>
<<else>>
<label>Male <<radiobutton "$robingender" "m">></label>
<</if>>
<br>
<<if $robingenitals is "vagina">>
<label>Vagina <<radiobutton "$robingenitals" "vagina" checked>></label>
<<else>>
<label>Vagina <<radiobutton "$robingenitals" "vagina">></label>
<</if>>
|
<<if $robingenitals is "penis">>
<label>Penis <<radiobutton "$robingenitals" "penis" checked>></label>
<<else>>
<label>Penis <<radiobutton "$robingenitals" "penis">></label>
<</if>>
<br><br>
Bailey<br>
<<if $baileygender is "f">>
<label>Female <<radiobutton "$baileygender" "f" checked>></label>
<<else>>
<label>Female <<radiobutton "$baileygender" "f">></label>
<</if>>
|
<<if $baileygender is "m">>
<label>Male <<radiobutton "$baileygender" "m" checked>></label>
<<else>>
<label>Male <<radiobutton "$baileygender" "m">></label>
<</if>>
<br>
<<if $baileygenitals is "vagina">>
<label>Vagina <<radiobutton "$baileygenitals" "vagina" checked>></label>
<<else>>
<label>Vagina <<radiobutton "$baileygenitals" "vagina">></label>
<</if>>
|
<<if $baileygenitals is "penis">>
<label>Penis <<radiobutton "$baileygenitals" "penis" checked>></label>
<<else>>
<label>Penis <<radiobutton "$baileygenitals" "penis">></label>
<</if>>
<br><br>
Charlie the dance coach<br>
<<if $charliegender is "f">>
<label>Female <<radiobutton "$charliegender" "f" checked>></label>
<<else>>
<label>Female <<radiobutton "$charliegender" "f">></label>
<</if>>
|
<<if $charliegender is "m">>
<label>Male <<radiobutton "$charliegender" "m" checked>></label>
<<else>>
<label>Male <<radiobutton "$charliegender" "m">></label>
<</if>>
<br>
<<if $charliegenitals is "vagina">>
<label>Vagina <<radiobutton "$charliegenitals" "vagina" checked>></label>
<<else>>
<label>Vagina <<radiobutton "$charliegenitals" "vagina">></label>
<</if>>
|
<<if $charliegenitals is "penis">>
<label>Penis <<radiobutton "$charliegenitals" "penis" checked>></label>
<<else>>
<label>Penis <<radiobutton "$charliegenitals" "penis">></label>
<</if>>
<br><br>
Darryl the club owner<br>
<<if $darrylgender is "f">>
<label>Female <<radiobutton "$darrylgender" "f" checked>></label>
<<else>>
<label>Female <<radiobutton "$darrylgender" "f">></label>
<</if>>
|
<<if $darrylgender is "m">>
<label>Male <<radiobutton "$darrylgender" "m" checked>></label>
<<else>>
<label>Male <<radiobutton "$darrylgender" "m">></label>
<</if>>
<br>
<<if $darrylgenitals is "vagina">>
<label>Vagina <<radiobutton "$darrylgenitals" "vagina" checked>></label>
<<else>>
<label>Vagina <<radiobutton "$darrylgenitals" "vagina">></label>
<</if>>
|
<<if $darrylgenitals is "penis">>
<label>Penis <<radiobutton "$darrylgenitals" "penis" checked>></label>
<<else>>
<label>Penis <<radiobutton "$darrylgenitals" "penis">></label>
<</if>>
<br><br>
Harper the doctor<br>
<<if $harpergender is "f">>
<label>Female <<radiobutton "$harpergender" "f" checked>></label>
<<else>>
<label>Female <<radiobutton "$harpergender" "f">></label>
<</if>>
|
<<if $harpergender is "m">>
<label>Male <<radiobutton "$harpergender" "m" checked>></label>
<<else>>
<label>Male <<radiobutton "$harpergender" "m">></label>
<</if>>
<br>
<<if $harpergenitals is "vagina">>
<label>Vagina <<radiobutton "$harpergenitals" "vagina" checked>></label>
<<else>>
<label>Vagina <<radiobutton "$harpergenitals" "vagina">></label>
<</if>>
|
<<if $harpergenitals is "penis">>
<label>Penis <<radiobutton "$harpergenitals" "penis" checked>></label>
<<else>>
<label>Penis <<radiobutton "$harpergenitals" "penis">></label>
<</if>>
<br><br>
Jordan the <<if $jordangender is "f">>nun<<else>>monk<</if>><br>
<<if $jordangender is "f">>
<label>Female <<radiobutton "$jordangender" "f" checked>></label>
<<else>>
<label>Female <<radiobutton "$jordangender" "f">></label>
<</if>>
|
<<if $jordangender is "m">>
<label>Male <<radiobutton "$jordangender" "m" checked>></label>
<<else>>
<label>Male <<radiobutton "$jordangender" "m">></label>
<</if>>
<br>
<<if $jordangenitals is "vagina">>
<label>Vagina <<radiobutton "$jordangenitals" "vagina" checked>></label>
<<else>>
<label>Vagina <<radiobutton "$jordangenitals" "vagina">></label>
<</if>>
|
<<if $jordangenitals is "penis">>
<label>Penis <<radiobutton "$jordangenitals" "penis" checked>></label>
<<else>>
<label>Penis <<radiobutton "$jordangenitals" "penis">></label>
<</if>>
<br><br>
Briar the brothel owner<br>
<<if $briargender is "f">>
<label>Female <<radiobutton "$briargender" "f" checked>></label>
<<else>>
<label>Female <<radiobutton "$briargender" "f">></label>
<</if>>
|
<<if $briargender is "m">>
<label>Male <<radiobutton "$briargender" "m" checked>></label>
<<else>>
<label>Male <<radiobutton "$briargender" "m">></label>
<</if>>
<br>
<<if $briargenitals is "vagina">>
<label>Vagina <<radiobutton "$briargenitals" "vagina" checked>></label>
<<else>>
<label>Vagina <<radiobutton "$briargenitals" "vagina">></label>
<</if>>
|
<<if $briargenitals is "penis">>
<label>Penis <<radiobutton "$briargenitals" "penis" checked>></label>
<<else>>
<label>Penis <<radiobutton "$briargenitals" "penis">></label>
<</if>>
<br><br>
Eden the hunter<br>
<<if $edengender is "f">>
<label>Female <<radiobutton "$edengender" "f" checked>></label>
<<else>>
<label>Female <<radiobutton "$edengender" "f">></label>
<</if>>
|
<<if $edengender is "m">>
<label>Male <<radiobutton "$edengender" "m" checked>></label>
<<else>>
<label>Male <<radiobutton "$edengender" "m">></label>
<</if>>
<br>
<<if $edengenitals is "vagina">>
<label>Vagina <<radiobutton "$edengenitals" "vagina" checked>></label>
<<else>>
<label>Vagina <<radiobutton "$edengenitals" "vagina">></label>
<</if>>
|
<<if $edengenitals is "penis">>
<label>Penis <<radiobutton "$edengenitals" "penis" checked>></label>
<<else>>
<label>Penis <<radiobutton "$edengenitals" "penis">></label>
<</if>>
<br><br>
Sam the cafe owner<br>
<<if $samgender is "f">>
<label>Female <<radiobutton "$samgender" "f" checked>></label>
<<else>>
<label>Female <<radiobutton "$samgender" "f">></label>
<</if>>
|
<<if $samgender is "m">>
<label>Male <<radiobutton "$samgender" "m" checked>></label>
<<else>>
<label>Male <<radiobutton "$samgender" "m">></label>
<</if>>
<br>
<<if $samgenitals is "vagina">>
<label>Vagina <<radiobutton "$samgenitals" "vagina" checked>></label>
<<else>>
<label>Vagina <<radiobutton "$samgenitals" "vagina">></label>
<</if>>
|
<<if $samgenitals is "penis">>
<label>Penis <<radiobutton "$samgenitals" "penis" checked>></label>
<<else>>
<label>Penis <<radiobutton "$samgenitals" "penis">></label>
<</if>>
<br><br>
Landry the criminal<br>
<<if $landrygender is "f">>
<label>Female <<radiobutton "$landrygender" "f" checked>></label>
<<else>>
<label>Female <<radiobutton "$landrygender" "f">></label>
<</if>>
|
<<if $landrygender is "m">>
<label>Male <<radiobutton "$landrygender" "m" checked>></label>
<<else>>
<label>Male <<radiobutton "$landrygender" "m">></label>
<</if>>
<br>
<<if $landrygenitals is "vagina">>
<label>Vagina <<radiobutton "$landrygenitals" "vagina" checked>></label>
<<else>>
<label>Vagina <<radiobutton "$landrygenitals" "vagina">></label>
<</if>>
|
<<if $landrygenitals is "penis">>
<label>Penis <<radiobutton "$landrygenitals" "penis" checked>></label>
<<else>>
<label>Penis <<radiobutton "$landrygenitals" "penis">></label>
<</if>>
<br><br>
Whitney the bully<br>
<<if $whitneygender is "f">>
<label>Female <<radiobutton "$whitneygender" "f" checked>></label>
<<else>>
<label>Female <<radiobutton "$whitneygender" "f">></label>
<</if>>
|
<<if $whitneygender is "m">>
<label>Male <<radiobutton "$whitneygender" "m" checked>></label>
<<else>>
<label>Male <<radiobutton "$whitneygender" "m">></label>
<</if>>
<br>
<<if $whitneygenitals is "vagina">>
<label>Vagina <<radiobutton "$whitneygenitals" "vagina" checked>></label>
<<else>>
<label>Vagina <<radiobutton "$whitneygenitals" "vagina">></label>
<</if>>
|
<<if $whitneygenitals is "penis">>
<label>Penis <<radiobutton "$whitneygenitals" "penis" checked>></label>
<<else>>
<label>Penis <<radiobutton "$whitneygenitals" "penis">></label>
<</if>>
<br><br>
Avery the <<if $averygender is "m">>businessman<<else>>businesswoman<</if>><br>
<<if $averygender is "f">>
<label>Female <<radiobutton "$averygender" "f" checked>></label>
<<else>>
<label>Female <<radiobutton "$averygender" "f">></label>
<</if>>
|
<<if $averygender is "m">>
<label>Male <<radiobutton "$averygender" "m" checked>></label>
<<else>>
<label>Male <<radiobutton "$averygender" "m">></label>
<</if>>
<br>
<<if $averygenitals is "vagina">>
<label>Vagina <<radiobutton "$averygenitals" "vagina" checked>></label>
<<else>>
<label>Vagina <<radiobutton "$averygenitals" "vagina">></label>
<</if>>
|
<<if $averygenitals is "penis">>
<label>Penis <<radiobutton "$averygenitals" "penis" checked>></label>
<<else>>
<label>Penis <<radiobutton "$averygenitals" "penis">></label>
<</if>>
<br><br>
<hr>
<b>Teachers</b><br><br>
Leighton the headteacher<br>
<<if $leightongender is "f">>
<label>Female <<radiobutton "$leightongender" "f" checked>></label>
<<else>>
<label>Female <<radiobutton "$leightongender" "f">></label>
<</if>>
|
<<if $leightongender is "m">>
<label>Male <<radiobutton "$leightongender" "m" checked>></label>
<<else>>
<label>Male <<radiobutton "$leightongender" "m">></label>
<</if>>
<br>
<<if $leightongenitals is "vagina">>
<label>Vagina <<radiobutton "$leightongenitals" "vagina" checked>></label>
<<else>>
<label>Vagina <<radiobutton "$leightongenitals" "vagina">></label>
<</if>>
|
<<if $leightongenitals is "penis">>
<label>Penis <<radiobutton "$leightongenitals" "penis" checked>></label>
<<else>>
<label>Penis <<radiobutton "$leightongenitals" "penis">></label>
<</if>>
<br><br>
Sirris the science teacher<br>
<<if $sirrisgender is "f">>
<label>Female <<radiobutton "$sirrisgender" "f" checked>></label>
<<else>>
<label>Female <<radiobutton "$sirrisgender" "f">></label>
<</if>>
|
<<if $sirrisgender is "m">>
<label>Male <<radiobutton "$sirrisgender" "m" checked>></label>
<<else>>
<label>Male <<radiobutton "$sirrisgender" "m">></label>
<</if>>
<br>
<<if $sirrisgenitals is "vagina">>
<label>Vagina <<radiobutton "$sirrisgenitals" "vagina" checked>></label>
<<else>>
<label>Vagina <<radiobutton "$sirrisgenitals" "vagina">></label>
<</if>>
|
<<if $sirrisgenitals is "penis">>
<label>Penis <<radiobutton "$sirrisgenitals" "penis" checked>></label>
<<else>>
<label>Penis <<radiobutton "$sirrisgenitals" "penis">></label>
<</if>>
<br><br>
River the maths teacher<br>
<<if $rivergender is "f">>
<label>Female <<radiobutton "$rivergender" "f" checked>></label>
<<else>>
<label>Female <<radiobutton "$rivergender" "f">></label>
<</if>>
|
<<if $rivergender is "m">>
<label>Male <<radiobutton "$rivergender" "m" checked>></label>
<<else>>
<label>Male <<radiobutton "$rivergender" "m">></label>
<</if>>
<br>
<<if $rivergenitals is "vagina">>
<label>Vagina <<radiobutton "$rivergenitals" "vagina" checked>></label>
<<else>>
<label>Vagina <<radiobutton "$rivergenitals" "vagina">></label>
<</if>>
|
<<if $rivergenitals is "penis">>
<label>Penis <<radiobutton "$rivergenitals" "penis" checked>></label>
<<else>>
<label>Penis <<radiobutton "$rivergenitals" "penis">></label>
<</if>>
<br><br>
Doren the english teacher<br>
<<if $dorengender is "f">>
<label>Female <<radiobutton "$dorengender" "f" checked>></label>
<<else>>
<label>Female <<radiobutton "$dorengender" "f">></label>
<</if>>
|
<<if $dorengender is "m">>
<label>Male <<radiobutton "$dorengender" "m" checked>></label>
<<else>>
<label>Male <<radiobutton "$dorengender" "m">></label>
<</if>>
<br>
<<if $dorengenitals is "vagina">>
<label>Vagina <<radiobutton "$dorengenitals" "vagina" checked>></label>
<<else>>
<label>Vagina <<radiobutton "$dorengenitals" "vagina">></label>
<</if>>
|
<<if $dorengenitals is "penis">>
<label>Penis <<radiobutton "$dorengenitals" "penis" checked>></label>
<<else>>
<label>Penis <<radiobutton "$dorengenitals" "penis">></label>
<</if>>
<br><br>
Winter the history teacher<br>
<<if $wintergender is "f">>
<label>Female <<radiobutton "$wintergender" "f" checked>></label>
<<else>>
<label>Female <<radiobutton "$wintergender" "f">></label>
<</if>>
|
<<if $wintergender is "m">>
<label>Male <<radiobutton "$wintergender" "m" checked>></label>
<<else>>
<label>Male <<radiobutton "$wintergender" "m">></label>
<</if>>
<br>
<<if $wintergenitals is "vagina">>
<label>Vagina <<radiobutton "$wintergenitals" "vagina" checked>></label>
<<else>>
<label>Vagina <<radiobutton "$wintergenitals" "vagina">></label>
<</if>>
|
<<if $wintergenitals is "penis">>
<label>Penis <<radiobutton "$wintergenitals" "penis" checked>></label>
<<else>>
<label>Penis <<radiobutton "$wintergenitals" "penis">></label>
<</if>>
<br><br>
Mason the swimming teacher<br>
<<if $masongender is "f">>
<label>Female <<radiobutton "$masongender" "f" checked>></label>
<<else>>
<label>Female <<radiobutton "$masongender" "f">></label>
<</if>>
|
<<if $masongender is "m">>
<label>Male <<radiobutton "$masongender" "m" checked>></label>
<<else>>
<label>Male <<radiobutton "$masongender" "m">></label>
<</if>>
<br>
<<if $masongenitals is "vagina">>
<label>Vagina <<radiobutton "$masongenitals" "vagina" checked>></label>
<<else>>
<label>Vagina <<radiobutton "$masongenitals" "vagina">></label>
<</if>>
|
<<if $masongenitals is "penis">>
<label>Penis <<radiobutton "$masongenitals" "penis" checked>></label>
<<else>>
<label>Penis <<radiobutton "$masongenitals" "penis">></label>
<</if>>
<br><br>
<</nobr>><</widget>>
:: Settings [nobr]
<<settings>><br><br>
<<link [[Next|Bedroom]]>><</link>><br>
:: Widgets Version Info [widget]
<<widget "versioninfo">><<nobr>>
<br><br>
Degrees of Lewdity 0.1.20.2<br><br>
"Version 0.001a" edition<br><br>
More information can be found at [[https://vrelnir.blogspot.com/| "https://vrelnir.blogspot.com/"]]<br><br>
<</nobr>><</widget>>
:: Widgets Sleep [widget]
<<widget "sleep">><<nobr>>
<<sleephour>>
<<sleephour>>
<<sleephour>>
<<sleephour>>
<<sleephour>>
<<sleephour>>
<<sleephour>>
<<sleephour>>
<<sleephour>>
<<sleephour>>
<</nobr>><</widget>>
<<widget "sleephour">><<nobr>>
<<effectstime>>
<<if $sleephour gte 1>><<set $sleephour -= 1>>
<<if $robinromance is 1 and $robinlust gte 20 and $robinbed isnot 1 and $location is "home" and $robinwakeday isnot 1>>
<<if $hour gte 18 or $hour lte 6>>
<<set $schoolwake to 1>><<set $robinlovewake to 1>><<set $robinwakeday to 1>>
<</if>>
<<elseif $robinlove gte 100 and $robindebtknown isnot 1 and $location is "home">>
<<if $hour gte 18 or $hour lte 6>>
<<set $schoolwake to 1>><<set $robindebtwake to 1>>
<</if>>
<<elseif $baileydefeatedchain gte 1 and $location is "home" and ($rng * 100) gte (9900 - ($allure / 5))>>
<<set $schoolwake to 1>><<set $baileyrapewake to 1>>
<<elseif $schoolday is 1 and $hour is 7 and $location is "home">>
<<set $schoolwake to 1>>
<<elseif $hour lte 6 and $location is "cabin" and $edenlust gte 26 and $edenwake isnot 1>>
<<set $edenwake to 1>>
<<set $schoolwake to 1>>
<<elseif $location is "forest" and $wolfpackferocity gte 10 and $wolfwake isnot 1>>
<<set $schoolwake to 1>><<set $wolfwake to 1>>
<<else>>
<</if>>
<<if $schoolwake isnot 1>>
<<if $sleeptrouble is 1 and $controlled is 0>>
<<set $tiredness -= 200>>
<<else>>
<<set $tiredness -= 250>>
<</if>>
<<pass 1 hour>>
<<if $nightmares gte 1 and $controlled is 0>>
<<stress 12>>
<</if>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "sleepeffects">><<nobr>>
<<if $sleeptransform is 1>>
<<if $wolfgirl is 0 and $wolfbuild gte 5>><<set $wolfgirl to 1>>
<span class="gold">You have a strange toothache.</span><br><br>
<<elseif $wolfgirl is 1 and $wolfbuild gte 10>><<set $wolfgirl to 2>>
<span class="gold">Your mouth feels different. You explore your mouth and wince as your tongue presses against your new fangs.</span><br><br>
<<elseif $wolfgirl is 1 and $wolfbuild lt 5>><<set $wolfgirl to 0>>
<span class="gold">Your toothache has stopped.</span><br><br>
<<elseif $wolfgirl is 2 and $wolfbuild gte 15>><<set $wolfgirl to 3>>
<span class="gold">Your scalp itches.</span><br><br>
<<elseif $wolfgirl is 2 and $wolfbuild lt 10>><<set $wolfgirl to 1>>
<span class="gold">Your fangs have turned into regular teeth.</span><br><br>
<<elseif $wolfgirl is 3 and $wolfbuild gte 20>><<set $wolfgirl to 4>>
<span class="gold">You feel something on your head. You reach up and tug, but it hurts. You have a new pair of wolf ears.</span><br><br>
<<elseif $wolfgirl is 3 and $wolfbuild lt 15>><<set $wolfgirl to 2>>
<span class="gold">Your scalp no longer itches.</span><br><br>
<<elseif $wolfgirl is 4 and $wolfbuild gte 25>><<set $wolfgirl to 5>>
<span class="gold">Your lower back itches.</span><br><br>
<<elseif $wolfgirl is 4 and $wolfbuild lte 20>><<set $wolfgirl to 3>>
<span class="gold">Your wolf ears have disappeared.</span><br><br>
<<elseif $wolfgirl is 5 and $wolfbuild gte 30>><<set $wolfgirl to 6>>
<span class="gold">You turn away from your bed and somehow knock your pillow to the floor. You reach behind you and feel your new wolf tail.</span><br><br>
<<elseif $wolfgirl is 5 and $wolfbuild lt 25>><<set $wolfgirl to 4>>
<span class="gold">Your lower back has stopped itching.</span><br><br>
<<elseif $wolfgirl is 6 and $wolfbuild lt 30>>Your balance feels different. Your wolf tail has disappeared.<<set $wolfgirl to 5>>
<span class="gold"></span><br><br>
<</if>>
<</if>>
<<if $stress gte 10000>>
<<set $stress -= 2000>>
<<trauma 10>>
<span class="red">Your stress level reached a peak while you slept and has since subsided, but at cost to your mental health.</span><<lstress>><<gtrauma>><br><br>
<</if>>
<<if $scienceproject is "ongoing" and $sciencephallusknown isnot 1 and $promiscuity gte 35>><<set $sciencephallusknown to 1>>
A lewd thought comes to you as you wake up. <span class="gold">You've conceived the "local phalli" science project.</span> Check your journal on the social page for details.<br><br>
<</if>>
<</nobr>><</widget>>
<<widget "clotheschoice">><<nobr>>
<<if $clothesselect is "casual">><<set $clothesselect to 0>><<storeclear>>
<<set $upperoff to $upperoutfitcasual>><<set $loweroff to $loweroutfitcasual>><<set $underoff to $underoutfitcasual>><<clotheson>>
<<elseif $clothesselect is "school">><<set $clothesselect to 0>><<storeclear>>
<<set $upperoff to $upperoutfitschool>><<set $loweroff to $loweroutfitschool>><<set $underoff to $underoutfitschool>><<clotheson>>
<<elseif $clothesselect is "custom1">><<set $clothesselect to 0>><<storeclear>>
<<set $upperoff to $upperoutfitcustom1>><<set $loweroff to $loweroutfitcustom1>><<set $underoff to $underoutfitcustom1>><<clotheson>>
<<elseif $clothesselect is "custom2">><<set $clothesselect to 0>><<storeclear>>
<<set $upperoff to $upperoutfitcustom2>><<set $loweroff to $loweroutfitcustom2>><<set $underoff to $underoutfitcustom2>><<clotheson>>
<<elseif $clothesselect is "custom3">><<set $clothesselect to 0>><<storeclear>>
<<set $upperoff to $upperoutfitcustom3>><<set $loweroff to $loweroutfitcustom3>><<set $underoff to $underoutfitcustom3>><<clotheson>>
<<elseif $clothesselect is "custom4">><<set $clothesselect to 0>><<storeclear>>
<<set $upperoff to $upperoutfitcustom4>><<set $loweroff to $loweroutfitcustom4>><<set $underoff to $underoutfitcustom4>><<clotheson>>
<<elseif $clothesselect is "clotheson">><<set $clothesselect to 0>>
<<if $upperstore is 0>>
<<upperundress>>
<</if>>
<<if $lowerstore is 0>>
<<lowerundress>>
<</if>>
<<if $understore is 0>>
<<underundress>>
<</if>>
<<storeon>>
<</if>>
<</nobr>><</widget>>
:: Widgets Transformation Img [widget]
<<widget "transformationwolfimg">><<nobr>>
<<if $wolfgirl gte 4>>
<img id="sexlashes" class="colour-hair" src="img/sex/doggy/idle/transformations/wolf/wolfearsred.gif">
<<if $hirsutedisable is "f">>
<img id="doggyhirsute" class="colour-hair" src="img/sex/doggy/idle/transformations/hirsute/bushtamered.png">
<</if>>
<</if>>
<<if $wolfgirl gte 6>>
<img id="sexlashes" class="colour-hair" src="img/sex/doggy/idle/transformations/wolf/wolftailred.gif">
<</if>>
<</nobr>><</widget>>
<<widget "transformationwolfimgslow">><<nobr>>
<<if $wolfgirl gte 4>>
<img id="sexlashes" class="colour-hair" src="img/sex/doggy/active/transformations/wolf/wolfearsredslow.gif">
<<if $hirsutedisable is "f">>
<img id="doggyhirsute" class="colour-hair" src="img/sex/doggy/active/transformations/hirsute/bushtameredslow.gif">
<</if>>
<</if>>
<<if $wolfgirl gte 6>>
<img id="sexlashes" class="colour-hair" src="img/sex/doggy/active/transformations/wolf/wolftailredslow.gif">
<</if>>
<</nobr>><</widget>>
<<widget "transformationwolfimgmid">><<nobr>>
<<if $wolfgirl gte 4>>
<img id="sexlashes" class="colour-hair" src="img/sex/doggy/active/transformations/wolf/wolfearsredmid.gif">
<<if $hirsutedisable is "f">>
<img id="doggyhirsute" class="colour-hair" src="img/sex/doggy/active/transformations/hirsute/bushtameredmid.gif">
<</if>>
<</if>>
<<if $wolfgirl gte 6>>
<img id="sexlashes" class="colour-hair" src="img/sex/doggy/active/transformations/wolf/wolftailredmid.gif">
<</if>>
<</nobr>><</widget>>
<<widget "transformationwolfimgfast">><<nobr>>
<<if $wolfgirl gte 4>>
<img id="sexlashes" class="colour-hair" src="img/sex/doggy/active/transformations/wolf/wolfearsredfast.gif">
<<if $hirsutedisable is "f">>
<img id="doggyhirsute" class="colour-hair" src="img/sex/doggy/active/transformations/hirsute/bushtameredfast.gif">
<</if>>
<</if>>
<<if $wolfgirl gte 6>>
<img id="sexlashes" class="colour-hair" src="img/sex/doggy/active/transformations/wolf/wolftailredfast.gif">
<</if>>
<</nobr>><</widget>>
<<widget "transformationwolfimgvfast">><<nobr>>
<<if $wolfgirl gte 4>>
<img id="sexlashes" class="colour-hair" src="img/sex/doggy/active/transformations/wolf/wolfearsredvfast.gif">
<<if $hirsutedisable is "f">>
<img id="doggyhirsute" class="colour-hair" src="img/sex/doggy/active/transformations/hirsute/bushtameredvfast.gif">
<</if>>
<</if>>
<<if $wolfgirl gte 6>>
<img id="sexlashes" class="colour-hair" src="img/sex/doggy/active/transformations/wolf/wolftailredvfast.gif">
<</if>>
<</nobr>><</widget>>
:: Widgets Compatibility [widget]
<<widget "compatibility">><<nobr>>
<</nobr>><</widget>>
:: Widgets Mirror [widget]
<<widget "mirror">><<nobr>>
You look into the mirror. A
<<if $trauma gte $traumamax>>
<<girl>> with glazed eyes
<<elseif $pain gte 100>>
crying <<girl>>
<<elseif $pain gte 40>>
tearful <<girl>>
<<elseif $pain gte 1>>
frowning <<girl>>
<<else>>
cheerful <<girl>>
<</if>>
stares back.<br><br>
<i>Attractiveness measures your ability to use your looks to your advantage.</i><br>
Attractiveness rating:
<<if $attractiveness gte 5000>>
<span class="green">S</span>
<<elseif $attractiveness gte 4000>>
<span class="teal">A</span>
<<elseif $attractiveness gte 3000>>
<span class="lblue">B</span>
<<elseif $attractiveness gte 2000>>
<span class="blue">C</span>
<<elseif $attractiveness gte 1000>>
<span class="purple">D</span>
<<else>>
<span class="pink">F</span>
<</if>>
<br><br>
<span class="green">
<<if $beauty gte ($beautymax / 7)>>
Cute<br>
<</if>>
<<if $beauty gte ($beautymax / 7) * 2>>
Pretty<br>
<</if>>
<<if $beauty gte ($beautymax / 7) * 3>>
Charming<br>
<</if>>
<<if $beauty gte ($beautymax / 7) * 4>>
Beautiful<br>
<</if>>
<<if $beauty gte ($beautymax / 7) * 5>>
Ravishing<br>
<</if>>
<<if $beauty gte ($beautymax / 7) * 6>>
Divine<br>
<</if>>
Hair length<br>
<<if $uppertype is "naked">>
Topless<br>
<<elseif $upperreveal gte 500>>
Revealing top<br>
<</if>>
<<if $lowertype is "naked">>
Bottomless<br>
<<elseif $lowerreveal gte 500>>
Revealing bottoms<br>
<</if>>
<<if $undertype is "naked">>
Pantiless<br>
<<elseif $underreveal gte 500>>
Sexy underwear<br>
<</if>>
<<if $wolfgirl gte 6>>
Wolfy<br>
<</if>>
<<if $angel gte 6>>
Angel<br>
<</if>>
<<if $fallenangel gte 2>>
Fallen angel<br>
<</if>>
<<if $demon gte 6>>
Demon<br>
<</if>>
<<if $legsacc is "stockings">>
Stockings<br>
<</if>>
<<if $legsacc is "fishnet stockings">>
Stockings<br>
<</if>>
</span>
<br>
<i>Allure is the dark side of attractiveness, and measures how much people will want to molest you.</i><br>
Allure: <<if $allure gte 6000 * $alluremod>><span class="red">You look like you need to be ravaged.</span>
<<elseif $allure gte 4000 * $alluremod>><span class="pink">You look perverted.</span>
<<elseif $allure gte 3000 * $alluremod>><span class="purple">You look lewd.</span>
<<elseif $allure gte 2000 * $alluremod>><span class="blue">You stand out.</span>
<<elseif $allure gte 1500 * $alluremod>><span class="lblue">You attract attention.</span>
<<elseif $allure gte 1000 * $alluremod>><span class="teal">You attract glances.</span>
<<else>><span class="green">You look unremarkable.</span>
<</if>><br><br>
<span class="red">
<<if $beauty gte ($beautymax / 7)>>
Cute<br>
<</if>>
<<if $beauty gte ($beautymax / 7) * 2>>
Pretty<br>
<</if>>
<<if $beauty gte ($beautymax / 7) * 3>>
Charming<br>
<</if>>
<<if $beauty gte ($beautymax / 7) * 4>>
Beautiful<br>
<</if>>
<<if $beauty gte ($beautymax / 7) * 5>>
Ravishing<br>
<</if>>
<<if $beauty gte ($beautymax / 7) * 6>>
Divine<br>
<</if>>
Hair length<br>
<<if $uppertype is "naked">>
Topless<br>
<<elseif $upperreveal gte 500>>
Revealing top<br>
<</if>>
<<if $lowertype is "naked">>
Bottomless<br>
<<elseif $lowerreveal gte 500>>
Revealing bottoms<br>
<</if>>
<<if $undertype is "naked">>
Pantiless<br>
<<elseif $underreveal gte 500>>
Sexy underwear<br>
<</if>>
<<if $wolfgirl gte 6>>
Wolfy<br>
<</if>>
<<if $angel gte 6>>
Angel<br>
<</if>>
<<if $fallenangel gte 2>>
Fallen angel<br>
<</if>>
<<if $demon gte 6>>
Demon<br>
<</if>>
<<if $legsacc is "stockings">>
Stockings<br>
<</if>>
<<if $legsacc is "fishnet stockings">>
Stockings<br>
<</if>>
<<if $daystate is "night">>
Night<br>
<</if>>
<<if $exposed gte 1>>
Exposed<br>
<</if>>
<<if $collared gte 1>>
Collared<br>
<</if>>
<<if $semencount + $goocount gte 1>>
Smell of cum<br>
<</if>>
<<if $semencount + $goocount gte 10>>
Covered in cum<br>
<</if>>
<<if $semencount + $goocount gte 30>>
Drenched in cum<br>
<</if>>
</span>
<</nobr>><</widget>>
:: NPC Settings [nobr]
<<npcsettings>><br><br>
<<link [[Next|Bedroom]]>><</link>><br>
:: Cabin NPC Settings [nobr]
<<npcsettings>>
<<link [[Back|Eden Cabin]]>><</link>><br>
:: Social [nobr]
<<back>><br><br><<set $menu to 1>>
<<if $initrobin is 1>>
<<robinrelationship>>
Love:
<<if $images is 1>>
<<if $robinlove gte 10>>
<img id="statbar" src="img/ui/heart.png">
<<else>>
<img id="statbar" src="img/ui/emptyheart.png">
<</if>>
<<if $robinlove gte 20>>
<img id="statbar" src="img/ui/heart.png">
<<else>>
<img id="statbar" src="img/ui/emptyheart.png">
<</if>>
<<if $robinlove gte 30>>
<img id="statbar" src="img/ui/heart.png">
<<else>>
<img id="statbar" src="img/ui/emptyheart.png">
<</if>>
<<if $robinlove gte 40>>
<img id="statbar" src="img/ui/heart.png">
<<else>>
<img id="statbar" src="img/ui/emptyheart.png">
<</if>>
<<if $robinlove gte 50>>
<img id="statbar" src="img/ui/heart.png">
<<else>>
<img id="statbar" src="img/ui/emptyheart.png">
<</if>>
<<if $robinlove gte 60>>
<img id="statbar" src="img/ui/heart.png">
<<else>>
<img id="statbar" src="img/ui/emptyheart.png">
<</if>>
<<if $robinlove gte 70>>
<img id="statbar" src="img/ui/heart.png">
<<else>>
<img id="statbar" src="img/ui/emptyheart.png">
<</if>>
<<if $robinlove gte 80>>
<img id="statbar" src="img/ui/heart.png">
<<else>>
<img id="statbar" src="img/ui/emptyheart.png">
<</if>>
<<if $robinlove gte 90>>
<img id="statbar" src="img/ui/heart.png">
<<else>>
<img id="statbar" src="img/ui/emptyheart.png">
<</if>>
<<if $robinlove gte 100>>
<img id="statbar" src="img/ui/heart.png">
<<else>>
<img id="statbar" src="img/ui/emptyheart.png">
<</if>>
<<else>>
<div class="meter">
<<set $robinlove = Math.clamp($robinlove, 0, 100)>>
<<set $percent=Math.floor(($robinlove/100)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<</if>>
<br>
Lust:
<<if $images is 1>>
<<if $robinlust gte 10>>
<img id="statbar" src="img/ui/vial.png">
<<else>>
<img id="statbar" src="img/ui/emptyvial.png">
<</if>>
<<if $robinlust gte 20>>
<img id="statbar" src="img/ui/vial.png">
<<else>>
<img id="statbar" src="img/ui/emptyvial.png">
<</if>>
<<if $robinlust gte 30>>
<img id="statbar" src="img/ui/vial.png">
<<else>>
<img id="statbar" src="img/ui/emptyvial.png">
<</if>>
<<if $robinlust gte 40>>
<img id="statbar" src="img/ui/vial.png">
<<else>>
<img id="statbar" src="img/ui/emptyvial.png">
<</if>>
<<if $robinlust gte 50>>
<img id="statbar" src="img/ui/vial.png">
<<else>>
<img id="statbar" src="img/ui/emptyvial.png">
<</if>>
<<if $robinlust gte 60>>
<img id="statbar" src="img/ui/vial.png">
<<else>>
<img id="statbar" src="img/ui/emptyvial.png">
<</if>>
<<if $robinlust gte 70>>
<img id="statbar" src="img/ui/vial.png">
<<else>>
<img id="statbar" src="img/ui/emptyvial.png">
<</if>>
<<if $robinlust gte 80>>
<img id="statbar" src="img/ui/vial.png">
<<else>>
<img id="statbar" src="img/ui/emptyvial.png">
<</if>>
<<if $robinlust gte 90>>
<img id="statbar" src="img/ui/vial.png">
<<else>>
<img id="statbar" src="img/ui/emptyvial.png">
<</if>>
<<if $robinlust gte 100>>
<img id="statbar" src="img/ui/vial.png">
<<else>>
<img id="statbar" src="img/ui/emptyvial.png">
<</if>>
<br>
<<else>>
<div class="meter">
<<set $robinlust = Math.clamp($robinlust, 0, 100)>>
<<set $percent=Math.floor(($robinlust/100)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<</if>>
<br>
<<if $robintrauma gte 1>>
Trauma:
<<if $images is 1>>
<img id="statbar" src="img/ui/redbolt.png">
<<if $robintrauma gte 11>>
<img id="statbar" src="img/ui/redbolt.png">
<<else>>
<img id="statbar" src="img/ui/point.png">
<</if>>
<<if $robintrauma gte 21>>
<img id="statbar" src="img/ui/redbolt.png">
<<else>>
<img id="statbar" src="img/ui/point.png">
<</if>>
<<if $robintrauma gte 31>>
<img id="statbar" src="img/ui/redbolt.png">
<<else>>
<img id="statbar" src="img/ui/point.png">
<</if>>
<<if $robintrauma gte 41>>
<img id="statbar" src="img/ui/redbolt.png">
<<else>>
<img id="statbar" src="img/ui/point.png">
<</if>>
<<if $robintrauma gte 51>>
<img id="statbar" src="img/ui/redbolt.png">
<<else>>
<img id="statbar" src="img/ui/point.png">
<</if>>
<<if $robintrauma gte 61>>
<img id="statbar" src="img/ui/redbolt.png">
<<else>>
<img id="statbar" src="img/ui/point.png">
<</if>>
<<if $robintrauma gte 71>>
<img id="statbar" src="img/ui/redbolt.png">
<<else>>
<img id="statbar" src="img/ui/point.png">
<</if>>
<<if $robintrauma gte 81>>
<img id="statbar" src="img/ui/redbolt.png">
<<else>>
<img id="statbar" src="img/ui/point.png">
<</if>>
<<if $robintrauma gte 91>>
<img id="statbar" src="img/ui/redbolt.png">
<<else>>
<img id="statbar" src="img/ui/point.png">
<</if>>
<<else>>
<div class="meter">
<<set $robintrauma = Math.clamp($robintrauma, 0, 100)>>
<<set $percent=Math.floor(($robintrauma/100)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<</if>>
<</if>>
<br>
<hr>
<br>
<</if>>
<<if $initwhitney is 1 and $whitneystate isnot "dungeon">>
<<whitneyrelationship>>
Love:
<<if $images is 1>>
<<if $whitneylove gte 3>>
<img id="statbar" src="img/ui/heart.png">
<<else>>
<img id="statbar" src="img/ui/emptyheart.png">
<</if>>
<<if $whitneylove gte 6>>
<img id="statbar" src="img/ui/heart.png">
<<else>>
<img id="statbar" src="img/ui/emptyheart.png">
<</if>>
<<if $whitneylove gte 9>>
<img id="statbar" src="img/ui/heart.png">
<<else>>
<img id="statbar" src="img/ui/emptyheart.png">
<</if>>
<<if $whitneylove gte 12>>
<img id="statbar" src="img/ui/heart.png">
<<else>>
<img id="statbar" src="img/ui/emptyheart.png">
<</if>>
<<if $whitneylove gte 15>>
<img id="statbar" src="img/ui/heart.png">
<<else>>
<img id="statbar" src="img/ui/emptyheart.png">
<</if>>
<<if $whitneylove gte 18>>
<img id="statbar" src="img/ui/heart.png">
<<else>>
<img id="statbar" src="img/ui/emptyheart.png">
<</if>>
<<if $whitneylove gte 21>>
<img id="statbar" src="img/ui/heart.png">
<<else>>
<img id="statbar" src="img/ui/emptyheart.png">
<</if>>
<<if $whitneylove gte 24>>
<img id="statbar" src="img/ui/heart.png">
<<else>>
<img id="statbar" src="img/ui/emptyheart.png">
<</if>>
<<if $whitneylove gte 27>>
<img id="statbar" src="img/ui/heart.png">
<<else>>
<img id="statbar" src="img/ui/emptyheart.png">
<</if>>
<<if $whitneylove gte 30>>
<img id="statbar" src="img/ui/heart.png">
<<else>>
<img id="statbar" src="img/ui/emptyheart.png">
<</if>>
<<else>>
<div class="meter">
<<set $whitneylove = Math.clamp($whitneylove, 0, 30)>>
<<set $percent=Math.floor(($whitneylove/30)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<</if>>
<br>
Lust:
<<if $images is 1>>
<<if $whitneylust gte 10>>
<img id="statbar" src="img/ui/vial.png">
<<else>>
<img id="statbar" src="img/ui/emptyvial.png">
<</if>>
<<if $whitneylust gte 20>>
<img id="statbar" src="img/ui/vial.png">
<<else>>
<img id="statbar" src="img/ui/emptyvial.png">
<</if>>
<<if $whitneylust gte 30>>
<img id="statbar" src="img/ui/vial.png">
<<else>>
<img id="statbar" src="img/ui/emptyvial.png">
<</if>>
<<if $whitneylust gte 40>>
<img id="statbar" src="img/ui/vial.png">
<<else>>
<img id="statbar" src="img/ui/emptyvial.png">
<</if>>
<<if $whitneylust gte 50>>
<img id="statbar" src="img/ui/vial.png">
<<else>>
<img id="statbar" src="img/ui/emptyvial.png">
<</if>>
<<if $whitneylust gte 60>>
<img id="statbar" src="img/ui/vial.png">
<<else>>
<img id="statbar" src="img/ui/emptyvial.png">
<</if>>
<<if $whitneylust gte 70>>
<img id="statbar" src="img/ui/vial.png">
<<else>>
<img id="statbar" src="img/ui/emptyvial.png">
<</if>>
<<if $whitneylust gte 80>>
<img id="statbar" src="img/ui/vial.png">
<<else>>
<img id="statbar" src="img/ui/emptyvial.png">
<</if>>
<<if $whitneylust gte 90>>
<img id="statbar" src="img/ui/vial.png">
<<else>>
<img id="statbar" src="img/ui/emptyvial.png">
<</if>>
<<if $whitneylust gte 100>>
<img id="statbar" src="img/ui/vial.png">
<<else>>
<img id="statbar" src="img/ui/emptyvial.png">
<</if>>
<<else>>
<div class="meter">
<<set $whitneylust = Math.clamp($whitneylust, 0, 100)>>
<<set $percent=Math.floor(($whitneylust/100)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<</if>>
<br>
Dominance:
<<if $images is 1>>
<<if $whitneydom gte 2>>
<img id="statbar" src="img/ui/collar.png">
<<else>>
<img id="statbar" src="img/ui/point.png">
<</if>>
<<if $whitneydom gte 4>>
<img id="statbar" src="img/ui/collar.png">
<<else>>
<img id="statbar" src="img/ui/point.png">
<</if>>
<<if $whitneydom gte 6>>
<img id="statbar" src="img/ui/collar.png">
<<else>>
<img id="statbar" src="img/ui/point.png">
<</if>>
<<if $whitneydom gte 8>>
<img id="statbar" src="img/ui/collar.png">
<<else>>
<img id="statbar" src="img/ui/point.png">
<</if>>
<<if $whitneydom gte 10>>
<img id="statbar" src="img/ui/collar.png">
<<else>>
<img id="statbar" src="img/ui/point.png">
<</if>>
<<if $whitneydom gte 12>>
<img id="statbar" src="img/ui/collar.png">
<<else>>
<img id="statbar" src="img/ui/point.png">
<</if>>
<<if $whitneydom gte 14>>
<img id="statbar" src="img/ui/collar.png">
<<else>>
<img id="statbar" src="img/ui/point.png">
<</if>>
<<if $whitneydom gte 16>>
<img id="statbar" src="img/ui/collar.png">
<<else>>
<img id="statbar" src="img/ui/point.png">
<</if>>
<<if $whitneydom gte 18>>
<img id="statbar" src="img/ui/collar.png">
<<else>>
<img id="statbar" src="img/ui/point.png">
<</if>>
<<if $whitneydom gte 20>>
<img id="statbar" src="img/ui/collar.png">
<<else>>
<img id="statbar" src="img/ui/point.png">
<</if>>
<<else>>
<div class="meter">
<<set $whitneydom = Math.clamp($whitneydom, 0, 20)>>
<<set $percent=Math.floor(($whitneydom/20)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<</if>>
<br>
<br>
<hr>
<br>
<</if>>
<<if $initeden is 1>>
<<edenrelationship>>
Love:
<<if $images is 1>>
<<if $edenlove gte 20>>
<img id="statbar" src="img/ui/heart.png">
<<else>>
<img id="statbar" src="img/ui/emptyheart.png">
<</if>>
<<if $edenlove gte 40>>
<img id="statbar" src="img/ui/heart.png">
<<else>>
<img id="statbar" src="img/ui/emptyheart.png">
<</if>>
<<if $edenlove gte 60>>
<img id="statbar" src="img/ui/heart.png">
<<else>>
<img id="statbar" src="img/ui/emptyheart.png">
<</if>>
<<if $edenlove gte 80>>
<img id="statbar" src="img/ui/heart.png">
<<else>>
<img id="statbar" src="img/ui/emptyheart.png">
<</if>>
<<if $edenlove gte 100>>
<img id="statbar" src="img/ui/heart.png">
<<else>>
<img id="statbar" src="img/ui/emptyheart.png">
<</if>>
<<if $edenlove gte 120>>
<img id="statbar" src="img/ui/heart.png">
<<else>>
<img id="statbar" src="img/ui/emptyheart.png">
<</if>>
<<if $edenlove gte 140>>
<img id="statbar" src="img/ui/heart.png">
<<else>>
<img id="statbar" src="img/ui/emptyheart.png">
<</if>>
<<if $edenlove gte 160>>
<img id="statbar" src="img/ui/heart.png">
<<else>>
<img id="statbar" src="img/ui/emptyheart.png">
<</if>>
<<if $edenlove gte 180>>
<img id="statbar" src="img/ui/heart.png">
<<else>>
<img id="statbar" src="img/ui/emptyheart.png">
<</if>>
<<if $edenlove gte 200>>
<img id="statbar" src="img/ui/heart.png">
<<else>>
<img id="statbar" src="img/ui/emptyheart.png">
<</if>>
<<else>>
<div class="meter">
<<set $edenlove = Math.clamp($edenlove, 0, 200)>>
<<set $percent=Math.floor(($edenlove/200)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<</if>>
<br>
Lust:
<<if $images is 1>>
<<if $edenlust gte 10>>
<img id="statbar" src="img/ui/vial.png">
<<else>>
<img id="statbar" src="img/ui/emptyvial.png">
<</if>>
<<if $edenlust gte 20>>
<img id="statbar" src="img/ui/vial.png">
<<else>>
<img id="statbar" src="img/ui/emptyvial.png">
<</if>>
<<if $edenlust gte 30>>
<img id="statbar" src="img/ui/vial.png">
<<else>>
<img id="statbar" src="img/ui/emptyvial.png">
<</if>>
<<if $edenlust gte 40>>
<img id="statbar" src="img/ui/vial.png">
<<else>>
<img id="statbar" src="img/ui/emptyvial.png">
<</if>>
<<if $edenlust gte 50>>
<img id="statbar" src="img/ui/vial.png">
<<else>>
<img id="statbar" src="img/ui/emptyvial.png">
<</if>>
<<if $edenlust gte 60>>
<img id="statbar" src="img/ui/vial.png">
<<else>>
<img id="statbar" src="img/ui/emptyvial.png">
<</if>>
<<if $edenlust gte 70>>
<img id="statbar" src="img/ui/vial.png">
<<else>>
<img id="statbar" src="img/ui/emptyvial.png">
<</if>>
<<if $edenlust gte 80>>
<img id="statbar" src="img/ui/vial.png">
<<else>>
<img id="statbar" src="img/ui/emptyvial.png">
<</if>>
<<if $edenlust gte 90>>
<img id="statbar" src="img/ui/vial.png">
<<else>>
<img id="statbar" src="img/ui/emptyvial.png">
<</if>>
<<if $edenlust gte 100>>
<img id="statbar" src="img/ui/vial.png">
<<else>>
<img id="statbar" src="img/ui/emptyvial.png">
<</if>>
<<else>>
<div class="meter">
<<set $edenlust = Math.clamp($edenlust, 0, 100)>>
<<set $percent=Math.floor(($edenlust/100)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<</if>>
<br>
<br>
<hr>
<br>
<</if>>
<<charlierelationship>>
<<darrylrelationship>>
<<harperrelationship>>
<<jordanrelationship>>
<<briarrelationship>>
<<riverrelationship>>
<<leightonrelationship>>
<<masonrelationship>>
<<winterrelationship>>
<<dorenrelationship>>
<<sirrisrelationship>>
<<samrelationship>>
<<landryrelationship>>
<<baileyrelationship>>
<<averyrelationship>>
<br><br>
You are considered
<<if $delinquency gte 1000>>
<span class="red">a terror</span>
<<elseif $delinquency gte 800>>
<span class="pink">a delinquent</span>
<<elseif $delinquency gte 600>>
<span class="purple">a delinquent</span>
<<elseif $delinquency gte 400>>
<span class="blue">a delinquent</span>
<<elseif $delinquency gte 200>>
<span class="lblue">a bad student</span>
<<elseif $delinquency gte 10>>
<span class="teal">a normal student</span>
<<else>>
<span class="green">an ideal student</span>
<</if>>
by the teachers and
<<if $cool gte 400>>
<span class="green">most of your fellow students aspire to be seen with you.</span>
<<elseif $cool gte 240>>
<span class="teal">cool</span> by your fellow students.
<<elseif $cool gte 160>>
<span class="lblue">cool</span> by your fellow students.
<<elseif $cool gte 120>>
<span class="blue">okay</span> by your fellow students.
<<elseif $cool gte 80>>
<span class="purple">dorky</span> by your fellow students.
<<elseif $cool gte 40>>
<span class="pink">odd</span> by your fellow students.
<<else>>
<span class="red">you are avoided</span> by your fellow students.
<</if>>
<br><br>
<<if $syndromewolves is 1>>
Wolf pack harmony:
<div class="meter">
<<set $percent=Math.floor(($wolfpackharmony/20)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
Wolf pack ferocity:
<div class="meter">
<<set $percent=Math.floor(($wolfpackferocity/20)*100)>>
<<print '<div class="goldbar" style="width:' + $percent + '%"></div>'>>
</div>
<br>
<</if>>
__Fame__<br>
Sex:
<<if $famesex gte 1000>>
<span class="red">Notorious slut</span><br>
<<elseif $famesex gte 600>>
<span class="pink">Famous</span><br>
<<elseif $famesex gte 400>>
<span class="purple">Recognised</span><br>
<<elseif $famesex gte 200>>
<span class="blue">Known</span><br>
<<elseif $famesex gte 100>>
<span class="lblue">Low-key</span><br>
<<elseif $famesex gte 30>>
<span class="teal">Obscure</span><br>
<<else>>
<span class="green">Unknown</span><br>
<</if>>
Prostitution:
<<if $fameprostitution gte 1000>>
<span class="red">Notorious whore</span><br>
<<elseif $fameprostitution gte 600>>
<span class="pink">Famous</span><br>
<<elseif $fameprostitution gte 400>>
<span class="purple">Recognised</span><br>
<<elseif $fameprostitution gte 200>>
<span class="blue">Known</span><br>
<<elseif $fameprostitution gte 100>>
<span class="lblue">Low-key</span><br>
<<elseif $fameprostitution gte 30>>
<span class="teal">Obscure</span><br>
<<else>>
<span class="green">Unknown</span><br>
<</if>>
Rape:
<<if $famerape gte 1000>>
<span class="red">Notorious fucktoy</span><br>
<<elseif $famerape gte 600>>
<span class="pink">Famous</span><br>
<<elseif $famerape gte 400>>
<span class="purple">Recognised</span><br>
<<elseif $famerape gte 200>>
<span class="blue">Known</span><br>
<<elseif $famerape gte 100>>
<span class="lblue">Low-key</span><br>
<<elseif $famerape gte 30>>
<span class="teal">Obscure</span><br>
<<else>>
<span class="green">Unknown</span><br>
<</if>>
<<if $bestialitydisable is "f">>
Bestiality:
<<if $famebestiality gte 1000>>
<span class="red">Notorious bitch</span><br>
<<elseif $famebestiality gte 600>>
<span class="pink">Famous</span><br>
<<elseif $famebestiality gte 400>>
<span class="purple">Recognised</span><br>
<<elseif $famebestiality gte 200>>
<span class="blue">Known</span><br>
<<elseif $famebestiality gte 100>>
<span class="lblue">Low-key</span><br>
<<elseif $famebestiality gte 30>>
<span class="teal">Obscure</span><br>
<<else>>
<span class="green">Unknown</span><br>
<</if>>
<</if>>
Exhibitionism:
<<if $fameexhibitionism gte 1000>>
<span class="red">Notorious flaunter</span><br>
<<elseif $fameexhibitionism gte 600>>
<span class="pink">Famous</span><br>
<<elseif $fameexhibitionism gte 400>>
<span class="purple">Recognised</span><br>
<<elseif $fameexhibitionism gte 200>>
<span class="blue">Known</span><br>
<<elseif $fameexhibitionism gte 100>>
<span class="lblue">Low-key</span><br>
<<elseif $fameexhibitionism gte 30>>
<span class="teal">Obscure</span><br>
<<else>>
<span class="green">Unknown</span><br>
<</if>>
Overall:
<<if $fame gte 4000>>
<span class="red">Notorious</span><br>
<<elseif $fame gte 3000>>
<span class="pink">Famous</span><br>
<<elseif $fame gte 2000>>
<span class="purple">Recognised</span><br>
<<elseif $fame gte 1000>>
<span class="blue">Known</span><br>
<<elseif $fame gte 500>>
<span class="lblue">Low-key</span><br>
<<elseif $fame gte 100>>
<span class="teal">Obscure</span><br>
<<else>>
<span class="green">Unknown</span><br>
<</if>>
<br>
<<journal>>
:: Widgets School Fame [widget]
<<widget "schoolfameboard">><<nobr>>
You see a large group of students up ahead. They're gathered around an announcement board, but you can't see what they're looking at. They murmur with excitement.<br><br>
<<generatey1>><<generatey2>><<person1>>A <<person>> turns and falls silent when <<he>> sees you. <<He>> stares at you. A <<person2>><<person>> spots you next, and whispers to <<his>> friend. More and more turn to look at you. The group parts and reveals the board.<br><br>
<span class="red">It's covered with pictures of you.</span>
<<if $famerape gte $famesex>>
<<if $famebestiality gte 1000>>
Being raped. By so many different people. Even animals appear to ravage you in some of them.
<<else>>
Being raped. By so many different people.
<</if>>
<<else>>
<<if $famebestiality gte 1000>>
Being fucked. By so many different people. Even animals appear to ravage you in some of them.
<<else>>
Being fucked. By so many different people.
<</if>>
<</if>>
<<if $famesex gte $famerape and $famebestiality lt 1000>>
You stare at the board. You feel angry.<<gtrauma>><<trauma 6>><br><br>
<<if $promiscuity gte 75>>
<<link [[Take Control|School Fame Gangbang]]>><<generatey3>><<generatey4>><<generatey5>><<generatey6>><<set $sexstart to 1>><</link>><<promiscuous5>><br>
<</if>>
<<link [[Look away|School Fame Away]]>><<set $cool to 1>><</link>><<lllcool>><br>
<<else>>
You stare at the board. You don't feel anything.<<lllcool>><<gtrauma>><<trauma 6>><<set $cool to 0>><br><br>
<<endevent>>
<<leighton>><<person1>>Leighton pushes through the crowd. "There's nothing to see here," <<he>> says. "I'm sure you have better places to be." The crowd disperses. Some students sneak pictures from the wall and hide them in their bags.<br><br>
Leighton starts tearing them down, but <<he>> puts them in <<his>> own pocket. <<He>> doesn't acknowledge you. <<He>> removes the last of the pictures and leaves you stood alone in the corridor.<br><br>
<<link [[Next|Hallways]]>><<set $eventskip to 1>><</link>><br>
<</if>>
<</nobr>><</widget>>
:: Widgets Deviancy [widget]
<<widget "deviancy1">><<nobr>>
<<if $control lt $controlmax>>
<<if $deviancy lte 19>>
<<set $deviancy += 2>>
Performing such a lewd act excites you and <span class="green">restores your sense of control and self-worth</span>, for now.<<ggcontrol>><<control 25>><<set $arousal += 100>><<set $stress -= 300>><<combattrauma -30>><<ltrauma>><<lstress>><<garousal>>
<<elseif $deviancy gte 20>>
While performing such a lewd act excites you, it does nothing to lift the cloud hanging over you. <span class="pink">You need to do something more extreme.</span><<set $arousal += 100>><<garousal>>
<<if $deviancystress1 isnot 1>><<set $deviancystress1 to 1>><<lstress>><<set $stress -= 100>>
<</if>>
<</if>>
<<else>>
<<if $deviancy lte 19>>
<<set $deviancy += 1>>
You already feel in control, but performing such a lewd act <span class="green">soothes</span> and excites you.<<control 25>><<set $arousal += 100>><<set $stress -= 300>><<combattrauma -30>><<ltrauma>><<lstress>><<garousal>>
<<elseif $deviancy gte 20>>
You already feel in control and the act is <span class="pink">too tame to soothe</span>, but it does excite you.<<set $arousal += 100>><<garousal>>
<<if $deviancystress1 isnot 1>><<set $deviancystress1 to 1>><<lstress>><<set $stress -= 100>>
<</if>>
<</if>>
<</if>>
<br><br><</nobr>><</widget>>
<<widget "deviancy2">><<nobr>>
<<if $control lt $controlmax>>
<<if $deviancy lte 39>>
<<set $deviancy += 2>>
Performing such a lewd act excites you and <span class="green">restores your sense of control and self-worth</span>, for now.<<ggcontrol>><<control 25>><<set $arousal += 200>><<set $stress -= 600>><<combattrauma -60>><<ltrauma>><<lstress>><<garousal>>
<<elseif $deviancy gte 40>>
While performing such a lewd act excites you, it does nothing to lift the cloud hanging over you. <span class="pink">You need to do something more extreme.</span><<set $arousal += 200>><<garousal>>
<<if $deviancystress2 isnot 1>><<set $deviancystress2 to 1>><<lstress>><<set $stress -= 200>>
<</if>>
<</if>>
<<else>>
<<if $deviancy lte 39>>
<<set $deviancy += 1>>
You already feel in control, but performing such a lewd act <span class="green">soothes</span> and excites you.<<control 25>><<set $arousal += 200>><<set $stress -= 600>><<combattrauma -60>><<ltrauma>><<lstress>><<garousal>>
<<elseif $deviancy gte 40>>
You already feel in control and the act is <span class="pink">too tame to soothe</span>, but it does excite you.<<set $arousal += 200>><<garousal>>
<<if $deviancystress2 isnot 1>><<set $deviancystress2 to 1>><<lstress>><<set $stress -= 200>>
<</if>>
<</if>>
<</if>>
<br><br><</nobr>><</widget>>
<<widget "deviancy3">><<nobr>>
<<if $control lt $controlmax>>
<<if $deviancy lte 59>>
<<set $deviancy += 2>>
Performing such a lewd act excites you and <span class="green">restores your sense of control and self-worth</span>, for now.<<ggcontrol>><<control 25>><<set $arousal += 300>><<set $stress -= 900>><<combattrauma -90>><<ltrauma>><<lstress>><<garousal>>
<<elseif $deviancy gte 60>>
While performing such a lewd act excites you, it does nothing to lift the cloud hanging over you. <span class="pink">You need to do something more extreme.</span><<set $arousal += 300>><<garousal>>
<<if $deviancystress3 isnot 1>><<set $deviancystress3 to 1>><<lstress>><<set $stress -= 300>>
<</if>>
<</if>>
<<else>>
<<if $deviancy lte 59>>
<<set $deviancy += 1>>
You already feel in control, but performing such a lewd act <span class="green">soothes</span> and excites you.<<control 25>><<set $arousal += 300>><<set $stress -= 900>><<combattrauma -90>><<ltrauma>><<lstress>><<garousal>>
<<elseif $deviancy gte 60>>
You already feel in control and the act is <span class="pink">too tame to soothe</span>, but it does excite you.<<set $arousal += 300>><<garousal>>
<<if $deviancystress3 isnot 1>><<set $deviancystress3 to 1>><<lstress>><<set $stress -= 300>>
<</if>>
<</if>>
<</if>>
<br><br><</nobr>><</widget>>
<<widget "deviancy4">><<nobr>>
<<if $control lt $controlmax>>
<<if $deviancy lte 79>>
<<set $deviancy += 2>>
Performing such a lewd act excites you and <span class="green">restores your sense of control and self-worth</span>, for now.<<ggcontrol>><<control 25>><<set $arousal += 400>><<set $stress -= 1200>><<combattrauma -120>><<ltrauma>><<lstress>><<garousal>>
<<elseif $deviancy gte 80>>
While performing such a lewd act excites you, it does nothing to lift the cloud hanging over you. <span class="pink">You need to do something more extreme.</span><<set $arousal += 400>><<garousal>>
<<if $deviancystress4 isnot 1>><<set $deviancystress4 to 1>><<lstress>><<set $stress -= 400>>
<</if>>
<</if>>
<<else>>
<<if $deviancy lte 79>>
<<set $deviancy += 1>>
You already feel in control, but performing such a lewd act <span class="green">soothes</span> and excites you.<<control 25>><<set $arousal += 400>><<set $stress -= 1200>><<combattrauma -120>><<ltrauma>><<lstress>><<garousal>>
<<elseif $deviancy gte 80>>
You already feel in control and the act is <span class="pink">too tame to soothe</span>, but it does excite you.<<set $arousal += 400>><<garousal>>
<<if $deviancystress4 isnot 1>><<set $deviancystress4 to 1>><<lstress>><<set $stress -= 400>>
<</if>>
<</if>>
<</if>>
<br><br><</nobr>><</widget>>
<<widget "deviancy5">><<nobr>>
<<if $control lt $controlmax>>
<<if $deviancy lte 99>>
<<set $deviancy += 2>>
Performing such a lewd act excites you and <span class="green">restores your sense of control and self-worth</span>, for now.<<ggcontrol>><<control 25>><<set $arousal += 500>><<set $stress -= 1500>><<combattrauma -150>><<ltrauma>><<lstress>><<garousal>>
<<elseif $deviancy gte 100>>
While performing such a lewd act excites you, it does nothing to lift the cloud hanging over you. <span class="pink">You need to do something more extreme.</span><<set $arousal += 500>><<garousal>>
<<if $deviancystress5 isnot 1>><<set $deviancystress5 to 1>><<lstress>><<set $stress -= 500>>
<</if>>
<</if>>
<<else>>
<<if $deviancy lte 99>>
<<set $deviancy += 1>>
You already feel in control, but performing such a lewd act <span class="green">soothes</span> and excites you.<<control 25>><<set $arousal += 500>><<set $stress -= 1500>><<combattrauma -150>><<ltrauma>><<lstress>><<garousal>>
<<elseif $deviancy gte 100>>
You already feel in control and the act is <span class="pink">too tame to soothe</span>, but it does excite you.<<set $arousal += 500>><<garousal>>
<<if $deviancystress5 isnot 1>><<set $deviancystress5 to 1>><<lstress>><<set $stress -= 500>>
<</if>>
<</if>>
<</if>>
<br><br><</nobr>><</widget>>
<<widget "combatdeviancy1">><<nobr>>
<<if $consensual is 1>>
<<if $control lt $controlmax>>
<<if $deviancy lte 19>>
<<set $deviancy += 2>>
You prepare to perform a particularly lewd act, <span class="green">restoring your sense of control.</span><<ggcontrol>><<control 25>><<set $arousal += 100>><<set $stress -= 300>><<combattrauma -30>><<ltrauma>><<lstress>><<garousal>>
<<elseif $deviancy gte 20>>
You prepare to perform a particularly lewd act, <span class="pink">though its too tame to soothe.</span><<set $arousal += 100>><<garousal>>
<<if $deviancystress1 isnot 1>><<set $deviancystress1 to 1>><<lstress>><<set $stress -= 100>>
<</if>>
<</if>>
<<else>>
<<if $deviancy lte 19>>
<<set $deviancy += 1>>
You prepare to perform a particularly lewd act, <span class="green">soothing and exciting you.</span><<control 25>><<set $arousal += 100>><<set $stress -= 300>><<combattrauma -30>><<ltrauma>><<lstress>><<garousal>>
<<elseif $deviancy gte 20>>
You prepare to perform a particularly lewd act, <span class="pink">though it's too tame to soothe.</span><<set $arousal += 100>><<garousal>>
<<if $deviancystress1 isnot 1>><<set $deviancystress1 to 1>><<lstress>><<set $stress -= 100>>
<</if>>
<</if>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "combatdeviancy2">><<nobr>>
<<if $consensual is 1>>
<<if $control lt $controlmax>>
<<if $deviancy lte 39>>
<<set $deviancy += 2>>
You prepare to perform a particularly lewd act, <span class="green">restoring your sense of control.</span><<ggcontrol>><<control 25>><<set $arousal += 200>><<set $stress -= 600>><<combattrauma -60>><<ltrauma>><<lstress>><<garousal>>
<<elseif $deviancy gte 40>>
You prepare to perform a particularly lewd act, <span class="pink">though its too tame to soothe you.</span><<set $arousal += 200>><<garousal>>
<<if $deviancystress2 isnot 1>><<set $deviancystress2 to 1>><<lstress>><<set $stress -= 200>>
<</if>>
<</if>>
<<else>>
<<if $deviancy lte 39>>
<<set $deviancy += 1>>
You prepare to perform a particularly lewd act, <span class="green">soothing and exciting you.</span><<control 25>><<set $arousal += 200>><<set $stress -= 600>><<combattrauma -60>><<ltrauma>><<lstress>><<garousal>>
<<elseif $deviancy gte 40>>
You prepare to perform a particularly lewd act, <span class="pink">though it's too tame to soothe.</span><<set $arousal += 200>><<garousal>>
<<if $deviancystress2 isnot 1>><<set $deviancystress2 to 1>><<lstress>><<set $stress -= 200>>
<</if>>
<</if>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "combatdeviancy3">><<nobr>>
<<if $consensual is 1>>
<<if $control lt $controlmax>>
<<if $deviancy lte 59>>
<<set $deviancy += 2>>
You prepare to perform a particularly lewd act, <span class="green">restoring your sense of control.</span><<ggcontrol>><<control 25>><<set $arousal += 300>><<set $stress -= 900>><<combattrauma -90>><<ltrauma>><<lstress>><<garousal>>
<<elseif $deviancy gte 60>>
You prepare to perform a particularly lewd act, <span class="pink">though its too tame to soothe you.</span><<set $arousal += 300>><<garousal>>
<<if $deviancystress3 isnot 1>><<set $deviancystress3 to 1>><<lstress>><<set $stress -= 300>>
<</if>>
<</if>>
<<else>>
<<if $deviancy lte 59>>
<<set $deviancy += 1>>
You prepare to perform a particularly lewd act, <span class="green">soothing and exciting you.</span><<control 25>><<set $arousal += 300>><<set $stress -= 900>><<combattrauma -90>><<ltrauma>><<lstress>><<garousal>>
<<elseif $deviancy gte 60>>
You prepare to perform a particularly lewd act, <span class="pink">though it's too tame to soothe.</span><<set $arousal += 300>><<garousal>>
<<if $deviancystress3 isnot 1>><<set $deviancystress3 to 1>><<lstress>><<set $stress -= 300>>
<</if>>
<</if>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "combatdeviancy4">><<nobr>>
<<if $consensual is 1>>
<<if $control lt $controlmax>>
<<if $deviancy lte 79>>
<<set $deviancy += 2>>
You prepare to perform a particularly lewd act, <span class="green">restoring your sense of control.</span><<ggcontrol>><<control 25>><<set $arousal += 400>><<set $stress -= 1200>><<combattrauma -120>><<ltrauma>><<lstress>><<garousal>>
You prepare to perform a particularly lewd act, <span class="pink">though its too tame to soothe you.</span><<set $arousal += 400>><<garousal>>
<<if $deviancystress4 isnot 1>><<set $deviancystress4 to 1>><<lstress>><<set $stress -= 400>>
<</if>>
<</if>>
<<else>>
<<if $deviancy lte 79>>
<<set $deviancy += 1>>
You prepare to perform a particularly lewd act, <span class="green">soothing and exciting you.</span><<control 25>><<set $arousal += 400>><<set $stress -= 1200>><<combattrauma -120>><<ltrauma>><<lstress>><<garousal>>
<<elseif $deviancy gte 80>>
You prepare to perform a particularly lewd act, <span class="pink">though it's too tame to soothe.</span><<set $arousal += 400>><<garousal>>
<<if $deviancystress4 isnot 1>><<set $deviancystress4 to 1>><<lstress>><<set $stress -= 400>>
<</if>>
<</if>>
<</if>>
<</if>>
<</nobr>><</widget>>
<<widget "combatdeviancy5">><<nobr>>
<<if $consensual is 1>>
<<if $control lt $controlmax>>
<<if $deviancy lte 99>>
<<set $deviancy += 2>>
You prepare to perform a particularly lewd act, <span class="green">restoring your sense of control.</span><<ggcontrol>><<control 25>><<set $arousal += 500>><<set $stress -= 1500>><<combattrauma -150>><<ltrauma>><<lstress>><<garousal>>
<<elseif $deviancy gte 100>>
You prepare to perform a particularly lewd act, <span class="pink">though its too tame to soothe you.</span><<set $arousal += 500>><<garousal>>
<<if $deviancystress5 isnot 1>><<set $deviancystress5 to 1>><<lstress>><<set $stress -= 500>>
<</if>>
<</if>>
<<else>>
<<if $deviancy lte 99>>
<<set $deviancy += 1>>
You prepare to perform a particularly lewd act, <span class="green">soothing and exciting you.</span><<control 25>><<set $arousal += 500>><<set $stress -= 1500>><<combattrauma -150>><<ltrauma>><<lstress>><<garousal>>
<<elseif $deviancy gte 100>>
You prepare to perform a particularly lewd act, <span class="pink">though it's too tame to soothe.</span><<set $arousal += 500>><<garousal>>
<<if $deviancystress5 isnot 1>><<set $deviancystress5 to 1>><<lstress>><<set $stress -= 500>>
<</if>>
<</if>>
<</if>>
<</if>>
<</nobr>><</widget>>
:: VersionUpdate
<<if $playergender isnot undefined>>
<<if $pubwhore is undefined>>
<<set $pubwhore to 0>>
<</if>>
<<if $masturbationstat is undefined>>
<<set $masturbationstat to 0>>
<</if>>
<<if $masturbationorgasmstat is undefined>>
<<set $masturbationorgasmstat to 0>>
<</if>>
<<if $masturbationtimestat is undefined>>
<<set $masturbationtimestat to 0>>
<</if>>
<<if $masturbationorgasm is undefined>>
<<set $masturbationorgasm to 0>>
<</if>>
<<if $whitechance is undefined>>
<<set $whitechance to 90>>
<</if>>
<<if $blackchance is undefined>>
<<set $blackchance to 10>>
<</if>>
<<if $wolfgirl gte 1>>
<<set $transformed to 1>>
<</if>>
<<if $angel is undefined>>
<<set $angel to 0>>
<</if>>
<<if $angelbuild is undefined>>
<<set $angelbuild to 0>>
<</if>>
<<if $demon is undefined>>
<<set $demon to 0>>
<</if>>
<<if $demonbuild is undefined>>
<<set $demonbuild to 0>>
<</if>>
<<if $demonabsorb is undefined>>
<<set $demonabsorb to 0>>
<</if>>
<<if $upperwet is undefined>>
<<set $upperwet to 0>>
<<set $upperwetstage to 0>>
<</if>>
<<if $lowerwet is undefined>>
<<set $lowerwet to 0>>
<<set $lowerwetstage to 0>>
<</if>>
<<if $underwet is undefined>>
<<set $underwet to 0>>
<<set $underwetstage to 0>>
<</if>>
<<if $upperwetcarry is undefined>>
<<set $upperwetcarry to 0>>
<<set $upperwetstagecarry to 0>>
<</if>>
<<if $lowerwetcarry is undefined>>
<<set $lowerwetcarry to 0>>
<<set $lowerwetstagecarry to 0>>
<</if>>
<<if $underwetcarry is undefined>>
<<set $underwetcarry to 0>>
<<set $underwetstagecarry to 0>>
<</if>>
<<if $schoolevent is undefined>>
<<set $schoolevent to 0>>
<<set $schooleventtimer to 5>>
<</if>>
<<if $stressmax is undefined>>
<<set $stressmax to 10010>>
<</if>>
<<if $tirednessmax is undefined>>
<<set $tirednessmax to 2000>>
<</if>>
<<if $physiquemax is undefined>>
<<set $physiquemax to 20000>>
<</if>>
<<if $beautymax is undefined>>
<<set $beautymax to 10000>>
<</if>>
<<if $malechance is undefined>>
<<set $malechance to 50>>
<<if $genderdisable is "f">>
<<set $malechance to 100>>
<<elseif $genderdisable is "m">>
<<set $malechance to 0>>
<<elseif $genderdisable is 90>>
<<set $malechance to 90>>
<<elseif $genderdisable is 10>>
<<set $malechance to 10>>
<</if>>
<</if>>
<<if $transformdisable is undefined>>
<<set $transformdisable to "f">>
<</if>>
<<if $robindebtlimit is undefined and $robinintro is 1>>
<<set $robindebtlimit to 5>>
<<if $robindebt gte $robindebtlimit>>
<<set $robindebt to ($robindebtlimit - 1)>>
<</if>>
<</if>>
<<if $robinrescued isnot undefined>>
<<set $robindebtknown to 1>>
<</if>>
<<if $initnpccompatibility isnot 1>><<set $initnpccompatibility to 1>>
<<initnpcgender>>
<</if>>
<<if $genderknown is undefined>>
<<set $genderknown to ["Robin", "Bailey"]>>
<</if>>
<<if $waterwash is undefined>>
<<set $waterwash to 0>>
<</if>>
<<if $npclovehigh isnot 10>>
<<set $npclovehigh to 10>>
<</if>>
<<if $npclovelow isnot -10>>
<<set $npclovelow to -10>>
<</if>>
<<if $npcdomhigh isnot 10>>
<<set $npcdomhigh to 10>>
<</if>>
<<if $npcdomlow isnot -10>>
<<set $npcdomlow to -10>>
<</if>>
<<if $whitneystate is undefined and $initwhitney is 1>>
<<set $whitneystate to "active">>
<<set $whitneydom to 10>>
<</if>>
<<if $bullytimeroutside is undefined>>
<<set $bullytimeroutside to 0>>
<</if>>
<<if $bullyeventoutside is undefined>>
<<set $bullyeventoutside to 0>>
<</if>>
<<if $whitneylust is undefined>>
<<set $whitneylust to 0>>
<</if>>
<<if $upperoutfitcasual is undefined>>
<<if $playergender is "m">>
<<set $upperoutfitcasual to "t-shirt">>
<<set $loweroutfitcasual to "shorts">>
<<set $underoutfitcasual to "Y fronts">>
<<set $upperoutfitschool to "school shirt">>
<<set $loweroutfitschool to "school shorts">>
<<set $underoutfitschool to "Y fronts">>
<<else>>
<<set $upperoutfitcasual to "sundress">>
<<set $loweroutfitcasual to "sundress skirt">>
<<set $underoutfitcasual to "plain panties">>
<<set $upperoutfitschool to "school shirt">>
<<set $loweroutfitschool to "school skirt">>
<<set $underoutfitschool to "plain panties">>
<</if>>
<</if>>
<<if $famesex is undefined>>
<<set $famesex to 0>>
<</if>>
<<if $famerape is undefined>>
<<set $famerape to 0>>
<</if>>
<<if $famegood is undefined>>
<<set $famegood to 0>>
<</if>>
<<if $famebusiness is undefined>>
<<set $famebusiness to 0>>
<</if>>
<<if $arousalmax is undefined>>
<<set $arousalmax to 10000>>
<</if>>
<<if $deviancy is undefined>>
<<set $deviancy to 0>>
<</if>>
<<if $squidcount is undefined>>
<<set $squidcount to 0>>
<</if>>
<<if $schoolevent is -1>>
<<set $schoolevent to 1>>
<</if>>
<<if $baileydefeated is undefined>>
<<set $baileydefeated to 0>>
<<set $baileydefeatedlewd to 0>>
<<set $baileydefeatedchain to 0>>
<</if>>
<<if $robinmoney is undefined>>
<<set $robinmoney to 300>>
<</if>>
<<if $scienceproject is undefined>>
<<set $scienceproject to "none">>
<</if>>
<<if $yeardays is undefined>>
<<set $yeardays to 0>>
<</if>>
<<if $averygender is undefined>>
<<if $malechance lt random(1, 100)>>
<<set $averygender to "f">>
<<else>>
<<set $averygender to "m">>
<</if>>
<</if>>
<<if $averygenitals is undefined>>
<<if $averygender is "m">>
<<if random(0, 99) gte $cbchance>>
<<set $averygenitals to "penis">>
<<else>>
<<set $averygenitals to "vagina">>
<</if>>
<<elseif $averygender is "f">>
<<if random(0, 99) gte $dgchance>>
<<set $averygenitals to "vagina">>
<<else>>
<<set $averygenitals to "penis">>
<</if>>
<</if>>
<</if>>
<<if $gamemode is undefined>>
<<set $gamemode to "normal">>
<</if>>
<<if $alluremod is undefined>>
<<set $alluremod to 1>>
<</if>>
<<if $oxygenmax is undefined>>
<<set $oxygenmax to 1200>>
<<set $oxygen to 1200>>
<</if>>
<<if $hallucinogen is undefined>>
<<set $hallucinogen to 0>>
<</if>>
<<if $antiquemoney is undefined>>
<<set $antiquemoney to 0>>
<<set $antiquemoneyhistory to 0>>
<<if $scienceproject is "done" or $scienceproject is "won">>
<<set $scienceproject to "none">>
<</if>>
<</if>>
<<if $controlmax is undefined>>
<<set $controlmax to 1000>>
<<if $control is 1>>
<<set $control to 1000>>
<<else>>
<<set $control to 0>>
<</if>>
<</if>>
<<if $scienceproject is "ongoing" and $sciencephallus is undefined>>
<<set $sciencephallusready to 0>>
<<set $sciencephallus to 0>>
<<set $sciencephalluspenis to 0>>
<<set $sciencephallusclit to 0>>
<</if>>
<<if $background is undefined>>
<<set $background to "waif">>
<</if>>
<</if>>
:: Widgets Journal [widget]
<<widget "journal">><<nobr>>
__Journal__<br>
<<if $rentday isnot undefined>>
<<if $renttime lte 0>>
Bailey is looking for you, and wants <span class="gold">£<<print $rentmoney / 100>></span>.<br>
<<else>>
Bailey wants <span class="gold">£<<print $rentmoney / 100>></span> on <<rentday>><br>
<</if>>
<<else>>
Bailey wants <span class="gold">£<<print $rentmoney / 100>></span>.<br>
<</if>>
<<if $psych is 1>>
You have an appointment with Doctor Harper on Friday.<br>
<</if>>
<<if $brothelshow isnot "none" and $brothelshowintro is 1>>
<<if $weekday is 6 and $brothelshowdone isnot 1>>
You're expected to perform at the brothel today.<br>
<<else>>
You're expected to perform at the brothel on Friday.<br>
<</if>>
<<elseif $brothelshowintro is 1>>
You can star in shows at the brothel.<br>
<</if>>
<<if $pubtask2 is 1>>
Return the black box to Landry at the pub.<br>
<<elseif $pubtask is 1>>
Landry wants you to retrieve a black box from the forest.<br>
<</if>>
<<if $robindebtevent gte 1 and $docksrobinintro isnot 1>>
Robin is missing. They were taken to the docks on Mer Street.<br>
<</if>>
<br>
<<if $scienceproject is "ongoing">>
<hr>
<<if $scienceprojectdays is 0>>
The science fair is being held at the town hall on Cliff street today from 9:00 until 18:00.<br>
<<else>>
The science fair will be held at the town hall on Cliff Street in $scienceprojectdays days.<br>
<</if>>
You have the following ongoing projects. You'll choose one to present at the fair.<br>
<<if $sciencelichenknown is 1>>
-<span class="green">Local lichen</span><br>
<<if $sciencelichenpark is 1>>
<<if $sciencelichenparkready is 1>>
--You've incorporated the lichen living in the park to your project. <span class="gold">+25% success chance.</span><br>
<<else>>
--You've examined lichen in the park. You need to write it up at home or the library.<br>
<</if>>
<<else>>
--<span class="black">Examine white lichen in the park.</span><br>
<</if>>
<<if $sciencelichentemple is 1>>
<<if $sciencelichentempleready is 1>>
--You've incorporated the lichen living on the temple to your project. <span class="gold">+25% success chance.</span><br>
<<else>>
--You've examined lichen living on the temple. You need to add it to your project at home or the library.<br>
<</if>>
<<else>>
--<span class="black">Examine pink lichen on the temple.</span><br>
<</if>>
<<if $sciencelichendrain is 1>>
<<if $sciencelichendrainready is 1>>
--You've incorporated the lichen living in the storm drain to your project. <span class="gold">+25% success chance.</span><br>
<<else>>
--You've examined lichen living in the storm drain. You need to add it to your project at home or the library.<br>
<</if>>
<<else>>
--<span class="black">Examine violet lichen in the storm drain, where it exits into the sea.</span><br>
<</if>>
<<if $sciencelichenlake is 1>>
<<if $sciencelichenlakeready is 1>>
--You've incorporated the lichen living on the lake ruin to your project. <span class="gold">+25% success chance</span><br>
<<else>>
--You've examined lichen living on the lake ruin. You need to add it to your project at home or the library.<br>
<</if>>
<<else>>
--<span class="black">Examine purple lichen on the lake ruin.</span><br>
<</if>>
As it is, this project has a <<print ($sciencelichenparkready * 25 + $sciencelichenlakeready * 25 + $sciencelichendrainready * 25 + $sciencelichentempleready * 25)>>% chance of winning the fair. Winning with this project will greatly reduce trauma and endear you to your teachers.<br><br>
<<else>>
<span class="black">????????????</span> - Explore to discover.<br><br>
<</if>>
<<if $scienceshroomknown is 1>>
-<span class="green">Local mushrooms</span><br>
-- $scienceshroomheart/5 heartshrooms found.<br>
-- $scienceshroomheartready/5 heartshrooms added to project.
<<if $scienceshroomheart gte $scienceshroomheartready>>
Add mushrooms to your project at home or the library.
<</if>>
<<if $scienceshroomheartready gte 1>>
<span class="gold">+<<print ($scienceshroomheartready * 10)>>% success chance.</span>
<</if>>
<br>
-- $scienceshroomwolf/5 wolfshrooms found.<br>
-- $scienceshroomwolfready/5 wolfshrooms added to project.
<<if $scienceshroomwolf gte $scienceshroomwolfready>>
Add mushrooms to your project at home or the library.
<</if>>
<<if $scienceshroomwolfready gte 1>>
<span class="gold">+<<print ($scienceshroomwolfready * 10)>>% success chance.</span>
<</if>>
<br>
As it is, this project has a <<print ($scienceshroomwolfready * 10 + $scienceshroomheartready * 10)>>% chance of winning the fair. Winning with this project will greatly reduce trauma and make you more popular among your peers.<br><br>
<<else>>
<span class="black">????????????</span> - Explore the forest to discover.<br><br>
<</if>>
<<if $sciencephallusknown is 1>>
-<span class="green">Local phalli</span> - Look for participants on the beach during good weather.<br>
-- $sciencephallus/10 phalli measured.<br>
-- $sciencephallusready/10 phalli added to project.
<<if $sciencephallus gte $sciencephallusready>>
Add phalli to your project at home or the library.
<</if>>
<<if $sciencephallusready gte 1>>
<span class="gold">+<<print ($sciencephallusready * 10)>>% success chance.</span>
<</if>>
<br>
As it is, this project has a <<print ($sciencephallusready * 10)>>% chance of winning the fair. Winning with this project will greatly reduce trauma and make you more famous.<br><br>
<<else>>
<span class="black">????????????</span> - Become more promiscuous to discover.<br><br>
<</if>>
<hr>
<</if>>
<</nobr>><</widget>>
|
QuiltedQuail/degrees
|
game/base-system.twee
|
twee
|
unknown
| 754,082 |
:: Abomination [nobr]
<<if $molestationstart is 1>>
<<set $molestationstart to 0>>
<<controlloss>>
<<violence 1>>
<<neutral 1>>
<<molested>>
<<set $event to "abomination">>
<<abomination>>
You awaken to find yourself being assaulted by a strange beast!
<</if>>
<<effects>>
<<effectsmult>><<man>>
<<stateman>><br>
<br>
<<actionsmult>>
<span id="next">
<<if $alarm is 1>>
<<if $rescue is 1>>
[[Next->Abomination]]
<<else>>
No one comes to your aid.<<set $alarm to 0>>
<<if $drugged is 1>>Intoxicated as you are, you couldn't cry very convincingly.<</if>><br><br>
<<if $enemyarousal gte $enemyarousalmax>>
[[Next->Abomination]]
<<else>>
[[Next->Abomination]]
<</if>>
<</if>>
<<elseif $enemyarousal gte $enemyarousalmax>>
[[Next->Abomination]]
<<elseif $enemyhealth lte 0>>
[[Next->Abomination]]
<<else>>
[[Next->Abomination]]
<</if>>
</span>
:: Monster Test [nobr]
<<set $outside to 1>><<set $location to "sea">><<effects>>
<<if $molestationstart is 1>><<set $molestationstart to 0>>
<<set $combat to 1>>
<<molested>>
<<controlloss>>
<<set $enemytype to "tentacles">>
<<set $tentacleno to 6>>
<<set $tentaclehealth to 15>>
<<tentaclestart>>
<<set $vorestage to 1>>
<<set $vorecreature to "whale">>
<<set $vorestrength to 1>>
<<if $hallucinations gte 1>>
<<set $voretentacles to 1>>
<<else>>
<<set $voretentacles to 0>>
<</if>>
<<set $swarmname to "swarms">>
<<set $swarmmove to "moving towards you">>
<<set $swarmcreature to "eels">>
<<set $swarmspill to "encircle you">>
<<set $swarmsteady to "fend off">>
<<set $swarmSteady to "Fend off">>
<<set $swarmcount to 10>>
<<set $swarm1 to "active">>
<<set $swarm2 to "contained">>
<<set $swarm3 to "contained">>
<<set $swarm4 to "contained">>
<<set $swarm5 to "contained">>
<<set $swarm6 to "contained">>
<<set $swarm7 to "contained">>
<<set $swarm8 to "contained">>
<<set $swarm9 to "contained">>
<<set $swarm10 to "contained">>
<<set $swarmactive to 1>>
<<set $swimdistance to 20>>
<<set $water to 1>>
<</if>>
<<voreeffects>><<swarmeffects>><<effectstentacles>>
<<vore>><<swarm>><<tentacles>>
<<statetentacles>>
<<voreactions>><<swarmactions>><<actionstentacles>>
<<if $stress gte 10000>>
<span id="next"><<link [[Next|Monster Test]]>><</link>></span><<nexttext>>
<<elseif $vorestage lte 0>>
<span id="next"><<link [[Next|Monster Test]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link "Next">><<script>>state.display(state.active.title, null, "back")<</script>><</link>></span><<nexttext>>
<</if>>
Background<br>
<label><span class="gold">Waif</span> <<radiobutton "$background" "waif" checked>> - No special advantages or disadvantages.<br> <i>Recommended for beginners.</i></label><br>
<label><span class="gold">Nerd</span> <<radiobutton "$background" "nerd">> - Good at school. Picked on.<br> <span class="green"> + Science | + Maths | + English | + History |</span><span class="red"> - Status</span></label><br>
<label><span class="gold">Athlete</span> <<radiobutton "$background" "athlete">> - Physically capable. Grades have suffered.<br> <span class="green"> + Physique | + Swimming</span><br><span class="red">- Science | - Maths | - English | - History |</span></label><br>
<label><span class="gold">Delinquent</span> <<radiobutton "$background" "delinquent">> - Your antics have made you popular with other students. Less so with the teachers.<br> <span class="green"> + Status |</span><span class="red"> + Delinquency</span></label><br>
<label><span class="gold">Promiscuous</span> <<radiobutton "$background" "promiscuous">> - You've experimented sexually.<br> <span class="blue"> + Promiscuity</span></label><br>
<label><span class="gold">Exhibitionist</span> <<radiobutton "$background" "exhibitionist">> - You have an affinity for exposing yourself in public places.<br> <span class="blue"> + Exhibitionism</span></label><br>
<label><span class="gold">Deviant</span> <<radiobutton "$background" "deviant">> - You really like animals.<br> <span class="blue"> + Deviancy</span></label><br>
<label><span class="gold">Beautiful</span> <<radiobutton "$background" "beautiful">> - You turn heads.<br> <i>Not recommended for beginners.</i><span class="blue"> + Beauty</span></label><br>
<br>
<hr>
|
QuiltedQuail/degrees
|
game/base-unknown.twee
|
twee
|
unknown
| 4,290 |
mouse.tooltip {font-weight: normal;}
mouse.tooltip span {
z-index:210;
display:none;
padding:14px 10px;
margin-top:50px; margin-left:-40px;
min-width: 50px;
max-width: 450px !important;
line-height:20px;
border-radius:2px;
box-shadow: 0px 0px 8px 4px #000;
}
mouse.tooltip:hover span{
display:inline;
position:absolute;
border:2px solid #000000;
color: #000000;
font-weight: normal;
text-decoration: none;
font-size:1.0em;
background:#C4C4C4 repeat-x 0 0;
}
#ui-bar {
z-index: 300;
}
#ui-bar-toggle {
z-index: 500;
}
.red {
color: #EC3535;
}
.pink {
color: #E40081;
}
.purple {
color: #AA4BC8;
}
.blue {
color: #4372FF;
}
.lblue {
color: #559BC0;
}
.teal {
color: #08C1C1;
}
.green {
color: #38B20A;
}
.brat {
color: #B75D41;
}
.meek {
color: #C44B8B;
}
.def {
color: #D20000;
}
.hide a {
color: #eee;
text-decoration: none;
}
.hide a:hover {
color: #eee;
text-decoration: none;
}
.sub {
color: #AA4BC8;
}
.gold {
color: #FFD700;
}
.orange {
color: #f28500
}
.tangerine {
color: #f28500
}
.black {
color: #929292
}
.brown {
color: #aa7243
}
.lewd {
color: #E04880
}
.grey {
color: #B7B7B7
}
.general {
opacity: 0.99;
}
.wetstage2 {
opacity: 0.90;
filter: brightness(0.95);
}
.wetstage3 {
opacity: 0.75;
filter: brightness(0.90);
}
#statbar {
position: relative;
left: 0px;
top: 9px;
z-index: 0;
}
#bg {
position: fixed;
left: 0px;
top: 0px;
z-index: 0;
}
#daystate {
position: fixed;
left: 0px;
top: 0px;
z-index: 10;
}
#weather {
position: fixed;
left: 0px;
top: 64px;
z-index: 10;
}
#location {
position: fixed;
left: 0px;
top: 128px;
z-index: 10;
}
#divandroidxray {
position: relative;
display: inline-block;
height: 256px;
width: 256px;
}
#xrayvaginal {
position: absolute;
left: 0px;
top: 0px;
z-index: 3;
}
#xrayvaginalcum {
position: absolute;
left: 0px;
top: 0px;
z-index: 4;
}
#xraypenile {
position: absolute;
left: 0px;
top: 0px;
z-index: 2;
}
#xrayanal {
position: absolute;
left: 512px;
top: 0px;
z-index: 1;
}
#xrayandroidanal {
position: relative;
left: 0px;
top: -150px;
z-index: 1;
}
#backhair {
position: absolute;
left: 0px;
top: 0px;
z-index: 10;
}
#base {
position: absolute;
left: 0px;
top: 0px;
z-index: 20;
}
#hirsute {
position: absolute;
left: 0px;
top: 0px;
z-index: 21;
}
#arm {
position: absolute;
left: 0px;
top: 0px;
z-index: 25;
}
#eyes {
position: absolute;
left: 0px;
top: 0px;
z-index: 30;
}
#sclera {
position: absolute;
left: 0px;
top: 0px;
z-index: 35;
}
#mouth {
position: absolute;
left: 0px;
top: 0px;
z-index: 40;
}
#blush {
position: absolute;
left: 0px;
top: 0px;
z-index: 50;
}
#tears {
position: absolute;
left: 0px;
top: 0px;
z-index: 55;
}
#hair {
position: absolute;
left: 0px;
top: 0px;
z-index: 60;
}
#brow {
position: absolute;
left: 0px;
top: 0px;
z-index: 62;
}
#lashes {
position: absolute;
left: 0px;
top: 0px;
z-index: 64;
}
#underacc {
position: absolute;
left: 0px;
top: 0px;
z-index: 70;
}
#under {
position: absolute;
left: 0px;
top: 0px;
z-index: 75;
}
#legs {
position: absolute;
left: 0px;
top: 0px;
z-index: 80;
}
#feet {
position: absolute;
left: 0px;
top: 0px;
z-index: 85;
}
#bottom {
position: absolute;
left: 0px;
top: 0px;
z-index: 90;
}
#top {
position: absolute;
left: 0px;
top: 0px;
z-index: 100;
}
#sleeve {
position: absolute;
left: 0px;
top: 0px;
z-index: 105;
}
#outer {
position: absolute;
left: 0px;
top: 0px;
z-index: 110;
}
#outersleeve {
position: absolute;
left: 0px;
top: 0px;
z-index: 115;
}
#neckacc {
position: absolute;
left: 0px;
top: 0px;
z-index: 120;
}
#faceacc {
position: absolute;
left: 0px;
top: 0px;
z-index: 125;
}
#headacc {
position: absolute;
left: 0px;
top: 0px;
z-index: 130;
}
#divsex {
position: relative;
display: inline-block;
height: 256px;
width: 768px;
}
#divandroidsex {
position: relative;
display: inline-block;
height: 256px;
width: 256px;
left: -256px;
}
#voreback {
position: absolute;
left: 256px;
top: 0px;
z-index: -20;
}
#sexbaseback {
position: absolute;
left: 256px;
top: 0px;
z-index: 1;
}
#closepenis {
position: absolute;
left: 321px;
top: -30px;
z-index: 250;
}
#closeanus {
position: absolute;
left: 451px;
top: -30px;
z-index: 250;
}
#closevagina {
position: absolute;
left: 386px;
top: -30px;
z-index: 250;
}
#sexpenis {
position: absolute;
left: 256px;
top: 0px;
z-index: 5;
}
#beastback {
position: absolute;
left: 256px;
top: 0px;
z-index: 6;
}
#sexbase {
position: absolute;
left: 256px;
top: 0px;
z-index: 10;
}
#sexbaseoverlay {
position: absolute;
left: 256px;
top: 0px;
z-index: 12;
}
#sexeyes {
position: absolute;
left: 256px;
top: 0px;
z-index: 20;
}
#sexsclera {
position: absolute;
left: 256px;
top: 0px;
z-index: 30;
}
#sexmouth {
position: absolute;
left: 256px;
top: 0px;
z-index: 40;
}
#sexblush {
position: absolute;
left: 256px;
top: 0px;
z-index: 50;
}
#sextears {
position: absolute;
left: 256px;
top: 0px;
z-index: 60;
}
#beastfront {
position: absolute;
left: 256px;
top: 0px;
z-index: 65;
}
#sexhair {
position: absolute;
left: 256px;
top: 0px;
z-index: 70;
}
#sexbrow {
position: absolute;
left: 256px;
top: 0px;
z-index: 80;
}
#sexlashes {
position: absolute;
left: 256px;
top: 0px;
z-index: 90;
}
#sexbasefront {
position: absolute;
left: 256px;
top: 0px;
z-index: 100;
}
#doggyhirsute {
position: absolute;
left: 256px;
top: 0px;
z-index: 101;
}
#sexunder {
position: absolute;
left: 256px;
top: 0px;
z-index: 102;
}
#sexlower {
position: absolute;
left: 256px;
top: 0px;
z-index: 104;
}
#sexupper {
position: absolute;
left: 256px;
top: 0px;
z-index: 106;
}
#sexaboveclothes {
position: absolute;
left: 256px;
top: 0px;
z-index: 108;
}
#foreground {
position: absolute;
left: 256px;
top: 0px;
z-index: 200;
}
#divmap {
position: relative;
display: inline-block;
height: 256px;
width: 256px;
}
#map {
position: absolute;
left: 0px;
top: 0px;
z-index: 10;
}
#maparrow {
position: absolute;
left: 0px;
top: 0px;
z-index: 20;
}
#lower {
position: absolute;
left: 0px;
top: 0px;
z-index: 90;
}
#upper {
position: absolute;
left: 0px;
top: 0px;
z-index: 95;
}
#collar {
position: absolute;
left: 0px;
top: 0px;
z-index: 100;
}
#rightarm {
position: absolute;
left: 0px;
top: 0px;
z-index: 105;
}
#leftarm {
position: absolute;
left: 0px;
top: 0px;
z-index: 105;
}
#rightarmclothes {
position: absolute;
left: 0px;
top: 0px;
z-index: 110;
}
#leftarmclothes {
position: absolute;
left: 0px;
top: 0px;
z-index: 110;
}
#legsacc {
position: absolute;
left: 0px;
top: 0px;
z-index: 80;
}
#feetacc {
position: absolute;
left: 0px;
top: 0px;
z-index: 85;
}
/*! <<numberpool>> macro set for SugarCube v2 */
div[id|="numberbox-body"] {
display: inline-block;
}
div[id|="numberbox-body"] input {
min-width: 3em;
width: 3em;
text-align: center;
}
div[id|="numberbox-body"] button {
font-family: "tme-fa-icons";
font-style: normal;
font-weight: normal;
font-variant: normal;
text-transform: none;
line-height: normal;
speak: none;
padding: 0.4em 0.6em;
}
div[id|="numberbox-body"] button[id|="numberbox-minus"] {
margin-right: 0.4em;
}
div[id|="numberbox-body"] button[id|="numberbox-plus"] {
margin-left: 0.4em;
}
div[id|="numberslider-body"] {
display: inline-block;
}
div[id|="numberslider-body"] span {
display: inline-block;
/*font-size: 1.25em;*/
margin-left: 0.25em;
min-width: 3em;
text-align: center;
vertical-align: middle;
}
div[id|="numberslider-body"] input {
-webkit-appearance: none;
cursor: pointer;
height: 1.25em;
min-width: 20em;
vertical-align: middle;
}
div[id|="numberslider-body"] input:focus {
outline: none;
}
div[id|="numberslider-body"] input::-webkit-slider-runnable-track {
background: #222;
border: 1px solid #444;
border-radius: 0;
cursor: pointer;
height: 10px;
width: 100%;
}
div[id|="numberslider-body"] input::-webkit-slider-thumb {
-webkit-appearance: none;
background: #35a;
border: 1px solid #57c;
border-radius: 0;
cursor: pointer;
height: 18px;
margin-top: -5px;
width: 33px;
}
div[id|="numberslider-body"] input:focus::-webkit-slider-runnable-track {
background: #222;
}
div[id|="numberslider-body"] input::-moz-range-track {
background: #222;
border: 1px solid #444;
border-radius: 0;
cursor: pointer;
height: 10px;
width: 100%;
}
div[id|="numberslider-body"] input::-moz-range-thumb {
background: #35a;
border: 1px solid #57c;
border-radius: 0;
cursor: pointer;
height: 18px;
width: 33px;
}
div[id|="numberslider-body"] input::-ms-track {
background: transparent;
border-color: transparent;
color: transparent;
cursor: pointer;
height: 10px;
width: 99%; /* fallback for MS browsers without support for calc() */
width: calc(100% - 1px);
}
div[id|="numberslider-body"] input::-ms-fill-lower {
background: #222;
border: 1px solid #444;
border-radius: 0;
}
div[id|="numberslider-body"] input::-ms-fill-upper {
background: #222;
border: 1px solid #444;
border-radius: 0;
}
div[id|="numberslider-body"] input::-ms-thumb {
background: #35a;
border: 1px solid #57c;
border-radius: 0;
cursor: pointer;
height: 16px;
width: 33px;
}
.meter {
position: relative;
height: 0.3em;
width: 100%;
background-color: gray;
text-align: center;
z-index: -10;
}
.redbar {
position: absolute;
left: 0;
top: 0;
height: 0.3em;
background-color: #EC3535;
z-index: -10;
}
.pinkbar {
position: absolute;
left: 0;
top: 0;
height: 0.3em;
background-color: #E40081;
z-index: -10;
}
.purplebar {
position: absolute;
left: 0;
top: 0;
height: 0.3em;
background-color: #AA4BC8;
z-index: -10;
}
.bluebar {
position: absolute;
left: 0;
top: 0;
height: 0.3em;
background-color: #4372FF;
z-index: -10;
}
.lbluebar {
position: absolute;
left: 0;
top: 0;
height: 0.3em;
background-color: #559BC0;
z-index: -10;
}
.tealbar {
position: absolute;
left: 0;
top: 0;
height: 0.3em;
background-color: #08C1C1;
z-index: -10;
}
.greenbar {
position: absolute;
left: 0;
top: 0;
height: 0.3em;
background-color: #38B20A;
z-index: -10;
}
.goldbar {
position: absolute;
left: 0;
top: 0;
height: 0.3em;
background-color: #FFD700;
z-index: -10;
}
/*
* Hair/Eye/Clothing colour filters
* Expected document structure:
* - some outer element has .hair-$haircolour (or .eye-/.lower-/.upper-/.under-) class
* - inner image element has .colour-hair (or -eye/-lower/-upper/-under) class
*/
/* Hair: base is red */
.hair-black .colour-hair {
filter: hue-rotate(0deg) saturate(0%) brightness(30%) contrast(100%);
}
.hair-blond .colour-hair {
filter: hue-rotate(55deg) saturate(60%) brightness(160%) contrast(100%);
}
.hair-blue .colour-hair {
filter: hue-rotate(210deg) saturate(200%) brightness(60%) contrast(150%);
}
.hair-brown .colour-hair {
filter: hue-rotate(40deg) saturate(80%) brightness(80%) contrast(100%);
}
.hair-ginger .colour-hair {
filter: hue-rotate(30deg) saturate(100%) brightness(100%) contrast(100%);
}
.hair-green .colour-hair {
filter: hue-rotate(90deg) saturate(100%) brightness(100%) contrast(100%);
}
.hair-pink .colour-hair {
filter: hue-rotate(-20deg) saturate(80%) brightness(150%) contrast(100%);
}
.hair-purple .colour-hair {
filter: hue-rotate(-90deg) saturate(100%) brightness(70%) contrast(140%);
}
.hair-red .colour-hair {
filter: hue-rotate(0deg) saturate(100%) brightness(100%) contrast(100%);
}
/* Eye: base is hazel */
.eye-dark-blue .colour-eye {
filter: hue-rotate(170deg) brightness(110%) saturate(80%) contrast(100%);
}
.eye-light-blue .colour-eye {
filter: hue-rotate(150deg) brightness(160%) saturate(40%) contrast(100%);
}
.eye-purple .colour-eye {
filter: hue-rotate(-120deg) brightness(100%) saturate(100%) contrast(100%);
}
.eye-hazel .colour-eye {
filter: hue-rotate(0deg) saturate(100%) brightness(100%) contrast(100%);
}
.eye-amber .colour-eye {
filter: hue-rotate(0deg) brightness(170%) saturate(100%) contrast(100%);
}
.eye-green .colour-eye {
filter: hue-rotate(30deg) brightness(140%) saturate(100%) contrast(100%);
}
/* Clothing: base is red */
.upper-blue .colour-upper, .lower-blue .colour-lower, .under-blue .colour-under {
filter: hue-rotate(-120deg) saturate(100%) brightness(100%) contrast(100%);
}
.upper-white .colour-upper, .lower-white .colour-lower, .under-white .colour-under {
filter: hue-rotate(40deg) saturate(0%) brightness(400%) contrast(100%);
}
.upper-red .colour-upper, .lower-red .colour-lower, .under-red .colour-under {
filter: hue-rotate(0deg) saturate(100%) brightness(100%) contrast(100%);
}
.upper-green .colour-upper, .lower-green .colour-lower, .under-green .colour-under {
filter: hue-rotate(120deg) saturate(100%) brightness(150%) contrast(100%);
}
.upper-black .colour-upper, .lower-black .colour-lower, .under-black .colour-under {
filter: hue-rotate(0deg) saturate(0%) brightness(100%) contrast(150%);
}
.upper-pink .colour-upper, .lower-pink .colour-lower, .under-pink .colour-under {
filter: hue-rotate(-30deg) saturate(50%) contrast(100%) brightness(160%);
}
.upper-purple .colour-upper, .lower-purple .colour-lower, .under-purple .colour-under {
filter: hue-rotate(-90deg) saturate(100%) brightness(100%) contrast(100%);
}
.upper-tangerine .colour-upper, .lower-tangerine .colour-lower, .under-tangerine .colour-under {
filter: hue-rotate(60deg) saturate(150%) brightness(250%) contrast(150%);
}
.upper-yellow .colour-upper, .lower-yellow .colour-lower, .under-yellow .colour-under {
filter: hue-rotate(60deg) saturate(150%) brightness(350%) contrast(150%);
}
/*
* Animation-related classes. Work-in-progress
* Expected document structure:
* div class="i256" -- should have the image size-related class
* img class="anim-2s anim-2f" -- should have
* 1) duration-related class like anim-2s (2 seconds)
* 2) frame count-related class like anim-2f (2 frames)
*/
.i256 {
width: 256px;
height: 256px;
overflow: hidden;
}
.anim-1s, .anim-2s {
animation-iteration-count: infinite;
animation-name: anim-default;
}
/* duration related-classes.
When adding, don't forget to add it to rule above with animation-iteration-count */
.anim-1s { animation-duration: 1s; }
.anim-2s { animation-duration: 2s; }
/* frame-count related classes */
.anim-2f { animation-timing-function: steps(2); }
@keyframes anim-default {
0% { transform: translateX(0); }
100% { transform: translateX(-100%); }
}
|
QuiltedQuail/degrees
|
game/base.css
|
CSS
|
unknown
| 15,165 |
:: dummy
/*
This is special passage to avoid false positive error in sanityCheck build script. Do not uncomment anything!
$dancestudioanger
*/
|
QuiltedQuail/degrees
|
game/dummy.twee
|
twee
|
unknown
| 144 |
:: Residential alleyways [nobr]
<<set $outside to 1>><<set $location to "town">><<effects>><<set $bus to "residential">>
You are in an alleyway in the residential district.
<<if $daystate is "day">>
There are a lot of people around.
<<elseif $daystate is "dusk">>
You hear children playing.
<<elseif $daystate is "night">>
You hear a dog barking.
<<elseif $daystate is "dawn">>
There are many people around.
<</if>>
Your home is nearby.
<br><br>
<<if $exposed gte 1>><<exhibitionismalley>><</if>>
<<if $arousal gte 10000>>
<<orgasmstreet>>
<</if>>
<<if $stress gte 10000>><<passoutalley>>
<<else>>
<<set $danger to random(1, 10000)>><<set $dangerevent to 0>>
<<if $danger gte (9900 - $allure) and $eventskip is 0>>
<<eventsstreet>>
<<else>>
Places of interest<br>
<<if $exposed gte 1>>
<<link [[Go home (0:02)->Home Fence]]>><<pass 2>><</link>><br>
<<else>>
<<link [[Go home (0:02)->Garden]]>><<pass 2>><</link>><br>
<</if>>
<br>
<<if $exposed gte 1 and $daystate isnot "night">>
<<else>>
Travel<br>
<<domus>><br>
<<barb>><br>
<<danube>><br>
<<connudatus>><br>
<</if>>
<br>
Alternate routes<br>
<<if $exposed gte 1 and $daystate isnot "night">>
<<else>>
<<commercial>><br>
<</if>>
<<stormdrain>><br>
<br>
<div id="divmap"><<if $images gte 1>><img id="map" src="img/misc/map.png"><img id="maparrow" src="img/misc/maparrowresidential.png"><<else>><<textmap>><</if>></div>
<</if>>
<</if>>
<<set $eventskip to 0>>
:: Commercial alleyways [nobr]
<<set $outside to 1>><<set $location to "town">><<effects>><<set $bus to "commercial">>
You are in an alleyway in the commerical district.
<<if $daystate is "day">>
You can hear the commotion of the high street.
<<elseif $daystate is "night">>
You hear laughter from a nearby building.
<<else>>
Many doors stand open and you hear voices within.
<</if>>
There's a ladder to your left, you think it will take you to the rooftops.
<br><br>
<<if $exposed gte 1>><<exhibitionismalley>>
<<if $daystate isnot "night">>
Connudatus street is packed with stalls. You might be able to cross the street by hiding under them. If something went wrong however, you'd find yourself exposed in the middle of a busy public street.<br><br>
<</if>>
<</if>>
<<if $arousal gte 10000>>
<<orgasmstreet>>
<</if>>
<<if $stress gte 10000>><<passoutalley>>
<<else>>
<<set $danger to random(1, 10000)>><<set $dangerevent to 0>>
<<if $danger gte (9900 - $allure) and $eventskip is 0>>
<<eventsstreet>>
<<else>>
Places of interest<br>
<<if $daystate isnot "night" and $exposed gte 1>>
<<link [[Sneak under the stalls (0:10)|Stalls Ex]]>><<pass 10>><</link>><br>
<</if>>
<<link [[Climb the ladder (0:02)->Commercial rooftops]]>><<pass 2>><</link>><br>
<br>
<<if $daystate isnot "night" and $exposed gte 1>>
<<else>>
Travel<br>
<<connudatus>><br>
<<cliff>><br>
<<wolf>><br>
<<high>><br>
<</if>>
<br>
Alternate routes<br>
<<if $exposed gte 1 and $daystate isnot "night">>
<<else>>
<<residential>><br>
<<park>><br>
<</if>>
<<stormdrain>><br>
<br>
<div id="divmap"><<if $images gte 1>><img id="map" src="img/misc/map.png"><img id="maparrow" src="img/misc/maparrowcommercial.png"><<else>><<textmap>><</if>></div>
<</if>>
<</if>>
<<set $eventskip to 0>>
:: Park [nobr]
<<set $outside to 1>><<set $location to "town">><<effects>><<set $bus to "park">>
You are in the park.
<<if $daystate is "dawn">>
There are a few people out walking or jogging. Some have dogs with them.
<<elseif $daystate is "day">>
There are many people around. Small children play in the playground.
<<elseif $daystate is "dusk">>There are many people around. Children play in the playground.
<<elseif $daystate is "night">>There is no one around.
<</if>>
<br><br>
<<if $exposed gte 1>><<exhibitionismpark>>
<<if $daystate isnot "night">>
You can hear the commotion of the High Street, there's no way you'll be able to cross like this. However, there's a depot from which crates are being carried across the road, maybe you could hide in one of them.<br><br>
<</if>>
<</if>>
<<if $arousal gte 10000>>
<<orgasmstreet>>
<</if>>
<<if $stress gte 10000>><<passoutpark>>
<<else>>
<<set $danger to random(1, 10000)>><<set $dangerevent to 0>>
<<if $danger gte (9900 - $allure) and $eventskip is 0>>
<<eventsstreet>>
<<else>>
Places of interest<br>
<<if $scienceproject is "ongoing" and $sciencelichenknown is 1 and $sciencelichenpark is 0 and $exposed lte 0>>
<<link [[Examine lichen for science project|Park Lichen]]>><</link>><br>
<</if>>
<<link [[Men's toilets|Men's Toilets]]>><</link>><br>
<<link [[Women's toilets|Women's Toilets]]>><</link>><br>
<br>
<<if $exposed gte 1 and $daystate isnot "night">>
<<link [[Hide in a Crate (0:10)|Crate Ex]]>><<pass 10>><</link>><br>
<<else>>
Travel<br>
<<high>><br>
<<starfish>><br>
<<oxford>><br>
<<nightingale>><br>
<</if>>
<br>
Alternate routes<br>
<<if $exposed gte 1 and $daystate isnot "night">>
<<else>>
<<commercial>><br>
<<industrial>><br>
<</if>>
<<stormdrain>><br>
<<if $historytrait gte 1 and $parktunnelintro gte 1>>
<<link [[Secret tunnel to school (0:05)|School Rear Playground]]>><<pass 5>><</link>><br>
<</if>>
<br>
<div id="divmap"><<if $images gte 1>><img id="map" src="img/misc/map.png"><img id="maparrow" src="img/misc/maparrowpark.png"><<else>><<textmap>><</if>></div>
<</if>>
<</if>>
<<set $eventskip to 0>>
:: Industrial alleyways [nobr]
<<set $outside to 1>><<set $location to "town">><<effects>><<set $bus to "industrial">>
You are in an alleyway in the industrial district.
<<if $daystate is "day">>
You hear machines operating in the buildings around you.
<<elseif $daystate is "night">>
<<else>>
You hear the engines of heavy vehicles.
<</if>>
There's a ladder to your right, you think it will take you to the rooftops. The rear of the school protrudes into this area, separated by a spiked fence.
<br><br>
<<if $exposed gte 1>><<exhibitionismalley>><</if>>
<<if $arousal gte 10000>>
<<orgasmstreet>>
<</if>>
<<if $stress gte 10000>><<passoutalley>>
<<else>>
<<set $danger to random(1, 10000)>><<set $dangerevent to 0>>
<<if $danger gte (9900 - $allure) and $eventskip is 0>>
<<eventsstreet>>
<<else>>
Points of interest<br>
<<link [[Climb the ladder (0:02)->Industrial rooftops]]>><<pass 2>><</link>><br>
<<link [[Back door to bus station (0:02)|Bus Station Back Entrance]]>><<pass 2>><</link>><br>
<<link [[Climb over the fence into the school grounds (0:05)|School Rear Fence]]>><<pass 5>><</link>><br>
<br>
<<if $exposed gte 1 and $daystate isnot "night">>
<<else>>
Travel<br>
<<oxford>><br>
<<mer>><br>
<<elk>><br>
<<harvest>><br>
<</if>>
<br>
Alternate routes<br>
<<if $exposed gte 1 and $daystate isnot "night">>
<<else>>
<<park>><br>
<</if>>
<<stormdrain>><br>
<div id="divmap"><<if $images gte 1>><img id="map" src="img/misc/map.png"><img id="maparrow" src="img/misc/maparrowindustrial.png"><<else>><<textmap>><</if>></div>
<</if>>
<</if>>
<<set $eventskip to 0>>
:: Widgets Passout Alley [widget]
<<widget "passoutalley">><<nobr>>
[[Everything fades to black...->Passout alley]]
<</nobr>><</widget>>
:: Passout alley [nobr]
You've pushed yourself too much.<br><br>
<<passout>>
<<set $safealley to 0>>
<<set $dangeralley to 0>>
<<set $danger to random(1, 10000)>>
<<if $danger gte (9900 - $allure)>><<set $dangeralley to random(1, 100)>><</if>>
<<if $danger lt (9900 - $allure)>><<set $safealley to random(1, 100)>><</if>>
<<if $dangeralley gte 71>><<link [[Wake up|Abduction]]>><<set $molestationstart to 1>><</link>>
<<elseif $dangeralley gte 45>><<link [[Wake up|Street Wake]]>><</link>>
<<elseif $dangeralley gte 1>><<link [[Wake up|Molestation alley]]>><<set $molestationstart to 1>><</link>><</if>>
<<if $safealley gte 1>><<ambulance>><</if>>
<<pass 1 hour>>
<<set $trauma +=10>><<set $stress -= 2000>>
:: Widgets Industrial Alleyways Ex [widget]
<<widget "industrialex1">><<nobr>>
<<generate1>><<person1>>You continue on, your heart pounding in your chest. You peek round a corner to make sure the way forward is safe. Just before you move however, a force impacts your left leg, closely followed by a sharp pain. You see the cuprit as you fall to the ground, a <<personstop>> <<He>> drops the metal pipe and is on top of you before you can recover.<br><br><<set $pain += 50>><<set $molestationstart to 1>>
[[Next->Molestation Industrial]]
<</nobr>><</widget>>
<<widget "industrialex2">><<nobr>>
You come to a dead end, your path blocked by a brick wall. You hear voices coming from the way you arrived. If you go back that way, you fear your <<lewdness>> will be seen. You notice a small hole at the base of the wall, maybe large enough for you to squeeze through. You could also wait until the threat has passed.<br><br>
<<link [[Squeeze through the hole|Industrial Ex Hole]]>><</link>><br>
<<link [[Hide and wait for them to pass (0:30)|Industrial Ex Hide]]>><<pass 30>><<stress 6>><</link>><<gstress>><br>
<</nobr>><</widget>>
:: Widgets Park Ex [widget]
<<widget "parkex1">><<nobr>>
<<generate1>>You move on, keeping to the bushes as much as you can. As you peek around a tree, a pair of arms wrap round you from behind and force you to the ground.<br><br>
<<set $molestationstart to 1>>
[[Next->Park Woman]]
<</nobr>><</widget>>
<<widget "parkex2">><<nobr>>
You hear a growl beside you.<br><br>
<<if $daystate isnot "night">>
There are people about. If you run, you'll be seen.<br><br>
<</if>>
<<if $bestialitydisable is "f">>
<<link [[Run|Park Ex Run]]>><</link>><br>
<<link [[Stay put|Park Ex Dog Molestation]]>><<set $molestationstart to 1>><</link>><br>
<<else>>
<<link [[Run|Park Ex Run]]>><</link>><br>
<</if>>
<</nobr>><</widget>>
:: Widgets Commercial Alleyways Ex [widget]
<<widget "commercialex1">><<nobr>>
<<generate1>><<person1>>You continue on, your heart pounding in your chest. You are peeking around a corner when the door beside you bursts open. A <<person>> carrying a large box rushes through, colliding with you and knocking you both to the ground. <<He>> recovers first, and seizes you by your hair.<br><br>
<<set $molestationstart to 1>>
<<link [[Next->Molestation Commercial]]>><<set $eventskip to 1>><</link>>
<</nobr>><</widget>>
<<widget "commercialex2">><<nobr>>
You are walking down an alley when you hear people up ahead. You turn back the way you came, but hear people coming from that direction as well. You look around for a way to keep your <<lewdness>> concealed, but there's nothing here except some mannequins lined up against a wall.<br><br>
<<link [[Pretend to be a mannequin|Commercial Ex Mannequin]]>><</link>><br>
<<set $rng to random(1,100)>>
<<if $rng gte 61>>
<<link [[Cover yourself and keep walking|Commercial Ex Molestation]]>><<set $molestationstart to 1>><</link>><<gtrauma>><<gstress>><br>
<<else>>
<<link [[Cover yourself and keep walking|Commercial Ex Exhibition]]>><</link>><<gtrauma>><<gstress>><br>
<</if>>
<</nobr>><</widget>>
:: Widgets Residential Alleyways [widget]
<<widget "residentialex1">><<nobr>>
<<generate1>>You continue on, your heart pounding in your chest. You hear voices up ahead so you move into a blind alley and duck behind a dumpster. The voices get quieter and you are about to move when the dumpster yawns open! Before you can react, a pair of arms emerge and drag you inside.<br><br>
<<set $molestationstart to 1>>
[[Next->Molestation Residential]]
<</nobr>><</widget>>
<<widget "residentialex2">><<nobr>>
You continue on, your heart pounding in your chest. You hear voices up ahead, so you move into a blind alley and duck behind a dumpster. The voices get louder, it sounds like a pair of teenagers. They stop at the end of the alley, trapping you. As you look around for an escape route you notice a stray dog looking at your from under a discarded newspaper.<br><br>
It walks over to you, tail wagging, and begins barking. You hope it doesn't attract attention to you.<br><br><<set $timer to 10>>
<<if $bestialitydisable is "f">>
<<link [[Stroke its ears->Residential Dog]]>><<set $phase to 2>><</link>><br>
<</if>>
<<link [[Endure|Residential Dog]]>><<set $phase to 1>><<set $noise += 1>><</link>><br><br>
<</nobr>><</widget>>
:: Molestation Industrial [nobr]
<<if $molestationstart is 1>>
<<set $molestationstart to 0>>
<<controlloss>>
<<violence 1>>
<<neutral 1>>
<<molested>>
<<set $event to "molestationindustrial">>
<<strangeman2init>>
<</if>>
<<effects>>
<<effectsman>><<man>>
<<stateman>><br>
<br>
<<actionsman>>
<<if $alarm is 1>>
<<if $rescue is 1>>
<span id="next"><<link [[Next->Industrial Alarm]]>><</link>></span><<nexttext>>
<<else>>
No one comes to your aid.<<set $alarm to 0>>
<<if $drugged is 1>>Intoxicated as you are, you couldn't cry very convincingly.<</if>><br><br>
<<if $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next->Industrial Ejaculation]]>><</link>></span><<nexttext>>
<<elseif $enemyhealth lte 0>>
<span id="next"><<link [[Next->Industrial Escape]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next->Molestation Industrial]]>><</link>></span><<nexttext>>
<</if>>
<</if>>
<<elseif $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next->Industrial Ejaculation]]>><</link>></span><<nexttext>>
<<elseif $enemyhealth lte 0>>
<span id="next"><<link [[Next->Industrial Escape]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next->Molestation Industrial]]>><</link>></span><<nexttext>>
<</if>>
:: Industrial Alarm
Double-click this passage to edit it.
:: Industrial Ejaculation [nobr]
<<effects>>
<<ejaculation>>
<<if $enemyanger gte ($enemyangermax / 5) * 3>>
<<He>> gives you one last smack to the face, then leaves you lying on the ground.<<violence 3>><br><br>
<<elseif $enemyanger gte 1>>
Without a word, <<he>> gets up and leaves you lying on the ground.<br><br>
<<else>>
Smiling, <<he>> kisses you on the cheek. "This is for you." <<He>> gets up and leaves you lying on the ground.<<set $money += 500>><br>
You've gained £5.<br><br>
<</if>>
<<if $upperoff isnot 0>>
<<uppersteal>>
<</if>>
<<if $loweroff isnot 0>>
<<lowersteal>>
<</if>>
<<if $underoff isnot 0>>
<<understeal>>
<</if>>
<br><br>
<<tearful>> you rise to your feet.<br><br>
<<clotheson>>
<<endcombat>>
<<industrialeventend>>
:: Industrial Escape [nobr]
<<effects>>
<<He>> recoils in pain, giving you the chance you need to escape. <<tearful>> you keep running until your legs give out and you collapse in a heap.<br><br>
<<if $upperoff isnot 0>>
<<uppersteal>>
<</if>>
<<if $loweroff isnot 0>>
<<lowersteal>>
<</if>>
<<if $underoff isnot 0>>
<<understeal>>
<</if>>
<br><br>
<<clotheson>>
<<endcombat>>
<<industrialeventend>>
:: Molestation alley [nobr]
<<if $molestationstart is 1>>
<<set $molestationstart to 0>>
<<controlloss>>
<<violence 1>>
<<neutral 1>>
<<molested>>
<<set $event to "molestationalley">>
<<generate1>><<strangeman2init>><<set $enemyanger += 60>>
You awaken to find yourself being dragged behind a dumpster by a strange <<person1>><<personstop>>
<</if>>
<<effects>>
<<effectsman>><<man>>
<<stateman>><br>
<br>
<<actionsman>>
<<if $alarm is 1>>
<<if $rescue is 1>>
<span id="next"><<link [[Next->Alley Alarm]]>><</link>></span><<nexttext>>
<<else>>
No one comes to your aid.<<set $alarm to 0>>
<<if $drugged is 1>>Intoxicated as you are, you couldn't cry very convincingly.<</if>><br><br>
<<if $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next->Alley Ejaculation]]>><</link>></span><<nexttext>>
<<elseif $enemyhealth lte 0>>
<span id="next"><<link [[Next->Alley Escape]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next->Molestation alley]]>><</link>></span><<nexttext>>
<</if>>
<</if>>
<<elseif $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next->Alley Ejaculation]]>><</link>></span><<nexttext>>
<<elseif $enemyhealth lte 0>>
<span id="next"><<link [[Next->Alley Escape]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next->Molestation alley]]>><</link>></span><<nexttext>>
<</if>>
:: Molestation Commercial [nobr]
<<if $molestationstart is 1>>
<<set $molestationstart to 0>>
<<controlloss>>
<<violence 1>>
<<neutral 1>>
<<molested>>
<<set $event to "molestationcommercial">>
<<strangewoman1init>><<set $enemyanger += 60>><<set $lefthand to "hair">>
<</if>>
<<effects>>
<<effectsman>><<man>>
<<stateman>><br>
<br>
<<actionsman>>
<<if $alarm is 1>>
<<if $rescue is 1>>
<span id="next"><<link [[Next->Commercial Alarm]]>><</link>></span><<nexttext>>
<<else>>
No one comes to your aid.<<set $alarm to 0>>
<<if $drugged is 1>>Intoxicated as you are, you couldn't cry very convincingly.<</if>><br><br>
<<if $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next->Commercial Ejaculation]]>><</link>></span><<nexttext>>
<<elseif $enemyhealth lte 0>>
<span id="next"><<link [[Next->Commercial Escape]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next->Molestation Commercial]]>><</link>></span><<nexttext>>
<</if>>
<</if>>
<<elseif $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next->Commercial Ejaculation]]>><</link>></span><<nexttext>>
<<elseif $enemyhealth lte 0>>
<span id="next"><<link [[Next->Commercial Escape]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next->Molestation Commercial]]>><</link>></span><<nexttext>>
<</if>>
:: Commercial Alarm
Double-click this passage to edit it.
:: Commercial Ejaculation [nobr]
<<effects>>
<<He>> tenses and presses <<his>> mouth against your neck to muffle the sound of <<his>> climax.<br><br>
<<ejaculation>>
<<if $enemyanger gte ($enemyangermax / 5) * 3>>
<<He>> gives you a hard bite then leaves you without a word<<violence 3>><br><br>
<<elseif $enemyanger gte 1>>
Without a word, <<he>> gets up and leaves you lying on the grass.<br><br>
<<else>>
Smiling, <<he>> kisses you on the cheek. "This is for you." <<He>> leaves you lying on the grass.<<set $money += 500>><br>
You've gained £5.<br><br>
<</if>>
<<tearful>> you struggle to your feet.<br><br>
<<clotheson>>
<<endcombat>>
<<commercialeventend>>
:: Commercial Escape [nobr]
<<effects>>
<<He>> recoils in pain, giving you the chance you need to escape. <<tearful>> you run round several corners before hiding behind a crate of fruit. No one follows you.<br><br>
<<if $upperoff isnot 0>>
<<uppersteal>>
<</if>>
<<if $loweroff isnot 0>>
<<lowersteal>>
<</if>>
<<if $underoff isnot 0>>
<<understeal>>
<</if>>
<br><br>
<<clotheson>>
<<endcombat>>
<<commercialeventend>>
:: Molestation Residential [nobr]
<<if $molestationstart is 1>>
<<set $molestationstart to 0>>
<<controlloss>>
<<violence 1>>
<<neutral 1>>
<<molested>>
<<set $event to "molestationresidential">>
<<strangeman2init>>
<</if>>
<<if $phase is 1>><<set $rescue to 1>><</if>>
<<effects>>
<<effectsman>><<man>>
<<stateman>><br>
<br>
<<actionsman>>
<<if $alarm is 1>>
<<if $rescue is 1>>
<span id="next"><<link [[Next->Residential Alarm]]>><</link>></span><<nexttext>>
<<else>>
No one comes to your aid.<<set $alarm to 0>>
<<if $drugged is 1>>Intoxicated as you are, you couldn't cry very convincingly.<</if>><br><br>
<<if $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next->Residential Ejaculation]]>><</link>></span><<nexttext>>
<<elseif $enemyhealth lte 0>>
<span id="next"><<link [[Next->Residential Escape]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next->Molestation Residential]]>><</link>></span><<nexttext>>
<</if>>
<</if>>
<<elseif $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next->Residential Ejaculation]]>><</link>></span><<nexttext>>
<<elseif $enemyhealth lte 0>>
<span id="next"><<link [[Next->Residential Escape]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next->Molestation Residential]]>><</link>></span><<nexttext>>
<</if>>
:: Residential Alarm [nobr]
<<effects>><<set $rescued += 1>>
The dumpster opens fully, someone heard your cry. <<generate2>><<generate3>>A <<person2>><<person>> and <<person3>><<person>> grab your shoulders and haul you out, slamming it shut behind you. <br><br>
<<clothesontowel>>
The <<person1>><<person>> looks concerned. "Good thing we heard you. Are you ok?" <<tearful>> you nod and thank them for the rescue, before parting ways.<br><br>
<<endcombat>>
<<residentialeventend>>
:: Residential Ejaculation [nobr]
<<ejaculation>>
<<if $enemyanger gte ($enemyangermax / 5) * 3>>
<<He>> bashes your head against the side of the dumpster, then drops you outside.<<violence 3>><br><br>
<<elseif $enemyanger gte 1>>
Without a word, <<he>> pushes you outside the dumpster<br><br>
<<else>>
<<He>> kisses you on the cheek, then lifts you out of the dumpster.<br><br>
<</if>>
<<tearful>> you gather yourself.<br><br>
<<if $upperoff isnot 0>>
<<uppersteal>>
<</if>>
<<if $loweroff isnot 0>>
<<lowersteal>>
<</if>>
<<if $underoff isnot 0>>
<<understeal>>
<</if>>
<br><br>
<<clotheson>>
<<endcombat>>
<<residentialeventend>>
:: Residential Escape [nobr]
<<effects>>
<<if $phase is 0>>
<<He>> recoils in pain, giving you the chance you need to escape. You push the lid with all your might, creating an opening. <<He>> recovers before you're able to make good on your escape however, and pulls you back down.<br><br>
<<link [[Next|Molestation Residential]]>><<set $phase to 1>><</link>>
<<set $enemyhealth to $enemyhealthmax>>
<</if>>
<<if $phase is 1>>
<<He>> recoils in pain again. With the dumpster already ajar, you are able to climb out and escape. <<tearful>> you flee around the corner.
<br><br>
<<if $upperoff isnot 0>>
<<uppersteal>>
<</if>>
<<if $loweroff isnot 0>>
<<lowersteal>>
<</if>>
<<if $underoff isnot 0>>
<<understeal>>
<</if>>
<br><br>
<<clotheson>>
<<endcombat>>
<<residentialeventend>>
<</if>>
:: Home Fence [nobr]
<<set $outside to 1>><<effects>>
<<if $stress gte 10000>><<passoutalley>><<else>>
You climb over the fence into the garden behind the orphanage.
<br><br><<link [[Next|Garden]]>><</link>><br>
<</if>>
:: Industrial rooftops [nobr]
<<set $outside to 1>><<set $location to "town">><<effects>>
On are on the rooftop of an industrial building. Plumes of smoke rise all around you. Buildings are closely packed, crossing between them should be no problem.
<br><br>
<<if $stress gte 10000>><<passoutalley>>
<<else>>
<<if $exposed gte 1>><<exhibitionismroof>>
There is an industrial chute leading into the park which would allow you to avoid the road.<br><br>
<<link [[Climb down the ladder (0:02)->Industrial alleyways]]>><<pass 2>><</link>><br>
<<link [[Climb in the chute (0:02)->Chute]]>><<pass 2>><</link>><br><br>
<<else>>
There is an industrial chute leading into the park.<br><br>
<<link [[Climb down the ladder (0:02)->Industrial alleyways]]>><<pass 2>><</link>><br>
<<link [[Climb in the chute (0:02)->Chute]]>><<pass 2>><</link>><br><br>
<</if>>
<</if>>
:: Chute [nobr]
<<set $outside to 0>><<effects>>
You slide down the chute to the park.<br>
<<if $upperclothes is "naked" and $lowerclothes is "naked" and $underclothes is "naked">>
<<else>>
Your clothing snags on a rut.<br><br>
<<set $upperintegrity -= 20>>
<<set $lowerintegrity -= 20>>
<<set $underintegrity -= 20>>
<br><br>
<</if>>
<<set $danger to random(1, 10000)>><<set $dangerchute to 0>>
<<if $danger gte (9900 - ($allure * 3))>><<set $dangerchute to random(1)>>
<</if>>
<<if $dangerchute is 1>>
As the chute exit comes into view you see someone has left a cement mixer in front of it!<br><br>
<<link [[Dodge it at any cost!|Molestation Chute]]>><<set $molestationstart to 1>><</link>><br>
<<link [[Brace for impact|Cement Mixer]]>><</link>><br><br>
<<else>>
<<parkquick>>
<</if>>
<<set $dangerchute to 0>>
:: Molestation Chute [nobr]
<<if $molestationstart is 1>>
<<set $molestationstart to 0>>
<<controlloss>>
<<violence 1>>
<<neutral 1>>
<<molested>>
<<set $event to "molestationchute">>
<<generate1>><<spankmaninit>>
<<person1>>You avoid landing in the mixer, but collide with the edge and knock it over. It shatters against the ground.<br><br>
As you try to recover, a <<person>> storms over. "I'll show you what happens when you break things that aren't yours!" <<He>> grabs you by the arms, hauls you over to a chair and bends you over <<his>> lap.<br><br>
<</if>>
<<effects>>
<<effectsman>><<man>>
<<stateman>><br>
<br>
<<actionsman>>
<<if $enemyanger lte 0>>
<span id="next"><<link [[Next->Chute Done]]>><</link>></span><<nexttext>>
<<elseif $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next->Chute Ejaculation]]>><</link>></span><<nexttext>>
<<elseif $enemyhealth lte 0>>
<span id="next"><<link [[Next->Chute Escape]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next->Molestation Chute]]>><</link>></span><<nexttext>>
<</if>>
:: Cement Mixer [nobr]
<<set $outside to 1>><<effects>>
You curl up and slam into the mixer. Fortunately, the cement cushions your blow. Unfortunately, it's cement. You manage to struggle free,
<<if $underclothes is "naked" and $lowerclothes is "naked" and $upperclothes is "naked">>
stumbling away without attractive notice.<br><br>
<<else>>
but lose your clothes in the process.<br><br>
<<underruined>>
<<lowerruined>>
<<upperruined>>
<</if>>
<<parkquick>>
:: Chute Done [nobr]
<<effects>>
"I think you've had enough." <<He>> releases you and you slip to the ground in a heap.<br><br>
<<He>> leaves you to sob.<br><br>
<<clotheson>>
<<endcombat>>
<<parkquick>>
:: Chute Ejaculation [nobr]
<<ejaculation>>
<<if $enemyanger gte ($enemyangermax / 5) * 3>>
<<He>> gives you one last spank, then leaves you lying on the ground.<<violence 3>><br><br>
<<elseif $enemyanger gte 20>>
Without a word, <<he>> gets up and leaves you lying on the ground.<br><br>
<<else>>
"I think you've learnt your lesson." <<He>> gets up and leaves you lying on the ground.<br><br>
<</if>>
<<tearful>> you rise to your feet.<br><br>
<<clotheson>>
<<endcombat>>
<<parkquick>>
:: Chute Escape [nobr]
<<effects>>
<<He>> recoils in pain. You take the opportunity to squirm free and bolt away. <<tearful>> you run into an area dense with foliage.<br><br>
<<if $upperoff isnot 0>>
<<uppersteal>>
<</if>>
<<if $loweroff isnot 0>>
<<lowersteal>>
<</if>>
<<if $underoff isnot 0>>
<<understeal>>
<</if>>
<br><br>
<<clotheson>>
<<endcombat>>
<<parkquick>>
:: Commercial rooftops [nobr]
<<set $outside to 1>><<set $location to "town">><<effects>>
You are on the rooftop of a commercial building. You can access the shopping centre from here. Buildings are closely packed, crossing between them should be no problem.
<br><br>
<<if $stress gte 10000>><<passoutalley>>
<<else>>
<<if $exposed gte 1>><<exhibitionismroof>>
<br><br>
<<link [[Climb down the ladder (0:02)->Commercial alleyways]]>><<pass 2>><</link>><br>
<<link [[Shopping centre (0:02)->Shopping Centre Top]]>><<pass 2>><</link>><br><br>
<<else>>
<br><br>
<<link [[Climb down the ladder (0:02)->Commercial alleyways]]>><<pass 2>><</link>><br>
<<link [[Shopping centre (0:02)->Shopping Centre Top]]>><<pass 2>><</link>><br><br>
<</if>>
<</if>>
:: Alley Alarm
Double-click this passage to edit it.
:: Alley Ejaculation [nobr]
<<effects>>
<<ejaculation>>
<<if $enemyanger gte ($enemyangermax / 5) * 3>>
<<He>> gives you one last smack to the face, then leaves you lying on the hard concrete.<<violence 3>><br><br>
<<elseif $enemyanger gte 1>>
Without a word, <<he>> gets up and leaves you lying on the hard concrete.<br><br>
<<else>>
Smiling, <<he>> kisses you on the cheek. "This is for you." <<He>> gets up and leaves you lying on the hard concrete.<<set $money += 500>><br>
You've gained £5.<br><br>
<</if>>
<<if $underoff isnot 0>>
<<understeal>>
<</if>>
<<tearful>> you rise to your feet.<br><br>
<<clotheson>>
<<endcombat>>
<<set $stress -= 1000>><<set $eventskip to 1>>
<<destination>>
:: Alley Escape [nobr]
<<effects>>
<<He>> falls to the ground, giving you the chance you need to escape. <<tearful>> you run round a few bends and take cover in a shadowed alcove.<br><br>
<<if $upperoff isnot 0>>
<<uppersteal>>
<</if>>
<<if $loweroff isnot 0>>
<<lowersteal>>
<</if>>
<<if $underoff isnot 0>>
<<understeal>>
<</if>>
<br><br>
<<clotheson>>
<<endcombat>>
<<set $stress -= 1000>><<set $eventskip to 1>>
<<destination>>
:: Residential Dog [nobr]
<<effects>>
<<if $noise is 2 and $combat is 0>>
<span class="red">The youths are wondering aloud why the dog is so agitated. They'll find you soon if you don't do something!</span><br><br>
<</if>>
<<if $timer is 1 and $combat is 0>>
You hear the youths move away from the alley. You take a peek and see that they are indeed gone. The dog looks dejected as you walk away.<br><br><<endevent>>
<<residentialeventend>><br><br>
<<elseif $timer is 1 and $combat is 1>>
You hear the youths move away from the alley. You try to take a peek but the dog tackles you to the ground.<br><br><<set $rescue to 0>>
<span id="next"><<link [[Next|Residential Dog]]>><</link>></span><<nexttext>><br><br>
<<elseif $noise gte 3>>
Fed up with the racket, the pair make their way over.<br><br>
<span id="next"><<link [[Next|Residential Dog Alarm]]>><</link>></span><<nexttext>>
<<elseif $phase is 1>>
It continues barking. You're afraid the youths will investigate if this continues.<br><br>
<<link [[Quietly tell it to shut up|Residential Dog]]>><<set $noise += 1>><</link>><br>
<<if $bestialitydisable is "f">>
<<link [[Stroke its head->Residential Dog]]>><<set $phase to 2>><</link>><br><br>
<</if>>
<<elseif $phase is 2>>
It quiets at your touch, runs in a small circle, then walks right up to you. You notice its penis is erect and ready. It looks at you expectantly.<br><br>
<<link [[Just keep stroking its head->Residential Dog]]>><<set $noise += 1>><<set $phase to 3>><</link>><br>
<span class="sub"><<link [[Grab its penis|Residential Dog]]>><<handskilluse>><<handstat>><<set $phase to 4>><</link>><br><br></span>
<<elseif $phase is 3>>
You continue to stroke its head, but it doesn't seem pleased and barks again.<br><br>
<<link [[Just keep stroking its head->Residential Dog]]>><<set $noise += 1>><<set $phase to 3>><</link>><br>
<<link [[Grab its penis|Residential Dog]]>><<set $phase to 4>><<handskilluse>><<handstat>><</link>><br><br>
<<elseif $phase is 4>><<set $molestationstart to 1>><<set $phase to 5>>
You take its penis in your hand. It starts humping against your fingers.<br><br>
<span id="next"><<link [[Next|Residential Dog]]>><</link>></span><<nexttext>><br><br>
<<elseif $phase is 5>>
<<if $molestationstart is 1>>
<<set $molestationstart to 0>>
<<controlloss>>
<<violence 1>>
<<neutral 1>>
<<molested>>
<<set $event to "residentialdog">>
<<dog1init>><<set $beasttype to "dog">><<set $leftarm to "penis">>
<<set $penis to "leftarm">>
<</if>>
<<if $timer gte 1>><<set $rescue to 1>><</if>>
<<effectsman>><br><<beast>><br><br>
<<stateman>><br>
<br>
<<actionsman>>
<<if $alarm is 1>>
<<if $rescue is 1>>
<span id="next"><<link [[Next->Residential Dog Alarm]]>><</link>></span><<nexttext>>
<<else>>
No one comes to your aid.<<set $alarm to 0>>
<<if $drugged is 1>>Intoxicated as you are, you couldn't cry very convincingly.<</if>><br><br>
<<if $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next->Residential Dog Ejaculation]]>><</link>></span><<nexttext>>
<elseif $enemyhealth lte 0>>
<span id="next"><<link [[Next->Residential Dog Escape]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next->Residential Dog]]>><</link>></span><<nexttext>>
<</if>>
<</if>>
<<elseif $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next->Residential Dog Ejaculation]]>><</link>></span><<nexttext>>
<<elseif $enemyhealth lte 0>>
<span id="next"><<link [[Next->Residential Dog Escape]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next->Residential Dog]]>><</link>></span><<nexttext>>
<</if>>
<</if>>
:: Residential Dog Alarm [nobr]
<<effects>>
<<if $alarm is 1>>
Your scream alerts the pair.<br><br>
<</if>>
At the sound of their approach, the dog ceases its adventure and bounds away.<br><br>
<<endcombat>>
<<generatey1>><<generatey2>>Before you can recover, you are discovered by a <<person1>><<person>> and a <<person2>><<personstop>><br><br>
<<set $danger to random(1, 10000)>><<set $dangerstreet to 0>>
<<if $danger gte (9900 - ($allure * 3))>><<set $dangerstreet to random(1, 100)>>
They take advantage of your vulnerability.<br><br><<set $molestationstart to 1>>
[[Next|Residential Pair]]
<<else>>
Seeing you in distress, the <<person1>><<person>> and <<person2>><<person>> help you to your feet.<br><br>
<<set $rescued += 1>>
<<clothesontowel>>
The <<person1>><<person>> looks concerned. "Are you ok?" <<tearful>> you nod and thank them for their concern, before parting ways.<br><br><br><br>
<<ambulance>>
<</if>>
:: Residential Dog Ejaculation [nobr]
<<beastejaculation>>
<<if $enemyanger gte ($enemyangermax / 5) * 3>>
<<He>> bites you on the thigh, then leaves you lying on the ground.<<violence 3>><br><br>
<<elseif $enemyanger gte 1>>
<<He>> barks then leaves you lying on the ground.<br><br>
<<else>>
<<He>> licks your <<genitals>> then darts away.<<neutral 5>><br><br>
<</if>>
<<if $timer gte 1>>The youths leave shortly after.<br><br><</if>>
<<tearful>> you rise to your feet.<br><br>
<<clotheson>>
<<endcombat>>
<<residentialeventend>>
:: Residential Dog Escape [nobr]
<<effects>>
Finally taking the hint, <<he>> whimpers and flees the alley.
<<if $timer gte 1>>After a short while the youths also leave.<</if>> <<tearful>> you rise to your feet.<br><br>
<<clotheson>>
<<endcombat>>
<<residentialeventend>>
:: Widgets Residential [widget]
<<widget "residential">><<nobr>>
<<link [[Residential alleyways (0:05)|Residential alleyways]]>><<pass 5>><</link>>
<</nobr>><</widget>>
<<widget "residentialquick">><<nobr>>
<<link [[Residential alleyways|Residential alleyways]]>><</link>>
<</nobr>><</widget>>
<<widget "residentialeventend">><<nobr>>
<<link [[Next|Residential alleyways]]>><<set $eventskip to 1>><</link>>
<</nobr>><</widget>>
:: Widgets Industrial [widget]
<<widget "industrial">><<nobr>>
<<link [[Industrial alleyways (0:05)|Industrial alleyways]]>><<pass 5>><</link>>
<</nobr>><</widget>>
<<widget "industrialquick">><<nobr>>
<<link [[Industrial alleyways|Industrial alleyways]]>><</link>>
<</nobr>><</widget>>
<<widget "industrialeventend">><<nobr>>
<<link [[Next|Industrial alleyways]]>><<set $eventskip to 1>><</link>>
<</nobr>><</widget>>
:: Widgets Commercial [widget]
<<widget "commercial">><<nobr>>
<<link [[Commercial alleyways (0:05)|Commercial alleyways]]>><<pass 5>><</link>>
<</nobr>><</widget>>
<<widget "commercialquick">><<nobr>>
<<link [[Commercial alleyways|Commercial alleyways]]>><</link>>
<</nobr>><</widget>>
<<widget "commercialeventend">><<nobr>>
<<link [[Next|Commercial alleyways]]>><<set $eventskip to 1>><</link>>
<</nobr>><</widget>>
:: Residential Pair [nobr]
<<if $molestationstart is 1>>
<<set $molestationstart to 0>>
<<controlloss>>
<<violence 1>>
<<neutral 1>>
<<molested>>
<<set $event to "molestationindustrial">>
<<man2init>>
<</if>>
<<effects>>
<<effectsman>><<man>>
<<stateman>><br>
<br>
<<actionsman>>
<<if $alarm is 1>>
<<if $rescue is 1>>
<<else>>
No one comes to your aid.<<set $alarm to 0>>
<<if $drugged is 1>>Intoxicated as you are, you couldn't cry very convincingly.<</if>><br><br>
<<if $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next->Residential Pair Ejaculation]]>><</link>></span><<nexttext>>
<<elseif $enemyhealth lte 0>>
<span id="next"><<link [[Next->Residential Pair Escape]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next->Residential Pair]]>><</link>></span><<nexttext>>
<</if>>
<</if>>
<<elseif $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next->Residential Pair Ejaculation]]>><</link>></span><<nexttext>>
<<elseif $enemyhealth lte 0>>
<span id="next"><<link [[Next->Residential Pair Escape]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next->Residential Pair]]>><</link>></span><<nexttext>>
<</if>>
:: Residential Pair Ejaculation [nobr]
<<effects>>
<<ejaculation>>
<<if $enemyanger gte ($enemyangermax / 5) * 3>>
They bash your head against the pavement, then leave you.<<violence 3>><br><br>
<<elseif $enemyanger gte 1>>
Without a word, they saunter off.<br><br>
<<else>>
<<person2>>The <<person>> kisses you on the cheek, they then saunter off.<br><br>
<</if>>
<<understeal>>
<<tearful>> you rise to your feet.<br><br>
<<clotheson>>
<<endcombat>>
<<destinationeventend>>
:: Residential Pair Escape [nobr]
<<effects>>
The <<person1>><<person>> recoils in pain, giving you the chance you need to escape. <<tearful>> you keep running until your legs give out and you collapse against a wall.<br><br>
<<if $upperoff isnot 0>>
<<uppersteal>>
<</if>>
<<if $loweroff isnot 0>>
<<lowersteal>>
<</if>>
<<if $underoff isnot 0>>
<<understeal>>
<</if>>
<br><br>
<<clotheson>>
<<endcombat>>
<<destinationeventend>>
|
QuiltedQuail/degrees
|
game/loc-alley.twee
|
twee
|
unknown
| 37,575 |
:: Beach [nobr]
<<set $outside to 1>><<set $location to "beach">><<effects>>
You are on the beach.
<<if $daystate is "day">>
<<if $weather is "clear">>
It is awash with visitors, children build sandcastles and play in the water while their parents bask in the sun. A group of teenagers are playing volleyball.
<<elseif $weather is "overcast">>
The clouds have driven away most would-be visitors, but there are still people strolling along the water's edge.
<<elseif $weather is "rain">>
The beach itself is mostly deserted due to the rain, but the violent waves have attracted surfers.
<</if>>
<<elseif $daystate is "dawn">>
<<if $weather is "clear">>
It is a popular destination for joggers, some have dogs with them. A few families are setting up windbreakers. A group of teenagers are playing volleyball.
<<elseif $weather is "overcast">>
It is a popular destination for joggers, some have dogs with them. Fog blocks your view of the ocean.
<<elseif $weather is "rain">>
The beach itself is mostly deserted due to the rain, but the violent waves have attracted surfers.
<</if>>
<<elseif $daystate is "dusk">>
<<if $weather is "clear">>
Families are leaving as the sun sets. A group of teenagers are playing volleyball.
<<elseif $weather is "overcast">>
It is mostly deserted, but some people are strolling along the water's edge.
<<elseif $weather is "rain">>
The beach itself is mostly deserted due to the rain, but the violent waves have attracted surfers.
<</if>>
<<elseif $daystate is "night">>
<<if $weather is "clear">>
It appears deserted, save for a group of teenagers who are drinking around a fire.
<<elseif $weather is "overcast">>
It appears deserted.
<<elseif $weather is "rain">>
It appears deserted.
<</if>>
<</if>>
You could go for a swim, but make sure to dress appropriately.
<br><br>
<<if $exposed gte 1>>
<<exhibitionismbeach>>
<</if>>
<<if $arousal gte 10000>>
<<orgasmbeach>>
<</if>>
<<if $stress gte 10000>><<passoutbeach>>
<<else>>
<<set $danger to random(1, 10000)>><<set $dangerevent to 0>>
<<if $danger gte (9900 - $allure) and $eventskip is 0>>
<<eventsbeach>>
<<else>>
<<if $exposed lte 0>>
<<if $scienceproject is "ongoing" and $sciencephallusknown is 1 and $sciencephallus lt 10 and $daystate isnot "night" and $weather isnot "rain" and $exposed lte 0>>
<<link [[Find participant for phallus project (0:15)|Beach Phallus]]>><<pass 15>><</link>><br>
<</if>>
<<link [[Go for a swim (0:02)|Sea Beach]]>><<pass 2>><</link>><br>
<</if>>
<<link [[Changing Room|Changing Room]]>><</link>><br>
<<if $exposed lte 0>>
<<if $robinintro is 1 and $robinmissing isnot 1 and $robintrauma lt 80>>
<<if $weekday is 7 and $hour gte 9 and $hour lte 16 or $weekday is 1 and $hour gte 9 and $hour lte 16>>
<<link [[Robin's Lemonade Stand|Robin's Lemonade]]>><</link>><br>
<</if>>
<</if>>
<<link [[Go for a run (0:30)|Beach Run]]>><</link>><<gtiredness>><<lstress>><br><</if>>
<<if $weather is "clear" and $daystate is "night" and $exposed lte 0>><<link [[Party|Beach Party]]>><</link>><br><</if>>
<<if $weather is "clear" and $daystate isnot "night" and $exposed lte 0>>
<<link [[Volleyball|Beach Volleyball]]>><</link>><br>
<<if $exhibitionism gte 75 and $beachstrip isnot 1>>
<<link [[Strip (0:20)|Beach Strip]]>><<pass 20>><</link>><<exhibitionist5>><br>
<</if>>
<</if>>
<br>
Travel<br>
<<if $exposed lte 0>><<cliff>><br><</if>>
<<if $exposed lte 0>><<starfish>><br><</if>>
<br>
<</if>>
<</if>>
<<set $eventskip to 0>>
:: Widgets Beach [widget]
<<widget "beachday1">><<nobr>>
<<generatey1>>You hear someone behind you. You turn just in time to see a <<person1>><<person>> rushing into you. <<He>> tackles you to the sand and tries to remove your clothes!<br><br>
<<link [[Next|Beach Day Molestation]]>><<set $molestationstart to 1>><<set $eventskip to 1>><</link>>
<</nobr>><</widget>>
<<widget "beachday2">><<nobr>>
You feel something yanking at your $lowerclothes. Looking over your shoulder, you see a small dog with your clothes between it's teeth.<<set $lowerintegrity -= 20>>
<<if $lowerintegrity lte 0>>
You try to wrestle your clothes free from its maw, but your $lowerclothes <<lowerplural>> torn from your body!
<<if $undertype is "naked">>
The dog scampers away, leaving you humiliated with your <<genitals>> on display.<<gtrauma>><<trauma 1>><<stress 1>><<gstress>>
<<else>>
The dog scampers away, leaving you humiliated with your $underclothes on display.<<stress 1>><<gstress>>
<</if>>
<<lowerruined>><<set $trauma += 10>>
<<else>>
You manage to wrestle your clothes free from its maw, though the ordeal has left them a little worse for wear.
<</if>>
<br><br>
<<link [[Next|Beach]]>><<set $eventskip to 1>><</link>>
<</nobr>><</widget>>
<<widget "beachday3">><<nobr>>
<<generate1>>You see a <<person1>><<person>> watching you. <<He>> seems to be here with <<his>> kids who are playing in the sand some way away. <<He>> looks away as you make eye contact.<br><br>
<<link [[Look away|Beach]]>><<set $eventskip to 1>><<endevent>><</link>><br>
<<link [[Approach|Beach Day Encounter]]>><</link>><br>
<</nobr>><</widget>>
<<widget "beachday4">><<nobr>>
A gust of wind blows in from the ocean, pleasantly caressing your skin. <<lstress>><<stress -2>><br><br>
<<if $skirt is 1>>
It flares up your skirt, laying bare your
<<if $undertype isnot "naked">>
$underclothes for anyone to see.<<garousal>><<arousal 1>>
<<else>>
<<genitals>>for anyone to see.<<garousal>><<gtrauma>><<arousal 1>><<trauma 1>>
<</if>>
<br><br>
You hasten to cover yourself, blushing.<br><br>
<</if>>
<<link [[Next|Beach]]>><<set $eventskip to 1>><</link>>
<</nobr>><</widget>>
<<widget "beachnight1">><<nobr>>
A wild-looking dog emerges from the darkness, teeth bared and eyes alight with hunger.<br><br>
<<if $bestialitydisable is "f">>
<<link [[Next|Beach Night Dog]]>><<set $eventskip to 1>><<set $molestationstart to 1>><</link>>
<<else>>
You manage to escape, but not unscathed.<<beastescape>><br><br>
<<link [[Next|Beach]]>><<set $eventskip to 1>><</link>>
<</if>>
<</nobr>><</widget>>
<<widget "beachnight2">><<nobr>>
<<generate1>>It's so dark, you don't see the <<person1>><<person>> lying on the sand until <<he>> grasps you by the ankle and pulls you to the ground.<br><br>
<<link [[Next|Beach Night Molestation]]>><<set $molestationstart to 1>><</link>>
<</nobr>><</widget>>
<<widget "beachex1">><<nobr>>
<<generatey1>>A <<person1>><<person>> spots you in your fragile state and calls out, <<lewdcatcall>> Other heads turn in response and you quickly find yourself the centre of attention.
<<if $panicattacks gte 1>>
You are overcome by anxiety. Robbed of higher thought, you can do nothing flee away from the crowds, chased by jeering laughter.<<fameexhibitionism 50>><<gstress>><<gtrauma>><<stress 12>><<trauma 6>><br><br>
When your fear subsides you find yourself slumped against the inside wall of a changing room.<br><br>
<<link [[Changing Room|Changing Room]]>><<endevent>><</link>>
<<else>>
<<gstress>><<gtrauma>><<stress 12>><<trauma 6>><br><br>
<<link [[Keep walking|Beach Exhibition]]>><</link>><br>
<<link [[Ask for help|Beach Exhibition]]>><<set $phase to 1>><</link>>
<</if>>
<</nobr>><</widget>>
<<widget "beachex2">><<nobr>>
<<generatey1>>A <<person1>><<person>> spots you in your fragile state and calls out to <<his>> friends. You quickly find yourself surrounded. The <<person>> speaks, "You know this isn't a nudist beach right? Infact, I think I should report you." You tense as <<he>> visibly inhales as if to shout, anticipating even more attention drawn to your predicament. Instead however, <<he>> and <<his>> friends burst into derisive laughter. "Or, you know, I could help you out, give you something to cover up with. Of course, I'll want something in return. Get on your knees."<<fameexhibitionism 20>><br><br>
<<if $promiscuity gte 35>>
<<link [[Comply|Beach Exhibit Molestation]]>><<set $phase to 1>><<set $sexstart to 1>><</link>><br>
<</if>>
<<link [[Refuse|Beach Exhibit Molestation]]>><<set $phase to 0>><<set $molestationstart to 1>><</link>><br>
<</nobr>><</widget>>
:: Beach Party [nobr]
<<set $outside to 1>><<set $location to "beach">><<effects>>
You approach the teenagers. Several are dancing near a fire on a makeshift stage while others are drinking and chattering.<br><br>
<<link [[Socialise (0:10)|Beach Party Chat]]>><<pass 10>><<stress -2>><<status 1>><<set $phase to 0>><</link>><<gcool>><<lstress>><br>
<<link [[Dance (0:05)|Beach Party Dance]]>><<set $dancing to 1>><<set $venuemod to 1>><<stress -4>><<tiredness 4>><</link>><<lstress>><<gtiredness>><br>
<br>
<<link [[Leave|Beach]]>><</link>>
:: Beach Volleyball [nobr]
<<set $outside to 1>><<set $location to "beach">><<effects>>
<<generatey1>><<generatey2>><<generatey3>><<generatey4>><<generatey5>>
You approach a group playing volleyball. A <<person1>><<person>> sits on the sand and watches four of <<his>> friends play.<br><br>
<<link [[Join In (0:30)|Beach Volleyball Play]]>><<pass 30>><<stress -6>><<tiredness 6>><<status 1>><</link>><<gcool>><<lstress>><<gtiredness>><br>
<<link [[Leave|Beach]]>><<endevent>><</link>>
:: Beach Volleyball Play [nobr]
<<set $outside to 1>><<set $location to "beach">><<effects>>
The teenagers are happy to have a sixth player, particularly the <<person1>><<personstop>><br><br>
<<physique 3>>
<<set $eventcheck to random(1, 10000)>>
<<if $eventcheck gte (9900 - ($allure))>>
<<if $rng gte 51>><<molested>>
You are so focused on the opposing team you do not notice one of your own sneak up on you. A pair of hands grasp the rim of your $lowerclothes.
<<if $skirt is 0 and $lowerset isnot $upperset>>
Before you can react, the <<person1>><<person>> has pulled them all the way to your knees,
<<elseif $skirt is 0 and $lowerset is $upperset>>
Before you can react, the <<person1>><<person>> has pulled it aside,
<<else>>
Before you can react, the <<person1>><<person>> has lifted it,
<</if>>
<<if $underclothes is "naked">>
exposing your <<genitals>> for all to see. Laughter and lewd gestures erupt from both teams as your face turns red and you hasten to protect your dignity.<<garousal>><<gstress>><<gtrauma>><<arousal 3>><<stress 6>><<set $trauma += 3>>
<<else>>
exposing your $underclothes. Laughter erupts from both teams and you hasten to protect your dignity.<<lcool>><<status -10>><<garousal>><<gstress>><<gtrauma>><<arousal 1>><<stress 2>><<set $trauma += 1>>
<</if>>
<br><br>
<<else>>
Part-way through the match the ball collides with your chest, sending you sprawling. <<set $upperintegrity -= 1>>It's embarrassing, but you soon dust yourself off.<br><br>
<</if>>
<<else>>
You have a good time.<br><br>
<</if>>
<<if $daystate is "night">>
With the sun fully set, continuing to play would be difficult. The <<person1>><<person>> tells you they are going to a beach party and invites you to come along. <br><br>
<<link [[Accept (0:10)|Beach Party Chat]]>><<pass 10>><<endevent>><<lstress>><<status 1>><</link>><<gcool>><<lstress>><br>
<<link [[Make excuses and say your goodbyes|Beach]]>><<endevent>><</link>><br>
<br>
<<else>>
<<link [[Play more (0:30)|Beach Volleyball Play]]>><<pass 30>><<stress -6>><<tiredness 6>><<status 1>><</link>><<gcool>><<lstress>><<gtiredness>><br>
<<link [[Stop|Beach]]>><<endevent>><</link>><br>
<br>
<</if>>
:: Beach Party Chat [nobr]
<<set $outside to 1>><<set $location to "beach">><<effects>>
<<if $phase is 0>>
You join the conversation.
<<if $allure gte 3000>>
You quickly become the centre of attention.
<<elseif $allure gte 2000>>
You draw eyes your way with ease.
<<elseif $allure gte 1000>>
People acknowledge you when you speak, but otherwise leave you alone.
<<else>>
Dour as you are, people constantly talk over you, as if unaware of your presence.
<</if>>
<<if $daystate isnot "night">>
The sun rises on the horizon and the remaining teenagers head home.<br><br>
<<link [[Next|Beach]]>><<endevent>><</link>><br>
<<else>>
<br><br>
<<set $eventcheck to random(1, 10000)>>
<<if $eventcheck gte (9900 - ($allure))>>
<<generatey1>><<person1>>A <<person>> sits next to you and offers you a beverage.<br><br>
<<link [[Drink (0:10)|Beach Party Chat]]>><<pass 10>><<stress -2>><<set $drunk += 60>><<set $phase to 1>><<status 1>><</link>><<gcool>><<lstress>><br>
<<link [[Just talk (0:10)|Beach Party Chat]]>><<pass 10>><<stress -2>><<set $phase to 1>><<status 1>><</link>><<gcool>><<lstress>><br>
<<link [[Leave|Beach]]>><<endevent>><</link>><br>
<br>
<<else>>
<<link [[Continue (0:10)|Beach Party Chat]]>><<pass 10>><<stress -2>><<status 1>><</link>><<gcool>><<lstress>><br>
<<link [[Leave|Beach]]>><<endevent>><</link>><br>
<br>
<</if>>
<</if>>
<<elseif $phase is 1>>
<<if $rng gte 21>>
You enjoy talking with the <<personstop>> <<He>> <<admires>> your body when <<he>> thinks you aren't looking.<br><br>
<<link [[Drink (0:10)|Beach Party Chat]]>><<pass 10>><<stress -2>><<set $drunk += 60>><<set $phase to 1>><<status 1>><</link>><<gcool>><<lstress>><br>
<<link [[Just talk (0:10)|Beach Party Chat]]>><<pass 10>><<stress -2>><<set $phase to 1>><<status 1>><</link>><<gcool>><<lstress>><br>
<<link [[Leave|Beach]]>><<endevent>><</link>><br>
<br>
<<else>>
You enjoy talking with the <<personstop>> <<He>> leans close and whispers, "Would you like to go somewhere private?"<br><br>
<<link [[Yes|Beach Party Sex]]>><<set $phase to 0>><<set $sexstart to 1>><</link>><<promiscuous1>><br>
<<link [[No|Beach Party Chat]]>><<set $phase to 2>><<status 1>><</link>><<gcool>><br>
<br>
<</if>>
<<elseif $phase is 2>>
<<if $rng gte 11>><<set $phase to 0>>
<<He>> is disappointed, but politely says goodbye before leaving to look elsewhere.<br><br>
<<link [[Continue (0:10)|Beach Party Chat]]>><<pass 10>><<stress -2>><<status 1>><<endevent>><</link>><<gcool>><<lstress>><br>
<<link [[Leave|Beach]]>><<endevent>><</link>><br>
<br>
<<else>>
<<He>> seizes you by the throat, "Well, that isn't very polite of you. I think you need a lesson." <<He>> stands you up and starts forcing you away from the rest of the group.<br><br>
<<link [[Continue|Beach Party Rape]]>><<set $molestationstart to 1>><<set $timer to 10>><</link>><br>
<br>
<</if>>
<</if>>
:: Beach Party Dance [nobr]
<<set $outside to 1>><<set $location to "beach">><<effects>>
<<danceeffects>>
<<danceaudience>>
<<danceactions>>
<<if $danceevent is 0 and $exhibitionism lte 74 and $exposed gte 2>>
There's no way you can continue dancing while so exposed! Face reddening, you flee the scene.<br><br>
<<elseif $danceevent is 0 and $exhibitionism lte 34 and $exposed gte 1>>
There's no way you can continue dancing while so exposed! Face reddening, you flee the scene.<br><br>
<</if>>
<<if $danceevent is "rape">>
<<link [[Next|Beach Party Dance Rape]]>><<set $molestationstart to 1>><</link>>
<<elseif $danceevent is "finish">>
<<link [[Next|Beach Party]]>><<clotheson>><<endevent>><</link>>
<<elseif $danceevent is 0>>
<<if $exposed gte 2 and $exhibitionism lte 74>>
<<link [[Flee|Changing Room]]>><<clotheson>><<endevent>><</link>>
<<elseif $exposed gte 1 and $exhibitionism lte 34>>
<<link [[Flee|Changing Room]]>><<clotheson>><<endevent>><</link>>
<<else>>
<<link [[Stop|Beach Party]]>><<clotheson>><<endevent>><</link>>
<</if>>
<</if>>
:: Beach Party Sex [nobr]
<<if $sexstart is 1>>
<<set $sexstart to 0>>
<<consensual>>
<<promiscuity1>>
<<set $consensual to 1>>
<<neutral 1>>
<<set $event to "molestationhome">>
<<man1init>>
<<set $enemytrust += 100>>
<<He>> quietly takes your hand and leads you away from the group. You walk into the dunes until you're out of earshot, then <<he>> turns and embraces you.<br><br>
<</if>>
<<effects>><<set $outside to 1>><<set $location to "beach">>
<<effectsman>><<man>>
<<stateman>><br>
<br>
<<actionsman>>
<<if $finish is 1>>
<span id="next"><<link [[Next->Beach Party Sex Finish]]>><</link>></span><<nexttext>>
<<else>>
<<if $alarm is 1>>
<<if $rescue is 1>>
<<else>>
No one comes to your aid.<<set $alarm to 0>>
<<if $drugged is 1>>Intoxicated as you are, you couldn't cry very convincingly.<</if>><br><br>
<<if $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next->Beach Party Sex Ejaculation]]>><</link>></span><<nexttext>>
<<elseif $enemyhealth lte 0>>
<span id="next"><<link [[Next->Beach Party Sex Escape]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next->Beach Party Sex]]>><</link>></span><<nexttext>>
<</if>>
<</if>>
<<elseif $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next->Beach Party Sex Ejaculation]]>><</link>></span><<nexttext>>
<<elseif $enemyhealth lte 0>>
<span id="next"><<link [[Next->Beach Party Sex Escape]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next->Beach Party Sex]]>><</link>></span><<nexttext>>
<</if>>
<</if>>
:: Beach Party Rape [nobr]
<<if $molestationstart is 1>>
<<set $molestationstart to 0>>
<<controlloss>>
<<violence 1>>
<<neutral 1>>
<<molested>>
<<set $event to "molestationhome">>
<<man1init>>
<<set $rescue to 1>>
<<set $lefthand to "mouth">>
<<set $mouthuse to "lefthand">>
<<set $righthand to "arms">>
<<set $leftarm to "grappled">>
<<set $rightarm to "grappled">>
<</if>>
<<effects>>
<<if $timer is 0 and $rescue is 1>>
<<set $rescue to 0>>
You walk behind a dune. You're too far for anyone to help you.
<<elseif $timer gte 1>>
You are pulled further from the group, but they're still in sight.
<<else>>
<</if>><br><br>
<<effectsman>><<man>>
<<stateman>><br>
<br>
<<actionsman>>
<<if $alarm is 1>>
<<if $rescue is 1>>
<span id="next"><<link [[Next->Beach Party Rape Alarm]]>><</link>></span><<nexttext>>
<<else>>
No one comes to your aid.<<set $alarm to 0>>
<<if $drugged is 1>>The drugs inhibit you, you couldn't cry very loudly.<</if>><br><br>
<<if $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next->Beach Party Rape Ejaculation]]>><</link>></span><<nexttext>>
<<elseif $enemyhealth lte 0>>
<span id="next"><<link [[Next->Beach Party Rape Escape]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next->Beach Party Rape]]>><</link>></span><<nexttext>>
<</if>>
<</if>>
<<elseif $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next->Beach Party Rape Ejaculation]]>><</link>></span><<nexttext>>
<<elseif $enemyhealth lte 0>>
<span id="next"><<link [[Next->Beach Party Rape Escape]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next->Beach Party Rape]]>><</link>></span><<nexttext>>
<</if>>
:: Beach Party Rape Alarm [nobr]
<<effects>><<set $rescued += 1>>
<<He>> notices several heads turning in response to your cry. <<He>> looks at you with anger and shouts, "Crazy Slut!" before heading back to <<his>> friends. <<tearful>> you gather yourself.<br><br>
<<clotheson>>
<<endcombat>>
[[Next|Beach]]
:: Beach Party Rape Ejaculation [nobr]
<<ejaculation>>
<<if $enemyanger gte ($enemyangermax / 5) * 3>>
<<He>> pushes you onto the sand.<<violence 1>><br><br>
<<elseif $enemyanger gte 1>>
Without a word, <<he>> heads back to his friends.<br><br>
<<else>>
Smiling, <<he>> leans closer, "Good <<girlstop>>" <<He>> leaves you lying on the sand.<br>
<br>
<</if>>
<<tearful>> you rise to your feet.<br><br>
<<clotheson>>
<<endcombat>>
[[Next|Beach]]
:: Beach Party Rape Escape [nobr]
<<effects>>
<<He>> recoils in pain, giving you the chance you need. <<tearful>> you escape into the darkness. <br><br>
<<if $upperoff isnot 0>>
<<uppersteal>>
<</if>>
<<if $loweroff isnot 0>>
<<lowersteal>>
<</if>>
<<if $underoff isnot 0>>
<<understeal>>
<</if>>
<br><br>
<<endcombat>>
[[Next|Beach]]
:: Beach Party Sex Ejaculation [nobr]
<<ejaculation>>
<<if $enemyanger gte ($enemyangermax / 5) * 3>>
<<He>> drops you on the sand.<<violence 3>><br><br>
<<elseif $enemyanger gte 1>>
Without a word, <<he>> leaves.<br><br>
<<else>>
Smiling, <<he>> kisses you on the cheek. <<He>> gets up and leaves you lying on the sand.<br><br>
<</if>>
<<tearful>> you rise to your feet.<br><br>
<<clotheson>>
<<endcombat>>
[[Next|Beach]]
:: Beach Party Sex Escape [nobr]
<<effects>>
<<if $daystate isnot "night">>
<<He>> recoils in pain, giving you the chance you need. <<tearful>> you escape into the darkness. <br><br>
<<else>>
<<He>> recoils in pain, giving you the chance you need. <<tearful>> you escape into the darkness. <br><br>
<</if>>
<<if $upperoff isnot 0>>
<<uppersteal>>
<</if>>
<<if $loweroff isnot 0>>
<<lowersteal>>
<</if>>
<<if $underoff isnot 0>>
<<understeal>>
<</if>>
<br><br>
<<endcombat>>
[[Next|Beach]]
:: Beach Party Sex Finish [nobr]
The <<person>> leaves you. <<He>> looks dejected.
<<clotheson>>
<<endcombat>>
[[Next|Beach]]
:: Beach Party Dance Rape [nobr]
<<if $molestationstart is 1>>
<<set $molestationstart to 0>>
<<controlloss>>
<<violence 1>>
<<neutral 1>>
<<set $event to "molestationhome">>
<<man1init>>
<<if $daystate isnot "night">>
<</if>>
<</if>>
<<effects>>
<<effectsman>><<man>>
<<audience>>
<<stateman>><br>
<br>
<<actionsman>>
<<if $alarm is 1>>
<<if $rescue is 1>>
<<else>>
No one comes to your aid.<<set $alarm to 0>>
<<if $drugged is 1>>Intoxicated as you are, you couldn't cry very convincingly.<</if>><br><br>
<<if $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next->Beach Party Dance Rape Ejaculation]]>><</link>></span><<nexttext>>
<<elseif $enemyhealth lte 0>>
<span id="next"><<link [[Next->Beach Party Dance Rape Escape]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next->Beach Party Dance Rape]]>><</link>></span><<nexttext>>
<</if>>
<</if>>
<<elseif $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next->Beach Party Dance Rape Ejaculation]]>><</link>></span><<nexttext>>
<<elseif $enemyhealth lte 0>>
<span id="next"><<link [[Next->Beach Party Dance Rape Escape]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next->Beach Party Dance Rape]]>><</link>></span><<nexttext>>
<</if>>
:: Beach Party Dance Rape Ejaculation [nobr]
<<ejaculation>>
<<if $audience is 1>>
A cheer erupts from the crowd as the <<person1>><<person>> climaxes. <<tearful>> you manage to stagger away before anyone else gets ideas.
<<elseif $audience lte 6>>
The <<person1>><<person>> and <<person2>><<person>> highfive each other. <<tearful>> you manage to stagger away while the audience congratulates each other.
<<else>>
A cheer erupts from the crowd, seems they enjoyed the show. <<tearful>> you manage to stagger away before anyone else gets any ideas.
<</if>>
<<if $upperoff isnot 0>>
<<uppersteal>>
<</if>>
<<if $loweroff isnot 0>>
<<lowersteal>>
<</if>>
<<if $underoff isnot 0>>
<<understeal>>
<</if>>
<br><br>
<<endcombat>>
[[Next|Beach]]
:: Beach Party Dance Rape Escape [nobr]
<<effects>>
<<if $daystate isnot "night">>
<<He>> recoils in pain, giving you the chance you need. <<tearful>> you escape into the darkness. <br><br>
<<else>>
<<He>> recoils in pain, giving you the chance you need. <<tearful>> you escape into the darkness. <br><br>
<</if>>
<<if $upperoff isnot 0>>
<<uppersteal>>
<</if>>
<<if $loweroff isnot 0>>
<<lowersteal>>
<</if>>
<<if $underoff isnot 0>>
<<understeal>>
<</if>>
<br><br>
<<endcombat>>
[[Next|Beach]]
:: Beach Run [nobr]
<<pass 30>><<set $outside to 1>><<set $location to "beach">><<effects>>
You run along the shore.
<<if $daystate is "night">>
<<if $weather is "rain">>
The sound of the waves crashing competes with the torrential rain.
<<elseif $weather is "clear">>
The cold night breeze invigorates you.
<<elseif $weather is "overcast">>
The cool night breeze feels pleasant against your skin.
<</if>>
<<else>>
<<if $weather is "rain">>
Shards of rain assault you as you jog across the wet sand.
<<elseif $weather is "clear">>
The sun's intensity wears you down, tiring you out.<<tiredness 6>><<gtiredness>>
<<elseif $weather is "overcast">>
The cool weather makes for a pleasant jog.
<</if>>
<</if>>
<<physique 3>><<tiredness 6>><<stress -6>><br><br>
<<link [[Next|Beach]]>><</link>>
:: Beach Day Molestation [nobr]
<<if $molestationstart is 1>>
<<set $molestationstart to 0>>
<<controlloss>>
<<violence 1>>
<<neutral 1>>
<<molested>>
<<set $event to "molestationhome">>
<<man1init>><<npcstrip>>
<<if $daystate isnot "night">>
<<set $rescue to 1>>
<</if>>
<</if>>
<<effects>>
<<effectsman>><<man>>
<<stateman>><br>
<br>
<<actionsman>>
<<if $alarm is 1>>
<<if $rescue is 1>>
<span id="next"><<link [[Next|Beach Day Molestation Alarm]]>><</link>></span><<nexttext>>
<<else>>
No one comes to your aid.<<set $alarm to 0>>
<<if $drugged is 1>>Intoxicated as you are, you couldn't cry very convincingly.<</if>><br><br>
<<if $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next->Beach Day Molestation Ejaculation]]>><</link>></span><<nexttext>>
<<elseif $enemyhealth lte 0>>
<span id="next"><<link [[Next->Beach Day Molestation Escape]]>><</link>></span><<nexttext>>
<<elseif $uppertype is "naked" and $lowertype is "naked">>
<span id="next"><<link [[Next|Beach Day Molestation Stripped]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next->Beach Day Molestation]]>><</link>></span><<nexttext>>
<</if>>
<</if>>
<<elseif $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next->Beach Day Molestation Ejaculation]]>><</link>></span><<nexttext>>
<<elseif $enemyhealth lte 0>>
<span id="next"><<link [[Next->Beach Day Molestation Escape]]>><</link>></span><<nexttext>>
<<elseif $uppertype is "naked" and $lowertype is "naked">>
<span id="next"><<link [[Next|Beach Day Molestation Stripped]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next->Beach Day Molestation]]>><</link>></span><<nexttext>>
<</if>>
:: Beach Day Molestation Ejaculation [nobr]
<<ejaculation>>
<<if $enemyanger gte ($enemyangermax / 5) * 3>>
"Stupid slut." <<He>> dumps you on the sand.<br><br>
<<elseif $enemyanger gte 1>>
Without a word, <<he>> leaves.<br><br>
<<else>>
Smiling, <<he>> kisses you on the cheek before taking <<his>> leave.<br><br>
<</if>>
<<if $upperoff isnot 0>>
<<uppersteal>>
<</if>>
<<if $loweroff isnot 0>>
<<lowersteal>>
<</if>>
<<if $underoff isnot 0>>
<<understeal>>
<</if>>
<br><br>
<<tearful>> you rise to your feet.<br><br>
<<clotheson>>
<<endcombat>>
<<link [[Next|Beach]]>><<set $eventskip to 1>><</link>>
:: Beach Day Molestation Escape [nobr]
<<effects>>
<<if $daystate isnot "night">>
<<He>> recoils in pain, giving you the chance you need. <<tearful>> you escape. <br><br>
<<else>>
<<He>> recoils in pain, giving you the chance you need. <<tearful>> you escape into the darkness. <br><br>
<</if>>
<<if $upperoff isnot 0>>
<<uppersteal>>
<</if>>
<<if $loweroff isnot 0>>
<<lowersteal>>
<</if>>
<<if $underoff isnot 0>>
<<understeal>>
<</if>>
<br><br>
<<clotheson>>
<<endcombat>>
<<link [[Next|Beach]]>><<set $eventskip to 1>><</link>>
:: Beach Day Molestation Stripped [nobr]
With your clothes bundled in <<his>> arms, the <<person>> gives you a mocking look before dashing away, leaving you lying bare on the sand. <<tearful>> you rise to your feet, keeping low to conceal your nudity.<br><br>
<<if $upperoff isnot 0>>
<<uppersteal>>
<</if>>
<<if $loweroff isnot 0>>
<<lowersteal>>
<</if>>
<<if $underoff isnot 0>>
<<understeal>>
<</if>>
<br><br>
<<clotheson>>
<<endcombat>>
<<link [[Next|Beach]]>><<set $eventskip to 1>><</link>>
:: Beach Day Encounter [nobr]
<<set $outside to 1>><<set $location to "beach">><<effects>>
<<if $phase is 0>>
You walk over to the <<person>> who pretends not to notice you until you stop in front of <<himstop>> <<He>> looks at you but doesn't speak.<br><br>
<<link [[Friendly chat (0:10)|Beach Day Encounter]]>><<set $phase to 1>><<pass 10>><<stress -2>><<trauma -1>><</link>><<lstress>><<ltrauma>><br>
<<link [[Flirt (0:05)|Beach Day Encounter]]>><<pass 5>><<set $phase to 2>><</link>><<promiscuous1>><br>
<<link [[Leave|Beach]]>><<endevent>><<set $eventskip to 1>><</link>>
<<elseif $phase is 1>>
You try to bring <<him>> out of <<his>> shell by talking about innocuous things. <<He>> responds politely but you do most of the talking. You catch <<him>> eyeing you up when <<he>> thinks you're not looking.<br><br>
<<link [[Say Goodbye|Beach]]>><<endevent>><<set $eventskip to 1>><</link>><br>
<<link [[Flirt (0:05)|Beach Day Encounter]]>><<pass 5>><<set $phase to 2>><</link>><<promiscuous1>><br>
<<elseif $phase is 2>>
You sit on the towel beside <<him>> and lean close. You tell <<him>> <<he>> is a terrific parent but that <<he>> must be in need of stress relief every now and then.
<<if $penis is "clothed">>
<<He>> shifts <<his>> legs as if to conceal something.
<<else>>
<<He>> blushes with increasing intensity as you continue.
<</if>>
<<promiscuity1>>
<br><br>
<<link [[Stop|Beach Day Encounter]]>><<set $phase to 3>><</link>><br>
<<if $promiscuity gte 15>>
<<link [[Seduce|Beach Day Encounter]]>><<set $phase to 4>><</link>><<seductiondifficulty>><<promiscuous2>>
<</if>>
<<elseif $phase is 3>>
Satisfied with the effect you stand and take your leave.<br><br>
<<link [[Next|Beach]]>><<endevent>><<set $eventskip to 1>><</link>>
<<elseif $phase is 4>><<seductionskilluse>><<promiscuity2>>
<<if 1000 - ($rng * 10) - $seductionskill - ($attractiveness / 10) lte -100>>
Gazing into <<his>> eyes, you press your body against <<his>> and make it absolutely clear what your intentions are. <<He>> glances at <<his>> kids. Satisfied that they're distracted, <<he>> turns and embraces you, <<his>> heart beating furiously.<br><br>
<<link [[Next|Beach Day Encounter Sex]]>><<set $sexstart to 1>><</link>>
<<else>>
Gazing into <<his>> eyes, you press your body against <<his>> and make it absolutely clear what your intentions are. Stammering excuses, <<he>> recoils from your advance and leaves to check on <<his>> children.<br><br>
<<link [[Nevermind|Beach]]>><<endevent>><<set $eventskip to 1>><</link>>
<</if>>
<</if>>
:: Beach Day Encounter Sex [nobr]
<<if $sexstart is 1>>
<<set $sexstart to 0>>
<<consensual>>
<<set $consensual to 1>>
<<neutral 1>>
<<set $event to "molestationhome">>
<<man1init>>
<<set $enemytrust += 100>>
<</if>>
<<effects>><<set $outside to 1>><<set $location to "beach">>
<<effectsman>><<man>>
<<stateman>><br>
<br>
<<actionsman>>
<<if $finish is 1>>
<span id="next"><<link[[Next->Beach Day Encounter Sex Finish]]>><</link>></span><<nexttext>>
<<else>>
<<if $alarm is 1>>
<<if $rescue is 1>>
<<else>>
No one comes to your aid.<<set $alarm to 0>>
<<if $drugged is 1>>Intoxicated as you are, you couldn't cry very convincingly.<</if>><br><br>
<<if $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next->Beach Day Encounter Sex Ejaculation]]>><</link>></span><<nexttext>>
<<elseif $enemyhealth lte 0>>
<span id="next"><<link [[Next->Beach Day Encounter Sex Escape]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next->Beach Day Encounter Sex]]>><</link>></span><<nexttext>>
<</if>>
<</if>>
<<elseif $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next->Beach Day Encounter Sex Ejaculation]]>><</link>></span><<nexttext>>
<<elseif $enemyhealth lte 0>>
<span id="next"><<link [[Next->Beach Day Encounter Sex Escape]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next->Beach Day Encounter Sex]]>><</link>></span><<nexttext>>
<</if>>
<</if>>
:: Beach Day Encounter Sex Finish [nobr]
<<effects>>
While you're stopping sooner than <<he>> would like, <<he>> looks relieved as <<he>> returns <<his>> attention back to <<his>> kids. They don't seem to have noticed anything.<br><br>
<<clotheson>>
<<endcombat>>
[[Next|Beach]]
:: Beach Day Encounter Sex Ejaculation [nobr]
<<ejaculation>>
Looking like <<he>> just awoke from a dream, <<he>> looks at <<his>> kids while motioning for you to leave. <<tearful>> you wink and turn away.<br><br>
<<clotheson>>
<<endcombat>>
[[Next|Beach]]
:: Beach Day Encounter Sex Escape [nobr]
<<effects>>
<<if $daystate isnot "night">>
<<He>> recoils in pain, giving you the chance you need. <<tearful>> you escape into the darkness. <br><br>
<<else>>
<<He>> recoils in pain, giving you the chance you need. <<tearful>> you escape into the darkness. <br><br>
<</if>>
<<if $upperoff isnot 0>>
<<uppersteal>>
<</if>>
<<if $loweroff isnot 0>>
<<lowersteal>>
<</if>>
<<if $underoff isnot 0>>
<<understeal>>
<</if>>
<br><br>
<<clotheson>>
<<endcombat>>
[[Next|Beach]]
:: Beach Night Dog [nobr]
<<if $molestationstart is 1>>
<<set $molestationstart to 0>>
<<controlloss>>
<<violence 1>>
<<neutral 1>>
<<molested>>
<<set $event to "dogpack">><<set $beasttype to "dog">>
<<beast1init>>
<</if>>
<<effects>>
<<effectsman>><br><<beast>><br><br>
<<stateman>><br>
<br>
<<actionsman>>
<<if $alarm is 1>>
<<if $rescue is 1>>
<<else>>
No one comes to your aid.<<set $alarm to 0>>
<<if $drugged is 1>>Intoxicated as you are, you couldn't cry very convincingly.<</if>><br><br>
<<if $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next|Beach Night Dog Ejaculation]]>><</link>></span><<nexttext>>
<<elseif $enemyhealth lte 0>>
<span id="next"><<link [[Next->Beach Night Dog Escape]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next|Beach Night Dog]]>><</link>></span><<nexttext>>
<</if>>
<</if>>
<<elseif $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next->Beach Night Dog Ejaculation]]>><</link>></span><<nexttext>>
<<elseif $enemyhealth lte 0>>
<span id="next"><<link [[Next->Beach Night Dog Escape]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next->Beach Night Dog]]>><</link>></span><<nexttext>>
<</if>>
:: Beach Night Dog Ejaculation [nobr]
<<beastejaculation>>
<<if $enemyanger gte ($enemyangermax / 5) * 3>>
<<He>> bites you on the thigh, then leaves you lying on the sand.<<violence 3>><br><br>
<<elseif $enemyanger gte 1>>
<<He>> barks then leaves you lying on the sand.<br><br>
<<else>>
<<He>> licks your <<genitals>> then darts away.<<neutral 5>><br><br>
<</if>>
<<tearful>> you rise to your feet.
<<clotheson>>
<<endcombat>>
<<link [[Next|Beach]]>><<set $eventskip to 1>><</link>>
:: Beach Night Dog Escape [nobr]
<<effects>>
The beast whimpers and flees into the darkness. <<tearful>> you rise to your feet.<br><br>
<<clotheson>>
<<endcombat>>
<<link [[Next|Beach]]>><<set $eventskip to 1>><</link>>
:: Beach Night Molestation [nobr]
<<if $molestationstart is 1>>
<<set $molestationstart to 0>>
<<controlloss>>
<<violence 1>>
<<neutral 1>>
<<molested>>
<<set $event to "molestationhome">>
<<man1init>>
<</if>>
<<effects>>
<<effectsman>><<man>>
<<stateman>><br>
<br>
<<actionsman>>
<<if $alarm is 1>>
<<if $rescue is 1>>
<<else>>
No one comes to your aid.<<set $alarm to 0>>
<<if $drugged is 1>>Intoxicated as you are, you couldn't cry very convincingly.<</if>><br><br>
<<if $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next->Beach Night Molestation Ejaculation]]>><</link>></span><<nexttext>>
<<elseif $enemyhealth lte 0>>
<span id="next"><<link [[Next->Beach Night Molestation Escape]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next->Beach Night Molestation]]>><</link>></span><<nexttext>>
<</if>>
<</if>>
<<elseif $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next->Beach Night Molestation Ejaculation]]>><</link>></span><<nexttext>>
<<elseif $enemyhealth lte 0>>
<span id="next"><<link [[Next->Beach Night Molestation Escape]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next->Beach Night Molestation]]>><</link>></span><<nexttext>>
<</if>>
:: Beach Night Molestation Ejaculation [nobr]
<<ejaculation>>
<<if $enemyanger gte ($enemyangermax / 5) * 3>>
<<He>> smacks your face, then leaves you lying on the sand.<<violence 3>><br><br>
<<elseif $enemyanger gte 1>>
Without a word, <<he>> leaves.<br><br>
<<else>>
Smiling, <<he>> kisses you on the cheek. <<His>> breath reeks of alcohol. "This is for you." <<He>> gets up and leaves you lying on the ground.<<set $money += 500>><br>
You've gained £5.<br><br>
<</if>>
<<if $underoff isnot 0>>
<<understeal>>
<</if>>
<<tearful>> you rise to your feet.<br><br>
<<clotheson>>
<<endcombat>>
<<link [[Next|Beach]]>><<set $eventskip to 1>><</link>>
:: Beach Night Molestation Escape [nobr]
<<effects>>
<<if $daystate isnot "night">>
<<He>> recoils in pain, giving you the chance you need. <<tearful>> you escape into the darkness. <br><br>
<<else>>
<<He>> recoils in pain, giving you the chance you need. <<tearful>> you escape into the darkness. <br><br>
<</if>>
<<if $upperoff isnot 0>>
<<uppersteal>>
<</if>>
<<if $loweroff isnot 0>>
<<lowersteal>>
<</if>>
<<if $underoff isnot 0>>
<<understeal>>
<</if>>
<br><br>
<<clotheson>>
<<endcombat>>
<<link [[Next|Beach]]>><<set $eventskip to 1>><</link>>
:: Beach Exhibition [nobr]
<<set $outside to 1>><<set $location to "beach">><<effects>>
<<if $phase is 0>>
<<if $leftarm is "bound" and $rightarm is "bound">>
Unable to cover youself, you bow your head in shame and march through the crowds to the safety of a changing room.<<garousal>><<gstress>><<gtrauma>><<stress 12>><<trauma 6>><<arousal 6>><<fameexhibitionism 50>><br><br>
<<link [[Changing Room|Changing Room]]>><<endevent>><</link>>
<<else>>
<<if $exposed gte 2>>
Face red with humiliation, you make sure your <<genitalsstop>>are properly concealed and make your way across the beach to the safety of a changing room, taunted and ridiculed all the way.<<fameexhibitionism 20>><<garousal>><<arousal 6>><br><br>
<<link [[Changing Room|Changing Room]]>><<endevent>><</link>>
<<else>>
Face red with humiliation, you make your way across the beach to the safety of a changing room, taunted and ridiculed all the way.<<garousal>><<arousal 3>><<fameexhibitionism 10>><br><br>
<<link [[Changing Room|Changing Room]]>><<endevent>><</link>>
<</if>>
<</if>>
<<else>>
<<generate2>>Swallowing your pride, you ask if anyone could lend you something to cover up with. Smiling, a <<person2>><<person>> produces some towels for you.<<fameexhibitionism 10>>
<<if $leftarm is "bound" and $rightarm is "bound">>
Seeing you restrained, <<he>> wraps them round you. <<He>> takes <<his>> time, as if savoring the situation, but eventually you find yourself properly covered.<<garousal>><<arousal 6>>
<<else>>
You take the offered cloth and, crouching for better concealment, you wrap them around yourself. They're a poor substitute for actual clothing, but you're not the only one attired in such a way.
<</if>>
<br><br>Still blushing, you thank the <<person>> and sheepishly move away from the growing crowd.<br><br>
<<if $lowerexposed gte 1>>
<<set $lowertowelnew to 1>><<lowertowel>>
<</if>>
<<if $upperexposed gte 1>>
<<set $uppertowelnew to 1>><<uppertowel>>
<</if>>
<<link [[Next|Beach]]>><<set $eventskip to 1>><<endevent>><</link>>
<</if>>
:: Beach Exhibit Molestation [nobr]
<<set $outside to 1>><<set $location to "beach">><<effects>>
<<if $phase is 0>>
<<if $molestationstart is 1>>
<<set $molestationstart to 0>>
<<controlloss>>
<<violence 1>>
<<neutral 1>>
<<molested>>
<<set $event to "molestationhome">>
<<generatey2>><<generatey3>><<generatey4>><<generatey5>>
<<man1init>><<npcstrip>><<npcexhibit>>
"Maybe you like being seen like this? We can help you out there." Arms reach out from all around you!<br><br>
<<set $rescue to 1>>
<</if>>
<<effects>>
<<effectsman>><<man>>
<<stateman>><br>
<br>
<<actionsman>>
<<if $alarm is 1>>
<<if $rescue is 1>>
<span id="next"><<link [[Next->Beach Exhibit Molestation Alarm]]>><</link>></span><<nexttext>>
<<else>>
No one comes to your aid.<<set $alarm to 0>>
<<if $drugged is 1>>Intoxicated as you are, you couldn't cry very convincingly.<</if>><br><br>
<<if $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next->Beach Exhibit Molestation Ejaculation]]>><</link>></span><<nexttext>>
<<elseif $enemyhealth lte 0>>
<span id="next"><<link [[Next->Beach Exhibit Molestation Escape]]>><</link>></span><<nexttext>>
<<elseif $orgasmdown gte 1>>
<span id="next"><<link [[Next->Beach Exhibit Molestation Orgasm]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next->Beach Exhibit Molestation]]>><</link>></span><<nexttext>>
<</if>>
<</if>>
<<elseif $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next->Beach Exhibit Molestation Ejaculation]]>><</link>></span><<nexttext>>
<<elseif $enemyhealth lte 0>>
<span id="next"><<link [[Next->Beach Exhibit Molestation Escape]]>><</link>></span><<nexttext>>
<<elseif $orgasmdown gte 1>>
<span id="next"><<link [[Next->Beach Exhibit Molestation Orgasm]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next->Beach Exhibit Molestation]]>><</link>></span><<nexttext>>
<</if>>
<<elseif $phase is 1>>
<<if $sexstart is 1>>
<<set $sexstart to 0>>
<<consensual>>
<<set $consensual to 1>>
<<neutral 1>>
<<set $event to "molestationhome">>
<<man1init>><<npcoral>>
<<set $enemytrust -= 40>>
<<set $rescue to 1>>
<</if>>
<<effects>>
<<effectsman>><<man>>
<<stateman>><br>
<br>
<<actionsman>>
<<if $alarm is 1>>
<<if $rescue is 1>>
<span id="next"><<link [[Next->Beach Exhibit Molestation Alarm]]>><</link>></span><<nexttext>>
<<else>>
No one comes to your aid.<<set $alarm to 0>>
<<if $drugged is 1>>Intoxicated as you are, you couldn't cry very convincingly.<</if>><br><br>
<<if $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next->Beach Exhibit Molestation Ejaculation]]>><</link>></span><<nexttext>>
<<elseif $enemyhealth lte 0>>
<span id="next"><<link [[Next->Beach Exhibit Molestation Escape]]>><</link>></span><<nexttext>>
<<elseif $finish is 1>>
<span id="next"><<link [[Next|Beach Exhibit Molestation Finish]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next->Beach Exhibit Molestation]]>><</link>></span><<nexttext>>
<</if>>
<</if>>
<<elseif $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next->Beach Exhibit Molestation Ejaculation]]>><</link>></span><<nexttext>>
<<elseif $enemyhealth lte 0>>
<span id="next"><<link [[Next->Beach Exhibit Molestation Escape]]>><</link>></span><<nexttext>>
<<elseif $finish is 1>>
<span id="next"><<link [[Next|Beach Exhibit Molestation Finish]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next->Beach Exhibit Molestation]]>><</link>></span><<nexttext>>
<</if>>
<</if>>
:: Beach Exhibit Molestation Alarm [nobr]
<<effects>><<set $rescued += 1>><<person1>>
<<He>> notices several heads turning in response to your cry. "You're fucking nuts." <<He>> and <<his>> friends make a quick getaway. <<tearful>> you gather yourself.<br><br>
<<clotheson>>
<<endcombat>>
[[Next|Beach]]
:: Beach Exhibit Molestation Ejaculation [nobr]
<<ejaculation>>
<<person1>>
<<if $enemyanger gte ($enemyangermax / 5) * 3>>
<<He>> pushes you onto the sand then spits on you. <<His>> friends follow suit and they leave you lying there, covered in fluid.
<<violence 1>><br><br>
<<if $upperoff isnot 0>>
<<uppersteal>>
<</if>>
<<if $loweroff isnot 0>>
<<lowersteal>>
<</if>>
<<if $underoff isnot 0>>
<<understeal>>
<</if>>
<<clotheson>>
<br><br>
<<elseif $enemyanger gte 1>>
"Oh, I said I'd help you." <<He>> grins at <<his>> friends, "That juice should cover you up well enough." They leave you lying on the sand.
<<clotheson>>
<br><br>
<<else>>
"See, that wasn't so bad was it?" <<He>> chucks you some towels before sauntering off with <<his>> friends.
<<clotheson>>
<br><br>
<<if $upperexposed gte 1 and $lowerexposed gte 1>>
You wrap a towel around your chest and nether regions, creating a makeshift skirt.<<set $uppertowelnew to 1>><<uppertowel>><<set $lowertowelnew to 1>><<lowertowel>>
<<elseif $upperexposed gte 1>>
You wrap a towel around your chest.<<set $uppertowelnew to 1>><<uppertowel>>
<<elseif $lowerexposed gte 1>>
You wrap a towel around your nether regions, creating a makeshift skirt.<<set $lowertowelnew to 1>><<lowertowel>>
<</if>>
<</if>>
<<tearful>> you rise to your feet.<br><br>
<<endcombat>><<set $eventskip to 1>>
[[Next|Beach]]
:: Beach Exhibit Molestation Escape [nobr]
<<effects>><<person1>>
<<if $daystate isnot "night">>
<<He>> recoils in pain, giving you the chance you need. <<tearful>> you escape into the crowds. <br><br>
<<else>>
<<He>> recoils in pain, giving you the chance you need. <<tearful>> you escape into the darkness. <br><br>
<</if>>
<<if $upperoff isnot 0>>
<<uppersteal>>
<</if>>
<<if $loweroff isnot 0>>
<<lowersteal>>
<</if>>
<<if $underoff isnot 0>>
<<understeal>>
<</if>>
<br><br>
<<clotheson>>
<<endcombat>><<set $eventskip to 1>>
[[Next|Beach]]
:: Beach Exhibit Molestation Orgasm [nobr]
<<person1>>A cheer erupts from the group as you spasm in orgasm. The <<person>> is particularly amused. "Wow, you really are a pathetic slut. I don't think you want help at all, I think you're precisely where you want to be." With that, the group leave you quivering on the sand.<br><br>
<<tearful>> you rise to your feet.<br><br>
<<clotheson>>
<<endcombat>>
[[Next|Beach]]
:: Beach Exhibit Molestation Finish [nobr]
<<person1>>
"Had enough?" Fine, but don't expect any help." <<He>> and <<his>> friends leave you on the sand.
<<tearful>> you rise to your feet.<br><br>
<<clotheson>>
<<endcombat>>
[[Next|Beach]]
:: Widgets Events Beach [widget]
<<widget "eventsbeach">><<nobr>>
<<set $dangerevent to random(1, 100)>>
<<if $daystate is "night">>
<<if $dangerevent lte 15>>
<<beachnight1>>
<<elseif $dangerevent lte 30>>
<<beachnight2>>
<<elseif $dangerevent lte 100>>
<<beachday4>>
<</if>>
<<elseif $exposed gte 1>>
<<if $dangerevent lte 80>>
<<beachex1>>
<<elseif $dangerevent lte 100>>
<<beachex2>>
<</if>>
<<else>>
<<if $dangerevent lte 10>>
<<beachday1>>
<<elseif $dangerevent lte 20>>
<<beachday2>>
<<elseif $dangerevent lte 50>>
<<beachday3>>
<<elseif $dangerevent lte 100>>
<<beachday4>>
<</if>>
<</if>>
<</nobr>><</widget>>
:: Widgets Passout Beach [widget]
<<widget "passoutbeach">><<nobr>>
[[Everything fades to black...->Passout Beach]]
<</nobr>><</widget>>
:: Passout Beach [nobr]
You've pushed yourself too much.<br><br>
<<passout>>
<<set $danger to random(1, 10000)>>
<<if $danger gte (9900 - $allure)>>
<<if $rng gte 1>>
<<link [[Wake up|Beach Abduction]]>><<uppernaked>><<lowernaked>><<undernaked>><</link>>
<</if>>
<<else>>
<<ambulance>>
<</if>>
<<pass 1 hour>>
<<set $trauma +=10>><<set $stress -= 2000>>
:: Beach Abduction [nobr]
<<effects>><<set $outside to 0>>
<<generatey1>><<generatey2>><<person1>>You wake up lying on your back, naked in the dunes. You hear a voice, "You're awake." You hasten to your feet and see the speaker, a <<personstop>> A <<person2>><<person>> stands next to <<person1>><<himstop>> <br><br>
<<if $loweroff is 0 and $upperoff is 0 and $underoff is 0>>
"You must be a huge slut, to be wandering around like that. Though I do feel bad about leaving you in such a state. There are some nasty people around."<br><br>
<<person2>>The <<person>> interjects, "I know! We'll lend you some towels," <<he>> produces some thin cables from <<his>> coat pocket "if you let us dress you first."<br><br>
<<person1>> The <<person>> seems taken with the idea, "It's your choice. If you don't want to play along, we'll leave you to be raped. You'd probably get off from it anyway."<br><br>
<<else>>
You see your <<if $upperoff isnot 0>>$upperoff <<elseif $loweroff isnot 0>>$loweroff <<else>>$underoff <</if>>in <<his>> hand. <<He>> twirls it playfully, "Finders keepers. Though I do feel bad about leaving you in such a state. There are some nasty people around."<br><br>
<<person2>>The <<person>> interjects, "I know! We'll give the clothes back," <<he>> produces some thin cables from <<his>> coat pocket "if you let us dress you first."<br><br>
<<person1>> The <<person>> seems taken with the idea, "It's your choice. If you don't want to play along, we'll be keeping your clothes to do with as we please." <<He>> slowly starts tearing the fabric.<br><br>
<</if>>
<<link [[Accept|Beach Abduction Bound]]>><</link>><br>
<<link [[Refuse|Beach Abduction Molestation]]>><<set $molestationstart to 1>><</link>><br>
:: Beach Abduction Bound [nobr]
<<effects>><<set $outside to 0>>
You submit to being bound. <<person2>> The <<person>> ties your arms together behind your back while the <<person1>><<person>> looks on, a sardonic smile on <<his>> face. It doesn't take long, the <<person2>><<person>> soon stands back to admire <<his>> handiwork. You try to move your arms, but they are tied together tightly. You can only wave them impotently behind your back. Feelings of helplessness rise within you.<<set $leftarm to "bound">><<set $rightarm to "bound">><br><br>
"Just one more thing I think," the <<person>> says, producing a collar and leash.<br><br>
<<link [[Accept|Beach Abduction Collared]]>><<set $collared to 1>><<set $phase to 1>><</link>><br>
<<link [[Refuse|Beach Abduction Molestation]]>><<set $molestationstart to 1>><</link>><br>
:: Beach Abduction Molestation [nobr]
<<if $molestationstart is 1>>
<<set $molestationstart to 0>>
<<controlloss>>
<<violence 1>>
<<neutral 1>>
<<molested>>
<<set $event to "molestationhome">>
<<man1init>>
<<if $phase is 0>>
They look taken aback. "Oh. You're actually okay walking around like that," The <<person1>><<person>> muses. "I guess you won't mind us taking a little more then." They advance on you.<br><br>
<<elseif $phase is 1>>
<</if>>
<</if>>
<<effects>>
<<effectsman>><<man>>
<<stateman>><br>
<br>
<<actionsman>>
<<if $alarm is 1>>
<<if $rescue is 1>>
<<else>>
No one comes to your aid.<<set $alarm to 0>>
<<if $drugged is 1>>Intoxicated as you are, you couldn't cry very convincingly.<</if>><br><br>
<<if $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next->Beach Abduction Molestation Ejaculation]]>><</link>></span><<nexttext>>
<<elseif $enemyhealth lte 0>>
<span id="next"><<link [[Next->Beach Abduction Molestation Escape]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next->Beach Abduction Molestation]]>><</link>></span><<nexttext>>
<</if>>
<</if>>
<<elseif $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next->Beach Abduction Molestation Ejaculation]]>><</link>></span><<nexttext>>
<<elseif $enemyhealth lte 0>>
<span id="next"><<link [[Next->Beach Abduction Molestation Escape]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next->Beach Abduction Molestation]]>><</link>></span><<nexttext>>
<</if>>
:: Beach Abduction Molestation Ejaculation [nobr]
<<ejaculation>>
<<if $phase is 0>>
"Thanks for the company," the <<person1>><<person>> says mockingly. "Good luck!" They leave you lying naked on the sand. <br><br>
<<if $upperoff isnot 0>>
<<uppersteal>>
<</if>>
<<if $loweroff isnot 0>>
<<lowersteal>>
<</if>>
<<if $underoff isnot 0>>
<<understeal>>
<</if>>
<<clotheson>>
<<elseif $phase is 1>>
Satisfied, the <<person1>><<person>> unties the cables binding your arms. "Here you go." <<He>> tosses the fabric at you. <<He>> and <<his>> friends leave you to cover up as they laugh their way back to the beach. They left the collar on.<br><br>
<<unbind>>
<<clothesontowel>>
<</if>>
<<tearful>> you struggle to your feet.<br><br>
<<endcombat>>
<<set $stress -= 500>>
<<link [[Next|Beach]]>><</link>>
<<set $eventskip to 1>>
:: Beach Abduction Molestation Escape [nobr]
<<effects>>
<<if $daystate isnot "night">>
They recoil in pain, giving you the chance you need. <<tearful>> you flee naked into the dunes. <br><br>
<<else>>
They recoil in pain, giving you the chance you need. <<tearful>> you flee naked into the darkness. <br><br>
<</if>>
<<if $upperoff isnot 0>>
<<uppersteal>>
<</if>>
<<if $loweroff isnot 0>>
<<lowersteal>>
<</if>>
<<if $underoff isnot 0>>
<<understeal>>
<</if>>
<br><br>
<<clotheson>>
<<endcombat>>
<<set $stress -= 500>>
<<link [[Next|Beach]]>><</link>>
<<set $eventskip to 1>>
:: Beach Abduction Collared [nobr]
<<effects>><<set $outside to 0>>
Having come this far, you submit to the collar being placed round your neck. You hear a decisive click as it locks shut. <<person2>>The <<person>> attaches the leash, and tugs.<br><br>
<<if $rng gte 51>>
The pair stand back to admire your body, the <<person2>><<person>> holding your leash securely. "Very nice," the <<person1>><<person>> says, circling around you for a different angle. With your arms bound, there's nothing you can do to shield yourself from their scrutiny.<br><br>
The <<person2>><<person>> approaches you, and you brace yourself for a more physical probing. Instead, <<he>> unties your bonds while the <<person1>><<person>> throws the fabric over your head. "Here you go. You can keep the collar." Laughing, they head in the direction of the beach. You try to cover up as quickly as possible, but you're still shaking from the ordeal.<br><br>
<<unbind>>
<<clothesontowel>>
<<endevent>>
<<set $stress -= 500>>
<<link [[Next|Beach]]>><</link>>
<<else>><<set $rng to random(1, 100)>>
<<person1>>Smirking, the <<person>> speaks, "You're all dressed up now, but it would be a waste for no one else to see you looking so fine." <<person2>>The <<person>> tugs again, harder this time. "We'll help as you as we said we would, but there's someone you need to meet first."<br><br>
Bound and leashed as you are, you have little choice but to go with them<<if $submission lte 850>>, though you seethe noiselessly at the humiliation<<else>> meekly<</if>>.<br><br>
You are led deeper into the dunes. You walk for several minutes, conscious of just how exposed and vulnerable you are. Your captors make no attempt to hide how much they enjoy being in a position of power over you, and constantly leer at your body, knowing there's nothing you can do to stop them.<br><br>
<<if $bestialitydisable is "f" and $rng gte 51>>
You come to a relatively flat area, surrounded by dunes on all sides, shielding it from view. In the centre is a dog, its leash tied to a wooden post. At the sight of you it leaps to it's feet, straining the leash in a bid to reach you.<br><br>
<<person1>> The <<person>> speaks in a high-pitched voice, "Who's a good boy! You are! We brought you a bitch, because you're such a good boy!"<br><br>
<<link [[Try to run|Beach Abduction Dog]]>><<set $molestationstart to 1>><<set $phase to 0>><</link>><br>
<<link [[Allow yourself to be led over|Beach Abduction Dog]]>><<set $molestationstart to 1>><</link>><br>
<<else>>
<<generatey3>><<generatey4>><<generatey5>><<generatey6>>You come to a relatively flat area, surrounded by dunes on all sides, shielding it from view. Four teenagers sit smoking in the centre. Your feelings of humiliation reach a new pitch as the new pairs of eyes see you in your shameful situation. Their initial shock quickly subsides, leaving a bare and primal lust.<br><br>
The <<person2>><<person>> leads you into the middle of the group, their eyes feasting on every inch of your body. "We found this piece of trash near the beach. Can't believe anyone would just leave it laying around, no respect at all," the <<person1>><<person>> starts fondling your <<genitals>>in front of everyone, causing your breath to catch in your chest. The rest of the group take the cue. Arms reach out from all around you, each wanting their share.<br><br>
<<link [[Next|Beach Abduction Molestation]]>><<set $molestationstart to 1>><</link>>
<</if>>
<</if>>
:: Beach Abduction Dog [nobr]
<<if $molestationstart is 1>>
<<set $molestationstart to 0>>
<<controlloss>>
<<violence 1>>
<<neutral 1>>
<<molested>>
<<set $event to "dogpack">><<set $beasttype to "dog">>
<<beast1init>>
<<if $phase is 0>>
You try to escape, but the <<person1>><<person>> grabs the leash and helps the <<person2>><<person>> yank you to the ground. Before you can recover, the <<person1>><<person>> has released the dog from it's post. It leaps ontop of you, pinning you down.<<set $beaststance to "top">><<set $head to "grappled">><br><br><<set $submissive -= 1>>
<<elseif $phase is 1>>
Trying to keep calm, you allow yourself to be led closer to the beast. The <<person1>><<person>> unties the dog, who darts towards you.<br><br><<set $submissive += 1>>
<</if>>
<<set $phase to 2>>
<</if>>
<<effects>>
<<if $phase is 2>><<set $phase to 1>>
The pair sit on the sand to spectate.<br><br>
<<else>>
<<if $orgasmdown gte 1 and $phase is 1>><<set $phase to 0>>
"I can't believe it," the <<person1>><<person>> shouts with joy, "You're actually cumming from being raped by an animal. This is fantastic." You feel utterly humiliated.<<set $trauma += 10>><<famebestiality 10>><<famebestiality 10>>
<<else>>
The <<person1>><<person>> and <<person2>><<person>> are enjoying the show.
<</if>>
<br><br>
<</if>>
<<effectsman>><br><<beast>><br><br>
<<stateman>><br>
<br>
<<actionsman>>
<<if $alarm is 1>>
<<if $rescue is 1>>
<<else>>
No one comes to your aid.<<set $alarm to 0>>
<<if $drugged is 1>>Intoxicated as you are, you couldn't cry very convincingly.<</if>><br><br>
<<if $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next|Beach Abduction Dog Ejaculation]]>><</link>></span><<nexttext>>
<<elseif $enemyhealth lte 0>>
<span id="next"><<link [[Next->Beach Abduction Dog Escape]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next|Beach Abduction Dog]]>><</link>></span><<nexttext>>
<</if>>
<</if>>
<<elseif $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next->Beach Abduction Dog Ejaculation]]>><</link>></span><<nexttext>>
<<elseif $enemyhealth lte 0>>
<span id="next"><<link [[Next->Beach Abduction Dog Escape]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next->Beach Abduction Dog]]>><</link>></span><<nexttext>>
<</if>>
:: Beach Abduction Dog Ejaculation [nobr]
<<beastejaculation>>
<<if $enemyanger gte ($enemyangermax / 5) * 3>>
<<He>> bites you on the thigh before leaving you lying there.<<violence 3>><br><br>
<<elseif $enemyanger gte 1>>
<<He>> barks then leaves you lying there.<br><br>
<<else>>
<<He>> licks your <<genitals>> then darts away.<<neutral 5>><br><br>
<</if>>
The <<person1>><<person>> and <<person2>><<person>> applaud. "Bred like the bitch you are," the <<person>> exclaims as <<he>> unties your bonds. The <<person1>><<person>> throws you the fabric they promised. "You can keep the collar. It suits you." Laughing, they leave you lying disgraced on the sand. <<tearful>> you struggle to your feet.<br><br>
<<unbind>>
<<clothesontowel>>
<<endcombat>>
<<set $stress -= 500>>
<<link [[Next|Beach]]>><</link>>
<<set $eventskip to 1>>
:: Beach Abduction Dog Escape [nobr]
<<effects>>
The dog whimpers and flees.<br><br>
Before the pair can react, you seize the opportunity and bolt away. <<tearful>> you quickly lose them in the dunes.<br><br>
<<if $upperoff isnot 0>>
<<uppersteal>>
<</if>>
<<if $loweroff isnot 0>>
<<lowersteal>>
<</if>>
<<if $underoff isnot 0>>
<<understeal>>
<</if>>
<<clotheson>>
<<endcombat>>
<<set $stress -= 500>>
<<link [[Next|Beach]]>><</link>>
<<set $eventskip to 1>>
:: Beach Day Molestation Alarm [nobr]
<<effects>>
The <<person>> looks offended, but relents. "You crazy slut, I was only having some fun." <<tearful>> you cover yourself and rise to your feet.
<br><br>
<<clotheson>>
<<endcombat>>
<<link [[Next|Beach]]>><<set $eventskip to 1>><</link>>
:: Beach Strip [nobr]
<<set $outside to 1>><<set $location to "beach">><<effects>>
<<set $beachstrip to 1>>
<<uppernaked>><<lowernaked>><<undernaked>>
<<generate1>><<generate2>><<generate3>><<generate4>><<generate5>><<generate6>>
Shivering with excitement you shuffle out of your clothes and bare your <<lewdness>> for the entire beach to see. People don't even realise how far you stripped at first. A lot of people dress scanty here after all. But none are dressed quite as scanty as you, and people start to notice.<br><br>
A <<person1>><<person>> looks at you and audibly gasps. A <<person2>><<person>> averts <<his>> eyes and avoids looking at you at all costs. A <<person3>><<person>> stares and looks like <<hes>> about to start drooling. You're pleased that <<his>> is the most common response. You're not ashamed of your <<genitalsstop>> You've everything to be proud of.<<exhibitionism5>><br><br>
You stroll down the beach, drawing eyes wherever you go. Each breeze caressing your bare flesh a reminder of your exposure. You feel so free, powerful and sexy. A whistle pierces the air. You turn and see a lifeguard running towards you.
<<endevent>><<generate1>><<person1>>
<<He>> stops in front of you, but looks away. "I'm sorry, but I need to ask you to cover up. This isn't a nudist beach."<br><br>
<<link [[Comply|Beach Strip Comply]]>><</link>><br>
<<link [[Refuse (1:00)|Beach Strip Refuse]]>><<stress -12>><<trauma -6>><<crime 50>><<pass 1 hour>><</link>><<crime>><<ltrauma>><<lstress>><br>
<<if $promiscuity gte 15>>
<<link [[Seduce|Beach Strip Seduce]]>><</link>><<promiscuous2>><br>
<</if>>
:: Beach Strip Comply [nobr]
<<set $outside to 1>><<set $location to "beach">><<effects>>
You decide you've had enough fun for now and pick up your clothes.
<<clotheson>>
"Thank you," says the lifeguard, sounding relieved. "I didn't want to have to get the police involved. Try to remain dressed from now on."<br><br>
<<endevent>>
<<link [[Next|Beach]]>><</link>><br>
:: Beach Strip Refuse [nobr]
<<set $outside to 1>><<set $location to "beach">><<effects>>
<<if $submissive gte 1150>>
"But I should be seen," you say. "Don't you think I'm beautiful?" You flare your arms at your sides and twirl. "Everyone should be allowed to look." You skip away.
<<elseif $submissive lte 850>>
You put your hands on your hips and pout. "Or what? You gonna make me?" You turn around, lean forwards and give your <<bottom>> a smack before sauntering away.
<<else>>
"No," you say. "I'm not gonna let you control me. You're welcome to join the fun though." You giggle and skip away.
<</if>>
<br><br>
<<endevent>>
You spend an hour running across the sand and splashing through waves. The sun feels warm and gentle against your bare skin. After a while though, the wind starts to pick up and the cold makes you shiver. You decide to get dressed for now. There's always another day.<br><br>
<<link [[Next|Beach]]>><<clotheson>><</link>><br>
:: Beach Strip Seduce [nobr]
<<effects>>
<<set $seductiondifficulty to 8000>>
<<seductioncheck>><br><br>
<span class="gold">You feel more confident in your powers of seduction.</span><<seductionskilluse>><br><br>
You walk closer to the <<personstop>> "I could get dressed," you say, leaning against <<his>> arm. "Or we could have some fun."<<promiscuity2>><br><br>
<<if $seductionrating gte $seductionrequired>>
<<He>> reaches for your <<genitalscomma>> but stops short and gulps. "M-maybe it would be fine if," <<he>> grabs your waist. "If I had a little fun."<br><br>
<<link [[Next|Beach Strip Sex]]>><<set $sexstart to 1>><</link>><br>
<<else>>
"I-I-No," <<he>> stammers and pulls away from you. "G-get dressed now, or I'll call the police!"<br><br>
<<link [[Comply|Beach Strip Comply]]>><</link>><br>
<<link [[Refuse (1:00)|Beach Strip Refuse]]>><<stress -12>><<trauma -6>><<crime 50>><<pass 1 hour>><</link>><<crime>><<ltrauma>><<lstress>><br>
<</if>>
:: Beach Strip Sex [nobr]
<<if $sexstart is 1>>
<<set $sexstart to 0>>
<<consensual>>
<<set $consensual to 1>>
<<neutral 1>>
<<set $event to "molestationhome">>
<<man1init>>
<<set $enemytrust += 50>>
<</if>>
<<effects>>
<<effectsman>><<man>>
<<audience>>
<<stateman>><br>
<br>
<<actionsman>>
<<if $finish is 1>>
<span id="next"><<link [[Next|Beach Strip Sex Finish]]>><</link>></span><<nexttext>>
<<elseif $enemyhealth lte 0>>
<span id="next"><<link [[Next|Beach Strip Sex Finish]]>><</link>></span><<nexttext>>
<<elseif $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next|Beach Strip Sex Finish]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next|Beach Strip Sex]]>><</link>></span><<nexttext>>
<</if>>
:: Beach Strip Sex Finish [nobr]
<<set $outside to 1>><<set $location to "beach">><<effects>>
<<if $enemyarousal gte $enemyarousalmax>>
<<ejaculation>>
"I only did that so you'd get dressed!" <<he>> says unconvincingly.<br><br>
It is getting cold though, so you decide to get dressed for now.<br><br>
<<clotheson>>
<<endcombat>>
<<elseif $enemyhealth lte 0>>
You shove the <<person>> onto the sand and dash away.<br><br>
It's getting a bit cold, so you decide to get dressed for now.<br><br>
<<clotheson>>
<<endcombat>>
<<elseif $finish is 1>>
"I only did that so you'd get dressed!" <<he>> says unconvincingly.<br><br>
It is getting cold though, so you decide to get dressed for now.<br><br>
<<clotheson>>
<<endcombat>>
<</if>>
<br><br>
<<link [[Next|Beach]]>><</link>>
:: Beach Phallus [nobr]
<<set $outside to 1>><<set $location to "beach">><<effects>>
<<generate1>><<person1>>You scan the beach for people wearing skimpy swimsuits, or otherwise look like they will agree to your request.<br><br>
<<if $rng gte 81>>
You see a <<person>> showing off <<his>> body, trying to impress a <<generate2>><<person2>><<personstop>> It isn't working.<br><br><<person1>>
<<if $penis isnot "none">>
<<link [[Ask to measure penis|Beach Phallus Flex]]>><</link>><<promiscuous3>><br>
<<else>>
<<link [[Ask to measure clitoris|Beach Phallus Flex]]>><</link>><<promiscuous3>><br>
<</if>>
<<elseif $rng gte 61>>
<<generate2>><<person1>>You see a <<person>> and <<person2>><<person>> holding hands.<br><br>
<<if $penis isnot "none">>
<<link [[Ask to measure penis|Beach Phallus Pair]]>><</link>><<promiscuous3>><br>
<<else>>
<<link [[Ask to measure clitoris|Beach Phallus Pair]]>><</link>><<promiscuous3>><br>
<</if>>
<<elseif $rng gte 41>>
You see a <<person>> moving between different groups and individuals, asking for money.<br><br>
<<if $penis isnot "none">>
<<link [[Ask to measure penis|Beach Phallus Beggar]]>><</link>><<promiscuous3>><br>
<<else>>
<<link [[Ask to measure clitoris|Beach Phallus Beggar]]>><</link>><<promiscuous3>><br>
<</if>>
<<elseif $rng gte 21>>
You see a <<person>> sitting alone on the sand.<br><br>
<<if $penis isnot "none">>
<<link [[Ask to measure penis|Beach Phallus Shy]]>><</link>><<promiscuous3>><br>
<<else>>
<<link [[Ask to measure clitoris|Beach Phallus Shy]]>><</link>><<promiscuous3>><br>
<</if>>
<<else>>
You see a <<person>> scanning the beach with one hand shielding <<his>> eyes from the sun.<br><br>
<<if $penis isnot "none">>
<<link [[Ask to measure penis|Beach Phallus Scan]]>><</link>><<promiscuous3>><br>
<<else>>
<<link [[Ask to measure clitoris|Beach Phallus Scan]]>><</link>><<promiscuous3>><br>
<</if>>
<</if>>
<<link [[Look for someone else (0:15)|Beach Phallus]]>><<endevent>><<pass 15>><</link>><br>
<<link [[Stop|Beach]]>><<pass 10>><<endevent>><</link>><br>
:: Beach Phallus Flex [nobr]
<<set $outside to 1>><<set $location to "beach">><<effects>>
You approach the <<person>> just as the <<person2>><<person>> walks off.<<person1>><br><br>
"You'll be back," the <<person>> says. <<He>> turns to you. "Hey," <<he>> says "What do you want?"<br><br>
<<if $submissive gte 1150>>
You can't look <<him>> in the eye. Not with a request like this. "C-could I measure your <<personpenis>> with this tape?" you ask. "It's for my science project."
<<elseif $submissive lte 850>>
"I'm gonna measure your <<personpeniscomma>>" you say. "For science."
<<else>>
"Hello," you say. "I'm doing a science project for school. Can I measure your <<personpenis>> with this tape?"
<</if>>
<<promiscuity3>>
<<He>> gapes, then bursts into laughter. "Damn, the schools here are fucked. Tell you what, you show me, and I'll show you." <<He>> leers at your <<crotchstop>><br><br>
<<if $lowertype is "naked">>
<<if $exhibitionism gte 75>>
<<link [[Show|Beach Phallus Show]]>><<set $phase to 0>><</link>><<exhibitionist5>><br>
<</if>>
<<else>>
<<if $undertype is "naked" or $undertype is "chastity">>
<<if $exhibitionism gte 75>>
<<link [[Show|Beach Phallus Show]]>><<set $phase to 1>><</link>><<exhibitionist5>><br>
<</if>>
<<else>>
<<if $exhibitionism gte 15>>
<<link [[Show|Beach Phallus Show]]>><<set $phase to 2>><</link>><<exhibitionist2>><br>
<</if>>
<</if>>
<</if>>
<<link [[Look for someone else (0:15)|Beach Phallus]]>><<endevent>><<pass 15>><</link>><br>
<<link [[Stop|Beach]]>><<pass 10>><<endevent>><</link>><br>
:: Beach Phallus Show [nobr]
<<set $outside to 1>><<set $location to "beach">><<effects>>
<<if $phase is 0>>
You pull aside your $underclothes, baring your <<genitals>> for the <<person>> to see.
<<else>>
You <<pulldown>> your $lowerclothes, baring your <<undies>> for the <<person>> to see.
<</if>>
<<if $phase is 0 or $phase is 1>>
<<exhibitionism5>>
<<His>> eyes widen. "Didn't think you actually would," <<he>> says, not taking <<his>> eyes off you. Without hesitating, <<he>> <<if $pronoun is "m">>pulls down <<his>> shorts<<else>>pulls aside <<his>> bikini bottoms<</if>>, baring <<himself>> in turn. "I don't have all day."<br><br>
You kneel and take <<his>> measurement from base to tip, then ask <<him>> questions about <<his>> lifestyle. "This is the real invasive part," <<he>> says at one point, but <<he>> answers all the questions.<br><br>
<<if $penis isnot "none">><<set $sciencephallus += 1>><<set $sciencephalluspenis += 1>>
<span class="gold">You can add the penis measurement you took to your project in your room or the school library.<br><br></span>
<<else>><<set $sciencephallus += 1>><<set $sciencephallusclit += 1>>
<span class="gold">You can add the clitoris measurement you took to your project in your room or the school library.<br><br></span>
<</if>>
<<link [[Next|Beach]]>><<endevent>><</link>><br>
<<else>>
<<exhibitionism2>>
"That's a start," <<he>> says. "But you're gonna need to do better."<br><br>
<<if $exhibitionism gte 75>>
<<link [[Show|Beach Phallus Show]]>><<set $phase to 0>><</link>><<exhibitionist5>><br>
<</if>>
<<link [[Flirt|Beach Phallus Flirt]]>><</link>><br>
<<link [[Look for someone else (0:15)|Beach Phallus]]>><<endevent>><<pass 15>><</link>><br>
<<link [[Stop|Beach]]>><<pass 10>><<endevent>><</link>><br>
<</if>>
:: Beach Phallus Flirt [nobr]
<<set $outside to 1>><<set $location to "beach">><<effects>>
"But you can already see so much of me," you say. "And I'm not experienced like you."<br><br>
<<set $seductiondifficulty to 4000>>
<<seductioncheck>><br><br>
<span class="gold">You feel more confident in your powers of seduction.</span><<seductionskilluse>><br><br>
<<if $seductionrating gte $seductionrequired>>
<<He>> chuckles. "Worth a try," <<he>> says. Without hesitating, <<he>> <<if $pronoun is "m">>pulls down <<his>> shorts<<else>>pulls aside <<his>> bikini bottoms<</if>>, baring <<himself>> to you. "I don't have all day."<br><br>
You kneel and take <<his>> measurement from base to tip, then ask <<him>> questions about <<his>> lifestyle. "This is the real invasive part," <<he>> says at one point, but <<he>> answers all the questions.<br><br>
<<if $penis isnot "none">><<set $sciencephallus += 1>><<set $sciencephalluspenis += 1>>
<span class="gold">You can add the penis measurement you took to your project in your room or the school library.<br><br></span>
<<else>><<set $sciencephallus += 1>><<set $sciencephallusclit += 1>>
<span class="gold">You can add the clitoris measurement you took to your project in your room or the school library.<br><br></span>
<</if>>
<<link [[Next|Beach]]>><<endevent>><</link>><br>
<<else>>
"I can see a lot less than you're asking of me," <<he>> says. "Show me more or go bother someone else."<br><br>
<<if $exhibitionism gte 75>>
<<link [[Show|Beach Phallus Show]]>><<set $phase to 0>><</link>><<exhibitionist5>><br>
<</if>>
<<link [[Look for someone else (0:15)|Beach Phallus]]>><<endevent>><<pass 15>><</link>><br>
<<link [[Stop|Beach]]>><<pass 10>><<endevent>><</link>><br>
<</if>>
:: Beach Phallus Pair [nobr]
<<set $outside to 1>><<set $location to "beach">><<effects>>
You approach the pair. The <<person2>><<person>> smiles at you. "How can we help you?" <<he>> says.<br><br>
<<if $submissive gte 1150>>
You can't look <<him>> in the eye. Not with a request like this. "C-could I measure your <<personpenis>> with this tape?" you ask. "It's for my science project."
<<elseif $submissive lte 850>>
"I'm gonna measure your <<personpeniscomma>>" you say. "For science."
<<else>>
"Hello," you say. "I'm doing a science project for school. Can I measure your <<personpenis>> with this tape?"
<</if>>
<<promiscuity3>>
<<He>> bursts into laughter. "Of course not," <<he>> says. <<He>> grabs the <<person1>><<persons>> arm. "<<He>> will be happy to help though."<br><br>
The <<person>> looks aghast. "No," <<he>> says. "That's not happening."<br><br>
The <<person2>><<person>> whispers something into the <<person1>><<persons>> ear, and <<his>> expression changes. They share a look. "Alright," the <<person>> says. "If you promise."<br><br>
"I promise," the <<person2>><<person>> responds. <<He>> kneels in front of the <<person1>><<person>> and yanks down <<his>> <<if $pronoun is "m">>shorts<<else>>bikini bottoms<</if>>.<br><br>
<<if $rng gte 61>>
You kneel and take <<his>> measurement from base to tip, then ask <<him>> questions about <<his>> lifestyle. The <<person2>><<person>> answers most of them for <<person1>><<himstop>> <<He>> looks uncomfortable the whole time.<br><br>
<<if $penis isnot "none">><<set $sciencephallus += 1>><<set $sciencephalluspenis += 1>>
<span class="gold">You can add the penis measurement you took to your project in your room or the school library.<br><br></span>
<<else>><<set $sciencephallus += 1>><<set $sciencephallusclit += 1>>
<span class="gold">You can add the clitoris measurement you took to your project in your room or the school library.<br><br></span>
<</if>>
<<link [[Next|Beach]]>><<endevent>><</link>><br>
<<else>>
You're kneeling to take <<his>> measurement when the the <<person2>><<person>> crouches behind you and puts a hand over your mouth. "Hold still," <<he>> says. "You're going to be nice to my lover here. Understood?" The <<person1>><<person>> smiles.<br><br>
<<link [[Next|Beach Phallus Rape]]>><<set $molestationstart to 1>><</link>><br>
<</if>>
:: Beach Phallus Rape [nobr]
<<if $molestationstart is 1>>
<<set $molestationstart to 0>>
<<controlloss>>
<<violence 1>>
<<neutral 1>>
<<molested>>
<<set $event to "molestationhome">>
<<man1init>><<if $penis is "clothed">><<set $penis to 0>><</if>><<if $vagina is "clothed">><<set $vagina to 0>><</if>><<set $lefthand2 to "mouth">><<set $mouthuse to "lefthand">>
<<set $rescue to 1>>
<</if>>
<<effects>>
<<effectsman>><<man>>
<<stateman>><br>
<br>
<<actionsman>>
<<if $enemyhealth lte 0>>
<span id="next"><<link [[Next|Beach Phallus Rape Finish]]>><</link>></span><<nexttext>>
<<elseif $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next|Beach Phallus Rape Finish]]>><</link>></span><<nexttext>>
<<elseif $alarm is 1 and $rescue is 1>>
<span id="next"><<link [[Next|Beach Phallus Rape Finish]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next|Beach Phallus Rape]]>><</link>></span><<nexttext>>
<</if>>
:: Beach Phallus Rape Finish [nobr]
<<set $outside to 1>><<set $location to "beach">><<effects>>
<<if $enemyarousal gte $enemyarousalmax>>
<<ejaculation>>
"Wanting such personal information," the <<person2>><<person>> says. "What nerve." They leave you lying on the sand.<br><br>
<<clotheson>>
<<endcombat>>
<<link [[Next|Beach]]>><</link>><br>
<<elseif $enemyhealth lte 0>>
You knock the <<person2>><<person>> way from you and escape into a more crowded area of the beach.<br><br>
<<clotheson>>
<<endcombat>>
<<link [[Next|Beach]]>><</link>><br>
<<else>>
Heads turn up and down the beach. The pair back away from you and walk fast away.<br><br>
<<clotheson>>
<<endcombat>>
<<link [[Next|Beach]]>><</link>><br>
<</if>>
:: Beach Phallus Beggar [nobr]
<<set $outside to 1>><<set $location to "beach">><<effects>>
You approach the <<personstop>> <<He>> smiles at you.<br><br>
<<if $submissive gte 1150>>
You can't look <<him>> in the eye. Not with a request like this. "C-could I measure your <<personpenis>> with this tape?" you ask. "It's for my science project."
<<elseif $submissive lte 850>>
"I'm gonna measure your <<personpeniscomma>>" you say. "For science."
<<else>>
"Hello," you say. "I'm doing a science project for school. Can I measure your <<personpenis>> with this tape?"
<</if>>
<<promiscuity3>>
<<His>> smile fades as you talk, but returns all at once. "Okay," <<he>> says. "If you pay me. I'm in a bit of a hard spot."<br><br>
<<if $money gte 1000>>
<<link [[Pay (£10)|Beach Phallus Pay]]>><<set $money -= 1000>><</link>><br>
<<link [[Give money for nothing in return (£10)|Beach Phallus Charity]]>><<famegood 1>><<set $money -= 1000>><<trauma -6>><</link>><<ltrauma>><br>
<</if>>
<<link [[Look for someone else (0:15)|Beach Phallus]]>><<endevent>><<pass 15>><</link>><br>
<<link [[Stop|Beach]]>><<pass 10>><<endevent>><</link>><br>
:: Beach Phallus Pay [nobr]
<<set $outside to 1>><<set $location to "beach">><<effects>>
You give <<him>> the money. <<He>> glances around to make sure no one is looking, then exposes <<his>> genitals.<br><br>
You kneel and take <<his>> measurement from base to tip, then ask <<him>> questions about <<his>> lifestyle. <<He>> answers slowly.<br><br>
<<if $penis isnot "none">><<set $sciencephallus += 1>><<set $sciencephalluspenis += 1>>
<span class="gold">You can add the penis measurement you took to your project in your room or the school library.<br><br></span>
<<else>><<set $sciencephallus += 1>><<set $sciencephallusclit += 1>>
<span class="gold">You can add the clitoris measurement you took to your project in your room or the school library.<br><br></span>
<</if>>
<<link [[Next|Beach]]>><<endevent>><</link>><br>
:: Beach Phallus Charity [nobr]
<<set $outside to 1>><<set $location to "beach">><<effects>>
<<if $submissive gte 1150>>
You hand <<him>> the money. <<He>> moves to expose <<his>> genitals. "N-no," you say. "It's fine. I'll find someone else."
<<elseif $submissive lte 850>>
"Just take the money," you say. "I'll find someone else."
<<else>>
"It's okay," you say. "Just take the money. I'll find someone else."
<</if>>
<br><br>
"Thank you so much," <<he>> says. <<He>> looks relieved.
<<if $rng gte 51>>
<<He>> steps closer as if to hug, but decides not to. <<He>> shuffles away.<br><br>
<<else>>
<<He>> plays with the money in <<his>> hand and frowns. With a grimace, <<he>> exposes <<his>> genitals. "It's okay," <<he>> smiles. "Take what you need."<br><br>
You kneel and take <<his>> measurement from base to tip, then ask <<him>> questions about <<his>> lifestyle. <<He>> answers slowly.<br><br>
<<if $penis isnot "none">><<set $sciencephallus += 1>><<set $sciencephalluspenis += 1>>
<span class="gold">You can add the penis measurement you took to your project in your room or the school library.<br><br></span>
<<else>><<set $sciencephallus += 1>><<set $sciencephallusclit += 1>>
<span class="gold">You can add the clitoris measurement you took to your project in your room or the school library.<br><br></span>
<</if>>
<</if>>
<<link [[Next|Beach]]>><<endevent>><</link>><br>
:: Beach Phallus Shy [nobr]
<<set $outside to 1>><<set $location to "beach">><<effects>>
You approach the <<personstop>> <<He>> looks away from you until you're right beside <<himstop>><br><br>
<<if $submissive gte 1150>>
You can't look <<him>> in the eye. Not with a request like this. "C-could I measure your <<personpenis>> with this tape?" you ask. "It's for my science project."
<<elseif $submissive lte 850>>
"I'm gonna measure your <<personpeniscomma>>" you say. "For science."
<<else>>
"Hello," you say. "I'm doing a science project for school. Can I measure your <<personpenis>> with this tape?"
<</if>>
<<promiscuity3>>
<<He>> looks away and blushes. You take it as a no, but then <<he>> pulls a towel over <<his>> legs and up to <<his>> waist. "C-crawl under," <<he>> says. "No one should see."<br><br>
You shuffle beneath the towel and between <<his>> legs. You <<if $pronoun is "m">>tug down <<his>> shorts<<else>>pull aside <<his>> bikini bottoms<</if>>.<br><br>
<<if $promiscuity gte 55>>
<<link [[Lick|Beach Phallus Oral]]>><<set $sexstart to 1>><</link>><<promiscuous4>><br>
<</if>>
<<link [[Take measurement|Beach Phallus Measure]]>><</link>><br>
:: Beach Phallus Oral [nobr]
<<if $sexstart is 1>>
<<set $sexstart to 0>>
<<consensual>>
<<set $consensual to 1>>
<<neutral 1>>
<<set $event to "molestationhome">>
<<man1init>>
You crawl closer and give <<him>> a teasing lick. "W-wait," <<he>> stammers, but <<he>> doesn't push you away.<<promiscuity4>>
<br><br>
<<npcoral>>
<</if>>
<<effects>>
<<effectsman>><<man>>
<<He>> keeps the towel pulled over you.<br><br>
<<stateman>><br>
<br>
<<actionsman>>
<<if $enemyhealth lte 0>>
<span id="next"><<link [[Next|Beach Phallus Oral Finish]]>><</link>></span><<nexttext>>
<<elseif $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next|Beach Phallus Oral Finish]]>><</link>></span><<nexttext>>
<<elseif $finish is 1>>
<span id="next"><<link [[Next|Beach Phallus Oral Finish]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next|Beach Phallus Oral]]>><</link>></span><<nexttext>>
<</if>>
:: Beach Phallus Oral Finish [nobr]
<<set $outside to 1>><<set $location to "beach">><<effects>>
<<if $enemyhealth lte 0>>
<<elseif $enemyarousal gte $enemyarousalmax>>
<<ejaculation>>
<<else>>
<</if>>
<<He>> lies still as you take <<his>> measurement from base to tip, then ask <<him>> questions about <<his>> lifestyle. <<He>> isn't keen on giving answers, but you get enough. You shuffle out from beneath the towel. <<He>> avoids looking at you.<br><br>
<<if $penis isnot "none">><<set $sciencephallus += 1>><<set $sciencephalluspenis += 1>>
<span class="gold">You can add the penis measurement you took to your project in your room or the school library.<br><br></span>
<<else>><<set $sciencephallus += 1>><<set $sciencephallusclit += 1>>
<span class="gold">You can add the clitoris measurement you took to your project in your room or the school library.<br><br></span>
<</if>>
<<clotheson>><<endcombat>>
<<link [[Next|Beach]]>><</link>><br>
:: Beach Phallus Measure [nobr]
<<set $outside to 1>><<set $location to "beach">><<effects>>
<<He>> lies still as you take <<his>> measurement from base to tip, then ask <<him>> questions about <<his>> lifestyle. <<He>> isn't keen on giving answers, but you get enough. You shuffle out from beneath the towel. <<He>> avoids looking at you.<br><br>
<<if $penis isnot "none">><<set $sciencephallus += 1>><<set $sciencephalluspenis += 1>>
<span class="gold">You can add the penis measurement you took to your project in your room or the school library.<br><br></span>
<<else>><<set $sciencephallus += 1>><<set $sciencephallusclit += 1>>
<span class="gold">You can add the clitoris measurement you took to your project in your room or the school library.<br><br></span>
<</if>>
<<endevent>>
<<link [[Next|Beach]]>><</link>><br>
:: Beach Phallus Scan [nobr]
<<set $outside to 1>><<set $location to "beach">><<effects>>
You approach the <<personstop>> <<He>> smiles at you. "Hey cutie," <<he>> says.<br><br>
<<if $submissive gte 1150>>
You can't look <<him>> in the eye. Not with a request like this. "C-could I measure your <<personpenis>> with this tape?" you ask. "It's for my science project."
<<elseif $submissive lte 850>>
"I'm gonna measure your <<personpeniscomma>>" you say. "For science."
<<else>>
"Hello," you say. "I'm doing a science project for school. Can I measure your <<personpenis>> with this tape?"
<</if>>
<<promiscuity3>>
<<His>> smile broadens and <<he>> leans close. "How forward. I'll show you everything," <<he>> whispers. "We're going to find somewhere private. Then I'm going to fuck you senseless." <<He>> grasps your arm and pulls.<br><br>
<<link [[Accept|Beach Phallus Accept]]>><</link>><br>
<<link [[Refuse|Beach Phallus Refuse]]>><</link>><br>
:: Beach Phallus Refuse [nobr]
<<set $outside to 1>><<set $location to "beach">><<effects>>
You resist <<his>> pull. <<He>> looks angry, but releases you. "How rude," <<he>> says. "Go find someone else to tease."<br><br>
<<endevent>>
<<link [[Next|Beach]]>><</link>><br>
:: Beach Phallus Accept [nobr]
<<set $outside to 1>><<set $location to "beach">><<effects>>
<<He>> leads you to a changing room and pushes you inside. <<He>> shuts the door after <<himcomma>> then tackles you to the ground.<br><br>
<<link [[Next|Beach Phallus Sex]]>><<set $sexstart to 1>><</link>><br>
:: Beach Phallus Sex [nobr]
<<if $sexstart is 1>>
<<set $sexstart to 0>>
<<consensual>>
<<set $consensual to 1>>
<<neutral 1>>
<<set $event to "molestationhome">>
<<man1init>>
<</if>>
<<effects>>
<<effectsman>><<man>>
<<stateman>><br>
<br>
<<actionsman>>
<<if $enemyhealth lte 0>>
<span id="next"><<link [[Next|Beach Phallus Sex Finish]]>><</link>></span><<nexttext>>
<<elseif $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next|Beach Phallus Sex Finish]]>><</link>></span><<nexttext>>
<<elseif $finish is 1>>
<span id="next"><<link [[Next|Beach Phallus Sex Finish]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next|Beach Phallus Sex]]>><</link>></span><<nexttext>>
<</if>>
:: Beach Phallus Sex Finish [nobr]
<<set $outside to 1>><<set $location to "beach">><<effects>>
<<if $enemyhealth lte 0>>
You knock <<him>> against the wooden wall and flee through the door.<br><br>
<<elseif $enemyarousal gte $enemyarousalmax>>
<<ejaculation>>
"Did you get the measure of me?" <<he>> says. <<He>> sees the tape in your hand. "Oh, you meant that literally? Help yourself I guess."<br><br>
<<He>> lies still as you take <<his>> measurement from base to tip, then ask <<him>> questions about <<his>> lifestyle. <<He>> seems bored, but answers to your satisfaction.<br><br>
<<if $penis isnot "none">><<set $sciencephallus += 1>><<set $sciencephalluspenis += 1>>
<span class="gold">You can add the penis measurement you took to your project in your room or the school library.<br><br></span>
<<else>><<set $sciencephallus += 1>><<set $sciencephallusclit += 1>>
<span class="gold">You can add the clitoris measurement you took to your project in your room or the school library.<br><br></span>
<</if>>
<<else>>
"You tease," <<he>> says. "Clear off. Before I change my mind."<br><br>
<</if>>
<<clotheson>><<endcombat>>
<<link [[Next|Beach]]>><</link>><br>
|
QuiltedQuail/degrees
|
game/loc-beach.twee
|
twee
|
unknown
| 87,639 |
:: Brothel [nobr]
<<set $outside to 0>><<set $location to "town">><<effects>>
You are in the brothel. Several stages dot the crowded room. The staff look flustered and overworked.<br><br>
<<if $stress gte 10000>><<passoutshop>>
<<elseif $brothelshowmissed gte 1>><<set $brothelshowmissed to 0>><<set $briarlove -= 1>>
<<briar>><<generate2>><<generate3>><<person1>>Briar storms towards you as two of <<his>> thugs block the entrance. "Where were you?" <<he>> asks. "The crowd were expecting a show. It cost me, but you'll pay for it," <<he>> holds out <<his>> hand. "£1000. Now."<br><br>
<<if $money gte 100000>>
<<link [[Pay (£1000)|Brothel Pay]]>><<set $briardom += 1>><<set $money -= 100000>><<set $submissive += 1>><</link>><br>
<</if>>
<<link [[Say you can't afford it|Brothel Pay Refuse]]>><</link>><br>
<<link [[Refuse|Brothel Pay Refuse]]>><<set $briardom -= 1>><<set $submissive -= 1>><</link>><br>
<<else>>
<<if $exposed gte 1>>
You feel exposed, despite not being the only one attired so lewdly.<br><br>
<</if>>
<<if $brotheljob is 1 and $fameprostitution gte 30 and $brothelshowintro is undefined>><<set $brothelshowintro to 0>>
<<generate1>><<person1>>The <<person>> guarding the door rests a hand on your shoulder. <span class="gold">"Boss wants to see you."</span><<endevent>><br><br>
<</if>>
<<if $brotheljob is 1>>
<<link [[Work as a dancer|Brothel Dance]]>><<set $dancing to 1>><<set $venuemod to 3>><<stress -4>><<tiredness 4>><<set $dancelocation to "brothel">><</link>><<lstress>><<gtiredness>><br>
<<if$brothelshowintro is 1>>
<<link [[Go behind the stage|Brothel Stage]]>><</link>><br>
<</if>>
<<link [[Dressing Room (0:01)|Brothel Dressing Room]]>><</link>><br>
<</if>>
<<link [[Briar's Office (0:03)|Briar's Office]]>><<pass 3>><</link>><br>
<<if $exposed lte 0>>
<<link [[Leave (0:01)|Harvest Street]]>><<pass 1>><</link>><br>
<</if>>
<</if>>
:: Brothel Intro [nobr]
<<set $outside to 0>><<set $location to "town">><<effects>>
You enter the building, not sure what to expect. <<generate1>><<person1>>A <<person>> stands at the end of an antechamber, guarding another set of doors. <<He>> smiles when <<he>> sees you. "You look lost, little <<girlstop>> What brings you here?"<br><br>
"I was told to come here." You reply, sheepishly.<br><br>
<<His>> smile broadens. "Good. Wait just a moment." <<He>> presses a finger against <<his>> ear before speaking to the air. "We have a... That's right. Yes boss." <<He>> lowers <<his>> hand. "The boss'll be down shortly to meet you. You won't need to wait long."<br><br>
<<He>> was right.<<endevent>><<briar>><<person1>>
<<if $pronoun is "m">>
The doors open to reveal a man wearing a blue suit, minus a shirt, showing off <<his>> well-toned chest and abdomen. Long chestnut hair flows behind <<him>> as <<he>> enters.
<<else>>
The doors open to reveal a woman wearing an expensive-looking red gown with a plunging neckline, revealing a portion of <<his>> pert breasts. Long chestnut hair flows behind <<him>> as <<he>> enters.
<</if>><br><br>
<<He>> fixes you with hazel eyes, wordlessly grabs your wrist and pulls you through the doors.<br><br>
You enter a large crowded room. The smell of sweat is palpable. Several stages dot the room, with dancers showing themselves off. Patrons ogle and cheer at them, waited on by other staff in various states of undress. You are lead through the room and through an inconspicuous door. A flight of stairs later and you find yourself in a lavishly-decorated office.<br><br>
<<He>> lies down on a velvet sofa in the middle of the room, props <<his>> head up with one arm and observes you. You look around for a place to sit but other than the sofa there's no seating. <<He>> interrupts your search. "My name is Briar. Welcome to my establishment."<br><br>
<<link [[Next|Brothel Intro2]]>><</link>><br>
:: Brothel Intro2 [nobr]
<<set $outside to 0>><<set $location to "town">><<effects>>
<<if $phase is 0>>
<<He>> eyes up your body as <<he>> speaks.
<<if $devstate is 0 and $dev is 1>>
"You'll do nicely. A large portion our clientele love kids.
<<else>>
"Nice. Very nice. Our clientele will love you.
<</if>>
I'd like to offer you work looking after our guests. You saw how it works on the way up." <<He>> pauses before continuing. "Oh right, you probably want details. You can dress however you want, but you'll get more attention if you dress appropriately. Use a stage to show yourself off. You might make some change there, but your real aim should be to get hired for some private time. We provide rooms for that purpose."<br><br>
"You'll be expected to take care of yourself. If someone tries to rape you just deal with it and don't bother me. I'm not your <<if $pronoun is "m">>daddy<<else>>mommy<</if>>."<br><br>
"We take a 40% cut of anything you earn, and don't you dare think you can cheat us either. You'll have access to a dressing room, naturally. I think I've covered everything. So, interested?"<br><br>
<<link [[Yes|Brothel Intro2]]>><<set $phase to 1>><<set $brotheljob to 1>><</link>><br>
<<link [[No|Brothel Intro2]]>><<set $phase to 2>><</link>><br>
<<link [[I need more information|Brothel Intro2]]>><<set $phase to 3>><</link>><br>
<<elseif $phase is 1>>
"Good! Come by whenever you feel like putting your body to work. I'll let the other staff know you're joining them." <<He>> rises to <<his>> feet and guides you to the top of the stairs.
<<if $id is 0>>
<<He>> speaks as you descend. "One more thing. If you're having trouble with your legal status we can fix you a fake ID. For a price, obviously." You turn to look at <<him>> but <<he>> is already gone.
<<else>>
<<He>> doesn't say anything as <<he>> leaves you to descend.
<</if>>
<br><br>
<<link [[Next|Brothel]]>><<endevent>><</link>>
<<elseif $phase is 2>>
"That's a shame. Well, you know where to find us if you change your mind. A body like yours is sure to sell well." <<He>> rises to <<his>> feet and guides you to the top of the stairs.
<<if $id is 0>>
<<He>> speaks as you descend. "One more thing. If you're having trouble with your legal status we can fix you a fake ID. For a price, obviously." You turn to look at <<him>> but <<he>> is already gone.
<<else>>
<<He>> doesn't say anything as <<he>> leaves you to descend.
<</if>>
<br><br>
<<link [[Next|Brothel]]>><<endevent>><</link>>
<<elseif $phase is 3>>
<<if $devlevel lte 12 and $dev is 1>>
<<He>> blinks, then laughs. "You may be a child, but don't pretend you're innocent. You've seen what's going on downstairs, darling. I'm sure you can work out the rest on your own."<br><br>
<<else>>
<<He>> blinks, then laughs. "Don't be coy. You've seen what's going on downstairs, darling. I'm sure you can work out the rest on your own."<br><br>
<</if>>
<<link [[I'm interested|Brothel Intro2]]>><<set $phase to 1>><<set $brotheljob to 1>><</link>><br>
<<link [[I'm not interested|Brothel Intro2]]>><<set $phase to 2>><</link>><br>
<</if>>
:: Brothel Dance [nobr]
<<set $outside to 0>><<set $location to "town">><<effects>>
<<danceeffects>>
<<danceaudience>>
<<danceactions>>
<<if $danceevent is 0 and $exhibitionism lte 74 and $exposed gte 2>>
There's no way you can continue dancing while so exposed! Face reddening, you flee the scene.<br><br>
<<elseif $danceevent is 0 and $exhibitionism lte 34 and $exposed gte 1>>
There's no way you can continue dancing while so exposed! Face reddening, you flee the scene.<br><br>
<</if>>
<<if $danceevent is "finish">>
<<link [[Next|Brothel]]>><<clotheson>><<endevent>><</link>>
<<elseif $danceevent is "private">>
<<if $promiscuity gte 35>>
<<link [[Private room|Brothel Private]]>><<set $enemyno to 1>><</link>><<promiscuous3>><br>
<</if>>
<<elseif $danceevent is "rape">>
<<link [[Next|Brothel Dance Rape]]>><<set $molestationstart to 1>><</link>>
<<elseif $danceevent is 0>>
<<if $exposed gte 2 and $exhibitionism lte 74>>
<<link [[Flee|Brothel Dressing Room]]>><<clotheson>><<endevent>> <</link>>
<<elseif $exposed gte 1 and $exhibitionism lte 34>>
<<link [[Flee|Brothel Dressing Room]]>><<clotheson>><<endevent>><</link>>
<<else>>
<<link [[Stop|Brothel]]>><<clotheson>><<endevent>><</link>>
<</if>>
<</if>>
:: Briar's Office [nobr]
<<set $outside to 0>><<set $location to "town">><<effects>>
<<briar>><<person1>>
<<if $phase is 1>>
"Good! Come by whenever you feel like putting your body to work. I'll let the other staff know you're joining them." <<He>> rises to <<his>> feet and guides you to the top of the stairs. <<He>> doesn't say anything as <<he>> leaves you to descend.<br><br>
<<link [[Next|Brothel]]>><<endevent>><</link>>
<<elseif $brothelshowintro is 0>><<set $brothelshowintro to 1>><<set $brothelshow to "none">>
Briar leans beside the window, staring out."Glad you could join me," <<he>> says, not turning to look. "People have been asking for you. Seems you've made a name for yourself." <<He>> turns and sizes you up. "I'd like to hold a little show on <span class="gold">Fridays</span>. Get the punters in. How'd you like to be the star?"<br><br>
<<He>> doesn't wait for a response. "Not your usual work I know, and I'll need time to prepare. Think about it, then come visit me and we'll talk specifics. And money.<br><br>
<<endevent>>
<<link [[Next|Brothel]]>><</link>><br>
<<elseif $brotheljob isnot 1>>
Briar sprawls on the sofa, holding a glass of wine. <<He>> looks up as you enter. "Have you reconsidered my offer?"<br><br>
<<link [[Yes|Briar's Office]]>><<set $brotheljob to 1>><<set $phase to 1>><</link>><br>
<<if $id is 0>>
<<link [[Inquire about ID Card|Briar's Office ID]]>><</link>><br>
<</if>>
<<link [[Leave|Brothel]]>><<endevent>><</link>><br>
<<else>>
Briar sprawls on the sofa, holding a glass of wine. <<He>> looks up as you enter. "Something I can do for you?"<br><br>
<<if $brothelshowintro is 1 and $brothelshow is "none">>
<<link [[Set up a show|Briar's Office Show]]>><</link>><br>
<</if>>
<<if $id is 0>>
<<link [[Inquire about ID Card|Briar's Office ID]]>><</link>><br>
<</if>>
<<link [[Leave|Brothel]]>><<endevent>><</link>><br>
<</if>>
:: Briar's Office ID [nobr]
<<set $outside to 0>><<set $location to "town">><<effects>>
<<if $phase is 1>>
"Excellent, you won't regret it." <<He>> walks over to <<his>> desk and presses a button concealed behind a painting. A bookcase parts to reveal a workshop manned <<generate2>><<person2>>by a <<person>> staring at bits of paper through a monocle.<br><br>
"One ID." Briar says, giving your rear a little smack as you walk past.<br><br>
The <<person>> asks you questions and photographs you. After twenty minutes you are in possesion of your ID card.<br><br>
<<link [[Next|Brothel]]>><<endevent>><</link>>
<<elseif $devstate gte 1>>
"I can supply you with a fake ID. But I believe I mentioned it would be expensive, yes? £500 specifically. Don't balk at the cost, these things fool government scanners and border checks. You don't want to take the risk of being caught with a cheap one, believe me."<br><br>
<<if $money gte 50000>>
<<link [[I'll buy one (0:20)|Briar's Office ID]]>><<set $phase to 1>><<set $id to 1>><<pass 20>><<set $money -= 50000>><</link>><br>
<</if>>
<<link [[Leave|Brothel]]>><<endevent>><</link>><br>
<<else>>
<<He>> looks you up and down for a moment, then laughs. "I'm sorry, but no amount of paperwork will convince anyone you're an adult. Wait until you've at least started blossoming, then come see me."<br><br>
<<link [[Next|Brothel]]>><<endevent>><</link>>
<</if>>
:: Brothel Private [nobr]
<<set $outside to 0>><<set $location to "town">><<effects>>
<<if $phase is 0>>
<<set $tipmod to 3>><<tipset>>
<<promiscuity3>>You lead the <<person>> into one of the back rooms. It's well-lit compared to the main room, it takes a moment for your eyes to adjust. There's a small stage with a pole in one corner. There's also a sofa, contoured to allow an extensive range of positions.<br><br>
<<if $rng gte 71>>
Before you can turn around, the <<person>> has their hands wrapped around your waist and their mouth nuzzled against your neck.<br><br>
<<link [[Pull away|Brothel Private]]>><<set $phase to 1>><</link>><br>
<<link [[Try to negotiate while being fondled|Brothel Private]]>><<arousal 6>><<set $phase to 2>><<submission 5>><<garousal>><</link>><br>
<<else>>
The <<person>> stands sheepishly by the door, clearly waiting for you to initiate things.<br><br>
<<set $rng to random(1, 100)>>
<<if $tipreaction is "low">>
You take <<him>> by the hands and sit on the sofa. You negotiate a price of £<<print ($tip / 100)>>, less than you'd hoped.<br><br>
"I know it's not much," <<he>> exclaims, "but it's all I can afford and still eat tomorrow." <<He>> looks down at <<his>> feet.<br><br>
<<if $rng gte 51>>
"Also, if it's okay, I don't want any touching. Well, maybe some, but mainly I'd just like to talk."<br><br>
<<link [[Accept|Brothel Private]]>><<set $phase to 3>><<pass 30>><</link>><br>
<<link [[Refuse|Brothel Private]]>><<set $phase to 4>><</link>><br>
<<else>>
<<link [[Accept|Brothel Private Sex]]>><<set $consensual to 1>><<set $sexstart to 1>><</link>><br>
<<link [[Refuse|Brothel Private]]>><<set $phase to 4>><</link>><br>
<</if>>
<<elseif $tipreaction is "mid">>
You take <<him>> by the hands and sit on the sofa. You negotiate a price of £<<print ($tip / 100)>>, which seems reasonable.<br><br>
<<if $rng gte 51>>
<<He>> speaks softly, "If it's okay, I don't want any touching. Well, maybe some, but mainly I'd just like to talk."<br><br>
<<link [[Accept|Brothel Private]]>><<set $phase to 3>><<pass 30>><</link>><br>
<<link [[Refuse|Brothel Private]]>><<set $phase to 4>><</link>><br>
<<else>>
<<link [[Accept|Brothel Private Sex]]>><<set $consensual to 1>><<set $sexstart to 1>><</link>><br>
<<link [[Refuse|Brothel Private]]>><<set $phase to 4>><</link>><br>
<</if>>
<</if>>
<</if>>
<<elseif $phase is 1>>
<<if $rng gte 21>>
You pull away from the <<personstop>> <<He>> seems frustrated, but it can't be helped. <<set $enemyanger += 20>>
<<if $tipreaction is "low">>
You negotiate a price of £<<print ($tip / 100)>>, less than you'd hoped.<br><br>
"You think you're worth more?" <<He>> laughs, "I can pick up sluts like you for free you know. This is charity, this is."<br><br>
<<link [[Accept|Brothel Private Sex]]>><<set $consensual to 1>><<set $sexstart to 1>><</link>><br>
<<link [[Refuse|Brothel Private]]>><<set $phase to 5>><</link>><br>
<<elseif $tipreaction is "mid">>
You negotiate a price of £<<print ($tip / 100)>>, which seems reasonable.<br><br>
<<link [[Accept|Brothel Private Sex]]>><<set $consensual to 1>><<set $sexstart to 1>><</link>><br>
<<link [[Refuse|Brothel Private]]>><<set $phase to 5>><</link>><br>
<</if>>
<<else>>
You try to pull away from the <<his>> intruding hands, but <<he>> grapples your arms with one hand and clamps down on your mouth with the other.<br><br><<set $enemyanger += 20>>
<<link [[Next|Brothel Private Sex]]>><<set $molestationstart to 1>><</link>><br>
<</if>>
<<elseif $phase is 2>>
<<if $tipreaction is "low">>
Despite <<his>> unrelenting pawing, you manage to negotiate a price of £<<print ($tip / 100)>>, less than you'd hoped.<br><br>
<<elseif $tipreaction is "mid">>
Despite <<his>> unrelenting pawing, you manage to negotiate a price of £<<print ($tip / 100)>>, which seems reasonable.<br><br>
<</if>>
<<link [[Accept|Brothel Private Sex]]>><<set $consensual to 1>><<set $sexstart to 1>><</link>><br>
<<link [[Refuse|Brothel Private]]>><<set $phase to 5>><</link>><br>
<<elseif $phase is 3>>
<<He>> rests <<his>> head on your lap and you gently stroke <<his>> hair. <<He>> talks about mundane topics while you lend a sympathetic ear. Despite the banality of the conversation <<he>> becomes tearful at one point, while mentioning how <<he>> doesn't feel able to open up to <<his>> spouse.<br><br>
After <<his>> thirty minutes are up, <<he>> pays you the agreed fee and thanks you for you time. <<He>> seems genuinely grateful.<br><br><<fameprostitution 1>>
<<clotheson>>
<<link [[Next|Brothel]]>><<set $money += $tip>><<endevent>><</link>>
<<elseif $phase is 4>>
<<He>> nods, eyes downcast. <<He>> doesn't waste any time leaving the room. <br><br>
<<clotheson>>
<<link [[Next|Brothel]]>><<endevent>><</link>>
<<elseif $phase is 5>>
<<set $rng to random(1, 100)>>
<<if $rng gte 21>>
<<He>> looks at you, as if unsure what to do. Finally, <<he>> says "You've probably got something contagious anyway." before leaving the room.<br><br>
<<clotheson>>
<<link [[Next|Brothel]]>><<endevent>><</link>>
<<else>>
<<He>> looks at you blankly for a moment, then laughs. "Good one, now get on your knees before I smack you down!" <<He>> assaults you!<br><br>
<<link [[Next|Brothel Private Sex]]>><<set $molestationstart to 1>><</link>><br>
<</if>>
<</if>>
:: Brothel Private Sex [nobr]
<<if $molestationstart is 1>>
<<set $molestationstart to 0>>
<<controlloss>>
<<violence 1>>
<<neutral 1>>
<<molested>>
<<set $event to "molestationhome">>
<<man1init>>
<<if $phase is 1>>
<<set $lefthand to "arms">>
<<set $leftarm to "grappled">>
<<set $rightarm to "grappled">>
<<set $righthand to "mouth">>
<<set $mouthuse to "grappled">>
<<elseif $phase is 5>>
<<set $enemyanger += 40>>
<</if>>
<<elseif $sexstart is 1>>
<<set $sexstart to 0>>
<<set $consensual to 1>>
<<neutral 1>>
<<set $event to "molestationhome">>
<<man1init>>
<<set $enemytrust += 40>>
<<if $phase is 2>>
"This better be worth it," <<he>> says.
<<else>>
<<set $enemytrust += 40>>
<</if>>
<<if $phase is 1>>
"This better be worth it," <<he>> says.
<<else>>
<<set $enemytrust += 40>>
<</if>>
<</if>>
<<effects>>
<<effectsman>><<man>>
<<stateman>><br>
<br>
<<actionsman>>
<<if $enemyarousal lte $enemyarousalmax and $enemyhealth gte 0 and $alarm lte 0 and $finish is 0>>
<span id="next"><<link [[Next|Brothel Private Sex]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next|Brothel Private Sex Finish]]>><</link>></span><<nexttext>>
<</if>>
:: Brothel Private Sex Finish [nobr]
<<set $outside to 0>><<set $location to "town">><<effects>>
<<if $consensual is 1>>
<<if $enemyarousal gte $enemyarousalmax>>
<<ejaculation>><<set $prostitutionstat += 1>><<fameprostitution 1>>
<<if $phase is 2>>
"Here's your pay, whore," the <<person>> gasps as <<he>> finishes off. <<He>> leaves the room without looking at you.<br><br>
<<tipreceive>>
<<elseif $phase is 1>>
"Here's your pay, whore," the <<person>> gasps as <<he>> finishes off. <<He>> leaves the room without looking at you.<br><br>
<<tipreceive>>
<<else>>
<<He>> smiles in contentment. "Thank you for your time. Here you go." <<He>> gives you a broad smile before leaving the room.<br><br>
<<tipreceive>>
<</if>>
<<else>>
<<if $phase is 2>>
"Fine. I hope you don't expect payment." <<He>> looks at you with disgust before leaving the room.<br><br>
<<elseif $phase is 1>>
"Fine. I hope you don't expect payment." <<He>> looks at you with disgust before leaving the room.<br><br>
<<else>>
"Did I do something wrong? I'm sorry!" <<He>> runs from the room.<br><br>
<</if>>
<</if>>
<<else>>
<<if $enemyarousal gte $enemyarousalmax>>
<<ejaculation>><<fameprostitution 1>>
"Here's your pay, whore," the <<person>> gasps as <<he>> finishes off. They leave the room without looking at you.<br><br>
<<tipreceive>>
<<elseif $enemyhealth lte 0>>
You manage to knock the <<person>> backwards, giving you time to escape. <<tearful>> you flee into the busy main room.<br><br>
<</if>>
<</if>>
<br><br>
<<clotheson>>
<<endcombat>>
<<link [[Next|Brothel]]>><</link>>
:: Brothel Dance Rape [nobr]
<<if $molestationstart is 1>>
<<set $molestationstart to 0>>
<<controlloss>>
<<violence 1>>
<<neutral 1>>
<<set $event to "molestationhome">>
<<man1init>>
<<if $daystate isnot "night">>
<</if>>
<</if>>
<<effects>>
<<effectsman>><<man>>
<<audience>>
<<stateman>><br>
<br>
<<actionsman>>
<<if $alarm is 1>>
<<if $rescue is 1>>
<<else>>
No one comes to your aid.<<set $alarm to 0>>
<<if $drugged is 1>>Intoxicated as you are, you couldn't cry very convincingly.<</if>><br><br>
<<if $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next->Brothel Dance Rape Finish]]>><</link>></span><<nexttext>>
<<elseif $enemyhealth lte 0>>
<span id="next"><<link [[Next->Brothel Dance Rape Finish]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next->Brothel Dance Rape]]>><</link>></span><<nexttext>>
<</if>>
<</if>>
<<elseif $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next->Brothel Dance Rape Finish]]>><</link>></span><<nexttext>>
<<elseif $enemyhealth lte 0>>
<span id="next"><<link [[Next->Brothel Dance Rape Finish]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next->Brothel Dance Rape]]>><</link>></span><<nexttext>>
<</if>>
:: Brothel Dance Rape Finish [nobr]
<<effects>>
<<if $enemyhealth lte 0>>
<<if $daystate isnot "night">>
<<He>> recoils in pain, giving you the chance you need. <<tearful>> you escape into the dressing room. <br><br>
<<else>>
<<He>> recoils in pain, giving you the chance you need. <<tearful>> you escape into the dressing room. <br><br>
<</if>>
<<if $upperoff isnot 0>>
<<uppersteal>>
<</if>>
<<if $loweroff isnot 0>>
<<lowersteal>>
<</if>>
<<if $underoff isnot 0>>
<<understeal>>
<</if>>
<br><br>
<<clotheson>>
<<endcombat>>
[[Next|Brothel Dressing Room]]
<<elseif $enemyarousal gte $enemyarousalmax>>
<<ejaculation>>
<<if $audience is 1>>
A cheer erupts from the crowd as the <<person1>><<person>> climaxes. <<tearful>> you manage to stagger away before anyone else gets ideas.
<<elseif $audience lte 6>>
The <<person1>><<person>> and <<person2>><<person>> highfive each other. <<tearful>> you manage to stagger away while the audience congratulates each other.
<<else>>
A cheer erupts from the crowd, seems they enjoyed the show. <<tearful>> you manage to stagger away before anyone else gets any ideas.
<</if>><br><br>
<<if $upperoff isnot 0>>
<<uppersteal>>
<</if>>
<<if $loweroff isnot 0>>
<<lowersteal>>
<</if>>
<<if $underoff isnot 0>>
<<understeal>>
<</if>>
<br><br>
<<clotheson>>
<<endcombat>>
[[Next|Brothel Dressing Room]]
<</if>>
:: Brothel Punishment [nobr]
<<set $outside to 1>><<set $location to "town">><<effects>>
You're sat down on a bench, and hear the engine start. The hood is pulled off you.<<briar>><<generate2>><<generate3>>
<<if $brothelintro is 1>>
On the seat opposite sits Briar, owner of the brothel. <<person1>><<Hes>> flanked by a <<person2>><<person>> and <<person3>><<personstop>><<person1>><br><br>
<<else>><<set $brothelintro to 1>>
<<if $pronoun is "m">>
On the seat opposite sits a man wearing a blue suit, minus a shirt, showing off his well-toned chest and abdomen. His long chestnut hair hangs loose.
<<else>>
On the seat opposite sits a woman wearing an expensive-looking red gown with a plunging neckline, revealing a portion of her pert breasts. Her long chestnut hair hangs loose.
<</if>><br><br>
<<Hes>> flanked by a <<person2>><<person>> and <<person3>><<personstop>><<person1>> <<He>> stares at you with hazel eyes.<br><br>
"So you're the waif causing me problems. I'm Briar, owner the finest establishment in town." <<He>> leans back on the bench.
<</if>>
"I hear you've been selling yourself in the pub. This is a problem. You see, I own all the whores this side of town. And what has your little ass been up to? Whoring, of course. That means I own you. And yet, I haven't received a penny. That changes now."<br><br>
The van halts and the <<person2>><<person>> and <<person3>><<person>> haul you out. They lead you to a staircase beside a building, descending underground. If you want to escape, now's your only chance. There are three of them however.<<person1>><br><br>
<<link [[Go with them|Brothel Punishment 2]]>><</link>><br>
<<link [[Fight|Brothel Punishment Fight]]>><<set $fightstart to 1>><<set $submissive -= 10>><</link>><br>
:: Brothel Punishment 2 [nobr]
<<set $outside to 0>><<set $location to "town">><<effects>>
You are led down a dim corridor. You can hear music playing somewhere above. The <<person2>><<person>> shoves you through a door into a tiny cell with a hole in the wall, then <<he>> and the <<person3>><<person>> start coiling rope around you. Once your arms and legs are held behind you in a hogtie, they hoist you into the air and tie you to the ceiling, leaving you suspended. <br><br>
"There," says Briar. "Now you're ready to service our customers. Because I'm kind, you'll only need to help five of them." <<He>> ties your neck to a peg beneath the hole, leaving your mouth pressed against it. "Have fun!" <<He>> shuts the door, leaving you in darkness. <br><br>
<<set $leftarm to "bound">>
<<set $rightarm to "bound">>
<<set $head to "bound">>
<<set $feetuse to "bound">>
<<set $punishmenthole to 5>>
<<endevent>>
<<link [[Next|Brothel Punishment Gloryhole]]>><</link>><br>
:: Brothel Punishment Fight [nobr]
<<if $fightstart is 1>>
<<set $fightstart to 0>>
<<neutral 1>>
<<set $event to "molestationhome">>
<<man1init>>
<<set $enemytrust -= 100>>
<<set $enemyanger += 200>>
<<npcidlegenitals>>
At the first sign of resistance, Briar laughs. "Oh little <<girlcomma>> you're not going anywhere." <br><br>
<</if>>
<<effects>>
<<effectsman>><<man>>
<<stateman>><br>
<br>
<<actionsman>>
<<if $enemyhealth lte 0>>
<span id="next"><<link [[Next|Brothel Punishment Fight Finish]]>><</link>></span><<nexttext>>
<<elseif $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next|Brothel Punishment Fight Finish]]>><</link>></span><<nexttext>>
<<elseif $pain gte 100>>
<span id="next"><<link [[Next|Brothel Punishment Fight Finish]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next|Brothel Punishment Fight]]>><</link>></span><<nexttext>>
<</if>>
:: Brothel Punishment Fight Finish [nobr]
<<set $outside to 0>><<set $location to "town">><<effects>>
<<if $enemyarousal gte $enemyarousalmax>>
<<ejaculation>>
"Don't let the <<girl>> escape!" shouts Briar to <<briar>><<his>> goons once <<he>> stops shuddering, but you're already gone. <<tearful>> you flee down the road.<br><br>
<<clotheson>>
<<endcombat>>
<<harvestquick>>
<<elseif $enemyhealth lte 0>>
You knock the <<person2>><<person>> aside, giving you the chance you need. <<tearful>> you run through the gap created and flee down the road. <<briar>>You hear Briar shout at <<his>> subordinates.<<ltrauma>><<lstress>><<trauma -6>><<stress -12>><br><br>
<<clotheson>>
<<endcombat>>
<<harvestquick>>
<<else>>
Briar laughs again. "Aww, is the little <<girl>> hurt?" You're far too injured to resist any longer. The <<person2>><<person>> and <<person3>><<person>> drag you down the staircase.<br><br>
<<link [[Next|Brothel Punishment 2]]>><</link>><br>
<</if>>
:: Brothel Punishment Gloryhole [nobr]
<<set $outside to 0>><<set $location to "town">><<effects>>
<<if $punishmenthole lte 0>>
<<briar>><<person1>>The cell door opens and Briar steps in, holding a knife. <<He>> severs the rope holding you to the ceiling and you fall to the ground. "Now we're even," <<he>> says as <<he>> cuts more rope. "If you want to sell that cute little body of yours in the future, you do so under my roof." <<He>> finishes cutting and steps back. "Is that understood? Good." <<He>> steps aside and a <<generate2>><<person2>><<person>> enters the cell. <<He>> drags you out the way you came in and slams the door behind you. <<briar>>They left your arms bound.<br><br>
<<if $brothelknown isnot 1>>
<<set $brothelknown to 1>><span class="gold">You can now access the Brothel on Harvest Street.</span>
<</if>>
<<clotheson>>
<<endevent>>
<<set $head to 0>>
<<set $feetuse to 0>>
<<link [[Next|Harvest Street]]>><</link>><br>
<<elseif $punishmentposition is "wall">>
You're suspended by rope in a cell, your ass and <<genitals>> poking through a hole in the wall. Strain as you might, you can't move your body an inch.<br><br>
<<set $punishmenthole -= 1>>
<<generate1>><<person1>>
Someone pinches your <<bottomstop>><br><br>
<<link [[Next|Brothel Punishment Molestation]]>><<set $molestationstart to 1>><</link>><br>
<<else>>
You're suspended by rope in a cell, your mouth held against a hole in the wall. Strain as you might, you can't move your body an inch.<br><br>
<<set $punishmenthole -= 1>>
<<generate1>><<person1>>
<<if $vagina is "clothed">>
Someone presses their pussy against the hole, and your lips.<br><br>
<<else>>
Someone sticks their penis through the hole, and against your lips.<br><br>
<</if>>
<<link [[Next|Brothel Punishment Molestation]]>><<set $molestationstart to 1>><</link>><br>
<</if>>
:: Brothel Punishment Molestation [nobr]
<<if $molestationstart is 1>>
<<set $molestationstart to 0>>
<<controlloss>>
<<violence 1>>
<<neutral 1>>
<<molested>>
<<set $event to "molestationhome">>
<<man1init>>
<<if $punishmentposition is "wall">>
<<set $position to "wall">>
<<set $enemyhealthmax to 1000>><<set $enemyhealth to 1000>>
<<else>>
<<npcoral>>
<<set $enemyhealthmax to 10>><<set $enemyhealth to 10>>
<<set $enemyarousal to $enemyarousalmax - 100>>
<<set $lefthand to "none">>
<<set $righthand to "none">>
<<set $mouth to "none">>
<</if>>
<</if>>
<<set $enemyarousal += 10>>
<<effects>>
<<effectsman>><<man>>
<<stateman>><br>
<br>
<<actionsman>>
<<if $enemyhealth lte 0 or $penisbitten is 1>>
<span id="next"><<link [[Next|Brothel Punishment Molestation Finish]]>><</link>></span><<nexttext>>
<<elseif $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next|Brothel Punishment Molestation Finish]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next|Brothel Punishment Molestation]]>><</link>></span><<nexttext>>
<</if>>
:: Brothel Punishment Molestation Finish [nobr]
<<effects>>
<<if $enemyarousal gte $enemyarousalmax>>
<<ejaculation>><<set $forcedprostitutionstat += 1>>
<<tearful>> you mentally prepare for more abuse.<br><br>
<<endcombat>>
<<link [[Next|Brothel Punishment Gloryhole]]>><</link>>
<<else>>
The <<person>> recoils from the hole. You hear <<him>> shout at someone, then silence. <<endevent>><<briar>><<person1>>A minute later Briar opens your cell. "I was so trying to be nice," <<he>> says. "But if you're going to behave so poorly, there's only one option." <<He>> unclips your neck, then pulls a level at the base of the wall. The hole expands several times in size. <<He>> spins you around and presses your behind into the hole, before clipping you in place once more. "There. Now our customers get to enjoy a less violent part of you." <<He>> slams the door shut this time.<br><br>
<<set $punishmenthole += 1>><<pass 1>><<set $punishmentposition to "wall">>
<<endcombat>>
<<link [[Next|Brothel Punishment Gloryhole]]>><</link>><br>
<</if>>
:: Briar's Office Show [nobr]
<<set $outside to 0>><<set $location to "town">><<effects>>
"Good," <<he>> says.
<<if $weekday is 6>>
"There's not enough time to prepare for a show today, but we can hold one next week."
<<else>>
<</if>>
<<He>> rises to <<his>> feet and walks behind <<his>> desk. "We have several options. The first is a simple performance. You flirt with the audience a bit, then invite an audience member, actually an actor, up on stage to fuck you. I'll pay you £600."<br><br>
<<He>> sits down. "Or you could play an uptight school <<girl>> lost in a bad part of town. Gangbang ensues. £1000 for that one. You'll need a school outfit of course. I suspect you already have one." <<He>> smirks. "Would that be too close to home?"<br><br>
<<if $bestialitydisable is "f">>
"Or," <<he>> says. "We could get a pig in from one of the local farms. Then you do nasty things with it for the audience's amusement. I don't know how many would be into it, but it would get tongues flapping. Which is what we want. You'll get £1500 for that."<br><br>
<</if>>
"So what takes your fancy?"<br><br>
<<if $promiscuity lte 54 and $deviancy lte 74>>
You aren't promiscuous or deviant enough to take up any of the offers.<br><br>
<</if>>
<<if $promiscuity gte 55>>
<<link [[Flirt and fuck|Briar's Office Show 2]]>><<set $phase to 0>><</link>><<promiscuous4>><br>
<</if>>
<<if $promiscuity gte 75>>
<<link [[Roleplay gangbang|Briar's Office Show 2]]>><<set $phase to 1>><</link>><<promiscuous5>><br>
<</if>>
<<if $bestialitydisable is "f" and $deviancy gte 75>>
<<link [[Pig|Briar's Office Show 2]]>><<set $phase to 2>><</link>><<deviant5>><br>
<</if>>
<<link [[Leave|Brothel]]>><<endevent>><</link>><br>
:: Briar's Office Show 2 [nobr]
<<set $outside to 0>><<set $location to "town">><<effects>>
<<if $weekday is 6>><<set $brothelshowdone to 1>><</if>>
<<if $phase is 0>><<set $brothelshow to "flirt">>
You agree to flirt with the audience and get fucked on stage. "Alright," <<he>> says. "Just act cute.
<<elseif $phase is 1>><<set $brothelshow to "gangbang">>
You agree to roleplay as a school <<girl>> and get gangbanged on stage. "Don't be nervous about acting," <<he>> says as <<he>> stands up. "That's not what the audience will be there for.
<<elseif $phase is 2>><<set $brothelshow to "pig">>
You agree to fuck a pig on stage. "You're a dirty one," <<he>> says as <<he>> stands up. "This is going to draw them in.
<</if>>
I'll make sure everything's set up nicely.
<<if $weekday is 6>>
There's no time to set it up for today. <span class="gold">We'll be ready next friday.</span>
<</if>>
I'm sure your fans will be excited." <<He>> escorts you to the top of the stairs. "Just makes sure you show up. People are coming to see you. I won't be able to placate them with some random whore."<br><br>
<<link [[Leave|Brothel]]>><<endevent>><</link>><br><br>
:: Brothel Show [nobr]
<<set $outside to 0>><<set $location to "town">><<effects>>
<<briar>><<person1>>
<<if $brothelshow is "flirt">><<set $brothelshow to "none">><<set $brothelshowdone to 1>>
Briar turns to you. "We're all set and ready. Just waiting for the star. Look out for the blue cap." You walk onto the stage. A single white light turns on above you, and the din of the dark room falls quiet. You can't see beyond the edge of the stage, but you can feel the eyes on you.<br><br>
<<endevent>><<generate1>><<person1>>
You flirt with the audience. Your eyes adjust and you just about make them out. You see a <<person>> wearing a blue cap at the front.<br><br>
"I'm so horny," you say. "I can't take it anymore. I need a volunteer." Hands shoot up across the room.<<promiscuity4>><br><br>
<<link [[Point at the actor|Brothel Show Flirt]]>><<set $phase to 0>><</link>><br>
<<link [[Point at a customer|Brothel Show Flirt]]>><<set $phase to 1>><</link>><br>
<<elseif $brothelshow is "gangbang">>
<<if $uppertype is "school" and $lowertype is "school">>
<<set $brothelshow to "none">><<set $brothelshowdone to 1>>Briar turns and beholds you. "Cute. We're all set and ready. There's no script. Try to antagonise the audience a bit." You walk onto the stage. A single white light turns on above you, and the din of the dark room falls quiet. You can't see beyond the edge of the stage, but you can feel the eyes on you.<br><br>
"Ladies and gentlemen," Briar's voice rings throughout the room. "Today we'll witness the tale of the school <<girl>> who wandered into the wrong part of town." Cheers and whistles erupt from the audience. "<<pShes>> top of <<pher>> class, but has no experience outside <<pher>> bubble. What will become of <<phim>> I wonder?"
<<endevent>><<generate1>><<generate2>><<generate3>><<generate4>><<person1>>Four of Briar's other employees climb on beside you. They face each other and feign talking, pretending not to notice you and waiting for your lead.<br><br>
<<link [[Stuck-up|Brothel Show Gangbang]]>><<set $phase to 0>><</link>><br>
<<link [[Lost and scared|Brothel Show Gangbang]]>><<set $phase to 1>><</link>><br>
<<else>>
Briar turns and beholds you. "We're ready. Change into your school uniform and we can begin."<br><br>
<<link [[Next|Brothel]]>><<endevent>><</link>>
<</if>>
<<elseif $brothelshow is "pig">><<set $brothelshow to "none">><<set $brothelshowdone to 1>>
Briar turns to you. "We're all set and ready. Just waiting for the star." The cage beside <<him>> shakes. "The beast is a bit worked up, but I'm sure you can handle it." You walk onto the stage. A single white light turns on above you, and the din of the dark room falls quiet. You can't see beyond the edge of the stage, but you can feel the eyes on you.<br><br>
"Ladies and gentlemen," Briar's voice rings throughout the room. "A special treat for you today. The tale of a <<girl>> lost in the woods, attacked by a ravening beast!" You hear the cage open, and the pig walks onto the stage. A leash is attached to its neck and trails behind the set. It has slack enough to reach you. The audience cheers it on.<<deviancy5>><br><br>
<<endevent>>
<<link [[Next|Brothel Show Pig]]>><<set $sexstart to 1>><</link>><br>
<</if>>
:: Brothel Show Gangbang [nobr]
<<set $outside to 0>><<set $location to "town">><<effects>>
<<if $phase is 0>>
You put your hands on your hips. "This place stinks," you say. You stare out at the audience. "What are you lot looking at? Keep your filthy gaze away from me." The audience responds with a theatric boo. One of Briar's other employees, a <<person1>><<personcomma>> walks towards you and trips, brushing against your leg on the way down. "Ew!" you exclaim. "Get away from me!" You kick at <<his>> head.<br><br>
"You shouldn't treat <<him>> like that," <<person2>>says another of Briar's actors behind you. "Stop it."<br><br>
"I'll treat you scum how I want." You gesture at the audience. "That goes for all of you." The booing redoubles. The <<person1>><<person>> stands up and grabs your arms. The audience cheers. "Let go of me!" You pretend to struggle.<br><br>
"I think it's time you learnt some manners," the <<person1>><<person>> says. The four of them surround you on all sides save the one facing the audience and start groping and probing at your body. You protest as their fingers explore you, dipping between the buttons on your shirt and up your thighs beneath your $lowerclothes.<br><br>
The audience is into it.<br>
"Fuck <<pher>> perfect face."<br>
"Show <<phim>> who's boss."<br>
"Teach <<phim>> what <<pshes>> really good for."<br><br>
Your protests become weaker, and you instead start to moan.<<promiscuity5>><br><br>
<<link [[Next|Brothel Show Gangbang Sex]]>><<set $sexstart to 1>><</link>><br>
<<elseif $phase is 1>>
You adopt a frightened face and look at out at the audience. "I must have taken a wrong turn. I don't know where I am!"<br><br>
One of Briar's actors, a <<person1>><<personcomma>> walks up to you. "Hey little <<girlcomma>> you lost?" <<he>> asks. <<He>> prowls around you, leering at your body.<br><br>
"Rape <<phimcomma>>" someone in the audience shouts.<br><br>
"Y-yes," you say. You hear the other three move closer behind you. "I'm lost and scared and all alone. Will you help me?"<br><br>
The <<person>> laughs. "Sure, we'll help." <<He>> grips your arm as someone else takes the other from behind you. The four of them start groping and probing your body. You protest as their fingers explore you, dipping between the buttons on your shirt and up your thighs beneath your $lowerclothes. It's not long before your resistance gives way to moans of pleasure.<<promiscuity5>>
<<link [[Next|Brothel Show Gangbang Sex]]>><<set $sexstart to 1>><</link>><br>
<</if>>
:: Brothel Show Gangbang Sex [nobr]
<<if $sexstart is 1>>
<<set $sexstart to 0>>
<<consensual>>
<<set $consensual to 1>>
<<neutral 1>>
<<set $event to "molestationhome">>
<<man1init>>
<<set $enemytrust += 100>>
<</if>>
<<effects>>
<<effectsman>><<man>>
<<audience>>
<<stateman>><br>
<br>
<<actionsman>>
<<if $finish is 1>>
<span id="next"><<link [[Next|Brothel Show Gangbang Sex Finish]]>><</link>></span><<nexttext>>
<<elseif $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next|Brothel Show Gangbang Sex Finish]]>><</link>></span><<nexttext>>
<<elseif $enemyhealth lte 0>>
<span id="next"><<link [[Next|Brothel Show Gangbang Sex Finish]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next|Brothel Show Gangbang Sex]]>><</link>></span><<nexttext>>
<</if>>
:: Brothel Show Gangbang Sex Finish [nobr]
<<effects>>
<<if $finish is 1>>
The <<person1>><<person>> steadies you while the others give you space. <<endevent>><<briar>><<person1>>"Why are you stopping?" Briar storms onto the stage. <<He>> glares at you, then seems to remember where <<he>> is. <<He>> smiles at the audience. "Apologies my friends, but that will be all for today." <<He>> ushers you and the others off the stage.<br><br>
<<clotheson>>
<<endcombat>>
<<briar>><<person1>>"Unprofessional," <<he>> says once you're off the stage and out of sight. "Don't expect payment."<<set $briarlove -= 1>><br><br>
<<elseif $enemyarousal gte $enemyarousalmax>>
<<ejaculation>>
<<if $phase is 0>>
<<person1>>"Not so stuck-up now, are ya?" the <<person>> says. They leave you lying on the stage. The audience cheer and applaud as you stand and bow.
<<else>>
"M-more," you whimper. They leave you lying on the stage. The audience cheer and applaud as you stand and bow.
<</if>>
<br><br>
<<clotheson>>
<<endcombat>>
<<briar>><<person1>>Briar's waiting for you behind the stage. "Nice work," <<he>> says.
<<if $phaselast is 0>>
"Everyone likes to see a stuck-up <<girl>> get ruined like that."
<<else>>
"I almost believed your performance myself."
<</if>>
<<He>> hands you the £1000 <<he>> promised.<<set $money += 100000>><<set $briarlove += 1>><br><br>
<<elseif $enemyhealth lte 0>>
You knock the actors away from you and escape from the stage.<br><br>
<<clotheson>>
<<endcombat>>
<<briar>><<person1>>Briar catches you as you pass. "Not so quick," <<he>> says. "Listen." You realise the audience are cheering. "That was unexpected, but they enjoyed it." <<He>> hands you the £1000 <<he>> promised.<<set $money += 100000>><<set $briarlove += 1>><br><br>
<</if>>
<<endevent>>
You return to the dressing room.<br><br>
<<link [[Next|Brothel Dressing Room]]>><</link>>
:: Brothel Show Flirt [nobr]
<<set $outside to 0>><<set $location to "town">><<effects>>
<<if $phase is 0>>
You invite the <<person>> up on stage. <<He>> points at <<his>> chest with a look of astonishment on <<his>> face, then clambers up.<br><br>
"T-take me now," you say. <<He>> nods, and pushes you to your knees.<br><br>
<<link [[Next|Brothel Show Flirt Sex]]>><<set $sexstart to 1>><</link>><br>
<<else>>
<<endevent>>
You invite a <<generate1>><<person1>><<person>> onto the stage. <<He>> trips on <<his>> way to the front, but manages to make it up. <<He>> waves back at someone in the audience.<br><br>
"T-take me now," you say. <<He>> paws at you with clumsy hands.<br><br>
<<link [[Next|Brothel Show Flirt Sex]]>><<set $sexstart to 1>><</link>><br>
<</if>>
:: Brothel Show Flirt Sex [nobr]
<<if $sexstart is 1>>
<<set $sexstart to 0>>
<<consensual>>
<<set $consensual to 1>>
<<neutral 1>>
<<set $event to "molestationhome">>
<<man1init>>
<<set $enemytrust += 100>>
<<if $phase is 0>>
<<npcoral>>
<</if>>
<</if>>
<<effects>>
<<effectsman>><<man>>
<<audience>>
<<stateman>><br>
<br>
<<actionsman>>
<<if $finish is 1>>
<span id="next"><<link [[Next|Brothel Show Flirt Sex Finish]]>><</link>></span><<nexttext>>
<<elseif $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next|Brothel Show Flirt Sex Finish]]>><</link>></span><<nexttext>>
<<elseif $enemyhealth lte 0>>
<span id="next"><<link [[Next|Brothel Show Flirt Sex Finish]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next|Brothel Show Flirt Sex]]>><</link>></span><<nexttext>>
<</if>>
:: Brothel Show Flirt Sex Finish [nobr]
<<effects>>
<<if $finish is 1>>
The <<person1>><<person>> steps away from you. <<endevent>><<briar>><<person1>>"Why are you stopping?" Briar storms onto the stage. <<He>> glares at you, then seems to remember where <<he>> is. <<He>> smiles at the audience. "Apologies my friends, but that will be all for today." <<He>> ushers you off the stage.<br><br>
<<clotheson>>
<<endcombat>>
<<briar>><<person1>>"Unprofessional," <<he>> says once you're off the stage and out of sight. "Don't expect payment."<<set $briarlove -= 1>><br><br>
<<elseif $enemyarousal gte $enemyarousalmax>>
<<ejaculation>>
<<if $phase is 0>>
<<person1>>The <<person>> waves at the audience, then jumps from the stage. The audience cheer and applaud.
<<else>>
<<person1>>"M-more," you whimper. They leave you lying on the stage. The audience cheer and applaud as you stand and bow.
<</if>>
<br><br>
"Thank you to the fine <<if $pronoun is "m">>gentleman<<else>>lady<</if>> who joined me today," you say. "I hope you enjoy your time here." You walk off the stage.<br><br>
<<clotheson>>
<<endcombat>>
<<briar>><<person1>>Briar's waiting for you. "Nice work," <<he>> says.
<<if $phase is 0>>
<<else>>
"Try to pick the right person next time darling," <<he>> says. "The lights are obnoxious but you should be able to see."
<</if>>
<<He>> hands you the £600 <<he>> promised.<<set $money += 60000>><<set $briarlove += 1>><br><br>
<<elseif $enemyhealth lte 0>>
You knock the <<person>> away from you and escape from the stage.<br><br>
<<clotheson>>
<<endcombat>>
<<briar>><<person1>>Briar catches you as you pass. "Not so quick," <<he>> says. "Listen." You realise the audience are cheering. "That was unexpected, but they enjoyed it." <<He>> hands you the £600 <<he>> promised.<<set $money += 60000>><<set $briarlove += 1>><br><br>
<</if>>
<<endevent>>
You return to the dressing room.<br><br>
<<link [[Next|Brothel Dressing Room]]>><</link>>
:: Brothel Show Pig [nobr]
<<if $sexstart is 1>>
<<set $sexstart to 0>>
<<consensual>>
<<set $consensual to 1>>
<<neutral 1>>
<<set $event to "dogpack">>
<<beast1init>><<set $beasttype to "pig">><<set $enemyanger += 50>><<set $enemytrust -= 40>>
<</if>>
<<effects>>
<<effectsman>>
<br><<beast>><br><br>
<<audience>>
<<stateman>><br>
<br>
<<actionsman>>
<<if $finish is 1>>
<span id="next"><<link [[Next|Brothel Show Pig Finish]]>><</link>></span><<nexttext>>
<<elseif $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next|Brothel Show Pig Finish]]>><</link>></span><<nexttext>>
<<elseif $enemyhealth lte 0>>
<span id="next"><<link [[Next|Brothel Show Pig Finish]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next|Brothel Show Pig]]>><</link>></span><<nexttext>>
<</if>>
:: Brothel Show Pig Finish [nobr]
<<effects>>
<<if $finish is 1>>
The pig trots behind the stage as Briar storms onto it.<<endevent>><<briar>><<person1>>"Why are you stopping?"<<He>> glares at you, then seems to remember where <<he>> is. <<He>> smiles at the audience. "Apologies my friends, but that will be all for today." <<He>> ushers you off the stage.<br><br>
<<clotheson>>
<<endcombat>>
<<briar>><<person1>>"Unprofessional," <<he>> says once you're off the stage and out of sight. "Don't expect payment."<<set $briarlove -= 1>><br><br>
<<elseif $enemyarousal gte $enemyarousalmax>>
<<ejaculation>>
Someone behind the stage tugs on the leash and the pig walks off. <<tearful>> you climb to your feet, bow, and follow.<br><br>
<<clotheson>>
<<endcombat>>
<<briar>><<generate2>><<person1>>Briar's waiting for you. "Nice work," <<he>> says. A <<person2>><<person>> struggles to stuff the pig back in its cage beside <<person1>><<himstop>> <<He>> hands you the £1500 <<he>> promised.<<set $money += 150000>><<set $briarlove += 1>><br><br>
<<elseif $enemyhealth lte 0>>
The pig runs away from you in fright. The audience cheers and you follow it off the stage.<br><br>
<<clotheson>>
<<endcombat>>
<<briar>><<person1>>Briar waits for you beside the pig, which hides in its cage. "They weren't expecting to see a <<girl>> fight a pig," <<he>> says. "They seemed to enjoy the spectacle." <<He>> hands you the £1500 <<he>> promised.<<set $money += 150000>><<set $briarlove += 1>><br><br>
<</if>>
<<endevent>>
You return to the dressing room.<br><br>
<<link [[Next|Brothel Dressing Room]]>><</link>>
:: Brothel Stage [nobr]
<<set $outside to 0>><<set $location to "town">><<effects>>
You are behind the largest stage in the brothel. This is where the more involved performances are prepared.<br><br>
<<if $brothelshow isnot "none" and $weekday is 6 and $brothelshowdone isnot 1>>
You see Briar talking to someone near the largest stage. You agreed to perform today.<br><br>
<<link [[Star in show|Brothel Show]]>><</link>><br>
<</if>>
<<link [[Leave|Brothel]]>><</link>><br>
:: Brothel Punishment Rape [nobr]
<<if $molestationstart is 1>>
<<set $molestationstart to 0>>
<<controlloss>>
<<violence 1>>
<<neutral 1>>
<<molested>>
<<set $event to "molestationhome">>
<<set $position to "wall">><<set $head to "bound">>
<<generate1>><<person1>><<man1init>>
<</if>>
<<effects>>
<<effectsman>><<man>>
<<stateman>><br>
<br>
<<actionsman>>
<<if $enemyhealth lte 0>>
<span id="next"><<link [[Next|Brothel Punishment Rape Finish]]>><</link>></span><<nexttext>>
<<elseif $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next|Brothel Punishment Rape Finish]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next|Brothel Punishment Rape]]>><</link>></span><<nexttext>>
<</if>>
:: Brothel Punishment Rape Finish [nobr]
<<set $outside to 0>><<set $location to "town">><<effects>>
<<if $enemyarousal gte $enemyarousalmax>>
<<ejaculation>>
<<He>> gives you a last pinch, then leaves you alone.<br><br>
<<endcombat>><<set $leftarm to "bound">><<set $rightarm to "bound">>
<<else>>
You kick the <<person>> away from you. You hear <<him>> grumble, but <<he>> leaves you alone.<br><br>
<<endcombat>><<set $leftarm to "bound">><<set $rightarm to "bound">>
<</if>>
<<set $punishmenthole -= 1>>
<<if $punishmenthole lte 0>>
<<briar>><<person1>>
The door swings open. Briar walks in. "I hope you've had fun," <<he>> says. <<He>> pulls the lever and the grip around your waist lessens. You wiggle into the room and drop to the floor.<br><br>
"You can show yourself out. Remember, your little ass belongs to me."<br><br>
<<unbind>>
<<clotheson>>
<<endevent>>
<<link [[Next|Harvest Street]]>><<set $eventskip to 1>><</link>><br>
<<elseif $punishmenthole is 5>>
<<briar>><<person1>>
The door swings open. Briar walks in and kneels in front of you, holding a card. It's a picture of your face, with your age and "£10" marked on it. "I thought you'd want to see how they see you," <<he>> nods at the wall your <<bottom>> is stuck in. "If you don't want to be sold so cheap, stop being such a greedy <<girlstop>>" <<He>> rises to <<his>> feet. "Break's over." <<He>> slams the door on <<his>> way out.<br><br>
<<endevent>>
<<link [[Next|Brothel Punishment Rape]]>><<set $molestationstart to 1>><</link>><br>
<<else>>
<<tearful>> you prepare for more abuse. You don't need to wait long.<br><br>
<<link [[Next|Brothel Punishment Rape]]>><<set $molestationstart to 1>><</link>><br>
<</if>>
:: Brothel Pay [nobr]
<<set $outside to 0>><<set $location to "town">><<effects>>
Briar counts the money. "Good," <<he>> nods at <<his>> thugs, who stop blocking the door. "I don't care if you're kidnapped by fucking wolves, next time you'll be there." <<He>> returns to <<his>> office.<br><br>
<<link [[Next|Brothel]]>><<endevent>><</link>><br>
:: Brothel Pay Refuse [nobr]
<<set $outside to 0>><<set $location to "town">><<effects>>
Briar withdraws <<his>> hand. <<He>> nods at <<his>> thugs. "Fine," <<he>> says. "There are other ways you can pay."<br><br>
<<link [[Next|Brothel Pay Strip]]>><<set $molestationstart to 1>><</link>><br>
:: Brothel Pay Strip [nobr]
<<if $molestationstart is 1>>
<<set $molestationstart to 0>>
<<controlloss>>
<<violence 1>>
<<neutral 1>>
<<molested>>
<<set $event to "molestationhome">>
<<man1init>><<npcstrip>><<npcidlegenitals>>
<<set $enemyanger += 200>><<set $enemytrust -= 60>>
<</if>>
<<effects>>
<<effectsman>><<man>>
<<audience>>
<<stateman>><br>
<br>
<<actionsman>>
<<if $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next|Brothel Pay Strip Finish]]>><</link>></span><<nexttext>>
<<elseif $enemyhealth lte 0>>
<span id="next"><<link [[Next|Brothel Pay Strip Finish]]>><</link>></span><<nexttext>>
<<elseif $pain gte 100>>
<span id="next"><<link [[Next|Brothel Pay Strip Finish]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next|Brothel Pay Strip]]>><</link>></span><<nexttext>>
<</if>>
:: Brothel Pay Strip Finish [nobr]
<<set $outside to 0>><<set $location to "town">><<effects>>
<<if $enemyarousal gte $enemyarousalmax>>
<<ejaculation>>
The crowd applauds, as if it were a show. Perhaps they think it was.<br><br>
<<person1>>Briar steadies <<himself>> against a chair. <<He>> looks at the crowd gathered to watch the spectacle and smiles. "You do know how to get their attention," <<he>> says, barely audible over the sound of the music. "Just show up next time." <<He>> returns to <<his>> office.<br><br>
<<clotheson>>
<<endcombat>>
<<link [[Next|Brothel]]>><</link>><br>
<<elseif $enemyhealth lte 0>>
<<person1>>You knock Briar back into a table. <<He>> crashes through it, the drinks on it spilling everywhere. <<His>> thugs don't know what to do. The crowd applauds, as if it were a show. Perhaps they think it was.<br><br>
Briar climbs to <<his>> feet and brushes <<himself>> down. <<He>> looks at the crowd gathered to watch the spectacle and smiles. "You do know how to get their attention," <<he>> says, barely audible over the sound of the music. "Just show up next time." <<He>> returns to <<his>> office.<br><br>
<<clotheson>>
<<endcombat>>
<<link [[Next|Brothel]]>><</link>><br>
<<else>>
<<person1>>You're too hurt to continue fighting, and fall to the ground in a heap. The crowd applauds, as if it were a show. Perhaps they think it is.<br><br>
Briar bows to the audience. "Thank you, thank you," <<he>> says. "And now my friends, feel free to use this whore. On the house." Another cheer, then hands reach out from all around.<br><br>
<<endcombat>>
<<link [[Next|Brothel Pay Rape]]>><<set $molestationstart to 1>><</link>><br>
<</if>>
:: Brothel Pay Rape [nobr]
<<if $molestationstart is 1>>
<<set $molestationstart to 0>>
<<controlloss>>
<<violence 1>>
<<neutral 1>>
<<molested>>
<<set $event to "molestationhome">>
<<generate1>><<generate2>><<generate3>><<generate4>><<generate5>><<generate6>><<man1init>><<person1>>
<</if>>
<<effects>>
<<effectsman>><<man>>
<<audience>>
<<stateman>><br>
<br>
<<actionsman>>
<<if $enemyhealth lte 0>>
<span id="next"><<link [[Next|Brothel Pay Finish]]>><</link>></span><<nexttext>>
<<elseif $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next|Brothel Pay Finish]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next|Brothel Pay Rape]]>><</link>></span><<nexttext>>
<</if>>
:: Brothel Pay Finish [nobr]
<<effects>>
<<if $enemyhealth lte 0>>
Some of the assailants recoil in pain. You crawl through the gap created, and manage to make it to the dressing room unmolested.
<<if $upperoff isnot 0>>
<<uppersteal>>
<</if>>
<<if $loweroff isnot 0>>
<<lowersteal>>
<</if>>
<<if $underoff isnot 0>>
<<understeal>>
<</if>>
<br><br>
<<clotheson>>
<<endcombat>>
[[Next|Brothel Dressing Room]]
<<else>>
<<ejaculation>>
A cheer erupts from the crowd, seems they enjoyed the show. <<tearful>> you escape to the dressing room.<br><br>
<<if $upperoff isnot 0>>
<<uppersteal>>
<</if>>
<<if $loweroff isnot 0>>
<<lowersteal>>
<</if>>
<<if $underoff isnot 0>>
<<understeal>>
<</if>>
<br><br>
<<clotheson>>
<<endcombat>>
[[Next|Brothel Dressing Room]]
<</if>>
|
QuiltedQuail/degrees
|
game/loc-brothel.twee
|
twee
|
unknown
| 56,273 |
:: Bus Station [nobr]
<<set $outside to 1>><<set $location to "town">><<effects>>
You are in the bus station.
<<if $daystate is "day">>
The main building is mostly empty, with the majority of vehicles in use.
<<elseif $daystate is "night">>
The building is packed with parked vehicles.
<<else>>
The main building is mostly empty, with the majority of vehicles in use.
<</if>>
<br><br>
<<if $stress gte 10000>><<passoutstreet>>
<<else>>
<<if $exposed gte 1>><<exhibitionismbuilding>>
<<if $daystate is "night">>
<<set $danger to random(1, 10000)>><<set $dangerindustrial to 0>>
<<if $danger gte (9900 - ($allure)) and $eventskip is 0>><<set $dangerindustrial to random(1, 100)>>
<<if $dangerindustrial gte 1>>
<<busstationex1>>
<</if>>
<<else>>
<<link [[Harvest Street (0:02)->Bus Station Front Door]]>><<pass 2>><</link>><br>
<<link [[Leave via back door (0:02)|Industrial alleyways]]>><<pass 2>><</link>><br><br>
<</if>>
<<else>>
<<set $danger to random(1, 10000)>><<set $dangerindustrial to 0>>
<<if $danger gte (9900 - ($allure * 2)) and $eventskip is 0>><<set $dangerindustrial to random(1, 100)>>
<<if $dangerindustrial gte 1>>
<<busstationex1>>
<</if>>
<<else>>
<<link [[Leave via back door (0:02)|Bus Station Back Door]]>><<pass 2>><</link>><br><br>
<</if>>
<</if>>
<<else>>
<<if $daystate is "night">>
<<link [[Harvest Street (0:02)->Bus Station Front Door]]>><<pass 2>><</link>><br>
<<link [[Leave via back door (0:02)|Bus Station Back Door]]>><<pass 2>><</link>><br><br>
<<else>>
<<link [[Harvest Street (0:02)->Harvest Street]]>><<pass 2>><</link>><br>
<<link [[Leave via back door (0:02)|Bus Station Back Door]]>><<pass 2>><</link>><br><br>
<</if>>
<</if>>
<</if>>
<<set $eventskip to 0>>
:: Bus Station Front Door [nobr]
<<set $outside to 0>><<effects>><<set $lock to 100>>
<<if $skulduggery gte $lock>>
<span class="green">The lock looks easy to pick.</span><br><br>
<<link [[Pick it (0:10)|Harvest Street]]>><<pass 10>><<crime 1>><</link>><<crime>><br>
<<else>>
<span class="red">The lock looks beyond your ability to pick.</span><<skulduggeryrequired>><br><br>
<</if>>
<<link [[Leave|Bus Station]]>><</link>><br>
:: Bus Station Back Door [nobr]
<<set $outside to 0>><<effects>><<set $lock to 0>>
<<if $skulduggery gte $lock>>
<span class="green">The lock looks easy to pick.</span><br><br>
<<link [[Pick it (0:10)|Industrial alleyways]]>><<pass 10>><<crime 1>><</link>><<crime>><br>
<<else>>
<span class="red">The lock looks beyond your ability to pick.</span><<skulduggeryrequired>><br><br>
<</if>>
<<link [[Leave|Bus Station]]>><</link>><br>
:: Bus Station Entrance [nobr]
<<set $outside to 0>><<effects>><<set $lock to 100>>
<<if $skulduggery gte $lock>>
<span class="green">The lock looks easy to pick.</span><br><br>
<<link [[Pick it (0:10)|Bus Station]]>><<pass 10>><<crime 1>><</link>><<crime>><br>
<<else>>
<span class="red">The lock looks beyond your ability to pick.</span><<skulduggeryrequired>><br><br>
<</if>>
<<link [[Leave|Harvest Street]]>><</link>><br>
:: Bus Station Back Entrance [nobr]
<<set $outside to 0>><<effects>><<set $lock to 0>>
<<if $skulduggery gte $lock>>
<span class="green">The lock looks easy to pick.</span><br><br>
<<link [[Pick it (0:10)|Bus Station]]>><<pass 10>><<crime 1>><</link>><<crime>><br>
<<else>>
<span class="red">The lock looks beyond your ability to pick.</span><<skulduggeryrequired>><br><br>
<</if>>
<<link [[Leave|Industrial alleyways]]>><</link>><br>
:: Widgets Bus Station Ex [widget]
<<widget "busstationex1">><<nobr>>
<<generate1>><<generate2>>
<<person1>>You are crouching behind a parked bus when you are accosted from behind!<br><br>
<<link [[Next|Molestation Bus Station]]>><<set $molestationstart to 1>><</link>>
<</nobr>><</widget>>
:: Molestation Bus Station [nobr]
<<if $molestationstart is 1>>
<<set $molestationstart to 0>>
<<controlloss>>
<<violence 1>>
<<neutral 1>>
<<molested>>
<<set $event to "molestationindustrial">>
<<man2init>>
<</if>>
<<effects>>
<<effectsman>><<man>>
<<stateman>><br>
<br>
<<actionsman>>
<<if $alarm is 1>>
<<if $rescue is 1>>
<span id="next"><<link [[Next->Bus Station Alarm]]>><</link>></span><<nexttext>>
<<else>>
No one comes to your aid.<<set $alarm to 0>>
<<if $drugged is 1>>Intoxicated as you are, you couldn't cry very convincingly.<</if>><br><br>
<<if $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next->Bus Station Ejaculation]]>><</link>></span><<nexttext>>
<<elseif $enemyhealth lte 0>>
<span id="next"><<link [[Next->Bus Station Escape]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next->Molestation Bus Station]]>><</link>></span><<nexttext>>
<</if>>
<</if>>
<<elseif $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next->Bus Station Ejaculation]]>><</link>></span><<nexttext>>
<<elseif $enemyhealth lte 0>>
<span id="next"><<link [[Next->Bus Station Escape]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next->Molestation Bus Station]]>><</link>></span><<nexttext>>
<</if>>
:: Bus Station Alarm
Double-click this passage to edit it.
:: Bus Station Ejaculation [nobr]
<<ejaculation>>
<<if $enemyanger gte ($enemyangermax / 5) * 3>>
They give you one last smack to the face, then leave you lying broken on the ground.<<violence 3>><br><br>
<<elseif $enemyanger gte 1>>
Without a word, they leave you lying broken on the ground.<br><br>
<<else>>
Smiling, <<person>> kisses you on the cheek. "This is for you." They get up and leave you lying broken on the ground.<<set $money += 500>><br>
You've gained £5.<br><br>
<</if>>
<<if $underoff isnot 0>>
<<understeal>>
<</if>>
<<tearful>> you rise to your feet.
<<clotheson>>
<<endcombat>>
<<set $eventskip to 1>>
[[Next|Bus Station]]
:: Bus Station Escape [nobr]
<<effects>>
<<He>> recoils in pain, giving you the chance you need to escape. <<tearful>> you escape through the back door, which is fortunately open.<br><br>
<<if $upperoff isnot 0>>
<<uppersteal>>
<</if>>
<<if $loweroff isnot 0>>
<<lowersteal>>
<</if>>
<<if $underoff isnot 0>>
<<understeal>>
<</if>>
<br><br>
<<clotheson>>
<<endcombat>>
<<industrialeventend>>
|
QuiltedQuail/degrees
|
game/loc-bus station.twee
|
twee
|
unknown
| 6,311 |
:: Bus [nobr]
<<set $outside to 0>><<effects>>
You climb aboard the bus. Tickets cost £1.<br><br>
<<if $money gte 100>>
Residential<br>
<<link [[Buy a ticket to Domus Street (Home)|Bus seat]]>><<set $bus to "domus">><<set $money -= 100>><</link>><br>
<<link [[Buy a ticket to Barb Street (Studio)|Bus seat]]>><<set $bus to "barb">><<set $money -= 100>><</link>><br>
<<link [[Buy a ticket to Danube Street (Mansions)|Bus seat]]>><<set $bus to "danube">><<set $money -= 100>><</link>><br>
<<link [[Buy a ticket to Wolf Street (Temple)|Bus seat]]>><<set $bus to "wolf">><<set $money -= 100>><</link>><br>
<br>
Commercial<br>
<<link [[Buy a ticket to High Street (Shopping Centre)|Bus seat]]>><<set $bus to "high">><<set $money -= 100>><</link>><br>
<<link [[Buy a ticket to Connudatus Street (Clubs)|Bus seat]]>><<set $bus to "connudatus">><<set $money -= 100>><</link>><br>
<<link [[Buy a ticket to Cliff Street (Cafe)|Bus seat]]>><<set $bus to "cliff">><<set $money -= 100>><</link>><br>
<<link [[Buy a ticket to Nightingale Street (Hospital)|Bus seat]]>><<set $bus to "nightingale">><<set $money -= 100>><</link>><br>
<<link [[Buy a ticket to Starfish Street (Beach)|Bus seat]]>><<set $bus to "starfish">><<set $money -= 100>><</link>><br>
<<link [[Buy a ticket to Oxford Street (School)|Bus seat]]>><<set $bus to "oxford">><<set $money -= 100>><</link>><br>
<br>
Industrial<br>
<<link [[Buy a ticket to Elk Street|Bus seat]]>><<set $bus to "elk">><<set $money -= 100>><</link>><br>
<<link [[Buy a ticket to Mer Street (Docks)|Bus seat]]>><<set $bus to "mer">><<set $money -= 100>><</link>><br>
<<link [[Buy a ticket to Harvest Street (Pub)|Bus seat]]>><<set $bus to "harvest">><<set $money -= 100>><</link>><br>
<<else>>
You cannot afford the fare.<br><br>
<</if>>
<br><br>
Get off<br>
<<destination>>
:: Widgets Bus [widget]
<<widget "buswait">><<nobr>>
<<link [[Wait for a bus (0:02)|Bus]]>><<pass 2>><</link>><br>
<</nobr>><</widget>>
:: Bus seat [nobr]
<<set $outside to 0>><<effects>>
<<if $weekday isnot 1 and $weekday isnot 7 and $hour gte 7 and $hour lte 8>>
You bus is crowded with children on their way to school.
<<elseif $weekday isnot 1 and $weekday isnot 7 and $hour is 15>>
You bus is crowded with children on their way home from school.
<</if>>
<<if $weather is "rain">>
Rain thuds against the windowpanes.
<</if>>
You take a seat and look out the window.<br><br>
<<if $stress gte 10000>><<passoutbus>>
<<else>>
<<set $dangerbus to 0>>
<<set $danger to random(1, 10000)>>
<<if $danger gte (9900 - $allure)>><<set $dangerbus to random(1, 2)>>
<<if $dangerbus is 1>>
<<generate1>>A <<person1>><<person>> sits down next to you and rests a hand on your leg.<br><br>
<<if $rng gte 61>>
<<link [[Move|Bus move]]>><<set $molestationstart to 1>><</link>><<gharass>><br>
<<else>>
<<link [[Move|Bus move Safe]]>><</link>><<gharass>><br>
<</if>>
<<if $rng gte 81>>
<<link [[Don't move|Bus endure]]>><<set $molestationstart to 1>><</link>><<gtrauma>><<gstress>><br><br>
<<else>>
<<link [[Don't move|Bus endure safe]]>><<trauma 6>><<stress 12>><</link>><<gtrauma>><<gstress>><br><br>
<</if>>
<<elseif $dangerbus is 2>>
<<if $weekday isnot 1 and $weekday isnot 7 and $hour gte 7 and $hour lte 8>>
Some delinquents are picking on the less popular students.<br><br>
<<if $cool lt 80>>
<<generatey1>><<generatey2>><<generatey3>><<person1>>One of them, a <<personcomma>> sits beside you. Two of <<his>> friends, a <<person2>><<person>> and <<person3>><<personcomma>> sit in front of you and lean over the backs of their seats.<br><br>
"We didn't say you could use our bus." Says the <<person1>><<personstop>><br>
"<<pShes>> probably too stupid to know any better." the <<person2>><<person>> interjects.<br>
The <<person3>><<person>> grins at you. "I know," <<he>> says. "How about you <<pullup>> your $upperclothes? Let's see some skin."<br><br>
<<link [[Comply|Bus Comply]]>><<trauma 6>><<stress 12>><<set $submissive += 1>><</link>><<gtrauma>><<gstress>><br>
<<link [[Refuse|Bus Refuse]]>><<set $submissive -= 1>><</link>><br>
<<else>>
Your bus arrives at your destination.<br><br>
<<destination5>>
<</if>>
<<elseif $weekday isnot 1 and $weekday isnot 7 and $hour is 15>>
Some delinquents are picking on the less popular students.<br><br>
<<if $cool lt 80>>
<<generatey1>><<generatey2>><<generatey3>><<person1>>One of them, a <<personcomma>> sits beside you. Two of <<his>> friends, a <<person2>><<person>> and <<person3>><<personcomma>> sit in front of you and lean over the backs of their seats.<br><br>
"We didn't say you could use our bus." Says the <<person1>><<personstop>><br>
"<<pShes>> probably too stupid to know any better." the <<person2>><<person>> interjects.<br>
<<if $playergenderappearance is "m" and $uppertype is "naked">>
"Probably. <<pShe>> even forgot <<pher>> shirt."<br>
"Or maybe <<pshe>> doesn't like wearing clothes at all. Maybe <<pshe>> would like our help removing them."<br><br>
<<if $submissive lte 850>>
"Fuck off," you say, determined to not be bullied.<br><br>
<<elseif $submissive gte 1150>>
You look at your lap and shake your head.<br><br>
<<else>>
"Leave me alone," you say.<br><br>
<</if>>
"I insist," says the <<person1>><<personcomma>> grabbing your $lowerclothes.<br><br>
<<link [[Next|Bus School Strip]]>><<set $molestationstart to 1>><</link>><br>
<<else>>
The <<person3>><<person>> grins at you. "I know," <<he>> says. "How about you <<pullup>> your $upperclothes? Let's see some skin."<br><br>
<<link [[Comply|Bus Comply]]>><<trauma 6>><<stress 12>><<set $submissive += 1>><</link>><<gtrauma>><<gstress>><br>
<<link [[Refuse|Bus Refuse]]>><<set $submissive -= 1>><</link>><br>
<</if>>
<<else>>
Your bus arrives at your destination.<br><br>
<<destination5>>
<</if>>
<<else>>
<<generate1>><<generate2>>The <<people>> in the bus seem to be crowding around you. Some even move seats to be closer.<br><br>
<<if $daystate is "night">>
The bus approaches your destination but doesn't slow down. You stand to tell the driver, but a <<person1>><<person>> blocks your path. "Going so soon?" A <<person2>><<person>> grabs you from behind. "You should know better than to wander at night."<br><br>
<<link [[Next|Bus Seat Rape]]>><<set $molestationstart to 1>><</link>><br>
<<else>>
The bus arrives at your destination. As you walk down the aisle a <<person1>><<person>> grabs your arm. "Don't leave yet, we need some company," <<he>> says as you struggle free. <<catcall>> They laugh as you leave the bus. <<gtrauma>><<gstress>><<trauma 6>><<stress 12>><br><br>
<<endevent>>
<<destination5>>
<</if>>
<</if>>
<</if>>
<<else>>
Your bus arrives at your destination.<br><br>
<<destination5>>
<</if>>
<</if>>
:: Stripped Bus [nobr]
<<controlloss>><<effects>>
You feel strangely cold as you awaken. You are still on the bus. You are about to stand up when you realise that you are completely naked! You frantically search for your clothing, but can find nothing. You cautiously look around the bus. No one seems to have noticed your predicament.<br><br>
<<if $daystate is "night">>
It's dark out and there are only a few people on the streets. You might be able to slip out the window at the next stop. Alternatively, you could hide under a seat and wait until the bus returns to the station.<br><br>
<<link [[Climb out (0:05)|Climb Out Bus]]>><<pass 5>><</link>><br>
<<link [[Wait (1:00)|Bus Station]]>><<pass 1 hour>><</link>>
<br><br>
<<else>>
You peek out the window and see numerous pedestrians. You can't think of any option other than hiding under a seat and waiting until the bus returns to station.<br><br>
<<link [[Wait (1:00)|Bus Station]]>><<pass 1 hour>><</link>>
<br><br>
<</if>>
:: Molestation bus [nobr]
<<if $molestationstart is 1>>
<<set $molestationstart to 0>>
<<controlloss>>
<<violence 1>>
<<neutral 1>>
<<molested>>
<<set $event to "molestationbus">>
<<generate1>><<molestbusinit>>You feel something probing your nethers. As you open your eyes a hand clasps down on your mouth, muffling your screams.<br>
<</if>>
<<effects>>
<<effectsman>><<man>>
<<stateman>><br>
<br>
<<actionsman>>
<<if $alarm is 1>>
<<if $rescue is 1>>
<span id="next"><<link [[Next->Molestation bus Alarm]]>><</link>></span><<nexttext>>
<<else>>
No one comes to your aid.<<set $alarm to 0>> There's no one else on the bus.
<<if $drugged is 1>>Intoxicated as you are, you couldn't cry very convincingly.<</if>><br><br>
<<if $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next->Molestation bus Ejaculation]]>><</link>></span><<nexttext>>
<<elseif $enemyhealth lte 0>>
<span id="next"><<link [[Next->Molestation bus Escape]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next->Molestation bus]]>><</link>></span><<nexttext>>
<</if>>
<</if>>
<<elseif $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next->Molestation bus Ejaculation]]>><</link>></span><<nexttext>>
<<elseif $enemyhealth lte 0>>
<span id="next"><<link [[Next->Molestation bus Escape]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next->Molestation bus]]>><</link>></span><<nexttext>>
<</if>>
:: Stranger rescue bus [nobr]
<<effects>><<pass 1 hour>><<set $hunger -= 500>><<set $thirst -= 500>><<set $stress -= 500>>
You feel someone shaking your shoulder. You look around and see an old woman smiling at you. She pours you a cup of tea from a flask and gives you a chocolate bar, letting you know that it's important to not let your blood-sugar levels drop too low. You thank her and shortly after the bus arrives at your destination.<br><br>
She waves from the window as the bus continues on.<br><br>
<<destination>>
:: Bus move [nobr]
<<if $molestationstart is 1>>
<<set $molestationstart to 0>>
<<controlloss>>
<<violence 1>>
<<neutral 1>>
<<molested>>
<<set $event to "busmove">>
<<busmoveinit>>As you try to pass <<he>> grabs your waist and forces you onto <<his>> lap.<br>
<<set $rescue to 1>>
<</if>>
<<effects>>
<<effectsman>><<man>>
<<stateman>><br>
<br>
<<actionsman>>
<<if $alarm is 1>>
<<if $rescue is 1>>
<span id="next"><<link [[Next->Bus move Alarm]]>><</link>></span><<nexttext>>
<<else>>
No one comes to your aid.<<set $alarm to 0>>
<<if $drugged is 1>>Intoxicated as you are, you couldn't cry very convincingly.<</if>><br><br>
<<if $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next->Bus move Ejaculation]]>><</link>></span><<nexttext>>
<<elseif $enemyhealth lte 0>>
<span id="next"><<link [[Next->Bus move Escape]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next->Bus move]]>><</link>></span><<nexttext>>
<</if>>
<</if>>
<<elseif $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next->Bus move Ejaculation]]>><</link>></span><<nexttext>>
<<elseif $enemyhealth lte 0>>
<span id="next"><<link [[Next->Bus move Escape]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next->Bus move]]>><</link>></span><<nexttext>>
<</if>>
:: Bus move Safe [nobr]
<<set $outside to 0>><<effects>>
You stand up and shuffle past the <<personcomma>> who doesn't stop you.<br><br>
The bus soon arrives at your destination.<br><br>
<<endevent>>
<<destination5>>
:: Bus endure safe [nobr]
<<set $outside to 0>><<effects>>
You remain seated. The <<persons>> hand moves to your inner thigh. <<He>> creeps closer to your crotch over the next couple of minutes, but stops when the bus arrives at <<his>> destination. It arrives at yours soon after.<br><br>
<<endevent>>
<<destination5>>
:: Bus Comply [nobr]
<<set $outside to 0>><<effects>>
You feel their hungry eyes as you <<pullup>> your $upperclothes, revealing your <<breastsstop>>
<<if $playergenderappearance is "m">>
"Don't be shy," says the <<person1>><<person>> as <<he>> reaches out and pinches your right nipple.
<<elseif $breastsize lte 2>>
"You call those pathetic things breasts?" says the <<person1>><<person>> as <<he>> reaches out and pinches your right nipple.
<<elseif $breastsize lte 5>>
"I knew you had nice boobs," says the <<person1>><<person>> as <<he>> reaches out and squeezes your right breast.
<<else>>
"Look at the size of them," says the <<person1>><<person>> as <<he>> reaches out and squeezes your right breast.
<</if>>
The other two join in bullying your exposed chest. Trapped in the corner, you can do nothing but endure and hope no one else can see your humiliation.<br><br>
After several minutes the bus stop and the <<person2>><<person>> pokes the <<person1>><<personstop>> "We need to get off here." They give your <<breasts>> one last slap before leaving. The bus arrives at your destination soon after.<br><br>
<<set $pain += 30>>
<<endevent>>
<<destination5>>
:: Bus Refuse [nobr]
<<set $outside to 0>><<effects>>
<<if $submissive lte 850>>
"Fuck off," you say, determined to not be bullied.<br><br>
<<elseif $submissive gte 1150>>
You look at your lap and shake your head.<br><br>
<<else>>
"Leave me alone," you say.<br><br>
<</if>>
"I insist," says the <<person1>><<personcomma>> grabbing your $upperclothes.<br><br>
<<link [[Next|Bus School Strip]]>><<set $molestationstart to 1>><</link>><br>
:: Bus School Strip [nobr]
<<if $molestationstart is 1>>
<<set $molestationstart to 0>>
<<controlloss>>
<<violence 1>>
<<neutral 1>>
<<molested>>
<<set $event to "molestationhome">>
<<man1init>><<npcstrip>><<npcidlegenitals>>
<<set $timer to 15>>
<<if $delinquency lt 400>><<set $rescue to 1>><</if>>
<</if>>
<<effects>>
<<effectsman>><<man>>
<<if $alarm is 1 and $rescue is 0>><<set $alarm to 0>>
No one comes to your aid, likely due to your reputation as a delinquent.<br><br>
<</if>>
<<stateman>><br>
<br>
<<actionsman>>
<<if $timer lte 1>>
<span id="next"><<link [[Next|Bus School Strip Finish]]>><</link>></span><<nexttext>>
<<elseif $alarm is 1 and $rescue is 1>>
<span id="next"><<link [[Next|Bus School Strip Finish]]>><</link>></span><<nexttext>>
<<elseif $uppertype is "naked" and $lowertype is "naked" and $undertype is "naked">>
<span id="next"><<link [[Next|Bus School Strip Finish]]>><</link>></span><<nexttext>>
<<elseif $uppertype is "naked" and $lowertype is "naked" and $undertype is "chastity">>
<span id="next"><<link [[Next|Bus School Strip Finish]]>><</link>></span><<nexttext>>
<<elseif $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next|Bus School Strip Finish]]>><</link>></span><<nexttext>>
<<elseif $enemyhealth lte 0>>
<span id="next"><<link [[Next|Bus School Strip Finish]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next|Bus School Strip]]>><</link>></span><<nexttext>>
<</if>>
:: Bus School Strip Finish [nobr]
<<if $enemyhealth lte 0>>
The <<person1>><<person>> falls back into the aisle and the other two pull away from you. "Come on," <<he>> says. "This psycho isn't worth it."<br><br>
<<clotheson>>
<<endcombat>>
The bus soon arrives at your destination.<br><br>
<<destination5>>
<<elseif $enemyarousal gte $enemyarousalmax>>
<<ejaculation>>
"You're good for something at least." <<tearful>> you gather yourself as the three of them find someone else to harass.<br><br>
<<clotheson>>
<<endcombat>>
The bus soon arrives at your destination.<br><br>
<<destination5>>
<<elseif $alarm is 1 and $rescue is 1>>
"Stop the tomfoolery back there, or I'll come sort you out," says the <<generate4>><<person4>><<person>> driving the bus. The trio relent in their attack.<br><br>
<<clotheson>>
<<endcombat>>
The bus soon arrives at your destination.<br><br>
<<destination5>>
<<elseif $timer lte 0>>
The bus pulls to a stop. "We need to get off here," says the <<person2>><<personstop>>
<<if $upperoff is 0 and $loweroff is 0 and $underoff is 0>>
<<else>><<stealclothes>>
They leave the bus, taking your clothes with them.
<</if>>
<<if $exposed gte 1>>
<<clotheson>>
<<endcombat>>
<<tearful>> you sink into your seat to avoid being seen.<br><br>
You'll arrive at your destination soon, but you can't leave like this. The bus must return to the station at some point.<br><br>
<<link [[Ask someone for help|Bus School Strip Help]]>><<trauma 6>><<stress 12>><</link>><<gtrauma>><<gstress>><br>
<<link [[Wait (1:00)|Bus Station]]>><<pass 1 hour>><</link>>
<<else>>
<<tearful>> you settle back into your seat.<br><br>
<<clotheson>>
<<endcombat>>
The bus soon arrives at your destination.<br><br>
<<destination5>>
<</if>>
<<else>>
"Much better," says the <<person1>><<personstop>> "Now everyone can see you." The bus comes to a halt. "That's our stop. See you later, slut." They take your clothes with them.<br><br>
<<stealclothes>>
<<clotheson>>
<<endcombat>>
<<tearful>> you sink into your seat to avoid being seen.<br><br>
You'll arrive at your destination soon, but you can't leave like this. The bus must return to the station at some point.<br><br>
<<link [[Ask someone for help|Bus School Strip Help]]>><<trauma 6>><<stress 12>><</link>><<gtrauma>><<gstress>><br>
<<link [[Wait (1:00)|Bus Station]]>><<pass 1 hour>><</link>>
<</if>>
:: Bus School Strip Help [nobr]
<<set $outside to 0>><<effects>>
Keeping low, you shuffle into the aisile and poke a <<generatey1>><<person1>><<person>> in the arm and return to your seat. <<He>> looks over <<his>> shoulder.
<<if $submissive gte 1150>>
"I-I need some towels. Please help," you say, unable to make eye contact.
<<elseif $submissive lte 850>>
"Gimme some towels. Quickly," you demand.
<<else>>
"Do you have any towels I can cover up with?" you ask.
<</if>>
<br><br>
<<if $rng gte 81>>
"Why would you-" <<he>> begins before realising your predicament and smiling. "I'll help, but I want a look at you first."<br><br>
<<if $submissive gte 1150>>
"Please don't make me,"
<<elseif $submissive lte 850>>
"Fuck off,"
<<else>>
"Don't be a pervert,"
<</if>>
you say, but <<he>> moves to the seat opposite you. <<covered>><br><br>
<<if $leftarm is "bound" and $rightarm is "bound">>
<<He>> laughs. "I was right. Now turn around so I can see you properly.
<<else>>
<<He>> laughs. "I was right. Move your hands so I can see you properly.
<</if>>
If you don't, I'll let the rest of the bus know and we can all get a look."<br><br>
<<link [[Comply|Bus School Strip Comply]]>><<submissive1>><<trauma 6>><<stress 12>><<fameexhibitionism 1>><</link>><br>
<<link [[Refuse|Bus School Strip Refuse]]>><<detention 1>><<defiant1>><<trauma 6>><<stress 12>><</link>><<gdelinquency>><br>
<<else>>
"Why would you-" <<he>> says, before blushing in realisation. <<He>> rummages in <<his>> back and throws some towels at you.<br><br>
<<towelup>>
<<endevent>>
The bus soon arrives at your destination.<br><br>
<<destination5>>
<</if>>
:: Bus School Strip Comply [nobr]
<<set $outside to 0>><<effects>>
<<if $leftarm is "bound" and $rightarm is "bound">>
You turn your body, baring your <<lewdness>> to the <<personstop>>
<<else>>
You move your arms out of the way, baring your <<lewdness>> to the <<personstop>>
<</if>>
<<He>> stares at you with hungry eyes and reaches out, but you recoil from <<his>> hand. <<He>> doesn't continue, thinking <<hes>> pushed <<his>> luck far enough.<br><br>
"Here you go," <<he>> says as <<he>> throws you some towels. "That wasn't so bad, was it?" <<He>> returns to <<his>> seat.<br><br>
<<towelup>>
<<endevent>>
The bus soon arrives at your destination.<br><br>
<<destination5>>
:: Bus School Strip Refuse [nobr]
<<set $outside to 0>><<effects>>
<<fameexhibitionism 20>>
<<He>> stands up. "Everyone, this <<girl>> isn't wearing anything!" <<he>> bellows, causing heads all over the bus to turn your way. You shrink in your seat, but it only enflames curiosity in your new audience. "Come have a look!"<br><br>
A <<generatey2>><<person2>><<person>> leans over the seat behind you. <<person1>>"<<Hes>> not lying. Come look." You're fortunate than none have the daring to assault you further, but the rest of the journey is miserable as they crowd and jeer.<br><br>
<<generate3>><<person3>>The bus comes to a stop at your destination and the driver climbs out of <<his>> seat. "Everyone away from <<phimcomma>> now." The kids start shuffling off the bus with some reluctance, lingering as long as they can. The driver, a <<personcomma>> throws you some towels. "I don't ever want to catch you slutting up my bus again. I'm letting the teachers know."<br><br>
There's not much to do but cover up and leave the bus.<br><br>
<<towelup>>
<<endevent>>
<<destination5>>
:: Bus Seat Rape [nobr]
<<if $molestationstart is 1>>
<<set $molestationstart to 0>>
<<controlloss>>
<<violence 1>>
<<neutral 1>>
<<molested>>
<<set $event to "molestationhome">>
<<man1init>>
<<set $enemyanger += 40>>
<<set $enemytrust -= 40>>
<</if>>
<<effects>>
<<effectsman>><<man>>
<<audience>>
<<stateman>><br>
<br>
<<actionsman>>
<<if $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next|Bus Seat Rape Finish]]>><</link>></span><<nexttext>>
<<elseif $enemyhealth lte 0>>
<span id="next"><<link [[Next|Bus Seat Rape Finish]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next|Bus Seat Rape]]>><</link>></span><<nexttext>>
<</if>>
:: Bus Seat Rape Finish [nobr]
<<if $enemyhealth lte 0>>
You knock the <<person1>><<person>> down, giving you a clear route out. <<tearful>> you run to the front of the bus.
<<if $submissive lte 850>>
"Let me off or I'll mess you up too," you say,
<<elseif $submissive gte 1150>>
"Please stop the bus," you say,
<<else>>
"Let me off!" you say,
<</if>>
aware that the <<person>> and <<his>> friends won't take long to recover. The driver doesn't respond.<br><br>
You open the door and look out at the town racing by. Jumping would be dangerous. You glance back at the <<people>> coming for you. You don't have long.<br><br>
<<link [[Jump|Bus Seat Rape Jump]]>><</link>><br>
<<if $submissive lte 500>>
<<link [[Punch the driver|Bus Seat Rape Punch]]>><<crime 100>><</link>><<crime>><br>
<</if>>
<<elseif $enemyarousal gte $enemyarousalmax>>
<<ejaculation>>
The bus stops and the group push you towards the door. They shove you out and drive away, jeering at you through the windows.
<<if $upperoff is 0 and $loweroff is 0 and $underoff is 0>>
<<else>>
They kept your clothes.
<</if>>
<<if $exposed gte 1>>
<<tearful>> you hide behind a car before you're seen.<br><br>
<<else>>
<<tearful>> you try to work out where you are.<br><br>
<</if>>
<<stealclothes>>
<<clotheson>>
<<endcombat>>
<<set $rng to random(1, 13)>>
<<if $rng is 1>>
<<set $bus to "nightingale">>
<<elseif $rng is 2>>
<<set $bus to "domus">>
<<elseif $rng is 3>>
<<set $bus to "elk">>
<<elseif $rng is 4>>
<<set $bus to "high">>
<<elseif $rng is 5>>
<<set $bus to "starfish">>
<<elseif $rng is 6>>
<<set $bus to "barb">>
<<elseif $rng is 7>>
<<set $bus to "connudatus">>
<<elseif $rng is 8>>
<<set $bus to "wolf">>
<<elseif $rng is 9>>
<<set $bus to "harvest">>
<<elseif $rng is 10>>
<<set $bus to "oxford">>
<<elseif $rng is 11>>
<<set $bus to "danube">>
<<elseif $rng is 12>>
<<set $bus to "mer">>
<<elseif $rng is 13>>
<<set $bus to "cliff">>
<</if>>
<<destination>>
<</if>>
:: Bus Seat Rape Jump [nobr]
<<effects>>
You leap from the bus. You land rolling on a patch of grass. <<tearful>> you struggle to your feet.<<set $pain += 60>>
<<clotheson>>
<<endcombat>>
<<set $rng to random(1, 13)>>
<<if $rng is 1>>
<<set $bus to "nightingale">>
<<elseif $rng is 2>>
<<set $bus to "domus">>
<<elseif $rng is 3>>
<<set $bus to "elk">>
<<elseif $rng is 4>>
<<set $bus to "high">>
<<elseif $rng is 5>>
<<set $bus to "starfish">>
<<elseif $rng is 6>>
<<set $bus to "barb">>
<<elseif $rng is 7>>
<<set $bus to "connudatus">>
<<elseif $rng is 8>>
<<set $bus to "wolf">>
<<elseif $rng is 9>>
<<set $bus to "harvest">>
<<elseif $rng is 10>>
<<set $bus to "oxford">>
<<elseif $rng is 11>>
<<set $bus to "danube">>
<<elseif $rng is 12>>
<<set $bus to "mer">>
<<elseif $rng is 13>>
<<set $bus to "cliff">>
<</if>>
<<destination>>
:: Bus Seat Rape Punch [nobr]
<<effects>>
You grip a pole with one hand and punch the driver in the jaw.<<He>> brakes, but the bus swerves off the road, colliding with the corner of a building before coming to a stop. The impact knocks everyone to the ground. <<tearful>> you escape the bus and run round a corner, away from view.
<<clotheson>>
<<endcombat>>
<<set $rng to random(1, 13)>>
<<if $rng is 1>>
<<set $bus to "nightingale">>
<<elseif $rng is 2>>
<<set $bus to "domus">>
<<elseif $rng is 3>>
<<set $bus to "elk">>
<<elseif $rng is 4>>
<<set $bus to "high">>
<<elseif $rng is 5>>
<<set $bus to "starfish">>
<<elseif $rng is 6>>
<<set $bus to "barb">>
<<elseif $rng is 7>>
<<set $bus to "connudatus">>
<<elseif $rng is 8>>
<<set $bus to "wolf">>
<<elseif $rng is 9>>
<<set $bus to "harvest">>
<<elseif $rng is 10>>
<<set $bus to "oxford">>
<<elseif $rng is 11>>
<<set $bus to "danube">>
<<elseif $rng is 12>>
<<set $bus to "mer">>
<<elseif $rng is 13>>
<<set $bus to "cliff">>
<</if>>
<<destination>>
:: Bus endure [nobr]
<<if $molestationstart is 1>>
<<set $molestationstart to 0>>
<<controlloss>>
<<violence 1>>
<<neutral 1>>
<<molested>>
<<set $event to "busendure">>
<<lefthandinit>><<He>> becomes bolder and begins to surreptitiously masturbate.<br>
<<set $rescue to 1>>
<</if>>
<<effects>>
<<effectsman>><<man>>
<<stateman>><br>
<br>
<<actionsman>>
<<if $alarm is 1>>
<<if $rescue is 1>>
<span id="next"><<link [[Next->Bus endure Alarm]]>><</link>></span><<nexttext>>
<<else>>
No one comes to your aid.<<set $alarm to 0>> There's no one else on the bus.
<<if $drugged is 1>>Intoxicated as you are, you couldn't cry very convincingly.<</if>><br><br>
<<if $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next->Bus endure Ejaculation]]>><</link>></span><<nexttext>>
<<elseif $enemyhealth lte 0>>
<span id="next"><<link [[Next->Bus endure Escape]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next->Bus endure]]>><</link>></span><<nexttext>>
<</if>>
<</if>>
<<elseif $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next->Bus endure Ejaculation]]>><</link>></span><<nexttext>>
<<elseif $enemyhealth lte 0>>
<span id="next"><<link [[Next->Bus endure Escape]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next->Bus endure]]>><</link>></span><<nexttext>>
<</if>>
:: Bus endure Alarm [nobr]
<<effects>>
<<He>> notices several heads turning in response to your cry, and relents in <<his>> assault. <<He>> leaves at the next stop, and you soon arrive at your own. <<tearful>> you leave the bus.<br><br>
<<clotheson>>
<<endcombat>>
<<destination5>>
:: Bus endure Ejaculation [nobr]
<<effects>>
<<ejaculation>>
<<He>> tenses during <<his>> climax, apparently just in time for <<his>> stop. <<He>> leaves abruptly, and you soon arrive at your own stop. <<tearful>> you leave the bus.<br><br>
<<clotheson>>
<<endcombat>>
<<destination5>>
:: Bus endure Escape [nobr]
<<effects>>
<<He>> recoils in pain as you arrive your destination. <<tearful>> you seize the oppurtunity and dart out the vehicle.<br><br>
<<if $upperoff isnot 0>>
<<uppersteal>>
<</if>>
<<if $loweroff isnot 0>>
<<lowersteal>>
<</if>>
<<if $underoff isnot 0>>
<<understeal>>
<</if>>
<br><br>
<<clotheson>>
<<endcombat>>
<<destination5>>
:: Bus move Alarm [nobr]
<<effects>>
<<He>> notices several heads turning in response to your cry, and relents in <<his>> assault. <<He>> leaves at the next stop, and you soon arrive at your own. <<tearful>> you leave the bus.<br><br>
<<clotheson>>
<<endcombat>>
<<destination5>>
:: Bus move Ejaculation [nobr]
<<effects>>
<<He>> tenses and a wet blotch forms on <<his>> trousers, apparently just in time for <<his>> stop. <<He>> leaves abruptly, and you soon arrive at your own stop. <<tearful>> you leave the bus. <br><br>
<<clotheson>>
<<endcombat>>
<<destination5>>
:: Bus move Escape [nobr]
<<effects>>
<<He>> recoils in pain as you arrive at your destination. <<tearful>> you seize the oppurtunity and dart out the vehicle.<br><br>
<<if $upperoff isnot 0>>
<<uppersteal>>
<</if>>
<<if $loweroff isnot 0>>
<<lowersteal>>
<</if>>
<<if $underoff isnot 0>>
<<understeal>>
<</if>>
<br><br>
<<clotheson>>
<<endcombat>>
<<destination5>>
:: Climb Out Bus [nobr]
The bus slows to round a corner. You take the opportunity to slip out unnoticed.<br><br>
<<starfishquick>>
:: Molestation bus Alarm [nobr]
<<effects>>
<<He>> notices several heads turning in response to your cry, and relents in his assault. <<He>> hurriedly leaves at the next stop, and you arrive at your own soon after. <<tearful>> you leave the bus.<br><br>
<<clotheson>>
<<endcombat>>
<<set $stress -= 1000>><<set $eventskip to 1>>
<<destination>>
:: Molestation bus Ejaculation [nobr]
<<effects>>
<<ejaculation>>
<<if $enemyanger gte ($enemyangermax / 5) * 3>>
<<He>> gives you one last smack to the face, then leaves you lying on the cum-stained seat.<<violence 3>><br><br>
<<elseif $enemyanger gte 1>>
Without a word, <<he>> gets up and leaves you lying on the cum-stained seat.<br><br>
<<else>>
Smiling, <<he>> kisses you on the cheek. "This is for you." <<He>> gets up and leaves you lying on the cum-stained seat.<<set $money += 500>><br>
You've gained £5.<br><br>
<</if>>
You soon arrive at your stop. <<tearful>> you leave the bus.<br><br>
<<clotheson>>
<<endcombat>>
<<set $stress -= 1000>><<set $eventskip to 1>>
<<destination>>
:: Molestation bus Escape [nobr]
<<effects>>
<<He>> recoils in pain as you arrive your destination. <<tearful>> you seize the opportunity and dart out the vehicle.<br><br>
<<if $upperoff isnot 0>>
<<uppersteal>>
<</if>>
<<if $loweroff isnot 0>>
<<lowersteal>>
<</if>>
<<if $underoff isnot 0>>
<<understeal>>
<</if>>
<br><br>
<<clotheson>>
<<endcombat>>
<<set $stress -= 1000>><<set $eventskip to 1>>
<<destination>>
:: Passout bus [nobr]
You've pushed yourself too much.<br><br>
<<passout>>
<<set $safebus to 0>>
<<set $dangerbus to 0>>
<<set $danger to random(1, 10000)>>
<<if $danger gte (9900 - $allure)>><<set $dangerbus to random(1, 2)>><</if>>
<<if $danger lt (9900 - $allure)>><<set $safebus to random(1, 2)>><</if>>
<<if $dangerbus eq 1>>
[[Wake up|Stripped Bus]]
<<elseif $dangerbus eq 2>>
<<link [[Wake up|Molestation bus]]>>
<<set $molestationstart to 1>>
<</link>><</if>>
<<if $safebus eq 1>>
[[Wake up|Stranger rescue bus]]
<<elseif $safebus eq 2>>
<<ambulance>>
<</if>>
<<pass 1 hour>>
<<set $trauma +=10>><<set $stress -= 2000>>
:: Widget Passout Bus [widget]
<<widget "passoutbus">><<nobr>>
[[Everything fades to black...->Passout bus]]
<</nobr>><</widget>>
:: Widgets Destination [widget]
<<widget "destination">><<nobr>>
<<if $bus is "nightingale">>
<<nightingalequick>><br><br>
<</if>>
<<if $bus is "domus">>
<<domusquick>><br><br>
<</if>>
<<if $bus is "elk">>
<<elkquick>><br><br>
<</if>>
<<if $bus is "high">>
<<highquick>><br><br>
<</if>>
<<if $bus is "starfish">>
<<starfishquick>><br><br>
<</if>>
<<if $bus is "barb">>
<<barbquick>><br><br>
<</if>>
<<if $bus is "connudatus">>
<<connudatusquick>><br><br>
<</if>>
<<if $bus is "wolf">>
<<wolfquick>><br><br>
<</if>>
<<if $bus is "harvest">>
<<harvestquick>><br><br>
<</if>>
<<if $bus is "oxford">>
<<oxfordquick>><br><br>
<</if>>
<<if $bus is "danube">>
<<danubequick>><br><br>
<</if>>
<<if $bus is "mer">>
<<merquick>><br><br>
<</if>>
<<if $bus is "cliff">>
<<cliffquick>><br><br>
<</if>>
<<if $bus is "industrial">>
<<industrialquick>><br><br>
<</if>>
<<if $bus is "residential">>
<<residentialquick>><br><br>
<</if>>
<<if $bus is "commercial">>
<<commercialquick>><br><br>
<</if>>
<<if $bus is "park">>
<<parkquick>><br><br>
<</if>>
<<if $bus is "industrialdrain">>
<<industrialdrainquick>><br><br>
<</if>>
<<if $bus is "residentialdrain">>
<<residentialdrainquick>><br><br>
<</if>>
<<if $bus is "commercialdrain">>
<<commercialdrainquick>><br><br>
<</if>>
<<if $bus is "seabeach">>
<<seabeachquick>><br><br>
<</if>>
<<if $bus is "searocks">>
<<searocksquick>><br><br>
<</if>>
<<if $bus is "seadocks">>
<<seadocksquick>><br><br>
<</if>>
<<if $bus is "seacliffs">>
<<seacliffsquick>><br><br>
<</if>>
<<if $bus is "drainexit">>
<<drainexitquick>><br><br>
<</if>>
<<if $bus is "sea">>
<<seamovequick>><br><br>
<</if>>
<</nobr>><</widget>>
<<widget "destination5">><<nobr>>
<<if $bus is "nightingale">>
<<nightingale>><br><br>
<</if>>
<<if $bus is "domus">>
<<domus>><br><br>
<</if>>
<<if $bus is "elk">>
<<elk>><br><br>
<</if>>
<<if $bus is "high">>
<<high>><br><br>
<</if>>
<<if $bus is "starfish">>
<<starfish>><br><br>
<</if>>
<<if $bus is "barb">>
<<barb>><br><br>
<</if>>
<<if $bus is "connudatus">>
<<connudatus>><br><br>
<</if>>
<<if $bus is "wolf">>
<<wolf>><br><br>
<</if>>
<<if $bus is "harvest">>
<<harvest>><br><br>
<</if>>
<<if $bus is "oxford">>
<<oxford>><br><br>
<</if>>
<<if $bus is "danube">>
<<danube>><br><br>
<</if>>
<<if $bus is "mer">>
<<mer>><br><br>
<</if>>
<<if $bus is "cliff">>
<<cliff>><br><br>
<</if>>
<<if $bus is "industrial">>
<<industrial>><br><br>
<</if>>
<<if $bus is "residential">>
<<residential>><br><br>
<</if>>
<<if $bus is "commercial">>
<<commercial>><br><br>
<</if>>
<<if $bus is "park">>
<<park>><br><br>
<</if>>
<<if $bus is "industrialdrain">>
<<industrialdrain>><br><br>
<</if>>
<<if $bus is "residentialdrain">>
<<residentialdrain>><br><br>
<</if>>
<<if $bus is "commercialdrain">>
<<commercialdrain>><br><br>
<</if>>
<<if $bus is "seabeach">>
<<seabeach>><br><br>
<</if>>
<<if $bus is "searocks">>
<<searocks>><br><br>
<</if>>
<<if $bus is "seadocks">>
<<seadocks>><br><br>
<</if>>
<<if $bus is "seacliffs">>
<<seacliffs>><br><br>
<</if>>
<<if $bus is "drainexit">>
<<drainexit>><br><br>
<</if>>
<<if $bus is "sea">>
<<seamove>><br><br>
<</if>>
<</nobr>><</widget>>
<<widget "destinationeventend">><<nobr>>
<<if $bus is "nightingale">>
<<nightingaleeventend>><br><br>
<</if>>
<<if $bus is "domus">>
<<domuseventend>><br><br>
<</if>>
<<if $bus is "elk">>
<<elkeventend>><br><br>
<</if>>
<<if $bus is "high">>
<<higheventend>><br><br>
<</if>>
<<if $bus is "starfish">>
<<starfisheventend>><br><br>
<</if>>
<<if $bus is "barb">>
<<barbeventend>><br><br>
<</if>>
<<if $bus is "connudatus">>
<<connudatuseventend>><br><br>
<</if>>
<<if $bus is "wolf">>
<<wolfeventend>><br><br>
<</if>>
<<if $bus is "harvest">>
<<harvesteventend>><br><br>
<</if>>
<<if $bus is "oxford">>
<<oxfordeventend>><br><br>
<</if>>
<<if $bus is "danube">>
<<danubeeventend>><br><br>
<</if>>
<<if $bus is "mer">>
<<mereventend>><br><br>
<</if>>
<<if $bus is "cliff">>
<<cliffeventend>><br><br>
<</if>>
<<if $bus is "industrial">>
<<industrialeventend>><br><br>
<</if>>
<<if $bus is "residential">>
<<residentialeventend>><br><br>
<</if>>
<<if $bus is "commercial">>
<<commercialeventend>><br><br>
<</if>>
<<if $bus is "park">>
<<parkeventend>><br><br>
<</if>>
<<if $bus is "industrialdrain">>
<<industrialdraineventend>><br><br>
<</if>>
<<if $bus is "residentialdrain">>
<<residentialdraineventend>><br><br>
<</if>>
<<if $bus is "commercialdrain">>
<<commercialdraineventend>><br><br>
<</if>>
<<if $bus is "seabeach">>
<<seabeacheventend>><br><br>
<</if>>
<<if $bus is "searocks">>
<<searockseventend>><br><br>
<</if>>
<<if $bus is "seadocks">>
<<seadockseventend>><br><br>
<</if>>
<<if $bus is "seacliffs">>
<<seacliffseventend>><br><br>
<</if>>
<<if $bus is "drainexit">>
<<drainexiteventend>><br><br>
<</if>>
<<if $bus is "sea">>
<<seamoveeventend>><br><br>
<</if>>
<</nobr>><</widget>>
|
QuiltedQuail/degrees
|
game/loc-bus.twee
|
twee
|
unknown
| 36,324 |
:: Eden Cabin [nobr]
<<set $outside to 0>><<set $location to "cabin">><<effects>><<set $bus to "edencabin">><<set $edendays to 0>>
You are in Eden's cabin.
<<if $exposed gte 2>>
You don't want to be seen like this! You rush to your clothes.<br><br>
<<link [[Next|Eden Wardrobe]]>><<endevent>><</link>><br><br>
<<elseif $exhibitionism lte 54 and $exposed gte 1>>
You don't want to be seen like this! You rush to your clothes.<br><br>
<<link [[Next|Eden Wardrobe]]>><<endevent>><</link>><br><br>
<<else>>
<<if $exposed is 1 and $exhibitionism gte 55>>
<span class="lewd">With your <<lewdness>> on display, you can't help but feel a primal thrill.</span><br><br>
<</if>>
<<if $daystate is "night">>
Embers burn in the hearth.
<<elseif $daystate is "dawn">>
<<elseif $daystate is "dusk">>
<<else>>
<</if>>
<<if $weather is "clear">>
<<elseif $weather is "overcast">>
<<elseif $weather is "rain">>
Droplets of rainwater seep through the wooden ceiling and patter on the ground.
<</if>>
<br><br>
<<if $hour lte 6>>
Eden is fast asleep.<br><br>
<<cabinactions>>
<<elseif $hour lte 8>>
<<if $edenbreakfast isnot 1>><<set $edenbreakfast to 1>>
<<eden>><<person1>>Eden lies on the bed. "Make me breakfast," <<he>> says.<br><br>
<<link [[Make the usual breakfast (0:20)|Eden Breakfast]]>><<set $edenlove += 1>><<set $edendom += 1>><<pass 20>><<set $phase to 0>><</link>><br>
<<link [[Make something new (0:20)|Eden Breakfast]]>><<pass 20>><<set $phase to 1>><</link>><br>
<<if $edengarden gte 3>>
<<link [[Use vegetables from the plot (0:20)|Eden Breakfast]]>><<pass 20>><<set $phase to 3>><</link>><br>
<</if>>
<<if $edenshrooms gte 3>>
<<link [[Use mushrooms from the barrel (0:20)|Eden Breakfast]]>><<pass 20>><<set $phase to 4>><</link>><br>
<</if>>
<<link [[Refuse|Eden Breakfast]]>><<set $edenlove -= 1>><<set $edendom -= 1>><<set $phase to 2>><</link>><br>
<<else>>
Eden is getting ready for the day.<br><br>
<<cabinedenactions>>
<<cabinactions>>
<</if>>
<<elseif $hour lte 16>>
Eden is working hard outside.<br><br>
<<cabinactions>>
<<elseif $hour lte 18>>
<<if $edenbath isnot 1>><<set $edenbath to 1>>
<<eden>><<person1>>Eden finishes running <<his>> bath and starts to strip. "Bath time," <<he>> says. "Come on, get in while the water's hot."<br><br>
<<link [[Strip and get in (0:30)|Eden Bath]]>><<pass 30>><<set $edendom += 1>><<set $edenlove += 1>><<set $phase to 0>><<uppernaked>><<lowernaked>><<undernaked>><</link>><br>
<<link [[Refuse|Eden Bath]]>><<set $edendom -= 1>><<set $edenlove += 1>><<set $phase to 1>><</link>><br>
<<else>>
Eden is relaxing in the bath.<br><br>
<<cabinedenactions>>
<<cabinactions>>
<</if>>
<<else>>
<<eden>><<person1>>Eden is cleaning <<his>> gun beside the fire.<br><br>
<<link [[Cuddle (0:30)|Eden Cuddle]]>><<trauma -3>><<stress -6>><<pass 30>><<set $edenlove += 1>><</link>><<ltrauma>><<lstress>><br>
<<cabinedenactions>>
<<cabinactions>>
<</if>>
<</if>>
:: Eden Breakfast [nobr]
<<set $outside to 0>><<set $location to "cabin">><<effects>>
<<if $phase is 0>>
You make Eden eggs the way you know <<he>> likes them. <<He>> sits at the table and you place the food in front of <<himstop>> <<He>> starts eating without a word.<br><br>
<<link [[Ask for a thank you|Eden Breakfast 2]]>><<set $edendom -= 1>><<set $submissive -= 1>><<set $phase to 1>><</link>><br>
<<link [[Chat|Eden Breakfast 2]]>><<trauma -6>><<stress -12>><<set $phase to 2>><</link>><<ltrauma>><<lstress>><br>
<<link [[Sit quietly|Eden Breakfast 2]]>><<set $submissive += 1>><<set $phase to 3>><</link>><br>
<<if $promiscuity gte 55>>
<<link [[Slip under the table|Eden Table Seduction]]>><</link>><<promiscuous4>><br>
<</if>>
<<elseif $phase is 1>>
<<if $rng gte 81>>
You cook the eggs a little differently to how <<he>> likes them, hoping the variety will spice things up a bit.
<<elseif $rng gte 61>>
You find some dried meat, which you think will be nice with some berries for desert.
<<elseif $rng gte 41>>
You boil some hearty root vegetables.
<<elseif $rng gte 21>>
You find some mushrooms and decide to make an omelette.
<<else>>
You think some berries would make a tasty meal.
<</if>>
<<He>> sits at the table and you place the food in front of <<himstop>> "I prefer having the same every day," <<he>> says, but <<he>> eats regardless.<br><br>
<<link [[Ask for a thank you|Eden Breakfast 2]]>><<set $edendom -= 1>><<set $submissive -= 1>><<set $phase to 1>><</link>><br>
<<link [[Chat|Eden Breakfast 2]]>><<trauma -6>><<stress -12>><<set $phase to 2>><</link>><<ltrauma>><<lstress>><br>
<<link [[Sit quietly|Eden Breakfast 2]]>><<set $submissive += 1>><<set $phase to 3>><</link>><br>
<<if $promiscuity gte 55>>
<<link [[Slip under the table|Eden Table Seduction]]>><</link>><<promiscuous4>><br>
<</if>>
<<elseif $phase is 2>>
<<if $edenlove gte 1>>
"Fine," <<he>> says. "I'll go hungry. It'll be your fault if I starve." <<He>> continues grumbling awhile.<br><br>
<<link [[Next|Eden Cabin]]>><<endevent>><</link>><br>
<<else>>
"That wasn't a request," <<he>> says, standing and walking over to you. "I think you need a reminder of your place." <<He>> grabs you and bends you over <<his>> knee.<br><br>
<<link [[Next|Eden Cabin Punishment]]>><<set $molestationstart to 1>><</link>><br>
<</if>>
<<elseif $phase is 3>>
With the garden mostly clear of weeds, you're able to harvest some delicious-looking vegetables. <<He>> sits at the table and you put the food in front of <<himstop>> <<He>> takes a bite, and <<his>> eyes widen. "This is good!" <<he>> says. "Are these from the garden? I didn't think that weedy patch of land had it in it."<<set $edenlove += 1>><br><br>
<<link [[Ask for a thank you|Eden Breakfast 2]]>><<set $edendom -= 1>><<set $submissive -= 1>><<set $phase to 1>><</link>><br>
<<link [[Chat|Eden Breakfast 2]]>><<trauma -6>><<stress -12>><<set $phase to 2>><</link>><<ltrauma>><<lstress>><br>
<<link [[Sit quietly|Eden Breakfast 2]]>><<set $submissive += 1>><<set $phase to 3>><</link>><br>
<<if $promiscuity gte 55>>
<<link [[Slip under the table|Eden Table Seduction]]>><</link>><<promiscuous4>><br>
<</if>>
<<elseif $phase is 4>>
With so many mushrooms stored, you think it'd be fine to have some for breakfast. You cook them in an omelette. <<He>> sits at the table and you put the food in front of <<himstop>> "I prefer having the same every day," <<he>> says, but <<he>> eats regardless.<br><br>
After a short while, <span class="lewd"><<his>> face starts to flush.</span> "You need to be careful with the sort of mushrooms you cook with," <<he>> says. "Some of them have interesting effects. Not that you've done wrong, it tastes fine."<<set $edenlust += 30>><br><br>
<<link [[Ask for a thank you|Eden Breakfast 2]]>><<set $edendom -= 1>><<set $submissive -= 1>><<set $phase to 1>><</link>><br>
<<link [[Chat|Eden Breakfast 2]]>><<trauma -6>><<stress -12>><<set $phase to 2>><</link>><<ltrauma>><<lstress>><br>
<<link [[Sit quietly|Eden Breakfast 2]]>><<set $submissive += 1>><<set $phase to 3>><</link>><br>
<<if $promiscuity gte 55>>
<<link [[Slip under the table|Eden Table Seduction]]>><</link>><<promiscuous4>><br>
<</if>>
<</if>>
:: Eden Breakfast 2 [nobr]
<<set $outside to 0>><<set $location to "cabin">><<effects>>
<<if $phase is 1>>
You mock cough, "ahem." <<He>> looks at you, bewildered for a moment before realising what you're after. "Oh. Thanks," <<he>> goes back to eating.<br><br>
<<link [[Request head pats|Eden Breakfast 2]]>><<set $edenlove += 1>><<set $phase to 4>><<trauma -6>><<stress -12>><</link>><<ltrauma>><<lstress>><br>
<<link [[Chat|Eden Breakfast 2]]>><<trauma -6>><<stress -12>><<set $phase to 2>><</link>><<ltrauma>><<lstress>><br>
<<link [[Sit quietly|Eden Breakfast 2]]>><<set $submissive += 1>><<set $phase to 3>><</link>><br>
<<if $promiscuity gte 55>>
<<link [[Slip under the table|Eden Table Seduction]]>><</link>><<promiscuous4>><br>
<</if>>
<<elseif $phase is 2>>
You try to chat with Eden, but <<he>> seems more interested in the food. You can tell <<hes>> listening though. "You can have the leftovers," <<he>> says, pushing the plate towards you. "I need to get ready."<br><br>
<<link [[Next|Eden Cabin]]>><<endevent>><</link>><br>
<<elseif $phase is 3>>
You sit quiety as Eden eats. <<He>> seems quite engrossed, until <<he>> glances at you. "You can have the leftovers," <<he>> says, pushing the plate towards you. "I need to get ready."<br><br>
<<link [[Next|Eden Cabin]]>><<endevent>><</link>><br>
<<else>>
You rest your head on <<his>> shoulder. <<He>> takes the hint and starts stroking your hair.
<<if $wolfgirl gte 4>>
<<His>> fingers brush against your wolf ears and a small yelp escapes your lips. Drawn to your weak spot, <<he>> scratches behind your ear. Waves of pleasure jolt through your scalp, down your neck and through your spine. Your leg jerks involuntarily. "You like it there, don't you."<<garousal>><<lstress>><<arousal 6>><<stress -12>><<set $arousal += 1000>><br><br>
<<if $arousal gte 10000>>
<<orgasmpassage>>
The spasms subside, but leave you tired and as weak as a puppy. "My fault," <<he>> says, bemused. "I went too hard on you." <<He>> kisses your forehead and holds you close.<br><br>
<<else>>
Just when you feel like it's too much for you, <<he>> stops. <<He>> wraps <<his>> arm around you and just holds you for a few minutes.
<</if>>
<</if>>
"I need to get ready," <<he>> says after a while. "You can finish the food."<br><br>
<<link [[Next|Eden Cabin]]>><<endevent>><</link>><br>
<</if>>
:: Eden Cabin Punishment [nobr]
<<if $molestationstart is 1>>
<<set $molestationstart to 0>>
<<controlloss>>
<<violence 1>>
<<neutral 1>>
<<molested>>
<<set $event to "molestationhome">>
<<man1init>><<npcspank>><<set $enemyhealth to 600>><<set $enemyhealthmax to 600>><<set $enemyanger += 200>>
<</if>>
<<effects>>
<<effectsman>><<man>>
<<stateman>><br>
<br>
<<actionsman>>
<<if $enemyhealth lte 0>>
<span id="next"><<link [[Next|Eden Cabin Punishment Finish]]>><</link>></span><<nexttext>>
<<elseif $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next|Eden Cabin Punishment Finish]]>><</link>></span><<nexttext>>
<<elseif $enemyanger lte 0>>
<span id="next"><<link [[Next|Eden Cabin Punishment Finish]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next|Eden Cabin Punishment]]>><</link>></span><<nexttext>>
<</if>>
:: Eden Table Seduction [nobr]
<<effects>>
<<set $seductiondifficulty to (10000 - ($edenlust * 200))>>
<<seductioncheck>><br><br>
<span class="gold">You feel more confident in your powers of seduction.</span><<seductionskilluse>><br><br>
<<if $pronoun is "f">>
You rest your arms on <<his>> knees and lift up <<his>> skirt, giving you a peek of <<his>> genitals.<<promiscuity4>><br><br>
<<else>>
You rest your arms on <<his>> knees and open <<his>> fly, giving you a peek of <<his>> genitals.<<promiscuity4>><br><br>
<</if>>
<<if $seductionrating gte $seductionrequired>>
"I like the way you think," <<he>> says, pressing a hand against the back of your head and pushing you closer.<br><br>
<<link [[Next|Eden Table Oral]]>><<set $sexstart to 1>><</link>><br>
<<else>>
"What are you doing under there?" <<he>> asks. "Now's not the time you dirty <<girlcomma>> I need to get ready." You climb back on your seat. "You can finish the rest. I need to get ready." <<He>> pushes the plate towards you.<br><br>
<i><<He>> will be more lusty, and easier to seduce, the longer <<hes>> gone without sex.</i><br><br>
<<link [[Next|Eden Cabin]]>><<endevent>><</link>><br>
<</if>>
:: Eden Cabin Punishment Finish [nobr]
<<set $outside to 0>><<set $location to "cabin">><<effects>>
<<if $enemyarousal gte $enemyarousalmax>>
<<ejaculation>><<set $edenlust -= 20>>
<<He>> pants from the exertion. "I hope you've learnt your lesson."<br><br>
<<tearful>> you avoid <<his>> gaze.<br><br>
<<clotheson>>
<<endcombat>>
<<link [[Next|Eden Cabin]]>><</link>><br>
<<elseif $enemyhealth lte 0>>
"You ungrateful slut," <<he>> says. "Maybe I should throw you out and leave you to the wolves!" <<He>> winces and holds <<his>> side. "I need to get something for this."<br><br>
<<tearful>> you gather yourself.<br><br>
<<clotheson>>
<<endcombat>>
<<link [[Next|Eden Cabin]]>><</link>><br>
<<elseif $enemyanger lte 0>>
<<He>> looks mollified, and releases you. "I hope you've learnt your lesson."<br><br>
<<tearful>> you avoid <<his>> gaze.<br><br>
<<clotheson>>
<<endcombat>>
<<link [[Next|Eden Cabin]]>><</link>><br>
<</if>>
:: Eden Table Oral [nobr]
<<if $sexstart is 1>>
<<set $sexstart to 0>>
<<consensual>>
<<set $consensual to 1>>
<<neutral 1>>
<<set $event to "molestationhome">>
<<man1init>><<npcoral>>
<<set $enemytrust += 100>><<set $enemyhealth to 600>><<set $enemyhealthmax to 600>>
<</if>>
<<effects>>
<<effectsman>><<man>>
<<stateman>><br>
<br>
<<actionsman>>
<<if $finish is 1>>
<span id="next"><<link [[Next|Eden Table Oral Finish]]>><</link>></span><<nexttext>>
<<elseif $enemyhealth lte 0>>
<span id="next"><<link [[Next|Eden Table Oral Finish]]>><</link>></span><<nexttext>>
<<elseif $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next|Eden Table Oral Finish]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next|Eden Table Oral]]>><</link>></span><<nexttext>>
<</if>>
:: Eden Table Oral Finish [nobr]
<<set $outside to 0>><<set $location to "cabin">><<effects>>
<<if $enemyarousal gte $enemyarousalmax>>
<<ejaculation>><<set $edenlust -= 20>><<set $edenlove += 1>>
"I knew I kept you around for a reason," <<he>> gasps.<br><br>
<<clotheson>>
<<endcombat>>
<<elseif $enemyhealth lte 0>>
"You ungrateful slut," <<he>> says. "Maybe I should throw you out and leave you to the wolves!" <<He>> winces and holds <<his>> side. "I need to get something for this."<br><br>
<<tearful>> you climb out from under the table.<br><br>
<<clotheson>>
<<endcombat>>
<<elseif $finish is 1>>
"You little tease," <<he>> says. "Don't get me worked up if you don't intend to go all the way."<br><br>
<<clotheson>>
<<endcombat>>
<</if>>
<br><br>
<<link [[Next|Eden Cabin]]>><</link>>
:: Widgets Cabin [widget]
<<widget "cabinactions">><<nobr>>
<<roomoptions>>
There's a large mattress with animal skin covers.<br>
<<link [[Sleep|Eden Cabin Bed]]>><<endevent>><</link>><br>
Your clothes are kept in the corner.<br>
<<link [[Wardrobe|Eden Wardrobe]]>><<endevent>><</link>><br>
<<link [[Mirror|Eden Mirror]]>><<endevent>><</link>><br>
<br>
<<link [[Go outside|Eden Clearing]]>><<endevent>><</link>><br>
<br>
<<link [[Settings|Cabin Settings]]>><<endevent>><</link>><br>
<<link [[NPC Settings|Cabin NPC Settings]]>><</link>><br><br>
<br>
<</nobr>><</widget>>
<<widget "cabinedenactions">><<nobr>>
<<if $exposed gte 1 and $exhibitionism gte 55>>
<span class="lewd">Eden keeps stealing glances at you.</span><<set $edenlust += 1>><br><br>
<</if>>
<<if $leftarm is "bound">>
<<link [[Ask Eden to undo your bindings (0:01)|Eden Bindings]]>><<pass 1>><<unbind>><<endevent>><</link>><br><br>
<<elseif $rightarm is "bound">>
<<link [[Ask Eden to undo your bindings (0:01)|Eden Bindings]]>><<pass 1>><<unbind>><<endevent>><</link>><br><br>
<</if>>
<<if $edenfreedom is undefined>>
<<link [[Ask for freedom to return to town|Eden Freedom]]>><<endevent>><</link>><br>
<</if>>
<<if $edenfreedom is 1>>
<<link [[Ask for freedom to remain in town|Eden Freedom 3]]>><<endevent>><</link>><br>
<</if>>
<<if $edenshopping is 1>>
<<link [[Give Eden the supplies|Eden Supplied]]>><<endevent>><</link>><br>
<</if>>
<br>
<</nobr>><</widget>>
<<widget "clearingactions">><<nobr>>
<<if $edengarden is 0>>
<span class="purple">Eden's crops are utterly strangled by weeds.</span><br>
<<link [[Remove the weeds (3:00)|Clearing Weeding]]>><<endevent>><<pass 2 hours>><<pass 1 hour>><<tiredness 12>><<set $edenlove += 1>><</link>><<gtiredness>><br><br>
<<elseif $edengarden is 1>>
<span class="blue">Eden's crops are tangled with weeds.</span><br>
<<link [[Remove the weeds (3:00)|Clearing Weeding]]>><<endevent>><<pass 2 hours>><<pass 1 hour>><<tiredness 12>><<set $edenlove += 1>><</link>><<gtiredness>><br><br>
<<elseif $edengarden is 2>>
<span class="lblue">There are as many weeds growing in Eden's plot as there are vegetables.</span><br>
<<link [[Remove the weeds (3:00)|Clearing Weeding]]>><<endevent>><<pass 2 hours>><<pass 1 hour>><<tiredness 12>><<set $edenlove += 1>><</link>><<gtiredness>><br><br>
<<elseif $edengarden is 3>>
<span class="teal">Eden's crops are mostly free of weeds, but more could be done.</span><br>
<<link [[Remove the weeds (3:00)|Clearing Weeding]]>><<endevent>><<pass 2 hours>><<pass 1 hour>><<tiredness 12>><<set $edenlove += 1>><</link>><<gtiredness>><br><br>
<<elseif $edengarden is 4>>
<span class="green">Eden's crops are completely free of weeds.</span><br><br>
<</if>>
<<if $edenshrooms is 0>>
<span class="purple">Eden's mushroom barrel is almost empty.</span><br>
<<link [[Look for mushrooms (1:00)|Clearing Mushrooms]]>><<endevent>><<pass 1 hour>><<set $edenlove += 1>><</link>><br><br>
<<elseif $edenshrooms is 1>>
<span class="blue">Eden's mushroom barrel is mostly empty.</span><br>
<<link [[Look for mushrooms (1:00)|Clearing Mushrooms]]>><<endevent>><<pass 1 hour>><<set $edenlove += 1>><</link>><br><br>
<<elseif $edenshrooms is 2>>
<span class="lblue">Eden's mushroom barrel is half full.</span><br>
<<link [[Look for mushrooms (1:00)|Clearing Mushrooms]]>><<endevent>><<pass 1 hour>><<set $edenlove += 1>><</link>><br><br>
<<elseif $edenshrooms is 3>>
<span class="teal">Eden's mushroom barrel is mostly full.</span><br>
<<link [[Look for mushrooms (1:00)|Clearing Mushrooms]]>><<endevent>><<pass 1 hour>><<set $edenlove += 1>><</link>><br><br>
<<elseif $edenshrooms is 4>>
<span class="green">Eden's mushroom barrel is brimming with fungi.</span><br><br>
<</if>>
<<if $edenspring is 0>>
<span class="purple">The spring is full of broken branches and twigs.</span><br>
<<link [[Clear the debris (0:30)|Clearing Debris]]>><<endevent>><<pass 30>><<tiredness 6>><<set $edenlove += 1>><</link>><<gtiredness>><br><br>
<<elseif $edenspring is 1>>
<span class="blue">The bottom of the spring is littered with branches.</span><br>
<<link [[Clear the debris (0:30)|Clearing Debris]]>><<endevent>><<pass 30>><<tiredness 6>><<set $edenlove += 1>><</link>><<gtiredness>><br><br>
<<elseif $edenspring is 2>>
<span class="lblue">You can see the bottom of the spring through the twigs and branches floating on its surface.</span><br>
<<link [[Clear the debris (0:30)|Clearing Debris]]>><<endevent>><<pass 30>><<tiredness 6>><<set $edenlove += 1>><</link>><<gtiredness>><br><br>
<<elseif $edenspring is 3>>
<span class="teal">Twigs float on the surface of the spring.</span><br>
<<link [[Clear the debris (0:30)|Clearing Debris]]>><<endevent>><<pass 30>><<tiredness 6>><<set $edenlove += 1>><</link>><<gtiredness>><br><br>
<<elseif $edenspring is 4>>
<span class="green">The spring is clean and clear.</span><br>
<<link [[Relax in the spring (0:30)|Clearing Spring]]>><<endevent>><<pass 30>><<stress -6>><</link>><<lstress>><br><br>
<</if>>
<<link [[Enter the cabin|Eden Cabin]]>><<endevent>><</link>><br>
<<if $edenfreedom gte 1>>
<<link [[Enter the forest|Forest]]>><<endevent>><<set $forest to 60>><</link>><br>
<<else>>
<<link [[Escape|Eden Cabin Escape]]>><<endevent>><<set $forest to 80>><</link>><br>
<</if>>
<br>
<</nobr>><</widget>>
<<widget "clearingedenactions">><<nobr>>
<<if $exposed gte 1 and $exhibitionism gte 55>>
<span class="lewd">Eden keeps stealing glances at you.</span><<set $edenlust += 1>><br><br>
<</if>>
<<if $leftarm is "bound">>
<<link [[Ask Eden to undo your bindings (0:01)|Eden Bindings]]>><<pass 1>><<unbind>><<endevent>><</link>><br><br>
<<elseif $rightarm is "bound">>
<<link [[Ask Eden to undo your bindings (0:01)|Eden Bindings]]>><<pass 1>><<unbind>><<endevent>><</link>><br><br>
<</if>>
<<if $edenfreedom is undefined>>
<<link [[Ask for freedom to return to town|Eden Freedom]]>><<endevent>><</link>><br>
<</if>>
<<if $edenfreedom is 1>>
<<link [[Ask for freedom to remain in town|Eden Freedom 3]]>><<endevent>><</link>><br>
<</if>>
<<if $edenshopping is 1>>
<<link [[Give Eden the supplies|Eden Supplied]]>><<endevent>><</link>><br>
<</if>>
<br>
<</nobr>><</widget>>
:: Eden Cabin Bed [nobr]
<<effects>>
You snuggle under the covers.<br><br>
<<if $sleeptrouble is 1 and $controlled is 0>>
<<link [[Sleep for 10 hours|Cabin Sleep]]>><<set $sleephour to 10>><</link>><<ltiredness>><br>
<<link [[Sleep for 9 hours|Cabin Sleep]]>><<set $sleephour to 9>><</link>><<ltiredness>><br>
<<link [[Sleep for 8 hours|Cabin Sleep]]>><<set $sleephour to 8>><</link>><<ltiredness>><br>
<<link [[Sleep for 7 hours|Cabin Sleep]]>><<set $sleephour to 7>><</link>><<ltiredness>><br>
<<link [[Sleep for 6 hours|Cabin Sleep]]>><<set $sleephour to 6>><</link>><<ltiredness>><br>
<<link [[Sleep for 5 hours|Cabin Sleep]]>><<set $sleephour to 5>><</link>><<ltiredness>><br>
<<link [[Sleep for 4 hours|Cabin Sleep]]>><<set $sleephour to 4>><</link>><<ltiredness>><br>
<<link [[Sleep for 3 hours|Cabin Sleep]]>><<set $sleephour to 3>><</link>><<ltiredness>><br>
<<link [[Sleep for 2 hours|Cabin Sleep]]>><<set $sleephour to 2>><</link>><<ltiredness>><br>
<<link [[Sleep for 1 hours|Cabin Sleep]]>><<set $sleephour to 1>><</link>><<ltiredness>><br>
<br>
<<else>>
<<link [[Sleep for 8 hours|Cabin Sleep]]>><<set $sleephour to 8>><</link>><<ltiredness>><br>
<<link [[Sleep for 7 hours|Cabin Sleep]]>><<set $sleephour to 7>><</link>><<ltiredness>><br>
<<link [[Sleep for 6 hours|Cabin Sleep]]>><<set $sleephour to 6>><</link>><<ltiredness>><br>
<<link [[Sleep for 5 hours|Cabin Sleep]]>><<set $sleephour to 5>><</link>><<ltiredness>><br>
<<link [[Sleep for 4 hours|Cabin Sleep]]>><<set $sleephour to 4>><</link>><<ltiredness>><br>
<<link [[Sleep for 3 hours|Cabin Sleep]]>><<set $sleephour to 3>><</link>><<ltiredness>><br>
<<link [[Sleep for 2 hours|Cabin Sleep]]>><<set $sleephour to 2>><</link>><<ltiredness>><br>
<<link [[Sleep for 1 hours|Cabin Sleep]]>><<set $sleephour to 1>><</link>><<ltiredness>><br><br>
<</if>>
<<link [[Climb out of bed|Eden Cabin]]>><</link>><br><br>
:: Cabin Sleep [nobr]
<<sleep>><<effects>>
<<if $nightmares gte 1 and $controlled is 0>>
You dream you are being hunted by something dark and terrible.
<<else>>
You sleep soundly.
<</if>>
<<sleepeffects>>
<<if $schoolwake is 1>><<set $schoolwake to 0>>
<<eden>><<person1>>You wake up to Eden's groping. <<He>> starts rubbing up against you.<br><br>
<<link [[Let it happen|Eden Sleep Sex]]>><<set $sexstart to 1>><</link>><<promiscuous1>><br>
<<link [[Push away|Eden Sleep Push]]>><</link>><br>
<<else>>
<br><br>
<<link [[Get out of bed|Eden Cabin]]>><</link>><br><br>
<</if>>
<<set $phase to 0>>
:: Forest Hunter Nod [nobr]
<<set $outside to 0>><<set $location to "cabin">><<effects>>
<<He>> smiles. "Good. I can't take your leash off just yet, not until you're properly trained." <<He>> ties <<his>> end of the leash around a wooden beam. "There should be enough slack for you to roam the entire cabin though."
<br><br>
<<link [[Next|Forest Cabin]]>><<set $eventskip to 1>><<endevent>><</link>><br>
:: Forest Hunter Refuse [nobr]
<<set $outside to 0>><<set $location to "cabin">><<effects>>
"You don't mean that," <<he>> says. "This benefits you far more than me." <<He>> grabs you and bends you over <<his>> lap. "But I can't let you get away with being so insolent."
<br><br>
<<link [[Next|Forest Hunter Punishment]]>><<set $molestationstart to 1>><</link>><br>
:: Forest Hunter Punishment [nobr]
<<if $molestationstart is 1>>
<<set $molestationstart to 0>>
<<controlloss>>
<<violence 1>>
<<neutral 1>>
<<molested>>
<<set $event to "molestationhome">>
<<man1init>><<npcspank>><<set $enemyhealth to 600>><<set $enemyhealthmax to 600>><<set $enemyanger += 200>>
<<if $phase is 1>>
<<npcoral>>
<</if>>
<</if>>
<<effects>>
<<effectsman>><<man>>
<<stateman>><br>
<br>
<<actionsman>>
<<if $enemyhealth lte 0>>
<span id="next"><<link [[Next|Forest Hunter Punishment Finish]]>><</link>></span><<nexttext>>
<<elseif $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next|Forest Hunter Punishment Finish]]>><</link>></span><<nexttext>>
<<elseif $enemyanger lte 0>>
<span id="next"><<link [[Next|Forest Hunter Punishment Finish]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next|Forest Hunter Punishment]]>><</link>></span><<nexttext>>
<</if>>
:: Forest Hunter Punishment Finish [nobr]
<<set $outside to 1>><<set $location to "cabin">><<effects>>
<<if $enemyarousal gte $enemyarousalmax>>
<<ejaculation>>
<<He>> pants from the exertion. "I hope you've learnt your lesson."<br><br>
<<tearful>> you avoid <<his>> gaze.<br><br>
<<clotheson>>
<<endcombat>>
<<link [[Next|Forest Cabin]]>><<set $eventskip to 1>><</link>><br>
<<elseif $enemyhealth lte 0>>
"You ungrateful slut," <<he>> says. "Maybe I should throw you out and leave you to the wolves!" <<He>> winces and holds <<his>> side. "I need to get something for this."<br><br>
<<tearful>> you gather yourself.<br><br>
<<clotheson>>
<<endcombat>>
<<link [[Next|Forest Cabin]]>><<set $eventskip to 1>><</link>><br>
<<elseif $enemyanger lte 0>>
<<He>> looks mollified, and releases you. "I hope you've learnt your lesson."<br><br>
<<tearful>> you avoid <<his>> gaze.<br><br>
<<clotheson>>
<<endcombat>>
<<link [[Next|Forest Cabin]]>><<set $eventskip to 1>><</link>><br>
<</if>>
:: Forest Cabin [nobr]
<<set $outside to 0>><<set $location to "cabin">><<effects>>
<<eden>><<person1>>
<<if $exposed gte 1>>
<<towelup>>
<</if>>
<<if $forestleashed is 1>>
<<if $edentrust gte 200>>
<span class="green">Eden unties the leash from the wooden beam.</span> "You've been a good <<girlcomma>> so I'm going to give you a bit more freedom. Don't you dare run out on me though. Stick to the cabin and the clearing just outside."<br><br><<set $forestleashed to 0>>
<<else>>
You are leashed tightly to a wooden beam, preventing escape.<br><br>
<</if>>
<<else>>
<<if $edentrust lt 100>>
<span class="red">Eden ties your leash to a wooden beam.</span> "You've been a bad <<girlcomma>> so I'm going to make sure you don't go anywhere."<br><br><<set $forestleashed to 1>>
<</if>>
<</if>>
<<if $forestleashed isnot 1>>
<<if $syndromeeden is undefined>><<set $syndromeeden to 1>><<set $edenlust to 0>><<set $edenshrooms to 0>><<set $edengarden to 0>><<set $edenspring to 0>><br><br>
<span class="red"><i>Eden isn't so bad, <<hes>> just lonely. It must be hard living here in the woods on your own.</i><br>
You've gained the "Stockholm Syndrome: Eden" trait.</span><br><br>
<</if>>
<<link [[Next|Eden Cabin]]>><<endevent>><</link>><br>
<<else>>
<<if $hour lte 6>>
Eden carries you to to the bed.
<<if $forestleashed is 1>>
<<He>> wraps your leash around the bars of the headboard, practically pinning you in place.
<</if>>
<<He>> leers at you, a ravenous look in <<his>> eyes. "You're so hot. I'm gonna enjoy this."<br><br>
<<link [[Next|Cabin Night Rape]]>><<set $molestationstart to 1>><</link>><br>
<<elseif $hour lte 8>>
Eden gives you instructions on how to prepare <<his>> breakfast.<br><br>
<<link [[Prepare the food as instructed|Forest Cabin Food]]>><<set $edentrust += 10>><<set $submissive += 1>><<pass 2 hours>><</link>><<gtrust>><br>
<<link [[Spit in the eggs|Forest Cabin Spit]]>><<set $edentrust -= 10>><<set $submissive -= 1>><<pass 2 hours>><</link>><<ltrust>><br>
<<elseif $hour lte 16>>
Eden leads you outside, and goes about <<his>> daily business.
<<if $forestleashed is 1>>
<<He>> keeps you close at all times, tying your leash around a tree when <<he>> needs to use both hands.
<<else>>
<<He>> keeps you close at all times.
<</if>>
<br><br>
<<if $forestleashed is 1>>
<<link [[Weaken the Leash|Forest Cabin Weaken]]>><<set $submissive -= 1>><</link>><br>
<</if>>
<<link [[Be good|Forest Cabin Good]]>><<set $submissive += 1>><</link>><br>
<<elseif $hour lte 18>>
Eden runs a bath. <<He>> eases <<his>> body into the water, and looks at you expectantly. "What are you waiting for? Strip, get in, and wash me."
<br><br>
<<link [[Wash|Cabin Bath]]>><<pass 2 hours>><<set $edentrust += 10>><<set $submissive += 1>><</link>><<gtrust>><br>
<<link [[Refuse|Cabin Bath Refuse]]>><<pass 2 hours>><<set $edentrust -= 10>><<set $submissive -= 1>><</link>><<ltrust>><br>
<<elseif $hour lte 22>>
Eden settles down to read a book, occasionally pausing to stoke the fireplace.<br><br>
<<link [[Cuddle|Cabin Cuddle]]>><<set $submissive += 1>><<set $edentrust += 20>><<set $edenlove += 1>><<pass 2 hours>><<pass 2 hours>><</link>><<gtrust>><br>
<<link [[Catch some sleep|Forest Cabin]]>><<set $submissive -= 1>><<tiredness -12>><<tiredness -12>><<pass 2 hours>><<pass 2 hours>><<endevent>><</link>><<ltiredness>><br>
<<else>>
Eden carries you to to the bed.
<<if $forestleashed is 1>>
<<He>> wraps your leash around the bars of the headboard, practically pinning you in place.
<</if>>
<<He>> leers at you, a ravenous look in <<his>> eyes. "You're so hot. I'm gonna enjoy this."<br><br>
<<link [[Next|Cabin Night Rape]]>><<set $molestationstart to 1>><</link>><br>
<</if>>
<</if>>
:: Cabin Night Rape [nobr]
<<if $molestationstart is 1>>
<<set $molestationstart to 0>>
<<controlloss>>
<<violence 1>>
<<neutral 1>>
<<molested>>
<<set $event to "molestationhome">>
<<man1init>><<set $enemyhealth to 600>><<set $enemyhealthmax to 600>>
<</if>>
<<effects>>
<<effectsman>><<man>>
<<stateman>><br>
<br>
<<actionsman>>
<<if $enemyhealth lte 0>>
<span id="next"><<link [[Next|Cabin Night Rape Finish]]>><</link>></span><<nexttext>>
<<elseif $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next|Cabin Night Rape Finish]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next|Cabin Night Rape]]>><</link>></span><<nexttext>>
<</if>>
:: Cabin Night Rape Finish [nobr]
<<set $outside to 1>><<set $location to "cabin">><<effects>>
<<if $enemyarousal gte $enemyarousalmax>>
<<ejaculation>>
Eden sighs and rolls onto <<his>> back. You soon hear <<his>> snoring.<br><br>
<<tearful>> you wonder what to do.<br><br>
<<clotheson>>
<<endcombat>>
<<link [[Next|Cabin Night]]>><</link>><br>
<<elseif $enemyhealth lte 0>>
Eden takes the hint, and rolls onto <<his>> side, facing away from you. You soon hear <<his>> snoring.<br><br>
<<tearful>> you wonder what to do.<br><br>
<<clotheson>>
<<endcombat>>
<<link [[Next|Cabin Night]]>><</link>><br>
<</if>>
:: Cabin Night [nobr]
<<set $outside to 0>><<set $location to "cabin">><<effects>>
<<if $forestleashed is 1>>
Eden is asleep, but with your neck leashed tightly to the bed, you can't move very far.<br><br>
<<link [[Sleep|Cabin Night Sleep]]>><<cabintime>><</link>><<ltiredness>><br>
<<link [[Weaken the leash|Cabin Night Leash]]>><<cabintime>><</link>><br>
<<else>>
Eden is asleep. You could escape if you wanted.<br><br>
<<link [[Sleep|Cabin Night Sleep]]>><<cabintime>><</link>><<ltiredness>><br>
<<link [[Escape|Cabin Night Escape]]>><<set $stress -= 2000>><</link>><br>
<</if>>
:: Cabin Night Sleep [nobr]
<<set $outside to 0>><<set $location to "cabin">><<effects>>
<<eden>><<person1>>
You settle down and try to sleep.<br><br>
You are awoken awhile later by Eden kissing you on the cheek. "Good morning." <<He>> yawns and stretches. "Time for breakfast."<br><br>
<<link [[Next|Forest Cabin]]>><<endevent>><</link>><br>
:: Cabin Night Leash [nobr]
<<set $outside to 0>><<set $location to "cabin">><<effects>>
<<if $forestleashedwear gte 1>>
<<set $forestleashedwear += 1>>
<<else>>
<<set $forestleashedwear to 1>>
<</if>>
You rub the leash against the headboard, hoping to wear it through. You think you feel it becoming thinner.<br><br>
<<if $forestleashedwear gte 3>>
Sunlight gently caresses your face, when the leash snaps, freeing you. Eden still slumbers, there's nothing preventing your escape.<<set $forestleashed to 0>><<set $forestleashedwear to 0>><br><br>
<<link [[Stay put|Cabin Leash Broken]]>><</link>><<gtrust>><br>
<<link [[Escape|Cabin Night Escape]]>><<set $stress -= 2000>><</link>><br>
<<else>>
<<eden>><<person1>>
Awhile later you hear Eden stir. <<He>> rolls over and kissing you on the cheek. "Good morning." <<He>> yawns and stretches. "Time for breakfast."<br><br>
<<link [[Next|Forest Cabin]]>><<endevent>><</link>><br>
<</if>>
:: Cabin Night Escape [nobr]
<<set $outside to 0>><<set $location to "cabin">><<effects>>
You sneak towards the cabin entrance and try the door handle. It opens, and you escape into the forest.<br><br>
<<link [[Next|Forest]]>><<set $edentrust -= 200>><<set $forest to 80>><</link>><br>
:: Cabin Leash Broken [nobr]
<<set $outside to 0>><<set $location to "cabin">><<effects>>
<<eden>><<person1>>
A while later you hear Eden stir. <<He>> rolls over and kisses you on the cheek. "Good morning." <<He>> yawns and stretches. "Time for breakfast." <<He>> notices your broken leash. "Oh dear, these things are usually sturdier. You're such a good <<girl>> for not running off." <<He>> leans over and kisses you on the forehead, then looks thoughtfully at the broken remains of the leash.<<set $edentrust += 200>>
<<if $edentrust gte 100>>
"I don't think keeping you tied is necessary anymore. Just don't run off on me. Stick to the cabin and the clearing just outside, where it's safe."
<<if $syndromeeden is undefined>><<set $syndromeeden to 1>><<set $edenlust to 0>><<set $edenshrooms to 0>><<set $edengarden to 0>><<set $edenspring to 0>><br><br>
<span class="red"><i>Eden isn't so bad, <<hes>> just lonely. It must be hard living here in the woods on your own.</i><br>
You've gained the "Stockholm Syndrome: Eden" trait.</span>
<</if>>
<</if>>
<br><br>
<<if $edentrust gte 100>>
<<link [[Next|Eden Cabin]]>><<endevent>><</link>><br>
<<else>>
<<link [[Next|Forest Cabin]]>><<endevent>><</link>><br>
<</if>>
:: Forest Cabin Food [nobr]
<<set $outside to 0>><<set $location to "cabin">><<effects>>
You prepare the food and place it on the table in front of <<himstop>> <<He>> takes a bite, then smiles and gently pats your head. <<He>> shares some with you and you eat together. Eden talks a lot about the minutiae of life here, pausing occasionally to allow you a response. You nod politely each time, which seems enough to satisfy <<himstop>><br><br>
<<His>> plate empty, <<he>> stands and looks out the window.
<<if $weather is "clear">>
"It's a lovely day! We'll be able to get lots of work done."
<<elseif $weather is "rain">>
"We've got lots of work to do today. A little rain won't stop us."
<<elseif $weather is "overcast">>
"The clouds are grumbling. Hopefully they don't burst before we're done for the day."
<</if>>
<br><br>
<<link [[Next|Forest Cabin]]>><<endevent>><</link>><br>
:: Forest Cabin Spit [nobr]
<<set $outside to 0>><<set $location to "cabin">><<effects>>
You prepare the food and place it on the table in front of <<himstop>> <<He>> takes a bite. "You did something to this, didn't you?" You try to suppress a defiant smile, but the twitching at the corner of your lips gives it away. <<He>> grabs you and bends you over <<his>> lap.<br><br>
<<link [[Next|Forest Hunter Punishment]]>><<set $molestationstart to 1>><</link>><br>
:: Cabin Cuddle [nobr]
<<set $outside to 0>><<set $location to "cabin">><<effects>>
You snuggle up to Eden. <<He>> is initially taken aback, but <<his>> face soon softens and <<he>> wraps an arm around you.<br><br>
<<link [[Next|Forest Cabin]]>><<endevent>><</link>><br>
:: Cabin Bath [nobr]
<<set $outside to 0>><<set $location to "cabin">><<effects>>
You remove your clothing and get in the bath. Using a sponge, you wash <<his>> back. <<He>> turns to you. "You're such a gentle thing. Now clean my chest." You continue washing, though it's more embarrassing when you can see <<his>> face.<<wash>><<garousal>><<set $arousal += 1000>>
<br><br>
<<link [[Next|Forest Cabin]]>><<endevent>><</link>>
:: Cabin Bath Refuse [nobr]
<<set $outside to 0>><<set $location to "cabin">><<effects>>
<<He>> yanks your leash, dragging you into the bath.
<br><br>
<<link [[Next|Forest Hunter Punishment]]>><<set $molestationstart to 1>><<set $phase to 1>><</link>><br>
:: Forest Cabin Weaken [nobr]
<<set $outside to 0>><<set $location to "cabin">><<effects>>
You subtly grind the leash against the tree, careful not to be noticed. You think you feel the leash become thinner.<br><br>
Some time later, Eden pants and stretches while looking at the setting sun. "I need a bath. Come on, let's go home."
<<if $forestleashedwear gte 1>>
<<set $forestleashedwear += 1>>
<<else>>
<<set $forestleashedwear to 1>>
<</if>>
<br><br>
<<link [[Next|Forest Cabin]]>><<pass 2 hours>><<pass 2 hours>><<pass 2 hours>><<pass 2 hours>><<endevent>><</link>><br>
:: Forest Cabin Good [nobr]
<<set $outside to 0>><<set $location to "cabin">><<effects>>
Some time later, Eden pants and stretches while looking at the setting sun. "I need a bath. Come on, let's go home."
<br><br>
<<link [[Next|Forest Cabin]]>><<pass 2 hours>><<pass 2 hours>><<pass 2 hours>><<pass 2 hours>><<endevent>><</link>><br>
:: Forest Clearing [nobr]
<<set $outside to 1>><<set $location to "forest">><<effects>>
<<if $foresthunt gte 1>>
<<set $foresthunt += 1>>
<</if>>
<<if $phase is 1>><<set $phase to 0>>
You search for plants long and sturdy enough to build an improvised garment. You find some suitable specimens and tie them together around your chest. It's fragile and revealing, and you don't think you could take it off without breaking it, but it's better than nothing.
<<plantupper>><br><br>
<<elseif $phase is 2>><<set $phase to 0>>
You search for plants long and sturdy enough to build an improvised garment. You find some suitable specimens and tie them together around your waist. It's fragile and revealing, and you don't think you could take it off without breaking it, but it's better than nothing.
<<plantlower>><br><br>
<</if>>
<<link [[Next|Forest]]>><<set $eventskip to 1>><</link>><br>
:: Eden Sleep Sex [nobr]
<<if $sexstart is 1>>
<<set $sexstart to 0>>
<<consensual>>
<<set $consensual to 1>>
<<neutral 1>>
<<set $event to "molestationhome">>
<<man1init>>
<<set $enemytrust += 100>><<set $enemyhealth to 600>><<set $enemyhealthmax to 600>>
<<promiscuity1>>
<<elseif $molestationstart is 1>>
<<set $molestationstart to 0>>
<<controlloss>>
<<violence 1>>
<<neutral 1>>
<<molested>>
<<set $event to "molestationhome">>
<<man1init>><<set $enemyhealth to 600>><<set $enemyhealthmax to 600>><<set $enemyanger += 50>>
<</if>>
<<effects>>
<<effectsman>><<man>>
<<stateman>><br>
<br>
<<actionsman>>
<<if $finish is 1>>
<span id="next"><<link [[Next|Eden Sleep Sex Finish]]>><</link>></span><<nexttext>>
<<elseif $enemyhealth lte 0>>
<span id="next"><<link [[Next|Eden Sleep Sex Finish]]>><</link>></span><<nexttext>>
<<elseif $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next|Eden Sleep Sex Finish]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next|Eden Sleep Sex]]>><</link>></span><<nexttext>>
<</if>>
:: Eden Sleep Push [nobr]
<<set $outside to 0>><<set $location to "cabin">><<effects>>
You shove <<him>> away from you.<<set $edenlove -= 1>><<set $edendom -= 1>>
<<if $edenlove - $edenlust gte 1>>
<<He>> grumbles something and rolls over. <<Hes>> asleep within moments.<br><br>
<<link [[Back to sleep|Eden Cabin Bed]]>><<endevent>><</link>><br>
<<link [[Get up|Eden Cabin]]>><<endevent>><</link>><br>
<<else>>
<<He>> starts groping more forcefully.<br><br>
<<link [[Next|Eden Sleep Sex]]>><<set $molestationstart to 1>><</link>><br>
<</if>>
:: Eden Sleep Sex Finish [nobr]
<<set $outside to 0>><<set $location to "cabin">><<effects>>
<<if $enemyarousal gte $enemyarousalmax>>
<<ejaculation>><<set $edenlust -= 20>>
<<He>> kisses you on the neck, rolls over, and goes to sleep.<br><br>
<<clotheson>>
<<endcombat>>
<<elseif $enemyhealth lte 0>>
"You ungrateful slut," <<he>> says. "Maybe I should throw you out and leave you to the wolves!" <<He>> winces and holds <<his>> side. "I need to get something for this."<br><br>
<<tearful>> you hide beneath the covers.<br><br>
<<clotheson>>
<<endcombat>>
<<elseif $finish is 1>>
<<He>> rolls over. You hear <<him>> snore moments later.<br><br>
<<clotheson>>
<<endcombat>>
<</if>>
<br><br>
<<link [[Next|Eden Cabin Bed]]>><</link>>
:: Eden Bindings [nobr]
<<effects>>
<<if $submissive gte 1150>>
"I-If it's no trouble, could you untie me please?" you ask.
<<elseif $submissive lte 850>>
"It may have escaped your notice, but my arms are tied. Could you help?" you ask.
<<else>>
"Can you untie me?" you ask.
<</if>>
Without a word, Eden picks up a knife and slashes your bindings.<br><br>
<<if $bus is "edenclearing">>
<<link [[Next|Eden Clearing]]>><<endevent>><</link>><br>
<<else>>
<<link [[Next|Eden Cabin]]>><<endevent>><</link>><br>
<</if>>
:: Eden Clearing [nobr]
<<set $outside to 1>><<set $location to "cabin">><<effects>><<set $bus to "edenclearing">><<set $edendays to 0>>
You are in the clearing outside Eden's cabin. The surrounding trees are so huge that you have to crane your neck to see the sky. There's a small farm plot where Eden grows vegetables. Behind the cabin is a spring at the base of a cliff.<br><br>
<<if $foresthunt gte 1>>
<span class="lblue">You're safe at Eden's cabin. Whatever was hunting you will have given up.</span><br><br>
<<set $foresthunt to 0>>
<</if>>
<<if $exposed gte 2>>
You don't want to be seen like this! You rush to your clothes.<br><br>
<<link [[Next|Eden Wardrobe]]>><<endevent>><</link>><br><br>
<<elseif $exhibitionism lte 54 and $exposed gte 1>>
You don't want to be seen like this! You rush to your clothes.<br><br>
<<link [[Next|Eden Wardrobe]]>><<endevent>><</link>><br><br>
<<else>>
<<if $exposed is 1 and $exhibitionism gte 55>>
<span class="lewd">With your <<lewdness>> on display, you can't help but feel a primal thrill.</span><br><br>
<</if>>
<<if $weather is "rain">>
Rainwater drips from the branches above.<br><br>
<</if>>
<<if $hour gte 9 and $hour lte 10>>
Eden is tending the crops.<br><br>
<<clearingedenactions>>
<<clearingactions>>
<<elseif $hour gte 11 and $hour lte 14>>
<<if $edenhunting isnot 1>><<set $edenhunting to 1>>
<<eden>><<person1>>Eden exits the cabin, gun in hand. "I'm going hunting. Stay near the cabin while I'm gone."<br><br>
<<link [[Nod|Eden Hunting]]>><<set $phase to 0>><</link>><br>
<<link [[Ask to go along|Eden Hunting]]>><<set $phase to 1>><</link>><br>
<<else>>
Eden is out hunting.<br><br>
<<clearingactions>>
<</if>>
<<elseif $hour is 15>>
Eden is skinning prey. The smell makes you queasy.<br><br>
<<clearingedenactions>>
<<clearingactions>>
<<elseif $hour is 16>>
<<if $edenlust gte 26 and $edenchoplust isnot 1>><<set $edenchoplust to 1>>
<<eden>><<person1>>Eden is chopping firewood. <<He>> stretches <<his>> back and spots you watching <<himstop>> "I could use a break," <<he>> says. <<He>> marches towards you, covered in sweat and axe still in hand. <<He>> probably doesn't realise how menacing <<he>> looks. <<He>> drops the axe and tries to pull you close to <<himstop>><br><br>
<<link [[Allow it|Eden Firewood Sex]]>><<set $sexstart to 1>><<set $edenlove += 1>><<set $edendom += 1>><</link>><br>
<<link [[Refuse|Eden Firewood Refuse]]>><<set $edenlove -= 1>><<set $edendom -= 1>><</link>><br>
<<else>>
Eden is chopping firewood.<br><br>
<<clearingedenactions>>
<<clearingactions>>
<</if>>
<<else>>
Eden is indoors.<br><br>
<<clearingactions>>
<</if>>
<</if>>
:: Eden Bath [nobr]
<<set $outside to 0>><<set $location to "cabin">><<effects>>
<<if $phase is 0>>
You remove your clothing as Eden eases <<himself>> into the bath.
<<if $exhibitionism gte 55>>
Feeling comfortable with your nudity, you climb in with <<himstop>>
<<else>>
<<covered>> You climb in with <<himstop>> Unable to hold the sides, you almost slip.
<</if>>
<br><br>
<<He>> reclines opposite you, enjoying the warmth and examining your body.<<wash>><br><br>
<<link [[Examine Eden in return|Eden Bath 2]]>><<set $phase to 0>><</link>><br>
<<link [[Wash Eden|Eden Bath 2]]>><<set $phase to 1>><<set $edenlove += 1>><</link>><br>
<<link [[Relax|Eden Bath 2]]>><<set $phase to 2>><<stress -12>><</link>><<lstress>><br>
<<if $promiscuity gte 15>>
<<link [[Seduce|Eden Bath Seduction]]>><</link>><<promiscuous2>><br>
<</if>>
<<elseif $phase is 1>>
<<if $edenlove gte 1>>
"Suit yourself," <<he>> says, easing <<himself>> into the water.<br><br>
<<link [[Next|Eden Cabin]]>><<endevent>><</link>><br>
<<else>>
"I said get in," <<he>> says, marching over to you. "I think you need another lesson." <<He>> bends you over <<his>> knee.<br><br>
<<link [[Next|Eden Cabin Punishment]]>><<set $molestationstart to 1>><</link>><br>
<</if>>
<</if>>
:: Eden Bath 2 [nobr]
<<set $outside to 0>><<set $location to "cabin">><<effects>>
<<if $phase is 0>>
You check out Eden's body. <<His>> muscles look very defined. <<He>> notices your gaze. "You can't avoid a body like this if you live like I do," <<he>> sounds almost ashamed.<br><br>
<<link [[Reassure|Eden Bath 2]]>><<set $phase to 3>><<set $edenlove += 1>><<set $edendom -= 1>><</link>><br>
<<link [[Look away and pick up the sponge|Eden Bath 2]]>><<set $phase to 1>><<set $edenlove += 1>><</link>><br>
<<link [[Look away and relax|Eden Bath 2]]>><<set $phase to 2>><<stress -12>><</link>><<lstress>><br>
<<elseif $phase is 1>>
You pick up the sponge and wave it. Eden turns <<his>> back to you and you get to scrubbing.
<<if $exhibitionism lt 55>>
You feel more comfortable about your nudity with <<his>> back turned.
<</if>>
<br><br>
The water starts to get cold after a while. "You can get out now, I'd like to stretch out anyway." You see no reason to complain.<br><br>
<<link [[Next|Eden Cabin]]>><<clotheson>><<endevent>><</link>>
<<elseif $phase is 2>>
You lean back and relax, letting the warmth seep into your muscles.<br><br>
The water starts to get cold after a while. "You can get out now, I'd like to stretch out anyway." You see no reason to complain.<br><br>
<<link [[Next|Eden Cabin]]>><<clotheson>><<endevent>><</link>>
<<elseif $phase is 3>>
<<if $submissive gte 1150>>
"You look amazing," you say.
<<elseif $submissive lte 850>>
"Don't be silly," you say. "People would kill for a body like yours."
<<else>>
"You look good," you say.
<</if>>
<br><br>
<<He>> smiles, "Thanks."<br><br>
<<link [[Wash Eden|Eden Bath 2]]>><<set $phase to 1>><<set $edenlove += 1>><</link>><br>
<<link [[Relax|Eden Bath 2]]>><<set $phase to 2>><<stress -12>><</link>><<lstress>><br>
<</if>>
:: Eden Bath Seduction [nobr]
<<effects>>
<<set $seductiondifficulty to (10000 - ($edenlust * 200))>>
<<seductioncheck>><br><br>
<span class="gold">You feel more confident in your powers of seduction.</span><<seductionskilluse>><br><br>
You kick some water at <<him>> playfully, coming tantalisingly close to flashing your <<genitalsstop>><<promiscuity2>>
<<if $seductionrating gte $seductionrequired>>
<<He>> takes the hint, grabbing your legs and pulling you closer.<br><br>
<<link [[Next|Eden Bath Sex]]>><<set $sexstart to 1>><</link>><br>
<<else>>
"Not right now," <<he>> says. "I just want to rest."<br><br>
<i><<He>> will be more lusty, and easier to seduce, the longer <<hes>> gone without sex.</i><br><br>
<<link [[Wash Eden|Eden Bath 2]]>><<set $phase to 1>><<set $edenlove += 1>><</link>><br>
<<link [[Relax|Eden Bath 2]]>><<set $phase to 2>><<stress -12>><</link>><<lstress>><br>
<</if>>
:: Eden Bath Sex [nobr]
<<if $sexstart is 1>>
<<set $sexstart to 0>>
<<consensual>>
<<set $consensual to 1>>
<<neutral 1>>
<<set $event to "molestationhome">>
<<man1init>>
<<set $enemytrust += 100>><<set $enemyhealth to 600>><<set $enemyhealthmax to 600>>
<</if>>
<<effects>>
<<effectsman>><<man>>
<<stateman>><br>
<br>
<<actionsman>>
<<if $finish is 1>>
<span id="next"><<link [[Next|Eden Bath Sex Finish]]>><</link>></span><<nexttext>>
<<elseif $enemyhealth lte 0>>
<span id="next"><<link [[Next|Eden Bath Sex Finish]]>><</link>></span><<nexttext>>
<<elseif $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next|Eden Bath Sex Finish]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next|Eden Bath Sex]]>><</link>></span><<nexttext>>
<</if>>
:: Eden Bath Sex Finish [nobr]
<<set $outside to 0>><<set $location to "cabin">><<effects>>
<<if $enemyarousal gte $enemyarousalmax>>
<<ejaculation>><<set $edenlust -= 20>><<set $edenlove += 1>>
"You're such a dirty <<girlcomma>> I love it," <<he>> says.<br><br>
<<clotheson>>
<<endcombat>>
<<elseif $enemyhealth lte 0>>
"You ungrateful slut," <<he>> says. "Maybe I should throw you out and leave you to the wolves!" <<He>> winces and holds <<his>> side. "I need to get something for this."<br><br>
<<tearful>> you climb out from under the table.<br><br>
<<clotheson>>
<<endcombat>>
<<elseif $finish is 1>>
"You little tease," <<he>> says. "Don't get me worked up if you don't intend to go all the way."<br><br>
<<clotheson>>
<<endcombat>>
<</if>>
<br><br>
The water starts to get cold after a while. "You can get out now, I'd like to stretch out anyway." You see no reason to complain.<br><br>
<<link [[Next|Eden Cabin]]>><</link>>
:: Eden Cuddle [nobr]
<<set $outside to 0>><<set $location to "cabin">><<effects>>
You snuggle up to Eden and <<he>> holds you close. Together you watch the fire.<br><br>
<<if $hour isnot 0>>
<<link [[Keep Cuddling (0:30)|Eden Cuddle]]>><<trauma -3>><<stress -6>><<pass 30>><<set $edenlove += 1>><</link>><<ltrauma>><<lstress>><br>
<</if>>
<<link [[Next|Eden Cabin]]>><<endevent>><</link>><br>
:: Eden Hunting [nobr]
<<set $outside to 1>><<set $location to "cabin">><<effects>>
<<if $phase is 0>>
<<He>> disappears between the trees.<br><br>
<<link [[Next|Eden Clearing]]>><<endevent>><</link>><br>
<<elseif $phase is 1>>
"Don't be ridiculous," <<he>> says. "Predators have learned to stay away from the cabin. You'll be safe here."<br><br>
<<if $submissive gte 1150>>
"I only feel safe with you," you say."<br><br>
<<elseif $submissive lte 850>>
"Maybe if you left your gun here I would be," you say.<br><br>
<<else>>
"Are you sure I'll be safe here alone?" you say.<br><br>
<</if>>
<<if $edenlove gte 50>>
"Fine," <<he>> says. "But be quiet and stay close to me. Bring a basket too, you can keep an eye out for berries."<br><br>
<<link [[Next|Eden Hunt]]>><</link>><br>
<<else>>
"I can't hunt and keep watch over you at the same time," <<he>> says. "That's final."<br><br>
<i>If <<he>> liked you more <<he>> might be more amenable to your request.</i><br><br>
<<link [[Next|Eden Hunting]]>><<set $phase to 0>><</link>><br>
<</if>>
<</if>>
:: Eden Hunt [nobr]
<<set $outside to 1>><<set $location to "forest">><<effects>>
You walk into the forest, keeping close behind Eden.
<<if $collared is 1>>
<<He>> grips your leash, pulling you along.
<<if $submissive gte 1150>>
"You're hurting my neck," you whisper. "I promise to be good."
<<elseif $submissive lte 850>>
"I won't find any berries if you drag me like this," you whisper.
<<else>>
"You can drop my leash. I promise I'll stay close," you whisper.
<</if>>
<<He>> looks at you, considers for a moment, then drops the leash.<br><br>
<</if>>
<br><br>
<<He>> seems to know exactly where <<hes>> going, but you quickly lose your sense of direction. <<pass 1 hour>><<He>> stops occasionally to check small traps. Most are empty but one contains a dead rabbit, which <<he>> ties to <<his>> belt.<br><br>
<<pass 1 hour>>More time passes, until <<he>> comes to an abrupt stop. "I've got you now," <<he>> whispers, <<his>> pace lowering to a creep. <<He>> glances at you. "Wait here. Don't move an inch." <<He>> disappears between the trees. You look around, but don't see any sign of whatever has <<him>> excited. You do, however, see a bush full of ripe berries. Eden hasn't noticed them.<br><br>
<<link [[Get the berries|Eden Hunt 2]]>><<set $phase to 0>><<endevent>><</link>><br>
<<link [[Stay close to Eden|Eden Hunt 2]]>><<set $phase to 1>><</link>><br>
:: Eden Hunt 2 [nobr]
<<set $outside to 1>><<set $location to "forest">><<effects>>
<<if $phase is 0>>
You sneak over to the bush, careful not to disturb a single twig. Once there you pick the fruit and quickly fill the basket. Satisfied, you start sneaking back to Eden.<br><br>
<<set $danger to random(1, 10000)>><<set $dangerevent to 0>>
<<if $danger gte (9900 - ($allure))>>
<<if $rng gte 81 and $bestialitydisable is "f" and $voredisable is "f">>
You round a tree and come face to face with a pair of eyes, hovering just inches from your face. All strength drains from your muscles, and you collapse to the ground. The snake slithers onto the forest floor.<<set $trance to 1>><br><br>
<<link [[Next|Eden Hunt Snake]]>><<set $molestationstart to 1>><</link>><br>
<<elseif $rng gte 41 and $bestialitydisable is "f">>
A wolf emerges from between the trees, teeth bared. Eden would hear your screams from here, but won't be happy with you.<br><br>
<<link [[Next|Eden Hunt Wolf]]>><<set $molestationstart to 1>><</link>><br>
<<else>>
<<generate1>><<generate2>>Something presses against your back. "What have we here?" the <<person1>><<person>> says. <<Hes>> holding a gun to your back.<br><br>
A <<person2>><<person>> puts a hand on your shoulder, "Turn around <<girlstop>> Now, what's a little thing like you doing all alone in the forest?"<br><br>
<<person1>>"It's dangerous out here," the <<person>> interjects. "But it's okay, we can keep you safe." <<He>> grabs your <<bottom>> and pulls you closer.<br><br>
Eden would hear your screams from here, but won't be happy with you.<br><br>
<<link [[Next|Eden Hunt Molestation]]>><<set $molestationstart to 1>><</link>><br>
<</if>>
<<else>>
<<eden>><<person1>>
<<link [[Next|Eden Hunt 3]]>><<set $phase to 0>><</link>><br>
<</if>>
<<elseif $phase is 1>>
<<eden>><<person1>>You were told to stay still, so that's what you do. You're only waiting for a couple of minutes before a gunshot sounds through forest.<br><br>
<<link [[Next|Eden Hunt 3]]>><<set $phase to 2>><</link>><br>
<</if>>
:: Eden Hunt Snake [nobr]
<<set $outside to 1>><<set $location to "forest">><<effects>>
<<if $molestationstart is 1>><<set $molestationstart to 0>>
<<set $combat to 1>>
<<molested>>
<<controlloss>>
<<set $vorestage to 1>>
<<set $vorecreature to "snake">>
<<set $vorestrength to 1>>
<<set $timer to 15>>
<</if>>
<<if $timer is 12>>
<<set $trance to 0>>
You break free from the trance, and realise the snake is trying to eat you!
<</if>>
<<voreeffects>>
<<vore>>
<<voreactions>>
<<if $timer lte 0>>
<span id="next"><<link [[Next|Eden Hunt Snake Finish]]>><</link>></span><<nexttext>>
<<elseif $vorestage lte 0>>
<span id="next"><<link [[Next|Eden Hunt Snake Finish]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link "Next">><<script>>state.display(state.active.title, null, "back")<</script>><</link>></span><<nexttext>>
<</if>>
:: Eden Hunt Snake Finish [nobr]
<<effects>>
<<set $trance to 0>>
<<if $timer lte 0>>
<<if $vorestage gte 5>>
The walls of the snake's innards tear open. Eden stands there, knife in hand, carving open the beast until you're freed.<br><br>
<<else>>
The snake hisses and spits you out. It flees into the undergrowth, trailing blood.<br><br>
<</if>>
<<clotheson>>
<<endcombat>>
<<eden>><<person1>>Eden plants <<his>> knife into the ground and grasps your arm. <<He>> bends you over <<his>> knee. "I was so close to catching that deer," <<he>> says. "And you fucking ruined it."<br><br>
<<link [[Next|Eden Hunt Punishment]]>><<set $molestationstart to 1>><</link>>
<<else>>
<<tearful>> you haul yourself out of the $vorecreature's maw. Deciding you aren't an appropriate meal, it disappears into the undergrowth.<br><br>
<<clotheson>>
<<endcombat>>
<<eden>><<person1>>
<<link [[Next|Eden Hunt 3]]>><<set $phase to 0>><</link>><br>
<</if>>
:: Eden Hunt Punishment [nobr]
<<if $molestationstart is 1>>
<<set $molestationstart to 0>>
<<controlloss>>
<<violence 1>>
<<neutral 1>>
<<molested>>
<<set $event to "molestationhome">>
<<man1init>><<npcspank>><<set $enemyhealth to 600>><<set $enemyhealthmax to 600>><<set $enemyanger += 200>><<set $edenlove -= 1>>
<</if>>
<<effects>>
<<effectsman>><<man>>
<<stateman>><br>
<br>
<<actionsman>>
<<if $enemyhealth lte 0>>
<span id="next"><<link [[Next|Eden Hunt Punishment Finish]]>><</link>></span><<nexttext>>
<<elseif $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next|Eden Hunt Punishment Finish]]>><</link>></span><<nexttext>>
<<elseif $enemyanger lte 0>>
<span id="next"><<link [[Next|Eden Hunt Punishment Finish]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next|Eden Hunt Punishment]]>><</link>></span><<nexttext>>
<</if>>
:: Eden Hunt 3 [nobr]
<<set $outside to 1>><<set $location to "forest">><<effects>>
<<if $phase is 0>>
<<if $rng gte 91>>
You find Eden slinging a deer over <<his>> shoulder. <<He>> sees the basket full of fruit in your hands and smiles. "We've done very well today," <<he>> says. "Maybe you're good luck."<<set $edenlove += 5>><br><br>
<<else>>
You find Eden crouched and frowning. "I let it get away," <<he>> says. <<He>> sees the basket of fruit in your hands and smiles. "At least we have something."<<set $edenlove += 5>><br><br>
<</if>>
<<elseif $phase is 1>>
You pick up the basket of fruit. "At least we got something," Eden says.<br><br>
<<elseif $phase is 2>>
<<if $rng gte 91>>
Eden appears between the trees, deer slung over <<his>> shoulder. "Knew I'd get it. Maybe you're a good luck charm."<br><br>
<<if $submissive gte 1150>>
"I found some berries, but I lost sight of of them," you say. "I'm sorry."
<<elseif $submissive lte 850>>
"There's a bush full of berries around here somewhere," you say.
<<else>>
"I saw a bush full of berries," you say. "But I can't see it now."
<</if>>
<br><br>
<<He>> shrugs. "I'm no good at hunting fruit. Besides, we're good for today."<br><br>
<<else>>
Eden appears between the trees, frowning. "I let it get away," <<he>> says.<br><br>
<<if $submissive gte 1150>>
"I found some berries, but I lost sight of of them," you say. "I'm sorry."
<<elseif $submissive lte 850>>
"There's a bush full of berries around here somewhere," you say.
<<else>>
"I saw a bush full of berries," you say. "But I can't see it now."
<</if>>
<br><br>
<<He>> shrugs. "I'm no good at hunting fruit. "We have something at least." <<He>> pats the rabbit on <<his>> belt.<br><br>
<</if>>
<</if>>
<<pass 2 hours>>You follow Eden through the forest, back to the safety of <<his>> cabin.<br><br>
<<endevent>>
<<link [[Next|Eden Clearing]]>><</link>><br>
:: Eden Hunt Punishment Finish [nobr]
<<set $outside to 1>><<set $location to "forest">><<effects>>
<<if $enemyarousal gte $enemyarousalmax>>
<<ejaculation>><<set $edenlust -= 20>>
<<He>> pants from the exertion. "I hope you've learnt your lesson."<br><br>
<<tearful>> you avoid <<his>> gaze.<br><br>
<<clotheson>>
<<endcombat>>
<<eden>><<person1>>
<<link [[Next|Eden Hunt 3]]>><<set $phase to 1>><</link>><br>
<<elseif $enemyhealth lte 0>>
"You ungrateful slut," <<he>> says. "Maybe I should throw you out and leave you to the wolves!" <<He>> winces and holds <<his>> side. "I need to get something for this."<br><br>
<<tearful>> you gather yourself.<br><br>
<<clotheson>>
<<endcombat>>
<<eden>><<person1>>
<<link [[Next|Eden Hunt 3]]>><<set $phase to 1>><</link>><br>
<<else>>
<<He>> looks mollified, and releases you. "I hope you've learnt your lesson."<br><br>
<<tearful>> you avoid <<his>> gaze.<br><br>
<<clotheson>>
<<endcombat>>
<<eden>><<person1>>
<<link [[Next|Eden Hunt 3]]>><<set $phase to 1>><</link>><br>
<</if>>
:: Eden Hunt Wolf [nobr]
<<if $molestationstart is 1>>
<<set $molestationstart to 0>>
<<controlloss>>
<<violence 1>>
<<neutral 1>>
<<molested>>
<<set $event to "dogpack">>
<<beast1init>><<set $beasttype to "wolf">><<set $enemytrust -= 40>>
<<set $rescue to 1>>
<</if>>
<<effects>>
<<effectsman>><br><<beast>><br><br>
<<stateman>><br>
<br>
<<actionsman>>
<<if $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next|Eden Hunt Wolf Finish]]>><</link>></span><<nexttext>>
<<elseif $enemyhealth lte 0>>
<span id="next"><<link [[Next|Eden Hunt Wolf Finish]]>><</link>></span><<nexttext>>
<<elseif $rescue is 1 and $alarm is 1>>
<span id="next"><<link [[Next|Eden Hunt Wolf Finish]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next|Eden Hunt Wolf]]>><</link>></span><<nexttext>>
<</if>>
:: Eden Hunt Wolf Finish [nobr]
<<set $outside to 1>><<set $location to "forest">><<effects>>
<<if $enemyarousal gte $enemyarousalmax>>
<<beastejaculation>>
The beast grunts in satisfaction, and leaves you lying between the trees.<br><br>
<<tearful>> you continue back to Eden.<br><br>
<<clotheson>>
<<endcombat>>
<<eden>><<person1>>
<<link [[Next|Eden Hunt 3]]>><<set $phase to 0>><</link>><br>
<<elseif $enemyhealth lte 0>>
The beast yelps and flees into the forest.<br><br>
<<tearful>> you continue back to Eden.<br><br>
<<clotheson>>
<<endcombat>>
<<eden>><<person1>>
<<link [[Next|Eden Hunt 3]]>><<set $phase to 0>><</link>><br>
<<else>>
A gun fires nearby, startling the wolf into fleeing. Eden marches towards you.
<<clotheson>>
<<endcombat>>
<<eden>><<person1>>
<<He>> grasps your arm and bends you over <<his>> knee. "Stupid <<bitchcomma>> I was so close to catching that deer."<br><br>
<<link [[Next|Eden Hunt Punishment]]>><<set $molestationstart to 1>><</link>><br>
<</if>>
:: Eden Hunt Molestation [nobr]
<<if $molestationstart is 1>>
<<set $molestationstart to 0>>
<<controlloss>>
<<violence 1>>
<<neutral 1>>
<<molested>>
<<set $event to "molestationhome">>
<<man1init>>
<<set $rescue to 1>>
<</if>>
<<effects>>
<<effectsman>><<man>>
<<stateman>><br>
<br>
<<actionsman>>
<<if $enemyhealth lte 0>>
<span id="next"><<link [[Next|Eden Hunt Molestation Finish]]>><</link>></span><<nexttext>>
<<elseif $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next|Eden Hunt Molestation Finish]]>><</link>></span><<nexttext>>
<<elseif $rescue is 1 and $alarm is 1>>
<span id="next"><<link [[Next|Eden Hunt Molestation Finish]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next|Eden Hunt Molestation]]>><</link>></span><<nexttext>>
<</if>>
:: Eden Hunt Molestation Finish [nobr]
<<set $outside to 1>><<set $location to "forest">><<effects>>
<<if $enemyarousal gte $enemyarousalmax>>
<<ejaculation>>
Finished with you, they shove you to the ground. "See ya around, slut."<br><br>
<<tearful>> you struggle to your feet and continue back to Eden.<br><br>
<<clotheson>>
<<endcombat>>
<<eden>><<person1>>
<<link [[Next|Eden Hunt 3]]>><<set $phase to 0>><</link>><br>
<<elseif $enemyhealth lte 0>>
"This <<bitch>> is crazy," says the <<person1>><<personcomma>> clutching <<his>> arm. "I think I need to get this looked at."<br><br>
The <<person2>><<person>> nods in agreement, "<<pShe>> ain't worth it." They stagger into the forest.<br><br>
<<tearful>> you continue back to Eden.<br><br>
<<clotheson>>
<<endcombat>>
<<eden>><<person1>>
<<link [[Next|Eden Hunt 3]]>><<set $phase to 0>><</link>><br>
<<else>>
A gunshot sounds and a bullet smashes into a nearby tree, startling the pair and making them dash for their own guns. They stare into the trees. "Who's there?" shouts the <<person1>><<personstop>> <<Hes>> responded to by another gunshot, the bullet landing closer this time. Their eyes dart around, but they can't see the shooter. Another gunshot, this time the bullet thuds into the ground at the <<person2>><<persons>> feet. "Shit! Fuck." <<he>> says, backing away, eyes wild. "Let's get the fuck away from here. This <<girl>> ain't worth it."<br><br>
They've barely disappeared between the trees when you see Eden marching towards you.<br><br>
<<clotheson>>
<<endcombat>>
<<eden>><<person1>>
<<He>> grasps your arm and bends you over <<his>> knee. "Stupid <<bitchcomma>> I was so close to catching that deer."<br><br>
<<link [[Next|Eden Hunt Punishment]]>><<set $molestationstart to 1>><</link>><br>
<</if>>
:: Eden Firewood Sex [nobr]
<<if $sexstart is 1>>
<<set $sexstart to 0>>
<<consensual>>
<<set $consensual to 1>>
<<neutral 1>>
<<set $event to "molestationhome">>
<<man1init>>
<<set $enemytrust += 100>><<set $enemyhealth to 600>><<set $enemyhealthmax to 600>>
<<promiscuity1>>
<<elseif $molestationstart is 1>>
<<set $molestationstart to 0>>
<<controlloss>>
<<violence 1>>
<<neutral 1>>
<<molested>>
<<set $event to "molestationhome">>
<<man1init>><<set $enemyhealth to 600>><<set $enemyhealthmax to 600>><<set $enemyanger += 50>>
<</if>>
<<effects>>
<<effectsman>><<man>>
<<stateman>><br>
<br>
<<actionsman>>
<<if $finish is 1>>
<span id="next"><<link [[Next|Eden Firewood Sex Finish]]>><</link>></span><<nexttext>>
<<elseif $enemyhealth lte 0>>
<span id="next"><<link [[Next|Eden Firewood Sex Finish]]>><</link>></span><<nexttext>>
<<elseif $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next|Eden Firewood Sex Finish]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next|Eden Firewood Sex]]>><</link>></span><<nexttext>>
<</if>>
:: Eden Firewood Refuse [nobr]
<<set $outside to 1>><<set $location to "cabin">><<effects>>
<<if $edenlove - $edenlust gte 1>>
You turn away from <<himcomma>> making your disapproval of <<his>> actions clear. "I'm working really hard out here," <<he>> says. "You could be more considerate."<br><br>
<<endevent>>
<<link [[Next|Eden Clearing]]>><</link>><br>
<<else>>
You turn away from <<himcomma>> making your disapproval of <<his>> actions clear. <<He>> grabs your neck and forcibly turns your head to face <<himstop>> "I'm working really hard out here," <<he>> says. "The least you could is show some appreciation."<br><br>
<<link [[Next|Eden Firewood Sex]]>><<set $molestationstart to 1>><</link>><br>
<</if>>
:: Eden Firewood Sex Finish [nobr]
<<set $outside to 0>><<set $location to "cabin">><<effects>>
<<if $enemyarousal gte $enemyarousalmax>>
<<ejaculation>><<set $edenlust -= 20>>
"I'm glad I have you around," <<he>> says. <<He>> picks up <<his>> axe and returns to <<his>> chopping.<br><br>
<<clotheson>>
<<endcombat>>
<<elseif $enemyhealth lte 0>>
"You ungrateful slut," <<he>> says. "Maybe I should throw you out and leave you to the wolves!" <<He>> winces and holds <<his>> side. "I need to get something for this."<br><br>
<<tearful>> you hide behind a tree.<br><br>
<<clotheson>>
<<endcombat>>
<<elseif $finish is 1>>
"I guess I do need to get back to work," <<he>> says.<br><br>
<<clotheson>>
<<endcombat>>
<</if>>
<br><br>
<<link [[Next|Eden Clearing]]>><</link>>
:: Eden Freedom [nobr]
<<effects>>
<<if $edenlove gte 20>><<set $edenfreedom to 1>><<set $edenshopping to 0>>
<<eden>><<person1>>"Why would you want to leave?" <<he>> asks. "You have everything you need here."<br><br>
<<if $submissive gte 1150>>
"B-but if I'm gone from town too long," you say. "People will come looking for me me here."
<<elseif $submissive lte 850>>
"Do you think my absence isn't noticed?" you say. "They'll come looking for me here."<br><br>
<<else>>
"If I keep missing school," you say. "People will start looking for me."
<</if>>
<br><br>
<<He>> seems conflicted. "I suppose it was too much to hope you'd be content stuck here. Fine, you can go back to town. Make sure you get your little <<bottom>> back here though. <span class="gold">If you're gone longer than a day you'll worry me sick.</span> I'd have to come find you."<br><br>
<<link [[Hug|Eden Freedom 2]]>><<set $phase to 0>><<set $edenlove += 1>><</link>><br>
<<link [[Nod|Eden Freedom 2]]>><<set $phase to 1>><</link>><br>
<<else>>
<<eden>><<person1>>"Why would you want to leave?" <<he>> asks. "You have everything you need here."<br><br>
<<if $submissive gte 1150>>
"B-but if I'm gone from town too long," you say. "People will come looking for me me here."
<<elseif $submissive lte 850>>
"Do you think my absence isn't noticed?" you say. "They'll come looking for me here."<br><br>
<<else>>
"If I keep missing school," you say. "People will start looking for me."
<</if>>
<br><br>
<<He>> shakes <<his>> head. "They won't find us. I know these woods, and will protect what's mine if necessary."<br><br>
<i>If <<he>> liked you more <<he>> might be more amenable to your request.</i><br><br>
<<if $bus is "edenclearing">>
<<link [[Next|Eden Clearing]]>><<endevent>><</link>><br>
<<else>>
<<link [[Next|Eden Cabin]]>><<endevent>><</link>><br>
<</if>>
<</if>>
:: Eden Freedom 2 [nobr]
<<effects>>
<<if $phase is 0>>
You hug Eden, taking <<him>> by surprise and almost knocking <<him>> over.<br><br>
<<if $submissive gte 1150>>
"Thank you," you say, pressing your face against <<himstop>>
<<elseif $submissive lte 850>>
"It's not that I need your permission or anything," you say. "It's just easier this way."
<<else>>
"Thank you," you say.
<</if>>
<br><br>
<<He>> squeezes you back. "One more thing. I make weekly supply runs into town to pick up essentials. You might as well do it for me. I hate that place. Alright, you can let go now."<br><br>
<<elseif $phase is 1>>
"One more thing," <<he>> says. "I make weekly supply runs into town to pick up essentials. You may as well do it for me if you're going anyway. I hate that place."<br><br>
<<else>>
You hug Eden. <<He>> expects it and catches you.
<<if $submissive gte 1150>>
"Thank you," you say, pressing your face against <<himstop>>
<<elseif $submissive lte 850>>
"It's not that I need your permission or anything," you say. "It's just easier this way."
<<else>>
"Thank you," you say.
<</if>>
<<He>> squeezes you back.
<br><br>
<</if>>
<<if $bus is "edenclearing">>
<<link [[Next|Eden Clearing]]>><<endevent>><</link>><br>
<<else>>
<<link [[Next|Eden Cabin]]>><<endevent>><</link>><br>
<</if>>
:: Eden Cabin Escape [nobr]
<<set $outside to 1>><<set $location to "forest">><<effects>>
You walk to the edge of the clearing and gaze into the darkness of the forest. Are you sure you want to escape?<br><br>
<<link [[Yes|Forest]]>><</link>><br>
<<link [[No|Eden Clearing]]>><</link>><br>
:: Eden Freedom 3 [nobr]
<<effects>>
<<if $edenlove gte 100>><<set $edenfreedom to 2>>
<<eden>><<person1>>"You already get a whole day," <<he>> says. "You want to sleep in someone else's bed, is that it?"<br><br>
<<if $submissive gte 1150>>
"N-no," you say. "You know I'm yours alone."
<<elseif $submissive lte 850>>
"I'm not a slut," you say. "But sometimes I need to be away for longer."<br><br>
<<else>>
"No!" you say. "It's just that braving the woods every day for school is dangerous."
<</if>>
<br><br>
<<He>> looks about to argue, but sighs in resignation. "Fine. I'm used to being alone. <span class="gold">You can leave for up to a week.</span> If you're gone longer, I'll hunt you down."<br><br>
<<link [[Hug|Eden Freedom 2]]>><<set $phase to 2>><<set $edenlove += 1>><</link>><br>
<<if $bus is "edenclearing">>
<<link [[Nod|Eden Clearing]]>><<endevent>><</link>><br>
<<else>>
<<link [[Nod|Eden Cabin]]>><<endevent>><</link>><br>
<</if>>
<<else>>
<<eden>><<person1>>"You already get a whole day," <<he>> says. "You want to sleep in someone else's bed, is that it?"<br><br>
<<if $submissive gte 1150>>
"N-no," you say. "You know I'm yours alone."
<<elseif $submissive lte 850>>
"I'm not a slut," you say. "But sometimes I need to be away for longer."<br><br>
<<else>>
"No!" you say. "It's just that braving the woods every day for school is dangerous."
<</if>>
<br><br>
<<He>> shakes <<his>> head. "That town is dangerous. The less time you spend there the better."<br><br>
<i>If <<he>> liked you more <<he>> might be more amenable to your request.</i><br><br>
<<if $bus is "edenclearing">>
<<link [[Next|Eden Clearing]]>><<endevent>><</link>><br>
<<else>>
<<link [[Next|Eden Cabin]]>><<endevent>><</link>><br>
<</if>>
<</if>>
:: Forest Cabin Return [nobr]
<<set $outside to 1>><<set $location to "cabin">><<effects>>
Eden leads you back to the safety of <<his>> cabin.<br><br>
<<link [[Next|Eden Cabin]]>><<endevent>><</link>><br>
:: Eden Recaptured [nobr]
<<set $outside to 0>><<set $location to "cabin">><<effects>>
Eden grabs your arm and pushes you in front of <<himstop>> <<He>> pushes you through the forest and back to <<his>> cabin. Once inside, <<he>> shoves you to the floor.<br><br>
"I trust you," <<he>> says. "So when you don't do as I say, it really hurts."<br><br>
<<link [[Seduce|Eden Recaptured Seduction]]>><</link>><<promiscuous1>><br>
<<link [[Apologise|Eden Recaptured Apologise]]>><<set $edenlove += 1>><<set $edendom += 1>><</link>><br>
<<link [[Do nothing|Eden Recaptured Spank]]>><<set $molestationstart to 1>><</link>><br>
:: Eden Recaptured Seduction [nobr]
<<effects>>
<<set $seductiondifficulty to (10000 - ($edenlust * 50))>>
<<seductioncheck>><br><br>
<span class="gold">You feel more confident in your powers of seduction.</span><<seductionskilluse>><br><br>
You climb to your knees.
<<if $submissive gte 1150>>
"I can make it up to you!" you say.
<<elseif $submissive lte 850>>
"I think I know what you need," you say.
<<else>>
"Let me make it up to you," you say.
<</if>>
<<if $pronoun is "f">>
You lift up <<his>> skirt.<<promiscuity1>><br><br>
<<else>>
You open <<his>> fly.<<promiscuity1>><br><br>
<</if>>
<<if $seductionrating gte $seductionrequired>>
"This is a good way to start making it up to me," <<he>> says, pressing a hand against the back of your head and pushing you closer.<br><br>
<<link [[Next|Eden Recaptured Oral]]>><<set $sexstart to 1>><</link>><br>
<<else>>
<<He>> shoves you back to the ground. "Oh no, you're not getting off that easy."<br><br>
<<link [[Next|Eden Recaptured Spank]]>><<set $molestationstart to 1>><</link>><br>
<</if>>
:: Eden Recaptured Apologise [nobr]
<<set $outside to 0>><<set $location to "cabin">><<effects>>
You climb to your knees and look up at <<himstop>>
<<if $submissive gte 1150>>
"I'm very very sorry," you say. "I know I've been bad." You bow your head.
<<elseif $submissive lte 850>>
"I didn't mean to worry you," you say.
<<else>>
"I'm sorry, I know I've been bad," you say.
<</if>>
<br><br>
"I still need to punish you," Eden says. "Or you'll forget the lesson."<br><br>
<<link [[Next|Eden Recaptured Spank]]>><<set $phase to 1>><<set $molestationstart to 1>><</link>><br>
:: Eden Recaptured Spank [nobr]
<<if $molestationstart is 1>>
<<set $molestationstart to 0>>
<<controlloss>>
<<violence 1>>
<<neutral 1>>
<<molested>>
<<set $event to "molestationhome">>
<<man1init>><<npcspank>><<set $enemyhealth to 600>><<set $enemyhealthmax to 600>><<set $enemyanger += 200>>
<<if $phase is 1>>
<<set $enemyanger -= 75>>
<</if>>
<<He>> bends you over <<his>> knee.<br><br>
<</if>>
<<effects>>
<<effectsman>><<man>>
<<stateman>><br>
<br>
<<actionsman>>
<<if $enemyhealth lte 0>>
<span id="next"><<link [[Next|Eden Recaptured Spank Finish]]>><</link>></span><<nexttext>>
<<elseif $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next|Eden Recaptured Spank Finish]]>><</link>></span><<nexttext>>
<<elseif $enemyanger lte 0>>
<span id="next"><<link [[Next|Eden Recaptured Spank Finish]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next|Eden Recaptured Spank]]>><</link>></span><<nexttext>>
<</if>>
:: Eden Recaptured Spank Finish [nobr]
<<set $outside to 0>><<set $location to "cabin">><<effects>>
<<if $enemyarousal gte $enemyarousalmax>>
<<ejaculation>><<set $edenlust -= 20>>
<<He>> pants from the exertion. "I hope you've learnt your lesson. Don't disobey me again."<br><br>
<<tearful>> you avoid <<his>> gaze.<br><br>
<<clotheson>>
<<endcombat>>
<<link [[Next|Eden Cabin]]>><</link>><br>
<<elseif $enemyhealth lte 0>>
"You ungrateful slut," <<he>> says. "Maybe I should throw you out and leave you to the wolves!" <<He>> winces and holds <<his>> side. "I need to get something for this."<br><br>
<<tearful>> you gather yourself.<br><br>
<<clotheson>>
<<endcombat>>
<<link [[Next|Eden Cabin]]>><</link>><br>
<<elseif $enemyanger lte 0>>
<<He>> looks mollified, and releases you. "I hope you've learnt your lesson. Don't disobey me again."<br><br>
<<tearful>> you avoid <<his>> gaze.<br><br>
<<clotheson>>
<<endcombat>>
<<link [[Next|Eden Cabin]]>><</link>><br>
<</if>>
:: Eden Recaptured Oral [nobr]
<<if $sexstart is 1>>
<<set $sexstart to 0>>
<<consensual>>
<<set $consensual to 1>>
<<neutral 1>>
<<set $event to "molestationhome">>
<<man1init>><<npcoral>>
<<set $enemytrust -= 100>><<set $enemyhealth to 600>><<set $enemyhealthmax to 600>><<set $enemyanger += 80>>
<</if>>
<<effects>>
<<effectsman>><<man>>
<<stateman>><br>
<br>
<<actionsman>>
<<if $finish is 1>>
<span id="next"><<link [[Next|Eden Recaptured Oral Finish]]>><</link>></span><<nexttext>>
<<elseif $enemyhealth lte 0>>
<span id="next"><<link [[Next|Eden Recaptured Oral Finish]]>><</link>></span><<nexttext>>
<<elseif $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next|Eden Recaptured Oral Finish]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next|Eden Recaptured Oral]]>><</link>></span><<nexttext>>
<</if>>
:: Eden Recaptured Oral Finish [nobr]
<<set $outside to 0>><<set $location to "cabin">><<effects>>
<<if $enemyarousal gte $enemyarousalmax>>
<<ejaculation>><<set $edenlust -= 20>><<set $edenlove += 1>>
"I can't stay mad at you," <<he>> gasps. "But don't you dare run off again."<br><br>
<<clotheson>>
<<endcombat>>
<<elseif $enemyhealth lte 0>>
"You ungrateful slut," <<he>> says. "Maybe I should throw you out and leave you to the wolves!" <<He>> winces and holds <<his>> side. "I need to get something for this."<br><br>
<<tearful>> you climb out from under the table.<br><br>
<<clotheson>>
<<endcombat>>
<<elseif $finish is 1>>
"Remember," <<he>> says. "I'm keeping an eye on you."<br><br>
<<clotheson>>
<<endcombat>>
<</if>>
<br><br>
<<link [[Next|Eden Cabin]]>><</link>>
:: Street Eden [nobr]
<<effects>>
You cross the road. Eden spots you. "You think this is funny?" <<He>> shouts, marching towards you. I've been worried half to death!" <<He>> grasps your arm. "I'm taking you home, and never letting you leave again. I'll keep you in a cage if I have to."<br><br>
<<if $collared isnot 1>><<set $collared to 1>>
<<He>> fastens a collar around your neck.<br><br>
<</if>>
<<He>> grabs hold of your leash and pulls. "Come on. I'll punish you when we get home."<br><br>
<<generate2>><<person2>>"You shouldn't treat <<phim>> like that," A <<person>> bravely interjects as Eden drags you by. Eden ignores <<himstop>><br><br>
The sight of a <<girl>> being dragged along on a leash turns heads. People whisper to each other, but no one intervenes. A <<generatey3>><<person3>><<person>> laughs and pulls out <<his>> phone to record you. Eden ignores <<him>> too.
Eden calms down a bit once you're in the forest.<br><br>
<<endevent>><<eden>><<person1>>
<<link [[Next|Eden Recaptured]]>><</link>><br>
:: Street Eden Hide [nobr]
<<effects>>
You hide behind a postbox. Eden continues bothering passers-by, unaware that you're so close. It looks like <<he>> doesn't intend to move on for a while, until <<he>> starts arguing with a <<generate2>><<person2>><<personstop>> The argument becomes more intense until Eden storms off.<br><br>
<<endevent>>
<<destinationeventend>>
:: Eden Supplies [nobr]
<<effects>>
<<set $edenshopping to 1>>You shop for the things Eden can't make or do without. Tools and medical supplies mostly.<br><br>
<<link [[Next|Shopping Centre]]>><</link>><br>
:: Eden Supplied [nobr]
<<effects>>
<<set $edenshopping to 2>><<set $edenlove += 5>>
<<if $submissive gte 1150>>
"I got these for you," you say, putting the supplies on the table.
<<elseif $submissive lte 850>>
"I did your chore for you," you say, putting the supplies on the table.
<<else>>
"I got your supplies from town," you say, putting the supplies on the table.
<</if>>
<br><br>
"Good job," Eden says. "How much were they? I'll give you the money."<br><br>
<<link [[I don't need money|Eden Supplied 2]]>><<set $phase to 0>><<set $edenlove += 1>><<set $edendom += 1>><</link>><br>
<<link [[£50|Eden Supplied 2]]>><<set $phase to 1>><</link>><br>
<<set $skulduggerydifficulty to 200>>
<<link [[£200|Eden Supplied 2]]>><<set $phase to 2>><</link>><<skulduggerydifficulty>><br>
:: Eden Supplied 2 [nobr]
<<effects>>
<<if $phase is 0>>
"I guess what's yours is mine anyway," <<he>> says. "Thanks though."<br><br>
<<if $bus is "edenclearing">>
<<link [[Next|Eden Clearing]]>><<endevent>><</link>><br>
<<else>>
<<link [[Next|Eden Cabin]]>><<endevent>><</link>><br>
<</if>>
<<elseif $phase is 1>>
"Sounds about right," <<he>> reaches into <<his>> pouch. "Here you go."<br><br>
You've gained £50.<<set $money += 5000>><br><br>
<<if $bus is "edenclearing">>
<<link [[Next|Eden Clearing]]>><<endevent>><</link>><br>
<<else>>
<<link [[Next|Eden Cabin]]>><<endevent>><</link>><br>
<</if>>
<<else>>
<<skulduggerycheck>>
<<if $skulduggerysuccess is 1>>
"Two hundred?" Eden looks annoyed. "You got ripped off." <<He>> reaches into <<his>> pouch. "Still, worth me not doing it. Here you go."<br><br>
You've gained £200.<<set $money += 20000>><br><br>
<<if $skulduggery lte ($skulduggerydifficulty + 100)>>
<<skulduggeryskilluse>>
<<else>>
<span class="blue">That was too easy. You didn't learn anything.</span><br><br>
<</if>>
<<if $bus is "edenclearing">>
<<link [[Next|Eden Clearing]]>><<endevent>><</link>><br>
<<else>>
<<link [[Next|Eden Cabin]]>><<endevent>><</link>><br>
<</if>>
<<else>>
"I'm not gonna fall for that," <<he>> says. "You can pay out of your own pocket."<br><br>
<<if $skulduggery lte ($skulduggerydifficulty + 100)>>
<<skulduggeryskilluse>>
<<else>>
<span class="blue">That was too easy. You didn't learn anything.</span><br><br>
<</if>>
<<if $bus is "edenclearing">>
<<link [[Next|Eden Clearing]]>><<endevent>><</link>><br>
<<else>>
<<link [[Next|Eden Cabin]]>><<endevent>><</link>><br>
<</if>>
<</if>>
<</if>>
:: Clearing Weeding [nobr]
<<set $outside to 1>><<set $location to "cabin">><<effects>>
You get on your hands and knees and start tugging up weeds at their roots. Some of them are really stuck in there.<<physique 6>><<set $edengarden += 1>><br><br>
<<set $danger to random(1, 10000)>><<set $dangerevent to 0>>
<<if $danger gte (9900 - $allure)>>
<<if $rng gte 51 and $tentacledisable is "f" and $hallucinations gte 2>>
The vines around you animate into life. You try to stand but they wrap around your wrists, forcing you to remain on your knees.<br><br>
<<link [[Next|Clearing Weeding Tentacles]]>><<set $molestationstart to 1>><</link>><br>
<<elseif $hour lt 11 or $hour gt 14>>
<<eden>><<person1>>Eden creeps up behind you, making you jump in fright. <<He>> leans on your back, preventing you from standing up. "Why don't you stay right there," <<he>> says, reaching around you and fondling your <<groinstop>><br><br>
<<link [[Let Eden continue|Clearing Fondle]]>><<set $edenlove += 1>><<set $submissive += 1>><<set $edendom += 1>><</link>><<garousal>><br>
<<link [[Shove Eden off|Clearing Shove]]>><<set $edenlove -= 1>><<set $submissive -= 1>><<set $edendom -= 1>><</link>><br>
<<else>>
You work for a few hours. You stand back to admire the result. It looks much better than when you started.<br><br>
<<link [[Next|Eden Clearing]]>><<endevent>><</link>><br>
<</if>>
<<else>>
You work for a few hours. You stand back to admire the result. It looks much better than when you started.<br><br>
<<link [[Next|Eden Clearing]]>><<endevent>><</link>><br>
<</if>>
:: Clearing Weeding Tentacles [nobr]
<<set $outside to 1>><<set $location to "cabin">>
<<if $molestationstart is 1>><<set $molestationstart to 0>>
<<set $combat to 1>>
<<set $enemytype to "tentacles">>
<<molested>>
<<controlloss>>
<<set $tentacleno to 4>>
<<set $tentaclehealth to 15>>
<<tentaclestart>>
<<set $tentacle1shaft to "leftarm">><<set $leftarm to "grappled">>
<<set $tentacle2shaft to "rightarm">><<set $rightarm to "grappled">>
<<set $timer to 50>>
<</if>>
<<effects>>
<<effectstentacles>>
<<tentacles>>
<<statetentacles>>
<<actionstentacles>>
<<if $activetentacleno lte ($tentacleno / 2)>>
<span id="next"><<link [[Next|Clearing Weeding Tentacles Finish]]>><</link>></span><<nexttext>>
<<elseif $timer lte 0>>
<span id="next"><<link [[Next|Clearing Weeding Tentacles Finish]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next|Clearing Weeding Tentacles]]>><</link>></span><<nexttext>>
<</if>>
:: Clearing Weeding Tentacles Finish [nobr]
<<effects>>
The roots lose interest in you, and disappear into the soil. <<tearful>> you untangle yourself from the plants and vines surrounding you.
<<clotheson>>
<<endcombat>>
You step back and look at the result. The plot is in a much better state, at least.<br><br>
<<link [[Next|Eden Clearing]]>><</link>><br>
:: Clearing Fondle [nobr]
<<set $outside to 1>><<set $location to "cabin">><<effects>>
<<if $lowertype isnot "naked">>
<<if $skirt is 1>>
<<if $undertype is "chastity">>
<<He>> reaches beneath your $lowerclothes and starts probing your $underclothes. "You're such a little slut I bet I can make you cum even with this thing on."
<<else>>
<<He>> reaches beneath your $lowerclothes and starts touching you directly.
<</if>>
<<else>>
<<if $undertype is "chastity">>
<<He>> reaches beneath your $lowerclothes and starts probing your $underclothes. "You're such a little slut I bet I can make you cum even with this thing on."
<<else>>
<<He>> reaches into your $lowerclothes and starts touching you directly.
<</if>>
<</if>>
<<elseif $undertype isnot "naked" and $undertype isnot "chastity">>
<<He>> reaches into your $underclothes and starts touching you directly.
<<elseif $undertype is "chastity">>
<<He>> starts probing your $underclothes. "You're such a little slut I bet I can make you cum even with this thing on."
<<else>>
<<He>> continues to stroke and fondle your <<genitalsstop>>
<</if>>
<br><br>
"I've heard that sexual fluids are good for plants," <<he>> says. "I like the idea anyway. Let's test it.
<<if $arousal gte 8000>>
You're wet already so this won't take long."
<<else>>
Just relax and let me work."
<</if>>
<br><br>
<<if $penisexist is 1>>
<<He>> holds your <<penis>> in <<his>> palm while running <<his>> thumb up and down your length. <<He>> sometimes alternates to rubbing the head with a fast, circular motion.
<<if $penilevirginity gte 1>>
"I'm saving your virginity for a special occasion." <<He>> plays with your prepuce to. "But knowing me I'll take it before then. It's not my fault you look so tasty."
<</if>>
<<else>>
<<He>> gently inserts a finger into your <<pussycomma>> but doesn't go very deep. <<His>> thumb rubs your clit with a fast, circular motion.
<<if $vaginalvirginity gte 1>>
"I'm saving your virginity for a special occasion." <<He>> prods your hymen. "But knowing me I'll take it before then. It's not my fault you look so tasty."
<</if>>
<</if>>
<br><br>
<<set $arousal += 10000>>
<<orgasmpassage>>
"Good <<girlcomma>> give these plants a nice drink," <<he>> says as your body convulses. <<He>> holds you firm in place, making sure your fluids land on the soil. <<He>> kisses you on the cheek as your orgasm subsides. "That wasn't so bad, was it?" <<tearful>> you struggle to your feet. Eden is gone.<br><br>
The plot looks tidier at least.<br><br>
<<link [[Next|Eden Clearing]]>><<endevent>><</link>><br>
:: Clearing Shove [nobr]
<<set $outside to 1>><<set $location to "cabin">><<effects>>
You shove Eden away from you and stand up. "What's the matter?" <<he>> smiles. "I was just rewarding you for the work you've done out here." <<He>> pats your head.<br><br>
<<link [[Next|Eden Clearing]]>><<endevent>><</link>><br>
:: Clearing Mushrooms [nobr]
<<set $outside to 1>><<set $location to "cabin">><<effects>>
Though you've no doubt you'd have more luck finding mushrooms in the forest proper, there's still room for fungi to grow in the clearing. You search at the base of tree stumps and the large trees growing at the outskirts of the clearing.<br><br>
<<set $edenshrooms += 1>>
<<set $danger to random(1, 10000)>><<set $dangerevent to 0>>
<<if $danger gte (9900 - $allure)>>
<<if $rng gte 81>>
<<set $wolfbuild += 3>>
After an hour you realise you've gathered quite a haul. Eden should be happy, but you feel angry for no discernable reason. You hope all the mushrooms you gathered are safe.<br><br>
<<link [[Next|Eden Clearing]]>><</link>><br>
<<elseif $rng gte 41>>
<<set $drugged += 120>>
After an hour you realise you've gathered quite a haul. Eden should be happy, but you feel lightheaded. You hope all the mushrooms you gathered are safe.<br><br>
<<link [[Next|Eden Clearing]]>><</link>><br>
<<else>>
<<set $drunk += 120>>
After an hour you've gathered quite a haul. Eden should be happy, but you feel oddly warm. You hope all the mushrooms you gathered are safe.<br><br>
<<link [[Next|Eden Clearing]]>><</link>><br>
<</if>>
<<else>>
After an hour you realise you've gathered quite a haul. Eden should be happy.<br><br>
<<link [[Next|Eden Clearing]]>><</link>><br>
<</if>>
:: Clearing Debris [nobr]
<<set $outside to 1>><<set $location to "cabin">><<effects>>
<<if $edenspring is 0>>
You pick up the net you assume is meant for this purpose and start fishing the debris from the spring. It's so messy you don't know where to start, but you leave the spring a little clearer than you found it.
<<elseif $edenspring is 1>>
You haul out the larger branches that have sunk to the bottom of the spring.
<<elseif $edenspring is 2>>
You use the net to guide the floating branches to the edge, where you can remove them with ease.
<<else>>
You skoop up the twigs with the net. When you're done, the spring is crystal clear.
<</if>>
<<physique 3>><br><br>
<<set $edenspring += 1>>
<<link [[Next|Eden Clearing]]>><<endevent>><</link>><br>
:: Clearing Spring [nobr]
<<set $outside to 1>><<set $location to "cabin">><<effects>>
<<uppernaked>><<lowernaked>><<undernaked>>
<<if $phase lte 0>>
The cliff face curves around the spring, hiding you from the rest of the clearing. You undress and slip into the cool water. You lie back, close your eyes, and relax.<<wash>><br><br>
<<else>>
You lie back, close your eyes, and relax.<<wash>><br><br>
<</if>>
<<set $danger to random(1, 10000)>><<set $dangerevent to 0>>
<<if $danger gte (9900 - $allure) and $edenlust gte 26 and $hour lt 11 or $danger gte (9900 - $allure) and $edenlust gte 26 and $hour gt 14>>
<<eden>><<person1>>You're disturbed by a whistling. You open your eyes in alarm. Eden stands at the edge of the spring, next to your clothes. <<covered>> "I don't bother keeping this place clear any more," <<he>> says as <<he>> undresses. "It's so much work. I'm glad you feel differently though." <<He>> jumps in, splashing you.<br><br>
<<He>> emerges behind you and wraps <<his>> arms around your waist. "There's something else you can do for me." <<He>> licks your cheek.<br><br>
<<link [[Push away|Clearing Spring Push]]>><<set $edenlove -= 1>><<set $edendom -= 1>><</link>><br>
<<link [[Let Eden have you|Clearing Spring Sex]]>><<set $sexstart to 1>><<set $edenlove += 1>><<set $edendom += 1>><</link>><<promiscuous1>><br>
<<else>>
<<link [[Stay in the spring (0:30)|Clearing Spring]]>><<endevent>><<pass 30>><<stress -6>><<set $phase to 1>><</link>><<lstress>><br>
<<link [[Masturbate|Clearing Spring Masturbation]]>><<set $masturbationstart to 1>><</link>><br>
<<link [[Get out|Eden Clearing]]>><<clotheson>><</link>>
<</if>>
:: Clearing Spring Push [nobr]
<<set $outside to 1>><<set $location to "cabin">><<effects>>
You press your hand against <<his>> face and push <<him>> away.
<<if $edenlove - $edenlust gte 1>>
"You wanna be like that?" <<he>> says. "Fine. Don't forget who looks after you though. You should show more respect." <<He>> swims to the shore and climbs out. <<He>> doesn't bother dressing before walking back to the cabin.<br><br>
<<link [[Stay in the spring|Clearing Spring]]>><<endevent>><<pass 30>><<stress -6>><<set $phase to 1>><</link>><<lstress>><br>
<<link [[Get out|Eden Clearing]]>><<clotheson>><</link>>
<<else>>
<<He>> swats your arm away and pulls you into <<himstop>><br><br>
<<link [[Next|Clearing Spring Sex]]>><<set $molestationstart to 1>><</link>><br>
<</if>>
:: Clearing Spring Sex [nobr]
<<if $sexstart is 1>>
<<set $sexstart to 0>>
<<consensual>>
<<set $consensual to 1>>
<<neutral 1>>
<<set $event to "molestationhome">>
<<man1init>>
<<set $enemytrust += 100>><<set $enemyhealth to 600>><<set $enemyhealthmax to 600>>
<<promiscuity1>>
<<if $penis is "clothed">>
<<set $penis to 0>>
<</if>>
<<if $vagina is "clothed">>
<<set $vagina to 0>>
<</if>>
<<elseif $molestationstart is 1>>
<<set $molestationstart to 0>>
<<controlloss>>
<<violence 1>>
<<neutral 1>>
<<molested>>
<<set $event to "molestationhome">>
<<man1init>><<set $enemyhealth to 600>><<set $enemyhealthmax to 600>><<set $enemyanger += 50>>
<</if>>
<<effects>>
<<effectsman>><<man>>
<<stateman>><br>
<br>
<<actionsman>>
<<if $finish is 1>>
<span id="next"><<link [[Next|Clearing Spring Sex Finish]]>><</link>></span><<nexttext>>
<<elseif $enemyhealth lte 0>>
<span id="next"><<link [[Next|Clearing Spring Sex Finish]]>><</link>></span><<nexttext>>
<<elseif $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next|Clearing Spring Sex Finish]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next|Clearing Spring Sex]]>><</link>></span><<nexttext>>
<</if>>
:: Clearing Spring Sex Finish [nobr]
<<set $outside to 0>><<set $location to "cabin">><<effects>>
<<if $enemyarousal gte $enemyarousalmax>>
<<ejaculation>><<set $edenlust -= 20>>
"You're extra wet now," <<he>> laughs. <<He>> swims to the shore and climbs out. <<He>> doesn't bother dressing before walking back to the cabin.<br><br>
<<endcombat>>
<<elseif $enemyhealth lte 0>>
"You ungrateful slut," <<he>> says. "Maybe I should just fucking drown you!" <<He>> winces and holds <<his>> side. "I need to get something for this."<br><br>
<<He>> swims to the shore and climbs out. <<He>> doesn't bother dressing before stumbling back to the cabin.<br><br>
<<endcombat>>
<<elseif $finish is 1>>
"Did I interrupt your bath?" <<he>> says. "You're so cute." <<He>> swims to the shore and climbs out. <<He>> doesn't bother dressing before walking back to the cabin.<br><br>
<<endcombat>>
<</if>>
<br><br>
<<link [[Stay in the spring|Clearing Spring]]>><<endevent>><<pass 30>><<stress -6>><<set $phase to 1>><</link>><<lstress>><br>
<<link [[Get out|Eden Clearing]]>><<clotheson>><</link>>
:: Cabin Settings [nobr]
<<settings>>
<<link [[Back|Eden Cabin]]>><</link>><br>
:: Eden Mirror [nobr]
<<effects>>
<<mirror>><br><br>
<<link [[Step away|Eden Cabin]]>><</link>><br>
|
QuiltedQuail/degrees
|
game/loc-cabin.twee
|
twee
|
unknown
| 95,755 |
:: Ocean Breeze [nobr]
<<set $outside to 0>><<set $location to "town">><<effects>>
You are in the Ocean Breeze Cafe.
<<if $openinghours is 1>>
<<if $weather is "clear">>
Most of the tables are full.
<<elseif $weather is "overcast">>
The cafe is busy, and despite the strong winds some people are sitting outside.
<<elseif $weather is "rain">>
No one is sitting outside due to the rain, but the cafe proper is crowded.
<</if>>
<</if>>
<br><br>
<<if $stress gte 10000>><<passoutshop>>
<<else>>
<<if $closinghour is 1>>
It's closing time. The proprietor is herding everyone outside.<<if $exposed gte 1>>You feel a twinge of panic as you realise how exposed you'll be should you be found in this state of dress.<</if>><br><br>
<<elseif $openinghours is 0>>
You are alone in the darkness.<br><br>
<<elseif $exposed gte 1>>
You are hiding beneath a table to protect your dignity.<br><br>
<</if>>
<<if $openinghours is 1 and $exposed lt 1 and $oceanbreezejob isnot 1>>
<<if $oceanbreezejoboffer is 1>>
<<link [[Ask for work|Ocean Breeze Ask Again]]>><</link>><br>
<<else>>
<<link [[Ask for work|Ocean Breeze Ask]]>><</link>><br>
<</if>>
<</if>>
<<if $openinghours is 1 and $exposed lt 1 and $oceanbreezejob is 1>>
<<if $playergenderappearance is "m">>
<<link [[Work as a waiter (1:00)|Ocean Breeze Work]]>><<set $tablesservedstat += random(10,30)>><</link>><br>
<<else>>
<<link [[Work as a waitress (1:00)|Ocean Breeze Work]]>><<set $tablesservedstat += random(10,30)>><</link>><br>
<</if>>
<</if>>
<<if $openinghours is 0 and $closinghour isnot 1 and $oceanbreezetheft isnot 1>>
<<link [[Examine the cash register|Ocean Breeze Register]]>><</link>><br>
<</if>>
<br>
[[Leave|Cliff Street]]<br>
<br>
<</if>>
:: Ocean Breeze Lock [nobr]
<<set $outside to 0>><<effects>><<set $lock to 200>>
<<openinghours>>
<<if $skulduggery gte $lock>>
<span class="green">The lock looks easy to pick.</span><br><br>
<<link [[Pick it (0:10)|Ocean Breeze]]>><<pass 10>><<crime 1>><</link>><<crime>><br>
<<else>>
<span class="red">The lock looks beyond your ability to pick.</span><<skulduggeryrequired>><br><br>
<</if>>
<<link [[Leave|Cliff Street]]>><</link>><br>
:: Ocean Breeze Ask [nobr]
<<set $outside to 0>><<set $location to "town">><<effects>>
<<set $oceanbreezejoboffer to 1>>
<<sam>><<person1>>You walk up to the overweight <<if $pronoun is "m">>man<<else>>woman<</if>> behind the counter. <<He>> smiles at you.
"Aren't you a cutie! What will it be?"<br><br>
You ask if <<he>> has any work for you. <<His>> smile broadens. "As a matter of fact I need a cute <<if $playergenderappearance is "m">>waiter.<<else>>waitress.<</if>> The pay is £5 an hour, plus tips. Just a warning though, some customers might try to grope you. Please be patient with them, they don't mean nothing by it! We're always understaffed, so you can work whenever we're open."
<br><br>
<<link [[Take job|Ocean Breeze Take Job]]>><</link>><br>
<<link [[Refuse job|Ocean Breeze]]>><<endevent>><</link>><br>
:: Ocean Breeze Take Job [nobr]
<<set $outside to 0>><<set $location to "town">><<effects>>
<<set $oceanbreezejob to 1>>
"Splendid!" <<He>> says, grabbing your hand in both of <<his>> own and shaking. "I'm Sam, by the way. Come on, let me show you the ropes."<br><br>
<<link [[Next|Ocean Breeze]]>><<endevent>><</link>>
:: Ocean Breeze Ask Again [nobr]
<<set $outside to 0>><<set $location to "town">><<effects>>
<<sam>><<person1>>You walk up to the overweight <<if $pronoun is "m">>man<<else>>woman<</if>> behind the counter. <<He>> smiles at you.
"Welcome back! Have you reconsidered?"<br><br>
<br><br>
<<link [[Take job|Ocean Breeze Take Job]]>><</link>><br>
<<link [[Refuse job|Ocean Breeze]]>><<endevent>><</link>><br>
:: Ocean Breeze Work [nobr]
<<set $outside to 0>><<set $location to "town">><<effects>>
<<set $rng to random(1, 100)>>
<<if $rng gte 81 and $weather isnot "rain">>
<<set $danger to random(1, 10000)>><<set $dangerevent to 0>>
<<if $danger gte (9900 - $allure)>>
<<if $skirt is 1>>
As you're serving tables outside the cafe, a strong breeze blows in from the ocean, lifting your skirt and exposing your <<undies>> for anyone who looks.<<undiestrauma>><br><br>
<<if $undertype isnot "naked" and $undertype isnot "chastity">>
<<link [[Own it|Ocean Breeze Own]]>><<set $phase to 0>><</link>><<exhibitionist1>><br>
<<elseif $exhibitionism gte 35>>
<<link [[Own it|Ocean Breeze Own]]>><<set $phase to 1>><</link>><<exhibitionist3>><br>
<</if>>
<<link [[Cover yourself|Ocean Breeze Cover]]>><</link>>
<<if $undertype isnot "naked" and $undertype isnot "chastity">>
<<fameexhibitionism 5>>
<<else>>
<<fameexhibitionism 10>>
<</if>>
<<else>>
As you're serving tables outside the cafe, a strong breeze blows in from the ocean, pleasantly caressing your skin.<<lstress>><<stress -4>><br><br>
The rest of the shift passes uneventfully. You earn £5.<<set $money += 500>><<pass 1 hour>><br><br>
<<link [[Next|Ocean Breeze]]>><<endevent>><</link>>
<</if>>
<<else>>
You spend most of the shift serving the tables outside, overlooking the ocean.<br><br>
The rest of the shift passes uneventfully. You earn £5.<<set $money += 500>><<pass 1 hour>><br><br>
<<link [[Next|Ocean Breeze]]>><<endevent>><</link>>
<</if>>
<<elseif $rng gte 61>>
<<set $danger to random(1, 10000)>><<set $dangerevent to 0>>
<<if $danger gte (9900 - $allure)>>
<<generate1>><<generate2>>You serve a young pair, a <<person1>><<person>> and a <<person2>><<personstop>>
<<if $skirt is 1>>
<<if $undertype is "naked">>
As you turn to leave, the <<person1>><<person>> lifts the hem of your $lowerclothes, revealing your bare <<bottom>> to the cafe. "No underwear?" <<He>> says with incredulity. "You're a little slut, aren't you?"<<fameexhibitionism 10>><<stress 12>><<arousal 6>><<gstress>><<garousal>><br><br>
<<link [[Get angry|Ocean Breeze Angry]]>><</link>><br>
<<link [[Ignore|Ocean Breeze Ignore]]>><<trauma 6>><<stress 12>><<set $phase to 2>><</link>><<gtrauma>><<gstress>><br>
<<else>>
As you turn to leave, the <<person1>><<person>> lifts the hem of your $lowerclothes, revealing your $underclothes to the cafe. <<He>> and the <<person2>><<person>> both laugh, drawing more attention to you.<<fameexhibitionism 1>><<stress 6>><<arousal 3>><<gstress>><<garousal>><br><br>
<<link [[Get angry|Ocean Breeze Angry]]>><</link>><br>
<<link [[Ignore|Ocean Breeze Ignore]]>><<trauma 3>><<stress 6>><<set $phase to 1>><</link>><<gtrauma>><<gstress>><br>
<</if>>
<<else>>
<<if $undertype is "naked">>
As you turn to leave, the <<person1>><<person>> pulls down the back of your $lowerclothes, revealing your bare <<bottom>> to the cafe. "No underwear!" <<He>> says with incredulity. "Bet you regret that now."<<fameexhibitionism 5>><<stress 6>><<arousal 3>><<gstress>><<garousal>><br><br>
<<link [[Get angry|Ocean Breeze Angry]]>><</link>><br>
<<link [[Ignore|Ocean Breeze Ignore]]>><<trauma 3>><<stress 6>><<set $phase to 1>><</link>><<gtrauma>><<gstress>><br>
<<else>>
As you turn to leave, the <<person1>><<person>> pulls down the back of your $lowerclothes, revealing your $underclothes to the cafe.<<fameexhibitionism 1>><<stress 4>><<arousal 2>><<gstress>><<garousal>><br><br>
<<link [[Get angry|Ocean Breeze Angry]]>><</link>><br>
<<link [[Ignore|Ocean Breeze Ignore]]>><<trauma 2>><<stress 4>><<set $phase to 0>><</link>><<gtrauma>><<gstress>><br>
<</if>>
<</if>>
<<else>>
<<generate1>><<generate2>>You serve a young pair, a <<person1>><<person>> and a <<person2>><<personstop>> You think you catch the <<person1>><<person>> checking you out, but they don't say anything.<br><br>
The rest of the shift passes uneventfully. You earn £5.<<pass 1 hour>><<set $money += 500>><br><br>
<<link [[Next|Ocean Breeze]]>><<endevent>><</link>><br>
<</if>>
<<elseif $rng gte 41>>
<<set $danger to random(1, 10000)>><<set $dangerevent to 0>>
<<if $danger gte (9900 - $allure)>>
<<generate1>><<person1>> A <<person>> enters the cafe and sits alone in the corner. <<He>> keeps stealing glances at you, and when you go to take <<his>> order <<he>> asks only for a glass of water. As you turn to leave <<he>> grabs your wrist. "You don't happen to be on the menu, do you?" <<He>> smiles. "How about you and I find somewhere quiet and have some fun? I'll make it worth your while." <<He>> taps <<his>> <<if $pronoun is "m">>wallet.<<else>>purse.<</if>> <<His>> intentions are clearly lewd in nature.<br><br>
<<if $promiscuity gte 15>>
<<link [[Accept the offer|Ocean Breeze Whore]]>><<set $sexstart to 1>><</link>><<promiscuous2>><br>
<<else>>
You are not promiscuous enough to take up such an offer.<br><br>
<</if>>
<<link [[Refuse|Ocean Breeze Whore Refuse]]>><</link>>
<<else>>
<<generate1>><<person1>> A <<person>> enters the cafe and sits alone in the corner. <<He>> keeps stealing glances at you. However, <<he>> refuses to make eye contact when you take <<his>> order.<br><br>
The rest of the shift passes uneventfully. You earn £5.<<set $money += 500>><<pass 1 hour>><br><br>
<<link [[Next|Ocean Breeze]]>><<endevent>><</link>>
<</if>>
<<elseif $rng gte 21>>
<<set $danger to random(1, 10000)>><<set $dangerevent to 0>>
<<if $danger gte (9900 - $allure)>>
<<generate1>><<generate2>><<generate3>><<generate4>>
A large group enters the cafe, taking up several tables by themselves. You try to ask for their order, but a <<person1>><<person>> interrupts you. "It's my birthday today you know. How about something special?" <<He>> openly ogles your body. "Wanna climb up on the table and give us a dance?"<br><br>
<<link [[Dance for them|Ocean Breeze Dance]]>><<set $dancing to 1>><<set $audience to 4>><<set $venuemod to 2>><<set $timer to 12>><<set $dancelocation to "cafe">><</link>><<exhibitionist1>><<gstress>><<gtiredness>><br><br>
<<link [[Refuse|Ocean Breeze Dance Refuse]]>><</link>>
<<else>>
A large group enters the cafe, taking up several tables by themselves. They don't give you any trouble though.
<br><br>
The rest of the shift passes uneventfully. You earn £5.<<set $money += 500>><<pass 1 hour>><br><br>
<<link [[Next|Ocean Breeze]]>><<endevent>><</link>>
<</if>>
<<else>>
<<set $rng to random(1, 100)>>
<<if $rng gte 51 and $bestialitydisable is "f">>
Sam asks you to take some trash to the dumpster beside the cafe. Stood beside the dumpster however is a stray dog. It growls as you approach.<br><br>
<<link [[Continue regardless|Ocean Breeze Dumpster Dog]]>><<stress 12>><</link>><<gstress>><br>
<<link [[Forget your task and go back inside|Ocean Breeze Dumpster Refuse]]>><</link>>
<<else>>
<<generate1>><<generate2>>Sam asks you to take some trash to the dumpster beside the cafe. Stood beside the dumpster however are a <<person1>><<person>> and a <<person2>><<personstop>> They have a dangerous look about them.<br><br>
<<link [[Continue regardless|Ocean Breeze Dumpster]]>><<stress 12>><</link>><<gstress>><br>
<<link [[Forget your task and go back inside|Ocean Breeze Dumpster Refuse]]>><</link>>
<</if>>
<</if>>
:: Ocean Breeze Angry [nobr]
<<set $outside to 0>><<set $location to "town">><<effects>>
<<set $samlove -= 1>>
You turn on the spot and glare at the <<person1>><<personstop>> The grin falls off <<his>> face. "Just having a laugh. No need to pout." Sam looks over at you disapprovingly.<br><br>
The rest of the shift passes uneventfully. You earn £5.<<set $money += 500>><<pass 1 hour>><br><br>
<<link [[Next|Ocean Breeze]]>><<endevent>><</link>>
:: Ocean Breeze Ignore [nobr]
<<set $outside to 0>><<set $location to "town">><<effects>>
<<if $phase is 0>>
You rearrange your $lowerclothes and continue as if nothing happened.<br><br>
<<set $tipmod to 0.2>><<tipset>>
<<set $tip += 500>>
<<set $tip += 100>>
The rest of the shift passes uneventfully. Someone left you a tip.<<tipreceive>><br><br>
<<elseif $phase is 1>>
You rearrange your $lowerclothes and continue as if nothing happened.<br><br>
<<set $tipmod to 0.2>><<tipset>>
<<set $tip += 500>>
<<set $tip += 200>>
The rest of the shift passes uneventfully. Someone left you a tip.<<tipreceive>><br><br>
<<else>>
You rearrange your $lowerclothes and continue as if nothing happened, blushing at being exposed and humiliated in public like this.<br><br>
<<set $tipmod to 0.2>><<tipset>>
<<set $tip += 500>>
<<set $tip += 500>>
The rest of the shift passes uneventfully. Someone left you a tip.<<tipreceive>><br><br>
<</if>>
<<pass 1 hour>>
<<link [[Next|Ocean Breeze]]>><<endevent>><</link>>
:: Ocean Breeze Whore [nobr]
<<if $sexstart is 1>>
<<set $sexstart to 0>>
<<consensual>>
<<set $consensual to 1>>
<<neutral 1>>
<<set $event to "molestationhome">>
<<man1init>>
<<set $enemytrust += 40>>
<<set $tipmod to 2>><<tipset>>
"Meet me in the alley next to the cafe in five minutes, behind the dumpster." <<He>> leaves without looking back.<<pass 5>> You slip out while no one is looking, and find <<him>> waiting for you behind the dumpster as promised. <<He>> doesn't waste any time.<<promiscuity2>><br><br>
<</if>>
<<effects>>
<<effectsman>><<man>>
<<stateman>><br>
<br>
<<actionsman>>
<<if $enemyarousal lte $enemyarousalmax and $enemyhealth gt 0 and $alarm lte 0 and $finish is 0>>
<span id="next"><<link [[Next|Ocean Breeze Whore]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next|Ocean Breeze Whore Finish]]>><</link>></span><<nexttext>>
<</if>>
:: Ocean Breeze Whore Refuse [nobr]
<<set $outside to 0>><<set $location to "town">><<effects>>
You tell the <<person>> that this establishment doesn't serve anything not found on the menu, and leave to fetch <<his>> water. When you return, <<hes>> already gone.<br><br>
The rest of the shift passes uneventfully. You earn £5.<<set $money += 500>><<pass 1 hour>><br><br>
<<link [[Next|Ocean Breeze]]>><<endevent>><</link>>
:: Ocean Breeze Whore Finish [nobr]
<<set $outside to 0>><<set $location to "town">><<effects>>
<<if $consensual is 1>>
<<if $enemyarousal gte $enemyarousalmax>>
<<ejaculation>><<set $prostitutionstat += 1>><<fameprostitution 1>>
"Here's your pay, whore." <<He>> drops some cash on you as <<he>> leaves. <<tearful>> you hurry back inside before you're missed.<br><br>
<<tipreceive>>
<<else>>
"Fine. I hope you don't expect anything." <<He>> looks at you with disgust as <<he>> leaves. <<tearful>> you hurry back inside before you're missed.<br><br>
<</if>>
<<else>>
<<if $enemyarousal gte $enemyarousalmax>>
<<ejaculation>><<fameprostitution 1>><<set $prostitutionstat += 1>>
"Here's your pay, whore." <<He>> drops some cash on you as <<he>> leaves. <<tearful>> you hurry back inside before you're missed.<br><br>
<<tipreceive>>
<<elseif $enemyhealth lte 0>>
You manage to knock the <<person>> backwards, giving you time to escape. <<tearful>> you flee back into the cafe.<br><br>
<</if>>
<<if $alarm gte 1>>
Sam bursts through the cafe back entrance to see what the fuss is about. The <<person>> shields hides <<his>> face and darts away, pushing you to the ground. Sam helps you up and gently steers you back inside.<<famerape 1>><br><br>
<</if>>
<</if>>
<br><br>
<<clothesontowel>>
<<endcombat>>
The rest of the shift passes uneventfully. You earn £5.<<set $money += 500>><<pass 53>><br><br>
<<link [[Next|Ocean Breeze]]>><</link>>
:: Ocean Breeze Dance [nobr]
<<set $outside to 0>><<set $location to "town">><<effects>>
<<danceeffects>>
<<danceaudience>>
<<danceactions>>
<<if $danceevent is 0 and $exhibitionism lte 74 and $exposed gte 2>>
There's no way you can continue dancing while so exposed! Face reddening, you flee the scene.<br><br>
<<elseif $danceevent is 0 and $exhibitionism lte 34 and $exposed gte 1>>
There's no way you can continue dancing while so exposed! Face reddening, you flee the scene.<br><br>
<</if>>
<<if $danceevent is "finish">>
<<link [[Next|Ocean Breeze]]>><<endevent>><<clotheson>><</link>>
<<elseif $danceevent is 0>>
<<if $exposed gte 2 and $exhibitionism lte 74>>
<<link [[Flee|Ocean Breeze Dance Stop]]>><</link>>
<<elseif $exposed gte 1 and $exhibitionism lte 34>>
<<link [[Flee|Ocean Breeze Dance Stop]]>><</link>>
<<else>>
<<link [[Stop|Ocean Breeze Dance Stop]]>><</link>>
<</if>>
<</if>>
:: Ocean Breeze Dance Refuse [nobr]
<<set $outside to 0>><<set $location to "town">><<effects>>
The rest of the shift passes uneventfully. You earn £5.<<set $money += 500>><<pass 1 hour>><br><br>
<<link [[Next|Ocean Breeze]]>><<endevent>><</link>>
:: Ocean Breeze Dance Stop [nobr]
<<set $outside to 0>><<set $location to "town">><<effects>>
You rush to a back room, out of sight. <<clotheson>> The rest of the shift passes uneventfully, though many of the patrons who saw you dance throw glances your way.<br><br>
You earn £5.<<set $money += 500>>
<<if $timer is 12>>
<<pass 60>>
<<elseif $timer is 11>>
<<pass 55>>
<<elseif $timer is 10>>
<<pass 50>>
<<elseif $timer is 9>>
<<pass 45>>
<<elseif $timer is 8>>
<<pass 40>>
<<elseif $timer is 7>>
<<pass 35>>
<<elseif $timer is 6>>
<<pass 30>>
<<elseif $timer is 5>>
<<pass 25>>
<<elseif $timer is 4>>
<<pass 20>>
<<elseif $timer is 3>>
<<pass 15>>
<<elseif $timer is 2>>
<<pass 10>>
<<elseif $timer is 1>>
<<pass 5>>
<</if>>
<br><br>
<<clothesontowel>>
<<link [[Next|Ocean Breeze]]>><<endevent>><</link>>
:: Ocean Breeze Dumpster [nobr]
<<set $outside to 0>><<set $location to "town">><<effects>>
<<set $danger to random(1, 10000)>><<set $dangerevent to 0>>
<<if $danger gte (9900 - $allure)>><<set $outside to 1>>
You decide you're being paranoid, and walk over to the dumpster. As you turn to leave however, you find the pair blocking your path. The <<person1>><<person>> grabs your arms and covers your mouth, while the <<person2>><<person>> grins at you. "Such a pretty little thing."<br><br>
<<link [[Next|Ocean Breeze Rape]]>><<set $molestationstart to 1>><</link>><br>
<<else>>
You decide you're being paranoid, and walk over to the dumpster. The pair check you out as you walk by, but don't say anything.<br><br>
The rest of the shift passes uneventfully. You earn £5.<<set $money += 500>><<pass 1 hour>><br><br>
<<link [[Next|Ocean Breeze]]>><<endevent>><</link>>
<</if>>
:: Ocean Breeze Dumpster Refuse [nobr]
<<set $outside to 0>><<set $location to "town">><<effects>>
<<endevent>>
<<sam>><<person1>>You decide not to risk it and go back inside. Sams says <<he>> understands, but doesn't look happy.<<set $samlove -= 1>><br><br>
The rest of the shift passes uneventfully. You earn £5.<<set $money += 500>><<pass 1 hour>><br><br>
<<link [[Next|Ocean Breeze]]>><<endevent>><</link>>
:: Ocean Breeze Rape [nobr]
<<if $molestationstart is 1>>
<<set $molestationstart to 0>>
<<controlloss>>
<<violence 1>>
<<neutral 1>>
<<molested>>
<<set $event to "molestationhome">>
<<set $rescue to 1>>
<<man2init>>
<<set $leftarm to "grappled">><<set $rightarm to "grappled">><<set $mouthuse to "lefthand">><<set $lefthand to "mouth">><<set $righthand to "arms">>
<</if>>
<<effects>>
<<effectsman>><<man>>
<<stateman>><br>
<br>
<<actionsman>>
<<if $enemyarousal lte $enemyarousalmax and $enemyhealth gt 0 and $alarm lte 0>>
<span id="next"><<link [[Next|Ocean Breeze Rape]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next|Ocean Breeze Rape Finish]]>><</link>></span><<nexttext>>
<</if>>
:: Ocean Breeze Rape Finish [nobr]
<<set $outside to 0>><<set $location to "town">><<effects>>
<<if $enemyarousal gte $enemyarousalmax>>
<<ejaculation>>
Satisfied, the pair leave you be. <<tearful>> you hurry back inside before you're missed.<br><br>
<<elseif $enemyhealth lte 0>>
You manage to knock the pair against the dumpster, giving you time to escape. <<tearful>> you flee back into the cafe.<br><br>
<<elseif $alarm gte 1>>
Sam bursts through the cafe back entrance to see what the fuss is about. The pair flee the scene, pushing you to the ground as they do. Sam helps you up and gently steers you back inside.<<set $rescued += 1>><<famerape 1>><br><br>
<</if>>
<<clothesontowel>>
<<endcombat>>
The rest of the shift passes uneventfully. You earn £5.<<set $money += 500>><<pass 53>><br><br>
<<link [[Next|Ocean Breeze]]>><</link>>
:: Ocean Breeze Dumpster Dog [nobr]
<<set $outside to 0>><<set $location to "town">><<effects>>
<<set $danger to random(1, 10000)>><<set $dangerevent to 0>>
<<if $danger gte (9900 - $allure)>><<set $outside to 1>>
You decide you're being paranoid, and walk over to the dumpster. As you turn to leave however, the dog blocks your path.<br><br>
<<link [[Next|Ocean Breeze Dog Rape]]>><<set $molestationstart to 1>><</link>><br>
<<else>>
You decide you're being paranoid, and walk over to the dumpster. The dog runs away as you draw closer.<br><br>
The rest of the shift passes uneventfully. You earn £5.<<set $money += 500>><<pass 1 hour>><br><br>
<<link [[Next|Ocean Breeze]]>><<endevent>><</link>>
<</if>>
:: Ocean Breeze Dog Rape [nobr]
<<if $molestationstart is 1>>
<<set $molestationstart to 0>>
<<controlloss>>
<<violence 1>>
<<neutral 1>>
<<molested>>
<<set $event to "dogpack">><<set $beasttype to "dog">>
<<set $rescue to 1>>
<<beast1init>>
<</if>>
<<effects>>
<<effectsman>><br><<beast>><br><br>
<<stateman>><br>
<br>
<<actionsman>>
<<if $alarm is 1 and $rescue is 1>>
<span id="next"><<link [[Next|Ocean Breeze Dog Rape Finish]]>><</link>></span><<nexttext>>
<<elseif $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next|Ocean Breeze Dog Rape Finish]]>><</link>></span><<nexttext>>
<<elseif $enemyhealth lte 0>>
<span id="next"><<link [[Next|Ocean Breeze Dog Rape Finish]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next|Ocean Breeze Dog Rape]]>><</link>></span><<nexttext>>
<</if>>
:: Ocean Breeze Dog Rape Finish [nobr]
<<set $outside to 0>><<set $location to "town">><<effects>>
<<if $enemyarousal gte $enemyarousalmax>>
<<beastejaculation>>
Satisfied, the dog leaves you be. <<tearful>> you head back into the cafe.<br><br>
<<elseif $enemyhealth lte 0>>
The dog yelps in pain and flees. <<tearful>> you head back into the cafe.<br><br>
<<elseif $alarm gte 1>>
Sam bursts through the cafe back entrance to see what the fuss is about. Startled, the dog flees. You feel humiliated, but Sam helps you up and gently steers you back inside.<<famebestiality 1>><<set $rescued += 1>><br><br>
<</if>>
<<clothesontowel>>
<<endcombat>>
The rest of the shift passes uneventfully. You earn £5.<<set $money += 500>><<pass 53>><br><br>
<<link [[Next|Ocean Breeze]]>><</link>>
:: Ocean Breeze Own [nobr]
<<set $outside to 0>><<set $location to "town">><<effects>>
<<if $phase is 0>>
You spin on the spot, flaring your skirt up even more and making sure everyone gets a good view before the wind dies down.<<exhibitionism1>><br><br>
<<set $tipmod to 0.2>><<tipset>>
<<set $tip += 500>>
<<set $tip += 200>>
The rest of the shift passes uneventfully. Someone left you a tip.<<tipreceive>><br><br>
<<else>>
You press down on the front of your skirt to cover your <<genitals>> but lean forward as you do, sticking your bare butt out while feigning embarrassment. <<exhibitionism3>><br><br>
<<set $tipmod to 0.2>><<tipset>>
<<set $tip += 500>>
<<set $tip += 500>>
The rest of the shift passes uneventfully. Someone left you a tip.<<tipreceive>><br><br>
<</if>>
<<link [[Next|Ocean Breeze]]>><<endevent>><<pass 1 hour>><</link>>
:: Ocean Breeze Cover [nobr]
<<set $outside to 0>><<set $location to "town">><<effects>>
Cheeks flushing, you press down on your skirt to cover your dignity before the situation worsens, and hasten back inside.<br><br>
<<if $playergenderappearance is "f" and $playergender is "m">>
As you escape into the cafe you think you hear someone say, "Was that a penis?"<br><br>
<</if>>
<<set $tipmod to 0.2>><<tipset>>
<<set $tip += 500>>
<<set $tip += 100>>
The rest of the shift passes uneventfully. Someone left you a tip.<<tipreceive>><br><br>
<<link [[Next|Ocean Breeze]]>><<endevent>><<pass 1 hour>><</link>>
|
QuiltedQuail/degrees
|
game/loc-cafe.twee
|
twee
|
unknown
| 24,263 |
:: Test [nobr]
<<set $wolfpacktrust += 50>><<eventwolfcave>>
:: Elk Compound Climb [nobr]
<<set $outside to 1>><<set $location to "town">><<effects>>
You climb the fence and haul yourself over the top, landing on Elk Street proper. You don't think anyone saw you.<br><br>
<<set $compoundalarm to 0>>
<<set $compoundpipes to 0>>
<<set $compoundsmoke to 0>>
<<set $compoundcentre to 0>>
<<set $compoundbluff to 0>>
<<link [[Next|Elk Street]]>><</link>><br>
:: Elk Compound [nobr]
<<set $outside to 1>><<set $location to "town">><<effects>>
You are in the compound on Elk Street. Three red brick buildings stand surrounded by a chain link fence. The gate is guarded by security personnel. <span class="red">You are trespassing.</span>
<br><br>
<<if $compoundstate is undefined>>
<span class="gold">You've discovered the compound on Elk Street.</span><br><br><<set $compoundstate to 0>>
<</if>>
<<if $compoundalarm gte 1>>
<<set $compoundstate to 1>>
<</if>>
<<if $compoundalarm is undefined>>
<<set $compoundalarm to 0>>
<</if>>
<<if $compoundalarm is 0>>
<span class="green">Security are relaxed.</span>
<<elseif $compoundalarm is 1>>
<span class="lblue">Security are suspicious.</span>
<<elseif $compoundalarm is 2>>
<span class="purple">Security are aware of an intruder.</span>
<<else>>
<span class="red">Security are on high alert.</span>
<</if>>
<br><br>
<<if $stress gte 10000>><<passoutcompound>>
<<else>>
<<set $danger to random(1, 10000)>><<set $dangerevent to 0>>
<<if $danger lte (3000 * $compoundalarm) and $eventskip isnot 1>>
<<if $bestialitydisable is "f" and $rng gte 51>>
A guard dog runs towards you. It stops a few feet away and starts barking.<br><br>
<<if $deviancy gte 15>>
<<link [[Calm it|Elk Compound Bestiality]]>><<set $sexstart to 1>><</link>><<deviant2>><br>
<</if>>
<<link [[Fight|Elk Compound Bestiality]]>><<set $molestationstart to 1>><</link>><br>
<<link [[Escape the compound|Elk Compound Run]]>><<crime 30>><</link>><<crime>><br>
<<else>>
A hand rests on your shoulder. <<generate1>><<person1>>"Alright <<girlcomma>> playtime's over," <<he>> waves <<his>> baton in front of your face. "I found <<phim>> outside," <<he>> says into <<his>> radio. "Alright, I'll keep <<phim>> here until then."<br><br>
<<if $compoundbluff is 1>>
<span class="pink">Bluffing isn't going to work again.</span><br>
<<else>>
<<set $skulduggerydifficulty to 600>>
<<link [[Bluff|Elk Compound Bluff]]>><</link>><<skulduggerydifficulty>><br>
<</if>>
<<link [[Fight|Elk Compound Fight]]>><<set $fightstart to 1>><</link>><br>
<<link [[Wait|Elk Compound Underground]]>><</link>><br>
<</if>>
<<else>>
<<if $compoundpipes isnot 1>>
<<link [[Investigate the building with storage tanks outside|Elk Compound Pipes]]>><</link>><br>
<</if>>
<<if $compoundsmoke isnot 1>>
<<link [[Investigate the building with smokestacks|Elk Compound Smoke]]>><</link>><br>
<</if>>
<<if $compoundcentre isnot 1>>
<<link [[Investigate the central building|Elk Compound Central]]>><</link>><br>
<</if>>
<<link [[Climb the fence to safety|Elk Compound Climb]]>><</link>><br>
<</if>>
<</if>>
<<set $eventskip to 0>>
:: Elk Compound Pipes [nobr]
<<set $outside to 0>><<set $location to "town">><<effects>>
The door to the building opens easily, and you enter. The inside is dominated by a pool of pink liquid. In the centre sits a pink crystal on a plinth, connected to the side by a thin walkway. It looks valuable.<br><br>
<<link [[Take it|Elk Compound Crystal]]>><</link>><<crime>><br>
<<link [[Leave|Elk Compound]]>><</link>><br>
:: Elk Compound Smoke [nobr]
<<set $outside to 0>><<set $location to "town">><<effects>>
The door opens easily and you enter the building. The inside is full of a sweet-smelling smoke. You can only see a few feet in front of you. The smoke makes you feel lightheaded.<br><br>
<<link [[Explore (0:10)|Elk Compound Explore]]>><<pass 10>><</link>><br>
<<link [[Leave|Elk Compound]]>><</link>><br>
:: Elk Compound Central [nobr]
<<set $outside to 1>><<set $location to "town">><<effects>><<set $lock to 300>>
The door is locked tight.<br><br>
<<if $skulduggery gte $lock>>
<span class="green">The lock looks easy to pick.</span><br><br>
<<link [[Break in (0:05)|Elk Compound Interior]]>><<pass 5>><<crime 1>><</link>><<crime>><br>
<<else>>
<span class="red">The lock looks beyond your ability to pick.</span><<skulduggeryrequired>><br><br>
<</if>>
<<link [[Leave|Elk Compound]]>><</link>><br>
:: Elk Compound Bestiality [nobr]
<<if $molestationstart is 1>>
<<set $molestationstart to 0>>
<<controlloss>>
<<violence 1>>
<<neutral 1>>
<<molested>>
<<set $event to "dogpack">>
<<beast1init>><<set $enemytrust -= 40>><<set $beasttype to "dog">><<set $enemyanger += 20>>
<<set $rescue to 1>>
<<elseif $sexstart is 1>>
<<set $sexstart to 0>>
<<consensual>>
<<set $consensual to 1>>
<<neutral 1>>
<<set $event to "dogpack">>
<<beast1init>><<set $beasttype to "dog">><<set $enemytrust -= 40>>
You drop to the floor and adopt a mating posture. The dog stops barking, but now has something else in mind.<<deviancy2>>
<<set $rescue to 1>>
<</if>>
<<effects>>
<<effectsman>><br><<beast>><br><br>
<<stateman>><br>
<br>
<<actionsman>>
<<if $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next|Elk Compound Bestiality Finish]]>><</link>></span><<nexttext>>
<<elseif $enemyhealth lte 0>>
<span id="next"><<link [[Next|Elk Compound Bestiality Finish]]>><</link>></span><<nexttext>>
<<elseif $alarm is 1>>
<span id="next"><<link [[Next|Elk Compound Bestiality Finish]]>><</link>></span><<nexttext>>
<<elseif $finish is 1>>
<span id="next"><<link [[Next|Elk Compound Bestiality Finish]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next|Elk Compound Bestiality]]>><</link>></span><<nexttext>>
<</if>>
:: Elk Compound Run [nobr]
<<set $outside to 1>><<set $location to "town">><<effects>>
<<if $physique gte $rng * 100 + 6000>>
You <span class="green">successfully</span> climb the fence and haul yourself over the top, landing on Elk Street proper. Dogs bark behind you and alert the guards who arrive in time to see you escape.<br><br>
<<set $compoundalarm to 0>>
<<set $compoundpipes to 0>>
<<set $compoundsmoke to 0>>
<<set $compoundcentre to 0>>
<<set $compoundbluff to 0>>
<<link [[Next|Elk Street]]>><</link>><br>
<<else>>
You try to run, <span class="red">but the dog chases you down.</span><br><br>
<<link [[Next|Elk Compound Bestiality]]>><<set $molestationstart to 1>><</link>><br>
<</if>>
:: Elk Compound Bestiality Finish [nobr]
<<set $outside to 1>><<set $location to "town">><<effects>>
<<if $enemyarousal gte $enemyarousalmax>>
<<beastejaculation>>
Panting, the guard dog returns to where it came from.<br><br>
<<tearful>> you rise to your feet.<br><br>
<<clotheson>>
<<endcombat>>
<<link [[Next|Elk Compound]]>><<set $eventskip to 1>><</link>><br>
<<elseif $enemyhealth lte 0>>
The beast whimpers and hides behind one of the buildings.<br><br>
<<tearful>> you rise to your feet.<br><br>
<<clotheson>>
<<endcombat>>
<<link [[Next|Elk Compound]]>><<set $eventskip to 1>><</link>><br>
<<elseif $alarm is 1 and $rescue is 1>>
<<generate1>><<generate2>><<person1>>A <<person>> and <<person2>><<person>> arrive to investigate the noise.
<<if $beaststance is "top">>
They see the dog humping you and laugh. "Good boy," the <<person1>><<person>> says.<br><br>
<<else>>
They see what the dog wants from you and laugh. "Good boy," the <<person1>><<person>> says.<br><br>
<</if>>
<<person2>>We should probably let the dog have its treat," says the <<person>> as <<he>> crouches for a closer look. <<He>> pulls out <<his>> phone and starts filming.<br><br>
<<link [[Next|Elk Compound Bestiality 2]]>><</link>><br>
<<else>>
The beast turns and darts away, barking.<<crime>><<set $compoundalarm += 1>>
<<crime 50>><br><br>
<<tearful>> you rise to your feet.<br><br>
<<clotheson>>
<<endcombat>>
<<link [[Next|Elk Compound]]>><<set $eventskip to 1>><</link>><br>
<</if>>
:: Elk Compound Bestiality 2 [nobr]
<<effects>>
<<effectsman>><br><<beast>><br><br>
The <<person2>><<person>> films you.
<<if $face is "covered">>
At least <<he>> can't see your face.
<<else>>
<<famebestiality 1>>
<</if>>
<br><br>
<<stateman>><br>
<br>
<<actionsman>>
<<if $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next|Elk Compound Bestiality 2 Finish]]>><</link>></span><<nexttext>>
<<elseif $enemyhealth lte 0>>
<span id="next"><<link [[Next|Elk Compound Bestiality 2 Finish]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next|Elk Compound Bestiality 2]]>><</link>></span><<nexttext>>
<</if>>
:: Elk Compound Bestiality 2 Finish [nobr]
<<set $outside to 1>><<set $location to "town">><<effects>>
<<if $enemyarousal gte $enemyarousalmax>>
<<beastejaculation>>
Panting, the guard dog returns to where it came from.<br><br>
The <<person1>><<person>> grabs your arm. "Alright little <<girlcomma>> you've had your fun," <<he>> says, dragging you to the gate.<br><br>
"Think we should tell them downstairs?" the <<person1>><<person>> asks.<br><br>
"Sure. You got it all on your phone didn't you? It'll make their day. This <<bitch>> just broke in for the thrill and has paid for it, we don't need to keep <<pher>> longer."
They shove you out the gate, closing it behind you.<br><br>
<<tearful>> you rise to your feet.<br><br>
<<clotheson>>
<<endcombat>>
<<set $compoundalarm to 0>>
<<set $compoundpipes to 0>>
<<set $compoundsmoke to 0>>
<<set $compoundcentre to 0>>
<<set $compoundbluff to 0>>
<<link [[Next|Elk Street]]>><<set $eventskip to 1>><</link>><br>
<<elseif $enemyhealth lte 0>>
The beast whimpers and hides behind one of the buildings.<br><br>
The <<person1>><<person>> grabs your arm. "Alright little <<girlcomma>> you've had your fun," <<he>> says, dragging you to the gate.<br><br>
"Think we should tell them downstairs?" the <<person1>><<person>> asks.<br><br>
"Sure. You got it all on your phone didn't you? It'll make their day. This <<bitch>> just broke in for the thrill and has paid for it, we don't need to keep <<pher>> any longer."
They shove you out the gate, closing it behind you.<br><br>
<<tearful>> you rise to your feet.<br><br>
<<clotheson>>
<<endcombat>>
<<set $compoundalarm to 0>>
<<set $compoundpipes to 0>>
<<set $compoundsmoke to 0>>
<<set $compoundcentre to 0>>
<<set $compoundbluff to 0>>
<<link [[Next|Elk Street]]>><<set $eventskip to 1>><</link>><br>
<</if>>
:: Elk Compound Bluff [nobr]
<<set $outside to 1>><<set $location to "town">><<effects>>
<<if $submissive gte 1150>>
"I-I-," you stammer. "I kicked my ball over the fence. I just wanted it back." You look down in mock shame.
<<elseif $submissive lte 850>>
You turn to face <<him>> and place your hands on your hips. "Excuse me?" you say. "I have every right to be here. You'll stop bothering me if you value your job."
<<else>>
"I'm delivering something," you say. "Go ask your boss."
<</if>>
<br><br>
<<if $skulduggery lte ($skulduggerydifficulty + 100)>>
<<skulduggeryskilluse>>
<<else>>
<span class="blue">That was too easy. You didn't learn anything.</span><br><br>
<</if>>
<<skulduggerycheck>>
<<if $skulduggerysuccess is 1>><<set $compoundbluff to 1>>
<<if $submissive gte 1150>>
<<He>> sighs. "Stupid <<girlcomma>> you shouldn't enter places you don't understand. Go find your ball, but then leave straight away, alright?" <span class="green">You nod and skip away.</span>
<<elseif $submissive lte 850>>
You've unnerved <<himstop>> "Wait a moment," <<he>> says. "Just let me confirm that with my supervisor." <<He>> turns away to talk into <<his>> radio. That's all you need. <span class="green">You slip away while <<his>> back is turned.</span>
<<else>>
"You really shouldn't be skulking around then," <<he>> says. "Just do your job and leave. It's not safe for you around here." <span class="green">You nod and walk away.</span>
<</if>>
<br><br>
<<endevent>>
<<link [[Next|Elk Compound]]>><<set $eventskip to 1>><</link>><br>
<<else>>
"Nice try," <<he>> says. "But you're not wriggling away." <span class="red"><<He>> grips your shoulder more tightly.</span><br><br>
<<link [[Next|Elk Compound Underground]]>><</link>><br>
<</if>>
:: Elk Compound Fight [nobr]
<<if $fightstart is 1>>
<<set $fightstart to 0>>
<<neutral 1>>
<<set $event to "molestationhome">>
<<man1init>>
<<set $enemytrust -= 100>>
<<set $enemyanger += 200>>
<<npcidlegenitals>>
You smack <<his>> hand away from you. "If that's how you want it," <<he>> says.
<br><br>
<</if>>
<<effects>>
<<effectsman>><<man>>
<<stateman>><br>
<br>
<<actionsman>>
<<if $enemyhealth lte 0>>
<span id="next"><<link [[Next|Elk Compound Fight Finish]]>><</link>></span><<nexttext>>
<<elseif $enemyarousal gte $enemyarousalmax>>
<span id="next"><<link [[Next|Elk Compound Fight Finish]]>><</link>></span><<nexttext>>
<<elseif $pain gte 100>>
<span id="next"><<link [[Next|Elk Compound Fight Finish]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next|Elk Compound Fight]]>><</link>></span><<nexttext>>
<</if>>
:: Elk Compound Underground [nobr]
<<set $outside to 1>><<set $location to "town">><<effects>>
"We won't need to wait long," the <<person1>><<person>> says. As if in answer, the door to the central building opens. A <<generate2>><<person2>><<person>> in a lab coat exits.<br><br>
"I'll take the <<girl>> from here," <<he>> says. "They want to speak to <<phim>> downstairs."<br><br>
"If you say so."<br><br>
As soon as the <<person>> touches your arm a jolt surges through you. You lose consciousness.<br><br>
<<upperruined>><<lowerruined>><<underruined>>
<<link [[Next|Elk Compound Experiment]]>><<endcombat>><</link>><br>
:: Elk Compound Fight Finish [nobr]
<<set $outside to 0>><<set $location to "town">><<effects>>
<<if $enemyarousal gte $enemyarousalmax>>
<<ejaculation>>
<<He>> leans against the wall, panting. <<tearful>> you escape into the maze of storage tanks and pipes littering the compound.<br><br>
<<clotheson>>
<<endcombat>>
<<link [[Next|Elk Compound]]>><<set $eventskip to 1>><</link>><br>
<<elseif $enemyhealth lte 0>>
<<tearful>> you shove the <<person>> into the wall and run. <<He>> tries to chase, but you lose <<him>> among the storage tanks and pipes littering the compound.<br><br>
<<clotheson>>
<<endcombat>>
<<link [[Next|Elk Compound]]>><<set $eventskip to 1>><</link>><br>
<<else>>
<<tearful>> you fall to the ground. "I didn't like that," the <<person1>><<person>> says. "But it's my job."<br><br>
<<clotheson>>
<<link [[Next|Elk Compound Underground]]>><</link>><br>
<</if>>
:: Elk Compound Experiment [nobr]
<<pass 1 hour>><<set $outside to 0>><<set $location to "town">><<effects>>
<<set $compoundalarm to 0>>
<<set $compoundpipes to 0>>
<<set $compoundsmoke to 0>>
<<set $compoundcentre to 0>>
<<set $compoundbluff to 0>>
You wake up, naked <<if $undertype is "chastity">>save for your chastity belt<</if>> and strapped to a metal board. Pipes and wires protrude from concrete walls. <<generate1>><<person1>>A <<person>> works at a console in the corner. <<He>> glances at you. "Aha," <<he>> says. "You're awake." <<He>> pushes <<himself>> towards you on <<his>> chair and produces a bundle of wires from <<his>> lab coat.<br><br>
The wires have pads on one end. <<He>> starts sticking them to your body. <<He>> goes about <<his>> work with a clinical professionalism that makes you feel less humiliated by your <<lewdness>> than you'd expect. That is until <<he>> places one on each of your nipples.<br><br>
<<if $undertype is "chastity">>
<<He>> places a whole bunch on your $underclothes. "We can turn up the frequency, this is no problem," <<he>> mutters to <<himselfstop>>
<</if>>
<<if $penisexist is 1 and $undertype isnot "chastity">>
<<He>> places one right on the tip of your <<penis>> and one on each teste. You tense at the sensation.
<</if>>
<<if $vaginaexist is 1 and $undertype isnot "chastity">>
<<He>> pushes one into your <<pussycomma>> then another. You tense at the sensation.
<</if>>
"There we go," <<he>> says, plugging the other end of the wires into a machine beside <<himstop>> "Now <<girlcomma>> tell me, who are you working for?"<br><br>
<i>If your pain or arousal max out, you'll tell <<him>> everything.</i><br><br>
<<set $compoundmock to 0>>
<<set $compoundhonest to 0>>
<<set $compoundlie to 0>>
<<set $compoundbeg to 0>>
<<set $compoundflirt to 0>>
<<compoundoptions>>
:: Elk Compound Crystal [nobr]
<<set $outside to 0>><<set $location to "town">><<effects>>
<<set $danger to random(1, 10000)>><<set $dangerevent to 0>>
<<if $danger gte (9900 - $allure) and $eventskip is 0>>
<<if $rng gte 51 and $tentacledisable is "f" and $hallucinations gte 2>>
As you cross the walkway several tentacles rise from the fluid beneath you.<br><br>
<<link [[Next|Elk Compound Tentacles]]>><<set $molestationstart to 1>><</link>><br>
<<else>>
As you cross the walkway the fluid beneath you becomes agitated. Some splashes you, eating through your clothing.<<set $upperintegrity -= 10>><<set $lowerintegrity -= 10>><br><br>
You continue to the centre and take the crystal. It's warm to the touch.<br><br>
<<set $compoundpipes to 1>>
<<set $blackmoney += 50>>
<<set $compoundalarm += 1>>
<<crime 50>>
<<link [[Next|Elk Compound]]>><</link>><br>
<</if>>
<<else>>
You cross the walkway and take the crystal. It's warm to the touch.<br><br>
<<set $compoundpipes to 1>>
<<set $blackmoney += 50>>
<<set $compoundalarm += 1>>
<<crime 50>>
<<link [[Next|Elk Compound]]>><</link>><br>
<</if>>
:: Elk Compound Tentacles [nobr]
<<if $molestationstart is 1>><<set $molestationstart to 0>>
<<set $combat to 1>>
<<set $enemytype to "tentacles">>
<<molested>>
<<controlloss>>
<<set $tentacleno to 7>>
<<set $tentaclehealth to 10>>
<<tentaclestart>>
<<set $tentacle1shaft to "waist">>
<</if>>
<<effects>>
<<effectstentacles>>
<<tentacles>>
<<statetentacles>>
<<actionstentacles>>
<<if $activetentacleno lte ($tentacleno / 2)>>
<span id="next"><<link [[Next|Elk Compound Tentacles Finish]]>><</link>></span><<nexttext>>
<<else>>
<span id="next"><<link [[Next|Elk Compound Tentacles]]>><</link>></span><<nexttext>>
<</if>>
:: Elk Compound Tentacles Finish [nobr]
<<effects>>
The creature loses interest in you, and disappears into the pink liquid. <<tearful>> you struggle to your feet and finish crossing to the crystal. It's warm to the touch.
<<clotheson>>
<<endcombat>>
<<set $compoundpipes to 1>>
<<set $blackmoney += 50>>
<<set $compoundalarm += 1>>
<<crime 50>>
<<link [[Next|Elk Compound]]>><</link>>
:: Elk Compound Explore [nobr]
<<set $outside to 0>><<set $location to "town">><<effects>>
You walk deeper into the building. The entrance is swallowed behind you. You make your way through a maze of pipes and machinery of unknown use. The smoke starts to make you feel warm.<<set $drugged += 60>><br><br>
You come to a plinth with a purple crystal sat atop it. It looks valuable.<br><br>
<<link [[Take it|Elk Compound Purple]]>><</link>><<crime>><br>
<<link [[Leave|Elk Compound]]>><</link>><br>
:: Elk Compound Purple [nobr]
<<set $outside to 0>><<set $location to "town">><<effects>>
You take the crystal. It's warm to the touch. Finding your way out is much easier than getting here.<br><br>
<<set $compoundsmoke to 1>>
<<set $blackmoney += 50>>
<<set $compoundalarm += 1>>
<<crime 50>>
<<link [[Next|Elk Compound]]>><</link>><br>
:: Elk Compound Honest [nobr]
<<set $outside to 0>><<set $location to "town">><<effects>>
<<if $compoundhonest is 1>>
"I'm not working for anyone," you say. "I'm here alone."<br><br>
<<He>> looks at a screen that you can only see the back of, then turns a dial. Soothing waves emanate from the pads attached to you, pleasuring every inch of your body. "Good. See, that wasn't so bad was it? Now then, why are you here?"<br><br>
<<elseif $compoundhonest is 2>>
"I'm here to steal things," you say. "For money."
<<He>> turns the dial again, and you are once more assailed by the soothing waves. "Now," <<he>> says. "What did you steal?"<br><br>
<<elseif $compoundhonest is 3>>
"I steal money or anything I can sell." you say.<br><br>
<<He>> turns the dial again, and you are once more assailed by the soothing waves. "Where do you sell things?"<br><br>
<<elseif $compoundhonest is 4>>
"I sell things on Harvest street," you say.<br><br>
<<He>> turns the dial again, and you are once more assailed by the soothing waves. "Who do you sell things to?" <span class="red">If you're honest again, <<he>> will have everything <<he>> needs from you.</span><br><br>
<<else>>
"I sell things to Landry," you say, ashamed.<br><br>
<</if>>
<<compoundoptions>>
:: Elk Compound Lie [nobr]
<<set $outside to 0>><<set $location to "town">><<effects>>
<<if $compoundlie is 1>>
"I work for the government," you say. "You better let me go."<br><br>
<<He>> looks at a screen you can't see. "Liar." <<He>> turns a dial on the machine and an excruciating pain surges through you. It lasts only a moment, but leaves you shaking. "I don't want to do that again. So don't lie to me."<br><br>
<<elseif $compoundlie is 2>>
"I got lost," you say. "I was just looking for a way out."<br><br>
<<He>> turns the dial once more and the pain surges through you again. "This could be so much easier for you," <<he>> says.<br><br>
<<elseif $compoundlie is 3>>
"I'm looking for my ball," <<he>> interrupts you with another surge of pain.<br><br>
"I'm not falling for that one," <<he>> says.<br><br>
<<elseif $compoundlie is 4>>
"I'm giving you the chance to let me go," you say. "Before I break out and kick your ass."<br><br>
<<He>> laughs as <<he>> turns the dial. "I don't even need to check the screen this time."
<<else>>
"You've hurt me too much," you say. "I can't remember anything."<br><br>
"That's bad news for you," <<he>> says, turning the dial. "I can be here a while."
<</if>>
<<compoundoptions>>
:: Elk Compound Mock [nobr]
<<set $outside to 0>><<set $location to "town">><<effects>>
<<if $compoundmock is 1>>
"Sure, I'll tell you everything," you say. "I'm here to spank naughty lab assistants. Unbind me so I can get to work."<br><br>
"You won't be laughing for long," <<he>> says, spinning a dial on the machine. Pain sears through you, but leaves your mind feeling clearer.<br><br>
<<elseif $compoundmock is 2>>
"You think you can hurt me with your little toy?" you say through gritted teeth. "It barely tickles."<br><br>
"Oh, then you won't mind this." <<He>> spins the dial again.<br><br>
<<elseif $compoundmock is 3>>
"I bet you tie yourself to this thing for fun," you say. "It's okay. We all have our fetishes."<br><br>
"I'm starting to think I've found yours." <<He>> spins the dial once more.<br><br>
<<elseif $compoundmock is 4>>
"I could get used to this," you say. "If the science thing doesn't work out, you could have a shining career as a kinky whore."<br><br>
"Is this thing even working?" <<he>> muses as <<he>> spins the dial again.<br><br>
<<else>>
"You like hurting <<girls>> then?" you say. "Better keep your porno stash hidden, if the police fi-"<br><br>
"Shut up," <<he>> interrupts, spinning the dial.<br><br>
<</if>>
<<compoundoptions>>
:: Elk Compound Beg [nobr]
<<set $outside to 0>><<set $location to "town">><<effects>>
<<if $compoundbeg is 1>>
"Please don't hurt me," you say.<br><br>
"If you do as I say I won't have to. Here's a little taste." <<He>> spins a dial and a wave of pleasure emanates from the pads. The feeling soothes you to the core.<br><br>
<<elseif $compoundbeg is 2>>
"I-I'm scared," you say.<br><br>
"It's okay <<girlcomma>> just give me what I ask." <<He>> spins the dial again, soothing you once more.<br><br>
<<elseif $compoundbeg is 3>>
"I didn't mean to do anything wrong," you say.<br><br>
"I know you didn't, so tell me what I want to know." <<He>> spins the dial.<br><br>
<<elseif $compoundbeg is 4>>
"Let me go, please," you say.<br><br>
"Cooperate and I will." <<He>> spins the dial.<br><br>
<<else>>
"Please just let me go," you say.<br><br>
"For the last time, cooperate and I will." <<He>> spins the dial.<br><br>
<</if>>
<<compoundoptions>>
:: Elk Compound Flirt [nobr]
<<set $outside to 0>><<set $location to "town">><<effects>>
<<if $compoundflirt is 1>>
"You have me all tied up and exposed," you say. "Isn't there something else you'd rather do to me?"<<promiscuity1>><br><br>
<<He>> blushes, unsure how to respond. "D-don't joke around like that. You're in big trouble." You control your breathing and focus.<br><br>
<<elseif $compoundflirt is 2>>
"Some people would pay good money for the treatment you're giving me," you say. "I should thank you properly."<<promiscuity2>><br><br>
<<He>> shifts uncomfortably. "Don't think you can sweet talk me. It won't work."<br><br>
<<elseif $compoundflirt is 3>>
"The real torture here," you say. "Is being denied your touch."<<promiscuity3>><br><br>
<<He>> moves <<his>> hand away from the dials and rubs <<his>> temple. "Just stop it will you?"<br><br>
<<elseif $compoundflirt is 4>>
"You're such a tease. I can't wait to see what you want for the main course." You wink.<br><br>
"This is the main course," <<he>> says, blushing. "Where did you learn to talk like this?"<br><br>
<<else>>
"I'm getting too hot here," you say. "Please help me. I'm at your mercy. Your fingers, your tongue, your..."<br><br>
"Stop! Right now." <<He>> seems serious.<br><br>
<</if>>
<<compoundoptions>>
:: Elk Compound Interior [nobr]
<<set $outside to 0>><<set $location to "town">><<effects>>
You successfully pick the lock and enter the building.<<set $compoundcentre to 1>><<set $compoundalarm += 1>>
<<if $skulduggery lt 400>>
<<skulduggeryskilluse>>
<<else>>
<span class="blue">There's nothing more you can learn from locks this simple.</span>
<</if>>
<br><br>
The inside is dominated by a large lift. You see no way to operate it, but a laptop sits on a table in the corner.<br><br>
<<link [[Take it and leave|Elk Compound]]>><<set $blackmoney += 100>><<crime 100>><</link>><<crime>><br>
<<link [[Leave|Elk Compound]]>><</link>><br>
|
QuiltedQuail/degrees
|
game/loc-compound.twee
|
twee
|
unknown
| 26,237 |
Subsets and Splits
No community queries yet
The top public SQL queries from the community will appear here once available.